Uses of Class
com.pervasive.datarush.operators.AbstractLogicalOperator
-
Packages that use AbstractLogicalOperator Package Description com.actian.dataflow.operators.io.orc com.actian.dataflow.operators.io.parquet com.pervasive.datarush.analytics.arm Provides common classes for Association Rule Mining (ARM).com.pervasive.datarush.analytics.arm.fpgrowth Provides the operator to perform the FP-growth ARM algorithm.com.pervasive.datarush.analytics.cleansing Provides operators related to data cleansing.com.pervasive.datarush.analytics.cluster Provides base PMML for clustering models.com.pervasive.datarush.analytics.cluster.kmeans Provides the KMeans algorithm.com.pervasive.datarush.analytics.decisiontree.learner Provides the PMML learner operator and associated classes.com.pervasive.datarush.analytics.decisiontree.predictor Provides the decision tree predictor operator and associated classes.com.pervasive.datarush.analytics.decisiontree.pruner Provides the decision tree pruner operator and associated classes.com.pervasive.datarush.analytics.knn Provides an implementation of the KNN algorithm using DataRush's sparse data API.com.pervasive.datarush.analytics.naivebayes.learner Provides an implementation of the Naive Bayes learner.com.pervasive.datarush.analytics.naivebayes.predictor Provides an implementation of a Naive Bayes predictor.com.pervasive.datarush.analytics.pmml Provides shared and base classes for PMML model representation of Analytics algorithms.com.pervasive.datarush.analytics.r com.pervasive.datarush.analytics.regression Provides utility, PMML and other classes for shared use by regression related entities.com.pervasive.datarush.analytics.stats Provides various statistics, Data Summarizer, and Data Quality Analyzer.com.pervasive.datarush.analytics.svm.predictor Provides an implementation of an SVM predictor.com.pervasive.datarush.analytics.text Provides various unstructured text processing operators.com.pervasive.datarush.analytics.util Provides some (internal) utility classes for Analytics.com.pervasive.datarush.analytics.viz Provides operators for classifier performance visualization.com.pervasive.datarush.hbase com.pervasive.datarush.matching Provides operators for performing discovering duplicates or links between records.com.pervasive.datarush.matching.block Provides operators for generating possible candidate pairs.com.pervasive.datarush.matching.cluster Provides operators for clustering the results of duplicate or linkage discovery.com.pervasive.datarush.matching.tune Provides operators for analyzing data for approximate matching.com.pervasive.datarush.operators Provides classes and interfaces for developing dataflow operators.com.pervasive.datarush.operators.assertion Provides operators for making assertions on flows and files.com.pervasive.datarush.operators.group Provides data aggregation components.com.pervasive.datarush.operators.io Provides base file I/O components including encoders and decoders.com.pervasive.datarush.operators.io.avro Provides operators for reading and writing files in Avro format.com.pervasive.datarush.operators.io.binary com.pervasive.datarush.operators.io.jdbc Provides operators for reading from JDBC sources and writing to JDBC targets.com.pervasive.datarush.operators.io.mdf com.pervasive.datarush.operators.io.staging Provides operators for reading and writing DataRush staging datasets.com.pervasive.datarush.operators.io.textfile Provides operators for reading and writing text data.com.pervasive.datarush.operators.io.vectorwise com.pervasive.datarush.operators.io.vectorwise.dl com.pervasive.datarush.operators.join Provides operators for joining together two data sets into a single one.com.pervasive.datarush.operators.model Provides operators for handling models.com.pervasive.datarush.operators.partition Provides operators for partitioning and unpartitioning flows of data.com.pervasive.datarush.operators.record Provides operators for manipulating record structure.com.pervasive.datarush.operators.scripting Provides theRunScriptoperator for running user-defined scripts on the rows of an input record flow.com.pervasive.datarush.operators.select Provides operators for selecting a subset of the data set.com.pervasive.datarush.operators.sink Provides theLogRowsoperator for writing debugging information about a flow to the logging API.com.pervasive.datarush.operators.sort Provides operators for sorting and manipulating sorted flows.com.pervasive.datarush.operators.source Provides operators for generating data tokens in various ways.com.pervasive.datarush.operators.string Provides operators for operating on string values in records.com.pervasive.datarush.operators.testutils com.pervasive.datarush.ports.record Provides implementations of port objects related to the flow of record sets between operators.com.pervasive.datarush.script.operators.group -
-
Uses of AbstractLogicalOperator in com.actian.dataflow.operators.io.orc
Subclasses of AbstractLogicalOperator in com.actian.dataflow.operators.io.orc Modifier and Type Class Description classReadORCclassWriteORCWrite data in the Apache Hive ORC format. -
Uses of AbstractLogicalOperator in com.actian.dataflow.operators.io.parquet
Subclasses of AbstractLogicalOperator in com.actian.dataflow.operators.io.parquet Modifier and Type Class Description classReadParquetReads data previously written using Apache Parquet format by Apache Hive. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.arm
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.arm Modifier and Type Class Description classConvertARMModelAn operator that converts an association model in PMML into a target format.classFrequentItemsCompute the frequent items within the given transactions. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.arm.fpgrowth
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.arm.fpgrowth Modifier and Type Class Description classFPGrowthAn operator that implements the FP-growth algorithm, outputting a PMML model containing generated items sets and association rules. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.cleansing
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.cleansing Modifier and Type Class Description classReplaceMissingValuesReplace missing values in the input data according to the given replacement specifications. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.cluster
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.cluster Modifier and Type Class Description classClusterPredictorAssigns input data to clusters based on the provided PMML Clustering Model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.cluster.kmeans
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.cluster.kmeans Modifier and Type Class Description classKMeansComputes clustering model for the given input based on the k-Means algorithm. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.learner
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.learner Modifier and Type Class Description classDecisionTreeLearnerOperator responsible for constructing a Decision Tree. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.predictor
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.predictor Modifier and Type Class Description classDecisionTreePredictorOperator responsible for predicting outcomes based on a Decision Tree PMML model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.pruner
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.pruner Modifier and Type Class Description classDecisionTreePrunerPerforms pruning of the provided input model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.knn
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.knn Modifier and Type Class Description classKNNClassifierApplies the K-nearest neighbor algorithm to classify input data against an already classified set of example data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.naivebayes.learner
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.naivebayes.learner Modifier and Type Class Description classNaiveBayesLearnerOperator responsible for building a Naive Bayes PMML model from input data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.naivebayes.predictor
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.naivebayes.predictor Modifier and Type Class Description classNaiveBayesPredictorOperator responsible for predicting outcomes based on a Naive Bayes PMML model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.pmml
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.pmml Modifier and Type Class Description classGetPMMLclassPutPMMLclassReadPMMLReads a PMML model object from a file.classWritePMMLWrite a PMML object representation to a file at the given path. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.r
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.r Modifier and Type Class Description classRunRScriptExecute an R script in flow. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.regression
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.regression Modifier and Type Class Description classLinearRegressionLearnerPerforms a multivariate linear regression on the given training data.classLogisticRegressionLearnerFits a multinomial logistic regression model to the training data.classLogisticRegressionPredictorclassRegressionPredictorApply a regression model to the input data.classSumOfSquaresCompute the sum of squares for the given fields of the input data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.stats
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.stats Modifier and Type Class Description classCountRangesDetermines which range each value in a field falls within and counts the totals.classDataQualityAnalyzerEvaluates a set of quality tests on an input dataset.classDistinctValuesCalculates distinct values of the given input field.classMostFrequentValuesCompute the most frequent values within the given fields.classNormalizeValuesApply normalization methods to fields within an input data flow.classRankRank data using the given rank mode.classSummaryStatisticsDiscovers various metrics of an input dataset, based on the configured detail level. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.svm.predictor
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.svm.predictor Modifier and Type Class Description classSVMPredictorOperator responsible for classification based on a SVM PMML model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.text
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.text Modifier and Type Class Description classCalculateNGramFrequencyCalculates the n-gram frequencies for a tokenized text field.classCalculateWordFrequencyCalculates the word frequencies for a tokenized text field.classConvertTextCaseConverts the case on a TokenizedText field.classCountTokensCounts the number of tokens in a tokenized text field.classDictionaryFilterFilters a tokenized text field using a dictionary.classExpandTextFrequencyExpands text frequency field.classExpandTextTokensExpands a TokenizedText field.classFilterTextFilters a tokenized text field.classGenerateBagOfWordsCalculates the bag of words for a tokenized text field.classTextFrequencyFilterFilters a frequency map field.classTextStemmerStems a TokenizedText field.classTextTokenizerTokenizes a string field as a TokenizedText object. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.util
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.util Modifier and Type Class Description classAbstractPredictorCommon base class for "predictor" processes. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.viz
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.viz Modifier and Type Class Description classDrawDiagnosticsChartThis operator takes the output of one or multiple predictors and uses the confidence values produced by these predictors along with the actual target values ("true class") to produce diagnostic charts. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.hbase
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.hbase Modifier and Type Class Description classDeleteHBaseWrite delete markers to HBaseclassKeyOperatorSpecifies key field mapping when accessing HBase.classKeyValueOperatorSpecifies data field mapping when accessing HBase.classReadHBaseRead a result set from HBase.classWriteHBaseWrite a result set to HBase. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.matching
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.matching Modifier and Type Class Description classDiscoverDuplicatesDiscover duplicate records within a single source using fuzzy matching operators.classDiscoverLinksUse fuzzy matching operators to discover linked records from two data sources. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.matching.block
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.matching.block Modifier and Type Class Description classBlockCartesianBlock the input data by creating a cartesian product of the data.classBlockRecordsBlock records into groups of like records based on a set of key fields and generate record pairs from these groups.classBlockSelfBlock records from a single source into groups of like records based on a set of key fields and generate record pairs from these groups.classGroupPairsSortedRowsFinds key groupings within the input key fields and, for each key group, generates all pairwise combinations of distinct rows in that group.classLargeGroupDetectorAn operator that issues warnings if a dataflow contains an unusually large number of distinct key values. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.matching.cluster
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.matching.cluster Modifier and Type Class Description classClusterDuplicatesTransform record pairs into clusters of like records, where the two sides of the pair are from the same source.classClusterLinksTransform record pairs into clusters of like records. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.matching.tune
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.matching.tune Modifier and Type Class Description classAnalyzeDuplicateKeysProvides an analysis of the quality of a set of blocking keys over data to be deduplicated.classAnalyzeLinkKeysProvides an analysis of the quality of a set of blocking keys over two data sets to be linked. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators Modifier and Type Class Description classAbstractDeferredRecordOperatorConvenient base class forDeferredCompositeOperator's that are alsoRecordPipelineOperator's.classAbstractExecutableRecordPipelineA base class for simple record-to-record operators, providing common functions.classAbstractRecordCompositeOperatorConvenient base class forCompositeOperator's that are alsoRecordPipelineOperator's.classCompositeOperatorTo be implemented by operators that can be defined by chaining together other operations.classDeferredCompositeOperatorFor rare use cases; implementors should useCompositeOperatorwhenever possible!classExecutableOperatorExecutableOperators are the most commonly used operators.classIterativeOperatorTo be implemented by operations that must make multiple passes over the input data.classOpenCompositeA composite operator that can be externally composed.classOpenModelSink<T>A model sink that can be externally composed.classOpenModelSource<T>A model source that can be externally composed.classOpenMultiModelSink<T>A model sink that can be externally composed.classOpenMultiModelSource<T>A model source that can be externally composed.classOpenMultiRecordSinkA record sink that can be externally composed.classOpenMultiRecordSourceA record source that can be externally composed.classOpenRecordSinkA record sink that can be externally composed.classOpenRecordSourceA record source that can be externally composed.classStreamingOperatorBase class for LogicalOperators that are a potentially streaming operation.Methods in com.pervasive.datarush.operators that return AbstractLogicalOperator Modifier and Type Method Description AbstractLogicalOperatorOperatorProxies.OperatorProxy. getTarget()Public only as a matter of implementation; not intended for external useMethods in com.pervasive.datarush.operators with parameters of type AbstractLogicalOperator Modifier and Type Method Description static OperatorProxies.OperatorProxyOperatorProxies. proxy(AbstractLogicalOperator op)Public only as a matter of implementation; not intended for external use Creates a proxy to the given operator that allows the framework to access its protected methods. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.assertion
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.assertion Modifier and Type Class Description classAssertEqualVerifies that actual rows are equal to expected rows.classAssertEqualHashVerifies that actual rows are equal to expected rows without regard to order.classAssertEqualRecordTypeAssert that the given type and the type of the input port are equal.classAssertEqualTypesAsserts that two input flows have identical types.classAssertMetadataAssert that the metadata on the input port is set correctly.classAssertPredicateAssert that the given predicate is true for all input values.classAssertRowCountVerifies that the input flow contains the specified row count.classAssertSortedVerifies that the input data is sorted by the given set of keys. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.group
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.group Modifier and Type Class Description classGroupPerforms grouping (aggregation) of sorted input data.classRemoveDuplicatesRemoves duplicate rows based on a specified set of group keys.classSortedGroupHandlerCommon base class for all processes that need to detect group boundaries -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io Modifier and Type Class Description classAbstractReaderA generic reader of byte data representing a stream of records.classAbstractWriterA generic writer of byte data representing a stream of records.classReadSourceReads a data source as a stream of records.classWriteSinkWrites a stream of records to a data sink. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.avro
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.avro Modifier and Type Class Description classReadAvroReads data previously written using Apache Avro format.classWriteAvroWrites data using Apache Avro format. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.binary
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.binary Modifier and Type Class Description classBinaryWriterWrites raw binary data to a filesystem. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.jdbc
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.jdbc Modifier and Type Class Description classAbstractWriteToJDBCAbstract implementation of a JDBC writer.protected static classAbstractWriteToJDBC.AbstractWriteToJDBCWorkerclassDeleteFromJDBCThis operator deletes data in the target table in a database by applying SQL delete statements.classFinalizeSQLWorkerclassInitializeSQLWorkerclassJDBCOperatorCommon base class forReadFromJDBCandAbstractWriteToJDBC.classReadFromJDBCTheReadFromJDBCoperator is used to access relational database systems using a supplied JDBC driver.classUpdateInJDBCThis operator updates the target table in a database by applying SQL update statements.classWriteToJDBCIn its simplest form, writes records from an input port to a JDBC target table using insert statements. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.mdf
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.mdf Modifier and Type Class Description classReadMDFReads data previously written using MDF format. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.staging
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.staging Modifier and Type Class Description classForceRecordStagingForces staging of record ports.classForceStaging<P extends LogicalPort>Forces the operators on the input and output sides to execute sequentially, instead of concurrently.classReadStagingDatasetReads a sequence of records previously staged to disk.classWriteStagingDatasetWrites a sequence of records to disk in an internal format for staged data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.textfile
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.textfile Modifier and Type Class Description classAbstractTextReaderA generic reader of text data representing a stream of records.classAbstractTextWriterA generic writer of text data representing a stream of records.classParseTextFieldsParses input text records according to a specified text schema.classReadARFFRead files in the Attribute-Relation File Format (ARFF).classReadDelimitedTextReads a text file of delimited records as record tokens.classReadFixedTextReads a text file of fixed-width records as record tokens.classReadJSONThe ReadJSON operator reads a JSON file of key-value pairs or array of objects as record tokens.classReadLogReads a log file as record tokens.classWriteARFFWrite files using the Attribute-Relation File Format (ARFF).classWriteDelimitedTextWrites a stream of records as delimited text.classWriteFixedTextWrites a record dataflow as a text file of fixed-width records. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.vectorwise
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.vectorwise Modifier and Type Class Description classLoadActianVectorBulk load data into the Actian Vector database.classLoadVectorOnHadoopDeprecated.this operator has been replaced withLoadActianVector; use that operator instead. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.vectorwise.dl
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.vectorwise.dl Modifier and Type Class Description classLoadVectorOnHadoopDirectDeprecated.this operator has been replaced withLoadActianVector; use that operator instead. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.join
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.join Modifier and Type Class Description classAbstractRelationalJoinCommon base class for the various types of join that we support.classCrossJoinProduce the cartesian product of two sets of records.classFilterExistingRowsFilters records on the left based on the presence of matching records on the right.classFilterExistJoinProcessclassJoinPerforms a relational equi-join on two input datasets by a specified set of keys.classSemiJoinDeprecated.this operator has been replaced withFilterExistingRows; use that operator instead, linking to the appropriate output port.classUnionAllProvides a union of two data sources. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.model
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.model Modifier and Type Class Description classGetModel<T>Provides a way to update an in-memory reference to a model object.classMergeModel<T>This operator is uses to force a merge of a partitioned model into a single model.classPutModel<T>Provides a way to inject an in-memory reference to a model object into a graph. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.partition
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.partition Modifier and Type Class Description classGatherHintForces parallel streams of data to be gathered into a single non-parallel stream.classPartitionHintForces the input data to be partitioned into parallel streams of data for subsequent parallel operations.classRandomizeOperator that re-orders its input in a random fashion. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.record
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.record Modifier and Type Class Description classColumnsToRowsNormalize records by transposing values from row columns into multiple rows.classDeriveFieldsApplies one or more functions to the input record data.classDiscoverDomainUtility operator for discovering the domain of string fields.classFilterFieldsBase class for operators which filter fields in the input records.classMergeFieldsMerges two streams of data with an equivalent number of rows into one.classRemapFieldsRearranges and renames fields in a record.classRemoveFieldsRemoves a subset of fields from the input records.classRetainFieldsPreserves a subset of fields from the input records.classRowsToColumnsThe RowsToColumns operator is used to pivot data from a narrow representation (rows) into a wider representation (columns).classSelectFieldsPreserves a subset of fields from the input records. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.scripting
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.scripting Modifier and Type Class Description classRunJavaScriptProcesses rows using user-defined scripts written in JavaScript.classRunScriptProcesses rows using user-defined scripts. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.select
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.select Modifier and Type Class Description classFilterRowsFilters records based on a specified predicate.classLimitRowsTruncates a flow to a fixed number of records.classSampleRandomRowsApply random sampling to the input data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.sink
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.sink Modifier and Type Class Description classCollectRecordsCollects input data into an in-memory token list.classLogRowsLog information about the input data from a flow. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.sort
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.sort Modifier and Type Class Description classSortSorts the input data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.source
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.source Modifier and Type Class Description classEmitRecordsEmits an in-memory token list as output.classGenerateArithmeticSequenceGenerates a sequence of numerical values, with a constant difference between consecutive values.classGenerateConstantGenerates copies of a constant value.classGenerateRandomGenerates rows of random data.classGenerateRepeatingCycleGenerates a cycle of repeating values. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.string
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.string Modifier and Type Class Description classSplitFieldSplits a string field into multiple fields, based on a specified pattern. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.testutils
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.testutils Modifier and Type Class Description classDumpPartitionsFor test purposes--sorts inputs and writes to a fileclassErrorSinkA record source sink throws an error either at composition time or execution time.classErrorSourceA record source that throws an error either at composition time or execution time.classSimulatePartitionsFor tests that wish to simulate a partitioned read. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.ports.record
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.ports.record Modifier and Type Class Description classExternalRecordSinkDefines an external sink of record data.classExternalRecordSourceDefines an external source of record data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.script.operators.group
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.script.operators.group Modifier and Type Class Description classProcessByGroupExecutes an application graph for each distinct key group of data within the input data set.
-