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 GroupCombineOperator<IN,OUT> extends SingleInputUdfOperator<IN,OUT,GroupCombineOperator<IN,OUT>>
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
GroupCombineOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
GroupCombineFunction<IN,OUT> function,
String defaultName)
Deprecated.
Constructor for a non-grouped reduce (all reduce).
|
GroupCombineOperator(Grouping<IN> input,
TypeInformation<OUT> resultType,
GroupCombineFunction<IN,OUT> function,
String defaultName)
Deprecated.
Constructor for a grouped reduce.
|
Modifier and Type | Method and Description |
---|---|
protected GroupCombineFunction<IN,OUT> |
getFunction()
Deprecated.
|
SingleInputSemanticProperties |
getSemanticProperties()
Deprecated.
Gets the semantic properties that have been set for the user-defined functions (UDF).
|
protected GroupCombineOperatorBase<?,OUT,?> |
translateToDataFlow(Operator<IN> input)
Deprecated.
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 GroupCombineOperator(DataSet<IN> input, TypeInformation<OUT> resultType, GroupCombineFunction<IN,OUT> function, String defaultName)
input
- The input data set to the groupReduce function.resultType
- The type information for the resulting type.function
- The user-defined GroupReduce function.defaultName
- The operator's name.public GroupCombineOperator(Grouping<IN> input, TypeInformation<OUT> resultType, GroupCombineFunction<IN,OUT> function, String defaultName)
input
- The grouped input to be processed group-wise by the groupReduce function.function
- The user-defined GroupReduce function.protected GroupCombineFunction<IN,OUT> getFunction()
getFunction
in class SingleInputUdfOperator<IN,OUT,GroupCombineOperator<IN,OUT>>
@Internal public SingleInputSemanticProperties getSemanticProperties()
UdfOperator
getSemanticProperties
in interface UdfOperator<GroupCombineOperator<IN,OUT>>
getSemanticProperties
in class SingleInputUdfOperator<IN,OUT,GroupCombineOperator<IN,OUT>>
protected GroupCombineOperatorBase<?,OUT,?> translateToDataFlow(Operator<IN> input)
SingleInputOperator
translateToDataFlow
in class SingleInputOperator<IN,OUT,GroupCombineOperator<IN,OUT>>
input
- The data flow operator that produces this operation's input data.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.