A B C D E F G H I J K L M N O P R S T U V W Z 

A

AbstractCompactionFilter<T extends AbstractSlice<?>> - Class in org.rocksdb
A CompactionFilter allows an application to modify/delete a key-value at the time of compaction.
AbstractCompactionFilter(long) - Constructor for class org.rocksdb.AbstractCompactionFilter
 
AbstractCompactionFilter.Context - Class in org.rocksdb
 
AbstractCompactionFilter.Context(boolean, boolean) - Constructor for class org.rocksdb.AbstractCompactionFilter.Context
 
AbstractCompactionFilterFactory<T extends AbstractCompactionFilter<?>> - Class in org.rocksdb
Each compaction will create a new AbstractCompactionFilter allowing the application to know about different compactions
AbstractCompactionFilterFactory() - Constructor for class org.rocksdb.AbstractCompactionFilterFactory
 
AbstractComparator - Class in org.rocksdb
Comparators are used by RocksDB to determine the ordering of keys.
AbstractComparator(ComparatorOptions) - Constructor for class org.rocksdb.AbstractComparator
 
AbstractImmutableNativeReference - Class in org.rocksdb
Offers functionality for implementations of AbstractNativeReference which have an immutable reference to the underlying native C++ object
AbstractImmutableNativeReference(boolean) - Constructor for class org.rocksdb.AbstractImmutableNativeReference
 
AbstractMutableOptions - Class in org.rocksdb
 
AbstractMutableOptions(String[], String[]) - Constructor for class org.rocksdb.AbstractMutableOptions
User must use builder pattern, or parser.
AbstractMutableOptions.AbstractMutableOptionsBuilder<T extends AbstractMutableOptions,U extends AbstractMutableOptions.AbstractMutableOptionsBuilder<T,U,K>,K extends MutableOptionKey> - Class in org.rocksdb
 
AbstractMutableOptions.AbstractMutableOptionsBuilder() - Constructor for class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
AbstractNativeReference - Class in org.rocksdb
AbstractNativeReference is the base-class of all RocksDB classes that have a pointer to a native C++ rocksdb object.
AbstractNativeReference() - Constructor for class org.rocksdb.AbstractNativeReference
 
AbstractRocksIterator<P extends RocksObject> - Class in org.rocksdb
Base class implementation for Rocks Iterators in the Java API
AbstractRocksIterator(P, long) - Constructor for class org.rocksdb.AbstractRocksIterator
 
AbstractSlice<T> - Class in org.rocksdb
Slices are used by RocksDB to provide efficient access to keys and values.
AbstractSlice() - Constructor for class org.rocksdb.AbstractSlice
 
AbstractSlice(long) - Constructor for class org.rocksdb.AbstractSlice
 
AbstractTableFilter - Class in org.rocksdb
Base class for Table Filters.
AbstractTableFilter() - Constructor for class org.rocksdb.AbstractTableFilter
 
AbstractTraceWriter - Class in org.rocksdb
Base class for TraceWriters.
AbstractTraceWriter() - Constructor for class org.rocksdb.AbstractTraceWriter
 
AbstractTransactionNotifier - Class in org.rocksdb
Provides notification to the caller of SetSnapshotOnNextOperation when the actual snapshot gets created
AbstractTransactionNotifier() - Constructor for class org.rocksdb.AbstractTransactionNotifier
 
AbstractWalFilter - Class in org.rocksdb
Base class for WAL Filters.
AbstractWalFilter() - Constructor for class org.rocksdb.AbstractWalFilter
 
AbstractWriteBatch - Class in org.rocksdb
 
AbstractWriteBatch(long) - Constructor for class org.rocksdb.AbstractWriteBatch
 
AccessHint - Enum in org.rocksdb
File access pattern once a compaction has started
accessHintOnCompactionStart() - Method in class org.rocksdb.DBOptions
 
accessHintOnCompactionStart() - Method in interface org.rocksdb.DBOptionsInterface
Specify the file access pattern once a compaction is started.
accessHintOnCompactionStart() - Method in class org.rocksdb.Options
 
add(CompactionJobStats) - Method in class org.rocksdb.CompactionJobStats
Aggregate the CompactionJobStats from another instance with this one.
add(Slice, Slice) - Method in class org.rocksdb.SstFileWriter
add(DirectSlice, DirectSlice) - Method in class org.rocksdb.SstFileWriter
AdvancedColumnFamilyOptionsInterface<T extends AdvancedColumnFamilyOptionsInterface<T>> - Interface in org.rocksdb
Advanced Column Family Options which are not mutable (i.e.
AdvancedMutableColumnFamilyOptionsInterface<T extends AdvancedMutableColumnFamilyOptionsInterface<T>> - Interface in org.rocksdb
Advanced Column Family Options which are mutable Taken from include/rocksdb/advanced_options.h and MutableCFOptions in util/cf_options.h
adviseRandomOnOpen() - Method in class org.rocksdb.DBOptions
 
adviseRandomOnOpen() - Method in interface org.rocksdb.DBOptionsInterface
If set true, will hint the underlying file system that the file access pattern is random, when a sst file is opened.
adviseRandomOnOpen() - Method in class org.rocksdb.Options
 
allKeys() - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
Get all of the possible keys
allKeys() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
allKeys() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
allow2pc() - Method in class org.rocksdb.DBOptions
 
allow2pc() - Method in interface org.rocksdb.DBOptionsInterface
if set to false then recovery will fail when a prepared transaction is encountered in the WAL Default: false
allow2pc() - Method in class org.rocksdb.Options
 
allowBlockingFlush() - Method in class org.rocksdb.IngestExternalFileOptions
If set to false and the file key range overlaps with the memtable key range (memtable flush required), IngestExternalFile will fail.
allowCompaction() - Method in class org.rocksdb.CompactionOptionsFIFO
Check if intra-L0 compaction is enabled.
allowConcurrentMemtableWrite() - Method in class org.rocksdb.DBOptions
 
allowConcurrentMemtableWrite() - Method in interface org.rocksdb.DBOptionsInterface
If true, allow multi-writers to update mem tables in parallel.
allowConcurrentMemtableWrite() - Method in class org.rocksdb.Options
 
allowFAllocate() - Method in class org.rocksdb.DBOptions
 
allowFAllocate() - Method in interface org.rocksdb.DBOptionsInterface
Whether fallocate calls are allowed
allowFallocate() - Method in class org.rocksdb.EnvOptions
Determine if fallocate calls are used.
allowFAllocate() - Method in class org.rocksdb.Options
 
allowGlobalSeqNo() - Method in class org.rocksdb.IngestExternalFileOptions
If set to false, RocksDB.ingestExternalFile(ColumnFamilyHandle, List, IngestExternalFileOptions) will fail if the file key range overlaps with existing keys or tombstones in the DB.
allowIngestBehind() - Method in class org.rocksdb.DBOptions
 
allowIngestBehind() - Method in interface org.rocksdb.DBOptionsInterface
Returns true if ingest behind is allowed.
allowIngestBehind() - Method in class org.rocksdb.Options
 
allowMmapReads() - Method in class org.rocksdb.DBOptions
 
allowMmapReads() - Method in interface org.rocksdb.DBOptionsInterface
Allow the OS to mmap file for reading sst tables.
allowMmapReads() - Method in class org.rocksdb.Options
 
allowMmapWrites() - Method in class org.rocksdb.DBOptions
 
allowMmapWrites() - Method in interface org.rocksdb.DBOptionsInterface
Allow the OS to mmap file for writing.
allowMmapWrites() - Method in class org.rocksdb.Options
 
allowTrivialMove() - Method in class org.rocksdb.CompactionOptionsUniversal
Option to optimize the universal multi level compaction by enabling trivial move for non overlapping files.
allowWriteStall() - Method in class org.rocksdb.CompactRangeOptions
If true, compaction will execute immediately even if doing so would cause the DB to enter write stall mode.
allowWriteStall() - Method in class org.rocksdb.FlushOptions
Returns true if writes are allowed to stall for flushes to complete, false otherwise.
appMetadata() - Method in class org.rocksdb.BackupInfo
 
arenaBlockSize() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The size of one block in arena memory allocation.
arenaBlockSize() - Method in class org.rocksdb.ColumnFamilyOptions
 
arenaBlockSize() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
arenaBlockSize() - Method in class org.rocksdb.Options
 
atomicFlush() - Method in class org.rocksdb.DBOptions
 
atomicFlush() - Method in interface org.rocksdb.DBOptionsInterface
Determine if atomic flush of multiple column families is enabled.
atomicFlush() - Method in class org.rocksdb.Options
 
avoidFlushDuringRecovery() - Method in class org.rocksdb.DBOptions
 
avoidFlushDuringRecovery() - Method in interface org.rocksdb.DBOptionsInterface
By default RocksDB replay WAL logs and flush them on DB open, which may create very small SST files.
avoidFlushDuringRecovery() - Method in class org.rocksdb.Options
 
avoidFlushDuringShutdown() - Method in class org.rocksdb.DBOptions
 
avoidFlushDuringShutdown() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
avoidFlushDuringShutdown() - Method in interface org.rocksdb.MutableDBOptionsInterface
By default RocksDB will flush all memtables on DB close if there are unpersisted data (i.e.
avoidFlushDuringShutdown() - Method in class org.rocksdb.Options
 

B

backgroundPurgeOnIteratorCleanup() - Method in class org.rocksdb.ReadOptions
If true, when PurgeObsoleteFile is called in CleanupIteratorState, we schedule a background job in the flush job queue and delete obsolete files in background.
BackupableDBOptions - Class in org.rocksdb
BackupableDBOptions to control the behavior of a backupable database.
BackupableDBOptions(String) - Constructor for class org.rocksdb.BackupableDBOptions
BackupableDBOptions constructor.
backupDir() - Method in class org.rocksdb.BackupableDBOptions
Returns the path to the BackupableDB directory.
BackupEngine - Class in org.rocksdb
BackupEngine allows you to backup and restore the database Be aware, that `new BackupEngine` takes time proportional to the amount of backups.
BackupEngine(long) - Constructor for class org.rocksdb.BackupEngine
 
backupEnv() - Method in class org.rocksdb.BackupableDBOptions
Backup Env object.
backupId() - Method in class org.rocksdb.BackupInfo
 
BackupInfo - Class in org.rocksdb
Instances of this class describe a Backup made by BackupEngine.
backupLogFiles() - Method in class org.rocksdb.BackupableDBOptions
Return information if log files shall be persisted.
backupRateLimit() - Method in class org.rocksdb.BackupableDBOptions
Return backup rate limit which described the max bytes that can be transferred in a second during backup.
backupRateLimiter() - Method in class org.rocksdb.BackupableDBOptions
Backup rate limiter.
baseBackgroundCompactions() - Method in class org.rocksdb.DBOptions
 
baseBackgroundCompactions() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
baseBackgroundCompactions() - Method in interface org.rocksdb.MutableDBOptionsInterface
NOT SUPPORTED ANYMORE: RocksDB automatically decides this based on the value of max_background_jobs.
baseBackgroundCompactions() - Method in class org.rocksdb.Options
 
baseInputLevel() - Method in class org.rocksdb.CompactionJobInfo
Get the smallest input level of the compaction.
beginTransaction(WriteOptions) - Method in class org.rocksdb.OptimisticTransactionDB
 
beginTransaction(WriteOptions, OptimisticTransactionOptions) - Method in class org.rocksdb.OptimisticTransactionDB
 
beginTransaction(WriteOptions, Transaction) - Method in class org.rocksdb.OptimisticTransactionDB
 
beginTransaction(WriteOptions, OptimisticTransactionOptions, Transaction) - Method in class org.rocksdb.OptimisticTransactionDB
 
beginTransaction(WriteOptions) - Method in class org.rocksdb.TransactionDB
 
beginTransaction(WriteOptions, TransactionOptions) - Method in class org.rocksdb.TransactionDB
 
beginTransaction(WriteOptions, Transaction) - Method in class org.rocksdb.TransactionDB
 
beginTransaction(WriteOptions, TransactionOptions, Transaction) - Method in class org.rocksdb.TransactionDB
 
beingCompacted() - Method in class org.rocksdb.SstFileMetaData
Returns true if the file is currently being compacted.
blockAlign() - Method in class org.rocksdb.BlockBasedTableConfig
Determines whether data blocks are aligned on the lesser of page size and block size.
BlockBasedTableConfig - Class in org.rocksdb
The config for plain table sst format.
BlockBasedTableConfig() - Constructor for class org.rocksdb.BlockBasedTableConfig
 
blockCacheCompressedNumShardBits() - Method in class org.rocksdb.BlockBasedTableConfig
Deprecated.
blockCacheCompressedSize() - Method in class org.rocksdb.BlockBasedTableConfig
Deprecated.
blockCacheSize() - Method in class org.rocksdb.BlockBasedTableConfig
Deprecated.
blockRestartInterval() - Method in class org.rocksdb.BlockBasedTableConfig
Get the block restart interval.
blockSize() - Method in class org.rocksdb.BlockBasedTableConfig
Get the approximate size of user data packed per block.
blockSizeDeviation() - Method in class org.rocksdb.BlockBasedTableConfig
 
bloomBitsPerKey() - Method in class org.rocksdb.PlainTableConfig
 
BloomFilter - Class in org.rocksdb
Bloom filter policy that uses a bloom filter with approximately the specified number of bits per key.
BloomFilter() - Constructor for class org.rocksdb.BloomFilter
BloomFilter constructor
BloomFilter(double) - Constructor for class org.rocksdb.BloomFilter
BloomFilter constructor
BloomFilter(double, boolean) - Constructor for class org.rocksdb.BloomFilter
BloomFilter constructor
bloomLocality() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Control locality of bloom filter probes to improve cache miss rate.
bloomLocality() - Method in class org.rocksdb.ColumnFamilyOptions
 
bloomLocality() - Method in class org.rocksdb.Options
 
bottommostCompressionOptions() - Method in class org.rocksdb.ColumnFamilyOptions
 
bottommostCompressionOptions() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Get the bottom most compression options.
bottommostCompressionOptions() - Method in class org.rocksdb.Options
 
bottommostCompressionType() - Method in class org.rocksdb.ColumnFamilyOptions
 
bottommostCompressionType() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Compression algorithm that will be used for the bottommost level that contain files.
bottommostCompressionType() - Method in class org.rocksdb.Options
 
bottommostLevelCompaction() - Method in class org.rocksdb.CompactRangeOptions
Returns the policy for compacting the bottommost level
branchingFactor() - Method in class org.rocksdb.HashSkipListMemTableConfig
 
bucketCount() - Method in class org.rocksdb.HashLinkedListMemTableConfig
Returns the number of buckets that will be used in the memtable created based on this config.
bucketCount() - Method in class org.rocksdb.HashSkipListMemTableConfig
 
bucketEntriesLoggingThreshold() - Method in class org.rocksdb.HashLinkedListMemTableConfig
Returns the maximum number of entries in one bucket before logging starts.
build(String[], String[]) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
Construct a sub-class instance of AbstractMutableOptions.
build() - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
build(String[], String[]) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
build(String[], String[]) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
builder() - Static method in class org.rocksdb.MutableColumnFamilyOptions
Creates a builder which allows you to set MutableColumnFamilyOptions in a fluent manner
builder() - Static method in class org.rocksdb.MutableDBOptions
Creates a builder which allows you to set MutableDBOptions in a fluent manner
BuiltinComparator - Enum in org.rocksdb
Builtin RocksDB comparators BYTEWISE_COMPARATOR - Sorts all keys in ascending bytewise order. REVERSE_BYTEWISE_COMPARATOR - Sorts all keys in descending bytewise order
bytes(String) - Static method in class org.rocksdb.util.ByteUtil
Convert a String to a UTF-8 byte array.
BYTES_MAX_DELETE_CHUNK_DEFAULT - Static variable in class org.rocksdb.SstFileManager
 
bytesPerSync() - Method in class org.rocksdb.DBOptions
 
bytesPerSync() - Method in class org.rocksdb.EnvOptions
Get the number of incremental bytes per sync written in the background.
bytesPerSync() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
bytesPerSync() - Method in interface org.rocksdb.MutableDBOptionsInterface
Allows OS to incrementally sync files to disk while they are being written, asynchronously, in the background.
bytesPerSync() - Method in class org.rocksdb.Options
 
ByteUtil - Class in org.rocksdb.util
 
ByteUtil() - Constructor for class org.rocksdb.util.ByteUtil
 
BytewiseComparator - Class in org.rocksdb.util
This is a Java Native implementation of the C++ equivalent BytewiseComparatorImpl using Slice The performance of Comparators implemented in Java is always less than their C++ counterparts due to the bridging overhead, as such you likely don't want to use this apart from benchmarking and you most likely instead wanted BuiltinComparator.BYTEWISE_COMPARATOR
BytewiseComparator(ComparatorOptions) - Constructor for class org.rocksdb.util.BytewiseComparator
 

C

Cache - Class in org.rocksdb
 
Cache(long) - Constructor for class org.rocksdb.Cache
 
cacheIndexAndFilterBlocks() - Method in class org.rocksdb.BlockBasedTableConfig
Indicating if we'd put index/filter blocks to the block cache.
cacheIndexAndFilterBlocksWithHighPriority() - Method in class org.rocksdb.BlockBasedTableConfig
Indicates if index and filter blocks will be treated as high-priority in the block cache.
cacheNumShardBits() - Method in class org.rocksdb.BlockBasedTableConfig
Deprecated.
callbackTriggerIntervalSize() - Method in class org.rocksdb.BackupableDBOptions
During backup user can get callback every time next BackupableDBOptions.callbackTriggerIntervalSize() bytes being copied.
CassandraCompactionFilter - Class in org.rocksdb
Just a Java wrapper around CassandraCompactionFilter implemented in C++
CassandraCompactionFilter(boolean, int) - Constructor for class org.rocksdb.CassandraCompactionFilter
 
CassandraValueMergeOperator - Class in org.rocksdb
CassandraValueMergeOperator is a merge operator that merges two cassandra wide column values.
CassandraValueMergeOperator(int) - Constructor for class org.rocksdb.CassandraValueMergeOperator
 
CassandraValueMergeOperator(int, int) - Constructor for class org.rocksdb.CassandraValueMergeOperator
 
changeLevel() - Method in class org.rocksdb.CompactRangeOptions
Returns whether compacted files will be moved to the minimum level capable of holding the data or given level (specified non-negative target_level).
Checkpoint - Class in org.rocksdb
Provides Checkpoint functionality.
checksumType() - Method in class org.rocksdb.BlockBasedTableConfig
Get the checksum type to be used with this table.
ChecksumType - Enum in org.rocksdb
Checksum types used in conjunction with BlockBasedTable.
clear() - Method in class org.rocksdb.AbstractSlice
Clears the backing slice
clear() - Method in class org.rocksdb.AbstractWriteBatch
 
clear() - Method in class org.rocksdb.DirectSlice
 
clear() - Method in class org.rocksdb.Slice
 
clear() - Method in class org.rocksdb.WriteBatch.SavePoint
 
clear() - Method in interface org.rocksdb.WriteBatchInterface
Clear all updates buffered in this batch
clearSnapshot() - Method in class org.rocksdb.Transaction
Clears the current snapshot (i.e.
ClockCache - Class in org.rocksdb
Similar to LRUCache, but based on the CLOCK algorithm with better concurrent performance in some cases
ClockCache(long) - Constructor for class org.rocksdb.ClockCache
Create a new cache with a fixed size capacity.
ClockCache(long, int) - Constructor for class org.rocksdb.ClockCache
Create a new cache with a fixed size capacity.
ClockCache(long, int, boolean) - Constructor for class org.rocksdb.ClockCache
Create a new cache with a fixed size capacity.
close() - Method in class org.rocksdb.AbstractImmutableNativeReference
 
close() - Method in class org.rocksdb.AbstractNativeReference
Frees the underlying C++ object
close() - Method in class org.rocksdb.OptimisticTransactionDB
This is similar to OptimisticTransactionDB.closeE() except that it silently ignores any errors.
close() - Method in class org.rocksdb.RocksDB
This is similar to RocksDB.closeE() except that it silently ignores any errors.
close() - Method in class org.rocksdb.RocksMutableObject
 
close() - Method in class org.rocksdb.TransactionDB
This is similar to TransactionDB.closeE() except that it silently ignores any errors.
close() - Method in class org.rocksdb.TtlDB
Close the TtlDB instance and release resource.
close() - Method in class org.rocksdb.WBWIRocksIterator
 
close() - Method in class org.rocksdb.WBWIRocksIterator.WriteEntry
 
closeE() - Method in class org.rocksdb.OptimisticTransactionDB
This is similar to OptimisticTransactionDB.close() except that it throws an exception if any error occurs.
closeE() - Method in class org.rocksdb.RocksDB
This is similar to RocksDB.close() except that it throws an exception if any error occurs.
closeE() - Method in class org.rocksdb.TransactionDB
This is similar to TransactionDB.close() except that it throws an exception if any error occurs.
closeE() - Method in class org.rocksdb.TtlDB
Close the TtlDB instance and release resource.
closeWriter() - Method in interface org.rocksdb.TraceWriter
Close the writer.
ColumnFamilyDescriptor - Class in org.rocksdb
Describes a column family with a name and respective Options.
ColumnFamilyDescriptor(byte[]) - Constructor for class org.rocksdb.ColumnFamilyDescriptor
Creates a new Column Family using a name and default options,
ColumnFamilyDescriptor(byte[], ColumnFamilyOptions) - Constructor for class org.rocksdb.ColumnFamilyDescriptor
Creates a new Column Family using a name and custom options.
ColumnFamilyHandle - Class in org.rocksdb
ColumnFamilyHandle class to hold handles to underlying rocksdb ColumnFamily Pointers.
columnFamilyLogNumberMap(Map<Integer, Long>, Map<String, Integer>) - Method in interface org.rocksdb.WalFilter
Provide ColumnFamily->LogNumber map to filter so that filter can determine whether a log number applies to a given column family (i.e.
ColumnFamilyMetaData - Class in org.rocksdb
The metadata that describes a column family.
columnFamilyName() - Method in class org.rocksdb.ColumnFamilyDescriptor
Deprecated.
columnFamilyName() - Method in class org.rocksdb.CompactionJobInfo
Get the name of the column family where the compaction happened.
columnFamilyName() - Method in class org.rocksdb.LiveFileMetaData
Get the name of the column family.
columnFamilyOptions() - Method in class org.rocksdb.ColumnFamilyDescriptor
Deprecated.
ColumnFamilyOptions - Class in org.rocksdb
ColumnFamilyOptions to control the behavior of a database.
ColumnFamilyOptions() - Constructor for class org.rocksdb.ColumnFamilyOptions
Construct ColumnFamilyOptions.
ColumnFamilyOptions(ColumnFamilyOptions) - Constructor for class org.rocksdb.ColumnFamilyOptions
Copy constructor for ColumnFamilyOptions.
ColumnFamilyOptions(Options) - Constructor for class org.rocksdb.ColumnFamilyOptions
Constructor from Options
ColumnFamilyOptionsInterface<T extends ColumnFamilyOptionsInterface<T>> - Interface in org.rocksdb
 
commit() - Method in class org.rocksdb.Transaction
Write all batched keys to the db atomically.
compactFiles(CompactionOptions, List<String>, int, int, CompactionJobInfo) - Method in class org.rocksdb.RocksDB
Takes a list of files specified by file names and compacts them to the specified level.
compactFiles(CompactionOptions, ColumnFamilyHandle, List<String>, int, int, CompactionJobInfo) - Method in class org.rocksdb.RocksDB
Takes a list of files specified by file names and compacts them to the specified level.
compactionFilter() - Method in class org.rocksdb.ColumnFamilyOptions
 
compactionFilter() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Accessor for the CompactionFilter instance in use.
compactionFilter() - Method in class org.rocksdb.Options
 
compactionFilterFactory() - Method in class org.rocksdb.ColumnFamilyOptions
 
compactionFilterFactory() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Accessor for the CompactionFilterFactory instance in use.
compactionFilterFactory() - Method in class org.rocksdb.Options
 
CompactionJobInfo - Class in org.rocksdb
 
CompactionJobInfo() - Constructor for class org.rocksdb.CompactionJobInfo
 
CompactionJobStats - Class in org.rocksdb
 
CompactionJobStats() - Constructor for class org.rocksdb.CompactionJobStats
 
CompactionOptions - Class in org.rocksdb
CompactionOptions() - Constructor for class org.rocksdb.CompactionOptions
 
compactionOptionsFIFO() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The options for FIFO compaction style
compactionOptionsFIFO() - Method in class org.rocksdb.ColumnFamilyOptions
 
CompactionOptionsFIFO - Class in org.rocksdb
Options for FIFO Compaction
CompactionOptionsFIFO() - Constructor for class org.rocksdb.CompactionOptionsFIFO
 
compactionOptionsFIFO() - Method in class org.rocksdb.Options
 
compactionOptionsUniversal() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The options needed to support Universal Style compactions
compactionOptionsUniversal() - Method in class org.rocksdb.ColumnFamilyOptions
 
CompactionOptionsUniversal - Class in org.rocksdb
Options for Universal Compaction
CompactionOptionsUniversal() - Constructor for class org.rocksdb.CompactionOptionsUniversal
 
compactionOptionsUniversal() - Method in class org.rocksdb.Options
 
compactionPriority() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Get the Compaction priority if level compaction is used for all levels
compactionPriority() - Method in class org.rocksdb.ColumnFamilyOptions
 
CompactionPriority - Enum in org.rocksdb
Compaction Priorities
compactionPriority() - Method in class org.rocksdb.Options
 
compactionReadaheadSize() - Method in class org.rocksdb.DBOptions
 
compactionReadaheadSize() - Method in class org.rocksdb.EnvOptions
compactionReadaheadSize() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
compactionReadaheadSize() - Method in interface org.rocksdb.MutableDBOptionsInterface
If non-zero, we perform bigger reads when doing compaction.
compactionReadaheadSize() - Method in class org.rocksdb.Options
 
compactionReason() - Method in class org.rocksdb.CompactionJobInfo
Get the Reason for running the compaction.
CompactionReason - Enum in org.rocksdb
 
CompactionStopStyle - Enum in org.rocksdb
Algorithm used to make a compaction request stop picking new files into a single compaction run
compactionStyle() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Compaction style for DB.
compactionStyle() - Method in class org.rocksdb.ColumnFamilyOptions
 
CompactionStyle - Enum in org.rocksdb
Enum CompactionStyle RocksDB supports different styles of compaction.
compactionStyle() - Method in class org.rocksdb.Options
 
compactRange() - Method in class org.rocksdb.RocksDB
Range compaction of database.
compactRange(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Range compaction of column family.
compactRange(byte[], byte[]) - Method in class org.rocksdb.RocksDB
Range compaction of database.
compactRange(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Range compaction of column family.
compactRange(boolean, int, int) - Method in class org.rocksdb.RocksDB
compactRange(ColumnFamilyHandle, boolean, int, int) - Method in class org.rocksdb.RocksDB
compactRange(byte[], byte[], boolean, int, int) - Method in class org.rocksdb.RocksDB
compactRange(ColumnFamilyHandle, byte[], byte[], boolean, int, int) - Method in class org.rocksdb.RocksDB
compactRange(ColumnFamilyHandle, byte[], byte[], CompactRangeOptions) - Method in class org.rocksdb.RocksDB
Range compaction of column family.
CompactRangeOptions - Class in org.rocksdb
CompactRangeOptions is used by CompactRange() call.
CompactRangeOptions() - Constructor for class org.rocksdb.CompactRangeOptions
Construct CompactRangeOptions.
CompactRangeOptions.BottommostLevelCompaction - Enum in org.rocksdb
 
ComparatorBug - Class in org.rocksdb
 
ComparatorBug() - Constructor for class org.rocksdb.ComparatorBug
 
ComparatorBug.VersionedComparator - Class in org.rocksdb
 
ComparatorBug.VersionedComparator(ComparatorOptions) - Constructor for class org.rocksdb.ComparatorBug.VersionedComparator
 
ComparatorOptions - Class in org.rocksdb
This class controls the behaviour of Java implementations of AbstractComparator Note that dispose() must be called before a ComparatorOptions instance becomes out-of-scope to release the allocated memory in C++.
ComparatorOptions() - Constructor for class org.rocksdb.ComparatorOptions
 
compare(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.AbstractComparator
Three-way key comparison.
compare(AbstractSlice<?>) - Method in class org.rocksdb.AbstractSlice
Three-way key comparison
compare(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.ComparatorBug.VersionedComparator
 
compare(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.NativeComparatorWrapper
 
compare(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.util.BytewiseComparator
 
compare(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.util.IntComparator
 
compare(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.util.ReverseBytewiseComparator
 
compression() - Method in class org.rocksdb.CompactionJobInfo
Get the compression algorithm used for output files.
compression() - Method in class org.rocksdb.CompactionOptions
Get the compaction output compression type.
compressionOptions() - Method in class org.rocksdb.ColumnFamilyOptions
 
compressionOptions() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Get the different options for compression algorithms
CompressionOptions - Class in org.rocksdb
Options for Compression
CompressionOptions() - Constructor for class org.rocksdb.CompressionOptions
 
compressionOptions() - Method in class org.rocksdb.Options
 
compressionPerLevel() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Return the currently set CompressionType per instances.
compressionPerLevel() - Method in class org.rocksdb.ColumnFamilyOptions
 
compressionPerLevel() - Method in class org.rocksdb.Options
 
compressionSizePercent() - Method in class org.rocksdb.CompactionOptionsUniversal
If this option is set to be -1 (the default value), all the output files will follow compression type specified.
compressionType() - Method in class org.rocksdb.ColumnFamilyOptions
 
CompressionType - Enum in org.rocksdb
Enum CompressionType
compressionType() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
compressionType() - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Compress blocks using the specified compression algorithm.
compressionType() - Method in class org.rocksdb.Options
 
CONTINUE_UNCHANGED - Static variable in class org.rocksdb.WalFilter.LogRecordFoundResult
 
continueBackgroundWork() - Method in class org.rocksdb.RocksDB
Resumes background work which was suspended by previously calling RocksDB.pauseBackgroundWork()
count() - Method in class org.rocksdb.AbstractWriteBatch
 
count - Variable in class org.rocksdb.RocksDB.CountAndSize
 
count() - Method in interface org.rocksdb.WriteBatchInterface
Returns the number of updates in the batch.
create(RocksDB) - Static method in class org.rocksdb.Checkpoint
Creates a Checkpoint object to be used for creating open-able snapshots.
createCheckpoint(String) - Method in class org.rocksdb.Checkpoint
Builds an open-able snapshot of RocksDB on the same disk, which accepts an output directory on the same disk, and under the directory (1) hard-linked SST files pointing to existing live SST files (2) a copied manifest files and other files
createColumnFamilies(ColumnFamilyOptions, List<byte[]>) - Method in class org.rocksdb.RocksDB
Bulk create column families with the same column family options.
createColumnFamilies(List<ColumnFamilyDescriptor>) - Method in class org.rocksdb.RocksDB
Bulk create column families with the same column family options.
createColumnFamily(ColumnFamilyDescriptor) - Method in class org.rocksdb.RocksDB
Creates a new column family with the name columnFamilyName and allocates a ColumnFamilyHandle within an internal structure.
createColumnFamilyWithTtl(ColumnFamilyDescriptor, int) - Method in class org.rocksdb.TtlDB
Creates a new ttl based column family with a name defined in given ColumnFamilyDescriptor and allocates a ColumnFamilyHandle within an internal structure.
createCompactionFilter(AbstractCompactionFilter.Context) - Method in class org.rocksdb.AbstractCompactionFilterFactory
Create a new compaction filter
createIfMissing() - Method in class org.rocksdb.DBOptions
 
createIfMissing() - Method in interface org.rocksdb.DBOptionsInterface
Return true if the create_if_missing flag is set to true.
createIfMissing() - Method in class org.rocksdb.Options
 
createMissingColumnFamilies() - Method in class org.rocksdb.DBOptions
 
createMissingColumnFamilies() - Method in interface org.rocksdb.DBOptionsInterface
Return true if the create_missing_column_families flag is set to true.
createMissingColumnFamilies() - Method in class org.rocksdb.Options
 
createNewBackup(RocksDB) - Method in class org.rocksdb.BackupEngine
Captures the state of the database in the latest backup Just a convenience for BackupEngine.createNewBackup(RocksDB, boolean) with the flushBeforeBackup parameter set to false
createNewBackup(RocksDB, boolean) - Method in class org.rocksdb.BackupEngine
Captures the state of the database in the latest backup
createNewBackupWithMetadata(RocksDB, String, boolean) - Method in class org.rocksdb.BackupEngine
Captures the state of the database in the latest backup along with application specific metadata.
createNewLoggerDbOptions(long) - Method in class org.rocksdb.Logger
 
createNewLoggerOptions(long) - Method in class org.rocksdb.Logger
 
createNewSliceFromString(String) - Static method in class org.rocksdb.AbstractSlice
 

D

data() - Method in class org.rocksdb.AbstractSlice
Returns the data of the slice.
data() - Method in class org.rocksdb.WriteBatch
Retrieve the serialized version of this batch.
data0(long) - Method in class org.rocksdb.AbstractSlice
Access to the data is provided by the subtype as it needs to handle the generic typing.
data0(long) - Method in class org.rocksdb.DirectSlice
 
data0(long) - Method in class org.rocksdb.Slice
 
dataBlockHashTableUtilRatio() - Method in class org.rocksdb.BlockBasedTableConfig
Get the #entries/#buckets.
dataBlockIndexType() - Method in class org.rocksdb.BlockBasedTableConfig
Get the data block index type.
DataBlockIndexType - Enum in org.rocksdb
DataBlockIndexType used in conjunction with BlockBasedTable.
dbLogDir() - Method in class org.rocksdb.DBOptions
 
dbLogDir() - Method in interface org.rocksdb.DBOptionsInterface
Returns the directory of info log.
dbLogDir() - Method in class org.rocksdb.Options
 
DBOptions - Class in org.rocksdb
DBOptions to control the behavior of a database.
DBOptions() - Constructor for class org.rocksdb.DBOptions
Construct DBOptions.
DBOptions(DBOptions) - Constructor for class org.rocksdb.DBOptions
Copy constructor for DBOptions.
DBOptions(Options) - Constructor for class org.rocksdb.DBOptions
Constructor from Options
DBOptionsInterface<T extends DBOptionsInterface<T>> - Interface in org.rocksdb
 
DbPath - Class in org.rocksdb
Tuple of database path and target size
DbPath(Path, long) - Constructor for class org.rocksdb.DbPath
 
dbPaths() - Method in class org.rocksdb.DBOptions
 
dbPaths() - Method in interface org.rocksdb.DBOptionsInterface
A list of paths where SST files can be put into, with its target size.
dbPaths() - Method in class org.rocksdb.Options
 
dbWriteBufferSize() - Method in class org.rocksdb.DBOptions
 
dbWriteBufferSize() - Method in interface org.rocksdb.DBOptionsInterface
Amount of data to build up in memtables across all column families before writing to disk.
dbWriteBufferSize() - Method in class org.rocksdb.Options
 
DEFAUL_THRESHOLD_USE_SKIPLIST - Static variable in class org.rocksdb.HashLinkedListMemTableConfig
 
DEFAULT_AUTOTUNE - Static variable in class org.rocksdb.RateLimiter
 
DEFAULT_BLOOM_BITS_PER_KEY - Static variable in class org.rocksdb.PlainTableConfig
 
DEFAULT_BRANCHING_FACTOR - Static variable in class org.rocksdb.HashSkipListMemTableConfig
 
DEFAULT_BUCKET_COUNT - Static variable in class org.rocksdb.HashLinkedListMemTableConfig
 
DEFAULT_BUCKET_COUNT - Static variable in class org.rocksdb.HashSkipListMemTableConfig
 
DEFAULT_BUCKET_ENTRIES_LOG_THRES - Static variable in class org.rocksdb.HashLinkedListMemTableConfig
 
DEFAULT_COLUMN_FAMILY - Static variable in class org.rocksdb.RocksDB
 
DEFAULT_COMPACTION_MEMTABLE_MEMORY_BUDGET - Static variable in interface org.rocksdb.ColumnFamilyOptionsInterface
DEFAULT_ENCODING_TYPE - Static variable in class org.rocksdb.PlainTableConfig
 
DEFAULT_FAIRNESS - Static variable in class org.rocksdb.RateLimiter
 
DEFAULT_FULL_SCAN_MODE - Static variable in class org.rocksdb.PlainTableConfig
 
DEFAULT_HASH_TABLE_RATIO - Static variable in class org.rocksdb.PlainTableConfig
 
DEFAULT_HEIGHT - Static variable in class org.rocksdb.HashSkipListMemTableConfig
 
DEFAULT_HUGE_PAGE_TLB_SIZE - Static variable in class org.rocksdb.HashLinkedListMemTableConfig
 
DEFAULT_HUGE_TLB_SIZE - Static variable in class org.rocksdb.PlainTableConfig
 
DEFAULT_IF_LOG_BUCKET_DIST_WHEN_FLUSH - Static variable in class org.rocksdb.HashLinkedListMemTableConfig
 
DEFAULT_INDEX_SPARSENESS - Static variable in class org.rocksdb.PlainTableConfig
 
DEFAULT_LOOKAHEAD - Static variable in class org.rocksdb.SkipListMemTableConfig
 
DEFAULT_MODE - Static variable in class org.rocksdb.RateLimiter
 
DEFAULT_REFILL_PERIOD_MICROS - Static variable in class org.rocksdb.RateLimiter
 
DEFAULT_RESERVED_SIZE - Static variable in class org.rocksdb.VectorMemTableConfig
 
DEFAULT_STORE_INDEX_IN_FILE - Static variable in class org.rocksdb.PlainTableConfig
 
delayedWriteRate() - Method in class org.rocksdb.DBOptions
 
delayedWriteRate() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
delayedWriteRate() - Method in interface org.rocksdb.MutableDBOptionsInterface
The limited write rate to DB if ColumnFamilyOptions.softPendingCompactionBytesLimit() or ColumnFamilyOptions.level0SlowdownWritesTrigger() is triggered, or we are writing to the last mem table allowed and we allow more than 3 mem tables.
delayedWriteRate() - Method in class org.rocksdb.Options
 
delete(byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
delete(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
delete(byte[]) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(byte[], int, int) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(ColumnFamilyHandle, byte[], int, int) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(WriteOptions, byte[]) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(WriteOptions, byte[], int, int) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(ColumnFamilyHandle, WriteOptions, byte[]) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(ColumnFamilyHandle, WriteOptions, byte[], int, int) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(WriteOptions, ByteBuffer) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(ColumnFamilyHandle, WriteOptions, ByteBuffer) - Method in class org.rocksdb.RocksDB
Delete the database entry (if any) for "key".
delete(Slice) - Method in class org.rocksdb.SstFileWriter
Add a deletion key to currently opened file.
delete(DirectSlice) - Method in class org.rocksdb.SstFileWriter
Add a deletion key to currently opened file.
delete(byte[]) - Method in class org.rocksdb.SstFileWriter
Add a deletion key to currently opened file.
delete(ColumnFamilyHandle, byte[], boolean) - Method in class org.rocksdb.Transaction
Similar to RocksDB.delete(ColumnFamilyHandle, byte[]), but will also perform conflict checking on the keys be written.
delete(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.Transaction
Similar to Transaction.delete(ColumnFamilyHandle, byte[], boolean) but with assumeTracked = false.
delete(byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.delete(byte[]), but will also perform conflict checking on the keys be written.
delete(ColumnFamilyHandle, byte[][], boolean) - Method in class org.rocksdb.Transaction
Similar to Transaction.delete(ColumnFamilyHandle, byte[]) but allows you to specify the key in several parts that will be concatenated together.
delete(ColumnFamilyHandle, byte[][]) - Method in class org.rocksdb.Transaction
Similar toTransaction.delete(ColumnFamilyHandle, byte[][], boolean) but with assumeTracked = false.
delete(byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.delete(byte[]) but allows you to specify key the in several parts that will be concatenated together.
delete(int, byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
delete(byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
delete(byte[]) - Method in interface org.rocksdb.WriteBatchInterface
If the database contains a mapping for "key", erase it.
delete(ColumnFamilyHandle, byte[]) - Method in interface org.rocksdb.WriteBatchInterface
If column family contains a mapping for "key", erase it.
DELETE_EXISTING_TRASH_DEFAULT - Static variable in class org.rocksdb.SstFileManager
 
deleteBackup(int) - Method in class org.rocksdb.BackupEngine
Deletes a backup
deleteFile(String) - Method in class org.rocksdb.RocksDB
Delete the file name from the db directory and update the internal state to reflect that.
deleteFilesInRanges(ColumnFamilyHandle, List<byte[]>, boolean) - Method in class org.rocksdb.RocksDB
Delete files in multiple ranges at once.
deleteObsoleteFilesPeriodMicros() - Method in class org.rocksdb.DBOptions
 
deleteObsoleteFilesPeriodMicros() - Method in interface org.rocksdb.DBOptionsInterface
The periodicity when obsolete files get deleted.
deleteObsoleteFilesPeriodMicros() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
deleteObsoleteFilesPeriodMicros() - Method in interface org.rocksdb.MutableDBOptionsInterface
The periodicity when obsolete files get deleted.
deleteObsoleteFilesPeriodMicros() - Method in class org.rocksdb.Options
 
deleteRange(byte[], byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
deleteRange(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
deleteRange(byte[], byte[]) - Method in class org.rocksdb.RocksDB
Removes the database entries in the range ["beginKey", "endKey"), i.e., including "beginKey" and excluding "endKey".
deleteRange(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Removes the database entries in the range ["beginKey", "endKey"), i.e., including "beginKey" and excluding "endKey".
deleteRange(WriteOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Removes the database entries in the range ["beginKey", "endKey"), i.e., including "beginKey" and excluding "endKey".
deleteRange(ColumnFamilyHandle, WriteOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Removes the database entries in the range ["beginKey", "endKey"), i.e., including "beginKey" and excluding "endKey".
deleteRange(int, byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
deleteRange(byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
deleteRange(byte[], byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Removes the database entries in the range ["beginKey", "endKey"), i.e., including "beginKey" and excluding "endKey".
deleteRange(ColumnFamilyHandle, byte[], byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Removes the database entries in the range ["beginKey", "endKey"), i.e., including "beginKey" and excluding "endKey".
deleteUntracked(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.delete(ColumnFamilyHandle, byte[]), but operates on the transactions write batch.
deleteUntracked(byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.delete(byte[]), but operates on the transactions write batch.
deleteUntracked(ColumnFamilyHandle, byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.deleteUntracked(ColumnFamilyHandle, byte[]) but allows you to specify the key in several parts that will be concatenated together.
deleteUntracked(byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.deleteUntracked(byte[]) but allows you to specify the key in several parts that will be concatenated together.
destroyDB(String, Options) - Static method in class org.rocksdb.RocksDB
Static method to destroy the contents of the specified database.
destroyOldData() - Method in class org.rocksdb.BackupableDBOptions
Returns if old data will be destroyed will performing new backups.
DirectSlice - Class in org.rocksdb
Base class for slices which will receive direct ByteBuffer based access to the underlying data.
DirectSlice(String) - Constructor for class org.rocksdb.DirectSlice
Constructs a slice where the data is taken from a String.
DirectSlice(ByteBuffer, int) - Constructor for class org.rocksdb.DirectSlice
Constructs a slice where the data is read from the provided ByteBuffer up to a certain length
DirectSlice(ByteBuffer) - Constructor for class org.rocksdb.DirectSlice
Constructs a slice where the data is read from the provided ByteBuffer
disableAutoCompactions() - Method in class org.rocksdb.ColumnFamilyOptions
 
disableAutoCompactions() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
disableAutoCompactions() - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Disable automatic compactions.
disableAutoCompactions() - Method in class org.rocksdb.Options
 
disableFileDeletions() - Method in class org.rocksdb.RocksDB
Prevent file deletions.
disableIndexing() - Method in class org.rocksdb.Transaction
By default, all put/merge/delete operations will be indexed in the transaction so that get/getForUpdate/getIterator can search for these keys.
disableWAL() - Method in class org.rocksdb.WriteOptions
If true, writes will not first go to the write ahead log, and the write may got lost after a crash.
disOwnNativeHandle() - Method in class org.rocksdb.AbstractImmutableNativeReference
Releases this AbstractNativeReference from the responsibility of freeing the underlying native C++ object
dispose() - Method in class org.rocksdb.AbstractNativeReference
Deprecated.
disposeInternal(long) - Method in class org.rocksdb.AbstractCompactionFilter
Deletes underlying C++ compaction pointer.
disposeInternal() - Method in class org.rocksdb.AbstractCompactionFilterFactory
We override RocksCallbackObject.disposeInternal() as disposing of a rocksdb::AbstractCompactionFilterFactory requires a slightly different approach as it is a std::shared_ptr
disposeInternal() - Method in class org.rocksdb.AbstractImmutableNativeReference
The helper function of AbstractNativeReference.dispose() which all subclasses of AbstractImmutableNativeReference must implement to release their underlying native C++ objects.
disposeInternal() - Method in class org.rocksdb.AbstractRocksIterator
Deletes underlying C++ iterator pointer.
disposeInternal(long) - Method in class org.rocksdb.AbstractSlice
Deletes underlying C++ slice pointer.
disposeInternal() - Method in class org.rocksdb.AbstractTransactionNotifier
Deletes underlying C++ TransactionNotifier pointer.
disposeInternal(long) - Method in class org.rocksdb.AbstractTransactionNotifier
 
disposeInternal(long) - Method in class org.rocksdb.BackupableDBOptions
 
disposeInternal(long) - Method in class org.rocksdb.BackupEngine
 
disposeInternal(long) - Method in class org.rocksdb.CassandraValueMergeOperator
 
disposeInternal(long) - Method in class org.rocksdb.Checkpoint
 
disposeInternal(long) - Method in class org.rocksdb.ClockCache
 
disposeInternal() - Method in class org.rocksdb.ColumnFamilyHandle
Deletes underlying C++ iterator pointer.
disposeInternal(long) - Method in class org.rocksdb.ColumnFamilyHandle
 
disposeInternal(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
disposeInternal(long) - Method in class org.rocksdb.CompactionJobInfo
 
disposeInternal(long) - Method in class org.rocksdb.CompactionJobStats
 
disposeInternal(long) - Method in class org.rocksdb.CompactionOptions
 
disposeInternal(long) - Method in class org.rocksdb.CompactionOptionsFIFO
 
disposeInternal(long) - Method in class org.rocksdb.CompactionOptionsUniversal
 
disposeInternal(long) - Method in class org.rocksdb.CompactRangeOptions
 
disposeInternal(long) - Method in class org.rocksdb.ComparatorOptions
 
disposeInternal(long) - Method in class org.rocksdb.CompressionOptions
 
disposeInternal(long) - Method in class org.rocksdb.DBOptions
 
disposeInternal() - Method in class org.rocksdb.DirectSlice
 
disposeInternal(long) - Method in class org.rocksdb.EnvOptions
 
disposeInternal() - Method in class org.rocksdb.Filter
Deletes underlying C++ filter pointer.
disposeInternal(long) - Method in class org.rocksdb.Filter
 
disposeInternal(long) - Method in class org.rocksdb.FlushOptions
 
disposeInternal(long) - Method in class org.rocksdb.HdfsEnv
 
disposeInternal(long) - Method in class org.rocksdb.IngestExternalFileOptions
 
disposeInternal() - Method in class org.rocksdb.Logger
We override RocksCallbackObject.disposeInternal() as disposing of a rocksdb::LoggerJniCallback requires a slightly different approach as it is a std::shared_ptr
disposeInternal(long) - Method in class org.rocksdb.LRUCache
 
disposeInternal() - Method in class org.rocksdb.NativeComparatorWrapper
We override RocksCallbackObject.disposeInternal() as disposing of a native rocksdb::Comparator extension requires a slightly different approach as it is not really a RocksCallbackObject
disposeInternal(long) - Method in class org.rocksdb.OptimisticTransactionDB
 
disposeInternal(long) - Method in class org.rocksdb.OptimisticTransactionOptions
 
disposeInternal(long) - Method in class org.rocksdb.Options
 
disposeInternal(long) - Method in class org.rocksdb.PersistentCache
 
disposeInternal(long) - Method in class org.rocksdb.RateLimiter
 
disposeInternal(long) - Method in class org.rocksdb.ReadOptions
 
disposeInternal(long) - Method in class org.rocksdb.RestoreOptions
 
disposeInternal() - Method in class org.rocksdb.RocksCallbackObject
Deletes underlying C++ native callback object pointer
disposeInternal(long) - Method in class org.rocksdb.RocksDB
 
disposeInternal(long) - Method in class org.rocksdb.RocksEnv
 
disposeInternal(long) - Method in class org.rocksdb.RocksIterator
 
disposeInternal(long) - Method in class org.rocksdb.RocksMemEnv
 
disposeInternal() - Method in class org.rocksdb.RocksMutableObject
 
disposeInternal(long) - Method in class org.rocksdb.RocksMutableObject
 
disposeInternal() - Method in class org.rocksdb.RocksObject
Deletes underlying C++ object pointer.
disposeInternal(long) - Method in class org.rocksdb.RocksObject
 
disposeInternal() - Method in class org.rocksdb.Slice
Deletes underlying C++ slice pointer and any buffered data.
disposeInternal(long) - Method in class org.rocksdb.Snapshot
 
disposeInternal(long) - Method in class org.rocksdb.SstFileManager
 
disposeInternal(long) - Method in class org.rocksdb.SstFileReader
 
disposeInternal(long) - Method in class org.rocksdb.SstFileReaderIterator
 
disposeInternal(long) - Method in class org.rocksdb.SstFileWriter
 
disposeInternal(long) - Method in class org.rocksdb.Statistics
 
disposeInternal(long) - Method in class org.rocksdb.StringAppendOperator
 
disposeInternal(long) - Method in class org.rocksdb.TimedEnv
 
disposeInternal(long) - Method in class org.rocksdb.Transaction
 
disposeInternal(long) - Method in class org.rocksdb.TransactionDB
 
disposeInternal(long) - Method in class org.rocksdb.TransactionDBOptions
 
disposeInternal(long) - Method in class org.rocksdb.TransactionLogIterator
 
disposeInternal(long) - Method in class org.rocksdb.TransactionOptions
 
disposeInternal(long) - Method in class org.rocksdb.TtlDB
 
disposeInternal(long) - Method in class org.rocksdb.UInt64AddOperator
 
disposeInternal(long) - Method in class org.rocksdb.WBWIRocksIterator
 
disposeInternal(long) - Method in class org.rocksdb.WriteBatch
 
disposeInternal(long) - Method in class org.rocksdb.WriteBatchWithIndex
 
disposeInternal(long) - Method in class org.rocksdb.WriteBufferManager
 
disposeInternal(long) - Method in class org.rocksdb.WriteOptions
 
dropColumnFamilies(List<ColumnFamilyHandle>) - Method in class org.rocksdb.RocksDB
 
dropColumnFamily(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Drops the column family specified by columnFamilyHandle.
dumpMallocStats() - Method in class org.rocksdb.DBOptions
 
dumpMallocStats() - Method in interface org.rocksdb.DBOptionsInterface
If true, then print malloc stats together with rocksdb.stats when printing to LOG.
dumpMallocStats() - Method in class org.rocksdb.Options
 

E

elapsedMicros() - Method in class org.rocksdb.CompactionJobStats
Get the elapsed time in micro of this compaction.
empty() - Method in class org.rocksdb.AbstractSlice
Return true if the length of the data is zero.
enableAutoCompaction(List<ColumnFamilyHandle>) - Method in class org.rocksdb.RocksDB
Enable automatic compactions for the given column families if they were previously disabled.
enabled() - Method in class org.rocksdb.CompressionOptions
Determine whether these compression options are used for the bottommost_compression_opts.
enableFileDeletions(boolean) - Method in class org.rocksdb.RocksDB
Allow compactions to delete obsolete files.
enableIndexCompression() - Method in class org.rocksdb.BlockBasedTableConfig
Determine if index compression is enabled.
enableIndexing() - Method in class org.rocksdb.Transaction
Re-enables indexing after a previous call to Transaction.disableIndexing()
enablePipelinedWrite() - Method in class org.rocksdb.DBOptions
 
enablePipelinedWrite() - Method in interface org.rocksdb.DBOptionsInterface
Returns true if pipelined writes are enabled.
enablePipelinedWrite() - Method in class org.rocksdb.Options
 
enableThreadTracking() - Method in class org.rocksdb.DBOptions
 
enableThreadTracking() - Method in interface org.rocksdb.DBOptionsInterface
If true, then the status of the threads involved in this DB will be tracked and available via GetThreadList() API.
enableThreadTracking() - Method in class org.rocksdb.Options
 
enableWriteThreadAdaptiveYield() - Method in class org.rocksdb.DBOptions
 
enableWriteThreadAdaptiveYield() - Method in interface org.rocksdb.DBOptionsInterface
If true, threads synchronizing with the write batch group leader will wait for up to DBOptionsInterface.writeThreadMaxYieldUsec() before blocking on a mutex.
enableWriteThreadAdaptiveYield() - Method in class org.rocksdb.Options
 
EncodingType - Enum in org.rocksdb
EncodingType
encodingType() - Method in class org.rocksdb.PlainTableConfig
Returns the active EncodingType
endTrace() - Method in class org.rocksdb.RocksDB
Stop tracing DB operations.
entry() - Method in class org.rocksdb.WBWIRocksIterator
Get the current entry The WriteEntry is only valid until the iterator is repositioned.
Env - Class in org.rocksdb
Base class for all Env implementations in RocksDB.
Environment - Class in org.rocksdb.util
 
Environment() - Constructor for class org.rocksdb.util.Environment
 
EnvOptions - Class in org.rocksdb
Options while opening a file to read/write
EnvOptions() - Constructor for class org.rocksdb.EnvOptions
Construct with default Options
EnvOptions(DBOptions) - Constructor for class org.rocksdb.EnvOptions
Construct from DBOptions.
equals(Object) - Method in class org.rocksdb.AbstractSlice
If other is a slice object, then we defer to compare to check equality, otherwise we return false.
equals(Object) - Method in class org.rocksdb.ColumnFamilyDescriptor
 
equals(Object) - Method in class org.rocksdb.ColumnFamilyHandle
 
equals(Object) - Method in class org.rocksdb.DbPath
 
equals(Object) - Method in class org.rocksdb.WBWIRocksIterator.WriteEntry
 
errorIfExists() - Method in class org.rocksdb.DBOptions
 
errorIfExists() - Method in interface org.rocksdb.DBOptionsInterface
If true, an error will be thrown during RocksDB.open() if the database already exists.
errorIfExists() - Method in class org.rocksdb.Options
 
exclusiveManualCompaction() - Method in class org.rocksdb.CompactRangeOptions
Returns whether the compaction is exclusive or other compactions may run concurrently at the same time.
Experimental - Annotation Type in org.rocksdb
Marks a feature as experimental, meaning that it is likely to change or even be removed/re-engineered in the future

F

failIfOptionsFileError() - Method in class org.rocksdb.DBOptions
 
failIfOptionsFileError() - Method in interface org.rocksdb.DBOptionsInterface
If true, then DB::Open / CreateColumnFamily / DropColumnFamily / SetOptions will fail if options file is not detected or properly persisted.
failIfOptionsFileError() - Method in class org.rocksdb.Options
 
fallocateWithKeepSize() - Method in class org.rocksdb.EnvOptions
Determine if file is preallocated.
fileCount() - Method in class org.rocksdb.ColumnFamilyMetaData
The number of files in this column family.
fileFsyncNanos() - Method in class org.rocksdb.CompactionJobStats
Get the Time spent on file fsync.
fileName() - Method in class org.rocksdb.SstFileMetaData
Get the name of the file.
filePrepareWriteNanos() - Method in class org.rocksdb.CompactionJobStats
Get the Time spent on preparing file write (falocate, etc) Only populated if ColumnFamilyOptions.reportBgIoStats() is set.
fileRangeSyncNanos() - Method in class org.rocksdb.CompactionJobStats
Get the Time spent on sync file range.
files() - Method in class org.rocksdb.LevelMetaData
The metadata of all sst files in this level.
files - Variable in class org.rocksdb.RocksDB.LiveFiles
The files are relative to the RocksDB.getName() and are not absolute paths.
fileSize() - Method in class org.rocksdb.SstFileWriter
Return the current file size.
fileWriteNanos() - Method in class org.rocksdb.CompactionJobStats
Get the Time spent on file's Append() call.
fillCache() - Method in class org.rocksdb.ReadOptions
Fill the cache when loading the block-based sst formated db.
Filter - Class in org.rocksdb
Filters are stored in rocksdb and are consulted automatically by rocksdb to decide whether or not to read some information from disk.
Filter(long) - Constructor for class org.rocksdb.Filter
 
filter(TableProperties) - Method in interface org.rocksdb.TableFilter
A callback to determine whether relevant keys for this scan exist in a given table based on the table's properties.
filterPolicy() - Method in class org.rocksdb.BlockBasedTableConfig
Get the filter policy.
finalize() - Method in class org.rocksdb.AbstractNativeReference
Deprecated.
You should not rely on GC of Rocks objects, and instead should either call AbstractNativeReference.close() manually or make use of some sort of ARM (Automatic Resource Management) such as Java 7's try-with-resources statement
findShortestSeparator(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.AbstractComparator
Used to reduce the space requirements for internal data structures like index blocks.
findShortestSeparator(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.NativeComparatorWrapper
 
findShortestSeparator(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.util.BytewiseComparator
 
findShortestSeparator(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.util.ReverseBytewiseComparator
 
findShortSuccessor(ByteBuffer) - Method in class org.rocksdb.AbstractComparator
Used to reduce the space requirements for internal data structures like index blocks.
findShortSuccessor(ByteBuffer) - Method in class org.rocksdb.NativeComparatorWrapper
 
findShortSuccessor(ByteBuffer) - Method in class org.rocksdb.util.BytewiseComparator
 
finish() - Method in class org.rocksdb.SstFileWriter
Finish the process and close the sst file.
flush(FlushOptions) - Method in class org.rocksdb.RocksDB
Flush all memory table data.
flush(FlushOptions, ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Flush all memory table data.
flush(FlushOptions, List<ColumnFamilyHandle>) - Method in class org.rocksdb.RocksDB
Flushes multiple column families.
FlushOptions - Class in org.rocksdb
FlushOptions to be passed to flush operations of RocksDB.
FlushOptions() - Constructor for class org.rocksdb.FlushOptions
Construct a new instance of FlushOptions.
flushWal(boolean) - Method in class org.rocksdb.RocksDB
Flush the WAL memory buffer to the file.
forceConsistencyChecks() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
In debug mode, RocksDB run consistency checks on the LSM every time the LSM change (Flush, Compaction, AddFile).
forceConsistencyChecks() - Method in class org.rocksdb.ColumnFamilyOptions
 
forceConsistencyChecks() - Method in class org.rocksdb.Options
 
formatVersion() - Method in class org.rocksdb.BlockBasedTableConfig
Get the format version.
fromId(byte) - Static method in enum org.rocksdb.WBWIRocksIterator.WriteType
 
fromRocksId(int) - Static method in enum org.rocksdb.CompactRangeOptions.BottommostLevelCompaction
Returns the BottommostLevelCompaction for the given C++ rocks enum value.
fromString(String, String) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
fromValue(byte) - Static method in enum org.rocksdb.WalProcessingOption
 
fullScanMode() - Method in class org.rocksdb.PlainTableConfig
Return if full scan mode is active

G

garbageCollect() - Method in class org.rocksdb.BackupEngine
Will delete all the files we don't need anymore.
GB - Static variable in class org.rocksdb.util.SizeUnit
 
get(int) - Method in class org.rocksdb.DirectSlice
Retrieves the byte at a specific offset from the underlying data
get(ReadOptions, ByteBuffer, ByteBuffer) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family.
get(ColumnFamilyHandle, ReadOptions, ByteBuffer, ByteBuffer) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family.
get(byte[], byte[]) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family*
get(byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family*
get(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family.
get(ColumnFamilyHandle, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family.
get(ReadOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key.
get(ReadOptions, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key.
get(ColumnFamilyHandle, ReadOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family.
get(ColumnFamilyHandle, ReadOptions, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Get the value associated with the specified key within column family.
get(byte[]) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(byte[], int, int) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ColumnFamilyHandle, byte[], int, int) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ReadOptions, byte[]) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ReadOptions, byte[], int, int) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ColumnFamilyHandle, ReadOptions, byte[]) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ColumnFamilyHandle, ReadOptions, byte[], int, int) - Method in class org.rocksdb.RocksDB
The simplified version of get which returns a new byte array storing the value associated with the specified input key if any.
get(ColumnFamilyHandle, ReadOptions, byte[]) - Method in class org.rocksdb.Transaction
This function is similar to RocksDB.get(ColumnFamilyHandle, ReadOptions, byte[]) except it will also read pending changes in this transaction.
get(ReadOptions, byte[]) - Method in class org.rocksdb.Transaction
This function is similar to RocksDB.get(ReadOptions, byte[]) except it will also read pending changes in this transaction.
getAccessHint(byte) - Static method in enum org.rocksdb.AccessHint
Get the AccessHint enumeration value by passing the byte identifier to this method.
getAggregatedLongProperty(String) - Method in class org.rocksdb.RocksDB
Return sum of the getLongProperty of all the column families
getAllPreparedTransactions() - Method in class org.rocksdb.TransactionDB
 
getAndResetTickerCount(TickerType) - Method in class org.rocksdb.Statistics
Get the count for a ticker and reset the tickers count.
getApproximateMemoryUsageByType(List<RocksDB>, Set<Cache>) - Static method in class org.rocksdb.MemoryUtil
Returns the approximate memory usage of different types in the input list of DBs and Cache set.
getApproximateMemTableStats(ColumnFamilyHandle, Range) - Method in class org.rocksdb.RocksDB
This method is similar to RocksDB.getApproximateSizes(ColumnFamilyHandle, List, SizeApproximationFlag...), except that it returns approximate number of records and size in memtables.
getApproximateMemTableStats(Range) - Method in class org.rocksdb.RocksDB
This method is similar to RocksDB.getApproximateSizes(ColumnFamilyHandle, List, SizeApproximationFlag...), except that it returns approximate number of records and size in memtables.
getApproximateSizes(ColumnFamilyHandle, List<Range>, SizeApproximationFlag...) - Method in class org.rocksdb.RocksDB
Get the approximate file system space used by keys in each range.
getApproximateSizes(List<Range>, SizeApproximationFlag...) - Method in class org.rocksdb.RocksDB
Get the approximate file system space used by keys in each range for the default column family.
getAverage() - Method in class org.rocksdb.HistogramData
 
getBackgroundThreads(Priority) - Method in class org.rocksdb.Env
Gets the number of background worker threads of the pool for this environment.
getBackupInfo() - Method in class org.rocksdb.BackupEngine
Gets information about the available backups
getBaseDB() - Method in class org.rocksdb.OptimisticTransactionDB
Get the underlying database that was opened.
getBatch() - Method in class org.rocksdb.TransactionLogIterator
If iterator position is valid, return the current write_batch and the sequence number of the earliest transaction contained in the batch.
getBoolean(K) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
getBytesPerSecond() - Method in class org.rocksdb.RateLimiter
Returns the bytes per second.
getCallback() - Method in class org.rocksdb.StatsCollectorInput
 
getCfName() - Method in class org.rocksdb.ThreadStatus
The name of the Column Family that the thread is currently involved with.
getCode(byte) - Static method in enum org.rocksdb.Status.Code
 
getCode() - Method in class org.rocksdb.Status
 
getCodeString() - Method in class org.rocksdb.Status
 
getColumnFamilyId() - Method in class org.rocksdb.TableProperties
Get the ID of column family for this SST file, corresponding to the column family identified by TableProperties.getColumnFamilyName().
getColumnFamilyId() - Method in class org.rocksdb.Transaction.WaitingTransactions
Get the Column Family ID.
getColumnFamilyId() - Method in class org.rocksdb.TransactionDB.DeadlockInfo
Get the Column Family ID.
getColumnFamilyMetaData(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Obtains the meta data of the specified column family of the DB.
GetColumnFamilyMetaData() - Method in class org.rocksdb.RocksDB
Obtains the meta data of the default column family of the DB.
getColumnFamilyName() - Method in class org.rocksdb.TableProperties
Get the name of the column family with which this SST file is associated.
getColumnFamilyOptionsFromProps(Properties) - Static method in class org.rocksdb.ColumnFamilyOptions
Method to get a options instance by using pre-configured property values.
getCommitTimeWriteBatch() - Method in class org.rocksdb.Transaction
Get the Commit time Write Batch.
getCompactionPriority(byte) - Static method in enum org.rocksdb.CompactionPriority
Get CompactionPriority by byte value.
getCompactionStopStyle(byte) - Static method in enum org.rocksdb.CompactionStopStyle
Get CompactionStopStyle by byte value.
getComparatorName() - Method in class org.rocksdb.TableProperties
Get the name of the comparator used in this table.
getCompressionName() - Method in class org.rocksdb.TableProperties
Get the name of the compression algorithm used to compress the SST files.
getCompressionType(String) - Static method in enum org.rocksdb.CompressionType
Get the CompressionType enumeration value by passing the library name to this method.
getCompressionType(byte) - Static method in enum org.rocksdb.CompressionType
Get the CompressionType enumeration value by passing the byte identifier to this method.
getContentFlags() - Method in class org.rocksdb.WriteBatch.SavePoint
Get the content flags.
getCorruptedBackups() - Method in class org.rocksdb.BackupEngine
Returns a list of corrupted backup ids.
getCount() - Method in class org.rocksdb.HistogramData
 
getCount() - Method in class org.rocksdb.WriteBatch.SavePoint
Get the number of elements.
getCreationTime() - Method in class org.rocksdb.TableProperties
The time when the SST file was created.
getDataSize() - Method in class org.rocksdb.TableProperties
Get the total size of all data blocks.
getDataSize() - Method in class org.rocksdb.WriteBatch
Retrieve data size of the batch.
getDbName() - Method in class org.rocksdb.ThreadStatus
The name of the DB instance that the thread is currently involved with.
getDBOptionsFromProps(Properties) - Static method in class org.rocksdb.DBOptions
Method to get a options instance by using pre-configured property values.
getDeadlockDetectDepth() - Method in class org.rocksdb.TransactionOptions
Gets the number of traversals to make during deadlock detection.
getDeadlockInfoBuffer() - Method in class org.rocksdb.TransactionDB
 
getDefault() - Static method in class org.rocksdb.Env
Returns the default environment suitable for the current operating system.
getDefaultColumnFamily() - Method in class org.rocksdb.RocksDB
Gets the handle for the default column family
getDefaultLockTimeout() - Method in class org.rocksdb.TransactionDBOptions
The wait timeout in milliseconds when writing a key OUTSIDE of a transaction (ie by calling RocksDB.put(byte[], byte[]), RocksDB.merge(byte[], byte[]), RocksDB.delete(byte[]) or RocksDB.write(org.rocksdb.WriteOptions, org.rocksdb.WriteBatch) directly).
getDeleteRateBytesPerSecond() - Method in class org.rocksdb.SstFileManager
Gets the delete rate limit.
getDescriptor() - Method in class org.rocksdb.ColumnFamilyHandle
Gets the up-to-date descriptor of the column family associated with this handle.
getDouble(K) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
getElapsedTime() - Method in class org.rocksdb.Transaction
Returns the elapsed time in milliseconds since this Transaction began.
getEnum(K) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
getEnv() - Method in class org.rocksdb.DBOptions
 
getEnv() - Method in interface org.rocksdb.DBOptionsInterface
Returns the set RocksEnv instance.
getEnv() - Method in class org.rocksdb.Options
 
getEnv() - Method in class org.rocksdb.RocksDB
Get the Env object from the DB
getExpiration() - Method in class org.rocksdb.TransactionOptions
Expiration duration in milliseconds.
getFileSize() - Method in interface org.rocksdb.TraceWriter
Get the size of the file that this writer is writing to.
getFilterPolicyName() - Method in class org.rocksdb.TableProperties
Get the name of the filter policy used in this table.
getFilterSize() - Method in class org.rocksdb.TableProperties
Get the size of filter block.
getFixedKeyLen() - Method in class org.rocksdb.TableProperties
Get the length of the keys.
getFormatVersion() - Method in class org.rocksdb.TableProperties
Get the format version, reserved for backward compatibility.
getForUpdate(ReadOptions, ColumnFamilyHandle, byte[], boolean, boolean) - Method in class org.rocksdb.Transaction
Read this key and ensure that this transaction will only be able to be committed if this key is not written outside this transaction after it has first been read (or after the snapshot if a snapshot is set in this transaction).
getForUpdate(ReadOptions, ColumnFamilyHandle, byte[], boolean) - Method in class org.rocksdb.Transaction
getForUpdate(ReadOptions, byte[], boolean) - Method in class org.rocksdb.Transaction
Read this key and ensure that this transaction will only be able to be committed if this key is not written outside this transaction after it has first been read (or after the snapshot if a snapshot is set in this transaction).
getFromBatch(ColumnFamilyHandle, DBOptions, byte[]) - Method in class org.rocksdb.WriteBatchWithIndex
Similar to RocksDB.get(ColumnFamilyHandle, byte[]) but will only read the key from this batch.
getFromBatch(DBOptions, byte[]) - Method in class org.rocksdb.WriteBatchWithIndex
Similar to RocksDB.get(byte[]) but will only read the key from this batch.
getFromBatchAndDB(RocksDB, ColumnFamilyHandle, ReadOptions, byte[]) - Method in class org.rocksdb.WriteBatchWithIndex
Similar to RocksDB.get(ColumnFamilyHandle, byte[]) but will also read writes from this batch.
getFromBatchAndDB(RocksDB, ReadOptions, byte[]) - Method in class org.rocksdb.WriteBatchWithIndex
Similar to RocksDB.get(byte[]) but will also read writes from this batch.
getHistogramData(HistogramType) - Method in class org.rocksdb.Statistics
Gets the histogram data for a particular histogram.
getHistogramString(HistogramType) - Method in class org.rocksdb.Statistics
Gets a string representation of a particular histogram.
getHistogramType(byte) - Static method in enum org.rocksdb.HistogramType
Get Histogram type by byte value.
getID() - Method in class org.rocksdb.ColumnFamilyHandle
Gets the ID of the Column Family.
getID() - Method in class org.rocksdb.Transaction
Get the ID of the transaction.
getId() - Method in class org.rocksdb.Transaction
The globally unique id with which the transaction is identified.
getIndexKeyIsUserKey() - Method in class org.rocksdb.TableProperties
Whether the index key is user key.
getIndexPartitions() - Method in class org.rocksdb.TableProperties
Get the total number of index partitions if IndexType.kTwoLevelIndexSearch is used.
getIndexSize() - Method in class org.rocksdb.TableProperties
Get the size of index block.
getIndexValueIsDeltaEncoded() - Method in class org.rocksdb.TableProperties
Whether delta encoding is used to encode the index values.
getInfoLogLevel(byte) - Static method in enum org.rocksdb.InfoLogLevel
Get InfoLogLevel by byte value.
getInstance() - Static method in class org.rocksdb.NativeLibraryLoader
Get a reference to the NativeLibraryLoader
getInt(K) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
getIntArray(K) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
getIterator(ReadOptions) - Method in class org.rocksdb.Transaction
Returns an iterator that will iterate on all keys in the default column family including both keys in the DB and uncommitted keys in this transaction.
getIterator(ReadOptions, ColumnFamilyHandle) - Method in class org.rocksdb.Transaction
Returns an iterator that will iterate on all keys in the default column family including both keys in the DB and uncommitted keys in this transaction.
getJniLibraryExtension() - Static method in class org.rocksdb.util.Environment
 
getJniLibraryFileName(String) - Static method in class org.rocksdb.util.Environment
 
getJniLibraryName(String) - Static method in class org.rocksdb.util.Environment
 
getKey() - Method in class org.rocksdb.Transaction.WaitingTransactions
Get the key on which the transactions are waiting.
getKey() - Method in class org.rocksdb.TransactionDB.KeyLockInfo
Get the key.
getKey() - Method in class org.rocksdb.WBWIRocksIterator.WriteEntry
Returns the key of the Write Entry
getLatestOptionsFileName(String, Env) - Static method in class org.rocksdb.OptionsUtil
Returns the latest options file name under the specified RocksDB path.
getLatestSequenceNumber() - Method in class org.rocksdb.RocksDB
The sequence number of the most recent transaction.
getLibcName() - Static method in class org.rocksdb.util.Environment
Get the name of the libc implementation
getLibraryName() - Method in enum org.rocksdb.CompressionType
Returns the library name of the compression type identified by the enumeration value.
getLiveFiles() - Method in class org.rocksdb.RocksDB
Retrieve the list of all files in the database after flushing the memtable.
getLiveFiles(boolean) - Method in class org.rocksdb.RocksDB
Retrieve the list of all files in the database.
getLiveFilesMetaData() - Method in class org.rocksdb.RocksDB
Gets a list of all table files metadata.
getLockStatusData() - Method in class org.rocksdb.TransactionDB
Returns map of all locks held.
getLockTimeout() - Method in class org.rocksdb.TransactionOptions
The wait timeout in milliseconds when a transaction attempts to lock a key.
getLogNumber() - Method in class org.rocksdb.Transaction
Get the log number.
getLong(K) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
getLongProperty(String) - Method in class org.rocksdb.RocksDB
Similar to GetProperty(), but only works for a subset of properties whose return value is a numerical value.
getLongProperty(ColumnFamilyHandle, String) - Method in class org.rocksdb.RocksDB
Similar to GetProperty(), but only works for a subset of properties whose return value is a numerical value.
getMapProperty(String) - Method in class org.rocksdb.RocksDB
Gets a property map.
getMapProperty(ColumnFamilyHandle, String) - Method in class org.rocksdb.RocksDB
Gets a property map.
getMax() - Method in class org.rocksdb.HistogramData
 
getMaxNumLocks() - Method in class org.rocksdb.TransactionDBOptions
Specifies the maximum number of keys that can be locked at the same time per column family.
getMaxTraceFileSize() - Method in class org.rocksdb.TraceOptions
To avoid the trace file size grows large than the storage space, user can set the max trace file size in Bytes.
getMaxTrashDBRatio() - Method in class org.rocksdb.SstFileManager
Get the trash/DB size ratio where new files will be deleted immediately.
getMaxWriteBatchSize() - Method in class org.rocksdb.TransactionOptions
Get the maximum number of bytes that may be used for the write batch.
getMedian() - Method in class org.rocksdb.HistogramData
 
getMemoryUsageType(byte) - Static method in enum org.rocksdb.MemoryUsageType
Get the MemoryUsageType enumeration value by passing the byte identifier to this method.
getMergeOperatorName() - Method in class org.rocksdb.TableProperties
Get the name of the merge operator used in this table.
getMin() - Method in class org.rocksdb.HistogramData
 
getName() - Method in class org.rocksdb.ColumnFamilyDescriptor
Retrieve name of column family.
getName() - Method in class org.rocksdb.ColumnFamilyHandle
Gets the name of the Column Family.
getName() - Method in class org.rocksdb.RocksDB
Get DB name -- the exact same name that was provided as an argument to as path to RocksDB.open(Options, String).
getName() - Method in class org.rocksdb.Transaction
Get the name of the transaction.
getNativeHandle() - Method in class org.rocksdb.RocksMutableObject
Gets the value of the C++ pointer pointing to the underlying native C++ object
getNumDataBlocks() - Method in class org.rocksdb.TableProperties
Get the number of blocks in this table.
getNumDeletes() - Method in class org.rocksdb.Transaction
Returns the number of deletes that have been applied to this transaction so far.
getNumDeletions() - Method in class org.rocksdb.TableProperties
Get the number of deletions in the table.
getNumEntries() - Method in class org.rocksdb.TableProperties
Get the number of entries in this table.
getNumKeys() - Method in class org.rocksdb.Transaction
Returns the number of distinct Keys being tracked by this transaction.
getNumMergeOperands() - Method in class org.rocksdb.TableProperties
Get the number of merge operands in the table.
getNumMerges() - Method in class org.rocksdb.Transaction
Returns the number of merges that have been applied to this transaction so far.
getNumPuts() - Method in class org.rocksdb.Transaction
Returns the number of puts that have been applied to this transaction so far.
getNumRangeDeletions() - Method in class org.rocksdb.TableProperties
Get the number of range deletions in this table.
getNumStripes() - Method in class org.rocksdb.TransactionDBOptions
The number of sub-tables per lock table (per column family)
getOldestKeyTime() - Method in class org.rocksdb.TableProperties
Get the timestamp of the earliest key.
getOperationElapsedTime() - Method in class org.rocksdb.ThreadStatus
Get the elapsed time of the current thread operation in microseconds.
getOperationName(OperationType) - Static method in class org.rocksdb.ThreadStatus
Get the name of an operation given its type.
getOperationProperties() - Method in class org.rocksdb.ThreadStatus
Get the list of properties that describe some details about the current operation.
getOperationPropertyName(OperationType, int) - Static method in class org.rocksdb.ThreadStatus
Obtain the name of the "i"th operation property of the specified operation.
getOperationStage() - Method in class org.rocksdb.ThreadStatus
Get the current stage where the thread is involved in the current operation.
getOperationStageName(OperationStage) - Static method in class org.rocksdb.ThreadStatus
Obtain a human-readable string describing the specified operation stage.
getOperationType() - Method in class org.rocksdb.ThreadStatus
Get the operation (high-level action) that the current thread is involved with.
getOptions() - Method in class org.rocksdb.ColumnFamilyDescriptor
Retrieve assigned options instance.
getPercentile95() - Method in class org.rocksdb.HistogramData
 
getPercentile99() - Method in class org.rocksdb.HistogramData
 
getPrefixExtractorName() - Method in class org.rocksdb.TableProperties
Get the name of the prefix extractor used in this table.
getPropertiesOfAllTables(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Get the properties of all tables.
getPropertiesOfAllTables() - Method in class org.rocksdb.RocksDB
Get the properties of all tables in the default column family.
getPropertiesOffsets() - Method in class org.rocksdb.TableProperties
The offset of the value of each property in the file.
getPropertiesOfTablesInRange(ColumnFamilyHandle, List<Range>) - Method in class org.rocksdb.RocksDB
Get the properties of tables in range.
getPropertiesOfTablesInRange(List<Range>) - Method in class org.rocksdb.RocksDB
Get the properties of tables in range for the default column family.
getProperty(ColumnFamilyHandle, String) - Method in class org.rocksdb.RocksDB
DB implements can export properties about their state via this method on a per column family level.
getProperty(String) - Method in class org.rocksdb.RocksDB
DB implementations can export properties about their state via this method.
getPropertyCollectorsNames() - Method in class org.rocksdb.TableProperties
Get the names of the property collectors factories used in this table.
getRateLimiterMode(byte) - Static method in enum org.rocksdb.RateLimiterMode
Get the RateLimiterMode enumeration value by passing the byte identifier to this method.
getRawKeySize() - Method in class org.rocksdb.TableProperties
Get the total raw key size.
getRawValueSize() - Method in class org.rocksdb.TableProperties
Get the total raw value size.
getReadableProperties() - Method in class org.rocksdb.TableProperties
Get the readable properties.
getReadTier(byte) - Static method in enum org.rocksdb.ReadTier
Get ReadTier by byte value.
getReusedSynchronisationType(byte) - Static method in enum org.rocksdb.ReusedSynchronisationType
Get ReusedSynchronisationType by byte value.
getSequenceNumber() - Method in class org.rocksdb.Snapshot
Return the associated sequence number;
getSharedLibraryFileName(String) - Static method in class org.rocksdb.util.Environment
 
getSharedLibraryName(String) - Static method in class org.rocksdb.util.Environment
 
getSingleBurstBytes() - Method in class org.rocksdb.RateLimiter
Max bytes can be granted in a single burst.
getSize() - Method in class org.rocksdb.WriteBatch.SavePoint
Get the size of the serialized representation.
getSnapshot() - Method in class org.rocksdb.RocksDB
Return a handle to the current DB state.
getSnapshot() - Method in class org.rocksdb.Transaction
Returns the Snapshot created by the last call to Transaction.setSnapshot().
getSortedWalFiles() - Method in class org.rocksdb.RocksDB
Retrieve the sorted list of all wal files with earliest file first.
getStandardDeviation() - Method in class org.rocksdb.HistogramData
 
getState() - Method in class org.rocksdb.Status
 
getState() - Method in class org.rocksdb.Transaction
Get the execution status of the transaction.
getStateName(StateType) - Static method in class org.rocksdb.ThreadStatus
Obtain the name of a state given its type.
getStateType() - Method in class org.rocksdb.ThreadStatus
Get the state (lower-level action) that the current thread is involved with.
getStatistics() - Method in class org.rocksdb.StatsCollectorInput
 
getStatsLevel(byte) - Static method in enum org.rocksdb.StatsLevel
Get StatsLevel by byte value.
getStatus() - Method in exception org.rocksdb.RocksDBException
Get the status returned from RocksDB
getSubCode() - Method in class org.rocksdb.Status
 
getSubCode(byte) - Static method in enum org.rocksdb.Status.SubCode
 
getSum() - Method in class org.rocksdb.HistogramData
 
getTableProperties() - Method in class org.rocksdb.SstFileReader
Get the properties of the table.
getThreadId() - Method in class org.rocksdb.ThreadStatus
Get the unique ID of the thread.
getThreadList() - Method in class org.rocksdb.Env
Returns the status of all threads that belong to the current Env.
getThreadPoolQueueLen(Priority) - Method in class org.rocksdb.Env
Returns the length of the queue associated with the specified thread pool.
getThreadType() - Method in class org.rocksdb.ThreadStatus
Get the type of the thread.
getThreadTypeName(ThreadType) - Static method in class org.rocksdb.ThreadStatus
Get the name of the thread type.
getTickerCount(TickerType) - Method in class org.rocksdb.Statistics
Get the count for a ticker.
getTickerType(byte) - Static method in enum org.rocksdb.TickerType
Get Ticker type by byte value.
getTopLevelIndexSize() - Method in class org.rocksdb.TableProperties
Size of the top-level index if IndexType.kTwoLevelIndexSearch is used.
getTotalBytesThrough() - Method in class org.rocksdb.RateLimiter
Total bytes that go through rate limiter.
getTotalRequests() - Method in class org.rocksdb.RateLimiter
Total # of requests that go through rate limiter.
getTotalSize() - Method in class org.rocksdb.SstFileManager
Get the total size of all tracked files.
getTrackedFiles() - Method in class org.rocksdb.SstFileManager
Gets all tracked files and their corresponding sizes.
getTransactionByName(String) - Method in class org.rocksdb.TransactionDB
 
getTransactionID() - Method in class org.rocksdb.TransactionDB.DeadlockInfo
Get the Transaction ID.
getTransactionIds() - Method in class org.rocksdb.Transaction.WaitingTransactions
Get the IDs of the waiting transactions.
getTransactionIDs() - Method in class org.rocksdb.TransactionDB.KeyLockInfo
Get the Transaction IDs.
getTransactionLockTimeout() - Method in class org.rocksdb.TransactionDBOptions
The default wait timeout in milliseconds when a transaction attempts to lock a key if not specified by TransactionOptions.setLockTimeout(long) If 0, no waiting is done if a lock cannot instantly be acquired.
getTransactionState(byte) - Static method in enum org.rocksdb.Transaction.TransactionState
Get TransactionState by byte value.
getTxnDBWritePolicy(byte) - Static method in enum org.rocksdb.TxnDBWritePolicy
Get the TxnDBWritePolicy enumeration value by passing the byte identifier to this method.
getType() - Method in class org.rocksdb.WBWIRocksIterator.WriteEntry
Returns the type of the Write Entry
getUpdatesSince(long) - Method in class org.rocksdb.RocksDB
Returns an iterator that is positioned at a write-batch containing seq_number.
getUserCollectedProperties() - Method in class org.rocksdb.TableProperties
Get the user collected properties.
getValue() - Method in enum org.rocksdb.AccessHint
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.ChecksumType
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.CompactionPriority
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.CompactionStopStyle
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.CompactionStyle
Get the internal representation value.
getValue() - Method in enum org.rocksdb.CompactRangeOptions.BottommostLevelCompaction
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.CompressionType
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.EncodingType
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.HistogramType
Returns the byte value of the enumerations value
getValue() - Method in class org.rocksdb.Holder
Get the instance reference.
getValue() - Method in enum org.rocksdb.IndexType
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.InfoLogLevel
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.MemoryUsageType
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.RateLimiterMode
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.ReadTier
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.ReusedSynchronisationType
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.StatsLevel
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.Status.Code
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.Status.SubCode
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.TickerType
Returns the byte value of the enumerations value
getValue() - Method in enum org.rocksdb.TxnDBWritePolicy
Returns the byte value of the enumerations value.
getValue() - Method in enum org.rocksdb.WALRecoveryMode
Returns the byte value of the enumerations value.
getValue() - Method in class org.rocksdb.WBWIRocksIterator.WriteEntry
Returns the value of the Write Entry
getValueType() - Method in enum org.rocksdb.MutableColumnFamilyOptions.CompactionOption
 
getValueType() - Method in enum org.rocksdb.MutableColumnFamilyOptions.MemtableOption
 
getValueType() - Method in enum org.rocksdb.MutableColumnFamilyOptions.MiscOption
 
getValueType() - Method in enum org.rocksdb.MutableDBOptions.DBOption
 
getValueType() - Method in interface org.rocksdb.MutableOptionKey
 
getWaitingKey() - Method in class org.rocksdb.TransactionDB.DeadlockInfo
Get the key that we are waiting on.
getWaitingTxns() - Method in class org.rocksdb.Transaction
Get the list of waiting transactions.
getWALRecoveryMode(byte) - Static method in enum org.rocksdb.WALRecoveryMode
Get the WALRecoveryMode enumeration value by passing the byte identifier to this method.
getWalTerminationPoint() - Method in class org.rocksdb.WriteBatch
Gets the WAL termination point.
getWriteBatch() - Method in class org.rocksdb.AbstractWriteBatch
 
getWriteBatch() - Method in class org.rocksdb.Transaction
Fetch the underlying write batch that contains all pending changes to be committed.
getWriteBatch() - Method in class org.rocksdb.WriteBatch
 
getWriteBatch() - Method in interface org.rocksdb.WriteBatchInterface
Get the underlying Write Batch.
getWriteOptions() - Method in class org.rocksdb.Transaction
Return the WriteOptions that will be used during Transaction.commit().
getWritePolicy() - Method in class org.rocksdb.TransactionDBOptions
The policy for when to write the data into the DB.

H

hardPendingCompactionBytesLimit() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
All writes are stopped if estimated bytes needed to be compaction exceed this threshold.
hardPendingCompactionBytesLimit() - Method in class org.rocksdb.ColumnFamilyOptions
 
hardPendingCompactionBytesLimit() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
hardPendingCompactionBytesLimit() - Method in class org.rocksdb.Options
 
hasBeginPrepare() - Method in class org.rocksdb.WriteBatch
Returns true if MarkBeginPrepare will be called during Iterate.
hasCommit() - Method in class org.rocksdb.WriteBatch
Returns true if MarkCommit will be called during Iterate.
hasDelete() - Method in class org.rocksdb.WriteBatch
Returns true if Delete will be called during Iterate.
hasDeleteRange() - Method in class org.rocksdb.WriteBatch
Returns true if DeleteRange will be called during Iterate.
hasEndPrepare() - Method in class org.rocksdb.WriteBatch
Returns true if MarkEndPrepare will be called during Iterate.
hashCode() - Method in class org.rocksdb.AbstractSlice
 
hashCode() - Method in class org.rocksdb.ColumnFamilyDescriptor
 
hashCode() - Method in class org.rocksdb.ColumnFamilyHandle
 
hashCode() - Method in class org.rocksdb.DbPath
 
hashCode() - Method in class org.rocksdb.WBWIRocksIterator.WriteEntry
Generates a hash code for the Write Entry.
hashIndexAllowCollision() - Method in class org.rocksdb.BlockBasedTableConfig
Deprecated.
This option is now deprecated. No matter what value it is set to, it will behave as if BlockBasedTableConfig.hashIndexAllowCollision() == true.
HashLinkedListMemTableConfig - Class in org.rocksdb
The config for hash linked list memtable representation Such memtable contains a fix-sized array of buckets, where each bucket points to a sorted singly-linked list (or null if the bucket is empty).
HashLinkedListMemTableConfig() - Constructor for class org.rocksdb.HashLinkedListMemTableConfig
HashLinkedListMemTableConfig constructor
HashSkipListMemTableConfig - Class in org.rocksdb
The config for hash skip-list mem-table representation.
HashSkipListMemTableConfig() - Constructor for class org.rocksdb.HashSkipListMemTableConfig
HashSkipListMemTableConfig constructor
hashTableRatio() - Method in class org.rocksdb.PlainTableConfig
 
hasMerge() - Method in class org.rocksdb.WriteBatch
Returns true if Merge will be called during Iterate.
hasPut() - Method in class org.rocksdb.WriteBatch
Returns true if Put will be called during Iterate.
hasRollback() - Method in class org.rocksdb.WriteBatch
Returns true if MarkRollback will be called during Iterate.
hasSingleDelete() - Method in class org.rocksdb.WriteBatch
Returns true if SingleDelete will be called during Iterate.
HdfsEnv - Class in org.rocksdb
HDFS environment.
HdfsEnv(String) - Constructor for class org.rocksdb.HdfsEnv
Creates a new environment that is used for HDFS environment.
height() - Method in class org.rocksdb.HashSkipListMemTableConfig
 
histogramCallback(HistogramType, HistogramData) - Method in interface org.rocksdb.StatisticsCollectorCallback
Callback function to get histogram values.
HistogramData - Class in org.rocksdb
 
HistogramData(double, double, double, double, double) - Constructor for class org.rocksdb.HistogramData
 
HistogramData(double, double, double, double, double, double, long, long, double) - Constructor for class org.rocksdb.HistogramData
 
HistogramType - Enum in org.rocksdb
 
Holder<T> - Class in org.rocksdb
Simple instance reference wrapper.
Holder() - Constructor for class org.rocksdb.Holder
Constructs a new Holder with null instance.
Holder(T) - Constructor for class org.rocksdb.Holder
Constructs a new Holder.
hugePageTlbSize() - Method in class org.rocksdb.HashLinkedListMemTableConfig
Returns the size value of hugePageTlbSize.
hugePageTlbSize() - Method in class org.rocksdb.PlainTableConfig
Returns the value for huge page tlb size

I

ifLogBucketDistWhenFlush() - Method in class org.rocksdb.HashLinkedListMemTableConfig
Returns information about logging the distribution of number of entries on flush.
ignoreMissingColumnFamilies() - Method in class org.rocksdb.WriteOptions
If true and if user is trying to write to column families that don't exist (they were dropped), ignore the write (don't return an error).
ignoreRangeDeletions() - Method in class org.rocksdb.ReadOptions
If true, keys deleted using the DeleteRange() API will be visible to readers until they are naturally deleted during compaction.
incBackgroundThreadsIfNeeded(int, Priority) - Method in class org.rocksdb.Env
Enlarge number of background worker threads of a specific thread pool for this environment if it is smaller than specified.
indexBlockRestartInterval() - Method in class org.rocksdb.BlockBasedTableConfig
Get the index block restart interval.
indexSparseness() - Method in class org.rocksdb.PlainTableConfig
 
indexType() - Method in class org.rocksdb.BlockBasedTableConfig
Get the index type.
IndexType - Enum in org.rocksdb
IndexType used in conjunction with BlockBasedTable.
infoLog() - Method in class org.rocksdb.BackupableDBOptions
Set the logger to use for Backup info and error messages Default: null
infoLogLevel() - Method in class org.rocksdb.DBOptions
 
infoLogLevel() - Method in interface org.rocksdb.DBOptionsInterface
Returns currently set log level.
InfoLogLevel - Enum in org.rocksdb
RocksDB log levels.
infoLogLevel() - Method in class org.rocksdb.Logger
Return the loggers log level.
infoLogLevel(long) - Method in class org.rocksdb.Logger
 
infoLogLevel() - Method in class org.rocksdb.Options
 
ingestBehind() - Method in class org.rocksdb.IngestExternalFileOptions
Returns true if duplicate keys in the file being ingested are to be skipped rather than overwriting existing data under that key.
ingestExternalFile(List<String>, IngestExternalFileOptions) - Method in class org.rocksdb.RocksDB
ingestExternalFile will load a list of external SST files (1) into the DB We will try to find the lowest possible level that the file can fit in, and ingest the file into this level (2).
ingestExternalFile(ColumnFamilyHandle, List<String>, IngestExternalFileOptions) - Method in class org.rocksdb.RocksDB
ingestExternalFile will load a list of external SST files (1) into the DB We will try to find the lowest possible level that the file can fit in, and ingest the file into this level (2).
IngestExternalFileOptions - Class in org.rocksdb
IngestExternalFileOptions() - Constructor for class org.rocksdb.IngestExternalFileOptions
 
IngestExternalFileOptions(boolean, boolean, boolean, boolean) - Constructor for class org.rocksdb.IngestExternalFileOptions
 
initializeNative(long...) - Method in class org.rocksdb.AbstractCompactionFilterFactory
 
initializeNative(long...) - Method in class org.rocksdb.AbstractComparator
 
initializeNative(long...) - Method in class org.rocksdb.AbstractTableFilter
 
initializeNative(long...) - Method in class org.rocksdb.AbstractTraceWriter
 
initializeNative(long...) - Method in class org.rocksdb.AbstractTransactionNotifier
 
initializeNative(long...) - Method in class org.rocksdb.AbstractWalFilter
 
initializeNative(long...) - Method in class org.rocksdb.Logger
 
initializeNative(long...) - Method in class org.rocksdb.RocksCallbackObject
Construct the Native C++ object which will callback to our object methods
initializeNative(long...) - Method in class org.rocksdb.WriteBatch.Handler
 
inplaceUpdateNumLocks() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Number of locks used for inplace update Default: 10000, if inplace_update_support = true, else 0.
inplaceUpdateNumLocks() - Method in class org.rocksdb.ColumnFamilyOptions
 
inplaceUpdateNumLocks() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
inplaceUpdateNumLocks() - Method in class org.rocksdb.Options
 
inplaceUpdateSupport() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Allows thread-safe inplace updates.
inplaceUpdateSupport() - Method in class org.rocksdb.ColumnFamilyOptions
 
inplaceUpdateSupport() - Method in class org.rocksdb.Options
 
inputFiles() - Method in class org.rocksdb.CompactionJobInfo
Get the names of the compaction input files.
IntComparator - Class in org.rocksdb.util
This is a Java implementation of a Comparator for Java int keys.
IntComparator(ComparatorOptions) - Constructor for class org.rocksdb.util.IntComparator
 
interpretOperationProperties(OperationType, long[]) - Static method in class org.rocksdb.ThreadStatus
Translate the "i"th property of the specified operation given a property value.
is64Bit() - Static method in class org.rocksdb.util.Environment
 
isAarch64() - Static method in class org.rocksdb.util.Environment
 
isAix() - Static method in class org.rocksdb.util.Environment
 
isCleared() - Method in class org.rocksdb.WriteBatch.SavePoint
 
isDeadlockDetect() - Method in class org.rocksdb.Transaction
Determine if a deadlock has been detected.
isDeadlockDetect() - Method in class org.rocksdb.TransactionOptions
True means that before acquiring locks, this transaction will check if doing so will cause a deadlock.
isEmpty() - Method in class org.rocksdb.TransactionDB.DeadlockPath
 
isExclusive() - Method in class org.rocksdb.TransactionDB.DeadlockInfo
Get the Lock status.
isExclusive() - Method in class org.rocksdb.TransactionDB.KeyLockInfo
Get the Lock status.
isFdCloseOnExec() - Method in class org.rocksdb.DBOptions
 
isFdCloseOnExec() - Method in interface org.rocksdb.DBOptionsInterface
Disable child process inherit open files.
isFdCloseOnExec() - Method in class org.rocksdb.Options
 
isFreeBSD() - Static method in class org.rocksdb.util.Environment
 
isFullCompaction() - Method in class org.rocksdb.AbstractCompactionFilter.Context
Does this compaction run include all data files
isMac() - Static method in class org.rocksdb.util.Environment
 
isManualCompaction() - Method in class org.rocksdb.AbstractCompactionFilter.Context
Is this compaction requested by the client, or is it occurring as an automatic compaction process
isManualCompaction() - Method in class org.rocksdb.CompactionJobStats
Determine if the compaction is a manual compaction.
isMaxAllowedSpaceReached() - Method in class org.rocksdb.SstFileManager
Determines if the total size of SST files exceeded the maximum allowed space usage.
isMaxAllowedSpaceReachedIncludingCompactions() - Method in class org.rocksdb.SstFileManager
Determines if the total size of SST files as well as estimated size of ongoing compactions exceeds the maximums allowed space usage.
isMuslLibc() - Static method in class org.rocksdb.util.Environment
 
isOpenBSD() - Static method in class org.rocksdb.util.Environment
 
isOwningHandle() - Method in class org.rocksdb.AbstractImmutableNativeReference
 
isOwningHandle() - Method in class org.rocksdb.AbstractNativeReference
Returns true if we are responsible for freeing the underlying C++ object
isOwningHandle() - Method in class org.rocksdb.RocksMutableObject
 
isPowerPC() - Static method in class org.rocksdb.util.Environment
 
isS390x() - Static method in class org.rocksdb.util.Environment
 
isSetSnapshot() - Method in class org.rocksdb.OptimisticTransactionOptions
 
isSetSnapshot() - Method in class org.rocksdb.TransactionOptions
 
isSolaris() - Static method in class org.rocksdb.util.Environment
 
isUnix() - Static method in class org.rocksdb.util.Environment
 
isValid() - Method in class org.rocksdb.AbstractRocksIterator
 
isValid() - Method in interface org.rocksdb.RocksIteratorInterface
An iterator is either positioned at an entry, or not valid.
isValid() - Method in class org.rocksdb.TransactionLogIterator
An iterator is either positioned at a WriteBatch or not valid.
isWindows() - Static method in class org.rocksdb.util.Environment
 
iterate(WriteBatch.Handler) - Method in class org.rocksdb.WriteBatch
Support for iterating over the contents of a batch.
iterateLowerBound() - Method in class org.rocksdb.ReadOptions
Returns the smallest key at which the backward iterator can return an entry.
iterateUpperBound() - Method in class org.rocksdb.ReadOptions
Returns the largest key at which the forward iterator can return an entry.
iterStartSeqnum() - Method in class org.rocksdb.ReadOptions
Returns the starting Sequence Number of any iterator.

J

jobId() - Method in class org.rocksdb.CompactionJobInfo
Get the job id, which is unique in the same thread.

K

KB - Static variable in class org.rocksdb.util.SizeUnit
 
keepLogFileNum() - Method in class org.rocksdb.DBOptions
 
keepLogFileNum() - Method in interface org.rocksdb.DBOptionsInterface
Returns the maximum number of info log files to be kept.
keepLogFileNum() - Method in class org.rocksdb.Options
 
key() - Method in class org.rocksdb.RocksIterator
Return the key for the current entry.
key(ByteBuffer) - Method in class org.rocksdb.RocksIterator
Return the key for the current entry.
key() - Method in class org.rocksdb.SstFileReaderIterator
Return the key for the current entry.
key(ByteBuffer) - Method in class org.rocksdb.SstFileReaderIterator
Return the key for the current entry.
KEY_VALUE_PAIR_SEPARATOR - Static variable in class org.rocksdb.AbstractMutableOptions
 
KEY_VALUE_SEPARATOR - Static variable in class org.rocksdb.AbstractMutableOptions
 
keyMayExist(byte[], Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(byte[], int, int, Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(ColumnFamilyHandle, byte[], Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(ColumnFamilyHandle, byte[], int, int, Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(ReadOptions, byte[], Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(ReadOptions, byte[], int, int, Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(ColumnFamilyHandle, ReadOptions, byte[], Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keyMayExist(ColumnFamilyHandle, ReadOptions, byte[], int, int, Holder<byte[]>) - Method in class org.rocksdb.RocksDB
If the key definitely does not exist in the database, then this method returns null, else it returns an instance of KeyMayExistResult If the caller wants to obtain value when the key is found in memory, then valueHolder must be set.
keys - Variable in class org.rocksdb.AbstractMutableOptions
 
keySize() - Method in class org.rocksdb.PlainTableConfig
 

L

largestKey() - Method in class org.rocksdb.SstFileMetaData
Get the largest user defined key in the file.
largestOutputKeyPrefix() - Method in class org.rocksdb.CompactionJobStats
Get the largest output key prefix.
largestSeqno() - Method in class org.rocksdb.SstFileMetaData
Get the largest sequence number in file.
level() - Method in class org.rocksdb.CompressionOptions
 
level() - Method in class org.rocksdb.LevelMetaData
The level which this meta data describes.
level() - Method in class org.rocksdb.LiveFileMetaData
Get the level at which this file resides.
level0FileNumCompactionTrigger() - Method in class org.rocksdb.ColumnFamilyOptions
 
level0FileNumCompactionTrigger() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
level0FileNumCompactionTrigger() - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Number of files to trigger level-0 compaction.
level0FileNumCompactionTrigger() - Method in class org.rocksdb.Options
 
level0SlowdownWritesTrigger() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Soft limit on number of level-0 files.
level0SlowdownWritesTrigger() - Method in class org.rocksdb.ColumnFamilyOptions
 
level0SlowdownWritesTrigger() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
level0SlowdownWritesTrigger() - Method in class org.rocksdb.Options
 
level0StopWritesTrigger() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Maximum number of level-0 files.
level0StopWritesTrigger() - Method in class org.rocksdb.ColumnFamilyOptions
 
level0StopWritesTrigger() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
level0StopWritesTrigger() - Method in class org.rocksdb.Options
 
level0StopWriteTrigger() - Method in class org.rocksdb.RocksDB
Number of files in level-0 that would stop writes.
level0StopWriteTrigger(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Number of files in level-0 that would stop writes.
levelCompactionDynamicLevelBytes() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Return if LevelCompactionDynamicLevelBytes is enabled.
levelCompactionDynamicLevelBytes() - Method in class org.rocksdb.ColumnFamilyOptions
 
levelCompactionDynamicLevelBytes() - Method in class org.rocksdb.Options
 
LevelMetaData - Class in org.rocksdb
The metadata that describes a level.
levels() - Method in class org.rocksdb.ColumnFamilyMetaData
The metadata of all levels in this column family.
levelZeroFileNumCompactionTrigger() - Method in class org.rocksdb.ColumnFamilyOptions
 
levelZeroFileNumCompactionTrigger() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
The number of files in level 0 to trigger compaction from level-0 to level-1.
levelZeroFileNumCompactionTrigger() - Method in class org.rocksdb.Options
 
levelZeroSlowdownWritesTrigger() - Method in class org.rocksdb.ColumnFamilyOptions
 
levelZeroSlowdownWritesTrigger() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Soft limit on the number of level-0 files.
levelZeroSlowdownWritesTrigger() - Method in class org.rocksdb.Options
 
levelZeroStopWritesTrigger() - Method in class org.rocksdb.ColumnFamilyOptions
 
levelZeroStopWritesTrigger() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Maximum number of level-0 files.
levelZeroStopWritesTrigger() - Method in class org.rocksdb.Options
 
listColumnFamilies(Options, String) - Static method in class org.rocksdb.RocksDB
Static method to determine all available column families for a rocksdb database identified by path
LiveFileMetaData - Class in org.rocksdb
The full set of metadata associated with each SST file.
loadLatestOptions(String, Env, DBOptions, List<ColumnFamilyDescriptor>) - Static method in class org.rocksdb.OptionsUtil
A static method to construct the DBOptions and ColumnFamilyDescriptors by loading the latest RocksDB options file stored in the specified rocksdb database.
loadLatestOptions(String, Env, DBOptions, List<ColumnFamilyDescriptor>, boolean) - Static method in class org.rocksdb.OptionsUtil
 
loadLibrary(String) - Method in class org.rocksdb.NativeLibraryLoader
Firstly attempts to load the library from java.library.path, if that fails then it falls back to extracting the library from the classpath NativeLibraryLoader.loadLibraryFromJar(java.lang.String)
loadLibrary() - Static method in class org.rocksdb.RocksDB
Loads the necessary library files.
loadLibrary(List<String>) - Static method in class org.rocksdb.RocksDB
Tries to load the necessary library files from the given list of directories.
loadOptionsFromFile(String, Env, DBOptions, List<ColumnFamilyDescriptor>) - Static method in class org.rocksdb.OptionsUtil
Similar to LoadLatestOptions, this function constructs the DBOptions and ColumnFamilyDescriptors based on the specified RocksDB Options file.
loadOptionsFromFile(String, Env, DBOptions, List<ColumnFamilyDescriptor>, boolean) - Static method in class org.rocksdb.OptionsUtil
 
log(InfoLogLevel, String) - Method in class org.rocksdb.Logger
 
logData(byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
LogFile - Class in org.rocksdb
 
logFileTimeToRoll() - Method in class org.rocksdb.DBOptions
 
logFileTimeToRoll() - Method in interface org.rocksdb.DBOptionsInterface
Returns the time interval for the info log file to roll (in seconds).
logFileTimeToRoll() - Method in class org.rocksdb.Options
 
Logger - Class in org.rocksdb
This class provides a custom logger functionality in Java which wraps RocksDB logging facilities.
Logger(Options) - Constructor for class org.rocksdb.Logger
AbstractLogger constructor.
Logger(DBOptions) - Constructor for class org.rocksdb.Logger
AbstractLogger constructor.
logNumber() - Method in class org.rocksdb.LogFile
Primary identifier for log file.
logRecordFound(long, String, WriteBatch, WriteBatch) - Method in interface org.rocksdb.WalFilter
LogRecord is invoked for each log record encountered for all the logs during replay on logs on recovery.
lookahead() - Method in class org.rocksdb.SkipListMemTableConfig
Returns the currently set lookahead value.
lowerThreadPoolCPUPriority(Priority) - Method in class org.rocksdb.Env
Lower CPU priority for threads from the specified pool.
lowerThreadPoolIOPriority(Priority) - Method in class org.rocksdb.Env
Lower IO priority for threads from the specified pool.
lowPri() - Method in class org.rocksdb.WriteOptions
Returns true if this write request is of lower priority if compaction is behind.
LRUCache - Class in org.rocksdb
Least Recently Used Cache
LRUCache(long) - Constructor for class org.rocksdb.LRUCache
Create a new cache with a fixed size capacity
LRUCache(long, int) - Constructor for class org.rocksdb.LRUCache
Create a new cache with a fixed size capacity.
LRUCache(long, int, boolean) - Constructor for class org.rocksdb.LRUCache
Create a new cache with a fixed size capacity.
LRUCache(long, int, boolean, double) - Constructor for class org.rocksdb.LRUCache
Create a new cache with a fixed size capacity.

M

main(String[]) - Static method in class org.rocksdb.ComparatorBug
 
managed() - Method in class org.rocksdb.ReadOptions
Deprecated.
This options is not used anymore.
manifestFileSize - Variable in class org.rocksdb.RocksDB.LiveFiles
The valid size of the manifest file.
manifestPreallocationSize() - Method in class org.rocksdb.DBOptions
 
manifestPreallocationSize() - Method in interface org.rocksdb.DBOptionsInterface
Number of bytes to preallocate (via fallocate) the manifest files.
manifestPreallocationSize() - Method in class org.rocksdb.Options
 
manualWalFlush() - Method in class org.rocksdb.DBOptions
 
manualWalFlush() - Method in interface org.rocksdb.DBOptionsInterface
Returns true if automatic WAL flushing is disabled.
manualWalFlush() - Method in class org.rocksdb.Options
 
markBeginPrepare() - Method in class org.rocksdb.WriteBatch.Handler
 
markCommit(byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
markEndPrepare(byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
markNoop(boolean) - Method in class org.rocksdb.WriteBatch.Handler
 
markRollback(byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
markWalTerminationPoint() - Method in class org.rocksdb.WriteBatch
Marks this point in the WriteBatch as the last record to be inserted into the WAL, provided the WAL is enabled.
MAX_TRASH_DB_RATION_DEFAULT - Static variable in class org.rocksdb.SstFileManager
 
maxBackgroundCompactions() - Method in class org.rocksdb.DBOptions
Deprecated.
maxBackgroundCompactions() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
Deprecated.
maxBackgroundCompactions() - Method in interface org.rocksdb.MutableDBOptionsInterface
maxBackgroundCompactions() - Method in class org.rocksdb.Options
Deprecated.
maxBackgroundFlushes() - Method in class org.rocksdb.DBOptions
Deprecated.
maxBackgroundFlushes() - Method in interface org.rocksdb.DBOptionsInterface
Deprecated.
maxBackgroundFlushes() - Method in class org.rocksdb.Options
Deprecated.
maxBackgroundJobs() - Method in class org.rocksdb.DBOptions
 
maxBackgroundJobs() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
maxBackgroundJobs() - Method in interface org.rocksdb.MutableDBOptionsInterface
Returns the maximum number of concurrent background jobs (both flushes and compactions combined).
maxBackgroundJobs() - Method in class org.rocksdb.Options
 
maxBackgroundOperations() - Method in class org.rocksdb.BackupableDBOptions
maxBytesForLevelBase() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxBytesForLevelBase() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxBytesForLevelBase() - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
The upper-bound of the total size of level-1 files in bytes.
maxBytesForLevelBase() - Method in class org.rocksdb.Options
 
maxBytesForLevelMultiplier() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The ratio between the total size of level-(L+1) files and the total size of level-L files for all L.
maxBytesForLevelMultiplier() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxBytesForLevelMultiplier() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
The ratio between the total size of level-(L+1) files and the total size of level-L files for all L.
maxBytesForLevelMultiplier() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxBytesForLevelMultiplier() - Method in class org.rocksdb.Options
 
maxBytesForLevelMultiplierAdditional() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Different max-size multipliers for different levels.
maxBytesForLevelMultiplierAdditional() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxBytesForLevelMultiplierAdditional() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxBytesForLevelMultiplierAdditional() - Method in class org.rocksdb.Options
 
maxCompactionBytes() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Control maximum size of each compaction (not guaranteed)
maxCompactionBytes() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxCompactionBytes() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxCompactionBytes() - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
We try to limit number of bytes in one compaction to be lower than this threshold.
maxCompactionBytes() - Method in class org.rocksdb.Options
 
maxDictBytes() - Method in class org.rocksdb.CompressionOptions
Maximum size of dictionary used to prime the compression library.
maxFileOpeningThreads() - Method in class org.rocksdb.DBOptions
 
maxFileOpeningThreads() - Method in interface org.rocksdb.DBOptionsInterface
If MutableDBOptionsInterface.maxOpenFiles() is -1, DB will open all files on DB::Open().
maxFileOpeningThreads() - Method in class org.rocksdb.Options
 
maxLogFileSize() - Method in class org.rocksdb.DBOptions
 
maxLogFileSize() - Method in interface org.rocksdb.DBOptionsInterface
Returns the maximum size of a info log file.
maxLogFileSize() - Method in class org.rocksdb.Options
 
maxManifestFileSize() - Method in class org.rocksdb.DBOptions
 
maxManifestFileSize() - Method in interface org.rocksdb.DBOptionsInterface
Manifest file is rolled over on reaching this limit.
maxManifestFileSize() - Method in class org.rocksdb.Options
 
maxMemCompactionLevel() - Method in class org.rocksdb.RocksDB
Maximum level to which a new compacted memtable is pushed if it does not create overlap.
maxMemCompactionLevel(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Maximum level to which a new compacted memtable is pushed if it does not create overlap.
maxMergeWidth() - Method in class org.rocksdb.CompactionOptionsUniversal
The maximum number of files in a single compaction run.
maxOpenFiles() - Method in class org.rocksdb.DBOptions
 
maxOpenFiles() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
maxOpenFiles() - Method in interface org.rocksdb.MutableDBOptionsInterface
Number of open files that can be used by the DB.
maxOpenFiles() - Method in class org.rocksdb.Options
 
maxReusedBufferSize() - Method in class org.rocksdb.ComparatorOptions
Maximum size of a buffer (in bytes) that will be reused.
maxSequentialSkipInIterations() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
An iteration->Next() sequentially skips over keys with the same user-key unless this option is set.
maxSequentialSkipInIterations() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxSequentialSkipInIterations() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxSequentialSkipInIterations() - Method in class org.rocksdb.Options
 
maxSizeAmplificationPercent() - Method in class org.rocksdb.CompactionOptionsUniversal
The size amplification is defined as the amount (in percentage) of additional storage needed to store a single byte of data in the database.
maxSkippableInternalKeys() - Method in class org.rocksdb.ReadOptions
A threshold for the number of keys that can be skipped before failing an iterator seek as incomplete.
maxSubcompactions() - Method in class org.rocksdb.CompactionOptions
Get the maximum number of threads that will concurrently perform a compaction job.
maxSubcompactions() - Method in class org.rocksdb.CompactRangeOptions
If > 0, it will replace the option in the DBOptions for this compaction
maxSubcompactions() - Method in class org.rocksdb.DBOptions
 
maxSubcompactions() - Method in interface org.rocksdb.DBOptionsInterface
This value represents the maximum number of threads that will concurrently perform a compaction job by breaking it into multiple, smaller ones that are run simultaneously.
maxSubcompactions() - Method in class org.rocksdb.Options
 
maxSuccessiveMerges() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Maximum number of successive merge operations on a key in the memtable.
maxSuccessiveMerges() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxSuccessiveMerges() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxSuccessiveMerges() - Method in class org.rocksdb.Options
 
maxTableFilesSize() - Method in class org.rocksdb.CompactionOptionsFIFO
Once the total sum of table files reaches this, we will delete the oldest table file Default: 1GB
maxTableFilesSizeFIFO() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxTableFilesSizeFIFO() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
FIFO compaction option.
maxTableFilesSizeFIFO() - Method in class org.rocksdb.Options
 
maxTotalWalSize() - Method in class org.rocksdb.DBOptions
 
maxTotalWalSize() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
maxTotalWalSize() - Method in interface org.rocksdb.MutableDBOptionsInterface
Returns the max total wal size.
maxTotalWalSize() - Method in class org.rocksdb.Options
 
maxWriteBufferNumber() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Returns maximum number of write buffers.
maxWriteBufferNumber() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxWriteBufferNumber() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
maxWriteBufferNumber() - Method in class org.rocksdb.Options
 
maxWriteBufferNumberToMaintain() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The total maximum number of write buffers to maintain in memory including copies of buffers that have already been flushed.
maxWriteBufferNumberToMaintain() - Method in class org.rocksdb.ColumnFamilyOptions
 
maxWriteBufferNumberToMaintain() - Method in class org.rocksdb.Options
 
MB - Static variable in class org.rocksdb.util.SizeUnit
 
memcmp(ByteBuffer, ByteBuffer, int) - Static method in class org.rocksdb.util.ByteUtil
Compares the first count bytes of two areas of memory.
MemoryUsageType - Enum in org.rocksdb
MemoryUsageType
MemoryUtil - Class in org.rocksdb
JNI passthrough for MemoryUtil.
MemoryUtil() - Constructor for class org.rocksdb.MemoryUtil
 
memTableConfig() - Method in class org.rocksdb.ColumnFamilyOptions
 
memTableConfig() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Get the config for mem-table.
MemTableConfig - Class in org.rocksdb
MemTableConfig is used to config the internal mem-table of a RocksDB.
MemTableConfig() - Constructor for class org.rocksdb.MemTableConfig
 
memTableConfig() - Method in class org.rocksdb.Options
 
memTableFactoryName() - Method in class org.rocksdb.ColumnFamilyOptions
 
memTableFactoryName() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Returns the name of the current mem table representation.
memTableFactoryName() - Method in class org.rocksdb.Options
 
memtableHugePageSize() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Page size for huge page TLB for bloom in memtable.
memtableHugePageSize() - Method in class org.rocksdb.ColumnFamilyOptions
 
memtableHugePageSize() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
memtableHugePageSize() - Method in class org.rocksdb.Options
 
memtablePrefixBloomSizeRatio() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
if prefix_extractor is set and memtable_prefix_bloom_size_ratio is not 0, create prefix bloom for memtable with the size of write_buffer_size * memtable_prefix_bloom_size_ratio.
memtablePrefixBloomSizeRatio() - Method in class org.rocksdb.ColumnFamilyOptions
 
memtablePrefixBloomSizeRatio() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
memtablePrefixBloomSizeRatio() - Method in class org.rocksdb.Options
 
merge(byte[], byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
merge(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
merge(byte[], byte[]) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair.
merge(byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair.
merge(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair in a ColumnFamily.
merge(ColumnFamilyHandle, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair in a ColumnFamily.
merge(WriteOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair.
merge(WriteOptions, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair.
merge(ColumnFamilyHandle, WriteOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair.
merge(ColumnFamilyHandle, WriteOptions, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Add merge operand for key/value pair.
merge(Slice, Slice) - Method in class org.rocksdb.SstFileWriter
Add a Merge key with value to currently opened file.
merge(byte[], byte[]) - Method in class org.rocksdb.SstFileWriter
Add a Merge key with value to currently opened file.
merge(DirectSlice, DirectSlice) - Method in class org.rocksdb.SstFileWriter
Add a Merge key with value to currently opened file.
merge(ColumnFamilyHandle, byte[], byte[], boolean) - Method in class org.rocksdb.Transaction
Similar to RocksDB.merge(ColumnFamilyHandle, byte[], byte[]), but will also perform conflict checking on the keys be written.
merge(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to Transaction.merge(ColumnFamilyHandle, byte[], byte[], boolean) but with assumeTracked = false.
merge(byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.merge(byte[], byte[]), but will also perform conflict checking on the keys be written.
merge(int, byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
merge(byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
merge(byte[], byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Merge "value" with the existing value of "key" in the database.
merge(ColumnFamilyHandle, byte[], byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Merge "value" with the existing value of "key" in given column family.
MergeOperator - Class in org.rocksdb
MergeOperator holds an operator to be applied when compacting two merge operands held under the same key in order to obtain a single value.
MergeOperator(long) - Constructor for class org.rocksdb.MergeOperator
 
mergeUntracked(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.merge(ColumnFamilyHandle, byte[], byte[]), but operates on the transactions write batch.
mergeUntracked(byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.merge(byte[], byte[]), but operates on the transactions write batch.
metadataBlockSize() - Method in class org.rocksdb.BlockBasedTableConfig
Get the block size for partitioned metadata.
microsToString(long) - Static method in class org.rocksdb.ThreadStatus
 
minMergeWidth() - Method in class org.rocksdb.CompactionOptionsUniversal
The minimum number of files in a single compaction run.
minWriteBufferNumberToMerge() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The minimum number of write buffers that will be merged together before writing to storage.
minWriteBufferNumberToMerge() - Method in class org.rocksdb.ColumnFamilyOptions
 
minWriteBufferNumberToMerge() - Method in class org.rocksdb.Options
 
moveFiles() - Method in class org.rocksdb.IngestExternalFileOptions
Can be set to true to move the files instead of copying them.
multiGet(List<byte[]>) - Method in class org.rocksdb.RocksDB
Deprecated.
multiGet(List<ColumnFamilyHandle>, List<byte[]>) - Method in class org.rocksdb.RocksDB
Deprecated.
multiGet(ReadOptions, List<byte[]>) - Method in class org.rocksdb.RocksDB
Deprecated.
multiGet(ReadOptions, List<ColumnFamilyHandle>, List<byte[]>) - Method in class org.rocksdb.RocksDB
multiGet(ReadOptions, List<ColumnFamilyHandle>, byte[][]) - Method in class org.rocksdb.Transaction
This function is similar to RocksDB.multiGet(ReadOptions, List, List) except it will also read pending changes in this transaction.
multiGet(ReadOptions, byte[][]) - Method in class org.rocksdb.Transaction
This function is similar to RocksDB.multiGet(ReadOptions, List) except it will also read pending changes in this transaction.
multiGetAsList(List<byte[]>) - Method in class org.rocksdb.RocksDB
Takes a list of keys, and returns a list of values for the given list of keys.
multiGetAsList(List<ColumnFamilyHandle>, List<byte[]>) - Method in class org.rocksdb.RocksDB
Returns a list of values for the given list of keys.
multiGetAsList(ReadOptions, List<byte[]>) - Method in class org.rocksdb.RocksDB
Returns a list of values for the given list of keys.
multiGetAsList(ReadOptions, List<ColumnFamilyHandle>, List<byte[]>) - Method in class org.rocksdb.RocksDB
Returns a list of values for the given list of keys.
multiGetForUpdate(ReadOptions, List<ColumnFamilyHandle>, byte[][]) - Method in class org.rocksdb.Transaction
multiGetForUpdate(ReadOptions, byte[][]) - Method in class org.rocksdb.Transaction
MutableColumnFamilyOptions - Class in org.rocksdb
 
MutableColumnFamilyOptions.CompactionOption - Enum in org.rocksdb
 
MutableColumnFamilyOptions.MemtableOption - Enum in org.rocksdb
 
MutableColumnFamilyOptions.MiscOption - Enum in org.rocksdb
 
MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder - Class in org.rocksdb
 
MutableColumnFamilyOptionsInterface<T extends MutableColumnFamilyOptionsInterface<T>> - Interface in org.rocksdb
 
MutableDBOptions - Class in org.rocksdb
 
MutableDBOptions.DBOption - Enum in org.rocksdb
 
MutableDBOptions.MutableDBOptionsBuilder - Class in org.rocksdb
 
MutableDBOptionsInterface<T extends MutableDBOptionsInterface<T>> - Interface in org.rocksdb
 
MutableOptionKey - Interface in org.rocksdb
 
MutableOptionKey.ValueType - Enum in org.rocksdb
 
MutableOptionValue<T> - Class in org.rocksdb
 
MutableOptionValue() - Constructor for class org.rocksdb.MutableOptionValue
 

N

name() - Method in class org.rocksdb.AbstractCompactionFilterFactory
A name which identifies this compaction filter The name will be printed to the LOG file on start up for diagnosis
name() - Method in class org.rocksdb.AbstractComparator
The name of the comparator.
name() - Method in class org.rocksdb.ColumnFamilyMetaData
The name of the column family.
name() - Method in class org.rocksdb.ComparatorBug.VersionedComparator
 
name() - Method in interface org.rocksdb.MutableOptionKey
 
name() - Method in class org.rocksdb.NativeComparatorWrapper
 
name() - Method in class org.rocksdb.util.BytewiseComparator
 
name() - Method in class org.rocksdb.util.IntComparator
 
name() - Method in class org.rocksdb.util.ReverseBytewiseComparator
 
name() - Method in interface org.rocksdb.WalFilter
Returns a name that identifies this WAL filter.
NativeComparatorWrapper - Class in org.rocksdb
A simple abstraction to allow a Java class to wrap a custom comparator implemented in C++.
NativeComparatorWrapper() - Constructor for class org.rocksdb.NativeComparatorWrapper
 
nativeHandle_ - Variable in class org.rocksdb.RocksCallbackObject
 
nativeHandle_ - Variable in class org.rocksdb.RocksObject
An immutable reference to the value of the C++ pointer pointing to some underlying native RocksDB C++ object.
NativeLibraryLoader - Class in org.rocksdb
This class is used to load the RocksDB shared library from within the jar.
newIterator() - Method in class org.rocksdb.RocksDB
Return a heap-allocated iterator over the contents of the database.
newIterator(ReadOptions) - Method in class org.rocksdb.RocksDB
Return a heap-allocated iterator over the contents of the database.
newIterator(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Return a heap-allocated iterator over the contents of the database.
newIterator(ColumnFamilyHandle, ReadOptions) - Method in class org.rocksdb.RocksDB
Return a heap-allocated iterator over the contents of the database.
newIterator(ReadOptions) - Method in class org.rocksdb.SstFileReader
Returns an iterator that will iterate on all keys in the default column family including both keys in the DB and uncommitted keys in this transaction.
newIterator(ColumnFamilyHandle) - Method in class org.rocksdb.WriteBatchWithIndex
Create an iterator of a column family.
newIterator() - Method in class org.rocksdb.WriteBatchWithIndex
Create an iterator of the default column family.
newIterators(List<ColumnFamilyHandle>) - Method in class org.rocksdb.RocksDB
Returns iterators from a consistent database state across multiple column families.
newIterators(List<ColumnFamilyHandle>, ReadOptions) - Method in class org.rocksdb.RocksDB
Returns iterators from a consistent database state across multiple column families.
newIteratorWithBase(ColumnFamilyHandle, RocksIterator) - Method in class org.rocksdb.WriteBatchWithIndex
Provides Read-Your-Own-Writes like functionality by creating a new Iterator that will use WBWIRocksIterator as a delta and baseIterator as a base Updating write batch with the current key of the iterator is not safe.
newIteratorWithBase(RocksIterator) - Method in class org.rocksdb.WriteBatchWithIndex
Provides Read-Your-Own-Writes like functionality by creating a new Iterator that will use WBWIRocksIterator as a delta and baseIterator as a base.
newMemTableFactoryHandle() - Method in class org.rocksdb.HashLinkedListMemTableConfig
 
newMemTableFactoryHandle() - Method in class org.rocksdb.HashSkipListMemTableConfig
 
newMemTableFactoryHandle() - Method in class org.rocksdb.MemTableConfig
This function should only be called by Options.setMemTableConfig(), which will create a c++ shared-pointer to the c++ MemTableRepFactory that associated with the Java MemTableConfig.
newMemTableFactoryHandle() - Method in class org.rocksdb.SkipListMemTableConfig
 
newMemTableFactoryHandle() - Method in class org.rocksdb.VectorMemTableConfig
 
newTableFactoryHandle() - Method in class org.rocksdb.BlockBasedTableConfig
 
newTableFactoryHandle() - Method in class org.rocksdb.PlainTableConfig
 
newTableFactoryHandle() - Method in class org.rocksdb.TableFormatConfig
This function should only be called by Options.setTableFormatConfig(), which will create a c++ shared-pointer to the c++ TableFactory that associated with the Java TableFormatConfig.
newTableReaderForCompactionInputs() - Method in class org.rocksdb.DBOptions
 
newTableReaderForCompactionInputs() - Method in interface org.rocksdb.DBOptionsInterface
If true, always create a new file descriptor and new table reader for compaction inputs.
newTableReaderForCompactionInputs() - Method in class org.rocksdb.Options
 
next() - Method in class org.rocksdb.AbstractRocksIterator
 
next() - Method in interface org.rocksdb.RocksIteratorInterface
Moves to the next entry in the source.
next() - Method in class org.rocksdb.TransactionLogIterator
Moves the iterator to the next WriteBatch.
noBlockCache() - Method in class org.rocksdb.BlockBasedTableConfig
Determine if the block cache is disabled.
NONE - Static variable in class org.rocksdb.DirectSlice
 
noSlowdown() - Method in class org.rocksdb.WriteOptions
If true and we need to wait or sleep for the write request, fails immediately with Status.Code.Incomplete.
NOT_FOUND - Static variable in class org.rocksdb.RocksDB
 
numberFiles() - Method in class org.rocksdb.BackupInfo
 
numberLevels() - Method in class org.rocksdb.RocksDB
Number of levels used for this DB.
numberLevels(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Number of levels used for a column family in this DB.
numCorruptKeys() - Method in class org.rocksdb.CompactionJobStats
Get the number of corrupt keys (ParseInternalKey returned false when applied to the key) encountered and written out.
numDeletions() - Method in class org.rocksdb.SstFileMetaData
Get the number of deletions.
numEntries() - Method in class org.rocksdb.SstFileMetaData
Get the number of entries.
numExpiredDeletionRecords() - Method in class org.rocksdb.CompactionJobStats
Get the number of deletion records that were found obsolete and discarded because it is not possible to delete any more keys with this entry.
numInputDeletionRecords() - Method in class org.rocksdb.CompactionJobStats
Get the number of deletion entries before compaction.
numInputFiles() - Method in class org.rocksdb.CompactionJobStats
Get the number of compaction input files.
numInputFilesAtOutputLevel() - Method in class org.rocksdb.CompactionJobStats
Get the number of compaction input files at the output level.
numInputRecords() - Method in class org.rocksdb.CompactionJobStats
Get the number of compaction input records.
numLevels() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
If level-styled compaction is used, then this number determines the total number of levels.
numLevels() - Method in class org.rocksdb.ColumnFamilyOptions
 
numLevels() - Method in class org.rocksdb.Options
 
numOutputFiles() - Method in class org.rocksdb.CompactionJobStats
Get the number of compaction output files.
numOutputRecords() - Method in class org.rocksdb.CompactionJobStats
Get the number of compaction output records.
numReadsSampled() - Method in class org.rocksdb.SstFileMetaData
Get the number of times the file has been read.
numRecordsReplaced() - Method in class org.rocksdb.CompactionJobStats
Get the number of records being replaced by newer record associated with same key.
numSingleDelFallthru() - Method in class org.rocksdb.CompactionJobStats
Get the number of single-deletes which do not meet a put.
numSingleDelMismatch() - Method in class org.rocksdb.CompactionJobStats
Get the number of single-deletes which meet something other than a put.

O

open(Env, BackupableDBOptions) - Static method in class org.rocksdb.BackupEngine
Opens a new Backup Engine
open(Options, String) - Static method in class org.rocksdb.OptimisticTransactionDB
Open an OptimisticTransactionDB similar to RocksDB.open(Options, String).
open(DBOptions, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Static method in class org.rocksdb.OptimisticTransactionDB
Open an OptimisticTransactionDB similar to RocksDB.open(DBOptions, String, List, List).
open(long, String) - Static method in class org.rocksdb.OptimisticTransactionDB
 
open(long, String, byte[][], long[]) - Static method in class org.rocksdb.OptimisticTransactionDB
 
open(String) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance given the path to the database using the default options w/ createIfMissing set to true.
open(String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance given the path to the database using the specified options and db path and a list of column family names.
open(Options, String) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance given the path to the database using the specified options and db path.
open(DBOptions, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance given the path to the database using the specified options and db path and a list of column family names.
open(String) - Method in class org.rocksdb.SstFileReader
Prepare SstFileReader to read a file.
open(String) - Method in class org.rocksdb.SstFileWriter
Prepare SstFileWriter to write to a file.
open(Options, TransactionDBOptions, String) - Static method in class org.rocksdb.TransactionDB
Open a TransactionDB, similar to RocksDB.open(Options, String).
open(DBOptions, TransactionDBOptions, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Static method in class org.rocksdb.TransactionDB
Open a TransactionDB, similar to RocksDB.open(DBOptions, String, List, List).
open(Options, String) - Static method in class org.rocksdb.TtlDB
Opens a TtlDB.
open(Options, String, int, boolean) - Static method in class org.rocksdb.TtlDB
Opens a TtlDB.
open(DBOptions, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>, List<Integer>, boolean) - Static method in class org.rocksdb.TtlDB
Opens a TtlDB.
openReadOnly(String) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance in Read-Only mode given the path to the database using the default options.
openReadOnly(String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance in Read-Only mode given the path to the database using the default options.
openReadOnly(Options, String) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance in Read-Only mode given the path to the database using the specified options and db path.
openReadOnly(DBOptions, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Static method in class org.rocksdb.RocksDB
The factory constructor of RocksDB that opens a RocksDB instance in Read-Only mode given the path to the database using the specified options and db path.
OperationStage - Enum in org.rocksdb
The operation stage.
OperationType - Enum in org.rocksdb
The type used to refer to a thread operation.
OptimisticTransactionDB - Class in org.rocksdb
Database with Transaction support.
OptimisticTransactionOptions - Class in org.rocksdb
 
OptimisticTransactionOptions() - Constructor for class org.rocksdb.OptimisticTransactionOptions
 
optimizeFiltersForHits() - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Returns the current state of the optimize_filters_for_hits setting.
optimizeFiltersForHits() - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeFiltersForHits() - Method in class org.rocksdb.Options
 
optimizeForPointLookup(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeForPointLookup(long) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Use this if you don't need to keep the data sorted, i.e.
optimizeForPointLookup(long) - Method in class org.rocksdb.Options
 
optimizeForSmallDb() - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeForSmallDb() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Use this if your DB is very small (like under 1GB) and you don't want to spend lots of memory for memtables.
optimizeForSmallDb() - Method in class org.rocksdb.DBOptions
 
optimizeForSmallDb() - Method in interface org.rocksdb.DBOptionsInterface
Use this if your DB is very small (like under 1GB) and you don't want to spend lots of memory for memtables.
optimizeForSmallDb() - Method in class org.rocksdb.Options
 
optimizeLevelStyleCompaction() - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeLevelStyleCompaction(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeLevelStyleCompaction() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Default values for some parameters in ColumnFamilyOptions are not optimized for heavy workloads and big datasets, which means you might observe write stalls under some conditions.
optimizeLevelStyleCompaction(long) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Default values for some parameters in ColumnFamilyOptions are not optimized for heavy workloads and big datasets, which means you might observe write stalls under some conditions.
optimizeLevelStyleCompaction() - Method in class org.rocksdb.Options
 
optimizeLevelStyleCompaction(long) - Method in class org.rocksdb.Options
 
optimizeUniversalStyleCompaction() - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeUniversalStyleCompaction(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
optimizeUniversalStyleCompaction() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Default values for some parameters in ColumnFamilyOptions are not optimized for heavy workloads and big datasets, which means you might observe write stalls under some conditions.
optimizeUniversalStyleCompaction(long) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Default values for some parameters in ColumnFamilyOptions are not optimized for heavy workloads and big datasets, which means you might observe write stalls under some conditions.
optimizeUniversalStyleCompaction() - Method in class org.rocksdb.Options
 
optimizeUniversalStyleCompaction(long) - Method in class org.rocksdb.Options
 
Options - Class in org.rocksdb
Options to control the behavior of a database.
Options() - Constructor for class org.rocksdb.Options
Construct options for opening a RocksDB.
Options(DBOptions, ColumnFamilyOptions) - Constructor for class org.rocksdb.Options
Construct options for opening a RocksDB.
Options(Options) - Constructor for class org.rocksdb.Options
Copy constructor for ColumnFamilyOptions.
options_ - Variable in class org.rocksdb.RocksDB
 
OptionsUtil - Class in org.rocksdb
 
org.rocksdb - package org.rocksdb
 
org.rocksdb.util - package org.rocksdb.util
 
outputFiles() - Method in class org.rocksdb.CompactionJobInfo
Get the names of the compaction output files.
outputFileSizeLimit() - Method in class org.rocksdb.CompactionOptions
Get the compaction output file size limit.
outputLevel() - Method in class org.rocksdb.CompactionJobInfo
Get the output level of the compaction.
owningHandle_ - Variable in class org.rocksdb.AbstractImmutableNativeReference
A flag indicating whether the current AbstractNativeReference is responsible to free the underlying C++ object

P

paranoidChecks() - Method in class org.rocksdb.DBOptions
 
paranoidChecks() - Method in interface org.rocksdb.DBOptionsInterface
If true, the implementation will do aggressive checking of the data it is processing and will stop early if it detects any errors.
paranoidChecks() - Method in class org.rocksdb.Options
 
paranoidFileChecks() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
After writing every SST file, reopen it and read all the keys.
paranoidFileChecks() - Method in class org.rocksdb.ColumnFamilyOptions
 
paranoidFileChecks() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
paranoidFileChecks() - Method in class org.rocksdb.Options
 
parse(String) - Static method in class org.rocksdb.MutableColumnFamilyOptions
Parses a String representation of MutableColumnFamilyOptions The format is: key1=value1;key2=value2;key3=value3 etc For int[] values, each int should be separated by a comma, e.g.
parse(String) - Static method in class org.rocksdb.MutableDBOptions
Parses a String representation of MutableDBOptions The format is: key1=value1;key2=value2;key3=value3 etc For int[] values, each int should be separated by a comma, e.g.
partitionFilters() - Method in class org.rocksdb.BlockBasedTableConfig
Indicates if we're using partitioned filters.
path() - Method in class org.rocksdb.SstFileMetaData
Get the full path where the file locates.
pathName() - Method in class org.rocksdb.LogFile
Returns log file's pathname relative to the main db dir Eg.
pauseBackgroundWork() - Method in class org.rocksdb.RocksDB
This function will wait until all currently running background processes finish.
PB - Static variable in class org.rocksdb.util.SizeUnit
 
PersistentCache - Class in org.rocksdb
Persistent cache for caching IO pages on a persistent medium.
PersistentCache(Env, String, long, Logger, boolean) - Constructor for class org.rocksdb.PersistentCache
 
pinData() - Method in class org.rocksdb.ReadOptions
Returns whether the blocks loaded by the iterator will be pinned in memory
pinL0FilterAndIndexBlocksInCache() - Method in class org.rocksdb.BlockBasedTableConfig
Indicating if we'd like to pin L0 index/filter blocks to the block cache.
pinTopLevelIndexAndFilter() - Method in class org.rocksdb.BlockBasedTableConfig
Indicates if top-level index and filter blocks should be pinned.
PlainTableConfig - Class in org.rocksdb
The config for plain table sst format.
PlainTableConfig() - Constructor for class org.rocksdb.PlainTableConfig
 
popSavePoint() - Method in class org.rocksdb.AbstractWriteBatch
 
popSavePoint() - Method in interface org.rocksdb.WriteBatchInterface
Pop the most recent save point.
prefixSameAsStart() - Method in class org.rocksdb.ReadOptions
Returns whether the iterator only iterates over the same prefix as the seek
prepareForBulkLoad() - Method in class org.rocksdb.Options
Set appropriate parameters for bulk loading.
preserveDeletes() - Method in class org.rocksdb.DBOptions
 
preserveDeletes() - Method in interface org.rocksdb.DBOptionsInterface
Returns true if deletes are preserved.
preserveDeletes() - Method in class org.rocksdb.Options
 
prev() - Method in class org.rocksdb.AbstractRocksIterator
 
prev() - Method in interface org.rocksdb.RocksIteratorInterface
Moves to the previous entry in the source.
Priority - Enum in org.rocksdb
The Thread Pool priority.
promoteL0(ColumnFamilyHandle, int) - Method in class org.rocksdb.RocksDB
Promote L0.
promoteL0(int) - Method in class org.rocksdb.RocksDB
Promote L0 for the default column family.
purgeOldBackups(int) - Method in class org.rocksdb.BackupEngine
Deletes old backups, keeping just the latest numBackupsToKeep
put(byte[], byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
put(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
put(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.AbstractWriteBatch
 
put(ColumnFamilyHandle, ByteBuffer, ByteBuffer) - Method in class org.rocksdb.AbstractWriteBatch
 
put(byte[], byte[]) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value".
put(byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value".
put(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value" in the specified column family.
put(ColumnFamilyHandle, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value" in the specified column family.
put(WriteOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value".
put(WriteOptions, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value".
put(ColumnFamilyHandle, WriteOptions, byte[], byte[]) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value" for the specified column family.
put(ColumnFamilyHandle, WriteOptions, ByteBuffer, ByteBuffer) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value" for the specified column family.
put(WriteOptions, ByteBuffer, ByteBuffer) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value".
put(ColumnFamilyHandle, WriteOptions, byte[], int, int, byte[], int, int) - Method in class org.rocksdb.RocksDB
Set the database entry for "key" to "value" for the specified column family.
put(Slice, Slice) - Method in class org.rocksdb.SstFileWriter
Add a Put key with value to currently opened file.
put(DirectSlice, DirectSlice) - Method in class org.rocksdb.SstFileWriter
Add a Put key with value to currently opened file.
put(ByteBuffer, ByteBuffer) - Method in class org.rocksdb.SstFileWriter
Add a Put key with value to currently opened file.
put(byte[], byte[]) - Method in class org.rocksdb.SstFileWriter
Add a Put key with value to currently opened file.
put(ColumnFamilyHandle, byte[], byte[], boolean) - Method in class org.rocksdb.Transaction
Similar to RocksDB.put(ColumnFamilyHandle, byte[], byte[]), but will also perform conflict checking on the keys be written.
put(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to Transaction.put(ColumnFamilyHandle, byte[], byte[], boolean) but with assumeTracked = false.
put(byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.put(byte[], byte[]), but will also perform conflict checking on the keys be written.
put(ColumnFamilyHandle, byte[][], byte[][], boolean) - Method in class org.rocksdb.Transaction
Similar to Transaction.put(ColumnFamilyHandle, byte[], byte[]) but allows you to specify the key and value in several parts that will be concatenated together.
put(ColumnFamilyHandle, byte[][], byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.put(ColumnFamilyHandle, byte[][], byte[][], boolean) but with with assumeTracked = false.
put(byte[][], byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.put(byte[], byte[]) but allows you to specify the key and value in several parts that will be concatenated together
put(int, byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
put(byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
put(byte[], byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Store the mapping "key->value" in the database.
put(ColumnFamilyHandle, byte[], byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Store the mapping "key->value" within given column family.
put(ByteBuffer, ByteBuffer) - Method in interface org.rocksdb.WriteBatchInterface
Store the mapping "key->value" within given column family.
put(ColumnFamilyHandle, ByteBuffer, ByteBuffer) - Method in interface org.rocksdb.WriteBatchInterface
Store the mapping "key->value" within given column family.
putBlobIndex(int, byte[], byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
putLogData(byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
putLogData(byte[]) - Method in class org.rocksdb.Transaction
putLogData(byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Append a blob of arbitrary size to the records in this batch.
putUntracked(ColumnFamilyHandle, byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.put(ColumnFamilyHandle, byte[], byte[]), but operates on the transactions write batch.
putUntracked(byte[], byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.put(byte[], byte[]), but operates on the transactions write batch.
putUntracked(ColumnFamilyHandle, byte[][], byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.putUntracked(ColumnFamilyHandle, byte[], byte[]) but allows you to specify the key and value in several parts that will be concatenated together.
putUntracked(byte[][], byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.putUntracked(byte[], byte[]) but allows you to specify the key and value in several parts that will be concatenated together.

R

randomAccessMaxBufferSize() - Method in class org.rocksdb.DBOptions
 
randomAccessMaxBufferSize() - Method in interface org.rocksdb.DBOptionsInterface
This is a maximum buffer size that is used by WinMmapReadableFile in unbuffered disk I/O mode.
randomAccessMaxBufferSize() - Method in class org.rocksdb.EnvOptions
randomAccessMaxBufferSize() - Method in class org.rocksdb.Options
 
Range - Class in org.rocksdb
Range from start to limit.
Range(Slice, Slice) - Constructor for class org.rocksdb.Range
 
RATE_BYTES_PER_SEC_DEFAULT - Static variable in class org.rocksdb.SstFileManager
 
rateLimiter() - Method in class org.rocksdb.EnvOptions
Get the write rate limiter for flush and compaction.
RateLimiter - Class in org.rocksdb
RateLimiter, which is used to control write rate of flush and compaction.
RateLimiter(long) - Constructor for class org.rocksdb.RateLimiter
RateLimiter constructor
RateLimiter(long, long) - Constructor for class org.rocksdb.RateLimiter
RateLimiter constructor
RateLimiter(long, long, int) - Constructor for class org.rocksdb.RateLimiter
RateLimiter constructor
RateLimiter(long, long, int, RateLimiterMode) - Constructor for class org.rocksdb.RateLimiter
RateLimiter constructor
RateLimiter(long, long, int, RateLimiterMode, boolean) - Constructor for class org.rocksdb.RateLimiter
RateLimiter constructor
RateLimiterMode - Enum in org.rocksdb
readaheadSize() - Method in class org.rocksdb.ReadOptions
If non-zero, NewIterator will create a new table reader which performs reads of the given size.
readAmpBytesPerBit() - Method in class org.rocksdb.BlockBasedTableConfig
Get the Read amplification bytes per-bit.
ReadOptions - Class in org.rocksdb
The class that controls the get behavior.
ReadOptions() - Constructor for class org.rocksdb.ReadOptions
 
ReadOptions(boolean, boolean) - Constructor for class org.rocksdb.ReadOptions
 
ReadOptions(ReadOptions) - Constructor for class org.rocksdb.ReadOptions
Copy constructor.
readTier() - Method in class org.rocksdb.ReadOptions
Returns the current read tier.
ReadTier - Enum in org.rocksdb
RocksDB ReadOptions read tiers.
rebuildFromWriteBatch(WriteBatch) - Method in class org.rocksdb.Transaction
Adds the keys from the WriteBatch to the transaction
recycleLogFileNum() - Method in class org.rocksdb.DBOptions
 
recycleLogFileNum() - Method in interface org.rocksdb.DBOptionsInterface
Recycle log files.
recycleLogFileNum() - Method in class org.rocksdb.Options
 
releaseSnapshot(Snapshot) - Method in class org.rocksdb.RocksDB
Release a previously acquired snapshot.
remove(byte[]) - Method in class org.rocksdb.AbstractWriteBatch
Deprecated.
remove(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.AbstractWriteBatch
Deprecated.
remove(ByteBuffer) - Method in class org.rocksdb.AbstractWriteBatch
 
remove(ColumnFamilyHandle, ByteBuffer) - Method in class org.rocksdb.AbstractWriteBatch
 
remove(byte[]) - Method in class org.rocksdb.RocksDB
Deprecated.
remove(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.RocksDB
remove(WriteOptions, byte[]) - Method in class org.rocksdb.RocksDB
remove(ColumnFamilyHandle, WriteOptions, byte[]) - Method in class org.rocksdb.RocksDB
remove(byte[]) - Method in interface org.rocksdb.WriteBatchInterface
remove(ColumnFamilyHandle, byte[]) - Method in interface org.rocksdb.WriteBatchInterface
remove(ByteBuffer) - Method in interface org.rocksdb.WriteBatchInterface
If column family contains a mapping for "key", erase it.
remove(ColumnFamilyHandle, ByteBuffer) - Method in interface org.rocksdb.WriteBatchInterface
If column family contains a mapping for "key", erase it.
RemoveEmptyValueCompactionFilter - Class in org.rocksdb
Just a Java wrapper around EmptyValueCompactionFilter implemented in C++
RemoveEmptyValueCompactionFilter() - Constructor for class org.rocksdb.RemoveEmptyValueCompactionFilter
 
removePrefix(int) - Method in class org.rocksdb.AbstractSlice
Drops the specified n number of bytes from the start of the backing slice
removePrefix(int) - Method in class org.rocksdb.DirectSlice
 
removePrefix(int) - Method in class org.rocksdb.Slice
 
reportBgIoStats() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Determine whether IO stats in compactions and flushes are being measured
reportBgIoStats() - Method in class org.rocksdb.ColumnFamilyOptions
 
reportBgIoStats() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
reportBgIoStats() - Method in class org.rocksdb.Options
 
request(long) - Method in class org.rocksdb.RateLimiter
Request for token to write bytes.
reservedSize() - Method in class org.rocksdb.VectorMemTableConfig
Returns the initial size of the vector used by the memtable created based on this config.
reset() - Method in class org.rocksdb.CompactionJobStats
Reset the stats.
reset() - Method in class org.rocksdb.Statistics
Resets all ticker and histogram stats.
resetNativeHandle(long, boolean) - Method in class org.rocksdb.RocksMutableObject
Closes the existing handle, and changes the handle to the new handle
resetStats() - Method in class org.rocksdb.RocksDB
Reset internal stats for DB and all column families.
restoreDbFromBackup(int, String, String, RestoreOptions) - Method in class org.rocksdb.BackupEngine
Restore the database from a backup IMPORTANT: if options.share_table_files == true and you restore the DB from some backup that is not the latest, and you start creating new backups from the new DB, they will probably fail! Example: Let's say you have backups 1, 2, 3, 4, 5 and you restore 3.
restoreDbFromLatestBackup(String, String, RestoreOptions) - Method in class org.rocksdb.BackupEngine
Restore the database from the latest backup
RestoreOptions - Class in org.rocksdb
RestoreOptions to control the behavior of restore.
RestoreOptions(boolean) - Constructor for class org.rocksdb.RestoreOptions
Constructor
restoreRateLimit() - Method in class org.rocksdb.BackupableDBOptions
Return restore rate limit which described the max bytes that can be transferred in a second during restore.
restoreRateLimiter() - Method in class org.rocksdb.BackupableDBOptions
Restore rate limiter.
reusedSynchronisationType() - Method in class org.rocksdb.ComparatorOptions
Get the synchronisation type used to guard the reused buffers.
ReusedSynchronisationType - Enum in org.rocksdb
Determines the type of synchronisation primitive used in native code.
ReverseBytewiseComparator - Class in org.rocksdb.util
This is a Java Native implementation of the C++ equivalent ReverseBytewiseComparatorImpl using Slice The performance of Comparators implemented in Java is always less than their C++ counterparts due to the bridging overhead, as such you likely don't want to use this apart from benchmarking and you most likely instead wanted BuiltinComparator.REVERSE_BYTEWISE_COMPARATOR
ReverseBytewiseComparator(ComparatorOptions) - Constructor for class org.rocksdb.util.ReverseBytewiseComparator
 
RocksCallbackObject - Class in org.rocksdb
RocksCallbackObject is similar to RocksObject but varies in its construction as it is designed for Java objects which have functions which are called from C++ via JNI.
RocksCallbackObject(long...) - Constructor for class org.rocksdb.RocksCallbackObject
 
RocksDB - Class in org.rocksdb
A RocksDB is a persistent ordered map from keys to values.
RocksDB(long) - Constructor for class org.rocksdb.RocksDB
Private constructor.
RocksDB.CountAndSize - Class in org.rocksdb
 
RocksDB.CountAndSize(long, long) - Constructor for class org.rocksdb.RocksDB.CountAndSize
 
RocksDB.LiveFiles - Class in org.rocksdb
 
RocksDBException - Exception in org.rocksdb
A RocksDBException encapsulates the error of an operation.
RocksDBException(String) - Constructor for exception org.rocksdb.RocksDBException
The private construct used by a set of public static factory method.
RocksDBException(String, Status) - Constructor for exception org.rocksdb.RocksDBException
 
RocksDBException(Status) - Constructor for exception org.rocksdb.RocksDBException
 
RocksEnv - Class in org.rocksdb
A RocksEnv is an interface used by the rocksdb implementation to access operating system functionality like the filesystem etc.
RocksIterator - Class in org.rocksdb
An iterator that yields a sequence of key/value pairs from a source.
RocksIterator(RocksDB, long) - Constructor for class org.rocksdb.RocksIterator
 
RocksIteratorInterface - Interface in org.rocksdb
Defines the interface for an Iterator which provides access to data one entry at a time.
RocksMemEnv - Class in org.rocksdb
Memory environment.
RocksMemEnv(Env) - Constructor for class org.rocksdb.RocksMemEnv
Creates a new environment that stores its data in memory and delegates all non-file-storage tasks to baseEnv.
RocksMemEnv() - Constructor for class org.rocksdb.RocksMemEnv
RocksMutableObject - Class in org.rocksdb
RocksMutableObject is an implementation of AbstractNativeReference whose reference to the underlying native C++ object can change.
RocksMutableObject() - Constructor for class org.rocksdb.RocksMutableObject
 
RocksMutableObject(long) - Constructor for class org.rocksdb.RocksMutableObject
 
RocksObject - Class in org.rocksdb
RocksObject is an implementation of AbstractNativeReference which has an immutable and therefore thread-safe reference to the underlying native C++ RocksDB object.
RocksObject(long) - Constructor for class org.rocksdb.RocksObject
 
rollback() - Method in class org.rocksdb.Transaction
Discard all batched writes in this transaction.
rollbackToSavePoint() - Method in class org.rocksdb.AbstractWriteBatch
 
rollbackToSavePoint() - Method in class org.rocksdb.Transaction
Undo all operations in this transaction (put, merge, delete, putLogData) since the most recent call to Transaction.setSavePoint() and removes the most recent Transaction.setSavePoint().
rollbackToSavePoint() - Method in interface org.rocksdb.WriteBatchInterface
Remove all entries in this batch (Put, Merge, Delete, PutLogData) since the most recent call to SetSavePoint() and removes the most recent save point.
rowCache() - Method in class org.rocksdb.DBOptions
 
rowCache() - Method in interface org.rocksdb.DBOptionsInterface
A global cache for table-level rows.
rowCache() - Method in class org.rocksdb.Options
 

S

seek(byte[]) - Method in class org.rocksdb.AbstractRocksIterator
 
seek(ByteBuffer) - Method in class org.rocksdb.AbstractRocksIterator
 
seek(byte[]) - Method in interface org.rocksdb.RocksIteratorInterface
Position at the first entry in the source whose key is at or past target.
seek(ByteBuffer) - Method in interface org.rocksdb.RocksIteratorInterface
Position at the first entry in the source whose key is that or past target.
seekForPrev(byte[]) - Method in class org.rocksdb.AbstractRocksIterator
 
seekForPrev(ByteBuffer) - Method in class org.rocksdb.AbstractRocksIterator
 
seekForPrev(byte[]) - Method in interface org.rocksdb.RocksIteratorInterface
Position at the first entry in the source whose key is that or before target.
seekForPrev(ByteBuffer) - Method in interface org.rocksdb.RocksIteratorInterface
Position at the last key that is less than or equal to the target key.
seekToFirst() - Method in class org.rocksdb.AbstractRocksIterator
 
seekToFirst() - Method in interface org.rocksdb.RocksIteratorInterface
Position at the first entry in the source.
seekToLast() - Method in class org.rocksdb.AbstractRocksIterator
 
seekToLast() - Method in interface org.rocksdb.RocksIteratorInterface
Position at the last entry in the source.
self() - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
self() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
self() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
sequenceNumber() - Method in class org.rocksdb.TransactionLogIterator.BatchResult
Return sequence number related to this BatchResult.
setAccessHintOnCompactionStart(AccessHint) - Method in class org.rocksdb.DBOptions
 
setAccessHintOnCompactionStart(AccessHint) - Method in interface org.rocksdb.DBOptionsInterface
Specify the file access pattern once a compaction is started.
setAccessHintOnCompactionStart(AccessHint) - Method in class org.rocksdb.Options
 
setAdviseRandomOnOpen(boolean) - Method in class org.rocksdb.DBOptions
 
setAdviseRandomOnOpen(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If set true, will hint the underlying file system that the file access pattern is random, when a sst file is opened.
setAdviseRandomOnOpen(boolean) - Method in class org.rocksdb.Options
 
setAllow2pc(boolean) - Method in class org.rocksdb.DBOptions
 
setAllow2pc(boolean) - Method in interface org.rocksdb.DBOptionsInterface
if set to false then recovery will fail when a prepared transaction is encountered in the WAL Default: false
setAllow2pc(boolean) - Method in class org.rocksdb.Options
 
setAllowBlockingFlush(boolean) - Method in class org.rocksdb.IngestExternalFileOptions
If set to false and the file key range overlaps with the memtable key range (memtable flush required), IngestExternalFile will fail.
setAllowCompaction(boolean) - Method in class org.rocksdb.CompactionOptionsFIFO
If true, try to do compaction to compact smaller files into larger ones.
setAllowConcurrentMemtableWrite(boolean) - Method in class org.rocksdb.DBOptions
 
setAllowConcurrentMemtableWrite(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, allow multi-writers to update mem tables in parallel.
setAllowConcurrentMemtableWrite(boolean) - Method in class org.rocksdb.Options
 
setAllowFAllocate(boolean) - Method in class org.rocksdb.DBOptions
 
setAllowFAllocate(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Whether fallocate calls are allowed
setAllowFallocate(boolean) - Method in class org.rocksdb.EnvOptions
Enable/Disable fallocate calls.
setAllowFAllocate(boolean) - Method in class org.rocksdb.Options
 
setAllowGlobalSeqNo(boolean) - Method in class org.rocksdb.IngestExternalFileOptions
If set to false, RocksDB.ingestExternalFile(ColumnFamilyHandle, List, IngestExternalFileOptions) will fail if the file key range overlaps with existing keys or tombstones in the DB.
setAllowIngestBehind(boolean) - Method in class org.rocksdb.DBOptions
 
setAllowIngestBehind(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Set this option to true during creation of database if you want to be able to ingest behind (call IngestExternalFile() skipping keys that already exist, rather than overwriting matching keys).
setAllowIngestBehind(boolean) - Method in class org.rocksdb.Options
 
setAllowMmapReads(boolean) - Method in class org.rocksdb.DBOptions
 
setAllowMmapReads(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Allow the OS to mmap file for reading sst tables.
setAllowMmapReads(boolean) - Method in class org.rocksdb.Options
 
setAllowMmapWrites(boolean) - Method in class org.rocksdb.DBOptions
 
setAllowMmapWrites(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Allow the OS to mmap file for writing.
setAllowMmapWrites(boolean) - Method in class org.rocksdb.Options
 
setAllowTrivialMove(boolean) - Method in class org.rocksdb.CompactionOptionsUniversal
Option to optimize the universal multi level compaction by enabling trivial move for non overlapping files.
setAllowWriteStall(boolean) - Method in class org.rocksdb.CompactRangeOptions
If true, compaction will execute immediately even if doing so would cause the DB to enter write stall mode.
setAllowWriteStall(boolean) - Method in class org.rocksdb.FlushOptions
Set to true so that flush would proceeds immediately even it it means writes will stall for the duration of the flush.
setArenaBlockSize(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The size of one block in arena memory allocation.
setArenaBlockSize(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setArenaBlockSize(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setArenaBlockSize(long) - Method in class org.rocksdb.Options
 
setAtomicFlush(boolean) - Method in class org.rocksdb.DBOptions
 
setAtomicFlush(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, RocksDB supports flushing multiple column families and committing their results atomically to MANIFEST.
setAtomicFlush(boolean) - Method in class org.rocksdb.Options
 
setAvoidFlushDuringRecovery(boolean) - Method in class org.rocksdb.DBOptions
 
setAvoidFlushDuringRecovery(boolean) - Method in interface org.rocksdb.DBOptionsInterface
By default RocksDB replay WAL logs and flush them on DB open, which may create very small SST files.
setAvoidFlushDuringRecovery(boolean) - Method in class org.rocksdb.Options
 
setAvoidFlushDuringShutdown(boolean) - Method in class org.rocksdb.DBOptions
 
setAvoidFlushDuringShutdown(boolean) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setAvoidFlushDuringShutdown(boolean) - Method in interface org.rocksdb.MutableDBOptionsInterface
By default RocksDB will flush all memtables on DB close if there are unpersisted data (i.e.
setAvoidFlushDuringShutdown(boolean) - Method in class org.rocksdb.Options
 
setBackgroundPurgeOnIteratorCleanup(boolean) - Method in class org.rocksdb.ReadOptions
If true, when PurgeObsoleteFile is called in CleanupIteratorState, we schedule a background job in the flush job queue and delete obsolete files in background.
setBackgroundThreads(int) - Method in class org.rocksdb.Env
Sets the number of background worker threads of the flush pool for this environment.
setBackgroundThreads(int, Priority) - Method in class org.rocksdb.Env
Sets the number of background worker threads of the specified thread pool for this environment.
setBackupEnv(Env) - Method in class org.rocksdb.BackupableDBOptions
Backup Env object.
setBackupLogFiles(boolean) - Method in class org.rocksdb.BackupableDBOptions
Set if log files shall be persisted.
setBackupRateLimit(long) - Method in class org.rocksdb.BackupableDBOptions
Set backup rate limit.
setBackupRateLimiter(RateLimiter) - Method in class org.rocksdb.BackupableDBOptions
Backup rate limiter.
setBaseBackgroundCompactions(int) - Method in class org.rocksdb.DBOptions
Deprecated.
setBaseBackgroundCompactions(int) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
Deprecated.
setBaseBackgroundCompactions(int) - Method in interface org.rocksdb.MutableDBOptionsInterface
setBaseBackgroundCompactions(int) - Method in class org.rocksdb.Options
Deprecated.
setBlockAlign(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Set whether data blocks should be aligned on the lesser of page size and block size.
setBlockCache(Cache) - Method in class org.rocksdb.BlockBasedTableConfig
Use the specified cache for blocks.
setBlockCacheCompressed(Cache) - Method in class org.rocksdb.BlockBasedTableConfig
Use the specified cache for compressed blocks.
setBlockCacheCompressedNumShardBits(int) - Method in class org.rocksdb.BlockBasedTableConfig
setBlockCacheCompressedSize(long) - Method in class org.rocksdb.BlockBasedTableConfig
setBlockCacheSize(long) - Method in class org.rocksdb.BlockBasedTableConfig
setBlockRestartInterval(int) - Method in class org.rocksdb.BlockBasedTableConfig
Set the block restart interval.
setBlockSize(long) - Method in class org.rocksdb.BlockBasedTableConfig
Approximate size of user data packed per block.
setBlockSizeDeviation(int) - Method in class org.rocksdb.BlockBasedTableConfig
This is used to close a block before it reaches the configured BlockBasedTableConfig.blockSize().
setBloomBitsPerKey(int) - Method in class org.rocksdb.PlainTableConfig
Set the number of bits per key used by the internal bloom filter in the plain table sst format.
setBloomLocality(int) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Control locality of bloom filter probes to improve cache miss rate.
setBloomLocality(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setBloomLocality(int) - Method in class org.rocksdb.Options
 
setBoolean(K, boolean) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
setBottommostCompressionOptions(CompressionOptions) - Method in class org.rocksdb.ColumnFamilyOptions
 
setBottommostCompressionOptions(CompressionOptions) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set the options for compression algorithms used by ColumnFamilyOptionsInterface.bottommostCompressionType() if it is enabled.
setBottommostCompressionOptions(CompressionOptions) - Method in class org.rocksdb.Options
 
setBottommostCompressionType(CompressionType) - Method in class org.rocksdb.ColumnFamilyOptions
 
setBottommostCompressionType(CompressionType) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Compression algorithm that will be used for the bottommost level that contain files.
setBottommostCompressionType(CompressionType) - Method in class org.rocksdb.Options
 
setBottommostLevelCompaction(CompactRangeOptions.BottommostLevelCompaction) - Method in class org.rocksdb.CompactRangeOptions
Sets the policy for compacting the bottommost level
setBranchingFactor(int) - Method in class org.rocksdb.HashSkipListMemTableConfig
Set the branching factor used in the hash skip-list memtable.
setBucketCount(long) - Method in class org.rocksdb.HashLinkedListMemTableConfig
Set the number of buckets in the fixed-size array used in the hash linked-list mem-table.
setBucketCount(long) - Method in class org.rocksdb.HashSkipListMemTableConfig
Set the number of hash buckets used in the hash skiplist memtable.
setBucketEntriesLoggingThreshold(int) - Method in class org.rocksdb.HashLinkedListMemTableConfig
If number of entries in one bucket exceeds that setting, log about it.
setBytesPerSecond(long) - Method in class org.rocksdb.RateLimiter
This API allows user to dynamically change rate limiter's bytes per second.
setBytesPerSync(long) - Method in class org.rocksdb.DBOptions
 
setBytesPerSync(long) - Method in class org.rocksdb.EnvOptions
Allows OS to incrementally sync files to disk while they are being written, in the background.
setBytesPerSync(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setBytesPerSync(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
Allows OS to incrementally sync files to disk while they are being written, asynchronously, in the background.
setBytesPerSync(long) - Method in class org.rocksdb.Options
 
setCacheIndexAndFilterBlocks(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Indicating if we'd put index/filter blocks to the block cache.
setCacheIndexAndFilterBlocksWithHighPriority(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
If true, cache index and filter blocks with high priority.
setCacheNumShardBits(int) - Method in class org.rocksdb.BlockBasedTableConfig
setCallbackTriggerIntervalSize(long) - Method in class org.rocksdb.BackupableDBOptions
During backup user can get callback every time next BackupableDBOptions.callbackTriggerIntervalSize() bytes being copied.
setChangeLevel(boolean) - Method in class org.rocksdb.CompactRangeOptions
Whether compacted files will be moved to the minimum level capable of holding the data or given level (specified non-negative target_level).
setChecksumType(ChecksumType) - Method in class org.rocksdb.BlockBasedTableConfig
Sets
setCompactionBufferSize(long) - Method in class org.rocksdb.SstFileManager
Set the amount of buffer room each compaction should be able to leave.
setCompactionFilter(AbstractCompactionFilter<? extends AbstractSlice<?>>) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompactionFilter(AbstractCompactionFilter<? extends AbstractSlice<?>>) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
A single CompactionFilter instance to call into during compaction.
setCompactionFilter(AbstractCompactionFilter<? extends AbstractSlice<?>>) - Method in class org.rocksdb.Options
 
setCompactionFilterFactory(AbstractCompactionFilterFactory<? extends AbstractCompactionFilter<?>>) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompactionFilterFactory(AbstractCompactionFilterFactory<? extends AbstractCompactionFilter<?>>) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
This is a factory that provides AbstractCompactionFilter objects which allow an application to modify/delete a key-value during background compaction.
setCompactionFilterFactory(AbstractCompactionFilterFactory<? extends AbstractCompactionFilter<?>>) - Method in class org.rocksdb.Options
 
setCompactionOptionsFIFO(CompactionOptionsFIFO) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The options for FIFO compaction style
setCompactionOptionsFIFO(CompactionOptionsFIFO) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompactionOptionsFIFO(CompactionOptionsFIFO) - Method in class org.rocksdb.Options
 
setCompactionOptionsUniversal(CompactionOptionsUniversal) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Set the options needed to support Universal Style compactions
setCompactionOptionsUniversal(CompactionOptionsUniversal) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompactionOptionsUniversal(CompactionOptionsUniversal) - Method in class org.rocksdb.Options
 
setCompactionPriority(CompactionPriority) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
If level AdvancedColumnFamilyOptionsInterface.compactionStyle() == CompactionStyle.LEVEL, for each level, which files are prioritized to be picked to compact.
setCompactionPriority(CompactionPriority) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompactionPriority(CompactionPriority) - Method in class org.rocksdb.Options
 
setCompactionReadaheadSize(long) - Method in class org.rocksdb.DBOptions
 
setCompactionReadaheadSize(long) - Method in class org.rocksdb.EnvOptions
setCompactionReadaheadSize(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setCompactionReadaheadSize(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
If non-zero, we perform bigger reads when doing compaction.
setCompactionReadaheadSize(long) - Method in class org.rocksdb.Options
 
setCompactionStyle(CompactionStyle) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Set compaction style for DB.
setCompactionStyle(CompactionStyle) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompactionStyle(CompactionStyle) - Method in class org.rocksdb.Options
 
setComparator(BuiltinComparator) - Method in class org.rocksdb.ColumnFamilyOptions
 
setComparator(AbstractComparator) - Method in class org.rocksdb.ColumnFamilyOptions
 
setComparator(BuiltinComparator) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set BuiltinComparator to be used with RocksDB.
setComparator(AbstractComparator) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Use the specified comparator for key ordering.
setComparator(AbstractComparator) - Method in class org.rocksdb.OptimisticTransactionOptions
Should be set if the DB has a non-default comparator.
setComparator(BuiltinComparator) - Method in class org.rocksdb.Options
 
setComparator(AbstractComparator) - Method in class org.rocksdb.Options
 
setCompression(CompressionType) - Method in class org.rocksdb.CompactionOptions
Set the compaction output compression type.
setCompressionOptions(CompressionOptions) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompressionOptions(CompressionOptions) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set the different options for compression algorithms
setCompressionOptions(CompressionOptions) - Method in class org.rocksdb.Options
 
setCompressionPerLevel(List<CompressionType>) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Different levels can have different compression policies.
setCompressionPerLevel(List<CompressionType>) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompressionPerLevel(List<CompressionType>) - Method in class org.rocksdb.Options
 
setCompressionSizePercent(int) - Method in class org.rocksdb.CompactionOptionsUniversal
If this option is set to be -1 (the default value), all the output files will follow compression type specified.
setCompressionType(CompressionType) - Method in class org.rocksdb.ColumnFamilyOptions
 
setCompressionType(CompressionType) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setCompressionType(CompressionType) - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Compress blocks using the specified compression algorithm.
setCompressionType(CompressionType) - Method in class org.rocksdb.Options
 
setCreateIfMissing(boolean) - Method in class org.rocksdb.DBOptions
 
setCreateIfMissing(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If this value is set to true, then the database will be created if it is missing during RocksDB.open().
setCreateIfMissing(boolean) - Method in class org.rocksdb.Options
 
setCreateMissingColumnFamilies(boolean) - Method in class org.rocksdb.DBOptions
 
setCreateMissingColumnFamilies(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, missing column families will be automatically created
setCreateMissingColumnFamilies(boolean) - Method in class org.rocksdb.Options
 
setDataBlockHashTableUtilRatio(double) - Method in class org.rocksdb.BlockBasedTableConfig
Set the #entries/#buckets.
setDataBlockIndexType(DataBlockIndexType) - Method in class org.rocksdb.BlockBasedTableConfig
Sets the data block index type to used with this table.
setDbLogDir(String) - Method in class org.rocksdb.DBOptions
 
setDbLogDir(String) - Method in interface org.rocksdb.DBOptionsInterface
This specifies the info LOG dir.
setDbLogDir(String) - Method in class org.rocksdb.Options
 
setDBOptions(MutableDBOptions) - Method in class org.rocksdb.RocksDB
Set the options for the column family handle.
setDbPaths(Collection<DbPath>) - Method in class org.rocksdb.DBOptions
 
setDbPaths(Collection<DbPath>) - Method in interface org.rocksdb.DBOptionsInterface
A list of paths where SST files can be put into, with its target size.
setDbPaths(Collection<DbPath>) - Method in class org.rocksdb.Options
 
setDbWriteBufferSize(long) - Method in class org.rocksdb.DBOptions
 
setDbWriteBufferSize(long) - Method in interface org.rocksdb.DBOptionsInterface
Amount of data to build up in memtables across all column families before writing to disk.
setDbWriteBufferSize(long) - Method in class org.rocksdb.Options
 
setDeadlockDetect(boolean) - Method in class org.rocksdb.TransactionOptions
Setting to true means that before acquiring locks, this transaction will check if doing so will cause a deadlock.
setDeadlockDetectDepth(long) - Method in class org.rocksdb.TransactionOptions
Sets the number of traversals to make during deadlock detection.
setDeadlockInfoBufferSize(int) - Method in class org.rocksdb.TransactionDB
 
setDefaultLockTimeout(long) - Method in class org.rocksdb.TransactionDBOptions
If positive, specifies the wait timeout in milliseconds when writing a key OUTSIDE of a transaction (ie by calling RocksDB.put(byte[], byte[]), RocksDB.merge(byte[], byte[]), RocksDB.delete(byte[]) or RocksDB.write(org.rocksdb.WriteOptions, org.rocksdb.WriteBatch) directly).
setDelayedWriteRate(long) - Method in class org.rocksdb.DBOptions
 
setDelayedWriteRate(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setDelayedWriteRate(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
The limited write rate to DB if ColumnFamilyOptions.softPendingCompactionBytesLimit() or ColumnFamilyOptions.level0SlowdownWritesTrigger() is triggered, or we are writing to the last mem table allowed and we allow more than 3 mem tables.
setDelayedWriteRate(long) - Method in class org.rocksdb.Options
 
setDeleteObsoleteFilesPeriodMicros(long) - Method in class org.rocksdb.DBOptions
 
setDeleteObsoleteFilesPeriodMicros(long) - Method in interface org.rocksdb.DBOptionsInterface
The periodicity when obsolete files get deleted.
setDeleteObsoleteFilesPeriodMicros(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setDeleteObsoleteFilesPeriodMicros(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
The periodicity when obsolete files get deleted.
setDeleteObsoleteFilesPeriodMicros(long) - Method in class org.rocksdb.Options
 
setDeleteRateBytesPerSecond(long) - Method in class org.rocksdb.SstFileManager
Set the delete rate limit.
setDestroyOldData(boolean) - Method in class org.rocksdb.BackupableDBOptions
Set if old data will be destroyed.
setDisableAutoCompactions(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setDisableAutoCompactions(boolean) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setDisableAutoCompactions(boolean) - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Disable automatic compactions.
setDisableAutoCompactions(boolean) - Method in class org.rocksdb.Options
 
setDisableWAL(boolean) - Method in class org.rocksdb.WriteOptions
If true, writes will not first go to the write ahead log, and the write may got lost after a crash.
setDouble(K, double) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
setDumpMallocStats(boolean) - Method in class org.rocksdb.DBOptions
 
setDumpMallocStats(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, then print malloc stats together with rocksdb.stats when printing to LOG.
setDumpMallocStats(boolean) - Method in class org.rocksdb.Options
 
setEnabled(boolean) - Method in class org.rocksdb.CompressionOptions
When the compression options are set by the user, it will be set to "true".
setEnableIndexCompression(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Store index blocks on disk in compressed format.
setEnablePipelinedWrite(boolean) - Method in class org.rocksdb.DBOptions
 
setEnablePipelinedWrite(boolean) - Method in interface org.rocksdb.DBOptionsInterface
By default, a single write thread queue is maintained.
setEnablePipelinedWrite(boolean) - Method in class org.rocksdb.Options
 
setEnableThreadTracking(boolean) - Method in class org.rocksdb.DBOptions
 
setEnableThreadTracking(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, then the status of the threads involved in this DB will be tracked and available via GetThreadList() API.
setEnableThreadTracking(boolean) - Method in class org.rocksdb.Options
 
setEnableWriteThreadAdaptiveYield(boolean) - Method in class org.rocksdb.DBOptions
 
setEnableWriteThreadAdaptiveYield(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, threads synchronizing with the write batch group leader will wait for up to DBOptionsInterface.writeThreadMaxYieldUsec() before blocking on a mutex.
setEnableWriteThreadAdaptiveYield(boolean) - Method in class org.rocksdb.Options
 
setEncodingType(EncodingType) - Method in class org.rocksdb.PlainTableConfig
Sets the encoding type.
setEnum(K, N) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
setEnv(Env) - Method in class org.rocksdb.DBOptions
 
setEnv(Env) - Method in interface org.rocksdb.DBOptionsInterface
Use the specified object to interact with the environment, e.g.
setEnv(Env) - Method in class org.rocksdb.Options
 
setErrorIfExists(boolean) - Method in class org.rocksdb.DBOptions
 
setErrorIfExists(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, an error will be thrown during RocksDB.open() if the database already exists.
setErrorIfExists(boolean) - Method in class org.rocksdb.Options
 
setExclusiveManualCompaction(boolean) - Method in class org.rocksdb.CompactRangeOptions
Sets whether the compaction is exclusive or other compaction are allowed run concurrently at the same time.
setExpiration(long) - Method in class org.rocksdb.TransactionOptions
Expiration duration in milliseconds.
setFailIfOptionsFileError(boolean) - Method in class org.rocksdb.DBOptions
 
setFailIfOptionsFileError(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, then DB::Open / CreateColumnFamily / DropColumnFamily / SetOptions will fail if options file is not detected or properly persisted.
setFailIfOptionsFileError(boolean) - Method in class org.rocksdb.Options
 
setFallocateWithKeepSize(boolean) - Method in class org.rocksdb.EnvOptions
If true, we will preallocate the file with FALLOC_FL_KEEP_SIZE flag, which means that file size won't change as part of preallocation.
setFdCloexec() - Method in class org.rocksdb.EnvOptions
Determine i fthe FD_CLOEXEC bit is set when opening file descriptors.
setFillCache(boolean) - Method in class org.rocksdb.ReadOptions
Fill the cache when loading the block-based sst formatted db.
setFilter(Filter) - Method in class org.rocksdb.BlockBasedTableConfig
setFilterPolicy(Filter) - Method in class org.rocksdb.BlockBasedTableConfig
Use the specified filter policy to reduce disk reads.
setForceConsistencyChecks(boolean) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
In debug mode, RocksDB run consistency checks on the LSM every time the LSM change (Flush, Compaction, AddFile).
setForceConsistencyChecks(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setForceConsistencyChecks(boolean) - Method in class org.rocksdb.Options
 
setFormatVersion(int) - Method in class org.rocksdb.BlockBasedTableConfig
We currently have five versions:
setFullScanMode(boolean) - Method in class org.rocksdb.PlainTableConfig
Set full scan mode, if true the whole file will be read one record by one without using the index.
setHardPendingCompactionBytesLimit(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
All writes are stopped if estimated bytes needed to be compaction exceed this threshold.
setHardPendingCompactionBytesLimit(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setHardPendingCompactionBytesLimit(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setHardPendingCompactionBytesLimit(long) - Method in class org.rocksdb.Options
 
setHashIndexAllowCollision(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Deprecated.
This option is now deprecated. No matter what value it is set to, it will behave as if BlockBasedTableConfig.hashIndexAllowCollision() == true.
setHashTableRatio(double) - Method in class org.rocksdb.PlainTableConfig
hashTableRatio is the desired utilization of the hash table used for prefix hashing.
setHeight(int) - Method in class org.rocksdb.HashSkipListMemTableConfig
Set the height of the skip list.
setHugePageTlbSize(long) - Method in class org.rocksdb.HashLinkedListMemTableConfig
Set the size of huge tlb or allocate the hashtable bytes from malloc if size <= 0.
setHugePageTlbSize(int) - Method in class org.rocksdb.PlainTableConfig
huge_page_tlb_size: if ≤0, allocate hash indexes and blooms from malloc otherwise from huge page TLB.
setIfLogBucketDistWhenFlush(boolean) - Method in class org.rocksdb.HashLinkedListMemTableConfig
If true the distrubition of number of entries will be logged.
setIgnoreMissingColumnFamilies(boolean) - Method in class org.rocksdb.WriteOptions
If true and if user is trying to write to column families that don't exist (they were dropped), ignore the write (don't return an error).
setIgnoreRangeDeletions(boolean) - Method in class org.rocksdb.ReadOptions
If true, keys deleted using the DeleteRange() API will be visible to readers until they are naturally deleted during compaction.
setIncreaseParallelism(int) - Method in class org.rocksdb.DBOptions
 
setIncreaseParallelism(int) - Method in interface org.rocksdb.DBOptionsInterface
By default, RocksDB uses only one background thread for flush and compaction.
setIncreaseParallelism(int) - Method in class org.rocksdb.Options
 
setIndexBlockRestartInterval(int) - Method in class org.rocksdb.BlockBasedTableConfig
Set the index block restart interval
setIndexSparseness(int) - Method in class org.rocksdb.PlainTableConfig
Index sparseness determines the index interval for keys inside the same prefix.
setIndexType(IndexType) - Method in class org.rocksdb.BlockBasedTableConfig
Sets the index type to used with this table.
setInfoLog(Logger) - Method in class org.rocksdb.BackupableDBOptions
Set the logger to use for Backup info and error messages
setInfoLogLevel(InfoLogLevel) - Method in class org.rocksdb.DBOptions
 
setInfoLogLevel(InfoLogLevel) - Method in interface org.rocksdb.DBOptionsInterface
Sets the RocksDB log level.
setInfoLogLevel(InfoLogLevel) - Method in class org.rocksdb.Logger
Set InfoLogLevel to AbstractLogger.
setInfoLogLevel(long, byte) - Method in class org.rocksdb.Logger
 
setInfoLogLevel(InfoLogLevel) - Method in class org.rocksdb.Options
 
setIngestBehind(boolean) - Method in class org.rocksdb.IngestExternalFileOptions
Set to true if you would like duplicate keys in the file being ingested to be skipped rather than overwriting existing data under that key.
setInplaceUpdateNumLocks(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Number of locks used for inplace update Default: 10000, if inplace_update_support = true, else 0.
setInplaceUpdateNumLocks(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setInplaceUpdateNumLocks(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setInplaceUpdateNumLocks(long) - Method in class org.rocksdb.Options
 
setInplaceUpdateSupport(boolean) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Allows thread-safe inplace updates.
setInplaceUpdateSupport(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setInplaceUpdateSupport(boolean) - Method in class org.rocksdb.Options
 
setInt(K, int) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
setIntArray(K, int[]) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
setIsFdCloseOnExec(boolean) - Method in class org.rocksdb.DBOptions
 
setIsFdCloseOnExec(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Disable child process inherit open files.
setIsFdCloseOnExec(boolean) - Method in class org.rocksdb.Options
 
setIterateLowerBound(Slice) - Method in class org.rocksdb.ReadOptions
Defines the smallest key at which the backward iterator can return an entry.
setIterateUpperBound(Slice) - Method in class org.rocksdb.ReadOptions
Defines the extent up to which the forward iterator can returns entries.
setIterStartSeqnum(long) - Method in class org.rocksdb.ReadOptions
Needed to support differential snapshots.
setKeepLogFileNum(long) - Method in class org.rocksdb.DBOptions
 
setKeepLogFileNum(long) - Method in interface org.rocksdb.DBOptionsInterface
Specifies the maximum number of info log files to be kept.
setKeepLogFileNum(long) - Method in class org.rocksdb.Options
 
setKeySize(int) - Method in class org.rocksdb.PlainTableConfig
Set the length of the user key.
setLevel(int) - Method in class org.rocksdb.CompressionOptions
 
setLevel0FileNumCompactionTrigger(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevel0FileNumCompactionTrigger(int) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setLevel0FileNumCompactionTrigger(int) - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Number of files to trigger level-0 compaction.
setLevel0FileNumCompactionTrigger(int) - Method in class org.rocksdb.Options
 
setLevel0SlowdownWritesTrigger(int) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Soft limit on number of level-0 files.
setLevel0SlowdownWritesTrigger(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevel0SlowdownWritesTrigger(int) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setLevel0SlowdownWritesTrigger(int) - Method in class org.rocksdb.Options
 
setLevel0StopWritesTrigger(int) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Maximum number of level-0 files.
setLevel0StopWritesTrigger(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevel0StopWritesTrigger(int) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setLevel0StopWritesTrigger(int) - Method in class org.rocksdb.Options
 
setLevelCompactionDynamicLevelBytes(boolean) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
If true, RocksDB will pick target size of each level dynamically.
setLevelCompactionDynamicLevelBytes(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevelCompactionDynamicLevelBytes(boolean) - Method in class org.rocksdb.Options
 
setLevelZeroFileNumCompactionTrigger(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevelZeroFileNumCompactionTrigger(int) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Number of files to trigger level-0 compaction.
setLevelZeroFileNumCompactionTrigger(int) - Method in class org.rocksdb.Options
 
setLevelZeroSlowdownWritesTrigger(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevelZeroSlowdownWritesTrigger(int) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Soft limit on number of level-0 files.
setLevelZeroSlowdownWritesTrigger(int) - Method in class org.rocksdb.Options
 
setLevelZeroStopWritesTrigger(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setLevelZeroStopWritesTrigger(int) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Maximum number of level-0 files.
setLevelZeroStopWritesTrigger(int) - Method in class org.rocksdb.Options
 
setLockTimeout(long) - Method in class org.rocksdb.Transaction
Change the value of TransactionOptions.getLockTimeout() (in milliseconds) for this transaction.
setLockTimeout(long) - Method in class org.rocksdb.TransactionOptions
If positive, specifies the wait timeout in milliseconds when a transaction attempts to lock a key.
setLogFileTimeToRoll(long) - Method in class org.rocksdb.DBOptions
 
setLogFileTimeToRoll(long) - Method in interface org.rocksdb.DBOptionsInterface
Specifies the time interval for the info log file to roll (in seconds).
setLogFileTimeToRoll(long) - Method in class org.rocksdb.Options
 
setLogger(Logger) - Method in class org.rocksdb.DBOptions
 
setLogger(Logger) - Method in interface org.rocksdb.DBOptionsInterface
Any internal progress/error information generated by the db will be written to the Logger if it is non-nullptr, or to a file stored in the same directory as the DB contents if info_log is nullptr.
setLogger(Logger) - Method in class org.rocksdb.Options
 
setLogNumber(long) - Method in class org.rocksdb.Transaction
Set the log number.
setLong(K, long) - Method in class org.rocksdb.AbstractMutableOptions.AbstractMutableOptionsBuilder
 
setLookahead(long) - Method in class org.rocksdb.SkipListMemTableConfig
Sets lookahead for SkipList
setLowPri(boolean) - Method in class org.rocksdb.WriteOptions
If true, this write request is of lower priority if compaction is behind.
setManaged(boolean) - Method in class org.rocksdb.ReadOptions
Deprecated.
This options is not used anymore.
setManifestPreallocationSize(long) - Method in class org.rocksdb.DBOptions
 
setManifestPreallocationSize(long) - Method in interface org.rocksdb.DBOptionsInterface
Number of bytes to preallocate (via fallocate) the manifest files.
setManifestPreallocationSize(long) - Method in class org.rocksdb.Options
 
setManualWalFlush(boolean) - Method in class org.rocksdb.DBOptions
 
setManualWalFlush(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true WAL is not flushed automatically after each write.
setManualWalFlush(boolean) - Method in class org.rocksdb.Options
 
setMaxAllowedSpaceUsage(long) - Method in class org.rocksdb.SstFileManager
Update the maximum allowed space that should be used by RocksDB, if the total size of the SST files exceeds maxAllowedSpace, writes to RocksDB will fail.
setMaxBackgroundCompactions(int) - Method in class org.rocksdb.DBOptions
Deprecated.
setMaxBackgroundCompactions(int) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
Deprecated.
setMaxBackgroundCompactions(int) - Method in interface org.rocksdb.MutableDBOptionsInterface
setMaxBackgroundCompactions(int) - Method in class org.rocksdb.Options
Deprecated.
setMaxBackgroundFlushes(int) - Method in class org.rocksdb.DBOptions
Deprecated.
setMaxBackgroundFlushes(int) - Method in interface org.rocksdb.DBOptionsInterface
setMaxBackgroundFlushes(int) - Method in class org.rocksdb.Options
Deprecated.
setMaxBackgroundJobs(int) - Method in class org.rocksdb.DBOptions
 
setMaxBackgroundJobs(int) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setMaxBackgroundJobs(int) - Method in interface org.rocksdb.MutableDBOptionsInterface
Specifies the maximum number of concurrent background jobs (both flushes and compactions combined).
setMaxBackgroundJobs(int) - Method in class org.rocksdb.Options
 
setMaxBackgroundOperations(int) - Method in class org.rocksdb.BackupableDBOptions
setMaxBytes(long) - Method in class org.rocksdb.AbstractWriteBatch
 
setMaxBytes(long) - Method in interface org.rocksdb.WriteBatchInterface
Set the maximum size of the write batch.
setMaxBytesForLevelBase(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxBytesForLevelBase(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxBytesForLevelBase(long) - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
The upper-bound of the total size of level-1 files in bytes.
setMaxBytesForLevelBase(long) - Method in class org.rocksdb.Options
 
setMaxBytesForLevelMultiplier(double) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The ratio between the total size of level-(L+1) files and the total size of level-L files for all L.
setMaxBytesForLevelMultiplier(double) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxBytesForLevelMultiplier(double) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
The ratio between the total size of level-(L+1) files and the total size of level-L files for all L.
setMaxBytesForLevelMultiplier(double) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxBytesForLevelMultiplier(double) - Method in class org.rocksdb.Options
 
setMaxBytesForLevelMultiplierAdditional(int[]) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Different max-size multipliers for different levels.
setMaxBytesForLevelMultiplierAdditional(int[]) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxBytesForLevelMultiplierAdditional(int[]) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxBytesForLevelMultiplierAdditional(int[]) - Method in class org.rocksdb.Options
 
setMaxCompactionBytes(long) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Maximum size of each compaction (not guarantee)
setMaxCompactionBytes(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxCompactionBytes(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxCompactionBytes(long) - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
We try to limit number of bytes in one compaction to be lower than this threshold.
setMaxCompactionBytes(long) - Method in class org.rocksdb.Options
 
setMaxDictBytes(int) - Method in class org.rocksdb.CompressionOptions
Maximum size of dictionary used to prime the compression library.
setMaxFileOpeningThreads(int) - Method in class org.rocksdb.DBOptions
 
setMaxFileOpeningThreads(int) - Method in interface org.rocksdb.DBOptionsInterface
If MutableDBOptionsInterface.maxOpenFiles() is -1, DB will open all files on DB::Open().
setMaxFileOpeningThreads(int) - Method in class org.rocksdb.Options
 
setMaxLogFileSize(long) - Method in class org.rocksdb.DBOptions
 
setMaxLogFileSize(long) - Method in interface org.rocksdb.DBOptionsInterface
Specifies the maximum size of a info log file.
setMaxLogFileSize(long) - Method in class org.rocksdb.Options
 
setMaxManifestFileSize(long) - Method in class org.rocksdb.DBOptions
 
setMaxManifestFileSize(long) - Method in interface org.rocksdb.DBOptionsInterface
Manifest file is rolled over on reaching this limit.
setMaxManifestFileSize(long) - Method in class org.rocksdb.Options
 
setMaxMergeWidth(int) - Method in class org.rocksdb.CompactionOptionsUniversal
The maximum number of files in a single compaction run.
setMaxNumLocks(long) - Method in class org.rocksdb.TransactionDBOptions
Specifies the maximum number of keys that can be locked at the same time per column family.
setMaxOpenFiles(int) - Method in class org.rocksdb.DBOptions
 
setMaxOpenFiles(int) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setMaxOpenFiles(int) - Method in interface org.rocksdb.MutableDBOptionsInterface
Number of open files that can be used by the DB.
setMaxOpenFiles(int) - Method in class org.rocksdb.Options
 
setMaxReusedBufferSize(int) - Method in class org.rocksdb.ComparatorOptions
Sets the maximum size of a buffer (in bytes) that will be reused.
setMaxSequentialSkipInIterations(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
An iteration->Next() sequentially skips over keys with the same user-key unless this option is set.
setMaxSequentialSkipInIterations(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxSequentialSkipInIterations(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxSequentialSkipInIterations(long) - Method in class org.rocksdb.Options
 
setMaxSizeAmplificationPercent(int) - Method in class org.rocksdb.CompactionOptionsUniversal
The size amplification is defined as the amount (in percentage) of additional storage needed to store a single byte of data in the database.
setMaxSkippableInternalKeys(long) - Method in class org.rocksdb.ReadOptions
A threshold for the number of keys that can be skipped before failing an iterator seek as incomplete.
setMaxSubcompactions(int) - Method in class org.rocksdb.CompactionOptions
This value represents the maximum number of threads that will concurrently perform a compaction job by breaking it into multiple, smaller ones that are run simultaneously.
setMaxSubcompactions(int) - Method in class org.rocksdb.CompactRangeOptions
If > 0, it will replace the option in the DBOptions for this compaction
setMaxSubcompactions(int) - Method in class org.rocksdb.DBOptions
 
setMaxSubcompactions(int) - Method in interface org.rocksdb.DBOptionsInterface
This value represents the maximum number of threads that will concurrently perform a compaction job by breaking it into multiple, smaller ones that are run simultaneously.
setMaxSubcompactions(int) - Method in class org.rocksdb.Options
 
setMaxSuccessiveMerges(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Maximum number of successive merge operations on a key in the memtable.
setMaxSuccessiveMerges(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxSuccessiveMerges(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxSuccessiveMerges(long) - Method in class org.rocksdb.Options
 
setMaxTableFilesSize(long) - Method in class org.rocksdb.CompactionOptionsFIFO
Once the total sum of table files reaches this, we will delete the oldest table file Default: 1GB
setMaxTableFilesSizeFIFO(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxTableFilesSizeFIFO(long) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
FIFO compaction option.
setMaxTableFilesSizeFIFO(long) - Method in class org.rocksdb.Options
 
setMaxTotalWalSize(long) - Method in class org.rocksdb.DBOptions
 
setMaxTotalWalSize(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setMaxTotalWalSize(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
Once write-ahead logs exceed this size, we will start forcing the flush of column families whose memtables are backed by the oldest live WAL file (i.e.
setMaxTotalWalSize(long) - Method in class org.rocksdb.Options
 
setMaxTrashDBRatio(double) - Method in class org.rocksdb.SstFileManager
Set the trash/DB size ratio where new files will be deleted immediately.
setMaxWriteBatchSize(long) - Method in class org.rocksdb.TransactionOptions
Set the maximum number of bytes that may be used for the write batch.
setMaxWriteBufferNumber(int) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The maximum number of write buffers that are built up in memory.
setMaxWriteBufferNumber(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxWriteBufferNumber(int) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMaxWriteBufferNumber(int) - Method in class org.rocksdb.Options
 
setMaxWriteBufferNumberToMaintain(int) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The total maximum number of write buffers to maintain in memory including copies of buffers that have already been flushed.
setMaxWriteBufferNumberToMaintain(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMaxWriteBufferNumberToMaintain(int) - Method in class org.rocksdb.Options
 
setMemTableConfig(MemTableConfig) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMemTableConfig(MemTableConfig) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set the config for mem-table.
setMemTableConfig(MemTableConfig) - Method in class org.rocksdb.Options
 
setMemtableHugePageSize(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Page size for huge page TLB for bloom in memtable.
setMemtableHugePageSize(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMemtableHugePageSize(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMemtableHugePageSize(long) - Method in class org.rocksdb.Options
 
setMemtablePrefixBloomSizeRatio(double) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
if prefix_extractor is set and memtable_prefix_bloom_size_ratio is not 0, create prefix bloom for memtable with the size of write_buffer_size * memtable_prefix_bloom_size_ratio.
setMemtablePrefixBloomSizeRatio(double) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMemtablePrefixBloomSizeRatio(double) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setMemtablePrefixBloomSizeRatio(double) - Method in class org.rocksdb.Options
 
setMergeOperator(MergeOperator) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMergeOperator(MergeOperator) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set the merge operator to be used for merging two different key/value pairs that share the same key.
setMergeOperator(MergeOperator) - Method in class org.rocksdb.Options
 
setMergeOperatorName(String) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMergeOperatorName(String) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set the merge operator to be used for merging two merge operands of the same key.
setMergeOperatorName(String) - Method in class org.rocksdb.Options
 
setMetadataBlockSize(long) - Method in class org.rocksdb.BlockBasedTableConfig
Set block size for partitioned metadata.
setMinMergeWidth(int) - Method in class org.rocksdb.CompactionOptionsUniversal
The minimum number of files in a single compaction run.
setMinWriteBufferNumberToMerge(int) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
The minimum number of write buffers that will be merged together before writing to storage.
setMinWriteBufferNumberToMerge(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setMinWriteBufferNumberToMerge(int) - Method in class org.rocksdb.Options
 
setMoveFiles(boolean) - Method in class org.rocksdb.IngestExternalFileOptions
Can be set to true to move the files instead of copying them.
setName(String) - Method in class org.rocksdb.Transaction
Set the name of the transaction.
setNativeHandle(long, boolean) - Method in class org.rocksdb.RocksMutableObject
Sets the handle (C++ pointer) of the underlying C++ native object
setNewTableReaderForCompactionInputs(boolean) - Method in class org.rocksdb.DBOptions
 
setNewTableReaderForCompactionInputs(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, always create a new file descriptor and new table reader for compaction inputs.
setNewTableReaderForCompactionInputs(boolean) - Method in class org.rocksdb.Options
 
setNoBlockCache(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Disable block cache.
setNoSlowdown(boolean) - Method in class org.rocksdb.WriteOptions
If true and we need to wait or sleep for the write request, fails immediately with Status.Code.Incomplete.
setNumLevels(int) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
Set the number of levels for this database If level-styled compaction is used, then this number determines the total number of levels.
setNumLevels(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setNumLevels(int) - Method in class org.rocksdb.Options
 
setNumStripes(long) - Method in class org.rocksdb.TransactionDBOptions
Increasing this value will increase the concurrency by dividing the lock table (per column family) into more sub-tables, each with their own separate mutex.
setOptimizeFiltersForHits(boolean) - Method in interface org.rocksdb.AdvancedColumnFamilyOptionsInterface
This flag specifies that the implementation should optimize the filters mainly for cases where keys are found rather than also optimize for keys missed.
setOptimizeFiltersForHits(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setOptimizeFiltersForHits(boolean) - Method in class org.rocksdb.Options
 
setOptions(ColumnFamilyHandle, MutableColumnFamilyOptions) - Method in class org.rocksdb.RocksDB
Change the options for the column family handle.
setOptions(MutableColumnFamilyOptions) - Method in class org.rocksdb.RocksDB
Change the options for the default column family handle.
setOutputFileSizeLimit(long) - Method in class org.rocksdb.CompactionOptions
Compaction will create files of size CompactionOptions.outputFileSizeLimit().
setParanoidChecks(boolean) - Method in class org.rocksdb.DBOptions
 
setParanoidChecks(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, the implementation will do aggressive checking of the data it is processing and will stop early if it detects any errors.
setParanoidChecks(boolean) - Method in class org.rocksdb.Options
 
setParanoidFileChecks(boolean) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
After writing every SST file, reopen it and read all the keys.
setParanoidFileChecks(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setParanoidFileChecks(boolean) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setParanoidFileChecks(boolean) - Method in class org.rocksdb.Options
 
setPartitionFilters(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Use partitioned full filters for each SST file.
setPersistentCache(PersistentCache) - Method in class org.rocksdb.BlockBasedTableConfig
Use the specified persistent cache.
setPinData(boolean) - Method in class org.rocksdb.ReadOptions
Keep the blocks loaded by the iterator pinned in memory as long as the iterator is not deleted, If used when reading from tables created with BlockBasedTableOptions::use_delta_encoding = false, Iterator's property "rocksdb.iterator.is-key-pinned" is guaranteed to return 1.
setPinL0FilterAndIndexBlocksInCache(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Indicating if we'd like to pin L0 index/filter blocks to the block cache.
setPinTopLevelIndexAndFilter(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
If cacheIndexAndFilterBlocks is true and the below is true, then the top-level index of partitioned filter and index blocks are stored in the cache, but a reference is held in the "table reader" object so the blocks are pinned and only evicted from cache when the table reader is freed.
setPrefixSameAsStart(boolean) - Method in class org.rocksdb.ReadOptions
Enforce that the iterator only iterates over the same prefix as the seek.
setPreserveDeletes(boolean) - Method in class org.rocksdb.DBOptions
 
setPreserveDeletes(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Needed to support differential snapshots.
setPreserveDeletes(boolean) - Method in class org.rocksdb.Options
 
setPreserveDeletesSequenceNumber(long) - Method in class org.rocksdb.RocksDB
Instructs DB to preserve deletes with sequence numbers >= sequenceNumber.
setRandomAccessMaxBufferSize(long) - Method in class org.rocksdb.DBOptions
 
setRandomAccessMaxBufferSize(long) - Method in interface org.rocksdb.DBOptionsInterface
This is a maximum buffer size that is used by WinMmapReadableFile in unbuffered disk I/O mode.
setRandomAccessMaxBufferSize(long) - Method in class org.rocksdb.EnvOptions
setRandomAccessMaxBufferSize(long) - Method in class org.rocksdb.Options
 
setRateLimiter(RateLimiter) - Method in class org.rocksdb.DBOptions
 
setRateLimiter(RateLimiter) - Method in interface org.rocksdb.DBOptionsInterface
Use to control write rate of flush and compaction.
setRateLimiter(RateLimiter) - Method in class org.rocksdb.EnvOptions
Set the write rate limiter for flush and compaction.
setRateLimiter(RateLimiter) - Method in class org.rocksdb.Options
 
setReadaheadSize(long) - Method in class org.rocksdb.ReadOptions
If non-zero, NewIterator will create a new table reader which performs reads of the given size.
setReadAmpBytesPerBit(int) - Method in class org.rocksdb.BlockBasedTableConfig
Set the Read amplification bytes per-bit.
setReadTier(ReadTier) - Method in class org.rocksdb.ReadOptions
Specify if this read request should process data that ALREADY resides on a particular cache.
setRecycleLogFileNum(long) - Method in class org.rocksdb.DBOptions
 
setRecycleLogFileNum(long) - Method in interface org.rocksdb.DBOptionsInterface
Recycle log files.
setRecycleLogFileNum(long) - Method in class org.rocksdb.Options
 
setReportBgIoStats(boolean) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Measure IO stats in compactions and flushes, if true.
setReportBgIoStats(boolean) - Method in class org.rocksdb.ColumnFamilyOptions
 
setReportBgIoStats(boolean) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setReportBgIoStats(boolean) - Method in class org.rocksdb.Options
 
setReservedSize(int) - Method in class org.rocksdb.VectorMemTableConfig
Set the initial size of the vector that will be used by the memtable created based on this config.
setRestoreRateLimit(long) - Method in class org.rocksdb.BackupableDBOptions
Set restore rate limit.
setRestoreRateLimiter(RateLimiter) - Method in class org.rocksdb.BackupableDBOptions
Restore rate limiter.
setReusedSynchronisationType(ReusedSynchronisationType) - Method in class org.rocksdb.ComparatorOptions
Set the synchronisation type used to guard the reused buffers.
setRowCache(Cache) - Method in class org.rocksdb.DBOptions
 
setRowCache(Cache) - Method in interface org.rocksdb.DBOptionsInterface
A global cache for table-level rows.
setRowCache(Cache) - Method in class org.rocksdb.Options
 
setSavePoint() - Method in class org.rocksdb.AbstractWriteBatch
 
setSavePoint() - Method in class org.rocksdb.Transaction
Records the state of the transaction for future calls to Transaction.rollbackToSavePoint().
setSavePoint() - Method in interface org.rocksdb.WriteBatchInterface
Records the state of the batch for future calls to RollbackToSavePoint().
setSetFdCloexec(boolean) - Method in class org.rocksdb.EnvOptions
Enable/Disable the FD_CLOEXEC bit when opening file descriptors.
setSetSnapshot(boolean) - Method in class org.rocksdb.OptimisticTransactionOptions
 
setSetSnapshot(boolean) - Method in class org.rocksdb.TransactionOptions
 
setShareFilesWithChecksum(boolean) - Method in class org.rocksdb.BackupableDBOptions
Only used if share_table_files is set to true.
setShareTableFiles(boolean) - Method in class org.rocksdb.BackupableDBOptions
Share table files between backups.
setSizeRatio(int) - Method in class org.rocksdb.CompactionOptionsUniversal
Percentage flexibility while comparing file size.
setSkipStatsUpdateOnDbOpen(boolean) - Method in class org.rocksdb.DBOptions
 
setSkipStatsUpdateOnDbOpen(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, then DB::Open() will not update the statistics used to optimize compaction decision by loading table properties from many files.
setSkipStatsUpdateOnDbOpen(boolean) - Method in class org.rocksdb.Options
 
setSnapshot(Snapshot) - Method in class org.rocksdb.ReadOptions
If "snapshot" is non-nullptr, read as of the supplied snapshot (which must belong to the DB that is being read and which must not have been released).
setSnapshot() - Method in class org.rocksdb.Transaction
If a transaction has a snapshot set, the transaction will ensure that any keys successfully written(or fetched via Transaction.getForUpdate(org.rocksdb.ReadOptions, org.rocksdb.ColumnFamilyHandle, byte[], boolean, boolean)) have not been modified outside of this transaction since the time the snapshot was set.
setSnapshotConsistency(boolean) - Method in class org.rocksdb.IngestExternalFileOptions
If set to false, an ingested file keys could appear in existing snapshots that where created before the file was ingested.
setSnapshotOnNextOperation() - Method in class org.rocksdb.Transaction
Similar to Transaction.setSnapshot(), but will not change the current snapshot until put/merge/delete/getForUpdate/multiGetForUpdate is called.
setSnapshotOnNextOperation(AbstractTransactionNotifier) - Method in class org.rocksdb.Transaction
Similar to Transaction.setSnapshot(), but will not change the current snapshot until put/merge/delete/getForUpdate/multiGetForUpdate is called.
setSoftPendingCompactionBytesLimit(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
All writes will be slowed down to at least delayed_write_rate if estimated bytes needed to be compaction exceed this threshold.
setSoftPendingCompactionBytesLimit(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setSoftPendingCompactionBytesLimit(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setSoftPendingCompactionBytesLimit(long) - Method in class org.rocksdb.Options
 
setSstFileManager(SstFileManager) - Method in class org.rocksdb.DBOptions
 
setSstFileManager(SstFileManager) - Method in interface org.rocksdb.DBOptionsInterface
Use to track SST files and control their file deletion rate.
setSstFileManager(SstFileManager) - Method in class org.rocksdb.Options
 
setStatistics(Statistics) - Method in class org.rocksdb.DBOptions
 
setStatistics(Statistics) - Method in interface org.rocksdb.DBOptionsInterface
Sets the statistics object which collects metrics about database operations.
setStatistics(Statistics) - Method in class org.rocksdb.Options
 
setStatsDumpPeriodSec(int) - Method in class org.rocksdb.DBOptions
 
setStatsDumpPeriodSec(int) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setStatsDumpPeriodSec(int) - Method in interface org.rocksdb.MutableDBOptionsInterface
if not zero, dump rocksdb.stats to LOG every stats_dump_period_sec Default: 600 (10 minutes)
setStatsDumpPeriodSec(int) - Method in class org.rocksdb.Options
 
setStatsHistoryBufferSize(long) - Method in class org.rocksdb.DBOptions
 
setStatsHistoryBufferSize(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setStatsHistoryBufferSize(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
If not zero, periodically take stats snapshots and store in memory, the memory size for stats snapshots is capped at statsHistoryBufferSize Default: 1MB
setStatsHistoryBufferSize(long) - Method in class org.rocksdb.Options
 
setStatsLevel(StatsLevel) - Method in class org.rocksdb.Statistics
Sets the stats level.
setStatsPersistPeriodSec(int) - Method in class org.rocksdb.DBOptions
 
setStatsPersistPeriodSec(int) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setStatsPersistPeriodSec(int) - Method in interface org.rocksdb.MutableDBOptionsInterface
If not zero, dump rocksdb.stats to RocksDB every statsPersistPeriodSec Default: 600
setStatsPersistPeriodSec(int) - Method in class org.rocksdb.Options
 
setStopStyle(CompactionStopStyle) - Method in class org.rocksdb.CompactionOptionsUniversal
The algorithm used to stop picking files into a single compaction run Default: CompactionStopStyle.CompactionStopStyleTotalSize
setStoreIndexInFile(boolean) - Method in class org.rocksdb.PlainTableConfig
If set to true: compute plain table index and bloom filter during file building and store it in file.
setStrategy(int) - Method in class org.rocksdb.CompressionOptions
 
setStrictBytesPerSync(boolean) - Method in class org.rocksdb.DBOptions
 
setStrictBytesPerSync(boolean) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setStrictBytesPerSync(boolean) - Method in interface org.rocksdb.MutableDBOptionsInterface
When true, guarantees WAL files have at most MutableDBOptionsInterface.walBytesPerSync() bytes submitted for writeback at any given time, and SST files have at most MutableDBOptionsInterface.bytesPerSync() bytes pending writeback at any given time.
setStrictBytesPerSync(boolean) - Method in class org.rocksdb.Options
 
setSync(boolean) - Method in class org.rocksdb.BackupableDBOptions
Set synchronous backups.
setSync(boolean) - Method in class org.rocksdb.WriteOptions
If true, the write will be flushed from the operating system buffer cache (by calling WritableFile::Sync()) before the write is considered complete.
setTableCacheNumshardbits(int) - Method in class org.rocksdb.DBOptions
 
setTableCacheNumshardbits(int) - Method in interface org.rocksdb.DBOptionsInterface
Number of shards used for table cache.
setTableCacheNumshardbits(int) - Method in class org.rocksdb.Options
 
setTableFilter(AbstractTableFilter) - Method in class org.rocksdb.ReadOptions
A callback to determine whether relevant keys for this scan exist in a given table based on the table's properties.
setTableFormatConfig(TableFormatConfig) - Method in class org.rocksdb.ColumnFamilyOptions
 
setTableFormatConfig(TableFormatConfig) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Set the config for table format.
setTableFormatConfig(TableFormatConfig) - Method in class org.rocksdb.Options
 
setTailing(boolean) - Method in class org.rocksdb.ReadOptions
Specify to create a tailing iterator -- a special iterator that has a view of the complete database (i.e.
setTargetFileSizeBase(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The target file size for compaction.
setTargetFileSizeBase(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setTargetFileSizeBase(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setTargetFileSizeBase(long) - Method in class org.rocksdb.Options
 
setTargetFileSizeMultiplier(int) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
targetFileSizeMultiplier defines the size ratio between a level-L file and level-(L+1) file.
setTargetFileSizeMultiplier(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
setTargetFileSizeMultiplier(int) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setTargetFileSizeMultiplier(int) - Method in class org.rocksdb.Options
 
setTargetLevel(int) - Method in class org.rocksdb.CompactRangeOptions
If change_level is true and target_level have non-negative value, compacted files will be moved to target_level.
setTargetPathId(int) - Method in class org.rocksdb.CompactRangeOptions
Compaction outputs will be placed in options.db_paths[target_path_id].
setThresholdUseSkiplist(int) - Method in class org.rocksdb.HashLinkedListMemTableConfig
Set maximum number of entries in one bucket.
setTotalOrderSeek(boolean) - Method in class org.rocksdb.ReadOptions
Enable a total order seek regardless of index format (e.g.
setTransactionLockTimeout(long) - Method in class org.rocksdb.TransactionDBOptions
If positive, specifies the default wait timeout in milliseconds when a transaction attempts to lock a key if not specified by TransactionOptions.setLockTimeout(long) If 0, no waiting is done if a lock cannot instantly be acquired.
setTtl(long) - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Non-bottom-level files older than TTL will go through the compaction process.
setTtl(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setTtl(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setTtl(long) - Method in class org.rocksdb.Options
 
setTwoWriteQueues(boolean) - Method in class org.rocksdb.DBOptions
 
setTwoWriteQueues(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If enabled it uses two queues for writes, one for the ones with disable_memtable and one for the ones that also write to memtable.
setTwoWriteQueues(boolean) - Method in class org.rocksdb.Options
 
setUnorderedWrite(boolean) - Method in class org.rocksdb.DBOptions
 
setUnorderedWrite(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Setting DBOptionsInterface.unorderedWrite() to true trades higher write throughput with relaxing the immutability guarantee of snapshots.
setUnorderedWrite(boolean) - Method in class org.rocksdb.Options
 
setUseAdaptiveMutex(boolean) - Method in class org.rocksdb.DBOptions
 
setUseAdaptiveMutex(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Use adaptive mutex, which spins in the user space before resorting to kernel.
setUseAdaptiveMutex(boolean) - Method in class org.rocksdb.Options
 
setUseDeltaEncoding(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Use delta encoding to compress keys in blocks.
setUseDirectBuffer(boolean) - Method in class org.rocksdb.ComparatorOptions
Controls whether a direct byte buffer (i.e.
setUseDirectIoForFlushAndCompaction(boolean) - Method in class org.rocksdb.DBOptions
 
setUseDirectIoForFlushAndCompaction(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Enable the OS to use direct reads and writes in flush and compaction Default: false
setUseDirectIoForFlushAndCompaction(boolean) - Method in class org.rocksdb.Options
 
setUseDirectReads(boolean) - Method in class org.rocksdb.DBOptions
 
setUseDirectReads(boolean) - Method in interface org.rocksdb.DBOptionsInterface
Enable the OS to use direct I/O for reading sst tables.
setUseDirectReads(boolean) - Method in class org.rocksdb.EnvOptions
Enable/Disable direct reads, i.e.
setUseDirectReads(boolean) - Method in class org.rocksdb.Options
 
setUseDirectWrites(boolean) - Method in class org.rocksdb.EnvOptions
Enable/Disable direct writes, i.e.
setUseFsync(boolean) - Method in class org.rocksdb.DBOptions
 
setUseFsync(boolean) - Method in interface org.rocksdb.DBOptionsInterface
If true, then every store to stable storage will issue a fsync.
setUseFsync(boolean) - Method in class org.rocksdb.Options
 
setUseMmapReads(boolean) - Method in class org.rocksdb.EnvOptions
Enable/Disable memory mapped reads.
setUseMmapWrites(boolean) - Method in class org.rocksdb.EnvOptions
Enable/Disable memory mapped Writes.
setValue(T) - Method in class org.rocksdb.Holder
Set the instance reference.
setVerifyChecksums(boolean) - Method in class org.rocksdb.ReadOptions
If true, all data read from underlying storage will be verified against corresponding checksums.
setVerifyCompression(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
Verify that decompressing the compressed block gives back the input.
setWaitForFlush(boolean) - Method in class org.rocksdb.FlushOptions
Set if the flush operation shall block until it terminates.
setWalBytesPerSync(long) - Method in class org.rocksdb.DBOptions
 
setWalBytesPerSync(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setWalBytesPerSync(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
Same as MutableDBOptionsInterface.setBytesPerSync(long) , but applies to WAL files Default: 0, turned off
setWalBytesPerSync(long) - Method in class org.rocksdb.Options
 
setWalDir(String) - Method in class org.rocksdb.DBOptions
 
setWalDir(String) - Method in interface org.rocksdb.DBOptionsInterface
This specifies the absolute dir path for write-ahead logs (WAL).
setWalDir(String) - Method in class org.rocksdb.Options
 
setWalFilter(AbstractWalFilter) - Method in class org.rocksdb.DBOptions
 
setWalFilter(AbstractWalFilter) - Method in interface org.rocksdb.DBOptionsInterface
A filter object supplied to be invoked while processing write-ahead-logs (WALs) during recovery.
setWalFilter(AbstractWalFilter) - Method in class org.rocksdb.Options
 
setWalRecoveryMode(WALRecoveryMode) - Method in class org.rocksdb.DBOptions
 
setWalRecoveryMode(WALRecoveryMode) - Method in interface org.rocksdb.DBOptionsInterface
Recovery mode to control the consistency while replaying WAL Default: WALRecoveryMode.PointInTimeRecovery
setWalRecoveryMode(WALRecoveryMode) - Method in class org.rocksdb.Options
 
setWalSizeLimitMB(long) - Method in class org.rocksdb.DBOptions
 
setWalSizeLimitMB(long) - Method in interface org.rocksdb.DBOptionsInterface
WalTtlSeconds() and walSizeLimitMB() affect how archived logs will be deleted.
setWalSizeLimitMB(long) - Method in class org.rocksdb.Options
 
setWalTtlSeconds(long) - Method in class org.rocksdb.DBOptions
 
setWalTtlSeconds(long) - Method in interface org.rocksdb.DBOptionsInterface
DBOptionsInterface.walTtlSeconds() and DBOptionsInterface.walSizeLimitMB() affect how archived logs will be deleted.
setWalTtlSeconds(long) - Method in class org.rocksdb.Options
 
setWholeKeyFiltering(boolean) - Method in class org.rocksdb.BlockBasedTableConfig
If true, place whole keys in the filter (not just prefixes).
setWindowBits(int) - Method in class org.rocksdb.CompressionOptions
 
setWritableFileMaxBufferSize(long) - Method in class org.rocksdb.DBOptions
 
setWritableFileMaxBufferSize(long) - Method in class org.rocksdb.EnvOptions
setWritableFileMaxBufferSize(long) - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
setWritableFileMaxBufferSize(long) - Method in interface org.rocksdb.MutableDBOptionsInterface
This is the maximum buffer size that is used by WritableFileWriter.
setWritableFileMaxBufferSize(long) - Method in class org.rocksdb.Options
 
setWriteBufferManager(WriteBufferManager) - Method in class org.rocksdb.DBOptions
 
setWriteBufferManager(WriteBufferManager) - Method in interface org.rocksdb.DBOptionsInterface
Use passed WriteBufferManager to control memory usage across multiple column families and/or DB instances.
setWriteBufferManager(WriteBufferManager) - Method in class org.rocksdb.Options
 
setWriteBufferSize(long) - Method in class org.rocksdb.ColumnFamilyOptions
 
setWriteBufferSize(long) - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
setWriteBufferSize(long) - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Amount of data to build up in memory (backed by an unsorted log on disk) before converting to a sorted on-disk file.
setWriteBufferSize(long) - Method in class org.rocksdb.Options
 
setWriteGlobalSeqno(boolean) - Method in class org.rocksdb.IngestExternalFileOptions
Set to true if you would like to write the global_seqno to a given offset in the external SST file for backward compatibility.
setWriteOptions(WriteOptions) - Method in class org.rocksdb.Transaction
Reset the WriteOptions that will be used during Transaction.commit().
setWritePolicy(TxnDBWritePolicy) - Method in class org.rocksdb.TransactionDBOptions
The policy for when to write the data into the DB.
setWriteThreadMaxYieldUsec(long) - Method in class org.rocksdb.DBOptions
 
setWriteThreadMaxYieldUsec(long) - Method in interface org.rocksdb.DBOptionsInterface
The maximum number of microseconds that a write operation will use a yielding spin loop to coordinate with other write threads before blocking on a mutex.
setWriteThreadMaxYieldUsec(long) - Method in class org.rocksdb.Options
 
setWriteThreadSlowYieldUsec(long) - Method in class org.rocksdb.DBOptions
 
setWriteThreadSlowYieldUsec(long) - Method in interface org.rocksdb.DBOptionsInterface
The latency in microseconds after which a std::this_thread::yield call (sched_yield on Linux) is considered to be a signal that other processes or threads would like to use the current core.
setWriteThreadSlowYieldUsec(long) - Method in class org.rocksdb.Options
 
setZStdMaxTrainBytes(int) - Method in class org.rocksdb.CompressionOptions
Maximum size of training data passed to zstd's dictionary trainer.
shareFilesWithChecksum() - Method in class org.rocksdb.BackupableDBOptions
Return of share files with checksum is active.
shareTableFiles() - Method in class org.rocksdb.BackupableDBOptions
Share table files between backups.
shouldContinue() - Method in class org.rocksdb.WriteBatch.Handler
shouldContinue is called by the underlying iterator WriteBatch.iterate(Handler).
shutDown(int) - Method in class org.rocksdb.StatisticsCollector
Shuts down statistics collector.
singleDelete(byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
singleDelete(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.AbstractWriteBatch
 
singleDelete(byte[]) - Method in class org.rocksdb.RocksDB
Remove the database entry for key.
singleDelete(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.RocksDB
Remove the database entry for key.
singleDelete(WriteOptions, byte[]) - Method in class org.rocksdb.RocksDB
Remove the database entry for key.
singleDelete(ColumnFamilyHandle, WriteOptions, byte[]) - Method in class org.rocksdb.RocksDB
Remove the database entry for key.
singleDelete(ColumnFamilyHandle, byte[], boolean) - Method in class org.rocksdb.Transaction
Similar to RocksDB.singleDelete(ColumnFamilyHandle, byte[]), but will also perform conflict checking on the keys be written.
singleDelete(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.Transaction
Similar to Transaction.singleDelete(ColumnFamilyHandle, byte[], boolean) but with assumeTracked = false.
singleDelete(byte[]) - Method in class org.rocksdb.Transaction
Similar to RocksDB.singleDelete(byte[]), but will also perform conflict checking on the keys be written.
singleDelete(ColumnFamilyHandle, byte[][], boolean) - Method in class org.rocksdb.Transaction
Similar to Transaction.singleDelete(ColumnFamilyHandle, byte[]) but allows you to specify the key in several parts that will be concatenated together.
singleDelete(ColumnFamilyHandle, byte[][]) - Method in class org.rocksdb.Transaction
Similar toTransaction.singleDelete(ColumnFamilyHandle, byte[][], boolean) but with assumeTracked = false.
singleDelete(byte[][]) - Method in class org.rocksdb.Transaction
Similar to Transaction.singleDelete(byte[]) but allows you to specify the key in several parts that will be concatenated together.
singleDelete(int, byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
singleDelete(byte[]) - Method in class org.rocksdb.WriteBatch.Handler
 
singleDelete(byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Remove the database entry for key.
singleDelete(ColumnFamilyHandle, byte[]) - Method in interface org.rocksdb.WriteBatchInterface
Remove the database entry for key.
size() - Method in class org.rocksdb.AbstractSlice
Return the length (in bytes) of the data.
size() - Method in class org.rocksdb.BackupInfo
 
size() - Method in class org.rocksdb.ColumnFamilyMetaData
The size of this column family in bytes, which is equal to the sum of the file size of its ColumnFamilyMetaData.levels().
size() - Method in class org.rocksdb.LevelMetaData
The size of this level in bytes, which is equal to the sum of the file size of its LevelMetaData.files().
size - Variable in class org.rocksdb.RocksDB.CountAndSize
 
size() - Method in class org.rocksdb.SstFileMetaData
Get the file size in bytes.
SizeApproximationFlag - Enum in org.rocksdb
Flags for RocksDB.getApproximateSizes(ColumnFamilyHandle, List, SizeApproximationFlag...) that specify whether memtable stats should be included, or file stats approximation or both.
sizeFileBytes() - Method in class org.rocksdb.LogFile
Size of log file on disk in Bytes.
sizeRatio() - Method in class org.rocksdb.CompactionOptionsUniversal
Percentage flexibility while comparing file size.
SizeUnit - Class in org.rocksdb.util
 
SkipListMemTableConfig - Class in org.rocksdb
The config for skip-list memtable representation.
SkipListMemTableConfig() - Constructor for class org.rocksdb.SkipListMemTableConfig
SkipListMemTableConfig constructor
skipStatsUpdateOnDbOpen() - Method in class org.rocksdb.DBOptions
 
skipStatsUpdateOnDbOpen() - Method in interface org.rocksdb.DBOptionsInterface
If true, then DB::Open() will not update the statistics used to optimize compaction decision by loading table properties from many files.
skipStatsUpdateOnDbOpen() - Method in class org.rocksdb.Options
 
Slice - Class in org.rocksdb
Base class for slices which will receive byte[] based access to the underlying data.
Slice(String) - Constructor for class org.rocksdb.Slice
Constructs a slice where the data is taken from a String.
Slice(byte[], int) - Constructor for class org.rocksdb.Slice
Constructs a slice where the data is a copy of the byte array from a specific offset.
Slice(byte[]) - Constructor for class org.rocksdb.Slice
Constructs a slice where the data is a copy of the byte array.
smallestKey() - Method in class org.rocksdb.SstFileMetaData
Get the smallest user defined key in the file.
smallestOutputKeyPrefix() - Method in class org.rocksdb.CompactionJobStats
Get the smallest output key prefix.
smallestSeqno() - Method in class org.rocksdb.SstFileMetaData
Get the smallest sequence number in file.
snapshot() - Method in class org.rocksdb.ReadOptions
Returns the currently assigned Snapshot instance.
Snapshot - Class in org.rocksdb
Snapshot of database
snapshotConsistency() - Method in class org.rocksdb.IngestExternalFileOptions
If set to false, an ingested file keys could appear in existing snapshots that where created before the file was ingested.
snapshotCreated(Snapshot) - Method in class org.rocksdb.AbstractTransactionNotifier
Implement this method to receive notification when a snapshot is requested via Transaction.setSnapshotOnNextOperation().
softPendingCompactionBytesLimit() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
All writes will be slowed down to at least delayed_write_rate if estimated bytes needed to be compaction exceed this threshold.
softPendingCompactionBytesLimit() - Method in class org.rocksdb.ColumnFamilyOptions
 
softPendingCompactionBytesLimit() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
softPendingCompactionBytesLimit() - Method in class org.rocksdb.Options
 
SstFileManager - Class in org.rocksdb
SstFileManager is used to track SST files in the DB and control their deletion rate.
SstFileManager(Env) - Constructor for class org.rocksdb.SstFileManager
Create a new SstFileManager that can be shared among multiple RocksDB instances to track SST file and control there deletion rate.
SstFileManager(Env, Logger) - Constructor for class org.rocksdb.SstFileManager
Create a new SstFileManager that can be shared among multiple RocksDB instances to track SST file and control there deletion rate.
SstFileManager(Env, Logger, long) - Constructor for class org.rocksdb.SstFileManager
Create a new SstFileManager that can be shared among multiple RocksDB instances to track SST file and control there deletion rate.
SstFileManager(Env, Logger, long, double) - Constructor for class org.rocksdb.SstFileManager
Create a new SstFileManager that can be shared among multiple RocksDB instances to track SST file and control there deletion rate.
SstFileManager(Env, Logger, long, double, long) - Constructor for class org.rocksdb.SstFileManager
Create a new SstFileManager that can be shared among multiple RocksDB instances to track SST file and control there deletion rate.
SstFileMetaData - Class in org.rocksdb
The metadata that describes a SST file.
SstFileMetaData(String, String, long, long, long, byte[], byte[], long, boolean, long, long) - Constructor for class org.rocksdb.SstFileMetaData
Called from JNI C++
SstFileReader - Class in org.rocksdb
 
SstFileReader(Options) - Constructor for class org.rocksdb.SstFileReader
 
SstFileReaderIterator - Class in org.rocksdb
An iterator that yields a sequence of key/value pairs from a source.
SstFileReaderIterator(SstFileReader, long) - Constructor for class org.rocksdb.SstFileReaderIterator
 
SstFileWriter - Class in org.rocksdb
SstFileWriter is used to create sst files that can be added to the database later.
SstFileWriter(EnvOptions, Options, AbstractComparator) - Constructor for class org.rocksdb.SstFileWriter
Deprecated.
Use SstFileWriter.SstFileWriter(EnvOptions, Options). Passing an explicit comparator is deprecated in lieu of passing the comparator as part of options. Use the other constructor instead.
SstFileWriter(EnvOptions, Options) - Constructor for class org.rocksdb.SstFileWriter
SstFileWriter Constructor.
start() - Method in class org.rocksdb.StatisticsCollector
 
startSequence() - Method in class org.rocksdb.LogFile
Starting sequence number of writebatch written in this log file.
startsWith(AbstractSlice<?>) - Method in class org.rocksdb.AbstractSlice
Determines whether this slice starts with another slice
startTrace(TraceOptions, AbstractTraceWriter) - Method in class org.rocksdb.RocksDB
Trace DB operations.
StateType - Enum in org.rocksdb
The type used to refer to a thread state.
statistics() - Method in class org.rocksdb.DBOptions
 
statistics() - Method in interface org.rocksdb.DBOptionsInterface
Returns statistics object.
statistics() - Method in class org.rocksdb.Options
 
Statistics - Class in org.rocksdb
Statistics to analyze the performance of a db.
Statistics() - Constructor for class org.rocksdb.Statistics
 
Statistics(Statistics) - Constructor for class org.rocksdb.Statistics
 
Statistics(EnumSet<HistogramType>) - Constructor for class org.rocksdb.Statistics
 
Statistics(EnumSet<HistogramType>, Statistics) - Constructor for class org.rocksdb.Statistics
 
StatisticsCollector - Class in org.rocksdb
Helper class to collect DB statistics periodically at a period specified in constructor.
StatisticsCollector(List<StatsCollectorInput>, int) - Constructor for class org.rocksdb.StatisticsCollector
Constructor for statistics collector.
StatisticsCollectorCallback - Interface in org.rocksdb
Callback interface provided to StatisticsCollector.
stats() - Method in class org.rocksdb.CompactionJobInfo
Get detailed information about this compaction.
StatsCollectorInput - Class in org.rocksdb
Contains all information necessary to collect statistics from one instance of DB statistics.
StatsCollectorInput(Statistics, StatisticsCollectorCallback) - Constructor for class org.rocksdb.StatsCollectorInput
Constructor for StatsCollectorInput.
statsDumpPeriodSec() - Method in class org.rocksdb.DBOptions
 
statsDumpPeriodSec() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
statsDumpPeriodSec() - Method in interface org.rocksdb.MutableDBOptionsInterface
If not zero, dump rocksdb.stats to LOG every stats_dump_period_sec Default: 600 (10 minutes)
statsDumpPeriodSec() - Method in class org.rocksdb.Options
 
statsHistoryBufferSize() - Method in class org.rocksdb.DBOptions
 
statsHistoryBufferSize() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
statsHistoryBufferSize() - Method in interface org.rocksdb.MutableDBOptionsInterface
If not zero, periodically take stats snapshots and store in memory, the memory size for stats snapshots is capped at statsHistoryBufferSize
statsHistoryBufferSize() - Method in class org.rocksdb.Options
 
statsLevel() - Method in class org.rocksdb.Statistics
Gets the current stats level.
StatsLevel - Enum in org.rocksdb
The level of Statistics to report.
statsPersistPeriodSec() - Method in class org.rocksdb.DBOptions
 
statsPersistPeriodSec() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
statsPersistPeriodSec() - Method in interface org.rocksdb.MutableDBOptionsInterface
If not zero, dump rocksdb.stats to RocksDB every statsPersistPeriodSec
statsPersistPeriodSec() - Method in class org.rocksdb.Options
 
status() - Method in class org.rocksdb.AbstractRocksIterator
 
status() - Method in class org.rocksdb.CompactionJobInfo
Get the status indicating whether the compaction was successful or not.
status() - Method in interface org.rocksdb.RocksIteratorInterface
If an error has occurred, return it.
Status - Class in org.rocksdb
Represents the status returned by a function call in RocksDB.
Status(Status.Code, Status.SubCode, String) - Constructor for class org.rocksdb.Status
 
status() - Method in class org.rocksdb.TransactionLogIterator
Throws RocksDBException if something went wrong.
Status.Code - Enum in org.rocksdb
 
Status.SubCode - Enum in org.rocksdb
 
stopStyle() - Method in class org.rocksdb.CompactionOptionsUniversal
The algorithm used to stop picking files into a single compaction run Default: CompactionStopStyle.CompactionStopStyleTotalSize
storeIndexInFile() - Method in class org.rocksdb.PlainTableConfig
Return a boolean value indicating if index shall be stored in a file.
storeOptionsInstance(DBOptionsInterface) - Method in class org.rocksdb.RocksDB
 
strategy() - Method in class org.rocksdb.CompressionOptions
 
strictBytesPerSync() - Method in class org.rocksdb.DBOptions
 
strictBytesPerSync() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
strictBytesPerSync() - Method in interface org.rocksdb.MutableDBOptionsInterface
Return the strict byte limit per sync.
strictBytesPerSync() - Method in class org.rocksdb.Options
 
StringAppendOperator - Class in org.rocksdb
StringAppendOperator is a merge operator that concatenates two strings.
StringAppendOperator() - Constructor for class org.rocksdb.StringAppendOperator
 
StringAppendOperator(char) - Constructor for class org.rocksdb.StringAppendOperator
 
suggestCompactRange(ColumnFamilyHandle) - Method in class org.rocksdb.RocksDB
Suggest the range to compact.
suggestCompactRange() - Method in class org.rocksdb.RocksDB
Suggest the range to compact for the default column family.
sync() - Method in class org.rocksdb.BackupableDBOptions
Are synchronous backups activated.
sync() - Method in class org.rocksdb.WriteOptions
If true, the write will be flushed from the operating system buffer cache (by calling WritableFile::Sync()) before the write is considered complete.
syncWal() - Method in class org.rocksdb.RocksDB
Sync the WAL.

T

tableCacheNumshardbits() - Method in class org.rocksdb.DBOptions
 
tableCacheNumshardbits() - Method in interface org.rocksdb.DBOptionsInterface
Number of shards used for table cache.
tableCacheNumshardbits() - Method in class org.rocksdb.Options
 
tableFactoryName() - Method in class org.rocksdb.ColumnFamilyOptions
 
tableFactoryName() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
 
tableFactoryName() - Method in class org.rocksdb.Options
 
TableFilter - Interface in org.rocksdb
Filter for iterating a table.
tableFormatConfig() - Method in class org.rocksdb.ColumnFamilyOptions
 
tableFormatConfig() - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Get the config for table format.
tableFormatConfig() - Method in class org.rocksdb.Options
 
TableFormatConfig - Class in org.rocksdb
TableFormatConfig is used to config the internal Table format of a RocksDB.
TableFormatConfig() - Constructor for class org.rocksdb.TableFormatConfig
 
tableProperties() - Method in class org.rocksdb.CompactionJobInfo
Get the table properties for the input and output tables.
TableProperties - Class in org.rocksdb
TableProperties contains read-only properties of its associated table.
tailing() - Method in class org.rocksdb.ReadOptions
Specify to create a tailing iterator -- a special iterator that has a view of the complete database (i.e.
targetFileSizeBase() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
The target file size for compaction.
targetFileSizeBase() - Method in class org.rocksdb.ColumnFamilyOptions
 
targetFileSizeBase() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
targetFileSizeBase() - Method in class org.rocksdb.Options
 
targetFileSizeMultiplier() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
targetFileSizeMultiplier defines the size ratio between a level-(L+1) file and level-L file.
targetFileSizeMultiplier() - Method in class org.rocksdb.ColumnFamilyOptions
 
targetFileSizeMultiplier() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
targetFileSizeMultiplier() - Method in class org.rocksdb.Options
 
targetLevel() - Method in class org.rocksdb.CompactRangeOptions
If change_level is true and target_level have non-negative value, compacted files will be moved to target_level.
targetPathId() - Method in class org.rocksdb.CompactRangeOptions
target_path_id for compaction output.
TB - Static variable in class org.rocksdb.util.SizeUnit
 
threadId() - Method in class org.rocksdb.CompactionJobInfo
Get the id of the thread that completed this compaction job.
ThreadStatus - Class in org.rocksdb
 
ThreadType - Enum in org.rocksdb
The type of a thread.
thresholdUseSkiplist() - Method in class org.rocksdb.HashLinkedListMemTableConfig
Returns entries per bucket threshold before LinkedList is replaced by SkipList usage for that bucket.
tickerCallback(TickerType, long) - Method in interface org.rocksdb.StatisticsCollectorCallback
Callback function to get ticker values.
TickerType - Enum in org.rocksdb
The logical mapping of tickers defined in rocksdb::Tickers.
TimedEnv - Class in org.rocksdb
Timed environment.
TimedEnv(Env) - Constructor for class org.rocksdb.TimedEnv
Creates a new environment that measures function call times for filesystem operations, reporting results to variables in PerfContext.
timestamp() - Method in class org.rocksdb.BackupInfo
 
toString() - Method in class org.rocksdb.AbstractMutableOptions
Returns a string representation of MutableOptions which is suitable for consumption by #parse(String).
toString(boolean) - Method in class org.rocksdb.AbstractSlice
Creates a string representation of the data
toString() - Method in class org.rocksdb.AbstractSlice
 
toString() - Method in class org.rocksdb.Statistics
String representation of the statistic object.
totalInputBytes() - Method in class org.rocksdb.CompactionJobStats
Get the size of the compaction input in bytes.
totalInputRawKeyBytes() - Method in class org.rocksdb.CompactionJobStats
Get the sum of the uncompressed input keys in bytes.
totalInputRawValueBytes() - Method in class org.rocksdb.CompactionJobStats
Get the sum of the uncompressed input values in bytes.
totalOrderSeek() - Method in class org.rocksdb.ReadOptions
Returns whether a total seek order will be used
totalOutputBytes() - Method in class org.rocksdb.CompactionJobStats
Get the size of the compaction output in bytes.
TraceOptions - Class in org.rocksdb
TraceOptions() - Constructor for class org.rocksdb.TraceOptions
 
TraceOptions(long) - Constructor for class org.rocksdb.TraceOptions
 
TraceWriter - Interface in org.rocksdb
TraceWriter allows exporting RocksDB traces to any system, one operation at a time.
Transaction - Class in org.rocksdb
Provides BEGIN/COMMIT/ROLLBACK transactions.
Transaction.TransactionState - Enum in org.rocksdb
 
Transaction.WaitingTransactions - Class in org.rocksdb
 
TransactionDB - Class in org.rocksdb
Database with Transaction support
TransactionDB.DeadlockInfo - Class in org.rocksdb
 
TransactionDB.DeadlockPath - Class in org.rocksdb
 
TransactionDB.DeadlockPath(TransactionDB.DeadlockInfo[], boolean) - Constructor for class org.rocksdb.TransactionDB.DeadlockPath
 
TransactionDB.KeyLockInfo - Class in org.rocksdb
 
TransactionDB.KeyLockInfo(String, long[], boolean) - Constructor for class org.rocksdb.TransactionDB.KeyLockInfo
 
TransactionDBOptions - Class in org.rocksdb
 
TransactionDBOptions() - Constructor for class org.rocksdb.TransactionDBOptions
 
TransactionLogIterator - Class in org.rocksdb
A TransactionLogIterator is used to iterate over the transactions in a db.
TransactionLogIterator.BatchResult - Class in org.rocksdb
BatchResult represents a data structure returned by a TransactionLogIterator containing a sequence number and a WriteBatch instance.
TransactionLogIterator.BatchResult(long, long) - Constructor for class org.rocksdb.TransactionLogIterator.BatchResult
Constructor of BatchResult class.
TransactionOptions - Class in org.rocksdb
 
TransactionOptions() - Constructor for class org.rocksdb.TransactionOptions
 
ttl() - Method in interface org.rocksdb.AdvancedMutableColumnFamilyOptionsInterface
Get the TTL for Non-bottom-level files that will go through the compaction process.
ttl() - Method in class org.rocksdb.ColumnFamilyOptions
 
ttl() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
ttl() - Method in class org.rocksdb.Options
 
TtlDB - Class in org.rocksdb
Database with TTL support.
TtlDB(long) - Constructor for class org.rocksdb.TtlDB
twoWriteQueues() - Method in class org.rocksdb.DBOptions
 
twoWriteQueues() - Method in interface org.rocksdb.DBOptionsInterface
Returns true if two write queues are enabled.
twoWriteQueues() - Method in class org.rocksdb.Options
 
TxnDBWritePolicy - Enum in org.rocksdb
The transaction db write policy.
type() - Method in class org.rocksdb.LogFile
Log file can be either alive or archived.

U

UInt64AddOperator - Class in org.rocksdb
Uint64AddOperator is a merge operator that accumlates a long integer value.
UInt64AddOperator() - Constructor for class org.rocksdb.UInt64AddOperator
 
undoGetForUpdate(ColumnFamilyHandle, byte[]) - Method in class org.rocksdb.Transaction
If this key was previously fetched in this transaction using Transaction.getForUpdate(ReadOptions, ColumnFamilyHandle, byte[], boolean)/ Transaction.multiGetForUpdate(ReadOptions, List, byte[][]), calling Transaction.undoGetForUpdate(ColumnFamilyHandle, byte[]) will tell the transaction that it no longer needs to do any conflict checking for this key.
undoGetForUpdate(byte[]) - Method in class org.rocksdb.Transaction
If this key was previously fetched in this transaction using Transaction.getForUpdate(ReadOptions, byte[], boolean)/ Transaction.multiGetForUpdate(ReadOptions, List, byte[][]), calling Transaction.undoGetForUpdate(byte[]) will tell the transaction that it no longer needs to do any conflict checking for this key.
unorderedWrite() - Method in class org.rocksdb.DBOptions
 
unorderedWrite() - Method in interface org.rocksdb.DBOptionsInterface
Returns true if unordered write are enabled.
unorderedWrite() - Method in class org.rocksdb.Options
 
useAdaptiveMutex() - Method in class org.rocksdb.DBOptions
 
useAdaptiveMutex() - Method in interface org.rocksdb.DBOptionsInterface
Use adaptive mutex, which spins in the user space before resorting to kernel.
useAdaptiveMutex() - Method in class org.rocksdb.Options
 
useCappedPrefixExtractor(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
useCappedPrefixExtractor(int) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
Same as fixed length prefix extractor, except that when slice is shorter than the fixed length, it will use the full key.
useCappedPrefixExtractor(int) - Method in class org.rocksdb.Options
 
useDeltaEncoding() - Method in class org.rocksdb.BlockBasedTableConfig
Determine if delta encoding is being used to compress block keys.
useDirectBuffer() - Method in class org.rocksdb.ComparatorOptions
Indicates if a direct byte buffer (i.e.
useDirectIoForFlushAndCompaction() - Method in class org.rocksdb.DBOptions
 
useDirectIoForFlushAndCompaction() - Method in interface org.rocksdb.DBOptionsInterface
Enable the OS to use direct reads and writes in flush and compaction
useDirectIoForFlushAndCompaction() - Method in class org.rocksdb.Options
 
useDirectReads() - Method in class org.rocksdb.DBOptions
 
useDirectReads() - Method in interface org.rocksdb.DBOptionsInterface
Enable the OS to use direct I/O for reading sst tables.
useDirectReads() - Method in class org.rocksdb.EnvOptions
Determine if direct reads are in-use.
useDirectReads() - Method in class org.rocksdb.Options
 
useDirectWrites() - Method in class org.rocksdb.EnvOptions
Determine if direct writes are in-use.
useFixedLengthPrefixExtractor(int) - Method in class org.rocksdb.ColumnFamilyOptions
 
useFixedLengthPrefixExtractor(int) - Method in interface org.rocksdb.ColumnFamilyOptionsInterface
This prefix-extractor uses the first n bytes of a key as its prefix.
useFixedLengthPrefixExtractor(int) - Method in class org.rocksdb.Options
 
useFsync() - Method in class org.rocksdb.DBOptions
 
useFsync() - Method in interface org.rocksdb.DBOptionsInterface
If true, then every store to stable storage will issue a fsync.
useFsync() - Method in class org.rocksdb.Options
 
useMmapReads() - Method in class org.rocksdb.EnvOptions
Determine if memory mapped reads are in-use.
useMmapWrites() - Method in class org.rocksdb.EnvOptions
Determine if memory mapped writes are in-use.
usingDirectBuffers() - Method in class org.rocksdb.AbstractComparator
 

V

value() - Method in class org.rocksdb.RocksIterator
Return the value for the current entry.
value(ByteBuffer) - Method in class org.rocksdb.RocksIterator
Return the value for the current entry.
value() - Method in class org.rocksdb.SstFileReaderIterator
Return the value for the current entry.
value(ByteBuffer) - Method in class org.rocksdb.SstFileReaderIterator
Return the value for the current entry.
valueOf(String) - Static method in enum org.rocksdb.AccessHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.BuiltinComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.ChecksumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.CompactionPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.CompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.CompactionStopStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.CompactionStyle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.CompactRangeOptions.BottommostLevelCompaction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.CompressionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.DataBlockIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.EncodingType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.HistogramType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.InfoLogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.MemoryUsageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.MutableColumnFamilyOptions.CompactionOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.MutableColumnFamilyOptions.MemtableOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.MutableColumnFamilyOptions.MiscOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.MutableDBOptions.DBOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.MutableOptionKey.ValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.OperationStage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.Priority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.RateLimiterMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.ReadTier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.ReusedSynchronisationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.SizeApproximationFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.StateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.StatsLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.Status.Code
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.Status.SubCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.ThreadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.TickerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.Transaction.TransactionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.TxnDBWritePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.WalFileType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.WalProcessingOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.WALRecoveryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.rocksdb.WBWIRocksIterator.WriteType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.rocksdb.AccessHint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.BuiltinComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.ChecksumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.CompactionPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.CompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.CompactionStopStyle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.CompactionStyle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.CompactRangeOptions.BottommostLevelCompaction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.CompressionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.DataBlockIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.EncodingType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.HistogramType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.InfoLogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.MemoryUsageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.MutableColumnFamilyOptions.CompactionOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.MutableColumnFamilyOptions.MemtableOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.MutableColumnFamilyOptions.MiscOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.MutableDBOptions.DBOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.MutableOptionKey.ValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.OperationStage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.Priority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.RateLimiterMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.ReadTier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.ReusedSynchronisationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.SizeApproximationFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.StateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.StatsLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.Status.Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.Status.SubCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.ThreadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.TickerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.Transaction.TransactionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.TxnDBWritePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.WalFileType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.WalProcessingOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.WALRecoveryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.rocksdb.WBWIRocksIterator.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
VARIABLE_LENGTH - Static variable in class org.rocksdb.PlainTableConfig
 
VectorMemTableConfig - Class in org.rocksdb
The config for vector memtable representation.
VectorMemTableConfig() - Constructor for class org.rocksdb.VectorMemTableConfig
VectorMemTableConfig constructor
verifyChecksum() - Method in class org.rocksdb.RocksDB
Verify checksum
verifyChecksum() - Method in class org.rocksdb.SstFileReader
Verify checksum
verifyChecksums() - Method in class org.rocksdb.ReadOptions
If true, all data read from underlying storage will be verified against corresponding checksums.
verifyCompression() - Method in class org.rocksdb.BlockBasedTableConfig
Returns true when compression verification is enabled.

W

waitForFlush() - Method in class org.rocksdb.FlushOptions
Wait for flush to finished.
walBytesPerSync() - Method in class org.rocksdb.DBOptions
 
walBytesPerSync() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
walBytesPerSync() - Method in interface org.rocksdb.MutableDBOptionsInterface
Same as MutableDBOptionsInterface.bytesPerSync() , but applies to WAL files Default: 0, turned off
walBytesPerSync() - Method in class org.rocksdb.Options
 
walDir() - Method in class org.rocksdb.DBOptions
 
walDir() - Method in interface org.rocksdb.DBOptionsInterface
Returns the path to the write-ahead-logs (WAL) directory.
walDir() - Method in class org.rocksdb.Options
 
WalFileType - Enum in org.rocksdb
 
walFilter() - Method in class org.rocksdb.DBOptions
 
walFilter() - Method in interface org.rocksdb.DBOptionsInterface
Get's the filter for processing WALs during recovery.
walFilter() - Method in class org.rocksdb.Options
 
WalFilter - Interface in org.rocksdb
WALFilter allows an application to inspect write-ahead-log (WAL) records or modify their processing on recovery.
WalFilter.LogRecordFoundResult - Class in org.rocksdb
 
WalFilter.LogRecordFoundResult(WalProcessingOption, boolean) - Constructor for class org.rocksdb.WalFilter.LogRecordFoundResult
 
WalProcessingOption - Enum in org.rocksdb
 
walRecoveryMode() - Method in class org.rocksdb.DBOptions
 
walRecoveryMode() - Method in interface org.rocksdb.DBOptionsInterface
Recovery mode to control the consistency while replaying WAL Default: WALRecoveryMode.PointInTimeRecovery
walRecoveryMode() - Method in class org.rocksdb.Options
 
WALRecoveryMode - Enum in org.rocksdb
The WAL Recover Mode
walSizeLimitMB() - Method in class org.rocksdb.DBOptions
 
walSizeLimitMB() - Method in interface org.rocksdb.DBOptionsInterface
DBOptionsInterface.walTtlSeconds() and #walSizeLimitMB() affect how archived logs will be deleted.
walSizeLimitMB() - Method in class org.rocksdb.Options
 
walTtlSeconds() - Method in class org.rocksdb.DBOptions
 
walTtlSeconds() - Method in interface org.rocksdb.DBOptionsInterface
WalTtlSeconds() and walSizeLimitMB() affect how archived logs will be deleted.
walTtlSeconds() - Method in class org.rocksdb.Options
 
WBWIRocksIterator - Class in org.rocksdb
 
WBWIRocksIterator(WriteBatchWithIndex, long) - Constructor for class org.rocksdb.WBWIRocksIterator
 
WBWIRocksIterator.WriteEntry - Class in org.rocksdb
Represents an entry returned by WBWIRocksIterator.entry() It is worth noting that a WriteEntry with the type WBWIRocksIterator.WriteType.DELETE or WBWIRocksIterator.WriteType.LOG will not have a value.
WBWIRocksIterator.WriteEntry(WBWIRocksIterator.WriteType, DirectSlice, DirectSlice) - Constructor for class org.rocksdb.WBWIRocksIterator.WriteEntry
 
WBWIRocksIterator.WriteType - Enum in org.rocksdb
Enumeration of the Write operation that created the record in the Write Batch
wholeKeyFiltering() - Method in class org.rocksdb.BlockBasedTableConfig
Determine if whole keys as opposed to prefixes are placed in the filter.
windowBits() - Method in class org.rocksdb.CompressionOptions
 
writableFileMaxBufferSize() - Method in class org.rocksdb.DBOptions
 
writableFileMaxBufferSize() - Method in class org.rocksdb.EnvOptions
writableFileMaxBufferSize() - Method in class org.rocksdb.MutableDBOptions.MutableDBOptionsBuilder
 
writableFileMaxBufferSize() - Method in interface org.rocksdb.MutableDBOptionsInterface
This is the maximum buffer size that is used by WritableFileWriter.
writableFileMaxBufferSize() - Method in class org.rocksdb.Options
 
write(WriteOptions, WriteBatch) - Method in class org.rocksdb.RocksDB
Apply the specified updates to the database.
write(WriteOptions, WriteBatchWithIndex) - Method in class org.rocksdb.RocksDB
Apply the specified updates to the database.
write(Slice) - Method in interface org.rocksdb.TraceWriter
Write the data.
writeBatch() - Method in class org.rocksdb.TransactionLogIterator.BatchResult
Return contained WriteBatch instance
WriteBatch - Class in org.rocksdb
WriteBatch holds a collection of updates to apply atomically to a DB.
WriteBatch() - Constructor for class org.rocksdb.WriteBatch
Constructs a WriteBatch instance.
WriteBatch(int) - Constructor for class org.rocksdb.WriteBatch
Constructs a WriteBatch instance with a given size.
WriteBatch(byte[]) - Constructor for class org.rocksdb.WriteBatch
Constructs a WriteBatch instance from a serialized representation as returned by WriteBatch.data().
WriteBatch.Handler - Class in org.rocksdb
Handler callback for iterating over the contents of a batch.
WriteBatch.Handler() - Constructor for class org.rocksdb.WriteBatch.Handler
 
WriteBatch.SavePoint - Class in org.rocksdb
A structure for describing the save point in the Write Batch.
WriteBatch.SavePoint(long, long, long) - Constructor for class org.rocksdb.WriteBatch.SavePoint
 
WriteBatchInterface - Interface in org.rocksdb
Defines the interface for a Write Batch which holds a collection of updates to apply atomically to a DB.
WriteBatchWithIndex - Class in org.rocksdb
Similar to WriteBatch but with a binary searchable index built for all the keys inserted.
WriteBatchWithIndex() - Constructor for class org.rocksdb.WriteBatchWithIndex
Creates a WriteBatchWithIndex where no bytes are reserved up-front, bytewise comparison is used for fallback key comparisons, and duplicate keys operations are retained
WriteBatchWithIndex(boolean) - Constructor for class org.rocksdb.WriteBatchWithIndex
Creates a WriteBatchWithIndex where no bytes are reserved up-front, bytewise comparison is used for fallback key comparisons, and duplicate key assignment is determined by the constructor argument
WriteBatchWithIndex(AbstractComparator, int, boolean) - Constructor for class org.rocksdb.WriteBatchWithIndex
Creates a WriteBatchWithIndex
writeBufferManager() - Method in class org.rocksdb.DBOptions
 
writeBufferManager() - Method in interface org.rocksdb.DBOptionsInterface
Reference to WriteBufferManager used by it.
writeBufferManager() - Method in class org.rocksdb.Options
 
WriteBufferManager - Class in org.rocksdb
Java wrapper over native write_buffer_manager class
WriteBufferManager(long, Cache) - Constructor for class org.rocksdb.WriteBufferManager
Construct a new instance of WriteBufferManager.
writeBufferSize() - Method in class org.rocksdb.ColumnFamilyOptions
 
writeBufferSize() - Method in class org.rocksdb.MutableColumnFamilyOptions.MutableColumnFamilyOptionsBuilder
 
writeBufferSize() - Method in interface org.rocksdb.MutableColumnFamilyOptionsInterface
Return size of write buffer size.
writeBufferSize() - Method in class org.rocksdb.Options
 
writeGlobalSeqno() - Method in class org.rocksdb.IngestExternalFileOptions
Returns true write if the global_seqno is written to a given offset in the external SST file for backward compatibility.
WriteOptions - Class in org.rocksdb
Options that control write operations.
WriteOptions() - Constructor for class org.rocksdb.WriteOptions
Construct WriteOptions instance.
WriteOptions(WriteOptions) - Constructor for class org.rocksdb.WriteOptions
Copy constructor for WriteOptions.
writeThreadMaxYieldUsec() - Method in class org.rocksdb.DBOptions
 
writeThreadMaxYieldUsec() - Method in interface org.rocksdb.DBOptionsInterface
The maximum number of microseconds that a write operation will use a yielding spin loop to coordinate with other write threads before blocking on a mutex.
writeThreadMaxYieldUsec() - Method in class org.rocksdb.Options
 
writeThreadSlowYieldUsec() - Method in class org.rocksdb.DBOptions
 
writeThreadSlowYieldUsec() - Method in interface org.rocksdb.DBOptionsInterface
The latency in microseconds after which a std::this_thread::yield call (sched_yield on Linux) is considered to be a signal that other processes or threads would like to use the current core.
writeThreadSlowYieldUsec() - Method in class org.rocksdb.Options
 

Z

zstdMaxTrainBytes() - Method in class org.rocksdb.CompressionOptions
Maximum size of training data passed to zstd's dictionary trainer.
A B C D E F G H I J K L M N O P R S T U V W Z