| 程序包 | 说明 |
|---|---|
| org.apache.flink.table.functions | |
| org.apache.flink.table.types.extraction |
| 限定符和类型 | 方法和说明 |
|---|---|
TableAggregateFunction<?,?> |
TableAggregateFunctionDefinition.getTableAggregateFunction() |
| 构造器和说明 |
|---|
TableAggregateFunctionDefinition(String name,
TableAggregateFunction<?,?> aggregateFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<?> resultTypeInfo,
org.apache.flink.api.common.typeinfo.TypeInformation<?> accTypeInfo) |
| 限定符和类型 | 方法和说明 |
|---|---|
static TypeInference |
TypeInferenceExtractor.forTableAggregateFunction(DataTypeFactory typeFactory,
Class<? extends TableAggregateFunction<?,?>> function)
Extracts a type inference from a
TableAggregateFunction. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.