Uses of Interface
com.pervasive.datarush.operators.LogicalOperator
-
Packages that use LogicalOperator 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.graphs Provides classes and interfaces for the construction of executable dataflow graphs.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 theRunScript
operator 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 theLogRows
operator 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 Provides classes and interfaces related to receiving and sending data in a dataflow graph.com.pervasive.datarush.ports.model Provides implementations of port objects dealing with the flow of single objects between operators.com.pervasive.datarush.ports.record Provides implementations of port objects related to the flow of record sets between operators.com.pervasive.datarush.script com.pervasive.datarush.script.operators.group -
-
Uses of LogicalOperator in com.actian.dataflow.operators.io.orc
Classes in com.actian.dataflow.operators.io.orc that implement LogicalOperator Modifier and Type Class Description class
ReadORC
class
WriteORC
Write data in the Apache Hive ORC format. -
Uses of LogicalOperator in com.actian.dataflow.operators.io.parquet
Classes in com.actian.dataflow.operators.io.parquet that implement LogicalOperator Modifier and Type Class Description class
ReadParquet
Reads data previously written using Apache Parquet format by Apache Hive. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.arm
Classes in com.pervasive.datarush.analytics.arm that implement LogicalOperator Modifier and Type Class Description class
ConvertARMModel
An operator that converts an association model in PMML into a target format.class
FrequentItems
Compute the frequent items within the given transactions. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.arm.fpgrowth
Classes in com.pervasive.datarush.analytics.arm.fpgrowth that implement LogicalOperator Modifier and Type Class Description class
FPGrowth
An operator that implements the FP-growth algorithm, outputting a PMML model containing generated items sets and association rules. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.cleansing
Classes in com.pervasive.datarush.analytics.cleansing that implement LogicalOperator Modifier and Type Class Description class
ReplaceMissingValues
Replace missing values in the input data according to the given replacement specifications. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.cluster
Classes in com.pervasive.datarush.analytics.cluster that implement LogicalOperator Modifier and Type Class Description class
ClusterPredictor
Assigns input data to clusters based on the provided PMML Clustering Model. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.cluster.kmeans
Classes in com.pervasive.datarush.analytics.cluster.kmeans that implement LogicalOperator Modifier and Type Class Description class
KMeans
Computes clustering model for the given input based on the k-Means algorithm. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.decisiontree.learner
Classes in com.pervasive.datarush.analytics.decisiontree.learner that implement LogicalOperator Modifier and Type Class Description class
DecisionTreeLearner
Operator responsible for constructing a Decision Tree. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.decisiontree.predictor
Classes in com.pervasive.datarush.analytics.decisiontree.predictor that implement LogicalOperator Modifier and Type Class Description class
DecisionTreePredictor
Operator responsible for predicting outcomes based on a Decision Tree PMML model. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.decisiontree.pruner
Classes in com.pervasive.datarush.analytics.decisiontree.pruner that implement LogicalOperator Modifier and Type Class Description class
DecisionTreePruner
Performs pruning of the provided input model. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.knn
Classes in com.pervasive.datarush.analytics.knn that implement LogicalOperator Modifier and Type Class Description class
KNNClassifier
Applies the K-nearest neighbor algorithm to classify input data against an already classified set of example data. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.naivebayes.learner
Classes in com.pervasive.datarush.analytics.naivebayes.learner that implement LogicalOperator Modifier and Type Class Description class
NaiveBayesLearner
Operator responsible for building a Naive Bayes PMML model from input data. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.naivebayes.predictor
Classes in com.pervasive.datarush.analytics.naivebayes.predictor that implement LogicalOperator Modifier and Type Class Description class
NaiveBayesPredictor
Operator responsible for predicting outcomes based on a Naive Bayes PMML model. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.pmml
Classes in com.pervasive.datarush.analytics.pmml that implement LogicalOperator Modifier and Type Class Description class
GetPMML
class
PutPMML
class
ReadPMML
Reads a PMML model object from a file.class
WritePMML
Write a PMML object representation to a file at the given path. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.r
Classes in com.pervasive.datarush.analytics.r that implement LogicalOperator Modifier and Type Class Description class
RunRScript
Execute an R script in flow. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.regression
Classes in com.pervasive.datarush.analytics.regression that implement LogicalOperator Modifier and Type Class Description class
LinearRegressionLearner
Performs a multivariate linear regression on the given training data.class
LogisticRegressionLearner
Fits a multinomial logistic regression model to the training data.class
LogisticRegressionPredictor
class
RegressionPredictor
Apply a regression model to the input data.class
SumOfSquares
Compute the sum of squares for the given fields of the input data. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.stats
Classes in com.pervasive.datarush.analytics.stats that implement LogicalOperator Modifier and Type Class Description class
CountRanges
Determines which range each value in a field falls within and counts the totals.class
DataQualityAnalyzer
Evaluates a set of quality tests on an input dataset.class
DistinctValues
Calculates distinct values of the given input field.class
MostFrequentValues
Compute the most frequent values within the given fields.class
NormalizeValues
Apply normalization methods to fields within an input data flow.class
Rank
Rank data using the given rank mode.class
SummaryStatistics
Discovers various metrics of an input dataset, based on the configured detail level. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.svm.predictor
Classes in com.pervasive.datarush.analytics.svm.predictor that implement LogicalOperator Modifier and Type Class Description class
SVMPredictor
Operator responsible for classification based on a SVM PMML model. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.text
Classes in com.pervasive.datarush.analytics.text that implement LogicalOperator Modifier and Type Class Description class
CalculateNGramFrequency
Calculates the n-gram frequencies for a tokenized text field.class
CalculateWordFrequency
Calculates the word frequencies for a tokenized text field.class
ConvertTextCase
Converts the case on a TokenizedText field.class
CountTokens
Counts the number of tokens in a tokenized text field.class
DictionaryFilter
Filters a tokenized text field using a dictionary.class
ExpandTextFrequency
Expands text frequency field.class
ExpandTextTokens
Expands a TokenizedText field.class
FilterText
Filters a tokenized text field.class
GenerateBagOfWords
Calculates the bag of words for a tokenized text field.class
TextFrequencyFilter
Filters a frequency map field.class
TextStemmer
Stems a TokenizedText field.class
TextTokenizer
Tokenizes a string field as a TokenizedText object. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.util
Classes in com.pervasive.datarush.analytics.util that implement LogicalOperator Modifier and Type Class Description class
AbstractPredictor
Common base class for "predictor" processes. -
Uses of LogicalOperator in com.pervasive.datarush.analytics.viz
Classes in com.pervasive.datarush.analytics.viz that implement LogicalOperator Modifier and Type Class Description class
DrawDiagnosticsChart
This 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 LogicalOperator in com.pervasive.datarush.graphs
Methods in com.pervasive.datarush.graphs with parameters of type LogicalOperator Modifier and Type Method Description static List<Throwable>
LogicalGraphInstances. getExceptions(LogicalGraphInstance instance, LogicalOperator operator)
Returns the exceptions associated with the given operator.OperatorInstance
LogicalGraphInstance. getOperatorInstance(LogicalOperator operator)
Looks up an operator instance by theLogicalOperator
added to the graph.static OperatorState
LogicalGraphInstances. getOperatorState(LogicalGraphInstance instance, LogicalOperator operator)
Returns the operator state associated with the given operator.static List<LogicalStatistic>
LogicalGraphInstances. getOperatorStatistics(LogicalGraphInstance instance, LogicalOperator operator)
Returns the operator statistics associated with the given operator.void
GraphCompilationListener. preCompile(MetadataContext ctx, GraphPath path, LogicalOperator operator)
Invoked just prior to compiling an operator. -
Uses of LogicalOperator in com.pervasive.datarush.hbase
Classes in com.pervasive.datarush.hbase that implement LogicalOperator Modifier and Type Class Description class
DeleteHBase
Write delete markers to HBaseclass
KeyOperator
Specifies key field mapping when accessing HBase.class
KeyValueOperator
Specifies data field mapping when accessing HBase.class
ReadHBase
Read a result set from HBase.class
WriteHBase
Write a result set to HBase. -
Uses of LogicalOperator in com.pervasive.datarush.matching
Classes in com.pervasive.datarush.matching that implement LogicalOperator Modifier and Type Class Description class
DiscoverDuplicates
Discover duplicate records within a single source using fuzzy matching operators.class
DiscoverLinks
Use fuzzy matching operators to discover linked records from two data sources. -
Uses of LogicalOperator in com.pervasive.datarush.matching.block
Classes in com.pervasive.datarush.matching.block that implement LogicalOperator Modifier and Type Class Description class
BlockCartesian
Block the input data by creating a cartesian product of the data.class
BlockRecords
Block records into groups of like records based on a set of key fields and generate record pairs from these groups.class
BlockSelf
Block records from a single source into groups of like records based on a set of key fields and generate record pairs from these groups.class
GroupPairsSortedRows
Finds key groupings within the input key fields and, for each key group, generates all pairwise combinations of distinct rows in that group.class
LargeGroupDetector
An operator that issues warnings if a dataflow contains an unusually large number of distinct key values. -
Uses of LogicalOperator in com.pervasive.datarush.matching.cluster
Classes in com.pervasive.datarush.matching.cluster that implement LogicalOperator Modifier and Type Class Description class
ClusterDuplicates
Transform record pairs into clusters of like records, where the two sides of the pair are from the same source.class
ClusterLinks
Transform record pairs into clusters of like records. -
Uses of LogicalOperator in com.pervasive.datarush.matching.tune
Classes in com.pervasive.datarush.matching.tune that implement LogicalOperator Modifier and Type Class Description class
AnalyzeDuplicateKeys
Provides an analysis of the quality of a set of blocking keys over data to be deduplicated.class
AnalyzeLinkKeys
Provides an analysis of the quality of a set of blocking keys over two data sets to be linked. -
Uses of LogicalOperator in com.pervasive.datarush.operators
Subinterfaces of LogicalOperator in com.pervasive.datarush.operators Modifier and Type Interface Description interface
MultiSinkOperator<T extends LogicalPort>
Mix-in interface to be implemented by some operators.interface
MultiSourceOperator<T extends LogicalPort>
Mix-in interface to be implemented by some operators.interface
PipelineOperator<T extends LogicalPort>
Mix-in interface to be implemented by some operators.interface
RecordPipelineOperator
Refinement ofPipelineOperator
, specific to RecortPort's.interface
RecordSinkOperator
Refinement ofSinkOperator
, specific to RecortPort's.interface
RecordSourceOperator
Refinement ofSourceOperator
, specific to RecortPort's.interface
SinkOperator<T extends LogicalPort>
Mix-in interface to be implemented by some operators.interface
SourceOperator<T extends LogicalPort>
Mix-in interface to be implemented by some operators.Classes in com.pervasive.datarush.operators that implement LogicalOperator Modifier and Type Class Description class
AbstractDeferredRecordOperator
Convenient base class forDeferredCompositeOperator
's that are alsoRecordPipelineOperator
's.class
AbstractExecutableRecordPipeline
A base class for simple record-to-record operators, providing common functions.class
AbstractLogicalOperator
Base class for all LogicalOperators.class
AbstractRecordCompositeOperator
Convenient base class forCompositeOperator
's that are alsoRecordPipelineOperator
's.class
CompositeOperator
To be implemented by operators that can be defined by chaining together other operations.class
DeferredCompositeOperator
For rare use cases; implementors should useCompositeOperator
whenever possible!class
ExecutableOperator
ExecutableOperators are the most commonly used operators.class
IterativeOperator
To be implemented by operations that must make multiple passes over the input data.class
OpenComposite
A composite operator that can be externally composed.class
OpenModelSink<T>
A model sink that can be externally composed.class
OpenModelSource<T>
A model source that can be externally composed.class
OpenMultiModelSink<T>
A model sink that can be externally composed.class
OpenMultiModelSource<T>
A model source that can be externally composed.class
OpenMultiRecordSink
A record sink that can be externally composed.class
OpenMultiRecordSource
A record source that can be externally composed.class
OpenRecordSink
A record sink that can be externally composed.class
OpenRecordSource
A record source that can be externally composed.class
StreamingOperator
Base class for LogicalOperators that are a potentially streaming operation.Methods in com.pervasive.datarush.operators with type parameters of type LogicalOperator Modifier and Type Method Description <O extends LogicalOperator>
OOperatorComposable. add(O op)
Add a LogicalOperator to this graph, using the short class name as the name of the operator.<O extends LogicalOperator>
OOperatorComposable. add(O op, OperatorSettings settings)
Add a LogicalOperator to this graph, specifying advanced operator settings.<O extends LogicalOperator>
OOperatorComposable. add(O op, String name)
Add a LogicalOperator to this graph, specifying a name of the operator.Methods in com.pervasive.datarush.operators that return LogicalOperator Modifier and Type Method Description LogicalOperator
MetadataCalculationContext. getOperator()
Returns the operator bound to this context.Methods in com.pervasive.datarush.operators with parameters of type LogicalOperator Modifier and Type Method Description static OperatorType
OperatorType. of(LogicalOperator op)
Returns the operator type that corresponds to the given operator. -
Uses of LogicalOperator in com.pervasive.datarush.operators.assertion
Classes in com.pervasive.datarush.operators.assertion that implement LogicalOperator Modifier and Type Class Description class
AssertEqual
Verifies that actual rows are equal to expected rows.class
AssertEqualHash
Verifies that actual rows are equal to expected rows without regard to order.class
AssertEqualRecordType
Assert that the given type and the type of the input port are equal.class
AssertEqualTypes
Asserts that two input flows have identical types.class
AssertMetadata
Assert that the metadata on the input port is set correctly.class
AssertPredicate
Assert that the given predicate is true for all input values.class
AssertRowCount
Verifies that the input flow contains the specified row count.class
AssertSorted
Verifies that the input data is sorted by the given set of keys. -
Uses of LogicalOperator in com.pervasive.datarush.operators.group
Classes in com.pervasive.datarush.operators.group that implement LogicalOperator Modifier and Type Class Description class
Group
Performs grouping (aggregation) of sorted input data.class
RemoveDuplicates
Removes duplicate rows based on a specified set of group keys.class
SortedGroupHandler
Common base class for all processes that need to detect group boundaries -
Uses of LogicalOperator in com.pervasive.datarush.operators.io
Classes in com.pervasive.datarush.operators.io that implement LogicalOperator Modifier and Type Class Description class
AbstractReader
A generic reader of byte data representing a stream of records.class
AbstractWriter
A generic writer of byte data representing a stream of records.class
ReadSource
Reads a data source as a stream of records.class
WriteSink
Writes a stream of records to a data sink. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.avro
Classes in com.pervasive.datarush.operators.io.avro that implement LogicalOperator Modifier and Type Class Description class
ReadAvro
Reads data previously written using Apache Avro format.class
WriteAvro
Writes data using Apache Avro format. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.binary
Classes in com.pervasive.datarush.operators.io.binary that implement LogicalOperator Modifier and Type Class Description class
BinaryWriter
Writes raw binary data to a filesystem. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.jdbc
Classes in com.pervasive.datarush.operators.io.jdbc that implement LogicalOperator Modifier and Type Class Description class
AbstractWriteToJDBC
Abstract implementation of a JDBC writer.protected static class
AbstractWriteToJDBC.AbstractWriteToJDBCWorker
class
DeleteFromJDBC
This operator deletes data in the target table in a database by applying SQL delete statements.class
FinalizeSQLWorker
class
InitializeSQLWorker
class
JDBCOperator
Common base class forReadFromJDBC
andAbstractWriteToJDBC
.class
ReadFromJDBC
TheReadFromJDBC
operator is used to access relational database systems using a supplied JDBC driver.class
UpdateInJDBC
This operator updates the target table in a database by applying SQL update statements.class
WriteToJDBC
In its simplest form, writes records from an input port to a JDBC target table using insert statements. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.mdf
Classes in com.pervasive.datarush.operators.io.mdf that implement LogicalOperator Modifier and Type Class Description class
ReadMDF
Reads data previously written using MDF format. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.staging
Classes in com.pervasive.datarush.operators.io.staging that implement LogicalOperator Modifier and Type Class Description class
ForceRecordStaging
Forces staging of record ports.class
ForceStaging<P extends LogicalPort>
Forces the operators on the input and output sides to execute sequentially, instead of concurrently.class
ReadStagingDataset
Reads a sequence of records previously staged to disk.class
WriteStagingDataset
Writes a sequence of records to disk in an internal format for staged data. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.textfile
Classes in com.pervasive.datarush.operators.io.textfile that implement LogicalOperator Modifier and Type Class Description class
AbstractTextReader
A generic reader of text data representing a stream of records.class
AbstractTextWriter
A generic writer of text data representing a stream of records.class
ParseTextFields
Parses input text records according to a specified text schema.class
ReadARFF
Read files in the Attribute-Relation File Format (ARFF).class
ReadDelimitedText
Reads a text file of delimited records as record tokens.class
ReadFixedText
Reads a text file of fixed-width records as record tokens.class
ReadJSON
The ReadJSON operator reads a JSON file of key-value pairs or array of objects as record tokens.class
ReadLog
Reads a log file as record tokens.class
WriteARFF
Write files using the Attribute-Relation File Format (ARFF).class
WriteDelimitedText
Writes a stream of records as delimited text.class
WriteFixedText
Writes a record dataflow as a text file of fixed-width records. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.vectorwise
Classes in com.pervasive.datarush.operators.io.vectorwise that implement LogicalOperator Modifier and Type Class Description class
LoadActianVector
Bulk load data into the Actian Vector database.class
LoadVectorOnHadoop
Deprecated.this operator has been replaced withLoadActianVector
; use that operator instead. -
Uses of LogicalOperator in com.pervasive.datarush.operators.io.vectorwise.dl
Classes in com.pervasive.datarush.operators.io.vectorwise.dl that implement LogicalOperator Modifier and Type Class Description class
LoadVectorOnHadoopDirect
Deprecated.this operator has been replaced withLoadActianVector
; use that operator instead. -
Uses of LogicalOperator in com.pervasive.datarush.operators.join
Classes in com.pervasive.datarush.operators.join that implement LogicalOperator Modifier and Type Class Description class
AbstractRelationalJoin
Common base class for the various types of join that we support.class
CrossJoin
Produce the cartesian product of two sets of records.class
FilterExistingRows
Filters records on the left based on the presence of matching records on the right.class
FilterExistJoinProcess
class
Join
Performs a relational equi-join on two input datasets by a specified set of keys.class
SemiJoin
Deprecated.this operator has been replaced withFilterExistingRows
; use that operator instead, linking to the appropriate output port.class
UnionAll
Provides a union of two data sources. -
Uses of LogicalOperator in com.pervasive.datarush.operators.model
Classes in com.pervasive.datarush.operators.model that implement LogicalOperator Modifier and Type Class Description class
GetModel<T>
Provides a way to update an in-memory reference to a model object.class
MergeModel<T>
This operator is uses to force a merge of a partitioned model into a single model.class
PutModel<T>
Provides a way to inject an in-memory reference to a model object into a graph. -
Uses of LogicalOperator in com.pervasive.datarush.operators.partition
Classes in com.pervasive.datarush.operators.partition that implement LogicalOperator Modifier and Type Class Description class
GatherHint
Forces parallel streams of data to be gathered into a single non-parallel stream.class
PartitionHint
Forces the input data to be partitioned into parallel streams of data for subsequent parallel operations.class
Randomize
Operator that re-orders its input in a random fashion. -
Uses of LogicalOperator in com.pervasive.datarush.operators.record
Classes in com.pervasive.datarush.operators.record that implement LogicalOperator Modifier and Type Class Description class
ColumnsToRows
Normalize records by transposing values from row columns into multiple rows.class
DeriveFields
Applies one or more functions to the input record data.class
DiscoverDomain
Utility operator for discovering the domain of string fields.class
FilterFields
Base class for operators which filter fields in the input records.class
MergeFields
Merges two streams of data with an equivalent number of rows into one.class
RemapFields
Rearranges and renames fields in a record.class
RemoveFields
Removes a subset of fields from the input records.class
RetainFields
Preserves a subset of fields from the input records.class
RowsToColumns
The RowsToColumns operator is used to pivot data from a narrow representation (rows) into a wider representation (columns).class
SelectFields
Preserves a subset of fields from the input records. -
Uses of LogicalOperator in com.pervasive.datarush.operators.scripting
Classes in com.pervasive.datarush.operators.scripting that implement LogicalOperator Modifier and Type Class Description class
RunJavaScript
Processes rows using user-defined scripts written in JavaScript.class
RunScript
Processes rows using user-defined scripts. -
Uses of LogicalOperator in com.pervasive.datarush.operators.select
Classes in com.pervasive.datarush.operators.select that implement LogicalOperator Modifier and Type Class Description class
FilterRows
Filters records based on a specified predicate.class
LimitRows
Truncates a flow to a fixed number of records.class
SampleRandomRows
Apply random sampling to the input data. -
Uses of LogicalOperator in com.pervasive.datarush.operators.sink
Classes in com.pervasive.datarush.operators.sink that implement LogicalOperator Modifier and Type Class Description class
CollectRecords
Collects input data into an in-memory token list.class
LogRows
Log information about the input data from a flow. -
Uses of LogicalOperator in com.pervasive.datarush.operators.sort
Classes in com.pervasive.datarush.operators.sort that implement LogicalOperator Modifier and Type Class Description class
Sort
Sorts the input data. -
Uses of LogicalOperator in com.pervasive.datarush.operators.source
Classes in com.pervasive.datarush.operators.source that implement LogicalOperator Modifier and Type Class Description class
EmitRecords
Emits an in-memory token list as output.class
GenerateArithmeticSequence
Generates a sequence of numerical values, with a constant difference between consecutive values.class
GenerateConstant
Generates copies of a constant value.class
GenerateRandom
Generates rows of random data.class
GenerateRepeatingCycle
Generates a cycle of repeating values. -
Uses of LogicalOperator in com.pervasive.datarush.operators.string
Classes in com.pervasive.datarush.operators.string that implement LogicalOperator Modifier and Type Class Description class
SplitField
Splits a string field into multiple fields, based on a specified pattern. -
Uses of LogicalOperator in com.pervasive.datarush.operators.testutils
Classes in com.pervasive.datarush.operators.testutils that implement LogicalOperator Modifier and Type Class Description class
DumpPartitions
For test purposes--sorts inputs and writes to a fileclass
ErrorSink
A record source sink throws an error either at composition time or execution time.class
ErrorSource
A record source that throws an error either at composition time or execution time.class
SimulatePartitions
For tests that wish to simulate a partitioned read. -
Uses of LogicalOperator in com.pervasive.datarush.ports
Methods in com.pervasive.datarush.ports that return LogicalOperator Modifier and Type Method Description LogicalOperator
LogicalPort. getOwner()
Returns a reference to the operator that declared this portMethods in com.pervasive.datarush.ports with parameters of type LogicalOperator Modifier and Type Method Description abstract T
LogicalPortFactory. newPort(LogicalOperator owner, String name, LogicalPort.Direction direction, boolean optional)
Public only as a matter of implementation; clients should not use this method directly.Constructors in com.pervasive.datarush.ports with parameters of type LogicalOperator Constructor Description LogicalPort(LogicalOperator owner, String name, LogicalPort.Direction direction, boolean optional)
Create a new LogicalPort -
Uses of LogicalOperator in com.pervasive.datarush.ports.model
Methods in com.pervasive.datarush.ports.model with parameters of type LogicalOperator Modifier and Type Method Description static DoneSignalPort
DoneSignalPort. getOutput(LogicalOperator op)
Returns the done signal port from the given operator if it defines one, throwing an exception if none foundSimpleModelPort<T>
SimpleModelPort.Factory. newPort(LogicalOperator owner, String name, LogicalPort.Direction direction, boolean optional)
Constructors in com.pervasive.datarush.ports.model with parameters of type LogicalOperator Constructor Description AbstractModelPort(LogicalOperator owner, String name, LogicalPort.Direction direction, boolean optional, ModelStorageHandler<T> storageHandler)
Subclasses must invoke this constructor -
Uses of LogicalOperator in com.pervasive.datarush.ports.record
Classes in com.pervasive.datarush.ports.record that implement LogicalOperator Modifier and Type Class Description class
ExternalRecordSink
Defines an external sink of record data.class
ExternalRecordSource
Defines an external source of record data. -
Uses of LogicalOperator in com.pervasive.datarush.script
Methods in com.pervasive.datarush.script that return LogicalOperator Modifier and Type Method Description LogicalOperator
OperatorDescriptor. createInstance()
Create an instance of the operator.Methods in com.pervasive.datarush.script that return types with arguments of type LogicalOperator Modifier and Type Method Description Class<? extends LogicalOperator>
OperatorDescriptor. getOpClass()
Get the class of the operator.Constructor parameters in com.pervasive.datarush.script with type arguments of type LogicalOperator Constructor Description OperatorDescriptor(Class<? extends LogicalOperator> opClass)
Construct an operator definition with the default name of the operator.OperatorDescriptor(Class<? extends LogicalOperator> opClass, String opName)
Construct an operator descriptor. -
Uses of LogicalOperator in com.pervasive.datarush.script.operators.group
Classes in com.pervasive.datarush.script.operators.group that implement LogicalOperator Modifier and Type Class Description class
ProcessByGroup
Executes an application graph for each distinct key group of data within the input data set.
-