Package | Description |
---|---|
org.apache.flink.table.functions | |
org.apache.flink.table.functions.python |
Modifier and Type | Class and Description |
---|---|
class |
AggregateFunction<T,ACC>
Base class for a user-defined aggregate function.
|
class |
TableAggregateFunction<T,ACC>
Base class for a user-defined table aggregate function.
|
Modifier and Type | Method and Description |
---|---|
static <T,ACC> org.apache.flink.api.common.typeinfo.TypeInformation<ACC> |
UserDefinedFunctionHelper.getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T,ACC> aggregateFunction)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
static <T,ACC> org.apache.flink.api.common.typeinfo.TypeInformation<ACC> |
UserDefinedFunctionHelper.getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T,ACC> aggregateFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<ACC> scalaType)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
static <T,ACC> org.apache.flink.api.common.typeinfo.TypeInformation<T> |
UserDefinedFunctionHelper.getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T,ACC> aggregateFunction)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
static <T,ACC> org.apache.flink.api.common.typeinfo.TypeInformation<T> |
UserDefinedFunctionHelper.getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T,ACC> aggregateFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<T> scalaType)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
Modifier and Type | Class and Description |
---|---|
class |
PythonAggregateFunction
The wrapper of user defined python aggregate function.
|
class |
PythonTableAggregateFunction
The wrapper of user defined python table aggregate function.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.