Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.streaming.api.operators |
Modifier and Type | Class and Description |
---|---|
class |
KeyGroupStatePartitionStreamProvider
This class provides access to an input stream that contains state data for one key group and the
key group id.
|
Modifier and Type | Method and Description |
---|---|
Iterable<StatePartitionStreamProvider> |
StateInitializationContext.getRawOperatorStateInputs()
Returns an iterable to obtain input streams for previously stored operator state partitions
that are assigned to this operator.
|
Iterable<StatePartitionStreamProvider> |
StateInitializationContextImpl.getRawOperatorStateInputs() |
Constructor and Description |
---|
StateInitializationContextImpl(Long restoredCheckpointId,
OperatorStateStore operatorStateStore,
KeyedStateStore keyedStateStore,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs,
Iterable<StatePartitionStreamProvider> rawOperatorStateInputs) |
Modifier and Type | Method and Description |
---|---|
CloseableIterable<StatePartitionStreamProvider> |
StreamOperatorStateContext.rawOperatorStateInputs()
Returns an iterable to obtain input streams for previously stored operator state partitions
that are assigned to this stream operator.
|
protected CloseableIterable<StatePartitionStreamProvider> |
StreamTaskStateInitializerImpl.rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives,
StateObject.StateObjectSizeStatsCollector statsCollector) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.