K
- The type of keys used for the timers and the registry.@Internal public interface InternalTimeServiceManager<K>
NOTE: These services are only available to keyed operators.
Modifier and Type | Interface and Description |
---|---|
static interface |
InternalTimeServiceManager.Provider
A provider pattern for creating an instance of a
InternalTimeServiceManager . |
Modifier and Type | Method and Description |
---|---|
void |
advanceWatermark(Watermark watermark)
Advances the Watermark of all managed
timer services ,
potentially firing event time timers. |
<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 . |
void |
snapshotToRawKeyedState(KeyedStateCheckpointOutputStream stateCheckpointOutputStream,
String operatorName)
Snapshots the timers to raw keyed state.
|
<N> InternalTimerService<N> getInternalTimerService(String name, TypeSerializer<K> keySerializer, TypeSerializer<N> namespaceSerializer, Triggerable<K,N> triggerable)
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.
void advanceWatermark(Watermark watermark) throws Exception
timer services
,
potentially firing event time timers.Exception
void snapshotToRawKeyedState(KeyedStateCheckpointOutputStream stateCheckpointOutputStream, String operatorName) throws Exception
TODO: This can be removed once heap-based timers are integrated with RocksDB incremental snapshots.
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.