Class TableFunctionResultFuture<T>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.table.runtime.collector.TableFunctionResultFuture<T>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.RichFunction,org.apache.flink.streaming.api.functions.async.ResultFuture<T>
public abstract class TableFunctionResultFuture<T> extends org.apache.flink.api.common.functions.AbstractRichFunction implements org.apache.flink.streaming.api.functions.async.ResultFuture<T>The basic implementation of collector forResultFuturein table joining.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description TableFunctionResultFuture()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidcomplete(org.apache.flink.streaming.api.functions.async.CollectionSupplier<T> supplier)Unsupported, because the containing classes are AsyncFunctions which don't have access to the mailbox to invoke from the caller thread.voidcompleteExceptionally(Throwable error)ObjectgetInput()Gets the input value from left table, which will be used to cross join with the result of right table.org.apache.flink.streaming.api.functions.async.ResultFuture<?>getResultFuture()Gets the internal collector which used to emit the final row.voidsetInput(Object input)Sets the input row from left table, which will be used to cross join with the result of right table.voidsetResultFuture(org.apache.flink.streaming.api.functions.async.ResultFuture<?> resultFuture)Sets the current collector, which used to emit the final row.-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
-
-
-
-
Method Detail
-
setInput
public void setInput(Object input)
Sets the input row from left table, which will be used to cross join with the result of right table.
-
getInput
public Object getInput()
Gets the input value from left table, which will be used to cross join with the result of right table.
-
setResultFuture
public void setResultFuture(org.apache.flink.streaming.api.functions.async.ResultFuture<?> resultFuture)
Sets the current collector, which used to emit the final row.
-
getResultFuture
public org.apache.flink.streaming.api.functions.async.ResultFuture<?> getResultFuture()
Gets the internal collector which used to emit the final row.
-
completeExceptionally
public void completeExceptionally(Throwable error)
- Specified by:
completeExceptionallyin interfaceorg.apache.flink.streaming.api.functions.async.ResultFuture<T>
-
complete
public void complete(org.apache.flink.streaming.api.functions.async.CollectionSupplier<T> supplier)
Unsupported, because the containing classes are AsyncFunctions which don't have access to the mailbox to invoke from the caller thread.- Specified by:
completein interfaceorg.apache.flink.streaming.api.functions.async.ResultFuture<T>
-
-