IN1
- The data type of the first input data set.IN2
- The data type of the second input data set.OUT
- The data type of the returned data set.@Deprecated @Public public abstract class TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> extends Operator<OUT,O>
minResources, name, parallelism, preferredResources
Modifier | Constructor and Description |
---|---|
protected |
TwoInputOperator(DataSet<IN1> input1,
DataSet<IN2> input2,
TypeInformation<OUT> resultType)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
DataSet<IN1> |
getInput1()
Deprecated.
Gets the data set that this operation uses as its first input.
|
TypeInformation<IN1> |
getInput1Type()
Deprecated.
Gets the type information of the data type of the first input data set.
|
DataSet<IN2> |
getInput2()
Deprecated.
Gets the data set that this operation uses as its second input.
|
TypeInformation<IN2> |
getInput2Type()
Deprecated.
Gets the type information of the data type of the second input data set.
|
protected abstract Operator<OUT> |
translateToDataFlow(Operator<IN1> input1,
Operator<IN2> input2)
Deprecated.
Translates this java API operator into a common API operator with two inputs.
|
getMinResources, getName, getParallelism, getPreferredResources, getResultType, name, setParallelism
aggregate, checkSameExecutionContext, clean, coGroup, collect, combineGroup, count, cross, crossWithHuge, crossWithTiny, distinct, distinct, distinct, distinct, fillInType, filter, first, flatMap, fullOuterJoin, fullOuterJoin, getExecutionEnvironment, getType, groupBy, groupBy, groupBy, iterate, iterateDelta, join, join, joinWithHuge, joinWithTiny, leftOuterJoin, leftOuterJoin, map, mapPartition, max, maxBy, min, minBy, output, partitionByHash, partitionByHash, partitionByHash, partitionByRange, partitionByRange, partitionByRange, partitionCustom, partitionCustom, partitionCustom, print, print, printOnTaskManager, printToErr, printToErr, project, rebalance, reduce, reduceGroup, rightOuterJoin, rightOuterJoin, runOperation, sortPartition, sortPartition, sortPartition, sum, union, write, write, writeAsCsv, writeAsCsv, writeAsCsv, writeAsCsv, writeAsFormattedText, writeAsFormattedText, writeAsText, writeAsText
public DataSet<IN1> getInput1()
public DataSet<IN2> getInput2()
public TypeInformation<IN1> getInput1Type()
getInput1().getType()
.public TypeInformation<IN2> getInput2Type()
getInput2().getType()
.protected abstract Operator<OUT> translateToDataFlow(Operator<IN1> input1, Operator<IN2> input2)
input1
- The first input of the operation, as a common API operator.input2
- The second input of the operation, as a common API operator.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.