Package | Description |
---|---|
org.apache.flink.api.java | |
org.apache.flink.api.java.operators | |
org.apache.flink.api.java.operators.join | |
org.apache.flink.api.java.utils |
Modifier and Type | Method and Description |
---|---|
<X> DataSet<X> |
DataSet.runOperation(CustomUnaryOperation<T,X> operation)
Deprecated.
Runs a
CustomUnaryOperation on the data set. |
Modifier and Type | Method and Description |
---|---|
protected static void |
DataSet.checkSameExecutionContext(DataSet<?> set1,
DataSet<?> set2)
Deprecated.
|
protected static void |
DataSet.checkSameExecutionContext(DataSet<?> set1,
DataSet<?> set2)
Deprecated.
|
<R> CoGroupOperator.CoGroupOperatorSets<T,R> |
DataSet.coGroup(DataSet<R> other)
Deprecated.
Initiates a CoGroup transformation.
|
<R> CrossOperator.DefaultCross<T,R> |
DataSet.cross(DataSet<R> other)
Deprecated.
Initiates a Cross transformation.
|
<R> CrossOperator.DefaultCross<T,R> |
DataSet.crossWithHuge(DataSet<R> other)
Deprecated.
Initiates a Cross transformation.
|
<R> CrossOperator.DefaultCross<T,R> |
DataSet.crossWithTiny(DataSet<R> other)
Deprecated.
Initiates a Cross transformation.
|
<R> JoinOperatorSetsBase<T,R> |
DataSet.fullOuterJoin(DataSet<R> other)
Deprecated.
Initiates a Full Outer Join transformation.
|
<R> JoinOperatorSetsBase<T,R> |
DataSet.fullOuterJoin(DataSet<R> other,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint strategy)
Deprecated.
Initiates a Full Outer Join transformation.
|
<R> DeltaIteration<T,R> |
DataSet.iterateDelta(DataSet<R> workset,
int maxIterations,
int... keyPositions)
Deprecated.
Initiates a delta iteration.
|
<R> JoinOperator.JoinOperatorSets<T,R> |
DataSet.join(DataSet<R> other)
Deprecated.
Initiates a Join transformation.
|
<R> JoinOperator.JoinOperatorSets<T,R> |
DataSet.join(DataSet<R> other,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint strategy)
Deprecated.
Initiates a Join transformation.
|
<R> JoinOperator.JoinOperatorSets<T,R> |
DataSet.joinWithHuge(DataSet<R> other)
Deprecated.
Initiates a Join transformation.
|
<R> JoinOperator.JoinOperatorSets<T,R> |
DataSet.joinWithTiny(DataSet<R> other)
Deprecated.
Initiates a Join transformation.
|
<R> JoinOperatorSetsBase<T,R> |
DataSet.leftOuterJoin(DataSet<R> other)
Deprecated.
Initiates a Left Outer Join transformation.
|
<R> JoinOperatorSetsBase<T,R> |
DataSet.leftOuterJoin(DataSet<R> other,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint strategy)
Deprecated.
Initiates a Left Outer Join transformation.
|
<R> JoinOperatorSetsBase<T,R> |
DataSet.rightOuterJoin(DataSet<R> other)
Deprecated.
Initiates a Right Outer Join transformation.
|
<R> JoinOperatorSetsBase<T,R> |
DataSet.rightOuterJoin(DataSet<R> other,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint strategy)
Deprecated.
Initiates a Right Outer Join transformation.
|
UnionOperator<T> |
DataSet.union(DataSet<T> other)
Deprecated.
Creates a union of this DataSet with an other DataSet.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateOperator<IN>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
BulkIterationResultSet<T>
Resulting
DataSet of bulk iterations. |
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
CoGroupRawOperator<I1,I2,OUT>
A
DataSet that is the result of a CoGroup transformation. |
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
static class |
CrossOperator.DefaultCross<I1,I2>
Deprecated.
A Cross transformation that wraps pairs of crossed elements into
Tuple2 . |
static class |
CrossOperator.ProjectCross<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple>
Deprecated.
A Cross transformation that projects crossing elements or fields of crossing
Tuples into result Tuples . |
class |
DataSource<OUT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
static class |
DeltaIteration.SolutionSetPlaceHolder<ST>
Deprecated.
A
DataSet that acts as a placeholder for the solution set during the iteration. |
static class |
DeltaIteration.WorksetPlaceHolder<WT>
Deprecated.
A
DataSet that acts as a placeholder for the workset during the iteration. |
class |
DeltaIterationResultSet<ST,WT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
DistinctOperator<T>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
FilterOperator<T>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
FlatMapOperator<IN,OUT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
GroupCombineOperator<IN,OUT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
GroupReduceOperator<IN,OUT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
IterativeDataSet<T>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
static class |
JoinOperator.DefaultJoin<I1,I2>
Deprecated.
A Join transformation that wraps pairs of joining elements into
Tuple2 . |
static class |
JoinOperator.EquiJoin<I1,I2,OUT>
Deprecated.
A Join transformation that applies a
JoinFunction on each pair of joining elements. |
static class |
JoinOperator.ProjectJoin<I1,I2,OUT extends org.apache.flink.api.java.tuple.Tuple>
Deprecated.
A Join transformation that projects joining elements or fields of joining
Tuples into result Tuples . |
class |
MapOperator<IN,OUT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
MapPartitionOperator<IN,OUT>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
NoOpOperator<IN>
This operator will be ignored during translation.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
PartitionOperator<T>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
ReduceOperator<IN>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
SortPartitionOperator<T>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
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. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
class |
UnionOperator<T>
Deprecated.
All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a
future Flink major version. You can still build your application in DataSet, but you should
move to either the DataStream and/or Table API.
|
Modifier and Type | Field and Description |
---|---|
protected DataSet<T> |
Grouping.inputDataSet
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
DataSet<ST> |
DeltaIteration.closeWith(DataSet<ST> solutionSetDelta,
DataSet<WT> newWorkset)
Deprecated.
Closes the delta iteration.
|
DataSet<T> |
IterativeDataSet.closeWith(DataSet<T> iterationResult)
Deprecated.
Closes the iteration.
|
DataSet<T> |
IterativeDataSet.closeWith(DataSet<T> iterationResult,
DataSet<?> terminationCriterion)
Deprecated.
Closes the iteration and specifies a termination criterion.
|
DataSet<OUT> |
CustomUnaryOperation.createResult()
Deprecated.
|
DataSet<T> |
DataSink.getDataSet()
Deprecated.
|
DataSet<ST> |
DeltaIteration.getInitialSolutionSet()
Deprecated.
Gets the initial solution set.
|
DataSet<WT> |
DeltaIteration.getInitialWorkset()
Deprecated.
Gets the initial workset.
|
DataSet<IN> |
SingleInputOperator.getInput()
Deprecated.
Gets the data set that this operation uses as its input.
|
DataSet<IN> |
NoOpOperator.getInput() |
DataSet<IN1> |
TwoInputOperator.getInput1()
Deprecated.
Gets the data set that this operation uses as its first input.
|
DataSet<IN2> |
TwoInputOperator.getInput2()
Deprecated.
Gets the data set that this operation uses as its second input.
|
DataSet<T> |
Grouping.getInputDataSet()
Deprecated.
Returns the input DataSet of a grouping operation, that is the one before the grouping.
|
DataSet<T> |
BulkIterationResultSet.getNextPartialSolution() |
DataSet<ST> |
DeltaIterationResultSet.getNextSolutionSet()
Deprecated.
|
DataSet<WT> |
DeltaIterationResultSet.getNextWorkset()
Deprecated.
|
DataSet<?> |
BulkIterationResultSet.getTerminationCriterion() |
Modifier and Type | Method and Description |
---|---|
Map<String,DataSet<?>> |
UdfOperator.getBroadcastSets()
Deprecated.
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
|
Map<String,DataSet<?>> |
TwoInputUdfOperator.getBroadcastSets()
Deprecated.
|
Map<String,DataSet<?>> |
SingleInputUdfOperator.getBroadcastSets()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
DataSet<ST> |
DeltaIteration.closeWith(DataSet<ST> solutionSetDelta,
DataSet<WT> newWorkset)
Deprecated.
Closes the delta iteration.
|
DataSet<ST> |
DeltaIteration.closeWith(DataSet<ST> solutionSetDelta,
DataSet<WT> newWorkset)
Deprecated.
Closes the delta iteration.
|
DataSet<T> |
IterativeDataSet.closeWith(DataSet<T> iterationResult)
Deprecated.
Closes the iteration.
|
DataSet<T> |
IterativeDataSet.closeWith(DataSet<T> iterationResult,
DataSet<?> terminationCriterion)
Deprecated.
Closes the iteration and specifies a termination criterion.
|
DataSet<T> |
IterativeDataSet.closeWith(DataSet<T> iterationResult,
DataSet<?> terminationCriterion)
Deprecated.
Closes the iteration and specifies a termination criterion.
|
void |
NoOpOperator.setInput(DataSet<IN> input) |
void |
CustomUnaryOperation.setInput(DataSet<IN> inputData)
Deprecated.
|
O |
UdfOperator.withBroadcastSet(DataSet<?> data,
String name)
Deprecated.
Adds a certain data set as a broadcast set to this operator.
|
O |
TwoInputUdfOperator.withBroadcastSet(DataSet<?> data,
String name)
Deprecated.
|
O |
SingleInputUdfOperator.withBroadcastSet(DataSet<?> data,
String name)
Deprecated.
|
Constructor and Description |
---|
AggregateOperator(DataSet<IN> input,
Aggregations function,
int field,
String aggregateLocationName)
Deprecated.
Non grouped aggregation.
|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
List<org.apache.commons.lang3.tuple.Pair<Integer,org.apache.flink.api.common.operators.Order>> groupSortKeyOrderFirst,
List<org.apache.commons.lang3.tuple.Pair<Integer,org.apache.flink.api.common.operators.Order>> groupSortKeyOrderSecond,
org.apache.flink.api.common.functions.Partitioner<?> customPartitioner,
String defaultName)
Deprecated.
|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
List<org.apache.commons.lang3.tuple.Pair<Integer,org.apache.flink.api.common.operators.Order>> groupSortKeyOrderFirst,
List<org.apache.commons.lang3.tuple.Pair<Integer,org.apache.flink.api.common.operators.Order>> groupSortKeyOrderSecond,
org.apache.flink.api.common.functions.Partitioner<?> customPartitioner,
String defaultName)
Deprecated.
|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.functions.Partitioner<?> customPartitioner,
String defaultName)
Deprecated.
|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.functions.Partitioner<?> customPartitioner,
String defaultName)
Deprecated.
|
CoGroupOperatorSets(DataSet<I1> input1,
DataSet<I2> input2) |
CoGroupOperatorSets(DataSet<I1> input1,
DataSet<I2> input2) |
CoGroupRawOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
String defaultName) |
CoGroupRawOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
String defaultName) |
CrossOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.functions.CrossFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint,
String defaultName)
Deprecated.
|
CrossOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.functions.CrossFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint,
String defaultName)
Deprecated.
|
CrossProjection(DataSet<I1> ds1,
DataSet<I2> ds2,
int[] firstFieldIndexes,
int[] secondFieldIndexes,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint) |
CrossProjection(DataSet<I1> ds1,
DataSet<I2> ds2,
int[] firstFieldIndexes,
int[] secondFieldIndexes,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint) |
DataSink(DataSet<T> data,
org.apache.flink.api.common.io.OutputFormat<T> format,
org.apache.flink.api.common.typeinfo.TypeInformation<T> type)
Deprecated.
|
DefaultCross(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint,
String defaultName) |
DefaultCross(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint,
String defaultName) |
DefaultJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
DefaultJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
DeltaIteration(ExecutionEnvironment context,
org.apache.flink.api.common.typeinfo.TypeInformation<ST> type,
DataSet<ST> solutionSet,
DataSet<WT> workset,
org.apache.flink.api.common.operators.Keys<ST> keys,
int maxIterations)
Deprecated.
|
DeltaIteration(ExecutionEnvironment context,
org.apache.flink.api.common.typeinfo.TypeInformation<ST> type,
DataSet<ST> solutionSet,
DataSet<WT> workset,
org.apache.flink.api.common.operators.Keys<ST> keys,
int maxIterations)
Deprecated.
|
DistinctOperator(DataSet<T> input,
org.apache.flink.api.common.operators.Keys<T> keys,
String distinctLocationName)
Deprecated.
|
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> generatedFunction,
org.apache.flink.api.common.functions.JoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> generatedFunction,
org.apache.flink.api.common.functions.JoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> generatedFunction,
org.apache.flink.api.common.functions.JoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> generatedFunction,
org.apache.flink.api.common.functions.JoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
EquiJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
String joinLocationName,
JoinType type) |
FilterOperator(DataSet<T> input,
org.apache.flink.api.common.functions.FilterFunction<T> function,
String defaultName)
Deprecated.
|
FlatMapOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.functions.FlatMapFunction<IN,OUT> function,
String defaultName)
Deprecated.
|
GroupCombineOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.functions.GroupCombineFunction<IN,OUT> function,
String defaultName)
Deprecated.
Constructor for a non-grouped reduce (all reduce).
|
Grouping(DataSet<T> set,
org.apache.flink.api.common.operators.Keys<T> keys)
Deprecated.
|
GroupReduceOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.functions.GroupReduceFunction<IN,OUT> function,
String defaultName)
Deprecated.
Constructor for a non-grouped reduce (all reduce).
|
IterativeDataSet(ExecutionEnvironment context,
org.apache.flink.api.common.typeinfo.TypeInformation<T> type,
DataSet<T> input,
int maxIterations)
Deprecated.
|
JoinOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
JoinType type)
Deprecated.
|
JoinOperator(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> returnType,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
JoinType type)
Deprecated.
|
JoinOperatorSets(DataSet<I1> input1,
DataSet<I2> input2) |
JoinOperatorSets(DataSet<I1> input1,
DataSet<I2> input2) |
JoinOperatorSets(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint) |
JoinOperatorSets(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint) |
MapOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.functions.MapFunction<IN,OUT> function,
String defaultName)
Deprecated.
|
MapPartitionOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.functions.MapPartitionFunction<IN,OUT> function,
String defaultName)
Deprecated.
|
NoOpOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<IN> resultType) |
PartitionOperator(DataSet<T> input,
org.apache.flink.api.common.operators.Keys<T> pKeys,
org.apache.flink.api.common.functions.Partitioner<?> customPartitioner,
String partitionLocationName)
Deprecated.
|
PartitionOperator(DataSet<T> input,
org.apache.flink.api.common.operators.Keys<T> pKeys,
org.apache.flink.api.common.functions.Partitioner<P> customPartitioner,
org.apache.flink.api.common.typeinfo.TypeInformation<P> partitionerTypeInfo,
String partitionLocationName)
Deprecated.
|
PartitionOperator(DataSet<T> input,
org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod pMethod,
org.apache.flink.api.common.operators.Keys<T> pKeys,
org.apache.flink.api.common.distributions.DataDistribution distribution,
String partitionLocationName)
Deprecated.
|
PartitionOperator(DataSet<T> input,
org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod pMethod,
org.apache.flink.api.common.operators.Keys<T> pKeys,
String partitionLocationName)
Deprecated.
|
PartitionOperator(DataSet<T> input,
org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod pMethod,
String partitionLocationName)
Deprecated.
|
ProjectCross(DataSet<I1> input1,
DataSet<I2> input2,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType,
CrossOperator.CrossProjection<I1,I2> crossProjection,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint) |
ProjectCross(DataSet<I1> input1,
DataSet<I2> input2,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType,
CrossOperator.CrossProjection<I1,I2> crossProjection,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint) |
ProjectCross(DataSet<I1> input1,
DataSet<I2> input2,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint) |
ProjectCross(DataSet<I1> input1,
DataSet<I2> input2,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType,
org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint hint) |
Projection(DataSet<T> ds,
int[] fieldIndexes) |
ProjectJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType) |
ProjectJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType) |
ProjectJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType,
org.apache.flink.api.java.operators.JoinOperator.JoinProjection<I1,I2> joinProj) |
ProjectJoin(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.Keys<I1> keys1,
org.apache.flink.api.common.operators.Keys<I2> keys2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
int[] fields,
boolean[] isFromFirst,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType,
org.apache.flink.api.java.operators.JoinOperator.JoinProjection<I1,I2> joinProj) |
ProjectOperator(DataSet<IN> input,
int[] fields,
org.apache.flink.api.java.typeutils.TupleTypeInfo<OUT> returnType)
Deprecated.
|
ReduceOperator(DataSet<IN> input,
org.apache.flink.api.common.functions.ReduceFunction<IN> function,
String defaultName)
Deprecated.
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
|
SingleInputOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)
Deprecated.
|
SingleInputUdfOperator(DataSet<IN> input,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)
Deprecated.
Creates a new operators with the given data set as input.
|
SortedGrouping(DataSet<T> set,
org.apache.flink.api.common.operators.Keys<T> keys,
int field,
org.apache.flink.api.common.operators.Order order)
Deprecated.
|
SortedGrouping(DataSet<T> set,
org.apache.flink.api.common.operators.Keys<T> keys,
org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys<T,K> keySelector,
org.apache.flink.api.common.operators.Order order)
Deprecated.
|
SortedGrouping(DataSet<T> set,
org.apache.flink.api.common.operators.Keys<T> keys,
String field,
org.apache.flink.api.common.operators.Order order)
Deprecated.
|
SortPartitionOperator(DataSet<T> dataSet,
int sortField,
org.apache.flink.api.common.operators.Order sortOrder,
String sortLocationName)
Deprecated.
|
SortPartitionOperator(DataSet<T> dataSet,
org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys<T,K> sortKey,
org.apache.flink.api.common.operators.Order sortOrder,
String sortLocationName)
Deprecated.
|
SortPartitionOperator(DataSet<T> dataSet,
String sortField,
org.apache.flink.api.common.operators.Order sortOrder,
String sortLocationName)
Deprecated.
|
TwoInputOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)
Deprecated.
|
TwoInputOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)
Deprecated.
|
TwoInputUdfOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)
Deprecated.
Creates a new operators with the two given data sets as inputs.
|
TwoInputUdfOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType)
Deprecated.
Creates a new operators with the two given data sets as inputs.
|
UnionOperator(DataSet<T> input1,
DataSet<T> input2,
String unionLocationName)
Deprecated.
Create an operator that produces the union of the two given data sets.
|
UnionOperator(DataSet<T> input1,
DataSet<T> input2,
String unionLocationName)
Deprecated.
Create an operator that produces the union of the two given data sets.
|
UnsortedGrouping(DataSet<T> set,
org.apache.flink.api.common.operators.Keys<T> keys)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected DataSet<I1> |
JoinOperatorSetsBase.input1
Deprecated.
|
protected DataSet<I2> |
JoinOperatorSetsBase.input2
Deprecated.
|
Constructor and Description |
---|
JoinOperatorSetsBase(DataSet<I1> input1,
DataSet<I2> input2)
Deprecated.
|
JoinOperatorSetsBase(DataSet<I1> input1,
DataSet<I2> input2)
Deprecated.
|
JoinOperatorSetsBase(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint)
Deprecated.
|
JoinOperatorSetsBase(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint)
Deprecated.
|
JoinOperatorSetsBase(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
JoinType type)
Deprecated.
|
JoinOperatorSetsBase(DataSet<I1> input1,
DataSet<I2> input2,
org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint hint,
JoinType type)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static <T> DataSet<org.apache.flink.api.java.tuple.Tuple2<Integer,Long>> |
DataSetUtils.countElementsPerPartition(DataSet<T> input)
Deprecated.
Method that goes over all the elements in each partition in order to retrieve the total
number of elements.
|
static <T> DataSet<T> |
DataSetUtils.sampleWithSize(DataSet<T> input,
boolean withReplacement,
int numSamples)
Deprecated.
Generate a sample of DataSet which contains fixed size elements.
|
static <T> DataSet<T> |
DataSetUtils.sampleWithSize(DataSet<T> input,
boolean withReplacement,
int numSamples,
long seed)
Deprecated.
Generate a sample of DataSet which contains fixed size elements.
|
static <T> DataSet<org.apache.flink.api.java.tuple.Tuple2<Long,T>> |
DataSetUtils.zipWithIndex(DataSet<T> input)
Deprecated.
Method that assigns a unique
Long value to all elements in the input data set. |
static <T> DataSet<org.apache.flink.api.java.tuple.Tuple2<Long,T>> |
DataSetUtils.zipWithUniqueId(DataSet<T> input)
Deprecated.
Method that assigns a unique
Long value to all elements in the input data set as
described below. |
Modifier and Type | Method and Description |
---|---|
static <T> Utils.ChecksumHashCode |
DataSetUtils.checksumHashCode(DataSet<T> input)
Deprecated.
This method will be removed at some point.
|
static <T> DataSet<org.apache.flink.api.java.tuple.Tuple2<Integer,Long>> |
DataSetUtils.countElementsPerPartition(DataSet<T> input)
Deprecated.
Method that goes over all the elements in each partition in order to retrieve the total
number of elements.
|
static <T> PartitionOperator<T> |
DataSetUtils.partitionByRange(DataSet<T> input,
org.apache.flink.api.common.distributions.DataDistribution distribution,
int... fields)
Deprecated.
Range-partitions a DataSet on the specified tuple field positions.
|
static <T,K extends Comparable<K>> |
DataSetUtils.partitionByRange(DataSet<T> input,
org.apache.flink.api.common.distributions.DataDistribution distribution,
org.apache.flink.api.java.functions.KeySelector<T,K> keyExtractor)
Deprecated.
Range-partitions a DataSet using the specified key selector function.
|
static <T> PartitionOperator<T> |
DataSetUtils.partitionByRange(DataSet<T> input,
org.apache.flink.api.common.distributions.DataDistribution distribution,
String... fields)
Deprecated.
Range-partitions a DataSet on the specified fields.
|
static <T> MapPartitionOperator<T,T> |
DataSetUtils.sample(DataSet<T> input,
boolean withReplacement,
double fraction)
Deprecated.
Generate a sample of DataSet by the probability fraction of each element.
|
static <T> MapPartitionOperator<T,T> |
DataSetUtils.sample(DataSet<T> input,
boolean withReplacement,
double fraction,
long seed)
Deprecated.
Generate a sample of DataSet by the probability fraction of each element.
|
static <T> DataSet<T> |
DataSetUtils.sampleWithSize(DataSet<T> input,
boolean withReplacement,
int numSamples)
Deprecated.
Generate a sample of DataSet which contains fixed size elements.
|
static <T> DataSet<T> |
DataSetUtils.sampleWithSize(DataSet<T> input,
boolean withReplacement,
int numSamples,
long seed)
Deprecated.
Generate a sample of DataSet which contains fixed size elements.
|
static <R extends org.apache.flink.api.java.tuple.Tuple,T extends org.apache.flink.api.java.tuple.Tuple> |
DataSetUtils.summarize(DataSet<T> input)
Deprecated.
Summarize a DataSet of Tuples by collecting single pass statistics for all columns.
|
static <T> DataSet<org.apache.flink.api.java.tuple.Tuple2<Long,T>> |
DataSetUtils.zipWithIndex(DataSet<T> input)
Deprecated.
Method that assigns a unique
Long value to all elements in the input data set. |
static <T> DataSet<org.apache.flink.api.java.tuple.Tuple2<Long,T>> |
DataSetUtils.zipWithUniqueId(DataSet<T> input)
Deprecated.
Method that assigns a unique
Long value to all elements in the input data set as
described below. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.