Class SimpleAsyncExecutionController.RunnableTask<K,RET>
- java.lang.Object
-
- org.apache.flink.runtime.asyncprocessing.AsyncRequest<K>
-
- org.apache.flink.runtime.asyncprocessing.SimpleAsyncExecutionController.RunnableTask<K,RET>
-
- Enclosing class:
- SimpleAsyncExecutionController<K>
public static class SimpleAsyncExecutionController.RunnableTask<K,RET> extends AsyncRequest<K>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.asyncprocessing.AsyncRequest
asyncFuture, context, sync
-
-
Constructor Summary
Constructors Constructor Description RunnableTask(RecordContext<K> context, boolean sync, org.apache.flink.core.asyncprocessing.InternalAsyncFuture<RET> asyncFuture, org.apache.flink.util.function.CheckedSupplier<RET> runnable)
-
-
-
Constructor Detail
-
RunnableTask
public RunnableTask(RecordContext<K> context, boolean sync, org.apache.flink.core.asyncprocessing.InternalAsyncFuture<RET> asyncFuture, org.apache.flink.util.function.CheckedSupplier<RET> runnable)
-
-