Class SimpleAsyncExecutionController<K>

    • 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 a AsyncRequest to this AsyncExecutionController and trigger it if needed.
        Parameters:
        checkedSupplier - the runnable to execute.
        allowOverdraft - whether to allow overdraft.
        Returns:
        the state future.