Class SimpleAsyncExecutionController<K>
- java.lang.Object
-
- org.apache.flink.runtime.asyncprocessing.AsyncExecutionController<K,SimpleAsyncExecutionController.RunnableTask<K,?>>
-
- org.apache.flink.runtime.asyncprocessing.SimpleAsyncExecutionController<K>
-
- All Implemented Interfaces:
Closeable
,AutoCloseable
public class SimpleAsyncExecutionController<K> extends AsyncExecutionController<K,SimpleAsyncExecutionController.RunnableTask<K,?>>
TheSimpleAsyncExecutionController
is responsible for handling simple runnable tasks.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
SimpleAsyncExecutionController.RunnableTask<K,RET>
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
AsyncExecutionController.SwitchContextListener<K>
-
-
Constructor Summary
Constructors Constructor Description SimpleAsyncExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, ExecutorService asyncThreadPool, DeclarationManager declarationManager, EpochManager.ParallelMode epochParallelMode, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <R> org.apache.flink.core.asyncprocessing.InternalAsyncFuture<R>
handleRequest(org.apache.flink.util.function.CheckedSupplier<R> checkedSupplier, boolean allowOverdraft)
Submit aAsyncRequest
to this AsyncExecutionController and trigger it if needed.-
Methods inherited from class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
buildContext, buildContext, close, drainInflightRecords, getAsyncExecutor, getCurrentContext, getInFlightRecordNum, getMailboxExecutor, handleRequest, processNonRecord, setCurrentContext, syncPointRequestWithCallback, triggerIfNeeded, waitUntil
-
-
-
-
Constructor Detail
-
SimpleAsyncExecutionController
public SimpleAsyncExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, ExecutorService asyncThreadPool, DeclarationManager declarationManager, EpochManager.ParallelMode epochParallelMode, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, @Nullable AsyncExecutionController.SwitchContextListener<K> switchContextListener, @Nullable org.apache.flink.metrics.MetricGroup metricGroup)
-
-
Method Detail
-
handleRequest
public <R> org.apache.flink.core.asyncprocessing.InternalAsyncFuture<R> handleRequest(org.apache.flink.util.function.CheckedSupplier<R> checkedSupplier, boolean allowOverdraft)
Submit aAsyncRequest
to this AsyncExecutionController and trigger it if needed.- Parameters:
checkedSupplier
- the runnable to execute.allowOverdraft
- whether to allow overdraft.- Returns:
- the state future.
-
-