Uses of Package
org.apache.flink.state.rocksdb
-
Classes in org.apache.flink.state.rocksdb used by org.apache.flink.contrib.streaming.state Class Description ConfigurableRocksDBOptionsFactory An interface for options factory that pick up additional parameters from a configuration.EmbeddedRocksDBStateBackend AStateBackend
that stores its state in an embeddedRocksDB
instance.RocksDBConfigurableOptions This class contains the configuration options for theEmbeddedRocksDBStateBackend
.RocksDBNativeMetricOptions Enable which RocksDB metrics to forward to Flink's metrics reporter.RocksDBOptions Configuration options for the RocksDB backend.RocksDBOptionsFactory -
Classes in org.apache.flink.state.rocksdb used by org.apache.flink.state.rocksdb Class Description AbstractRocksDBState Base class forState
implementations that store state in a RocksDB database.EmbeddedRocksDBStateBackend AStateBackend
that stores its state in an embeddedRocksDB
instance.EmbeddedRocksDBStateBackend.PriorityQueueStateType The options to chose for the type of priority queue state.PredefinedOptions ThePredefinedOptions
are configuration settings for theEmbeddedRocksDBStateBackend
.RocksDBCachingPriorityQueueSet.OrderedByteArraySetCache Cache that is organized as an ordered set for byte-arrays.RocksDBIncrementalCheckpointUtils.RangeCheckResult Helper class that represents the result of a range check of the actual keys in a RocksDB instance against the proclaimed key-group range of the instance.RocksDBKeyedStateBackend AnAbstractKeyedStateBackend
that stores its state inRocksDB
and serializes state to streams provided by aCheckpointStreamFactory
upon checkpointing.RocksDBKeyedStateBackend.RocksDbKvStateInfo Rocks DB specific information about the k/v states.RocksDBKeyedStateBackendBuilder Builder class forRocksDBKeyedStateBackend
which handles all necessary initializations and clean ups.RocksDBMemoryConfiguration The settings regarding RocksDBs memory usage.RocksDBMemoryControllerUtils.RocksDBMemoryFactory Factory for Write Buffer Manager and Bock Cache.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.RocksDBOptionsFactory RocksDBPriorityQueueConfig The configuration of rocksDB priority queue state implementation.RocksDBProperty RocksDB
properties that can be queried by Flink's metrics reporter.RocksDBResourceContainer The container for RocksDB resources, including predefined options, option factory and shared resource among instances.RocksDBStateDataTransferHelper Data transfer helper forRocksDBKeyedStateBackend
.RocksDBWriteBatchWrapper It's a wrapper class around RocksDB'sWriteBatch
for writing in bulk.RocksIteratorWrapper This class was originally a wrapper aroundRocksIterator
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.StateHandleDownloadSpec This class represents a download specification for the content of oneIncrementalRemoteKeyedStateHandle
to a targetPath
. -
Classes in org.apache.flink.state.rocksdb used by org.apache.flink.state.rocksdb.iterator Class Description RocksIteratorWrapper This class was originally a wrapper aroundRocksIterator
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. -
Classes in org.apache.flink.state.rocksdb used by org.apache.flink.state.rocksdb.restore Class Description RocksDBKeyedStateBackend.RocksDbKvStateInfo Rocks DB specific information about the k/v states.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. -
Classes in org.apache.flink.state.rocksdb used by org.apache.flink.state.rocksdb.snapshot Class Description RocksDBKeyedStateBackend.RocksDbKvStateInfo Rocks DB specific information about the k/v states.RocksDBStateUploader Help class for uploading RocksDB state files. -
Classes in org.apache.flink.state.rocksdb used by org.apache.flink.state.rocksdb.sstmerge Class Description RocksDBKeyedStateBackend.RocksDbKvStateInfo Rocks DB specific information about the k/v states.