| BooleanSummaryAggregator |
|
| CompensatedSum |
Used to calculate sums using the Kahan summation algorithm
The Kahan summation algorithm (also known as compensated summation) reduces the numerical errors that
occur when adding a sequence of finite precision floating point numbers.
|
| DoubleSummaryAggregator |
Aggregator that can handle Double types
|
| DoubleSummaryAggregator.MaxDoubleAggregator |
|
| DoubleSummaryAggregator.MinDoubleAggregator |
|
| DoubleSummaryAggregator.SumDoubleAggregator |
|
| FloatSummaryAggregator |
Aggregator that can handle Float types
|
| FloatSummaryAggregator.MaxFloatAggregator |
|
| FloatSummaryAggregator.MinFloatAggregator |
|
| FloatSummaryAggregator.SumFloatAggregator |
|
| IntegerSummaryAggregator |
Aggregator that can handle Integer types
|
| IntegerSummaryAggregator.MaxIntegerAggregator |
|
| IntegerSummaryAggregator.MinIntegerAggregator |
|
| IntegerSummaryAggregator.SumIntegerAggregator |
|
| LongSummaryAggregator |
Aggregator that can handle Long types
|
| LongSummaryAggregator.MaxLongAggregator |
|
| LongSummaryAggregator.MinLongAggregator |
|
| LongSummaryAggregator.SumLongAggregator |
|
| NumericSummaryAggregator<T extends Number> |
Generic aggregator for all numeric types creates a summary of a column of numbers.
|
| ObjectSummaryAggregator |
|
| ShortSummaryAggregator |
Aggregator that can handle Short types
|
| ShortSummaryAggregator.MaxShortAggregator |
|
| ShortSummaryAggregator.MinShortAggregator |
|
| ShortSummaryAggregator.SumShortAggregator |
|
| StringSummaryAggregator |
|
| SummaryAggregatorFactory |
Factory for creating Summary Aggregators
|
| TupleSummaryAggregator<R extends org.apache.flink.api.java.tuple.Tuple> |
Aggregate tuples using an array of aggregators, one for each "column" or position within the Tuple.
|
| ValueSummaryAggregator<VT extends org.apache.flink.types.Value,PT,R,A extends Aggregator<PT,R>> |
This is a generic Aggregator for Value types like StringValue, DoubleValue, etc.
|
| ValueSummaryAggregator.BooleanValueSummaryAggregator |
|
| ValueSummaryAggregator.DoubleValueSummaryAggregator |
|
| ValueSummaryAggregator.FloatValueSummaryAggregator |
|
| ValueSummaryAggregator.IntegerValueSummaryAggregator |
|
| ValueSummaryAggregator.LongValueSummaryAggregator |
|
| ValueSummaryAggregator.ShortValueSummaryAggregator |
|
| ValueSummaryAggregator.StringValueSummaryAggregator |
|