Class and Description |
---|
AggregateOperator
This operator represents the application of a "aggregate" operation on a data set, and the
result data set produced by the function.
|
CoGroupOperator.CoGroupOperatorSets
Intermediate step of a CoGroup transformation.
|
CrossOperator.DefaultCross
A Cross transformation that wraps pairs of crossed elements into
Tuple2 .It also represents the DataSet that is the result of a Cross transformation. |
CustomUnaryOperation |
DataSink |
DataSource
An operation that creates a new data set (data source).
|
DeltaIteration
The DeltaIteration represents the start of a delta iteration.
|
DistinctOperator
This operator represents the application of a "distinct" function on a data set, and the
result data set produced by the function.
|
FilterOperator
This operator represents the application of a "filter" function on a data set, and the
result data set produced by the function.
|
FlatMapOperator
This operator represents the application of a "flatMap" function on a data set, and the
result data set produced by the function.
|
GroupCombineOperator
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data
locally in their partitions.
|
GroupReduceOperator
This operator represents the application of a "reduceGroup" function on a data set, and the
result data set produced by the function.
|
IterativeDataSet
The IterativeDataSet represents the start of an iteration.
|
JoinOperator.JoinOperatorSets
Intermediate step of a Join transformation.
|
MapOperator
This operator represents the application of a "map" function on a data set, and the
result data set produced by the function.
|
MapPartitionOperator
This operator represents the application of a "mapPartition" function on a data set, and the
result data set produced by the function.
|
PartitionOperator
This operator represents a partitioning.
|
ProjectOperator
This operator represents the application of a projection operation on a data set, and the
result data set produced by the function.
|
ReduceOperator
This operator represents the application of a "reduce" function on a data set, and the
result data set produced by the function.
|
SortPartitionOperator
This operator represents a DataSet with locally sorted partitions.
|
UnionOperator
Java API operator for union of two data sets
|
UnsortedGrouping |
Class and Description |
---|
DataSource
An operation that creates a new data set (data source).
|
Class and Description |
---|
AggregateOperator
This operator represents the application of a "aggregate" operation on a data set, and the
result data set produced by the function.
|
CoGroupOperator
A
DataSet that is the result of a CoGroup transformation. |
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Intermediate step of a CoGroup transformation.
|
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction |
CrossOperator
A
DataSet that is the result of a Cross transformation. |
CrossOperator.CrossProjection |
CrossOperator.ProjectCross
A Cross transformation that projects crossing elements or fields of crossing
Tuples
into result Tuples . |
CrossOperator.ProjectCrossFunction |
DataSink |
DataSource
An operation that creates a new data set (data source).
|
DeltaIteration
The DeltaIteration represents the start of a delta iteration.
|
DeltaIteration.SolutionSetPlaceHolder
A
DataSet that acts as a placeholder for the solution set during the iteration. |
DeltaIteration.WorksetPlaceHolder
A
DataSet that acts as a placeholder for the workset during the iteration. |
DistinctOperator
This operator represents the application of a "distinct" function on a data set, and the
result data set produced by the function.
|
GroupCombineOperator
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data
locally in their partitions.
|
Grouping
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
This operator represents the application of a "reduceGroup" function on a data set, and the
result data set produced by the function.
|
IterativeDataSet
The IterativeDataSet represents the start of an iteration.
|
JoinOperator
A
DataSet that is the result of a Join transformation. |
JoinOperator.DefaultJoin
A Join transformation that wraps pairs of joining elements into
Tuple2 .It also represents the DataSet that is the result of a Join transformation. |
JoinOperator.EquiJoin
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.JoinOperatorSetsPredicate
Intermediate step of a Join transformation.
|
JoinOperator.JoinProjection |
JoinOperator.ProjectFlatJoinFunction |
JoinOperator.ProjectJoin
A Join transformation that projects joining elements or fields of joining
Tuples
into result Tuples . |
Operator
Base class of all operators in the Java API.
|
PartitionOperator
This operator represents a partitioning.
|
ProjectOperator
This operator represents the application of a projection operation on a data set, and the
result data set produced by the function.
|
ReduceOperator
This operator represents the application of a "reduce" function on a data set, and the
result data set produced by the function.
|
SingleInputOperator
Base class for operations that operates on a single input data set.
|
SingleInputUdfOperator
The SingleInputUdfOperator is the base class of all unary operators that execute
user-defined functions (UDFs).
|
SortedGrouping
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
This operator represents a DataSet with locally sorted partitions.
|
TwoInputOperator
Base class for operations that operates on two input data sets.
|
TwoInputUdfOperator
The TwoInputUdfOperator is the base class of all binary operators that execute
user-defined functions (UDFs).
|
UdfOperator
This interface marks operators as operators that execute user-defined functions (UDFs), such as
RichMapFunction , RichReduceFunction ,
or RichCoGroupFunction . |
UnsortedGrouping |
Class and Description |
---|
JoinOperator
A
DataSet that is the result of a Join transformation. |
JoinOperator.DefaultJoin
A Join transformation that wraps pairs of joining elements into
Tuple2 .It also represents the DataSet that is the result of a Join transformation. |
Class and Description |
---|
MapPartitionOperator
This operator represents the application of a "mapPartition" function on a data set, and the
result data set produced by the function.
|
PartitionOperator
This operator represents a partitioning.
|
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.