K
- The type of keys used for the timers and the registry.@Internal public class InternalTimeServiceManager<K> extends Object
AbstractStreamOperator
. Right now, this is only a timer
services
.
NOTE: These services are only available to keyed operators.
Modifier and Type | Field and Description |
---|---|
protected static org.slf4j.Logger |
LOG |
Modifier and Type | Method and Description |
---|---|
void |
advanceWatermark(Watermark watermark) |
<N> InternalTimerService<N> |
getInternalTimerService(String name,
TimerSerializer<K,N> timerSerializer,
Triggerable<K,N> triggerable) |
<N> InternalTimerService<N> |
getInternalTimerService(String name,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerable,
KeyedStateBackend<K> keyedStateBackend) |
int |
numEventTimeTimers() |
int |
numProcessingTimeTimers() |
void |
restoreStateForKeyGroup(InputStream stream,
int keyGroupIdx,
ClassLoader userCodeClassLoader) |
void |
snapshotState(KeyedStateBackend<?> keyedStateBackend,
StateSnapshotContext context,
String operatorName) |
void |
snapshotStateForKeyGroup(DataOutputView stream,
int keyGroupIdx) |
public <N> InternalTimerService<N> getInternalTimerService(String name, TypeSerializer<N> namespaceSerializer, Triggerable<K,N> triggerable, KeyedStateBackend<K> keyedStateBackend)
public <N> InternalTimerService<N> getInternalTimerService(String name, TimerSerializer<K,N> timerSerializer, Triggerable<K,N> triggerable)
public void advanceWatermark(Watermark watermark) throws Exception
Exception
public void snapshotState(KeyedStateBackend<?> keyedStateBackend, StateSnapshotContext context, String operatorName) throws Exception
Exception
public void snapshotStateForKeyGroup(DataOutputView stream, int keyGroupIdx) throws IOException
IOException
public void restoreStateForKeyGroup(InputStream stream, int keyGroupIdx, ClassLoader userCodeClassLoader) throws IOException
IOException
@VisibleForTesting public int numProcessingTimeTimers()
@VisibleForTesting public int numEventTimeTimers()
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.