Package | Description |
---|---|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.functions.aggregation |
Modifier and Type | Method and Description |
---|---|
protected SingleOutputStreamOperator<T> |
KeyedStream.aggregate(AggregationFunction<T> aggregate) |
Modifier and Type | Class and Description |
---|---|
class |
ComparableAggregator<T>
An
AggregationFunction that computes values based on comparisons of Comparables . |
class |
SumAggregator<T>
An
AggregationFunction that sums up fields. |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.