Uses of Class
org.apache.flink.table.functions.TableFunction
-
-
Uses of TableFunction in org.apache.flink.table.functions
Subclasses of TableFunction in org.apache.flink.table.functions Modifier and Type Class Description class
LookupFunction
A wrapper class ofTableFunction
for synchronously lookup rows matching the lookup keys from external system.class
TemporalTableFunction
Class representing temporal table function over some history table.Methods in org.apache.flink.table.functions that return TableFunction Modifier and Type Method Description TableFunction<?>
TableFunctionDefinition. getTableFunction()
Deprecated.Methods in org.apache.flink.table.functions with parameters of type TableFunction Modifier and Type Method Description static InputTypeStrategy
LegacyUserDefinedFunctionInference. getInputTypeStrategy(TableFunction<?> func)
Deprecated.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.Constructors in org.apache.flink.table.functions with parameters of type TableFunction Constructor Description TableFunctionDefinition(String name, TableFunction<?> tableFunction, org.apache.flink.api.common.typeinfo.TypeInformation<?> resultType)
Deprecated. -
Uses of TableFunction in org.apache.flink.table.functions.python
Subclasses of TableFunction in org.apache.flink.table.functions.python Modifier and Type Class Description class
PythonTableFunction
The wrapper of user defined python table function. -
Uses of TableFunction in org.apache.flink.table.legacy.connector.source
Methods in org.apache.flink.table.legacy.connector.source that return TableFunction Modifier and Type Method Description TableFunction<T>
TableFunctionProvider. createTableFunction()
Deprecated.Creates aTableFunction
instance.Methods in org.apache.flink.table.legacy.connector.source with parameters of type TableFunction Modifier and Type Method Description static <T> TableFunctionProvider<T>
TableFunctionProvider. of(TableFunction<T> tableFunction)
Deprecated.Helper method for creating a static provider. -
Uses of TableFunction in org.apache.flink.table.legacy.sources
Methods in org.apache.flink.table.legacy.sources that return TableFunction Modifier and Type Method Description TableFunction<T>
LookupableTableSource. getLookupFunction(String[] lookupKeys)
Deprecated.Gets theTableFunction
which supports lookup one key at a time. -
Uses of TableFunction in org.apache.flink.table.types.extraction
Method parameters in org.apache.flink.table.types.extraction with type arguments of type TableFunction Modifier and Type Method Description static TypeInference
TypeInferenceExtractor. forTableFunction(DataTypeFactory typeFactory, Class<? extends TableFunction<?>> function)
Extracts a type inference from aTableFunction
.
-