Class StateExecutionController<K>

    • Constructor Detail

      • StateExecutionController

        public StateExecutionController​(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor,
                                        org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler,
                                        AsyncExecutor<StateRequest<?,​?,​?,​?>> stateExecutor,
                                        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 <IN,​OUT> org.apache.flink.core.asyncprocessing.InternalAsyncFuture<OUT> handleRequest​(@Nullable
                                                                                                           org.apache.flink.api.common.state.v2.State state,
                                                                                                           StateRequestType type,
                                                                                                           @Nullable
                                                                                                           IN payload)
        Submit a StateRequest to this AsyncExecutionController and trigger it if needed.
        Specified by:
        handleRequest in interface StateRequestHandler
        Parameters:
        state - the state to request.
        type - the type of this request.
        payload - the payload input for this request.
        Returns:
        the state future.
      • handleRequest

        public <IN,​OUT> org.apache.flink.core.asyncprocessing.InternalAsyncFuture<OUT> handleRequest​(@Nullable
                                                                                                           org.apache.flink.api.common.state.v2.State state,
                                                                                                           StateRequestType type,
                                                                                                           boolean sync,
                                                                                                           @Nullable
                                                                                                           IN payload,
                                                                                                           boolean allowOverdraft)
        Submit a StateRequest to this AsyncExecutionController and trigger it if needed.
        Parameters:
        state - the state to request.
        type - the type of this request.
        sync - whether to trigger the request synchronously once it's ready.
        payload - the payload input for this request.
        allowOverdraft - whether to allow overdraft.
        Returns:
        the state future.
      • handleRequestSync

        public <IN,​OUT> OUT handleRequestSync​(org.apache.flink.api.common.state.v2.State state,
                                                    StateRequestType type,
                                                    @Nullable
                                                    IN payload)
        Description copied from interface: StateRequestHandler
        Submit a StateRequest to this StateRequestHandler, and wait for the response synchronously.
        Specified by:
        handleRequestSync in interface StateRequestHandler
        Parameters:
        state - the state to request.
        type - the type of this request.
        payload - the payload input for this request.
        Returns:
        the state future.