@PublicEvolving public final class AggregateFunctionDefinition extends Object implements FunctionDefinition
This class can be dropped once we introduce a new type inference.
构造器和说明 |
---|
AggregateFunctionDefinition(String name,
AggregateFunction<?,?> aggregateFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<?> resultTypeInfo,
org.apache.flink.api.common.typeinfo.TypeInformation<?> accTypeInfo) |
限定符和类型 | 方法和说明 |
---|---|
boolean |
equals(Object o) |
org.apache.flink.api.common.typeinfo.TypeInformation<?> |
getAccumulatorTypeInfo() |
AggregateFunction<?,?> |
getAggregateFunction() |
FunctionKind |
getKind()
Returns the kind of function this definition describes.
|
String |
getName() |
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 String getName()
public AggregateFunction<?,?> getAggregateFunction()
public org.apache.flink.api.common.typeinfo.TypeInformation<?> getResultTypeInfo()
public org.apache.flink.api.common.typeinfo.TypeInformation<?> getAccumulatorTypeInfo()
public FunctionKind getKind()
FunctionDefinition
getKind
在接口中 FunctionDefinition
public Set<FunctionRequirement> getRequirements()
FunctionDefinition
getRequirements
在接口中 FunctionDefinition
public boolean isDeterministic()
FunctionDefinition
It 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
在接口中 FunctionDefinition
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.