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