IN
- The type of the data set aggregated by the operator.@Deprecated @Public public class AggregateOperator<IN> extends SingleInputOperator<IN,IN,AggregateOperator<IN>>
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
AggregateOperator(DataSet<IN> input,
Aggregations function,
int field,
String aggregateLocationName)
Deprecated.
Non grouped aggregation.
|
AggregateOperator(Grouping<IN> input,
Aggregations function,
int field,
String aggregateLocationName)
Deprecated.
Grouped aggregation.
|
Modifier and Type | Method and Description |
---|---|
AggregateOperator<IN> |
and(Aggregations function,
int field)
Deprecated.
|
AggregateOperator<IN> |
andMax(int field)
Deprecated.
|
AggregateOperator<IN> |
andMin(int field)
Deprecated.
|
AggregateOperator<IN> |
andSum(int field)
Deprecated.
|
protected GroupReduceOperatorBase<IN,IN,GroupReduceFunction<IN,IN>> |
translateToDataFlow(Operator<IN> input)
Deprecated.
Translates this operation to a data flow operator of the common data flow API.
|
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 AggregateOperator(DataSet<IN> input, Aggregations function, int field, String aggregateLocationName)
public AggregateOperator(Grouping<IN> input, Aggregations function, int field, String aggregateLocationName)
input
- function
- field
- public AggregateOperator<IN> and(Aggregations function, int field)
public AggregateOperator<IN> andSum(int field)
public AggregateOperator<IN> andMin(int field)
public AggregateOperator<IN> andMax(int field)
@Internal protected GroupReduceOperatorBase<IN,IN,GroupReduceFunction<IN,IN>> translateToDataFlow(Operator<IN> input)
SingleInputOperator
translateToDataFlow
in class SingleInputOperator<IN,IN,AggregateOperator<IN>>
input
- The data flow operator that produces this operation's input data.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.