| 限定符和类型 | 方法和说明 |
|---|---|
TableFunction<T> |
TableFunctionProvider.createTableFunction()
Creates a
TableFunction instance. |
| 限定符和类型 | 方法和说明 |
|---|---|
static <T> TableFunctionProvider<T> |
TableFunctionProvider.of(TableFunction<T> tableFunction)
Helper method for creating a static provider.
|
| 限定符和类型 | 类和说明 |
|---|---|
class |
TemporalTableFunction
Class representing temporal table function over some history table.
|
| 限定符和类型 | 方法和说明 |
|---|---|
TableFunction<?> |
TableFunctionDefinition.getTableFunction() |
| 限定符和类型 | 方法和说明 |
|---|---|
static <T> org.apache.flink.api.common.typeinfo.TypeInformation<T> |
UserDefinedFunctionHelper.getReturnTypeOfTableFunction(TableFunction<T> tableFunction)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
static <T> org.apache.flink.api.common.typeinfo.TypeInformation<T> |
UserDefinedFunctionHelper.getReturnTypeOfTableFunction(TableFunction<T> tableFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<T> scalaType)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
| 构造器和说明 |
|---|
TableFunctionDefinition(String name,
TableFunction<?> tableFunction,
org.apache.flink.api.common.typeinfo.TypeInformation<?> resultType) |
| 限定符和类型 | 类和说明 |
|---|---|
class |
PythonTableFunction
The wrapper of user defined python table function.
|
| 限定符和类型 | 方法和说明 |
|---|---|
TableFunction<T> |
LookupableTableSource.getLookupFunction(String[] lookupKeys)
Gets the
TableFunction which supports lookup one key at a time. |
| 限定符和类型 | 方法和说明 |
|---|---|
static TypeInference |
TypeInferenceExtractor.forTableFunction(DataTypeFactory typeFactory,
Class<? extends TableFunction<?>> function)
Extracts a type inference from a
TableFunction. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.