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 InputTypeStrategy |
LegacyUserDefinedFunctionInference.getInputTypeStrategy(ImperativeAggregateFunction<?,?> func) |
Deprecated.
|
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.
|