K
- The type of keys used for the timers and the registry.@Internal public class InternalTimeServiceManagerImpl<K> extends Object implements InternalTimeServiceManager<K>
timer services
.
NOTE: These services are only available to keyed operators.
InternalTimeServiceManager.Provider
Modifier and Type | Field and Description |
---|---|
protected static org.slf4j.Logger |
LOG |
Modifier and Type | Method and Description |
---|---|
void |
advanceWatermark(Watermark watermark)
Advances the Watermark of all managed
timer services ,
potentially firing event time timers. |
static <K> InternalTimeServiceManagerImpl<K> |
create(CheckpointableKeyedStateBackend<K> keyedStateBackend,
ClassLoader userClassloader,
KeyContext keyContext,
ProcessingTimeService processingTimeService,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates,
StreamTaskCancellationContext cancellationContext)
A factory method for creating the
InternalTimeServiceManagerImpl . |
<N> InternalTimerService<N> |
getInternalTimerService(String name,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerable)
Creates an
InternalTimerService for handling a group of timers identified by the
given name . |
int |
numEventTimeTimers() |
int |
numProcessingTimeTimers() |
void |
snapshotToRawKeyedState(KeyedStateCheckpointOutputStream out,
String operatorName)
Snapshots the timers to raw keyed state.
|
public static <K> InternalTimeServiceManagerImpl<K> create(CheckpointableKeyedStateBackend<K> keyedStateBackend, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext) throws Exception
InternalTimeServiceManagerImpl
.
IMPORTANT: Keep in sync with InternalTimeServiceManager.Provider
.
Exception
public <N> InternalTimerService<N> getInternalTimerService(String name, TypeSerializer<K> keySerializer, TypeSerializer<N> namespaceSerializer, Triggerable<K,N> triggerable)
InternalTimeServiceManager
InternalTimerService
for handling a group of timers identified by the
given name
. The timers are scoped to a key and namespace.
When a timer fires the given Triggerable
will be invoked.
getInternalTimerService
in interface InternalTimeServiceManager<K>
public void advanceWatermark(Watermark watermark) throws Exception
InternalTimeServiceManager
timer services
,
potentially firing event time timers.advanceWatermark
in interface InternalTimeServiceManager<K>
Exception
public void snapshotToRawKeyedState(KeyedStateCheckpointOutputStream out, String operatorName) throws Exception
InternalTimeServiceManager
TODO: This can be removed once heap-based timers are integrated with RocksDB incremental snapshots.
snapshotToRawKeyedState
in interface InternalTimeServiceManager<K>
Exception
@VisibleForTesting public int numProcessingTimeTimers()
@VisibleForTesting public int numEventTimeTimers()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.