Package | Description |
---|---|
org.apache.flink.streaming.api.operators |
Modifier and Type | Field and Description |
---|---|
protected InternalTimeServiceManager<?> |
AbstractStreamOperator.timeServiceManager |
Modifier and Type | Method and Description |
---|---|
InternalTimeServiceManager<?> |
StreamOperatorStateContext.internalTimerServiceManager()
Returns the internal timer service manager for the stream operator.
|
protected <K> InternalTimeServiceManager<K> |
StreamTaskStateInitializerImpl.internalTimeServiceManager(AbstractKeyedStateBackend<K> keyedStatedBackend,
KeyContext keyContext,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates) |
Constructor and Description |
---|
InternalTimerServiceSerializationProxy(InternalTimeServiceManager<K> timerServicesManager,
ClassLoader userCodeClassLoader,
int keyGroupIdx)
Constructor to use when restoring timer services.
|
InternalTimerServiceSerializationProxy(InternalTimeServiceManager<K> timerServicesManager,
int keyGroupIdx)
Constructor to use when writing timer services.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.