LCOV - code coverage report
Current view: top level - pebble/sstable - properties.go (source / functions) Hit Total Coverage
Test: 2024-01-30 08:15Z eb8e9db5 - tests + meta.lcov Lines: 244 253 96.4 %
Date: 2024-01-30 08:16:42 Functions: 0 0 -

          Line data    Source code
       1             : // Copyright 2018 The LevelDB-Go and Pebble Authors. All rights reserved. Use
       2             : // of this source code is governed by a BSD-style license that can be found in
       3             : // the LICENSE file.
       4             : 
       5             : package sstable
       6             : 
       7             : import (
       8             :         "bytes"
       9             :         "encoding/binary"
      10             :         "fmt"
      11             :         "math"
      12             :         "reflect"
      13             :         "sort"
      14             :         "unsafe"
      15             : 
      16             :         "github.com/cockroachdb/pebble/internal/intern"
      17             : )
      18             : 
      19             : const propertiesBlockRestartInterval = math.MaxInt32
      20             : const propGlobalSeqnumName = "rocksdb.external_sst_file.global_seqno"
      21             : 
      22             : var propTagMap = make(map[string]reflect.StructField)
      23             : var propBoolTrue = []byte{'1'}
      24             : var propBoolFalse = []byte{'0'}
      25             : 
      26             : var propOffsetTagMap = make(map[uintptr]string)
      27             : 
      28           2 : func generateTagMaps(t reflect.Type, indexPrefix []int) {
      29           2 :         for i := 0; i < t.NumField(); i++ {
      30           2 :                 f := t.Field(i)
      31           2 :                 if f.Type.Kind() == reflect.Struct {
      32           2 :                         if tag := f.Tag.Get("prop"); i == 0 && tag == "pebble.embbeded_common_properties" {
      33           2 :                                 // CommonProperties struct embedded in Properties. Note that since
      34           2 :                                 // CommonProperties is placed at the top of properties we can use
      35           2 :                                 // the offsets of the fields within CommonProperties to determine
      36           2 :                                 // the offsets of those fields within Properties.
      37           2 :                                 generateTagMaps(f.Type, []int{i})
      38           2 :                                 continue
      39             :                         }
      40           0 :                         panic("pebble: unknown struct type in Properties")
      41             :                 }
      42           2 :                 if tag := f.Tag.Get("prop"); tag != "" {
      43           2 :                         switch f.Type.Kind() {
      44           2 :                         case reflect.Bool:
      45           2 :                         case reflect.Uint32:
      46           2 :                         case reflect.Uint64:
      47           2 :                         case reflect.String:
      48           0 :                         default:
      49           0 :                                 panic(fmt.Sprintf("unsupported property field type: %s %s", f.Name, f.Type))
      50             :                         }
      51           2 :                         if len(indexPrefix) > 0 {
      52           2 :                                 // Prepend the index prefix so that we can use FieldByIndex on the top-level struct.
      53           2 :                                 f.Index = append(indexPrefix[:len(indexPrefix):len(indexPrefix)], f.Index...)
      54           2 :                         }
      55           2 :                         propTagMap[tag] = f
      56           2 :                         propOffsetTagMap[f.Offset] = tag
      57             :                 }
      58             :         }
      59             : }
      60             : 
      61           2 : func init() {
      62           2 :         generateTagMaps(reflect.TypeOf(Properties{}), nil)
      63           2 : }
      64             : 
      65             : // CommonProperties holds properties for either a virtual or a physical sstable. This
      66             : // can be used by code which doesn't care to make the distinction between physical
      67             : // and virtual sstables properties.
      68             : //
      69             : // For virtual sstables, fields are constructed through extrapolation upon virtual
      70             : // reader construction. See MakeVirtualReader for implementation details.
      71             : //
      72             : // NB: The values of these properties can affect correctness. For example,
      73             : // if NumRangeKeySets == 0, but the sstable actually contains range keys, then
      74             : // the iterators will behave incorrectly.
      75             : type CommonProperties struct {
      76             :         // The number of entries in this table.
      77             :         NumEntries uint64 `prop:"rocksdb.num.entries"`
      78             :         // Total raw key size.
      79             :         RawKeySize uint64 `prop:"rocksdb.raw.key.size"`
      80             :         // Total raw value size.
      81             :         RawValueSize uint64 `prop:"rocksdb.raw.value.size"`
      82             :         // Total raw key size of point deletion tombstones. This value is comparable
      83             :         // to RawKeySize.
      84             :         RawPointTombstoneKeySize uint64 `prop:"pebble.raw.point-tombstone.key.size"`
      85             :         // Sum of the raw value sizes carried by point deletion tombstones
      86             :         // containing size estimates. See the DeleteSized key kind. This value is
      87             :         // comparable to Raw{Key,Value}Size.
      88             :         RawPointTombstoneValueSize uint64 `prop:"pebble.raw.point-tombstone.value.size"`
      89             :         // The number of point deletion entries ("tombstones") in this table that
      90             :         // carry a size hint indicating the size of the value the tombstone deletes.
      91             :         NumSizedDeletions uint64 `prop:"pebble.num.deletions.sized"`
      92             :         // The number of deletion entries in this table, including both point and
      93             :         // range deletions.
      94             :         NumDeletions uint64 `prop:"rocksdb.deleted.keys"`
      95             :         // The number of range deletions in this table.
      96             :         NumRangeDeletions uint64 `prop:"rocksdb.num.range-deletions"`
      97             :         // The number of RANGEKEYDELs in this table.
      98             :         NumRangeKeyDels uint64 `prop:"pebble.num.range-key-dels"`
      99             :         // The number of RANGEKEYSETs in this table.
     100             :         NumRangeKeySets uint64 `prop:"pebble.num.range-key-sets"`
     101             :         // Total size of value blocks and value index block. Only serialized if > 0.
     102             :         ValueBlocksSize uint64 `prop:"pebble.value-blocks.size"`
     103             : }
     104             : 
     105             : // String is only used for testing purposes.
     106           1 : func (c *CommonProperties) String() string {
     107           1 :         var buf bytes.Buffer
     108           1 :         v := reflect.ValueOf(*c)
     109           1 :         loaded := make(map[uintptr]struct{})
     110           1 :         writeProperties(loaded, v, &buf)
     111           1 :         return buf.String()
     112           1 : }
     113             : 
     114             : // NumPointDeletions is the number of point deletions in the sstable. For virtual
     115             : // sstables, this is an estimate.
     116           2 : func (c *CommonProperties) NumPointDeletions() uint64 {
     117           2 :         return c.NumDeletions - c.NumRangeDeletions
     118           2 : }
     119             : 
     120             : // Properties holds the sstable property values. The properties are
     121             : // automatically populated during sstable creation and load from the properties
     122             : // meta block when an sstable is opened.
     123             : type Properties struct {
     124             :         // CommonProperties needs to be at the top of the Properties struct so that the
     125             :         // offsets of the fields in CommonProperties match the offsets of the embedded
     126             :         // fields of CommonProperties in Properties.
     127             :         CommonProperties `prop:"pebble.embbeded_common_properties"`
     128             : 
     129             :         // The name of the comparer used in this table.
     130             :         ComparerName string `prop:"rocksdb.comparator"`
     131             :         // The compression algorithm used to compress blocks.
     132             :         CompressionName string `prop:"rocksdb.compression"`
     133             :         // The compression options used to compress blocks.
     134             :         CompressionOptions string `prop:"rocksdb.compression_options"`
     135             :         // The total size of all data blocks.
     136             :         DataSize uint64 `prop:"rocksdb.data.size"`
     137             :         // The external sstable version format. Version 2 is the one RocksDB has been
     138             :         // using since 5.13. RocksDB only uses the global sequence number for an
     139             :         // sstable if this property has been set.
     140             :         ExternalFormatVersion uint32 `prop:"rocksdb.external_sst_file.version"`
     141             :         // The name of the filter policy used in this table. Empty if no filter
     142             :         // policy is used.
     143             :         FilterPolicyName string `prop:"rocksdb.filter.policy"`
     144             :         // The size of filter block.
     145             :         FilterSize uint64 `prop:"rocksdb.filter.size"`
     146             :         // The global sequence number to use for all entries in the table. Present if
     147             :         // the table was created externally and ingested whole.
     148             :         GlobalSeqNum uint64 `prop:"rocksdb.external_sst_file.global_seqno"`
     149             :         // Total number of index partitions if kTwoLevelIndexSearch is used.
     150             :         IndexPartitions uint64 `prop:"rocksdb.index.partitions"`
     151             :         // The size of index block.
     152             :         IndexSize uint64 `prop:"rocksdb.index.size"`
     153             :         // The index type. TODO(peter): add a more detailed description.
     154             :         IndexType uint32 `prop:"rocksdb.block.based.table.index.type"`
     155             :         // For formats >= TableFormatPebblev4, this is set to true if the obsolete
     156             :         // bit is strict for all the point keys.
     157             :         IsStrictObsolete bool `prop:"pebble.obsolete.is_strict"`
     158             :         // The name of the merger used in this table. Empty if no merger is used.
     159             :         MergerName string `prop:"rocksdb.merge.operator"`
     160             :         // The number of blocks in this table.
     161             :         NumDataBlocks uint64 `prop:"rocksdb.num.data.blocks"`
     162             :         // The number of merge operands in the table.
     163             :         NumMergeOperands uint64 `prop:"rocksdb.merge.operands"`
     164             :         // The number of RANGEKEYUNSETs in this table.
     165             :         NumRangeKeyUnsets uint64 `prop:"pebble.num.range-key-unsets"`
     166             :         // The number of value blocks in this table. Only serialized if > 0.
     167             :         NumValueBlocks uint64 `prop:"pebble.num.value-blocks"`
     168             :         // The number of values stored in value blocks. Only serialized if > 0.
     169             :         NumValuesInValueBlocks uint64 `prop:"pebble.num.values.in.value-blocks"`
     170             :         // The name of the prefix extractor used in this table. Empty if no prefix
     171             :         // extractor is used.
     172             :         PrefixExtractorName string `prop:"rocksdb.prefix.extractor.name"`
     173             :         // If filtering is enabled, was the filter created on the key prefix.
     174             :         PrefixFiltering bool `prop:"rocksdb.block.based.table.prefix.filtering"`
     175             :         // A comma separated list of names of the property collectors used in this
     176             :         // table.
     177             :         PropertyCollectorNames string `prop:"rocksdb.property.collectors"`
     178             :         // Total raw rangekey key size.
     179             :         RawRangeKeyKeySize uint64 `prop:"pebble.raw.range-key.key.size"`
     180             :         // Total raw rangekey value size.
     181             :         RawRangeKeyValueSize uint64 `prop:"pebble.raw.range-key.value.size"`
     182             :         // The total number of keys in this table that were pinned by open snapshots.
     183             :         SnapshotPinnedKeys uint64 `prop:"pebble.num.snapshot-pinned-keys"`
     184             :         // The cumulative bytes of keys in this table that were pinned by
     185             :         // open snapshots. This value is comparable to RawKeySize.
     186             :         SnapshotPinnedKeySize uint64 `prop:"pebble.raw.snapshot-pinned-keys.size"`
     187             :         // The cumulative bytes of values in this table that were pinned by
     188             :         // open snapshots. This value is comparable to RawValueSize.
     189             :         SnapshotPinnedValueSize uint64 `prop:"pebble.raw.snapshot-pinned-values.size"`
     190             :         // Size of the top-level index if kTwoLevelIndexSearch is used.
     191             :         TopLevelIndexSize uint64 `prop:"rocksdb.top-level.index.size"`
     192             :         // User collected properties.
     193             :         UserProperties map[string]string
     194             :         // If filtering is enabled, was the filter created on the whole key.
     195             :         WholeKeyFiltering bool `prop:"rocksdb.block.based.table.whole.key.filtering"`
     196             : 
     197             :         // Loaded set indicating which fields have been loaded from disk. Indexed by
     198             :         // the field's byte offset within the struct
     199             :         // (reflect.StructField.Offset). Only set if the properties have been loaded
     200             :         // from a file. Only exported for testing purposes.
     201             :         Loaded map[uintptr]struct{}
     202             : }
     203             : 
     204             : // NumPointDeletions returns the number of point deletions in this table.
     205           1 : func (p *Properties) NumPointDeletions() uint64 {
     206           1 :         return p.NumDeletions - p.NumRangeDeletions
     207           1 : }
     208             : 
     209             : // NumRangeKeys returns a count of the number of range keys in this table.
     210           2 : func (p *Properties) NumRangeKeys() uint64 {
     211           2 :         return p.NumRangeKeyDels + p.NumRangeKeySets + p.NumRangeKeyUnsets
     212           2 : }
     213             : 
     214           1 : func writeProperties(loaded map[uintptr]struct{}, v reflect.Value, buf *bytes.Buffer) {
     215           1 :         vt := v.Type()
     216           1 :         for i := 0; i < v.NumField(); i++ {
     217           1 :                 ft := vt.Field(i)
     218           1 :                 if ft.Type.Kind() == reflect.Struct {
     219           1 :                         // Embedded struct within the properties.
     220           1 :                         writeProperties(loaded, v.Field(i), buf)
     221           1 :                         continue
     222             :                 }
     223           1 :                 tag := ft.Tag.Get("prop")
     224           1 :                 if tag == "" {
     225           1 :                         continue
     226             :                 }
     227             : 
     228           1 :                 f := v.Field(i)
     229           1 :                 // TODO(peter): Use f.IsZero() when we can rely on go1.13.
     230           1 :                 if zero := reflect.Zero(f.Type()); zero.Interface() == f.Interface() {
     231           1 :                         // Skip printing of zero values which were not loaded from disk.
     232           1 :                         if _, ok := loaded[ft.Offset]; !ok {
     233           1 :                                 continue
     234             :                         }
     235             :                 }
     236             : 
     237           1 :                 fmt.Fprintf(buf, "%s: ", tag)
     238           1 :                 switch ft.Type.Kind() {
     239           1 :                 case reflect.Bool:
     240           1 :                         fmt.Fprintf(buf, "%t\n", f.Bool())
     241           1 :                 case reflect.Uint32:
     242           1 :                         fmt.Fprintf(buf, "%d\n", f.Uint())
     243           1 :                 case reflect.Uint64:
     244           1 :                         fmt.Fprintf(buf, "%d\n", f.Uint())
     245           1 :                 case reflect.String:
     246           1 :                         fmt.Fprintf(buf, "%s\n", f.String())
     247           0 :                 default:
     248           0 :                         panic("not reached")
     249             :                 }
     250             :         }
     251             : }
     252             : 
     253           1 : func (p *Properties) String() string {
     254           1 :         var buf bytes.Buffer
     255           1 :         v := reflect.ValueOf(*p)
     256           1 :         writeProperties(p.Loaded, v, &buf)
     257           1 : 
     258           1 :         // Write the UserProperties.
     259           1 :         keys := make([]string, 0, len(p.UserProperties))
     260           1 :         for key := range p.UserProperties {
     261           1 :                 keys = append(keys, key)
     262           1 :         }
     263           1 :         sort.Strings(keys)
     264           1 :         for _, key := range keys {
     265           1 :                 fmt.Fprintf(&buf, "%s: %s\n", key, p.UserProperties[key])
     266           1 :         }
     267           1 :         return buf.String()
     268             : }
     269             : 
     270             : func (p *Properties) load(
     271             :         b block, blockOffset uint64, deniedUserProperties map[string]struct{},
     272           2 : ) error {
     273           2 :         i, err := newRawBlockIter(bytes.Compare, b)
     274           2 :         if err != nil {
     275           0 :                 return err
     276           0 :         }
     277           2 :         p.Loaded = make(map[uintptr]struct{})
     278           2 :         v := reflect.ValueOf(p).Elem()
     279           2 : 
     280           2 :         for valid := i.First(); valid; valid = i.Next() {
     281           2 :                 if f, ok := propTagMap[string(i.Key().UserKey)]; ok {
     282           2 :                         p.Loaded[f.Offset] = struct{}{}
     283           2 :                         field := v.FieldByIndex(f.Index)
     284           2 :                         switch f.Type.Kind() {
     285           2 :                         case reflect.Bool:
     286           2 :                                 field.SetBool(bytes.Equal(i.Value(), propBoolTrue))
     287           2 :                         case reflect.Uint32:
     288           2 :                                 field.SetUint(uint64(binary.LittleEndian.Uint32(i.Value())))
     289           2 :                         case reflect.Uint64:
     290           2 :                                 var n uint64
     291           2 :                                 if string(i.Key().UserKey) == propGlobalSeqnumName {
     292           2 :                                         n = binary.LittleEndian.Uint64(i.Value())
     293           2 :                                 } else {
     294           2 :                                         n, _ = binary.Uvarint(i.Value())
     295           2 :                                 }
     296           2 :                                 field.SetUint(n)
     297           2 :                         case reflect.String:
     298           2 :                                 field.SetString(intern.Bytes(i.Value()))
     299           0 :                         default:
     300           0 :                                 panic("not reached")
     301             :                         }
     302           2 :                         continue
     303             :                 }
     304           2 :                 if p.UserProperties == nil {
     305           2 :                         p.UserProperties = make(map[string]string)
     306           2 :                 }
     307             : 
     308           2 :                 if _, denied := deniedUserProperties[string(i.Key().UserKey)]; !denied {
     309           2 :                         p.UserProperties[intern.Bytes(i.Key().UserKey)] = string(i.Value())
     310           2 :                 }
     311             :         }
     312           2 :         return nil
     313             : }
     314             : 
     315           2 : func (p *Properties) saveBool(m map[string][]byte, offset uintptr, value bool) {
     316           2 :         tag := propOffsetTagMap[offset]
     317           2 :         if value {
     318           2 :                 m[tag] = propBoolTrue
     319           2 :         } else {
     320           2 :                 m[tag] = propBoolFalse
     321           2 :         }
     322             : }
     323             : 
     324           2 : func (p *Properties) saveUint32(m map[string][]byte, offset uintptr, value uint32) {
     325           2 :         var buf [4]byte
     326           2 :         binary.LittleEndian.PutUint32(buf[:], value)
     327           2 :         m[propOffsetTagMap[offset]] = buf[:]
     328           2 : }
     329             : 
     330           2 : func (p *Properties) saveUint64(m map[string][]byte, offset uintptr, value uint64) {
     331           2 :         var buf [8]byte
     332           2 :         binary.LittleEndian.PutUint64(buf[:], value)
     333           2 :         m[propOffsetTagMap[offset]] = buf[:]
     334           2 : }
     335             : 
     336           2 : func (p *Properties) saveUvarint(m map[string][]byte, offset uintptr, value uint64) {
     337           2 :         var buf [10]byte
     338           2 :         n := binary.PutUvarint(buf[:], value)
     339           2 :         m[propOffsetTagMap[offset]] = buf[:n]
     340           2 : }
     341             : 
     342           2 : func (p *Properties) saveString(m map[string][]byte, offset uintptr, value string) {
     343           2 :         m[propOffsetTagMap[offset]] = []byte(value)
     344           2 : }
     345             : 
     346           2 : func (p *Properties) save(tblFormat TableFormat, w *rawBlockWriter) {
     347           2 :         m := make(map[string][]byte)
     348           2 :         for k, v := range p.UserProperties {
     349           2 :                 m[k] = []byte(v)
     350           2 :         }
     351             : 
     352           2 :         if p.ComparerName != "" {
     353           2 :                 p.saveString(m, unsafe.Offsetof(p.ComparerName), p.ComparerName)
     354           2 :         }
     355           2 :         if p.CompressionName != "" {
     356           2 :                 p.saveString(m, unsafe.Offsetof(p.CompressionName), p.CompressionName)
     357           2 :         }
     358           2 :         if p.CompressionOptions != "" {
     359           2 :                 p.saveString(m, unsafe.Offsetof(p.CompressionOptions), p.CompressionOptions)
     360           2 :         }
     361           2 :         p.saveUvarint(m, unsafe.Offsetof(p.DataSize), p.DataSize)
     362           2 :         if p.ExternalFormatVersion != 0 {
     363           2 :                 p.saveUint32(m, unsafe.Offsetof(p.ExternalFormatVersion), p.ExternalFormatVersion)
     364           2 :                 p.saveUint64(m, unsafe.Offsetof(p.GlobalSeqNum), p.GlobalSeqNum)
     365           2 :         }
     366           2 :         if p.FilterPolicyName != "" {
     367           2 :                 p.saveString(m, unsafe.Offsetof(p.FilterPolicyName), p.FilterPolicyName)
     368           2 :         }
     369           2 :         p.saveUvarint(m, unsafe.Offsetof(p.FilterSize), p.FilterSize)
     370           2 :         if p.IndexPartitions != 0 {
     371           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.IndexPartitions), p.IndexPartitions)
     372           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.TopLevelIndexSize), p.TopLevelIndexSize)
     373           2 :         }
     374           2 :         p.saveUvarint(m, unsafe.Offsetof(p.IndexSize), p.IndexSize)
     375           2 :         p.saveUint32(m, unsafe.Offsetof(p.IndexType), p.IndexType)
     376           2 :         if p.IsStrictObsolete {
     377           1 :                 p.saveBool(m, unsafe.Offsetof(p.IsStrictObsolete), p.IsStrictObsolete)
     378           1 :         }
     379           2 :         if p.MergerName != "" {
     380           2 :                 p.saveString(m, unsafe.Offsetof(p.MergerName), p.MergerName)
     381           2 :         }
     382           2 :         p.saveUvarint(m, unsafe.Offsetof(p.NumDataBlocks), p.NumDataBlocks)
     383           2 :         p.saveUvarint(m, unsafe.Offsetof(p.NumEntries), p.NumEntries)
     384           2 :         p.saveUvarint(m, unsafe.Offsetof(p.NumDeletions), p.NumDeletions)
     385           2 :         if p.NumSizedDeletions > 0 {
     386           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.NumSizedDeletions), p.NumSizedDeletions)
     387           2 :         }
     388           2 :         p.saveUvarint(m, unsafe.Offsetof(p.NumMergeOperands), p.NumMergeOperands)
     389           2 :         p.saveUvarint(m, unsafe.Offsetof(p.NumRangeDeletions), p.NumRangeDeletions)
     390           2 :         // NB: We only write out some properties for Pebble formats. This isn't
     391           2 :         // strictly necessary because unrecognized properties are interpreted as
     392           2 :         // user-defined properties, however writing them prevents byte-for-byte
     393           2 :         // equivalence with RocksDB files that some of our testing requires.
     394           2 :         if p.RawPointTombstoneKeySize > 0 && tblFormat >= TableFormatPebblev1 {
     395           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.RawPointTombstoneKeySize), p.RawPointTombstoneKeySize)
     396           2 :         }
     397           2 :         if p.RawPointTombstoneValueSize > 0 {
     398           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.RawPointTombstoneValueSize), p.RawPointTombstoneValueSize)
     399           2 :         }
     400           2 :         if p.NumRangeKeys() > 0 {
     401           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.NumRangeKeyDels), p.NumRangeKeyDels)
     402           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.NumRangeKeySets), p.NumRangeKeySets)
     403           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.NumRangeKeyUnsets), p.NumRangeKeyUnsets)
     404           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.RawRangeKeyKeySize), p.RawRangeKeyKeySize)
     405           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.RawRangeKeyValueSize), p.RawRangeKeyValueSize)
     406           2 :         }
     407           2 :         if p.NumValueBlocks > 0 {
     408           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.NumValueBlocks), p.NumValueBlocks)
     409           2 :         }
     410           2 :         if p.NumValuesInValueBlocks > 0 {
     411           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.NumValuesInValueBlocks), p.NumValuesInValueBlocks)
     412           2 :         }
     413           2 :         if p.PrefixExtractorName != "" {
     414           2 :                 p.saveString(m, unsafe.Offsetof(p.PrefixExtractorName), p.PrefixExtractorName)
     415           2 :         }
     416           2 :         p.saveBool(m, unsafe.Offsetof(p.PrefixFiltering), p.PrefixFiltering)
     417           2 :         if p.PropertyCollectorNames != "" {
     418           2 :                 p.saveString(m, unsafe.Offsetof(p.PropertyCollectorNames), p.PropertyCollectorNames)
     419           2 :         }
     420           2 :         if p.SnapshotPinnedKeys > 0 {
     421           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.SnapshotPinnedKeys), p.SnapshotPinnedKeys)
     422           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.SnapshotPinnedKeySize), p.SnapshotPinnedKeySize)
     423           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.SnapshotPinnedValueSize), p.SnapshotPinnedValueSize)
     424           2 :         }
     425           2 :         p.saveUvarint(m, unsafe.Offsetof(p.RawKeySize), p.RawKeySize)
     426           2 :         p.saveUvarint(m, unsafe.Offsetof(p.RawValueSize), p.RawValueSize)
     427           2 :         if p.ValueBlocksSize > 0 {
     428           2 :                 p.saveUvarint(m, unsafe.Offsetof(p.ValueBlocksSize), p.ValueBlocksSize)
     429           2 :         }
     430           2 :         p.saveBool(m, unsafe.Offsetof(p.WholeKeyFiltering), p.WholeKeyFiltering)
     431           2 : 
     432           2 :         if tblFormat < TableFormatPebblev1 {
     433           1 :                 m["rocksdb.column.family.id"] = binary.AppendUvarint([]byte(nil), math.MaxInt32)
     434           1 :                 m["rocksdb.fixed.key.length"] = []byte{0x00}
     435           1 :                 m["rocksdb.index.key.is.user.key"] = []byte{0x00}
     436           1 :                 m["rocksdb.index.value.is.delta.encoded"] = []byte{0x00}
     437           1 :                 m["rocksdb.oldest.key.time"] = []byte{0x00}
     438           1 :                 m["rocksdb.creation.time"] = []byte{0x00}
     439           1 :                 m["rocksdb.format.version"] = []byte{0x00}
     440           1 :         }
     441             : 
     442           2 :         keys := make([]string, 0, len(m))
     443           2 :         for key := range m {
     444           2 :                 keys = append(keys, key)
     445           2 :         }
     446           2 :         sort.Strings(keys)
     447           2 :         for _, key := range keys {
     448           2 :                 w.add(InternalKey{UserKey: []byte(key)}, m[key])
     449           2 :         }
     450             : }

Generated by: LCOV version 1.14