Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state on the JVM
heap as objects.
|
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.sorted.state |
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 | Field and Description |
---|---|
protected RunnableFuture<SnapshotResult<KeyedStateHandle>> |
StateSnapshotContextSynchronousImpl.keyedStateCheckpointClosingFuture |
protected RunnableFuture<SnapshotResult<OperatorStateHandle>> |
StateSnapshotContextSynchronousImpl.operatorStateCheckpointClosingFuture |
Modifier and Type | Method and Description |
---|---|
SnapshotResult<StreamStateHandle> |
CheckpointStreamWithResultProvider.closeAndFinalizeCheckpointStreamResult()
Closes the stream ans returns a snapshot result with the stream handle(s).
|
SnapshotResult<StreamStateHandle> |
CheckpointStreamWithResultProvider.PrimaryStreamOnly.closeAndFinalizeCheckpointStreamResult() |
SnapshotResult<StreamStateHandle> |
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream.closeAndFinalizeCheckpointStreamResult() |
static <T extends StateObject> |
SnapshotResult.empty() |
SnapshotResult<S> |
SnapshotStrategy.SnapshotResultSupplier.get(CloseableRegistry snapshotCloseableRegistry)
Performs the asynchronous part of a checkpoint and returns the snapshot result.
|
SnapshotResult<KeyedStateHandle> |
FullSnapshotAsyncWriter.get(CloseableRegistry snapshotCloseableRegistry) |
static <T extends StateObject> |
SnapshotResult.of(T jobManagerState) |
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. |
static <T extends StateObject> |
SnapshotResult.withLocalState(T jobManagerState,
T localState) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
StateSnapshotContextSynchronousImpl.getKeyedStateStreamFuture() |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
StateSnapshotContextSynchronousImpl.getOperatorStateStreamFuture() |
RunnableFuture<SnapshotResult<T>> |
SnapshotStrategyRunner.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
DefaultOperatorStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
HeapKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>> |
OperatorSnapshotFutures.getInputChannelStateFuture() |
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
OperatorSnapshotFutures.getKeyedStateManagedFuture() |
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
OperatorSnapshotFutures.getKeyedStateRawFuture() |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
OperatorSnapshotFutures.getOperatorStateManagedFuture() |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
OperatorSnapshotFutures.getOperatorStateRawFuture() |
Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>> |
OperatorSnapshotFutures.getResultSubpartitionStateFuture() |
Modifier and Type | Method and Description |
---|---|
void |
OperatorSnapshotFutures.setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>> inputChannelStateFuture) |
void |
OperatorSnapshotFutures.setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture) |
void |
OperatorSnapshotFutures.setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture) |
void |
OperatorSnapshotFutures.setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture) |
void |
OperatorSnapshotFutures.setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture) |
void |
OperatorSnapshotFutures.setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>> resultSubpartitionStateFuture) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
BatchExecutionKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.