Uses of Class
com.pervasive.datarush.operators.AbstractLogicalOperator
Packages that use AbstractLogicalOperator
Package
Description
Provides common classes for Association Rule Mining (ARM).
Provides the operator to perform the FP-growth ARM algorithm.
Provides operators related to data cleansing.
Provides base PMML for clustering models.
Provides the KMeans algorithm.
Provides the PMML learner operator and associated classes.
Provides the decision tree predictor operator and associated classes.
Provides the decision tree pruner operator and associated classes.
Provides an implementation of the KNN algorithm using DataRush's sparse data API.
Provides an implementation of the Naive Bayes learner.
Provides an implementation of a Naive Bayes predictor.
Provides shared and base classes for PMML model representation of Analytics algorithms.
Provides utility, PMML and other classes for shared use by regression related entities.
Provides various statistics, Data Summarizer, and Data Quality Analyzer.
Provides an implementation of an SVM learner.
Provides an implementation of an SVM predictor.
Provides various unstructured text processing operators.
Provides some (internal) utility classes for Analytics.
Provides operators for classifier performance visualization.
Provides operators for performing discovering duplicates or links between
records.
Provides operators for generating possible candidate pairs.
Provides operators for clustering the results of duplicate or
linkage discovery.
Provides operators for analyzing data for approximate matching.
Provides classes and interfaces for developing dataflow operators.
Provides operators for making assertions on flows and files.
Provides data aggregation components.
Provides base file I/O components including encoders and decoders.
Provides operators for reading and writing files in Avro format.
Provides operators for reading from JDBC sources and writing to JDBC targets.
Provides operators for reading and writing DataRush staging datasets.
Provides operators for reading and writing text data.
Provides operators for joining together two data sets into a single one.
Provides operators for handling models.
Provides operators for partitioning and unpartitioning flows of data.
Provides operators for manipulating record structure.
Provides the
RunScript
operator for running user-defined scripts on the rows of an input record flow.Provides operators for selecting a subset of the data set.
Provides the
LogRows operator
for writing debugging information about a flow to the logging API.Provides operators for sorting and manipulating sorted
flows.
Provides operators for generating data tokens in various ways.
Provides operators for operating on string values in records.
Provides implementations of port objects related to the flow of record sets
between operators.
-
Uses of AbstractLogicalOperator in com.actian.dataflow.operators.io.orc
Subclasses of AbstractLogicalOperator in com.actian.dataflow.operators.io.orc -
Uses of AbstractLogicalOperator in com.actian.dataflow.operators.io.parquet
Subclasses of AbstractLogicalOperator in com.actian.dataflow.operators.io.parquetModifier and TypeClassDescriptionclassReads 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.armModifier and TypeClassDescriptionclassAn operator that converts an association model in PMML into a target format.classCompute 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.fpgrowthModifier and TypeClassDescriptionclassAn 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.cleansingModifier and TypeClassDescriptionclassReplace 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.clusterModifier and TypeClassDescriptionfinal classAssigns 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.kmeansModifier and TypeClassDescriptionfinal classComputes clustering model for the given input based on the k-Means algorithm. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.learner
Modifier and TypeClassDescriptionfinal classOperator responsible for constructing a Decision Tree. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.predictor
Modifier and TypeClassDescriptionfinal classOperator responsible for predicting outcomes based on a Decision Tree PMML model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.decisiontree.pruner
Modifier and TypeClassDescriptionfinal classPerforms pruning of the provided input model. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.knn
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.knnModifier and TypeClassDescriptionfinal classApplies 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
Modifier and TypeClassDescriptionfinal classOperator responsible for building a Naive Bayes PMML model from input data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.naivebayes.predictor
Modifier and TypeClassDescriptionfinal classOperator 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.pmmlModifier and TypeClassDescriptionfinal classfinal classfinal classReads a PMML model object from a file.final classWrite 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 -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.regression
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.regressionModifier and TypeClassDescriptionclassPerforms a multivariate linear regression on the given training data.classFits a multinomial logistic regression model to the training data.classclassApply a regression model to the input data.final classCompute 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.statsModifier and TypeClassDescriptionclassDetermines which range each value in a field falls within and counts the totals.final classEvaluates a set of quality tests on an input dataset.final classCalculates distinct values of the given input field.classThe EqualRangeBinning operator can be used to divide a set of numeric data into equal range bins.classCompute the most frequent values within the given fields.final classApply normalization methods to fields within an input data flow.classRank data using the given rank mode.final classDiscovers various metrics of an input dataset, based on the configured detail level. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.svm.learner
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.svm.learnerModifier and TypeClassDescriptionfinal classBuilds aPMMLSupportVectorMachineModelfrom an input dataset. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.svm.predictor
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.svm.predictorModifier and TypeClassDescriptionfinal classOperator 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.textModifier and TypeClassDescriptionclassCalculates the n-gram frequencies for a tokenized text field.classCalculates the word frequencies for a tokenized text field.classConverts the case on a TokenizedText field.classCounts the number of tokens in a tokenized text field.classFilters a tokenized text field using a dictionary.classExpands text frequency field.classExpands a TokenizedText field.classFilters a tokenized text field.classCalculates the bag of words for a tokenized text field.classFilters a frequency map field.classStems a TokenizedText field.classTokenizes a string field as a TokenizedText object. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.util
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.utilModifier and TypeClassDescriptionclassCommon base class for "predictor" processes. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.analytics.viz
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.analytics.vizModifier and TypeClassDescriptionclassThis 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.hbaseModifier and TypeClassDescriptionclassWrite delete markers to HBaseclassSpecifies key field mapping when accessing HBase.classSpecifies data field mapping when accessing HBase.classRead a result set from HBase.classWrite a result set to HBase. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.matching
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.matchingModifier and TypeClassDescriptionclassDiscover duplicate records within a single source using fuzzy matching operators.classUse 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.blockModifier and TypeClassDescriptionclassBlock the input data by creating a cartesian product of the data.classBlock records into groups of like records based on a set of key fields and generate record pairs from these groups.classBlock records from a single source into groups of like records based on a set of key fields and generate record pairs from these groups.classFinds key groupings within the input key fields and, for each key group, generates all pairwise combinations of distinct rows in that group.classAn 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.clusterModifier and TypeClassDescriptionclassTransform record pairs into clusters of like records, where the two sides of the pair are from the same source.classTransform record pairs into clusters of like records. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.matching.tune
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.matching.tuneModifier and TypeClassDescriptionclassProvides an analysis of the quality of a set of blocking keys over data to be deduplicated.classProvides 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.operatorsModifier and TypeClassDescriptionclassConvenient base class forDeferredCompositeOperator's that are alsoRecordPipelineOperator's.classA base class for simple record-to-record operators, providing common functions.classConvenient base class forCompositeOperator's that are alsoRecordPipelineOperator's.classTo be implemented by operators that can be defined by chaining together other operations.classFor rare use cases; implementors should useCompositeOperatorwhenever possible!classExecutableOperators are the most commonly used operators.classTo be implemented by operations that must make multiple passes over the input data.final classA composite operator that can be externally composed.final classA model sink that can be externally composed.final classA model source that can be externally composed.final classA model sink that can be externally composed.final classA model source that can be externally composed.final classA record sink that can be externally composed.final classA record source that can be externally composed.final classA record sink that can be externally composed.final classA record source that can be externally composed.classBase class for LogicalOperators that are a potentially streaming operation.Methods in com.pervasive.datarush.operators that return AbstractLogicalOperatorModifier and TypeMethodDescriptionOperatorProxies.OperatorProxy.getTarget()Public only as a matter of implementation; not intended for external useMethods in com.pervasive.datarush.operators with parameters of type AbstractLogicalOperatorModifier and TypeMethodDescriptionOperatorProxies.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.assertionModifier and TypeClassDescriptionclassVerifies that actual rows are equal to expected rows.classVerifies that actual rows are equal to expected rows without regard to order.classAssert that the given type and the type of the input port are equal.classAsserts that two input flows have identical types.classAssert that the metadata on the input port is set correctly.classAssert that the given predicate is true for all input values.classVerifies that the input flow contains the specified row count.final classVerifies that the input data is sorted by the given set of keys. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.graph
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.graphModifier and TypeClassDescriptionclassA mockable sink that can be utilized with the SubJobExecutor to pass data back to the launcher.classA mockable source that can be utilized with the SubJobExecutor to insert parameter data.classThe SubJobExecutor operator can be used to execute JSON serialized subgraphs within the current workflow. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.group
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.groupModifier and TypeClassDescriptionfinal classPerforms grouping (aggregation) of sorted input data.classRemoves duplicate rows based on a specified set of group keys.classCommon 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.ioModifier and TypeClassDescriptionclassA generic reader of byte data representing a stream of records.classA generic writer of byte data representing a stream of records.final classReads a data source as a stream of records.final classWrites 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.avroModifier and TypeClassDescriptionclassReads data previously written using Apache Avro format.classWrites 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 -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.jdbc
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.jdbcModifier and TypeClassDescriptionclassAbstract implementation of a JDBC writer.protected static classfinal classThis operator deletes data in the target table in a database by applying SQL delete statements.classclassclassCommon base class forReadFromJDBCandAbstractWriteToJDBC.classTheReadFromJDBCoperator is used to access relational database systems using a supplied JDBC driver.final classThis operator updates the target table in a database by applying SQL update statements.final classIn 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 -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.staging
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.io.stagingModifier and TypeClassDescriptionfinal classForces staging of record ports.classForceStaging<P extends LogicalPort>Forces the operators on the input and output sides to execute sequentially, instead of concurrently.classReads a sequence of records previously staged to disk.final classWrites 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.textfileModifier and TypeClassDescriptionclassA generic reader of text data representing a stream of records.classA generic writer of text data representing a stream of records.classParses input text records according to a specified text schema.classRead files in the Attribute-Relation File Format (ARFF).final classReads a text file of delimited records as record tokens.classReads a text file of fixed-width records as record tokens.classThe ReadJSON operator reads a JSON file of key-value pairs or array of objects as record tokens.classReads a log file as record tokens.classWrite files using the Attribute-Relation File Format (ARFF).final classWrites a stream of records as delimited text.classWrites 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.vectorwiseModifier and TypeClassDescriptionfinal classBulk load data into the Actian Vector database.classBulk read data from the Actian Vector database. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.join
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.joinModifier and TypeClassDescriptionclassCommon base class for the various types of join that we support.final classProduce the cartesian product of two sets of records.final classFilters records on the left based on the presence of matching records on the right.classfinal classPerforms a relational equi-join on two input datasets by a specified set of keys.final classDeprecated.classProvides a union of two data sources. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.model
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.modelModifier and TypeClassDescriptionclassGetModel<T>Provides a way to update an in-memory reference to a model object.final 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.partitionModifier and TypeClassDescriptionfinal classForces parallel streams of data to be gathered into a single non-parallel stream.final classForces the input data to be partitioned into parallel streams of data for subsequent parallel operations.classOperator 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.recordModifier and TypeClassDescriptionclassNormalize records by transposing values from row columns into multiple rows.final classApplies one or more functions to the input record data.final classUtility operator for discovering the domain of string fields.classBase class for operators which filter fields in the input records.classMerges two streams of data with an equivalent number of rows into one.classRearranges and renames fields in a record.classRemoves a subset of fields from the input records.classPreserves a subset of fields from the input records.classThe RowsToColumns operator is used to pivot data from a narrow representation (rows) into a wider representation (columns).classPreserves 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.scriptingModifier and TypeClassDescriptionclassProcesses rows using user-defined scripts written in JavaScript.classProcesses rows using user-defined scripts. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.select
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.selectModifier and TypeClassDescriptionclassFilters records based on a specified predicate.classTruncates a flow to a fixed number of records.classApply random sampling to the input data. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.sink
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.sinkModifier and TypeClassDescriptionfinal classCollects input data into an in-memory token list.final classLog 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 -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.source
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.sourceModifier and TypeClassDescriptionfinal classEmits an in-memory token list as output.final classGenerates a sequence of numerical values, with a constant difference between consecutive values.final classGenerates copies of a constant value.final classGenerates rows of random data.final classGenerates a cycle of repeating values. -
Uses of AbstractLogicalOperator in com.pervasive.datarush.operators.string
Subclasses of AbstractLogicalOperator in com.pervasive.datarush.operators.stringModifier and TypeClassDescriptionclassSplits 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.testutilsModifier and TypeClassDescriptionfinal classFor test purposes--sorts inputs and writes to a filefinal classA record source sink throws an error either at composition time or execution time.final classA record source that throws an error either at composition time or execution time.final classFor 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.recordModifier and TypeClassDescriptionfinal classDefines an external sink of record data.final classDefines 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.groupModifier and TypeClassDescriptionclassExecutes an application graph for each distinct key group of data within the input data set.
FilterExistingRows; use that operator instead, linking to the appropriate output port.