@PublicEvolving public final class AggregateFunctionDefinition extends Object implements FunctionDefinition
This class can be dropped once we introduce a new type inference.
| Constructor and Description |
|---|
AggregateFunctionDefinition(String name,
AggregateFunction<?,?> aggregateFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<?> resultTypeInfo,
org.apache.flink.api.common.typeinfo.TypeInformation<?> accTypeInfo) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
equals(Object o) |
org.apache.flink.api.common.typeinfo.TypeInformation<?> |
getAccumulatorTypeInfo() |
AggregateFunction<?,?> |
getAggregateFunction() |
FunctionKind |
getKind()
Returns the kind of function this definition describes.
|
Set<FunctionRequirement> |
getRequirements()
Returns the set of requirements this definition demands.
|
org.apache.flink.api.common.typeinfo.TypeInformation<?> |
getResultTypeInfo() |
int |
hashCode() |
boolean |
isDeterministic()
Returns information about the determinism of the function's results.
|
String |
toString() |
public AggregateFunctionDefinition(String name, AggregateFunction<?,?> aggregateFunction, org.apache.flink.api.common.typeinfo.TypeInformation<?> resultTypeInfo, org.apache.flink.api.common.typeinfo.TypeInformation<?> accTypeInfo)
public AggregateFunction<?,?> getAggregateFunction()
public org.apache.flink.api.common.typeinfo.TypeInformation<?> getResultTypeInfo()
public org.apache.flink.api.common.typeinfo.TypeInformation<?> getAccumulatorTypeInfo()
public FunctionKind getKind()
FunctionDefinitiongetKind in interface FunctionDefinitionpublic Set<FunctionRequirement> getRequirements()
FunctionDefinitiongetRequirements in interface FunctionDefinitionpublic boolean isDeterministic()
FunctionDefinitionIt returns true if and only if a call to this function is guaranteed to
always return the same result given the same parameters. true is
assumed by default. If the function is not pure functional like random(), date(), now(), ...
this method must return false.
isDeterministic in interface FunctionDefinitionCopyright © 2014–2019 The Apache Software Foundation. All rights reserved.