@PublicEvolving public abstract class UserDefinedAggregateFunction<T,ACC> extends UserDefinedFunction
| Constructor and Description |
|---|
UserDefinedAggregateFunction() |
| Modifier and Type | Method and Description |
|---|---|
abstract ACC |
createAccumulator()
Creates and initializes the accumulator for this
UserDefinedAggregateFunction. |
org.apache.flink.api.common.typeinfo.TypeInformation<ACC> |
getAccumulatorType()
Returns the
TypeInformation of the UserDefinedAggregateFunction's accumulator. |
org.apache.flink.api.common.typeinfo.TypeInformation<T> |
getResultType()
Returns the
TypeInformation of the UserDefinedAggregateFunction's result. |
close, functionIdentifier, open, toStringclone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitgetKind, getRequirements, isDeterministicpublic abstract ACC createAccumulator()
UserDefinedAggregateFunction. The
accumulator is used to keep the aggregated values which are needed to compute an aggregation
result.public org.apache.flink.api.common.typeinfo.TypeInformation<T> getResultType()
TypeInformation of the UserDefinedAggregateFunction's result.TypeInformation of the UserDefinedAggregateFunction's result or
null if the result type should be automatically inferred.public org.apache.flink.api.common.typeinfo.TypeInformation<ACC> getAccumulatorType()
TypeInformation of the UserDefinedAggregateFunction's accumulator.TypeInformation of the UserDefinedAggregateFunction's accumulator
or null if the accumulator type should be automatically inferred.Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.