IN
- The type of the data set reduced by the operator.@Public public class ReduceOperator<IN> extends SingleInputUdfOperator<IN,IN,ReduceOperator<IN>>
ReduceFunction
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
ReduceOperator(DataSet<IN> input,
ReduceFunction<IN> function,
String defaultName)
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
|
ReduceOperator(Grouping<IN> input,
ReduceFunction<IN> function,
String defaultName) |
Modifier and Type | Method and Description |
---|---|
protected ReduceFunction<IN> |
getFunction() |
SingleInputSemanticProperties |
getSemanticProperties()
Gets the semantic properties that have been set for the user-defined functions (UDF).
|
ReduceOperator<IN> |
setCombineHint(ReduceOperatorBase.CombineHint strategy)
Sets the strategy to use for the combine phase of the reduce.
|
protected SingleInputOperator<?,IN,?> |
translateToDataFlow(Operator<IN> input)
Translates this operation to a data flow operator of the common data flow API.
|
extractSemanticAnnotations, getAnalyzedUdfSemanticsFlag, getBroadcastSets, getParameters, 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
public ReduceOperator(DataSet<IN> input, ReduceFunction<IN> function, String defaultName)
input
- function
- public ReduceOperator(Grouping<IN> input, ReduceFunction<IN> function, String defaultName)
protected ReduceFunction<IN> getFunction()
getFunction
in class SingleInputUdfOperator<IN,IN,ReduceOperator<IN>>
@Internal public SingleInputSemanticProperties getSemanticProperties()
UdfOperator
getSemanticProperties
in interface UdfOperator<ReduceOperator<IN>>
getSemanticProperties
in class SingleInputUdfOperator<IN,IN,ReduceOperator<IN>>
protected SingleInputOperator<?,IN,?> translateToDataFlow(Operator<IN> input)
SingleInputOperator
translateToDataFlow
in class SingleInputOperator<IN,IN,ReduceOperator<IN>>
input
- The data flow operator that produces this operation's input data.@PublicEvolving public ReduceOperator<IN> setCombineHint(ReduceOperatorBase.CombineHint strategy)
If this method is not called, then the default hint will be used. (ReduceOperatorBase.CombineHint.OPTIMIZER_CHOOSES
)
strategy
- The hint to use.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.