Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.sorted.state |
Modifier and Type | Method and Description |
---|---|
Iterable<KeyGroupStatePartitionStreamProvider> |
StateInitializationContextImpl.getRawKeyedStateInputs() |
Iterable<KeyGroupStatePartitionStreamProvider> |
StateInitializationContext.getRawKeyedStateInputs()
Returns an iterable to obtain input streams for previously stored keyed state partitions that
are assigned to this operator.
|
Constructor and Description |
---|
StateInitializationContextImpl(Long restoredCheckpointId,
OperatorStateStore operatorStateStore,
KeyedStateStore keyedStateStore,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs,
Iterable<StatePartitionStreamProvider> rawOperatorStateInputs) |
Modifier and Type | Method and Description |
---|---|
CloseableIterable<KeyGroupStatePartitionStreamProvider> |
StreamOperatorStateContext.rawKeyedStateInputs()
Returns an iterable to obtain input streams for previously stored keyed state partitions that
are assigned to this operator.
|
protected CloseableIterable<KeyGroupStatePartitionStreamProvider> |
StreamTaskStateInitializerImpl.rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives) |
Modifier and Type | Method and Description |
---|---|
<K> InternalTimeServiceManager<K> |
InternalTimeServiceManager.Provider.create(CheckpointableKeyedStateBackend<K> keyedStatedBackend,
ClassLoader userClassloader,
KeyContext keyContext,
ProcessingTimeService processingTimeService,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates) |
static <K> InternalTimeServiceManagerImpl<K> |
InternalTimeServiceManagerImpl.create(CheckpointableKeyedStateBackend<K> keyedStateBackend,
ClassLoader userClassloader,
KeyContext keyContext,
ProcessingTimeService processingTimeService,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates)
A factory method for creating the
InternalTimeServiceManagerImpl . |
Modifier and Type | Method and Description |
---|---|
static <K> InternalTimeServiceManager<K> |
BatchExecutionInternalTimeServiceManager.create(CheckpointableKeyedStateBackend<K> keyedStatedBackend,
ClassLoader userClassloader,
KeyContext keyContext,
ProcessingTimeService processingTimeService,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.