Enum rocksdb::statistics::Ticker

source ·
#[repr(u32)]
pub enum Ticker {
Show 215 variants BlockCacheMiss = 0, BlockCacheHit = 1, BlockCacheAdd = 2, BlockCacheAddFailures = 3, BlockCacheIndexMiss = 4, BlockCacheIndexHit = 5, BlockCacheIndexAdd = 6, BlockCacheIndexBytesInsert = 7, BlockCacheFilterMiss = 8, BlockCacheFilterHit = 9, BlockCacheFilterAdd = 10, BlockCacheFilterBytesInsert = 11, BlockCacheDataMiss = 12, BlockCacheDataHit = 13, BlockCacheDataAdd = 14, BlockCacheDataBytesInsert = 15, BlockCacheBytesRead = 16, BlockCacheBytesWrite = 17, BloomFilterUseful = 18, BloomFilterFullPositive = 19, BloomFilterFullTruePositive = 20, PersistentCacheHit = 21, PersistentCacheMiss = 22, SimBlockCacheHit = 23, SimBlockCacheMiss = 24, MemtableHit = 25, MemtableMiss = 26, GetHitL0 = 27, GetHitL1 = 28, GetHitL2AndUp = 29, CompactionKeyDropNewerEntry = 30, CompactionKeyDropObsolete = 31, CompactionKeyDropRangeDel = 32, CompactionKeyDropUser = 33, CompactionRangeDelDropObsolete = 34, CompactionOptimizedDelDropObsolete = 35, CompactionCancelled = 36, NumberKeysWritten = 37, NumberKeysRead = 38, NumberKeysUpdated = 39, BytesWritten = 40, BytesRead = 41, NumberDbSeek = 42, NumberDbNext = 43, NumberDbPrev = 44, NumberDbSeekFound = 45, NumberDbNextFound = 46, NumberDbPrevFound = 47, IterBytesRead = 48, NoFileOpens = 49, NoFileErrors = 50, StallMicros = 51, DbMutexWaitMicros = 52, NumberMultigetCalls = 53, NumberMultigetKeysRead = 54, NumberMultigetBytesRead = 55, NumberMergeFailures = 56, BloomFilterPrefixChecked = 57, BloomFilterPrefixUseful = 58, BloomFilterPrefixTruePositive = 59, NumberOfReseeksInIteration = 60, GetUpdatesSinceCalls = 61, WalFileSynced = 62, WalFileBytes = 63, WriteDoneBySelf = 64, WriteDoneByOther = 65, WriteWithWal = 66, CompactReadBytes = 67, CompactWriteBytes = 68, FlushWriteBytes = 69, CompactReadBytesMarked = 70, CompactReadBytesPeriodic = 71, CompactReadBytesTtl = 72, CompactWriteBytesMarked = 73, CompactWriteBytesPeriodic = 74, CompactWriteBytesTtl = 75, NumberDirectLoadTableProperties = 76, NumberSuperversionAcquires = 77, NumberSuperversionReleases = 78, NumberSuperversionCleanups = 79, NumberBlockCompressed = 80, NumberBlockDecompressed = 81, NumberBlockNotCompressed = 82, MergeOperationTotalTime = 83, FilterOperationTotalTime = 84, CompactionCpuTotalTime = 85, RowCacheHit = 86, RowCacheMiss = 87, ReadAmpEstimateUsefulBytes = 88, ReadAmpTotalReadBytes = 89, NumberRateLimiterDrains = 90, NumberIterSkip = 91, BlobDbNumPut = 92, BlobDbNumWrite = 93, BlobDbNumGet = 94, BlobDbNumMultiget = 95, BlobDbNumSeek = 96, BlobDbNumNext = 97, BlobDbNumPrev = 98, BlobDbNumKeysWritten = 99, BlobDbNumKeysRead = 100, BlobDbBytesWritten = 101, BlobDbBytesRead = 102, BlobDbWriteInlined = 103, BlobDbWriteInlinedTtl = 104, BlobDbWriteBlob = 105, BlobDbWriteBlobTtl = 106, BlobDbBlobFileBytesWritten = 107, BlobDbBlobFileBytesRead = 108, BlobDbBlobFileSynced = 109, BlobDbBlobIndexExpiredCount = 110, BlobDbBlobIndexExpiredSize = 111, BlobDbBlobIndexEvictedCount = 112, BlobDbBlobIndexEvictedSize = 113, BlobDbGcNumFiles = 114, BlobDbGcNumNewFiles = 115, BlobDbGcFailures = 116, BlobDbGcNumKeysRelocated = 117, BlobDbGcBytesRelocated = 118, BlobDbFifoNumFilesEvicted = 119, BlobDbFifoNumKeysEvicted = 120, BlobDbFifoBytesEvicted = 121, TxnPrepareMutexOverhead = 122, TxnOldCommitMapMutexOverhead = 123, TxnDuplicateKeyOverhead = 124, TxnSnapshotMutexOverhead = 125, TxnGetTryAgain = 126, NumberMultigetKeysFound = 127, NoIteratorCreated = 128, NoIteratorDeleted = 129, BlockCacheCompressionDictMiss = 130, BlockCacheCompressionDictHit = 131, BlockCacheCompressionDictAdd = 132, BlockCacheCompressionDictBytesInsert = 133, BlockCacheAddRedundant = 134, BlockCacheIndexAddRedundant = 135, BlockCacheFilterAddRedundant = 136, BlockCacheDataAddRedundant = 137, BlockCacheCompressionDictAddRedundant = 138, FilesMarkedTrash = 139, FilesDeletedFromTrashQueue = 140, FilesDeletedImmediately = 141, ErrorHandlerBgErrorCount = 142, ErrorHandlerBgErrorCountMisspelled = 143, ErrorHandlerBgIoErrorCount = 144, ErrorHandlerBgIoErrorCountMisspelled = 145, ErrorHandlerBgRetryableIoErrorCount = 146, ErrorHandlerBgRetryableIoErrorCountMisspelled = 147, ErrorHandlerAutoResumeCount = 148, ErrorHandlerAutoResumeRetryTotalCount = 149, ErrorHandlerAutoResumeSuccessCount = 150, MemtablePayloadBytesAtFlush = 151, MemtableGarbageBytesAtFlush = 152, SecondaryCacheHits = 153, VerifyChecksumReadBytes = 154, BackupReadBytes = 155, BackupWriteBytes = 156, RemoteCompactReadBytes = 157, RemoteCompactWriteBytes = 158, HotFileReadBytes = 159, WarmFileReadBytes = 160, ColdFileReadBytes = 161, HotFileReadCount = 162, WarmFileReadCount = 163, ColdFileReadCount = 164, LastLevelReadBytes = 165, LastLevelReadCount = 166, NonLastLevelReadBytes = 167, NonLastLevelReadCount = 168, LastLevelSeekFiltered = 169, LastLevelSeekFilterMatch = 170, LastLevelSeekData = 171, LastLevelSeekDataUsefulNoFilter = 172, LastLevelSeekDataUsefulFilterMatch = 173, NonLastLevelSeekFiltered = 174, NonLastLevelSeekFilterMatch = 175, NonLastLevelSeekData = 176, NonLastLevelSeekDataUsefulNoFilter = 177, NonLastLevelSeekDataUsefulFilterMatch = 178, BlockChecksumComputeCount = 179, BlockChecksumMismatchCount = 180, MultigetCoroutineCount = 181, BlobDbCacheMiss = 182, BlobDbCacheHit = 183, BlobDbCacheAdd = 184, BlobDbCacheAddFailures = 185, BlobDbCacheBytesRead = 186, BlobDbCacheBytesWrite = 187, ReadAsyncMicros = 188, AsyncReadErrorCount = 189, SecondaryCacheFilterHits = 190, SecondaryCacheIndexHits = 191, SecondaryCacheDataHits = 192, TableOpenPrefetchTailMiss = 193, TableOpenPrefetchTailHit = 194, TimestampFilterTableChecked = 195, TimestampFilterTableFiltered = 196, BytesCompressedFrom = 197, BytesCompressedTo = 198, BytesCompressionBypassed = 199, BytesCompressionRejected = 200, NumberBlockCompressionBypassed = 201, NumberBlockCompressionRejected = 202, BytesDecompressedFrom = 203, BytesDecompressedTo = 204, ReadAheadTrimmed = 205, FifoMaxSizeCompactions = 206, FifoTtlCompactions = 207, PrefetchBytes = 208, PrefetchBytesUseful = 209, PrefetchHits = 210, CompressedSecondaryCacheDummyHits = 211, CompressedSecondaryCacheHits = 212, CompressedSecondaryCachePromotions = 213, CompressedSecondaryCachePromotionSkips = 214,
}

Variants§

§

BlockCacheMiss = 0

total block cache misses REQUIRES: BlockCacheMiss == BlockCacheIndexMiss + BlockCacheFilterMiss + BlockCacheDataMiss;

§

BlockCacheHit = 1

total block cache hit REQUIRES: BlockCacheHit == BlockCacheIndexHit + BlockCacheFilterHit + BlockCacheDataHit;

§

BlockCacheAdd = 2

§of blocks added to block cache.

§

BlockCacheAddFailures = 3

§of failures when adding blocks to block cache.

§

BlockCacheIndexMiss = 4

§of times cache miss when accessing index block from block cache.

§

BlockCacheIndexHit = 5

§of times cache hit when accessing index block from block cache.

§

BlockCacheIndexAdd = 6

§of index blocks added to block cache.

§

BlockCacheIndexBytesInsert = 7

§of bytes of index blocks inserted into cache

§

BlockCacheFilterMiss = 8

§of times cache miss when accessing filter block from block cache.

§

BlockCacheFilterHit = 9

§of times cache hit when accessing filter block from block cache.

§

BlockCacheFilterAdd = 10

§of filter blocks added to block cache.

§

BlockCacheFilterBytesInsert = 11

§of bytes of bloom filter blocks inserted into cache

§

BlockCacheDataMiss = 12

§of times cache miss when accessing data block from block cache.

§

BlockCacheDataHit = 13

§of times cache hit when accessing data block from block cache.

§

BlockCacheDataAdd = 14

§of data blocks added to block cache.

§

BlockCacheDataBytesInsert = 15

§of bytes of data blocks inserted into cache

§

BlockCacheBytesRead = 16

§of bytes read from cache.

§

BlockCacheBytesWrite = 17

§of bytes written into cache.

§

BloomFilterUseful = 18

§of times bloom filter has avoided file reads, i.e., negatives.

§

BloomFilterFullPositive = 19

§of times bloom FullFilter has not avoided the reads.

§

BloomFilterFullTruePositive = 20

§of times bloom FullFilter has not avoided the reads and data actually

exist.

§

PersistentCacheHit = 21

§persistent cache hit

§

PersistentCacheMiss = 22

§persistent cache miss

§

SimBlockCacheHit = 23

§total simulation block cache hits

§

SimBlockCacheMiss = 24

§total simulation block cache misses

§

MemtableHit = 25

§of memtable hits.

§

MemtableMiss = 26

§of memtable misses.

§

GetHitL0 = 27

§of Get() queries served by L0

§

GetHitL1 = 28

§of Get() queries served by L1

§

GetHitL2AndUp = 29

§of Get() queries served by L2 and up

§

CompactionKeyDropNewerEntry = 30

  • Compaction_KeyDrop* count the reasons for key drop during compaction
  • There are 4 reasons currently.
§

CompactionKeyDropObsolete = 31

key was written with a newer value. Also includes keys dropped for range del.

§

CompactionKeyDropRangeDel = 32

The key is obsolete.

§

CompactionKeyDropUser = 33

key was covered by a range tombstone.

§

CompactionRangeDelDropObsolete = 34

user compaction function has dropped the key.

§

CompactionOptimizedDelDropObsolete = 35

all keys in range were deleted. Deletions obsoleted before bottom level due to file gap optimization.

§

CompactionCancelled = 36

If a compaction was canceled in sfm to prevent ENOSPC

§

NumberKeysWritten = 37

Number of keys written to the database via the Put and Write call’s

§

NumberKeysRead = 38

Number of Keys read,

§

NumberKeysUpdated = 39

Number keys updated, if inplace update is enabled

§

BytesWritten = 40

The number of uncompressed bytes issued by DB::Put(), DB::Delete(), DB::Merge(), and DB::Write().

§

BytesRead = 41

The number of uncompressed bytes read from DB::Get(). It could be either from memtables, cache, or table files. For the number of logical bytes read from DB::MultiGet(), please use NumberMultigetBytesRead.

§

NumberDbSeek = 42

The number of calls to seek/next/prev

§

NumberDbNext = 43

§

NumberDbPrev = 44

§

NumberDbSeekFound = 45

The number of calls to seek/next/prev that returned data

§

NumberDbNextFound = 46

§

NumberDbPrevFound = 47

§

IterBytesRead = 48

The number of uncompressed bytes read from an iterator. Includes size of key and value.

§

NoFileOpens = 49

§

NoFileErrors = 50

§

StallMicros = 51

Writer has to wait for compaction or flush to finish.

§

DbMutexWaitMicros = 52

The wait time for db mutex. Disabled by default. To enable it set stats level to kAll

§

NumberMultigetCalls = 53

Number of MultiGet calls, keys read, and bytes read

§

NumberMultigetKeysRead = 54

§

NumberMultigetBytesRead = 55

§

NumberMergeFailures = 56

§

BloomFilterPrefixChecked = 57

Prefix filter stats when used for point lookups (Get / MultiGet). (For prefix filter stats on iterators, see LEVEL_Seek.) Checked: filter was queried

§

BloomFilterPrefixUseful = 58

Useful: filter returned false so prevented accessing data+index blocks

§

BloomFilterPrefixTruePositive = 59

True positive: found a key matching the point query. When another key with the same prefix matches, it is considered a false positive by these statistics even though the filter returned a true positive.

§

NumberOfReseeksInIteration = 60

Number of times we had to reseek inside an iteration to skip over large number of keys with same userkey.

§

GetUpdatesSinceCalls = 61

Record the number of calls to GetUpdatesSince. Useful to keep track of transaction log iterator refreshes

§

WalFileSynced = 62

Number of times WAL sync is done

§

WalFileBytes = 63

Number of bytes written to WAL

§

WriteDoneBySelf = 64

Writes can be processed by requesting thread or by the thread at the head of the writers queue.

§

WriteDoneByOther = 65

§

WriteWithWal = 66

Equivalent to writes done for others

§

CompactReadBytes = 67

Number of Write calls that request WAL

§

CompactWriteBytes = 68

Bytes read during compaction

§

FlushWriteBytes = 69

Bytes written during compaction

§

CompactReadBytesMarked = 70

Bytes written during flush Compaction read and write statistics broken down by CompactionReason

§

CompactReadBytesPeriodic = 71

§

CompactReadBytesTtl = 72

§

CompactWriteBytesMarked = 73

§

CompactWriteBytesPeriodic = 74

§

CompactWriteBytesTtl = 75

§

NumberDirectLoadTableProperties = 76

Number of table’s properties loaded directly from file, without creating table reader object.

§

NumberSuperversionAcquires = 77

§

NumberSuperversionReleases = 78

§

NumberSuperversionCleanups = 79

§

NumberBlockCompressed = 80

§of compressions/decompressions executed

§

NumberBlockDecompressed = 81

§

NumberBlockNotCompressed = 82

DEPRECATED / unused (see NumberBlockCompression_*)

§

MergeOperationTotalTime = 83

Tickers that record cumulative time.

§

FilterOperationTotalTime = 84

§

CompactionCpuTotalTime = 85

§

RowCacheHit = 86

Row cache.

§

RowCacheMiss = 87

§

ReadAmpEstimateUsefulBytes = 88

Read amplification statistics. Read amplification can be calculated using this formula (ReadAMP_ToTAL_ReadBytes / Read_AMP_Estimate_UsefulBytes) REQUIRES: ReadOptions::read_amp_bytes_per_bit to be enabled

§

ReadAmpTotalReadBytes = 89

Estimate of total bytes actually used.

§

NumberRateLimiterDrains = 90

Total size of loaded data blocks. Number of refill intervals where rate limiter’s bytes are fully consumed.

§

NumberIterSkip = 91

Number of internal keys skipped by Iterator

§

BlobDbNumPut = 92

BlobDB specific stats

§of Put/PutTtl/PutUntil to BlobDB. Only applicable to legacy BlobDB.

§

BlobDbNumWrite = 93

§of Write to BlobDB. Only applicable to legacy BlobDB.

§

BlobDbNumGet = 94

§of Get to BlobDB. Only applicable to legacy BlobDB.

§

BlobDbNumMultiget = 95

§of MultiGet to BlobDB. Only applicable to legacy BlobDB.

§

BlobDbNumSeek = 96

§of Seek/SeekToFirst/SeekToLast/SeekForPrev to BlobDB iterator. Only

applicable to legacy BlobDB.

§

BlobDbNumNext = 97

§of Next to BlobDB iterator. Only applicable to legacy BlobDB.

§

BlobDbNumPrev = 98

§of Prev to BlobDB iterator. Only applicable to legacy BlobDB.

§

BlobDbNumKeysWritten = 99

§of keys written to BlobDB. Only applicable to legacy BlobDB.

§

BlobDbNumKeysRead = 100

§of keys read from BlobDB. Only applicable to legacy BlobDB.

§

BlobDbBytesWritten = 101

§of bytes (key + value) written to BlobDB. Only applicable to legacy

BlobDB.

§

BlobDbBytesRead = 102

§of bytes (keys + value) read from BlobDB. Only applicable to legacy

BlobDB.

§

BlobDbWriteInlined = 103

§of keys written by BlobDB as non-Ttl inlined value. Only applicable to

legacy BlobDB.

§

BlobDbWriteInlinedTtl = 104

§of keys written by BlobDB as Ttl inlined value. Only applicable to legacy

BlobDB.

§

BlobDbWriteBlob = 105

§of keys written by BlobDB as non-Ttl blob value. Only applicable to

legacy BlobDB.

§

BlobDbWriteBlobTtl = 106

§of keys written by BlobDB as Ttl blob value. Only applicable to legacy

BlobDB.

§

BlobDbBlobFileBytesWritten = 107

§of bytes written to blob file.

§

BlobDbBlobFileBytesRead = 108

§of bytes read from blob file.

§

BlobDbBlobFileSynced = 109

§of times a blob files being synced.

§

BlobDbBlobIndexExpiredCount = 110

§of blob index evicted from base DB by BlobDB compaction filter because

of expiration. Only applicable to legacy BlobDB.

§

BlobDbBlobIndexExpiredSize = 111

size of blob index evicted from base DB by BlobDB compaction filter because of expiration. Only applicable to legacy BlobDB.

§

BlobDbBlobIndexEvictedCount = 112

§of blob index evicted from base DB by BlobDB compaction filter because

of corresponding file deleted. Only applicable to legacy BlobDB.

§

BlobDbBlobIndexEvictedSize = 113

size of blob index evicted from base DB by BlobDB compaction filter because of corresponding file deleted. Only applicable to legacy BlobDB.

§

BlobDbGcNumFiles = 114

§of blob files that were obsoleted by garbage collection. Only applicable

to legacy BlobDB.

§

BlobDbGcNumNewFiles = 115

§of blob files generated by garbage collection. Only applicable to legacy

BlobDB.

§

BlobDbGcFailures = 116

§of BlobDB garbage collection failures. Only applicable to legacy BlobDB.

§

BlobDbGcNumKeysRelocated = 117

§of keys relocated to new blob file by garbage collection.

§

BlobDbGcBytesRelocated = 118

§of bytes relocated to new blob file by garbage collection.

§

BlobDbFifoNumFilesEvicted = 119

§of blob files evicted because of BlobDB is full. Only applicable to

legacy BlobDB.

§

BlobDbFifoNumKeysEvicted = 120

§of keys in the blob files evicted because of BlobDB is full. Only

applicable to legacy BlobDB.

§

BlobDbFifoBytesEvicted = 121

§of bytes in the blob files evicted because of BlobDB is full. Only

applicable to legacy BlobDB.

§

TxnPrepareMutexOverhead = 122

These counters indicate a performance issue in WritePrepared transactions. We should not seem them ticking them much.

§of times prepare_mutex_ is acquired in the fast path.

§

TxnOldCommitMapMutexOverhead = 123

§of times old_commit_map_mutex_ is acquired in the fast path.

§

TxnDuplicateKeyOverhead = 124

§of times we checked a batch for duplicate keys.

§

TxnSnapshotMutexOverhead = 125

§of times snapshot_mutex_ is acquired in the fast path.

§

TxnGetTryAgain = 126

§of times ::Get returned TryAgain due to expired snapshot seq

§

NumberMultigetKeysFound = 127

Number of keys actually found in MultiGet calls (vs number requested by caller) NumberMultigetKeys_Read gives the number requested by caller

§

NoIteratorCreated = 128

§

NoIteratorDeleted = 129

number of iterators created

§

BlockCacheCompressionDictMiss = 130

number of iterators deleted

§

BlockCacheCompressionDictHit = 131

§

BlockCacheCompressionDictAdd = 132

§

BlockCacheCompressionDictBytesInsert = 133

§

BlockCacheAddRedundant = 134

§of blocks redundantly inserted into block cache.

REQUIRES: BlockCacheAddRedundant <= BlockCacheAdd

§

BlockCacheIndexAddRedundant = 135

§of index blocks redundantly inserted into block cache.

REQUIRES: BlockCacheIndexAddRedundant <= BlockCacheIndexAdd

§

BlockCacheFilterAddRedundant = 136

§of filter blocks redundantly inserted into block cache.

REQUIRES: BlockCacheFilterAddRedundant <= BlockCacheFilterAdd

§

BlockCacheDataAddRedundant = 137

§of data blocks redundantly inserted into block cache.

REQUIRES: BlockCacheDataAddRedundant <= BlockCacheDataAdd

§

BlockCacheCompressionDictAddRedundant = 138

§of dict blocks redundantly inserted into block cache.

REQUIRES: BlockCacheCompressionDictAddRedundant <= BlockCacheCompressionDictAdd

§

FilesMarkedTrash = 139

§of files marked as trash by sst file manager and will be deleted

later by background thread.

§

FilesDeletedFromTrashQueue = 140

§of trash files deleted by the background thread from the trash queue.

§

FilesDeletedImmediately = 141

§of files deleted immediately by sst file manager through delete

scheduler.

§

ErrorHandlerBgErrorCount = 142

The counters for error handler, not that, bg_io_error is the subset of bg_error and bg_retryable_io_error is the subset of bg_io_error. The misspelled versions are deprecated and only kept for compatibility. ToDO: remove the misspelled tickers in the next major release.

§

ErrorHandlerBgErrorCountMisspelled = 143

§

ErrorHandlerBgIoErrorCount = 144

§

ErrorHandlerBgIoErrorCountMisspelled = 145

§

ErrorHandlerBgRetryableIoErrorCount = 146

§

ErrorHandlerBgRetryableIoErrorCountMisspelled = 147

§

ErrorHandlerAutoResumeCount = 148

§

ErrorHandlerAutoResumeRetryTotalCount = 149

§

ErrorHandlerAutoResumeSuccessCount = 150

§

MemtablePayloadBytesAtFlush = 151

Statistics for memtable garbage collection: Raw bytes of data (payload) present on memtable at flush time.

§

MemtableGarbageBytesAtFlush = 152

Outdated bytes of data present on memtable at flush time.

§

SecondaryCacheHits = 153

Secondary cache statistics

§

VerifyChecksumReadBytes = 154

Bytes read by VerifyChecksum() and VerifyFileChecksums() APIs.

§

BackupReadBytes = 155

Bytes read/written while creating backups

§

BackupWriteBytes = 156

§

RemoteCompactReadBytes = 157

Remote compaction read/write statistics

§

RemoteCompactWriteBytes = 158

§

HotFileReadBytes = 159

Tiered storage related statistics

§

WarmFileReadBytes = 160

§

ColdFileReadBytes = 161

§

HotFileReadCount = 162

§

WarmFileReadCount = 163

§

ColdFileReadCount = 164

§

LastLevelReadBytes = 165

Last level and non-last level read statistics

§

LastLevelReadCount = 166

§

NonLastLevelReadBytes = 167

§

NonLastLevelReadCount = 168

§

LastLevelSeekFiltered = 169

Statistics on iterator Seek() (and variants) for each sorted run. I.e. a single user Seek() can result in many sorted run Seek()s. The stats are split between last level and non-last level. Filtered: a filter such as prefix Bloom filter indicate the Seek() would not find anything relevant, so avoided a likely access to data+index blocks.

§

LastLevelSeekFilterMatch = 170

Filter match: a filter such as prefix Bloom filter was queried but did not filter out the seek.

§

LastLevelSeekData = 171

At least one data block was accessed for a Seek() (or variant) on a sorted run.

§

LastLevelSeekDataUsefulNoFilter = 172

At least one value() was accessed for the seek (suggesting it was useful), and no filter such as prefix Bloom was queried.

§

LastLevelSeekDataUsefulFilterMatch = 173

At least one value() was accessed for the seek (suggesting it was useful), after querying a filter such as prefix Bloom.

§

NonLastLevelSeekFiltered = 174

The same set of stats, but for non-last level seeks.

§

NonLastLevelSeekFilterMatch = 175

§

NonLastLevelSeekData = 176

§

NonLastLevelSeekDataUsefulNoFilter = 177

§

NonLastLevelSeekDataUsefulFilterMatch = 178

§

BlockChecksumComputeCount = 179

Number of block checksum verifications

§

BlockChecksumMismatchCount = 180

Number of times RocksDB detected a corruption while verifying a block checksum. RocksDB does not remember corruptions that happened during user reads so the same block corruption may be detected multiple times.

§

MultigetCoroutineCount = 181

§

BlobDbCacheMiss = 182

Integrated BlobDB specific stats

§of times cache miss when accessing blob from blob cache.

§

BlobDbCacheHit = 183

§of times cache hit when accessing blob from blob cache.

§

BlobDbCacheAdd = 184

§of data blocks added to blob cache.

§

BlobDbCacheAddFailures = 185

§of failures when adding blobs to blob cache.

§

BlobDbCacheBytesRead = 186

§of bytes read from blob cache.

§

BlobDbCacheBytesWrite = 187

§of bytes written into blob cache.

§

ReadAsyncMicros = 188

Time spent in the ReadAsync file system call

§

AsyncReadErrorCount = 189

Number of errors returned to the async read callback

§

SecondaryCacheFilterHits = 190

Fine grained secondary cache stats

§

SecondaryCacheIndexHits = 191

§

SecondaryCacheDataHits = 192

§

TableOpenPrefetchTailMiss = 193

Number of lookup into the prefetched tail (see TableOpenPrefetchTailReadBytes) that can’t find its data for table open

§

TableOpenPrefetchTailHit = 194

Number of lookup into the prefetched tail (see TableOpenPrefetchTailReadBytes) that finds its data for table open

§

TimestampFilterTableChecked = 195

Statistics on the filtering by user-defined timestamps

§of times timestamps are checked on accessing the table

§

TimestampFilterTableFiltered = 196

§of times timestamps can successfully help skip the table access

§

BytesCompressedFrom = 197

Number of input bytes (uncompressed) to compression for SST blocks that are stored compressed.

§

BytesCompressedTo = 198

Number of output bytes (compressed) from compression for SST blocks that are stored compressed.

§

BytesCompressionBypassed = 199

Number of uncompressed bytes for SST blocks that are stored uncompressed because compression type is kNoCompression, or some error case caused compression not to run or produce an output. Index blocks are only counted if enable_index_compression is true.

§

BytesCompressionRejected = 200

Number of input bytes (uncompressed) to compression for SST blocks that are stored uncompressed because the compression result was rejected, either because the ratio was not acceptable (see CompressionOptions::max_compressed_bytes_per_kb) or found invalid by the verify_compression option.

§

NumberBlockCompressionBypassed = 201

Like BytesCompressionBypassed but counting number of blocks

§

NumberBlockCompressionRejected = 202

Like BytesCompressionRejected but counting number of blocks

§

BytesDecompressedFrom = 203

Number of input bytes (compressed) to decompression in reading compressed SST blocks from storage.

§

BytesDecompressedTo = 204

Number of output bytes (uncompressed) from decompression in reading compressed SST blocks from storage.

§

ReadAheadTrimmed = 205

Number of times readahead is trimmed during scans when ReadOptions.auto_readahead_size is set.

§

FifoMaxSizeCompactions = 206

Number of Fifo compactions that drop files based on different reasons

§

FifoTtlCompactions = 207

§

PrefetchBytes = 208

Number of bytes prefetched during user initiated scan

§

PrefetchBytesUseful = 209

Number of prefetched bytes that were actually useful

§

PrefetchHits = 210

Number of FS reads avoided due to scan prefetching

§

CompressedSecondaryCacheDummyHits = 211

Compressed secondary cache related stats

§

CompressedSecondaryCacheHits = 212

§

CompressedSecondaryCachePromotions = 213

§

CompressedSecondaryCachePromotionSkips = 214

Implementations§

source§

impl Ticker

source

pub const fn name(&self) -> &'static str

The corresponding rocksdb string identifier for this variant

source

pub fn iter() -> Iter<'static, Ticker>

Trait Implementations§

source§

impl Clone for Ticker

source§

fn clone(&self) -> Ticker

Returns a copy of the value. Read more
1.0.0 · source§

fn clone_from(&mut self, source: &Self)

Performs copy-assignment from source. Read more
source§

impl Debug for Ticker

source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result

Formats the value using the given formatter. Read more
source§

impl Display for Ticker

source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result

Formats the value using the given formatter. Read more
source§

impl FromStr for Ticker

§

type Err = NameParseError

The associated error which can be returned from parsing.
source§

fn from_str(s: &str) -> Result<Self, Self::Err>

Parses a string s to return a value of this type. Read more
source§

impl PartialEq for Ticker

source§

fn eq(&self, other: &Ticker) -> bool

Tests for self and other values to be equal, and is used by ==.
1.0.0 · source§

fn ne(&self, other: &Rhs) -> bool

Tests for !=. The default implementation is almost always sufficient, and should not be overridden without very good reason.
source§

impl Copy for Ticker

source§

impl Eq for Ticker

source§

impl StructuralPartialEq for Ticker

Auto Trait Implementations§

§

impl Freeze for Ticker

§

impl RefUnwindSafe for Ticker

§

impl Send for Ticker

§

impl Sync for Ticker

§

impl Unpin for Ticker

§

impl UnwindSafe for Ticker

Blanket Implementations§

source§

impl<T> Any for T
where T: 'static + ?Sized,

source§

fn type_id(&self) -> TypeId

Gets the TypeId of self. Read more
source§

impl<T> Borrow<T> for T
where T: ?Sized,

source§

fn borrow(&self) -> &T

Immutably borrows from an owned value. Read more
source§

impl<T> BorrowMut<T> for T
where T: ?Sized,

source§

fn borrow_mut(&mut self) -> &mut T

Mutably borrows from an owned value. Read more
source§

impl<T> CloneToUninit for T
where T: Clone,

source§

default unsafe fn clone_to_uninit(&self, dst: *mut T)

🔬This is a nightly-only experimental API. (clone_to_uninit)
Performs copy-assignment from self to dst. Read more
source§

impl<T> CloneToUninit for T
where T: Copy,

source§

unsafe fn clone_to_uninit(&self, dst: *mut T)

🔬This is a nightly-only experimental API. (clone_to_uninit)
Performs copy-assignment from self to dst. Read more
source§

impl<T> From<T> for T

source§

fn from(t: T) -> T

Returns the argument unchanged.

source§

impl<T, U> Into<U> for T
where U: From<T>,

source§

fn into(self) -> U

Calls U::from(self).

That is, this conversion is whatever the implementation of From<T> for U chooses to do.

source§

impl<T> ToOwned for T
where T: Clone,

§

type Owned = T

The resulting type after obtaining ownership.
source§

fn to_owned(&self) -> T

Creates owned data from borrowed data, usually by cloning. Read more
source§

fn clone_into(&self, target: &mut T)

Uses borrowed data to replace owned data, usually by cloning. Read more
source§

impl<T> ToString for T
where T: Display + ?Sized,

source§

default fn to_string(&self) -> String

Converts the given value to a String. Read more
source§

impl<T, U> TryFrom<U> for T
where U: Into<T>,

§

type Error = Infallible

The type returned in the event of a conversion error.
source§

fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>

Performs the conversion.
source§

impl<T, U> TryInto<U> for T
where U: TryFrom<T>,

§

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.
source§

fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>

Performs the conversion.