| Interface | Description | 
|---|---|
| CustomUnaryOperation<IN,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| UdfOperator<O extends UdfOperator<O>> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| Class | Description | 
|---|---|
| AggregateOperator<IN> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| BulkIterationResultSet<T> | Resulting  DataSetof bulk iterations. | 
| CoGroupOperator<I1,I2,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| 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> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| 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> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| DataSource<OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| DeltaIteration<ST,WT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| 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> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| DistinctOperator<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| FilterOperator<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| FlatMapOperator<IN,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| GroupCombineOperator<IN,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| Grouping<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| GroupReduceOperator<IN,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| IterativeDataSet<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| JoinOperator<I1,I2,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| 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> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| MapPartitionOperator<IN,OUT> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| NoOpOperator<IN> | This operator will be ignored during translation. | 
| Operator<OUT,O extends Operator<OUT,O>> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| OperatorTranslation | Used for translating data sets into corresponding operators. | 
| PartitionOperator<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| ProjectOperator<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| ProjectOperator.Projection<T> | A projection of  DataSet. | 
| ReduceOperator<IN> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| SortedGrouping<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| SortPartitionOperator<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| UnionOperator<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
| UnsortedGrouping<T> | Deprecated All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
     future Flink major version. | 
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.