Uses of Class
org.apache.flink.runtime.asyncprocessing.EpochManager.ParallelMode
-
Packages that use EpochManager.ParallelMode Package Description org.apache.flink.runtime.asyncprocessing org.apache.flink.runtime.asyncprocessing.operators -
-
Uses of EpochManager.ParallelMode in org.apache.flink.runtime.asyncprocessing
Methods in org.apache.flink.runtime.asyncprocessing that return EpochManager.ParallelMode Modifier and Type Method Description static EpochManager.ParallelMode
EpochManager.ParallelMode. valueOf(String name)
Returns the enum constant of this type with the specified name.static EpochManager.ParallelMode[]
EpochManager.ParallelMode. values()
Returns an array containing the constants of this enum type, in the order they are declared.Methods in org.apache.flink.runtime.asyncprocessing with parameters of type EpochManager.ParallelMode Modifier and Type Method Description void
EpochManager. onNonRecord(Runnable triggerAction, Runnable finalAction, EpochManager.ParallelMode parallelMode)
Add a non-record to the current epoch, close current epoch and open a new epoch.Constructors in org.apache.flink.runtime.asyncprocessing with parameters of type EpochManager.ParallelMode Constructor Description AsyncExecutionController(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, org.apache.flink.core.asyncprocessing.AsyncFutureImpl.AsyncFrameworkExceptionHandler exceptionHandler, AsyncExecutor<REQUEST> asyncExecutor, DeclarationManager declarationManager, EpochManager.ParallelMode epochParallelMode, int maxParallelism, int batchSize, long bufferTimeout, int maxInFlightRecords, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
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)
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, AsyncExecutionController.SwitchContextListener<K> switchContextListener, org.apache.flink.metrics.MetricGroup metricGroup)
-
Uses of EpochManager.ParallelMode in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators that return EpochManager.ParallelMode Modifier and Type Method Description protected EpochManager.ParallelMode
AbstractAsyncRunnableStreamOperator. getEpochParallelMode()
Define the parallel mode of the epoch manager.
-