Interface | Description |
---|---|
ConfigurableRocksDBOptionsFactory |
An interface for options factory that pick up additional parameters from a configuration.
|
RocksDBCachingPriorityQueueSet.OrderedByteArraySetCache |
Cache that is organized as an ordered set for byte-arrays.
|
RocksDBOptionsFactory |
Class | Description |
---|---|
AbstractRocksDBState<K,N,V> |
Base class for
State implementations that store state in a RocksDB database. |
DefaultConfigurableOptionsFactory |
An implementation of
ConfigurableRocksDBOptionsFactory using options provided by RocksDBConfigurableOptions . |
RocksDBCachingPriorityQueueSet<E extends HeapPriorityQueueElement> |
A priority queue with set semantics, implemented on top of RocksDB.
|
RocksDBConfigurableOptions |
This class contains the configuration options for the
DefaultConfigurableOptionsFactory . |
RocksDBIncrementalCheckpointUtils |
Utils for RocksDB Incremental Checkpoint.
|
RocksDBKeyedStateBackend<K> |
An
AbstractKeyedStateBackend that stores its state in RocksDB and serializes
state to streams provided by a CheckpointStreamFactory
upon checkpointing. |
RocksDBKeyedStateBackend.RocksDbKvStateInfo |
Rocks DB specific information about the k/v states.
|
RocksDBKeyedStateBackendBuilder<K> |
Builder class for
RocksDBKeyedStateBackend which handles all necessary initializations
and clean ups. |
RocksDBKeySerializationUtils |
Utils for RocksDB state serialization and deserialization.
|
RocksDBMemoryConfiguration |
The settings regarding RocksDBs memory usage.
|
RocksDBMemoryControllerUtils |
Utils to create
Cache and WriteBufferManager which are used to control total
memory usage of RocksDB. |
RocksDBNativeMetricMonitor |
A monitor which pulls {
RocksDB } native metrics and forwards them to Flink's metric group. |
RocksDBNativeMetricOptions |
Enable which RocksDB metrics to forward to Flink's metrics reporter.
|
RocksDBOperationUtils |
Utils for RocksDB Operations.
|
RocksDBOptions |
Configuration options for the RocksDB backend.
|
RocksDBPriorityQueueSetFactory |
Encapsulates the logic and resources in connection with creating priority queue state structures,
for RocksDB backend.
|
RocksDBResourceContainer |
The container for RocksDB resources, including predefined options, option factory and shared
resource among instances.
|
RocksDBStateBackend |
A State Backend that stores its state in
RocksDB . |
RocksDBStateBackendFactory |
A factory that creates an
RocksDBStateBackend
from a configuration. |
RocksDBStateDownloader |
Help class for downloading RocksDB state files.
|
RocksDBStateUploader |
Help class for uploading RocksDB state files.
|
RocksDBWriteBatchWrapper |
It's a wrapper class around RocksDB's
WriteBatch for writing in bulk. |
RocksIteratorWrapper |
This is a wrapper around
RocksIterator to check the iterator status for all the methods
mentioned to require this check in the wiki documentation: seek, next, seekToFirst, seekToLast,
seekForPrev, and prev. |
TreeOrderedSetCache |
Implementation of a lexicographically ordered set of byte-arrays, based on a
TreeSet . |
Enum | Description |
---|---|
PredefinedOptions |
The
PredefinedOptions are configuration settings for the RocksDBStateBackend . |
RocksDBProperty |
RocksDB properties that can be queried by Flink's metrics reporter. |
RocksDBStateBackend.PriorityQueueStateType |
The options to chose for the type of priority queue state.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.