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.
|
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,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
org.rocksdb.RocksDB db,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
int keyGroupPrefixBytes,
CloseableRegistry cancelStreamRegistry,
StreamCompressionDecorator keyGroupCompressionDecorator,
ResourceGuard rocksDBResourceGuard,
RocksDBSnapshotStrategyBase<K> checkpointSnapshotStrategy,
RocksDBSnapshotStrategyBase<K> savepointSnapshotStrategy,
RocksDBWriteBatchWrapper writeBatchWrapper,
org.rocksdb.ColumnFamilyHandle defaultColumnFamilyHandle,
RocksDBNativeMetricMonitor nativeMetricMonitor,
org.apache.flink.contrib.streaming.state.RocksDBSerializedCompositeKeyBuilder<K> sharedRocksKeyBuilder,
PriorityQueueSetFactory priorityQueueFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
InternalKeyContext<K> keyContext,
long writeBatchSize) |
Modifier and Type | Interface and Description |
---|---|
interface |
KeyedStateBackend<K>
A keyed state backend provides methods for managing keyed state.
|
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 . |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.