Class AggregationFunction<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.aggregation.AggregationFunction<T>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.ReduceFunction<T>
- Direct Known Subclasses:
ComparableAggregator,SumAggregator
@Internal public abstract class AggregationFunction<T> extends Object implements org.apache.flink.api.common.functions.ReduceFunction<T>
Holder class for aggregation types that can be used on a windowed stream or keyed stream.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static classAggregationFunction.AggregationTypeAggregation types that can be used on a windowed stream or keyed stream.
-
Constructor Summary
Constructors Constructor Description AggregationFunction()
-