public static final class SumAggregationFunction.LongValueSumAgg extends SumAggregationFunction<org.apache.flink.types.LongValue>
SumAggregationFunction.ByteSumAgg, SumAggregationFunction.ByteValueSumAgg, SumAggregationFunction.DoubleSumAgg, SumAggregationFunction.DoubleValueSumAgg, SumAggregationFunction.FloatSumAgg, SumAggregationFunction.FloatValueSumAgg, SumAggregationFunction.IntSumAgg, SumAggregationFunction.IntValueSumAgg, SumAggregationFunction.LongSumAgg, SumAggregationFunction.LongValueSumAgg, SumAggregationFunction.ShortSumAgg, SumAggregationFunction.ShortValueSumAgg, SumAggregationFunction.SumAggregationFunctionFactory
Constructor and Description |
---|
LongValueSumAgg() |
Modifier and Type | Method and Description |
---|---|
void |
aggregate(org.apache.flink.types.LongValue value) |
org.apache.flink.types.LongValue |
getAggregate() |
void |
initializeAggregate() |
toString
public void initializeAggregate()
initializeAggregate
in class AggregationFunction<org.apache.flink.types.LongValue>
public void aggregate(org.apache.flink.types.LongValue value)
aggregate
in class AggregationFunction<org.apache.flink.types.LongValue>
public org.apache.flink.types.LongValue getAggregate()
getAggregate
in class AggregationFunction<org.apache.flink.types.LongValue>
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.