Uses of Class
org.apache.flink.table.functions.AggregateFunction
-
Packages that use AggregateFunction Package Description org.apache.flink.table.functions org.apache.flink.table.functions.python org.apache.flink.table.types.extraction -
-
Uses of AggregateFunction in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions that return AggregateFunction Modifier and Type Method Description AggregateFunction<?,?>
AggregateFunctionDefinition. getAggregateFunction()
Deprecated.Constructors in org.apache.flink.table.functions with parameters of type AggregateFunction Constructor Description AggregateFunctionDefinition(String name, AggregateFunction<?,?> aggregateFunction, org.apache.flink.api.common.typeinfo.TypeInformation<?> resultTypeInfo, org.apache.flink.api.common.typeinfo.TypeInformation<?> accTypeInfo)
Deprecated. -
Uses of AggregateFunction in org.apache.flink.table.functions.python
Subclasses of AggregateFunction in org.apache.flink.table.functions.python Modifier and Type Class Description class
PythonAggregateFunction
The wrapper of user defined python aggregate function. -
Uses of AggregateFunction in org.apache.flink.table.types.extraction
Method parameters in org.apache.flink.table.types.extraction with type arguments of type AggregateFunction Modifier and Type Method Description static TypeInference
TypeInferenceExtractor. forAggregateFunction(DataTypeFactory typeFactory, Class<? extends AggregateFunction<?,?>> function)
Extracts a type inference from aAggregateFunction
.
-