public interface ProcessingTimeService extends ProcessingTimeService
The access to the time via getCurrentProcessingTime()
is always available, regardless
of whether the timer service has been shut down.
ProcessingTimeService.ProcessingTimeCallback
Modifier and Type | Method and Description |
---|---|
Clock |
getClock()
Returns
Clock associated with this timer service. |
default long |
getCurrentProcessingTime()
Returns the current processing time.
|
CompletableFuture<Void> |
quiesce()
This method puts the service into a state where it does not register new timers, but returns
for each call to
ProcessingTimeService.registerTimer(long, org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback) or scheduleAtFixedRate(org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback, long, long) a "mock" future and
the "mock" future will be never completed. |
ScheduledFuture<?> |
scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback callback,
long initialDelay,
long period)
Registers a task to be executed repeatedly at a fixed rate.
|
ScheduledFuture<?> |
scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback callback,
long initialDelay,
long period)
Registers a task to be executed repeatedly with a fixed delay.
|
registerTimer
default long getCurrentProcessingTime()
ProcessingTimeService
getCurrentProcessingTime
in interface ProcessingTimeService
ScheduledFuture<?> scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback callback, long initialDelay, long period)
This call behaves similar to ScheduledExecutor.scheduleAtFixedRate(Runnable, long,
long, TimeUnit)
.
callback
- to be executed after the initial delay and then after each periodinitialDelay
- initial delay to start executing callbackperiod
- after the initial delay after which the callback is executedScheduledFuture<?> scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback callback, long initialDelay, long period)
This call behaves similar to ScheduledExecutor.scheduleWithFixedDelay(Runnable,
long, long, TimeUnit)
.
callback
- to be executed after the initial delay and then after each periodinitialDelay
- initial delay to start executing callbackperiod
- after the initial delay after which the callback is executedCompletableFuture<Void> quiesce()
ProcessingTimeService.registerTimer(long, org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback)
or scheduleAtFixedRate(org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback, long, long)
a "mock" future and
the "mock" future will be never completed. Furthermore, the timers registered before are
prevented from firing, but the timers in running are allowed to finish.
If no timer is running, the quiesce-completed future is immediately completed and returned. Otherwise, the future returned will be completed when all running timers have finished.
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.