Class RetryableLookupFunctionDelegator
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.TableFunction<RowData>
-
- org.apache.flink.table.functions.LookupFunction
-
- org.apache.flink.table.runtime.operators.join.lookup.RetryableLookupFunctionDelegator
-
- All Implemented Interfaces:
Serializable
,FunctionDefinition
public class RetryableLookupFunctionDelegator extends LookupFunction
A delegator holds user'sLookupFunction
to handle retries.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description RetryableLookupFunctionDelegator(LookupFunction userLookupFunction, ResultRetryStrategy retryStrategy)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
Tear-down method for user-defined function.Collection<RowData>
lookup(RowData keyRow)
Synchronously lookup rows matching the lookup keys.void
open(FunctionContext context)
Setup method for user-defined function.-
Methods inherited from class org.apache.flink.table.functions.LookupFunction
eval
-
Methods inherited from class org.apache.flink.table.functions.TableFunction
collect, finish, getKind, getParameterTypes, getResultType, getTypeInference, setCollector
-
Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction
functionIdentifier, toString
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
-
Methods inherited from interface org.apache.flink.table.functions.FunctionDefinition
getRequirements, isDeterministic, supportsConstantFolding
-
-
-
-
Constructor Detail
-
RetryableLookupFunctionDelegator
public RetryableLookupFunctionDelegator(@Nonnull LookupFunction userLookupFunction, @Nonnull ResultRetryStrategy retryStrategy)
-
-
Method Detail
-
lookup
public Collection<RowData> lookup(RowData keyRow) throws IOException
Description copied from class:LookupFunction
Synchronously lookup rows matching the lookup keys.Please note that the returning collection of RowData shouldn't be reused across invocations.
- Specified by:
lookup
in classLookupFunction
- Parameters:
keyRow
- - ARowData
that wraps lookup keys.- Returns:
- A collection of all matching rows in the lookup table.
- Throws:
IOException
-
open
public void open(FunctionContext context) throws Exception
Description copied from class:UserDefinedFunction
Setup method for user-defined function. It can be used for initialization work. By default, this method does nothing.- Overrides:
open
in classUserDefinedFunction
- Throws:
Exception
-
close
public void close() throws Exception
Description copied from class:UserDefinedFunction
Tear-down method for user-defined function. It can be used for clean up work. By default, this method does nothing.- Overrides:
close
in classUserDefinedFunction
- Throws:
Exception
-
-