Modifier and Type | Class and Description |
---|---|
class |
FileSystemLookupFunction<P>
Lookup function for filesystem connector tables.
|
Modifier and Type | Method and Description |
---|---|
<T> void |
StreamTableEnvironment.registerFunction(String name,
TableFunction<T> tableFunction)
Deprecated.
Use
TableEnvironment.createTemporarySystemFunction(String, UserDefinedFunction) instead.
Please note that the new method also uses the new type system and reflective extraction
logic. It might be necessary to update the function implementation as well. See the
documentation of TableFunction for more information on the new function design. |
Modifier and Type | Method and Description |
---|---|
<T> void |
StreamTableEnvironmentImpl.registerFunction(String name,
TableFunction<T> tableFunction) |
Modifier and Type | Method and Description |
---|---|
<T> void |
FunctionCatalog.registerTempSystemTableFunction(String name,
TableFunction<T> function,
TypeInformation<T> resultType)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TableFunction<T> |
TableFunctionProvider.createTableFunction()
Deprecated.
Creates a
TableFunction instance. |
Modifier and Type | Method and Description |
---|---|
static <T> TableFunctionProvider<T> |
TableFunctionProvider.of(TableFunction<T> tableFunction)
Deprecated.
Helper method for creating a static provider.
|
Modifier and Type | Class and Description |
---|---|
class |
LookupFunction
A wrapper class of
TableFunction for synchronously lookup rows matching the lookup keys
from external system. |
class |
TemporalTableFunction
Class representing temporal table function over some history table.
|
class |
TemporalTableFunctionImpl
Class representing temporal table function over some history table.
|
Modifier and Type | Method and Description |
---|---|
TableFunction<?> |
TableFunctionDefinition.getTableFunction()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static InputTypeStrategy |
LegacyUserDefinedFunctionInference.getInputTypeStrategy(TableFunction<?> func)
Deprecated.
|
static <T> TypeInformation<T> |
UserDefinedFunctionHelper.getReturnTypeOfTableFunction(TableFunction<T> tableFunction)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
static <T> TypeInformation<T> |
UserDefinedFunctionHelper.getReturnTypeOfTableFunction(TableFunction<T> tableFunction,
TypeInformation<T> scalaType)
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
|
Constructor and Description |
---|
TableFunctionDefinition(String name,
TableFunction<?> tableFunction,
TypeInformation<?> resultType)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
HiveGenericUDTF
A TableFunction implementation that calls Hive's
GenericUDTF . |
Modifier and Type | Class and Description |
---|---|
class |
PythonTableFunction
The wrapper of user defined python table function.
|
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
BatchExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
Modifier and Type | Method and Description |
---|---|
protected ProcessFunction<RowData,RowData> |
CommonExecLookupJoin.createSyncLookupJoinFunction(org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled) |
protected abstract Transformation<RowData> |
CommonExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
StreamExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
Modifier and Type | Class and Description |
---|---|
class |
BuiltInTableFunction<T>
Base class for runtime implementation represented as
TableFunction that is constructed
from SpecializedFunction.specialize(SpecializedContext) . |
class |
ReplicateRowsFunction
Replicate the row N times.
|
static class |
UnnestRowsFunction.CollectionUnnestTableFunction
Table function that unwraps the elements of a collection (array or multiset).
|
static class |
UnnestRowsFunction.MapUnnestTableFunction
Table function that unwraps the elements of a map.
|
Modifier and Type | Class and Description |
---|---|
class |
CachingLookupFunction
A wrapper function around user-provided lookup function with a cache layer.
|
Modifier and Type | Class and Description |
---|---|
class |
RetryableLookupFunctionDelegator
A delegator holds user's
LookupFunction to handle retries. |
Modifier and Type | Class and Description |
---|---|
static class |
CsvTableSource.CsvLookupFunction
Deprecated.
LookupFunction to support lookup in CsvTableSource.
|
Modifier and Type | Method and Description |
---|---|
TableFunction<Row> |
CsvTableSource.getLookupFunction(String[] lookupKeys)
Deprecated.
|
TableFunction<T> |
LookupableTableSource.getLookupFunction(String[] lookupKeys)
Deprecated.
Gets the
TableFunction which supports lookup one key at a time. |
Modifier and Type | Method and Description |
---|---|
static TypeInference |
TypeInferenceExtractor.forTableFunction(DataTypeFactory typeFactory,
Class<? extends TableFunction<?>> function)
Extracts a type inference from a
TableFunction . |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.