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.state.changelog | |
org.apache.flink.streaming.api.operators.sorted.state |
Modifier and Type | Class and Description |
---|---|
class |
RocksDBKeyedStateBackend<K>
An
AbstractKeyedStateBackend that stores its state in RocksDB and serializes
state to streams provided by a CheckpointStreamFactory
upon checkpointing. |
class |
RocksDBPriorityQueueSetFactory
Encapsulates the logic and resources in connection with creating priority queue state structures,
for RocksDB backend.
|
Constructor and Description |
---|
RocksDBKeyedStateBackend(ClassLoader userCodeClassLoader,
File instanceBasePath,
RocksDBResourceContainer optionsContainer,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
org.rocksdb.RocksDB db,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
int keyGroupPrefixBytes,
CloseableRegistry cancelStreamRegistry,
StreamCompressionDecorator keyGroupCompressionDecorator,
ResourceGuard rocksDBResourceGuard,
RocksDBSnapshotStrategyBase<K,?> checkpointSnapshotStrategy,
RocksDBWriteBatchWrapper writeBatchWrapper,
org.rocksdb.ColumnFamilyHandle defaultColumnFamilyHandle,
RocksDBNativeMetricMonitor nativeMetricMonitor,
SerializedCompositeKeyBuilder<K> sharedRocksKeyBuilder,
PriorityQueueSetFactory priorityQueueFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
InternalKeyContext<K> keyContext,
long writeBatchSize) |
Modifier and Type | Interface and Description |
---|---|
interface |
CheckpointableKeyedStateBackend<K>
Interface that combines both, the
KeyedStateBackend interface, which encapsulates methods
responsible for keyed state management and the Snapshotable which tells the system how to
snapshot the underlying state. |
interface |
KeyedStateBackend<K>
A keyed state backend provides methods for managing keyed state.
|
interface |
TestableKeyedStateBackend<K>
A keyed state backend interface for internal testing purpose.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.
|
Modifier and Type | Class and Description |
---|---|
class |
HeapKeyedStateBackend<K>
A
AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to
streams provided by a CheckpointStreamFactory upon checkpointing. |
class |
HeapPriorityQueueSetFactory
Factory for
HeapPriorityQueueSet . |
Modifier and Type | Class and Description |
---|---|
class |
ChangelogKeyedStateBackend<K>
A
KeyedStateBackend that keeps state on the underlying delegated keyed state backend as
well as on the state change log. |
Modifier and Type | Class and Description |
---|---|
class |
BatchExecutionKeyedStateBackend<K>
A
CheckpointableKeyedStateBackend which keeps values for a single key at a time. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.