Uses of Interface
org.apache.flink.streaming.runtime.tasks.TimerService
-
Packages that use TimerService Package Description org.apache.flink.streaming.runtime.io.checkpointing org.apache.flink.streaming.runtime.tasks org.apache.flink.streaming.runtime.tasks.mailbox -
-
Uses of TimerService in org.apache.flink.streaming.runtime.io.checkpointing
Methods in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type TimerService Modifier and Type Method Description static CheckpointBarrierHandlerInputProcessorUtil. createCheckpointBarrierHandler(CheckpointableTask toNotifyOnCheckpoint, StreamConfig config, SubtaskCheckpointCoordinator checkpointCoordinator, String taskName, List<IndexedInputGate>[] inputGates, List<StreamTaskSourceInput<?>> sourceInputs, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, TimerService timerService)static BarrierAlignmentUtil.DelayableTimerBarrierAlignmentUtil. createRegisterTimerCallback(org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor, TimerService timerService) -
Uses of TimerService in org.apache.flink.streaming.runtime.tasks
Classes in org.apache.flink.streaming.runtime.tasks that implement TimerService Modifier and Type Class Description classSystemProcessingTimeServiceATimerServicewhich assigns as current processing time the result of callingSystem.currentTimeMillis()and registers timers using aScheduledThreadPoolExecutor.Fields in org.apache.flink.streaming.runtime.tasks declared as TimerService Modifier and Type Field Description protected TimerServiceStreamTask. systemTimerServiceIn contrast toStreamTask.timerServicewe should not register any user timers here.protected TimerServiceStreamTask. timerServiceThe internalTimerServiceused to define the current processing time (default =System.currentTimeMillis()) and register timers for tasks to be executed in the future.Constructors in org.apache.flink.streaming.runtime.tasks with parameters of type TimerService Constructor Description OneInputStreamTask(Environment env, TimerService timeProvider)Constructor for initialization, possibly with initial state (recovery / savepoint / etc).StreamTask(Environment env, TimerService timerService)Constructor for initialization, possibly with initial state (recovery / savepoint / etc).StreamTask(Environment environment, TimerService timerService, Thread.UncaughtExceptionHandler uncaughtExceptionHandler)StreamTask(Environment environment, TimerService timerService, Thread.UncaughtExceptionHandler uncaughtExceptionHandler, StreamTaskActionExecutor actionExecutor)Constructor for initialization, possibly with initial state (recovery / savepoint / etc).StreamTask(Environment environment, TimerService timerService, Thread.UncaughtExceptionHandler uncaughtExceptionHandler, StreamTaskActionExecutor actionExecutor, TaskMailbox mailbox) -
Uses of TimerService in org.apache.flink.streaming.runtime.tasks.mailbox
Methods in org.apache.flink.streaming.runtime.tasks.mailbox with parameters of type TimerService Modifier and Type Method Description voidMailboxMetricsController. setupLatencyMeasurement(TimerService timerService, org.apache.flink.api.common.operators.MailboxExecutor mailboxExecutor)Sets up latency measurement with requiredTimerServiceandMailboxExecutor.
-