IN
- The type of the data set consumed by the operator.OUT
- The type of the data set created by the operator.@Deprecated @Public public class MapPartitionOperator<IN,OUT> extends SingleInputUdfOperator<IN,OUT,MapPartitionOperator<IN,OUT>>
Modifier and Type | Field and Description |
---|---|
protected String |
defaultName
Deprecated.
|
protected MapPartitionFunction<IN,OUT> |
function
Deprecated.
|
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
MapPartitionOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
MapPartitionFunction<IN,OUT> function,
String defaultName)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected MapPartitionFunction<IN,OUT> |
getFunction()
Deprecated.
|
protected MapPartitionOperatorBase<IN,OUT,MapPartitionFunction<IN,OUT>> |
translateToDataFlow(Operator<IN> input)
Deprecated.
Translates this operation to a data flow operator of the common data flow API.
|
extractSemanticAnnotations, getAnalyzedUdfSemanticsFlag, getBroadcastSets, getParameters, getSemanticProperties, returns, returns, returns, setAnalyzedUdfSemanticsFlag, setSemanticProperties, udfWithForwardedFieldsAnnotation, withBroadcastSet, withForwardedFields, withParameters
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
protected final MapPartitionFunction<IN,OUT> function
protected final String defaultName
public MapPartitionOperator(DataSet<IN> input, TypeInformation<OUT> resultType, MapPartitionFunction<IN,OUT> function, String defaultName)
protected MapPartitionFunction<IN,OUT> getFunction()
getFunction
in class SingleInputUdfOperator<IN,OUT,MapPartitionOperator<IN,OUT>>
protected MapPartitionOperatorBase<IN,OUT,MapPartitionFunction<IN,OUT>> translateToDataFlow(Operator<IN> input)
SingleInputOperator
translateToDataFlow
in class SingleInputOperator<IN,OUT,MapPartitionOperator<IN,OUT>>
input
- The data flow operator that produces this operation's input data.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.