Releases: facebook/rocksdb
Releases · facebook/rocksdb
RocksDB 6.13.3
6.13.3 (2020-10-14)
Bug Fixes
- Fix a bug that could cause a stalled write to crash with mixed of slowdown and no_slowdown writes (
WriteOptions.no_slowdown=true
).
6.13.2 (2020-10-13)
Bug Fixes
- Fix false positive flush/compaction
Status::Corruption
failure whenparanoid_file_checks == true
and range tombstones were written to the compaction output files.
6.13.1 (2020-10-12)
Bug Fixes
- Since 6.12, memtable lookup should report unrecognized value_type as corruption (#7121).
- Fixed a bug in the following combination of features: indexes with user keys (
format_version >= 3
), indexes are partitioned (index_type == kTwoLevelIndexSearch
), and some index partitions are pinned in memory (BlockBasedTableOptions::pin_l0_filter_and_index_blocks_in_cache
). The bug could cause keys to be truncated when read from the index leading to wrong read results or other unexpected behavior. - Fixed a bug when indexes are partitioned (
index_type == kTwoLevelIndexSearch
), some index partitions are pinned in memory (BlockBasedTableOptions::pin_l0_filter_and_index_blocks_in_cache
), and partitions reads could be mixed between block cache and directly from the file (e.g., withenable_index_compression == 1
andmmap_read == 1
, partitions that were stored uncompressed due to poor compression ratio would be read directly from the file via mmap, while partitions that were stored compressed would be read from block cache). The bug could cause index partitions to be mistakenly considered empty during reads leading to wrong read results.
6.13 (2020-09-24)
Bug fixes
- Fix a performance regression introduced in 6.4 that makes a upper bound check for every Next() even if keys are within a data block that is within the upper bound.
- Fix a possible corruption to the LSM state (overlapping files within a level) when a
CompactRange()
for refitting levels (CompactRangeOptions::change_level == true
) and another manual compaction are executed in parallel. - Sanitize
recycle_log_file_num
to zero when the user attempts to enable it in combination withWALRecoveryMode::kTolerateCorruptedTailRecords
. Previously the two features were allowed together, which compromised the user's configured crash-recovery guarantees. - Fix a bug where a level refitting in CompactRange() might race with an automatic compaction that puts the data to the target level of the refitting. The bug has been there for years.
- Fixed a bug in version 6.12 in which BackupEngine::CreateNewBackup could fail intermittently with non-OK status when backing up a read-write DB configured with a DBOptions::file_checksum_gen_factory.
- Fix useless no-op compactions scheduled upon snapshot release when options.disable-auto-compactions = true.
- Fix a bug when max_write_buffer_size_to_maintain is set, immutable flushed memtable destruction is delayed until the next super version is installed. A memtable is not added to delete list because of its reference hold by super version and super version doesn't switch because of empt delete list. So memory usage keeps on increasing beyond write_buffer_size + max_write_buffer_size_to_maintain.
- Avoid converting MERGES to PUTS when allow_ingest_behind is true.
- Fix compression dictionary sampling together with
SstFileWriter
. Previously, the dictionary would be trained/finalized immediately with zero samples. Now, the wholeSstFileWriter
file is buffered in memory and then sampled. - Fix a bug with
avoid_unnecessary_blocking_io=1
and creating backups (BackupEngine::CreateNewBackup) or checkpoints (Checkpoint::Create). With this setting and WAL enabled, these operations could randomly fail with non-OK status. - Fix a bug in which bottommost compaction continues to advance the underlying InternalIterator to skip tombstones even after shutdown.
New Features
- A new field
std::string requested_checksum_func_name
is added toFileChecksumGenContext
, which enables the checksum factory to create generators for a suite of different functions. - Added a new subcommand,
ldb unsafe_remove_sst_file
, which removes a lost or corrupt SST file from a DB's metadata. This command involves data loss and must not be used on a live DB.
Performance Improvements
- Reduce thread number for multiple DB instances by re-using one global thread for statistics dumping and persisting.
- Reduce write-amp in heavy write bursts in
kCompactionStyleLevel
compaction style withlevel_compaction_dynamic_level_bytes
set. - BackupEngine incremental backups no longer read DB table files that are already saved to a shared part of the backup directory, unless
share_files_with_checksum
is used withkLegacyCrc32cAndFileSize
naming (discouraged).- For
share_files_with_checksum
, we are confident there is no regression (vs. pre-6.12) in detecting DB or backup corruption at backup creation time, mostly because the old design did not leverage this extra checksum computation for detecting inconsistencies at backup creation time. - For
share_table_files
without "checksum" (not recommended), there is a regression in detecting fundamentally unsafe use of the option, greatly mitigated by file size checking (under "Behavior Changes"). Almost no reason to useshare_files_with_checksum=false
should remain. DB::VerifyChecksum
andBackupEngine::VerifyBackup
with checksum checking are still able to catch corruptions thatCreateNewBackup
does not.
- For
Public API Change
- Expose kTypeDeleteWithTimestamp in EntryType and update GetEntryType() accordingly.
- Added file_checksum and file_checksum_func_name to TableFileCreationInfo, which can pass the table file checksum information through the OnTableFileCreated callback during flush and compaction.
- A warning is added to
DB::DeleteFile()
API describing its known problems and deprecation plan. - Add a new stats level, i.e. StatsLevel::kExceptTickers (PR7329) to exclude tickers even if application passes a non-null Statistics object.
- Added a new status code IOStatus::IOFenced() for the Env/FileSystem to indicate that writes from this instance are fenced off. Like any other background error, this error is returned to the user in Put/Merge/Delete/Flush calls and can be checked using Status::IsIOFenced().
Behavior Changes
- File abstraction
FSRandomAccessFile.Prefetch()
default return status is changed fromOK
toNotSupported
. If the user inherited file doesn't implement prefetch, RocksDB will create internal prefetch buffer to improve read performance. - When retryable IO error happens during Flush (manifest write error is excluded) and WAL is disabled, originally it is mapped to kHardError. Now,it is mapped to soft error. So DB will not stall the writes unless the memtable is full. At the same time, when auto resume is triggered to recover the retryable IO error during Flush, SwitchMemtable is not called to avoid generating to many small immutable memtables. If WAL is enabled, no behavior changes.
- When considering whether a table file is already backed up in a shared part of backup directory, BackupEngine would already query the sizes of source (DB) and pre-existing destination (backup) files. BackupEngine now uses these file sizes to detect corruption, as at least one of (a) old backup, (b) backup in progress, or (c) current DB is corrupt if there's a size mismatch.
Others
- Error in prefetching partitioned index blocks will not be swallowed. It will fail the query and return the IOError users.
RocksDB 6.12.7
6.12.7 (2020-10-14)
Other
Fix build issue to enable RocksJava release for ppc64le
RocksDB 6.12.6
6.12.6 (2020-10-13)
Bug Fixes
- Fix false positive flush/compaction
Status::Corruption
failure whenparanoid_file_checks == true
and range tombstones were written to the compaction output files.
6.12.5 (2020-10-12)
Bug Fixes
- Since 6.12, memtable lookup should report unrecognized value_type as corruption (#7121).
- Fixed a bug in the following combination of features: indexes with user keys (
format_version >= 3
), indexes are partitioned (index_type == kTwoLevelIndexSearch
), and some index partitions are pinned in memory (BlockBasedTableOptions::pin_l0_filter_and_index_blocks_in_cache
). The bug could cause keys to be truncated when read from the index leading to wrong read results or other unexpected behavior. - Fixed a bug when indexes are partitioned (
index_type == kTwoLevelIndexSearch
), some index partitions are pinned in memory (BlockBasedTableOptions::pin_l0_filter_and_index_blocks_in_cache
), and partitions reads could be mixed between block cache and directly from the file (e.g., withenable_index_compression == 1
andmmap_read == 1
, partitions that were stored uncompressed due to poor compression ratio would be read directly from the file via mmap, while partitions that were stored compressed would be read from block cache). The bug could cause index partitions to be mistakenly considered empty during reads leading to wrong read results.
6.12.4 (2020-09-18)
Public API Change
- Reworked
BackupableDBOptions::share_files_with_checksum_naming
(new in 6.12) with some minor improvements and to better support those who were extracting files sizes from backup file names.
6.12.3 (2020-09-16)
Bug fixes
- Fixed a bug in size-amp-triggered and periodic-triggered universal compaction, where the compression settings for the first input level were used rather than the compression settings for the output (bottom) level.
6.12.2 (2020-09-14)
Public API Change
- BlobDB now exposes the start of the expiration range of TTL blob files via the
GetLiveFilesMetaData
API.
6.12.1 (2020-08-20)
Bug fixes
- BackupEngine::CreateNewBackup could fail intermittently with non-OK status when backing up a read-write DB configured with a DBOptions::file_checksum_gen_factory. This issue has been worked-around such that CreateNewBackup should succeed, but (until fully fixed) BackupEngine might not see all checksums available in the DB.
6.12 (2020-07-28)
Public API Change
- Encryption file classes now exposed for inheritance in env_encryption.h
- File I/O listener is extended to cover more I/O operations. Now class
EventListener
in listener.h contains new callback functions:OnFileFlushFinish()
,OnFileSyncFinish()
,OnFileRangeSyncFinish()
,OnFileTruncateFinish()
, andOnFileCloseFinish()
. FileOperationInfo
now reportsduration
measured bystd::chrono::steady_clock
andstart_ts
measured bystd::chrono::system_clock
instead of start and finish timestamps measured bysystem_clock
. Note thatsystem_clock
is called beforesteady_clock
in program order at operation starts.DB::GetDbSessionId(std::string& session_id)
is added.session_id
stores a unique identifier that gets reset every time the DB is opened. This DB session ID should be unique among all open DB instances on all hosts, and should be unique among re-openings of the same or other DBs. This identifier is recorded in the LOG file on the line starting with "DB Session ID:".DB::OpenForReadOnly()
now returnsStatus::NotFound
when the specified DB directory does not exist. Previously the error returned depended on the underlyingEnv
. This change is available in all 6.11 releases as well.- A parameter
verify_with_checksum
is added toBackupEngine::VerifyBackup
, which is false by default. If it is ture,BackupEngine::VerifyBackup
verifies checksums and file sizes of backup files. Passfalse
forverify_with_checksum
to maintain the previous behavior and performance ofBackupEngine::VerifyBackup
, by only verifying sizes of backup files.
Behavior Changes
- Best-efforts recovery ignores CURRENT file completely. If CURRENT file is missing during recovery, best-efforts recovery still proceeds with MANIFEST file(s).
- In best-efforts recovery, an error that is not Corruption or IOError::kNotFound or IOError::kPathNotFound will be overwritten silently. Fix this by checking all non-ok cases and return early.
- When
file_checksum_gen_factory
is set toGetFileChecksumGenCrc32cFactory()
, BackupEngine will compare the crc32c checksums of table files computed when creating a backup to the expected checksums stored in the DB manifest, and will failCreateNewBackup()
on mismatch (corruption). If thefile_checksum_gen_factory
is not set or set to any other customized factory, there is no checksum verification to detect if SST files in a DB are corrupt when read, copied, and independently checksummed by BackupEngine. - When a DB sets
stats_dump_period_sec > 0
, either as the initial value for DB open or as a dynamic option change, the first stats dump is staggered in the following X seconds, where X is an integer in[0, stats_dump_period_sec)
. Subsequent stats dumps are still spacedstats_dump_period_sec
seconds apart. - When the paranoid_file_checks option is true, a hash is generated of all keys and values are generated when the SST file is written, and then the values are read back in to validate the file. A corruption is signaled if the two hashes do not match.
Bug fixes
- Compressed block cache was automatically disabled with read-only DBs by mistake. Now it is fixed: compressed block cache will be in effective with read-only DB too.
- Fix a bug of wrong iterator result if another thread finishes an update and a DB flush between two statement.
- Disable file deletion after MANIFEST write/sync failure until db re-open or Resume() so that subsequent re-open will not see MANIFEST referencing deleted SSTs.
- Fix a bug when index_type == kTwoLevelIndexSearch in PartitionedIndexBuilder to update FlushPolicy to point to internal key partitioner when it changes from user-key mode to internal-key mode in index partition.
- Make compaction report InternalKey corruption while iterating over the input.
- Fix a bug which may cause MultiGet to be slow because it may read more data than requested, but this won't affect correctness. The bug was introduced in 6.10 release.
- Fail recovery and report once hitting a physical log record checksum mismatch, while reading MANIFEST. RocksDB should not continue processing the MANIFEST any further.
New Features
- DB identity (
db_id
) and DB session identity (db_session_id
) are added to table properties and stored in SST files. SST files generated from SstFileWriter and Repairer have DB identity “SST Writer” and “DB Repairer”, respectively. Their DB session IDs are generated in the same way asDB::GetDbSessionId
. The session ID for SstFileWriter (resp., Repairer) resets every timeSstFileWriter::Open
(resp.,Repairer::Run
) is called. - Added experimental option BlockBasedTableOptions::optimize_filters_for_memory for reducing allocated memory size of Bloom filters (~10% savings with Jemalloc) while preserving the same general accuracy. To have an effect, the option requires format_version=5 and malloc_usable_size. Enabling this option is forward and backward compatible with existing format_version=5.
BackupableDBOptions::share_files_with_checksum_naming
is added with new default behavior for naming backup files withshare_files_with_checksum
, to address performance and backup integrity issues. See API comments for details.- Added auto resume function to automatically recover the DB from background Retryable IO Error. When retryable IOError happens during flush and WAL write, the error is mapped to Hard Error and DB will be in read mode. When retryable IO Error happens during compaction, the error will be mapped to Soft Error. DB is still in write/read mode. Autoresume function will create a thread for a DB to call DB->ResumeImpl() to try the recover for Retryable IO Error during flush and WAL write. Compaction will be rescheduled by itself if retryable IO Error happens. Auto resume may also cause other Retryable IO Error during the recovery, so the recovery will fail. Retry the auto resume may solve the issue, so we use max_bgerror_resume_count to decide how many resume cycles will be tried in total. If it is <=0, auto resume retryable IO Error is disabled. Default is INT_MAX, which will lead to a infinit auto resume. bgerror_resume_retry_interval decides the time interval between two auto resumes.
- Option
max_subcompactions
can be set dynamically using DB::SetDBOptions(). - Added experimental ColumnFamilyOptions::sst_partitioner_factory to define determine the partitioning of sst files. This helps compaction to split the files on interesting boundaries (key prefixes) to make propagation of sst files less write amplifying (covering the whole key space).
Performance Improvements
- Eliminate key copies for internal comparisons while accessing ingested block-based tables.
- Reduce key comparisons during random access in all block-based tables.
- BackupEngine avoids unnecessary repeated checksum computation for backing up a table file to the
shared_checksum
directory when usingshare_files_with_checksum_naming = kUseDbSessionId
(new default), except on SST files generated before this version of RocksDB, which fall back on usingkLegacyCrc32cAndFileSize
.
RocksDB 6.11.6
6.11.6 (10/12/2020)
Bug Fixes
- Fixed a bug in the following combination of features: indexes with user keys (
format_version >= 3
), indexes are partitioned (index_type == kTwoLevelIndexSearch
), and some index partitions are pinned in memory (BlockBasedTableOptions::pin_l0_filter_and_index_blocks_in_cache
). The bug could cause keys to be truncated when read from the index leading to wrong read results or other unexpected behavior. - Fixed a bug when indexes are partitioned (
index_type == kTwoLevelIndexSearch
), some index partitions are pinned in memory (BlockBasedTableOptions::pin_l0_filter_and_index_blocks_in_cache
), and partitions reads could be mixed between block cache and directly from the file (e.g., withenable_index_compression == 1
andmmap_read == 1
, partitions that were stored uncompressed due to poor compression ratio would be read directly from the file via mmap, while partitions that were stored compressed would be read from block cache). The bug could cause index partitions to be mistakenly considered empty during reads leading to wrong read results.
6.11.5 (7/23/2020)
Bug Fixes
- Memtable lookup should report unrecognized value_type as corruption (#7121).
RocksDB 6.11.4
6.11.4 (2020-07-15)
Bug Fixes
- Make compaction report InternalKey corruption while iterating over the input.
6.11.3 (2020-07-09)
Bug Fixes
- Fix a bug when index_type == kTwoLevelIndexSearch in PartitionedIndexBuilder to update FlushPolicy to point to internal key partitioner when it changes from user-key mode to internal-key mode in index partition.
- Disable file deletion after MANIFEST write/sync failure until db re-open or Resume() so that subsequent re-open will not see MANIFEST referencing deleted SSTs.
6.11.1 (2020-06-23)
Bug Fixes
- Best-efforts recovery ignores CURRENT file completely. If CURRENT file is missing during recovery, best-efforts recovery still proceeds with MANIFEST file(s).
- In best-efforts recovery, an error that is not Corruption or IOError::kNotFound or IOError::kPathNotFound will be overwritten silently. Fix this by checking all non-ok cases and return early.
- Compressed block cache was automatically disabled with read-only DBs by mistake. Now it is fixed: compressed block cache will be in effective with read-only DB too.
- Fail recovery and report once hitting a physical log record checksum mismatch, while reading MANIFEST. RocksDB should not continue processing the MANIFEST any further.
- Fix a bug of wrong iterator result if another thread finishes an update and a DB flush between two statement.
Public API Change
DB::OpenForReadOnly()
now returnsStatus::NotFound
when the specified DB directory does not exist. Previously the error returned depended on the underlyingEnv
.
6.11 (2020-06-12)
Bug Fixes
- Fix consistency checking error swallowing in some cases when options.force_consistency_checks = true.
- Fix possible false NotFound status from batched MultiGet using index type kHashSearch.
- Fix corruption caused by enabling delete triggered compaction (NewCompactOnDeletionCollectorFactory) in universal compaction mode, along with parallel compactions. The bug can result in two parallel compactions picking the same input files, resulting in the DB resurrecting older and deleted versions of some keys.
- Fix a use-after-free bug in best-efforts recovery. column_family_memtables_ needs to point to valid ColumnFamilySet.
- Let best-efforts recovery ignore corrupted files during table loading.
- Fix corrupt key read from ingested file when iterator direction switches from reverse to forward at a key that is a prefix of another key in the same file. It is only possible in files with a non-zero global seqno.
- Fix abnormally large estimate from GetApproximateSizes when a range starts near the end of one SST file and near the beginning of another. Now GetApproximateSizes consistently and fairly includes the size of SST metadata in addition to data blocks, attributing metadata proportionally among the data blocks based on their size.
- Fix potential file descriptor leakage in PosixEnv's IsDirectory() and NewRandomAccessFile().
- Fix false negative from the VerifyChecksum() API when there is a checksum mismatch in an index partition block in a BlockBasedTable format table file (index_type is kTwoLevelIndexSearch).
- Fix sst_dump to return non-zero exit code if the specified file is not a recognized SST file or fails requested checks.
- Fix incorrect results from batched MultiGet for duplicate keys, when the duplicate key matches the largest key of an SST file and the value type for the key in the file is a merge value.
Public API Change
- Flush(..., column_family) may return Status::ColumnFamilyDropped() instead of Status::InvalidArgument() if column_family is dropped while processing the flush request.
- BlobDB now explicitly disallows using the default column family's storage directories as blob directory.
- DeleteRange now returns
Status::InvalidArgument
if the range's end key comes before its start key according to the user comparator. Previously the behavior was undefined. - ldb now uses options.force_consistency_checks = true by default and "--disable_consistency_checks" is added to disable it.
- DB::OpenForReadOnly no longer creates files or directories if the named DB does not exist, unless create_if_missing is set to true.
- The consistency checks that validate LSM state changes (table file additions/deletions during flushes and compactions) are now stricter, more efficient, and no longer optional, i.e. they are performed even if
force_consistency_checks
isfalse
. - Disable delete triggered compaction (NewCompactOnDeletionCollectorFactory) in universal compaction mode and num_levels = 1 in order to avoid a corruption bug.
pin_l0_filter_and_index_blocks_in_cache
no longer applies to L0 files larger than1.5 * write_buffer_size
to give more predictable memory usage. Such L0 files may exist due to intra-L0 compaction, external file ingestion, or user dynamically changingwrite_buffer_size
(note, however, that files that are already pinned will continue being pinned, even after such a dynamic change).- In point-in-time wal recovery mode, fail database recovery in case of IOError while reading the WAL to avoid data loss.
New Features
- sst_dump to add a new --readahead_size argument. Users can specify read size when scanning the data. Sst_dump also tries to prefetch tail part of the SST files so usually some number of I/Os are saved there too.
- Generate file checksum in SstFileWriter if Options.file_checksum_gen_factory is set. The checksum and checksum function name are stored in ExternalSstFileInfo after the sst file write is finished.
- Add a value_size_soft_limit in read options which limits the cumulative value size of keys read in batches in MultiGet. Once the cumulative value size of found keys exceeds read_options.value_size_soft_limit, all the remaining keys are returned with status Abort without further finding their values. By default the value_size_soft_limit is std::numeric_limits<uint64_t>::max().
- Enable SST file ingestion with file checksum information when calling IngestExternalFiles(const std::vector& args). Added files_checksums and files_checksum_func_names to IngestExternalFileArg such that user can ingest the sst files with their file checksum information. Added verify_file_checksum to IngestExternalFileOptions (default is True). To be backward compatible, if DB does not enable file checksum or user does not provide checksum information (vectors of files_checksums and files_checksum_func_names are both empty), verification of file checksum is always sucessful. If DB enables file checksum, DB will always generate the checksum for each ingested SST file during Prepare stage of ingestion and store the checksum in Manifest, unless verify_file_checksum is False and checksum information is provided by the application. In this case, we only verify the checksum function name and directly store the ingested checksum in Manifest. If verify_file_checksum is set to True, DB will verify the ingested checksum and function name with the genrated ones. Any mismatch will fail the ingestion. Note that, if IngestExternalFileOptions::write_global_seqno is True, the seqno will be changed in the ingested file. Therefore, the checksum of the file will be changed. In this case, a new checksum will be generated after the seqno is updated and be stored in the Manifest.
Performance Improvements
- Eliminate redundant key comparisons during random access in block-based tables.
RocksDB 6.10.2
6.10.2 (2020-06-05)
Bug fix
- Fix false negative from the VerifyChecksum() API when there is a checksum mismatch in an index partition block in a BlockBasedTable format table file (index_type is kTwoLevelIndexSearch).
RocksDB 6.10.1
6.10.1 (2020-05-27)
Bug fix
- Remove "u''" in TARGETS file.
- Fix db_stress_lib target in buck.
6.10 (2020-05-02)
Behavior Changes
- Disable delete triggered compaction (NewCompactOnDeletionCollectorFactory) in universal compaction mode and num_levels = 1 in order to avoid a corruption bug.
Bug Fixes
- Fix wrong result being read from ingested file. May happen when a key in the file happen to be prefix of another key also in the file. The issue can further cause more data corruption. The issue exists with rocksdb >= 5.0.0 since DB::IngestExternalFile() was introduced.
- Finish implementation of BlockBasedTableOptions::IndexType::kBinarySearchWithFirstKey. It's now ready for use. Significantly reduces read amplification in some setups, especially for iterator seeks.
- Fix a bug by updating CURRENT file so that it points to the correct MANIFEST file after best-efforts recovery.
- Fixed a bug where ColumnFamilyHandle objects were not cleaned up in case an error happened during BlobDB's open after the base DB had been opened.
- Fix a potential undefined behavior caused by trying to dereference nullable pointer (timestamp argument) in DB::MultiGet.
- Fix a bug caused by not including user timestamp in MultiGet LookupKey construction. This can lead to wrong query result since the trailing bytes of a user key, if not shorter than timestamp, will be mistaken for user timestamp.
- Fix a bug caused by using wrong compare function when sorting the input keys of MultiGet with timestamps.
Upgraded version of bzip library (1.0.6 -> 1.0.8) used with RocksJava to address potential vulnerabilities if an attacker can manipulate compressed data saved and loaded by RocksDB (not normal). See issue #6703. - Fix consistency checking error swallowing in some cases when options.force_consistency_checks = true.
- Fix possible false NotFound status from batched MultiGet using index type kHashSearch.
- Fix corruption caused by enabling delete triggered compaction (NewCompactOnDeletionCollectorFactory) in universal compaction mode, along with parallel compactions. The bug can result in two parallel compactions picking the same input files, resulting in the DB resurrecting older and deleted versions of some keys.
- Fix a use-after-free bug in best-efforts recovery. column_family_memtables_ needs to point to valid ColumnFamilySet.
- Let best-efforts recovery ignore corrupted files during table loading.
- Fix a bug when making options.bottommost_compression, options.compression_opts and options.bottommost_compression_opts dynamically changeable: the modified values are not written to option files or returned back to users when being queried.
- Fix a bug where index key comparisons were unaccounted in PerfContext::user_key_comparison_count for lookups in files written with format_version >= 3.
- Fix many bloom.filter statistics not being updated in batch MultiGet.
Public API Change
- Add a ConfigOptions argument to the APIs dealing with converting options to and from strings and files. The ConfigOptions is meant to replace some of the options (such as input_strings_escaped and ignore_unknown_options) and allow for more parameters to be passed in the future without changing the function signature.
- Add NewFileChecksumGenCrc32cFactory to the file checksum public API, such that the builtin Crc32c based file checksum generator factory can be used by applications.
- Add IsDirectory to Env and FS to indicate if a path is a directory.
ldb now uses options.force_consistency_checks = true by default and "--disable_consistency_checks" is added to disable it. - Add ReadOptions::deadline to allow users to specify a deadline for MultiGet requests
New Features
- Added support for pipelined & parallel compression optimization for BlockBasedTableBuilder. This optimization makes block building, block compression and block appending a pipeline, and uses multiple threads to accelerate block compression. Users can set CompressionOptions::parallel_threads greater than 1 to enable compression parallelism. This feature is experimental for now.
- Provide an allocator for memkind to be used with block cache. This is to work with memory technologies (Intel DCPMM is one such technology currently available) that require different libraries for allocation and management (such as PMDK and memkind). The high capacities available make it possible to provision large caches (up to several TBs in size) beyond what is achievable with DRAM.
- Option max_background_flushes can be set dynamically using DB::SetDBOptions().
- Added functionality in sst_dump tool to check the compressed file size for different compression levels and print the time spent on compressing files with each compression type. Added arguments --compression_level_from and --compression_level_to to report size of all compression levels and one compression_type must be specified with it so that it will report compressed sizes of one compression type with different levels.
- Added statistics for redundant insertions into block cache: rocksdb.block.cache.*add.redundant. (There is currently no coordination to ensure that only one thread loads a table block when many threads are trying to access that same table block.)
Performance Improvements
- Improve performance of batch MultiGet with partitioned filters, by sharing block cache lookups to applicable filter blocks.
- Reduced memory copies when fetching and uncompressing compressed blocks from sst files.
RocksDB v6.8.1
6.8.1 (2020-03-30)
Behavior changes
- Since RocksDB 6.8.0, ttl-based FIFO compaction can drop a file whose oldest key becomes older than options.ttl while others have not. This fix reverts this and makes ttl-based FIFO compaction use the file's flush time as the criterion. This fix also requires that max_open_files = -1 and compaction_options_fifo.allow_compaction = false to function properly.
6.8.0 (2020-02-24)
Java API Changes
- Major breaking changes to Java comparators, toward standardizing on ByteBuffer for performant, locale-neutral operations on keys (#6252).
- Added overloads of common API methods using direct ByteBuffers for keys and values (#2283).
Bug Fixes
- Fix incorrect results while block-based table uses kHashSearch, together with Prev()/SeekForPrev().
- Fix a bug that prevents opening a DB after two consecutive crash with TransactionDB, where the first crash recovers from a corrupted WAL with kPointInTimeRecovery but the second cannot.
- Fixed issue #6316 that can cause a corruption of the MANIFEST file in the middle when writing to it fails due to no disk space.
- Add DBOptions::skip_checking_sst_file_sizes_on_db_open. It disables potentially expensive checking of all sst file sizes in DB::Open().
- BlobDB now ignores trivially moved files when updating the mapping between blob files and SSTs. This should mitigate issue #6338 where out of order flush/compaction notifications could trigger an assertion with the earlier code.
- Batched MultiGet() ignores IO errors while reading data blocks, causing it to potentially continue looking for a key and returning stale results.
WriteBatchWithIndex::DeleteRange
returnsStatus::NotSupported
. Previously it returned success even though reads on the batch did not account for range tombstones. The corresponding language bindings now cannot be used. In C, that includesrocksdb_writebatch_wi_delete_range
,rocksdb_writebatch_wi_delete_range_cf
,rocksdb_writebatch_wi_delete_rangev
, androcksdb_writebatch_wi_delete_rangev_cf
. In Java, that includesWriteBatchWithIndex::deleteRange
.- Assign new MANIFEST file number when caller tries to create a new MANIFEST by calling LogAndApply(..., new_descriptor_log=true). This bug can cause MANIFEST being overwritten during recovery if options.write_dbid_to_manifest = true and there are WAL file(s).
Performance Improvements
- Perfom readahead when reading from option files. Inside DB, options.log_readahead_size will be used as the readahead size. In other cases, a default 512KB is used.
Public API Change
- The BlobDB garbage collector now emits the statistics
BLOB_DB_GC_NUM_FILES
(number of blob files obsoleted during GC),BLOB_DB_GC_NUM_NEW_FILES
(number of new blob files generated during GC),BLOB_DB_GC_FAILURES
(number of failed GC passes),BLOB_DB_GC_NUM_KEYS_RELOCATED
(number of blobs relocated during GC), andBLOB_DB_GC_BYTES_RELOCATED
(total size of blobs relocated during GC). On the other hand, the following statistics, which are not relevant for the new GC implementation, are now deprecated:BLOB_DB_GC_NUM_KEYS_OVERWRITTEN
,BLOB_DB_GC_NUM_KEYS_EXPIRED
,BLOB_DB_GC_BYTES_OVERWRITTEN
,BLOB_DB_GC_BYTES_EXPIRED
, andBLOB_DB_GC_MICROS
. - Disable recycle_log_file_num when an inconsistent recovery modes are requested: kPointInTimeRecovery and kAbsoluteConsistency
New Features
- Added the checksum for each SST file generated by Flush or Compaction. Added sst_file_checksum_func to Options such that user can plugin their own SST file checksum function via override the FileChecksumFunc class. If user does not set the sst_file_checksum_func, SST file checksum calculation will not be enabled. The checksum information inlcuding uint32_t checksum value and a checksum function name (string). The checksum information is stored in FileMetadata in version store and also logged to MANIFEST. A new tool is added to LDB such that user can dump out a list of file checksum information from MANIFEST (stored in an unordered_map).
db_bench
now supportsvalue_size_distribution_type
,value_size_min
,value_size_max
options for generating random variable sized value. Addedblob_db_compression_type
option for BlobDB to enable blob compression.- Replace RocksDB namespace "rocksdb" with flag "ROCKSDB_NAMESPACE" which if is not defined, defined as "rocksdb" in header file rocksdb_namespace.h.
RocksDB v6.7.3
6.7.3 (2020-03-18)
Bug Fixes
- Fix a data race that might cause crash when calling DB::GetCreationTimeOfOldestFile() by a small chance. The bug was introduced in 6.6 Release.
6.7.2 (2020-02-24)
Bug Fixes
- Fixed a bug of IO Uring partial result handling introduced in 6.7.0.
6.7.1 (2020-02-13)
Bug Fixes
- Fixed issue #6316 that can cause a corruption of the MANIFEST file in the middle when writing to it fails due to no disk space.
- Batched MultiGet() ignores IO errors while reading data blocks, causing it to potentially continue looking for a key and returning stale results.
6.7.0 (2020-01-21)
Public API Change
- Added a rocksdb::FileSystem class in include/rocksdb/file_system.h to encapsulate file creation/read/write operations, and an option DBOptions::file_system to allow a user to pass in an instance of rocksdb::FileSystem. If its a non-null value, this will take precendence over DBOptions::env for file operations. A new API rocksdb::FileSystem::Default() returns a platform default object. The DBOptions::env option and Env::Default() API will continue to be used for threading and other OS related functions, and where DBOptions::file_system is not specified, for file operations. For storage developers who are accustomed to rocksdb::Env, the interface in rocksdb::FileSystem is new and will probably undergo some changes as more storage systems are ported to it from rocksdb::Env. As of now, no env other than Posix has been ported to the new interface.
- A new rocksdb::NewSstFileManager() API that allows the caller to pass in separate Env and FileSystem objects.
- Changed Java API for RocksDB.keyMayExist functions to use Holder<byte[]> instead of StringBuilder, so that retrieved values need not decode to Strings.
- A new
OptimisticTransactionDBOptions
Option that allows users to configure occ validation policy. The default policy changes from kValidateSerial to kValidateParallel to reduce mutex contention.
Bug Fixes
- Fix a bug that can cause unnecessary bg thread to be scheduled(#6104).
- Fix crash caused by concurrent CF iterations and drops(#6147).
- Fix a race condition for cfd->log_number_ between manifest switch and memtable switch (PR 6249) when number of column families is greater than 1.
- Fix a bug on fractional cascading index when multiple files at the same level contain the same smallest user key, and those user keys are for merge operands. In this case, Get() the exact key may miss some merge operands.
- Delcare kHashSearch index type feature-incompatible with index_block_restart_interval larger than 1.
- Fixed an issue where the thread pools were not resized upon setting
max_background_jobs
dynamically through theSetDBOptions
interface. - Fix a bug that can cause write threads to hang when a slowdown/stall happens and there is a mix of writers with WriteOptions::no_slowdown set/unset.
- Fixed an issue where an incorrect "number of input records" value was used to compute the "records dropped" statistics for compactions.
New Features
- It is now possible to enable periodic compactions for the base DB when using BlobDB.
- BlobDB now garbage collects non-TTL blobs when
enable_garbage_collection
is set totrue
inBlobDBOptions
. Garbage collection is performed during compaction: any valid blobs located in the oldest N files (where N is the number of non-TTL blob files multiplied by the value ofBlobDBOptions::garbage_collection_cutoff
) encountered during compaction get relocated to new blob files, and old blob files are dropped once they are no longer needed. Note: we recommend enabling periodic compactions for the base DB when using this feature to deal with the case when some old blob files are kept alive by SSTs that otherwise do not get picked for compaction. db_bench
now supports thegarbage_collection_cutoff
option for BlobDB.- MultiGet() can use IO Uring to parallelize read from the same SST file. This featuer is by default disabled. It can be enabled with environment variable ROCKSDB_USE_IO_URING.
RocksDB v6.6.4
Rocksdb Change Log
6.6.4 (2020-01-31)
Bug Fixes
- Fixed issue #6316 that can cause a corruption of the MANIFEST file in the middle when writing to it fails due to no disk space.