Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.contrib.streaming.state.snapshot | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.filesystem | |
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.runtime.state.memory | |
org.apache.flink.state.api.output.operators | |
org.apache.flink.state.changelog | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.sorted.state | |
org.apache.flink.streaming.runtime.operators.asyncprocessing | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
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.
|
List<IncrementalKeyedStateHandle.HandleAndLocalPath> |
RocksDBStateUploader.uploadFilesToCheckpointFs(List<Path> files,
CheckpointStreamFactory checkpointStreamFactory,
CheckpointedStateScope stateScope,
CloseableRegistry closeableRegistry,
CloseableRegistry tmpResourcesRegistry)
Upload all the files to checkpoint fileSystem using specified number of threads.
|
Modifier and Type | Field and Description |
---|---|
protected CheckpointStreamFactory |
RocksDBSnapshotStrategyBase.RocksDBSnapshotOperation.checkpointStreamFactory
Stream factory that creates the output streams to DFS.
|
Constructor and Description |
---|
RocksDBSnapshotOperation(long checkpointId,
CheckpointStreamFactory checkpointStreamFactory,
SnapshotDirectory localBackupDirectory,
List<StateMetaInfoSnapshot> stateMetaInfoSnapshots) |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointStorageLocation
A storage location for one particular checkpoint, offering data persistent, metadata persistence,
and lifecycle/cleanup methods.
|
Modifier and Type | Method and Description |
---|---|
CheckpointStreamFactory |
CheckpointStorageWorkerView.resolveCheckpointStorageLocation(long checkpointId,
CheckpointStorageLocationReference reference)
Resolves a storage location reference into a CheckpointStreamFactory.
|
Modifier and Type | Method and Description |
---|---|
SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle> |
SavepointSnapshotStrategy.asyncSnapshot(FullSnapshotResources<K> savepointResources,
long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
SnapshotStrategy.SnapshotResultSupplier<S> |
SnapshotStrategy.asyncSnapshot(SR syncPartResource,
long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions)
Operation that writes a snapshot into a stream that is provided by the given
CheckpointStreamFactory and returns a @SupplierWithException that gives a state
handle to the snapshot. |
static CheckpointStreamWithResultProvider |
CheckpointStreamWithResultProvider.createDuplicatingStream(long checkpointId,
CheckpointedStateScope checkpointedStateScope,
CheckpointStreamFactory primaryStreamFactory,
LocalSnapshotDirectoryProvider secondaryStreamDirProvider) |
static CheckpointStreamWithResultProvider |
CheckpointStreamWithResultProvider.createSimpleStream(CheckpointedStateScope checkpointedStateScope,
CheckpointStreamFactory primaryStreamFactory) |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
DefaultOperatorStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
RunnableFuture<SnapshotResult<T>> |
SnapshotStrategyRunner.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
RunnableFuture<S> |
Snapshotable.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions)
Operation that writes a snapshot into a stream that is provided by the given
CheckpointStreamFactory and returns a @RunnableFuture that gives a state handle to
the snapshot. |
Constructor and Description |
---|
StateSnapshotContextSynchronousImpl(long checkpointId,
long checkpointTimestamp,
CheckpointStreamFactory streamFactory,
KeyGroupRange keyGroupRange,
CloseableRegistry closableRegistry) |
Modifier and Type | Class and Description |
---|---|
class |
FsCheckpointStorageLocation
A storage location for checkpoints on a file system.
|
class |
FsCheckpointStreamFactory
A
CheckpointStreamFactory that produces streams that write to a FileSystem . |
class |
FsMergingCheckpointStorageLocation
An implementation of checkpoint storage location for file merging checkpoints.
|
Modifier and Type | Method and Description |
---|---|
CheckpointStreamFactory |
FsCheckpointStorageAccess.resolveCheckpointStorageLocation(long checkpointId,
CheckpointStorageLocationReference reference) |
CheckpointStreamFactory |
FsMergingCheckpointStorageAccess.resolveCheckpointStorageLocation(long checkpointId,
CheckpointStorageLocationReference reference) |
CheckpointStreamFactory |
FsMergingCheckpointStorageLocation.toNonFileMerging() |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
HeapKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Class and Description |
---|---|
class |
MemCheckpointStreamFactory
CheckpointStreamFactory that produces streams that write to in-memory byte arrays. |
class |
NonPersistentMetadataCheckpointStorageLocation
A checkpoint storage location for the
MemoryStateBackend in case no durable persistence
for metadata has been configured. |
class |
PersistentMetadataCheckpointStorageLocation
A checkpoint storage location for the
MemoryStateBackend when it durably persists the
metadata in a file system. |
Modifier and Type | Method and Description |
---|---|
CheckpointStreamFactory |
MemoryBackendCheckpointStorageAccess.resolveCheckpointStorageLocation(long checkpointId,
CheckpointStorageLocationReference reference) |
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
StateBootstrapWrapperOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory storageLocation) |
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 |
---|---|
OperatorSnapshotFutures |
AbstractStreamOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
OperatorSnapshotFutures |
StreamOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory storageLocation)
Called to draw a state snapshot from the operator.
|
OperatorSnapshotFutures |
AbstractStreamOperatorV2.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
OperatorSnapshotFutures |
StreamOperatorStateHandler.snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator streamOperator,
Optional<InternalTimeServiceManager<?>> timeServiceManager,
String operatorName,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory,
boolean isUsingCustomRawKeyedState) |
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 |
---|---|
OperatorSnapshotFutures |
AbstractAsyncStateStreamOperatorV2.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
OperatorSnapshotFutures |
AbstractAsyncStateStreamOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.