Package | Description |
---|---|
org.apache.flink.state.api.input.operator | |
org.apache.flink.streaming.api.operators |
Modifier and Type | Method and Description |
---|---|
void |
StateReaderOperator.setup(ExecutionConfig executionConfig,
KeyedStateBackend<KEY> keyKeyedStateBackend,
InternalTimeServiceManager<KEY> timerServiceManager,
SavepointRuntimeContext ctx) |
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,
ProcessingTimeService processingTimeService,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates) |
Modifier and Type | Method and Description |
---|---|
protected Optional<InternalTimeServiceManager<?>> |
AbstractStreamOperator.getTimeServiceManager() |
protected Optional<InternalTimeServiceManager<?>> |
AbstractStreamOperatorV2.getTimeServiceManager() |
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
StreamOperatorStateHandler.snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator streamOperator,
Optional<InternalTimeServiceManager<?>> timeServiceManager,
String operatorName,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
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–2021 The Apache Software Foundation. All rights reserved.