Modifier and Type | Method and Description |
---|---|
static KeyedStateHandle |
RocksDBIncrementalCheckpointUtils.chooseTheBestStateHandleForInitial(Collection<KeyedStateHandle> restoreStateHandles,
KeyGroupRange targetKeyGroupRange)
Choose the best state handle according to the
RocksDBIncrementalCheckpointUtils.STATE_HANDLE_EVALUATOR to init the
initial db. |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksDBKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions)
Triggers an asynchronous snapshot of the keyed state backend from RocksDB.
|
Modifier and Type | Method and Description |
---|---|
static KeyedStateHandle |
RocksDBIncrementalCheckpointUtils.chooseTheBestStateHandleForInitial(Collection<KeyedStateHandle> restoreStateHandles,
KeyGroupRange targetKeyGroupRange)
Choose the best state handle according to the
RocksDBIncrementalCheckpointUtils.STATE_HANDLE_EVALUATOR to init the
initial db. |
<K> AbstractKeyedStateBackend<K> |
EmbeddedRocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
EmbeddedRocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Deprecated.
|
Constructor and Description |
---|
RocksDBKeyedStateBackendBuilder(String operatorIdentifier,
ClassLoader userCodeClassLoader,
File instanceBasePath,
RocksDBResourceContainer optionsContainer,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
ExecutionConfig executionConfig,
LocalRecoveryConfig localRecoveryConfig,
EmbeddedRocksDBStateBackend.PriorityQueueStateType priorityQueueStateType,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
StreamCompressionDecorator keyGroupCompressionDecorator,
CloseableRegistry cancelStreamRegistry) |
Constructor and Description |
---|
RocksDBFullRestoreOperation(KeyGroupRange keyGroupRange,
ClassLoader userCodeClassLoader,
Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
StateSerializerProvider<K> keySerializerProvider,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
Collection<KeyedStateHandle> restoreStateHandles,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
long writeBatchSize,
Long writeBufferManagerCapacity) |
RocksDBHeapTimersFullRestoreOperation(KeyGroupRange keyGroupRange,
int numberOfKeyGroups,
ClassLoader userCodeClassLoader,
Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
LinkedHashMap<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
HeapPriorityQueueSetFactory priorityQueueFactory,
StateSerializerProvider<K> keySerializerProvider,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
Collection<KeyedStateHandle> restoreStateHandles,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
long writeBatchSize,
Long writeBufferManagerCapacity) |
RocksDBIncrementalRestoreOperation(String operatorIdentifier,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
int numberOfTransferringThreads,
CloseableRegistry cancelStreamRegistry,
ClassLoader userCodeClassLoader,
Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
StateSerializerProvider<K> keySerializerProvider,
File instanceBasePath,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
Collection<KeyedStateHandle> restoreStateHandles,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
long writeBatchSize,
Long writeBufferManagerCapacity) |
Modifier and Type | Method and Description |
---|---|
SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle> |
RocksFullSnapshotStrategy.asyncSnapshot(FullSnapshotResources<K> fullRocksDBSnapshotResources,
long checkpointId,
long timestamp,
CheckpointStreamFactory checkpointStreamFactory,
CheckpointOptions checkpointOptions) |
SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle> |
RocksIncrementalSnapshotStrategy.asyncSnapshot(org.apache.flink.contrib.streaming.state.snapshot.RocksIncrementalSnapshotStrategy.IncrementalRocksDBSnapshotResources snapshotResources,
long checkpointId,
long timestamp,
CheckpointStreamFactory checkpointStreamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
KeyedStateHandle |
SubtaskState.getManagedKeyedState()
Deprecated.
|
KeyedStateHandle |
SubtaskState.getRawKeyedState()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
StateObjectCollection<KeyedStateHandle> |
PrioritizedOperatorSubtaskState.getJobManagerManagedKeyedState()
Returns the managed keyed state from the job manager, which represents the ground truth about
what this state should represent.
|
StateObjectCollection<KeyedStateHandle> |
PrioritizedOperatorSubtaskState.getJobManagerRawKeyedState()
Returns the raw keyed state from the job manager, which represents the ground truth about
what this state should represent.
|
StateObjectCollection<KeyedStateHandle> |
OperatorSubtaskState.getManagedKeyedState() |
static List<KeyedStateHandle> |
StateAssignmentOperation.getManagedKeyedStateHandles(OperatorState operatorState,
KeyGroupRange subtaskKeyGroupRange)
Collect
managedKeyedStateHandles which have intersection with
given KeyGroupRange from operatorState . |
List<StateObjectCollection<KeyedStateHandle>> |
PrioritizedOperatorSubtaskState.getPrioritizedManagedKeyedState()
Returns an immutable list with all alternative snapshots to restore the managed keyed state,
in the order in which we should attempt to restore.
|
List<StateObjectCollection<KeyedStateHandle>> |
PrioritizedOperatorSubtaskState.getPrioritizedRawKeyedState()
Returns an immutable list with all alternative snapshots to restore the raw keyed state, in
the order in which we should attempt to restore.
|
StateObjectCollection<KeyedStateHandle> |
OperatorSubtaskState.getRawKeyedState() |
static List<KeyedStateHandle> |
StateAssignmentOperation.getRawKeyedStateHandles(OperatorState operatorState,
KeyGroupRange subtaskKeyGroupRange)
|
Modifier and Type | Method and Description |
---|---|
OperatorSubtaskState.Builder |
OperatorSubtaskState.Builder.setManagedKeyedState(KeyedStateHandle managedKeyedState) |
OperatorSubtaskState.Builder |
OperatorSubtaskState.Builder.setRawKeyedState(KeyedStateHandle rawKeyedState) |
Modifier and Type | Method and Description |
---|---|
static void |
StateAssignmentOperation.extractIntersectingState(Collection<? extends KeyedStateHandle> originalSubtaskStateHandles,
KeyGroupRange rangeToExtract,
List<KeyedStateHandle> extractedStateCollector)
Extracts certain key group ranges from the given state handles and adds them to the
collector.
|
static void |
StateAssignmentOperation.extractIntersectingState(Collection<? extends KeyedStateHandle> originalSubtaskStateHandles,
KeyGroupRange rangeToExtract,
List<KeyedStateHandle> extractedStateCollector)
Extracts certain key group ranges from the given state handles and adds them to the
collector.
|
OperatorSubtaskState.Builder |
OperatorSubtaskState.Builder.setManagedKeyedState(StateObjectCollection<KeyedStateHandle> managedKeyedState) |
OperatorSubtaskState.Builder |
OperatorSubtaskState.Builder.setRawKeyedState(StateObjectCollection<KeyedStateHandle> rawKeyedState) |
Constructor and Description |
---|
SubtaskState(ChainedStateHandle<OperatorStateHandle> managedOperatorState,
ChainedStateHandle<OperatorStateHandle> rawOperatorState,
KeyedStateHandle managedKeyedState,
KeyedStateHandle rawKeyedState)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static KeyedStateHandle |
MetadataV3Serializer.deserializeKeyedStateHandleUtil(DataInputStream dis) |
Modifier and Type | Method and Description |
---|---|
static void |
MetadataV3Serializer.serializeKeyedStateHandleUtil(KeyedStateHandle stateHandle,
DataOutputStream dos) |
Modifier and Type | Interface and Description |
---|---|
interface |
IncrementalKeyedStateHandle
Common interface to all incremental
KeyedStateHandle . |
interface |
SavepointKeyedStateHandle
A
KeyedStateHandle that points to a savepoint taken in the unified format. |
Modifier and Type | Class and Description |
---|---|
class |
DirectoryKeyedStateHandle
This class is a keyed state handle based on a directory.
|
class |
IncrementalLocalKeyedStateHandle
State handle for local copies of
IncrementalRemoteKeyedStateHandle . |
class |
IncrementalRemoteKeyedStateHandle
The handle to states of an incremental snapshot.
|
class |
KeyGroupsSavepointStateHandle
A
KeyGroupsStateHandle that describes a savepoint in the unified format. |
class |
KeyGroupsStateHandle
A handle to the partitioned stream operator state after it has been checkpointed.
|
Modifier and Type | Field and Description |
---|---|
protected RunnableFuture<SnapshotResult<KeyedStateHandle>> |
StateSnapshotContextSynchronousImpl.keyedStateCheckpointClosingFuture |
protected Collection<KeyedStateHandle> |
AbstractKeyedStateBackendBuilder.restoreStateHandles |
Modifier and Type | Method and Description |
---|---|
KeyedStateHandle |
CheckpointStreamWithResultProvider.KeyedStateHandleFactory.create(KeyGroupRangeOffsets keyGroupRangeOffsets,
StreamStateHandle streamStateHandle) |
KeyedStateHandle |
IncrementalRemoteKeyedStateHandle.getIntersection(KeyGroupRange keyGroupRange) |
KeyedStateHandle |
KeyedStateHandle.getIntersection(KeyGroupRange keyGroupRange)
Returns a state over a range that is the intersection between this handle's key-group range
and the provided key-group range.
|
KeyedStateHandle |
DirectoryKeyedStateHandle.getIntersection(KeyGroupRange otherKeyGroupRange) |
Modifier and Type | Method and Description |
---|---|
SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle> |
SavepointSnapshotStrategy.asyncSnapshot(FullSnapshotResources<K> savepointResources,
long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
SnapshotResult<KeyedStateHandle> |
FullSnapshotAsyncWriter.get(CloseableRegistry snapshotCloseableRegistry) |
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
StateSnapshotContextSynchronousImpl.getKeyedStateStreamFuture() |
static SnapshotResult<KeyedStateHandle> |
CheckpointStreamWithResultProvider.toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle> snapshotResult,
KeyGroupRangeOffsets keyGroupRangeOffsets,
CheckpointStreamWithResultProvider.KeyedStateHandleFactory stateHandleFactory)
Helper method that takes a
SnapshotResult and a KeyGroupRangeOffsets and creates a SnapshotResult by combining the
key groups offsets with all the present stream state handles. |
Modifier and Type | Method and Description |
---|---|
abstract <K> AbstractKeyedStateBackend<K> |
AbstractStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Creates a new
CheckpointableKeyedStateBackend that is responsible for holding
keyed state and checkpointing it. |
default <K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Creates a new
CheckpointableKeyedStateBackend with the given managed memory fraction. |
abstract <K> AbstractKeyedStateBackend<K> |
AbstractManagedMemoryStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
Constructor and Description |
---|
AbstractKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ClassLoader userCodeClassLoader,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
Collection<KeyedStateHandle> stateHandles,
StreamCompressionDecorator keyGroupCompressionDecorator,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Interface and Description |
---|---|
interface |
ChangelogStateBackendHandle
A handle to ChangelogStateBackend state.
|
interface |
ChangelogStateHandle
A handle to saved
state changes . |
Modifier and Type | Class and Description |
---|---|
static class |
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl |
class |
ChangelogStateHandleStreamImpl
ChangelogStateHandle implementation based on StreamStateHandle . |
Modifier and Type | Method and Description |
---|---|
KeyedStateHandle |
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl.getIntersection(KeyGroupRange keyGroupRange) |
KeyedStateHandle |
ChangelogStateHandleStreamImpl.getIntersection(KeyGroupRange keyGroupRange) |
Modifier and Type | Method and Description |
---|---|
List<KeyedStateHandle> |
ChangelogStateBackendHandle.getMaterializedStateHandles() |
List<KeyedStateHandle> |
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl.getMaterializedStateHandles() |
Modifier and Type | Method and Description |
---|---|
static ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl |
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl.restore(List<KeyedStateHandle> materialized,
List<ChangelogStateHandle> nonMaterialized,
KeyGroupRange keyGroupRange,
long materializationID,
long persistedSizeOfThisCheckpoint,
StateHandleID stateHandleId) |
Constructor and Description |
---|
ChangelogStateBackendHandleImpl(List<KeyedStateHandle> materialized,
List<ChangelogStateHandle> nonMaterialized,
KeyGroupRange keyGroupRange,
long materializationID,
long persistedSizeOfThisCheckpoint) |
Modifier and Type | Class and Description |
---|---|
class |
InMemoryChangelogStateHandle
In-memory
ChangelogStateHandle . |
Modifier and Type | Method and Description |
---|---|
KeyedStateHandle |
InMemoryChangelogStateHandle.getIntersection(KeyGroupRange keyGroupRange) |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
FsStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
HashMapStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
HeapKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Constructor and Description |
---|
HeapKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ClassLoader userCodeClassLoader,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
Collection<KeyedStateHandle> stateHandles,
StreamCompressionDecorator keyGroupCompressionDecorator,
LocalRecoveryConfig localRecoveryConfig,
HeapPriorityQueueSetFactory priorityQueueSetFactory,
boolean asynchronousSnapshots,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
MemoryStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
Constructor and Description |
---|
FullSnapshotRestoreOperation(KeyGroupRange keyGroupRange,
ClassLoader userCodeClassLoader,
Collection<KeyedStateHandle> restoreStateHandles,
StateSerializerProvider<K> keySerializerProvider) |
Constructor and Description |
---|
KeyGroupRangeInputSplit(List<KeyedStateHandle> managedKeyedState,
List<KeyedStateHandle> rawKeyedState,
int numKeyGroups,
int split) |
KeyGroupRangeInputSplit(List<KeyedStateHandle> managedKeyedState,
List<KeyedStateHandle> rawKeyedState,
int numKeyGroups,
int split) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
ChangelogKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
<K> ChangelogKeyedStateBackend<K> |
ChangelogStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> CheckpointableKeyedStateBackend<K> |
ChangelogStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
void |
ChangelogKeyedStateBackend.updateChangelogSnapshotState(SnapshotResult<KeyedStateHandle> materializedSnapshot,
long materializationID,
SequenceNumber upTo)
This method is not thread safe.
|
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
OperatorSnapshotFutures.getKeyedStateManagedFuture() |
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
OperatorSnapshotFutures.getKeyedStateRawFuture() |
static SnapshotStrategyRunner<KeyedStateHandle,? extends FullSnapshotResources<?>> |
StreamOperatorStateHandler.prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?> keyedStateBackend,
CloseableRegistry closeableRegistry) |
Modifier and Type | Method and Description |
---|---|
protected CloseableIterable<KeyGroupStatePartitionStreamProvider> |
StreamTaskStateInitializerImpl.rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives) |
void |
OperatorSnapshotFutures.setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture) |
void |
OperatorSnapshotFutures.setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
BatchExecutionKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
<K> CheckpointableKeyedStateBackend<K> |
BatchExecutionStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.