Uses of Class
org.apache.flink.table.functions.AsyncTableFunction
-
-
Uses of AsyncTableFunction in org.apache.flink.table.functions
Subclasses of AsyncTableFunction in org.apache.flink.table.functions Modifier and Type Class Description class
AsyncLookupFunction
A wrapper class ofAsyncTableFunction
for asynchronously lookup rows matching the lookup keys from external system. -
Uses of AsyncTableFunction in org.apache.flink.table.legacy.connector.source
Methods in org.apache.flink.table.legacy.connector.source that return AsyncTableFunction Modifier and Type Method Description AsyncTableFunction<T>
AsyncTableFunctionProvider. createAsyncTableFunction()
Deprecated.Creates aAsyncTableFunction
instance.Methods in org.apache.flink.table.legacy.connector.source with parameters of type AsyncTableFunction Modifier and Type Method Description static <T> AsyncTableFunctionProvider<T>
AsyncTableFunctionProvider. of(AsyncTableFunction<T> asyncTableFunction)
Deprecated.Helper method for creating a static provider. -
Uses of AsyncTableFunction in org.apache.flink.table.legacy.sources
Methods in org.apache.flink.table.legacy.sources that return AsyncTableFunction Modifier and Type Method Description AsyncTableFunction<T>
LookupableTableSource. getAsyncLookupFunction(String[] lookupKeys)
Deprecated.Gets theAsyncTableFunction
which supports async lookup one key at a time. -
Uses of AsyncTableFunction in org.apache.flink.table.runtime.functions.table.lookup
Subclasses of AsyncTableFunction in org.apache.flink.table.runtime.functions.table.lookup Modifier and Type Class Description class
CachingAsyncLookupFunction
A wrapper function around user-provided async lookup function with a cache layer. -
Uses of AsyncTableFunction in org.apache.flink.table.runtime.operators.join.lookup
Subclasses of AsyncTableFunction in org.apache.flink.table.runtime.operators.join.lookup Modifier and Type Class Description class
RetryableAsyncLookupFunctionDelegator
A delegator holds user'sAsyncLookupFunction
to handle retries. -
Uses of AsyncTableFunction in org.apache.flink.table.sources
Methods in org.apache.flink.table.sources that return AsyncTableFunction Modifier and Type Method Description AsyncTableFunction<Row>
CsvTableSource. getAsyncLookupFunction(String[] lookupKeys)
Deprecated. -
Uses of AsyncTableFunction in org.apache.flink.table.types.extraction
Method parameters in org.apache.flink.table.types.extraction with type arguments of type AsyncTableFunction Modifier and Type Method Description static TypeInference
TypeInferenceExtractor. forAsyncTableFunction(DataTypeFactory typeFactory, Class<? extends AsyncTableFunction<?>> function)
Extracts a type inference from aAsyncTableFunction
.
-