Interface | Description |
---|---|
CustomUnaryOperation<IN,OUT> | |
UdfOperator<O extends UdfOperator<O>> |
This interface marks operators as operators that execute user-defined functions (UDFs), such as
RichMapFunction , RichReduceFunction ,
or RichCoGroupFunction . |
Class | Description |
---|---|
AggregateOperator<IN> |
This operator represents the application of a "aggregate" operation on a data set, and the
result data set produced by the function.
|
AggregateOperator.AggregatingUdf<T extends Tuple> | |
BulkIterationResultSet<T> | |
CoGroupOperator<I1,I2,OUT> |
A
DataSet that is the result of a CoGroup transformation. |
CoGroupOperator.CoGroupOperatorSets<I1,I2> |
Intermediate step of a CoGroup transformation.
|
CoGroupRawOperator<I1,I2,OUT> |
A
DataSet that is the result of a CoGroup transformation. |
CrossOperator<I1,I2,OUT> |
A
DataSet that is the result of a Cross transformation. |
CrossOperator.CrossProjection<I1,I2> | |
CrossOperator.DefaultCross<I1,I2> | |
CrossOperator.DefaultCrossFunction<T1,T2> | |
CrossOperator.ProjectCross<I1,I2,OUT extends Tuple> | |
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> | |
DataSink<T> | |
DataSource<OUT> |
An operation that creates a new data set (data source).
|
DeltaIteration<ST,WT> |
The DeltaIteration represents the start of a delta iteration.
|
DeltaIteration.SolutionSetPlaceHolder<ST> |
A
DataSet that acts as a placeholder for the solution set during the iteration. |
DeltaIteration.WorksetPlaceHolder<WT> |
A
DataSet that acts as a placeholder for the workset during the iteration. |
DeltaIterationResultSet<ST,WT> | |
DistinctOperator<T> |
This operator represents the application of a "distinct" function on a data set, and the
result data set produced by the function.
|
DistinctOperator.DistinctFunction<T> | |
FilterOperator<T> |
This operator represents the application of a "filter" function on a data set, and the
result data set produced by the function.
|
FlatMapOperator<IN,OUT> |
This operator represents the application of a "flatMap" function on a data set, and the
result data set produced by the function.
|
GroupCombineOperator<IN,OUT> |
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data
locally in their partitions.
|
Grouping<T> |
Grouping is an intermediate step for a transformation on a grouped DataSet.
The following transformation can be applied on Grouping: UnsortedGrouping.reduce(org.apache.flink.api.common.functions.ReduceFunction) ,
UnsortedGrouping.reduceGroup(org.apache.flink.api.common.functions.GroupReduceFunction) , and
UnsortedGrouping.aggregate(org.apache.flink.api.java.aggregation.Aggregations, int) .
|
GroupReduceOperator<IN,OUT> |
This operator represents the application of a "reduceGroup" function on a data set, and the
result data set produced by the function.
|
IterativeDataSet<T> |
The IterativeDataSet represents the start of an iteration.
|
JoinOperator<I1,I2,OUT> |
A
DataSet that is the result of a Join transformation. |
JoinOperator.DefaultFlatJoinFunction<T1,T2> | |
JoinOperator.DefaultJoin<I1,I2> | |
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT> | |
JoinOperator.EquiJoin<I1,I2,OUT> |
A Join transformation that applies a
JoinFunction on each pair of joining elements.It also represents the DataSet that is the result of a Join transformation. |
JoinOperator.JoinOperatorSets<I1,I2> |
Intermediate step of a Join transformation.
|
JoinOperator.JoinProjection<I1,I2> | |
JoinOperator.ProjectFlatJoinFunction<T1,T2,R extends Tuple> | |
JoinOperator.ProjectJoin<I1,I2,OUT extends Tuple> | |
KeyFunctions |
This class holds static utilities to append functions that extract and
prune keys.
|
MapOperator<IN,OUT> |
This operator represents the application of a "map" function on a data set, and the
result data set produced by the function.
|
MapPartitionOperator<IN,OUT> |
This operator represents the application of a "mapPartition" function on a data set, and the
result data set produced by the function.
|
Operator<OUT,O extends Operator<OUT,O>> |
Base class of all operators in the Java API.
|
OperatorTranslation | |
PartitionOperator<T> |
This operator represents a partitioning.
|
ProjectOperator<IN,OUT extends Tuple> |
This operator represents the application of a projection operation on a data set, and the
result data set produced by the function.
|
ProjectOperator.Projection<T> | |
ReduceOperator<IN> |
This operator represents the application of a "reduce" function on a data set, and the
result data set produced by the function.
|
SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> |
Base class for operations that operates on a single input data set.
|
SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> |
The SingleInputUdfOperator is the base class of all unary operators that execute
user-defined functions (UDFs).
|
SortedGrouping<T> |
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.
The following transformation can be applied on sorted groups: SortedGrouping.reduceGroup(org.apache.flink.api.common.functions.GroupReduceFunction) ,
|
SortPartitionOperator<T> |
This operator represents a DataSet with locally sorted partitions.
|
TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> |
Base class for operations that operates on two input data sets.
|
TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> |
The TwoInputUdfOperator is the base class of all binary operators that execute
user-defined functions (UDFs).
|
UdfOperatorUtils |
Utility class that contains helper methods to work with UDF operators.
|
UnionOperator<T> |
Java API operator for union of two data sets
|
UnsortedGrouping<T> |
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.