IN
- The type of the data set projected by the operator.OUT
- The type of data set that is the result of the projection.@Deprecated @Public public class ProjectOperator<IN,OUT extends Tuple> extends SingleInputOperator<IN,OUT,ProjectOperator<IN,OUT>>
Modifier and Type | Class and Description |
---|---|
static class |
ProjectOperator.Projection<T>
Deprecated.
A projection of
DataSet . |
Modifier and Type | Field and Description |
---|---|
protected int[] |
fields
Deprecated.
|
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
ProjectOperator(DataSet<IN> input,
int[] fields,
TupleTypeInfo<OUT> returnType)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected MapOperatorBase<IN,OUT,MapFunction<IN,OUT>> |
translateToDataFlow(Operator<IN> input)
Deprecated.
Translates this operation to a data flow operator of the common data flow API.
|
<R extends Tuple> |
types(Class<?>... types)
Deprecated.
Deprecated method only kept for compatibility.
|
getInput, getInputType
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 ProjectOperator(DataSet<IN> input, int[] fields, TupleTypeInfo<OUT> returnType)
protected MapOperatorBase<IN,OUT,MapFunction<IN,OUT>> translateToDataFlow(Operator<IN> input)
SingleInputOperator
translateToDataFlow
in class SingleInputOperator<IN,OUT extends Tuple,ProjectOperator<IN,OUT extends Tuple>>
input
- The data flow operator that produces this operation's input data.@Deprecated @PublicEvolving public <R extends Tuple> ProjectOperator<IN,R> types(Class<?>... types)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.