IN
- The data type of the input data set.OUT
- The data type of the returned data set.@Deprecated @Public public abstract class SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> extends Operator<OUT,O>
minResources, name, parallelism, preferredResources
Modifier | Constructor and Description |
---|---|
protected |
SingleInputOperator(DataSet<IN> input,
TypeInformation<OUT> resultType)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
DataSet<IN> |
getInput()
Deprecated.
Gets the data set that this operation uses as its input.
|
TypeInformation<IN> |
getInputType()
Deprecated.
Gets the type information of the data type of the input data set.
|
protected abstract Operator<OUT> |
translateToDataFlow(Operator<IN> input)
Deprecated.
Translates this operation to a data flow operator of the common data flow API.
|
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
protected SingleInputOperator(DataSet<IN> input, TypeInformation<OUT> resultType)
public DataSet<IN> getInput()
public TypeInformation<IN> getInputType()
getInput().getType()
.protected abstract Operator<OUT> translateToDataFlow(Operator<IN> input)
input
- The data flow operator that produces this operation's input data.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.