| 接口 | 说明 | 
|---|---|
| CustomUnaryOperation<IN,OUT> | |
| UdfOperator<O extends UdfOperator<O>> | This interface marks operators as operators that execute user-defined functions (UDFs), such as
  RichMapFunction,RichReduceFunction, orRichCoGroupFunction. | 
| 类 | 说明 | 
|---|---|
| AggregateOperator<IN> | This operator represents the application of a "aggregate" operation on a data set, and the result
 data set produced by the function. | 
| BulkIterationResultSet<T> | Resulting  DataSetof bulk iterations. | 
| CoGroupOperator<I1,I2,OUT> | A  DataSetthat is the result of a CoGroup transformation. | 
| CoGroupOperator.CoGroupOperatorSets<I1,I2> | Intermediate step of a CoGroup transformation. | 
| CoGroupRawOperator<I1,I2,OUT> | A  DataSetthat is the result of a CoGroup transformation. | 
| CrossOperator<I1,I2,OUT> | A  DataSetthat is the result of a Cross transformation. | 
| CrossOperator.CrossProjection<I1,I2> | |
| CrossOperator.DefaultCross<I1,I2> | A Cross transformation that wraps pairs of crossed elements into  Tuple2. | 
| CrossOperator.ProjectCross<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> | A Cross transformation that projects crossing elements or fields of crossing  Tuplesinto resultTuples. | 
| CrossOperator.ProjectCrossFunction<T1,T2,R extends org.apache.flink.api.java.tuple.Tuple> | |
| DataSink<T> | An operation that allows storing data results. | 
| 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  DataSetthat acts as a placeholder for the solution set during the iteration. | 
| DeltaIteration.WorksetPlaceHolder<WT> | A  DataSetthat acts as a placeholder for the workset during the iteration. | 
| DeltaIterationResultSet<ST,WT> | Resulting  DataSetof a delta iteration operation. | 
| DistinctOperator<T> | This operator represents the application of a "distinct" function on a data set, and the result
 data set produced by the function. | 
| 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. | 
| 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  DataSetthat is the result of a Join transformation. | 
| JoinOperator.DefaultJoin<I1,I2> | A Join transformation that wraps pairs of joining elements into  Tuple2. | 
| JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT> | Wrapper around  JoinFunction. | 
| JoinOperator.EquiJoin<I1,I2,OUT> | A Join transformation that applies a  JoinFunctionon each pair of joining elements. | 
| JoinOperator.JoinOperatorSets<I1,I2> | Intermediate step of a Join transformation. | 
| JoinOperator.ProjectJoin<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple> | A Join transformation that projects joining elements or fields of joining  Tuplesinto resultTuples. | 
| 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. | 
| NoOpOperator<IN> | This operator will be ignored during translation. | 
| Operator<OUT,O extends Operator<OUT,O>> | Base class of all operators in the Java API. | 
| OperatorTranslation | Used for translating data sets into corresponding operators. | 
| PartitionOperator<T> | This operator represents a partitioning. | 
| ProjectOperator<IN,OUT extends org.apache.flink.api.java.tuple.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> | A projection of  DataSet. | 
| 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. | 
| 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). | 
| UnionOperator<T> | Java API operator for union of two data sets. | 
| UnsortedGrouping<T> | A  Groupingthat is unsorted. | 
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.