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