Uses of Interface
org.apache.flink.runtime.asyncprocessing.StateExecutor
-
Packages that use StateExecutor Package Description org.apache.flink.runtime.asyncprocessing org.apache.flink.runtime.state org.apache.flink.runtime.state.v2.adaptor -
-
Uses of StateExecutor in org.apache.flink.runtime.asyncprocessing
Methods in org.apache.flink.runtime.asyncprocessing that return StateExecutor Modifier and Type Method Description StateExecutor
AsyncExecutionController. getStateExecutor()
Constructors in org.apache.flink.runtime.asyncprocessing with parameters of type StateExecutor Constructor Description AsyncExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.state.StateFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, StateExecutor stateExecutor, DeclarationManager declarationManager, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
-
Uses of StateExecutor in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return StateExecutor Modifier and Type Method Description StateExecutor
AsyncKeyedStateBackend. createStateExecutor()
Creates aStateExecutor
which supports to execute a batch of state requests asynchronously. -
Uses of StateExecutor in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor that return StateExecutor Modifier and Type Method Description StateExecutor
AsyncKeyedStateBackendAdaptor. createStateExecutor()
-