github.com/cockroachdb/cockroach@v20.2.0-alpha.1+incompatible/pkg/kv/kvserver/kvserverpb/proposer_kv.pb.go (about)

     1  // Code generated by protoc-gen-gogo. DO NOT EDIT.
     2  // source: kv/kvserver/kvserverpb/proposer_kv.proto
     3  
     4  package kvserverpb
     5  
     6  import proto "github.com/gogo/protobuf/proto"
     7  import fmt "fmt"
     8  import math "math"
     9  import roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    10  import enginepb "github.com/cockroachdb/cockroach/pkg/storage/enginepb"
    11  import hlc "github.com/cockroachdb/cockroach/pkg/util/hlc"
    12  
    13  import github_com_cockroachdb_cockroach_pkg_util_uuid "github.com/cockroachdb/cockroach/pkg/util/uuid"
    14  import github_com_cockroachdb_cockroach_pkg_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    15  
    16  import bytes "bytes"
    17  
    18  import github_com_gogo_protobuf_sortkeys "github.com/gogo/protobuf/sortkeys"
    19  
    20  import io "io"
    21  
    22  // Reference imports to suppress errors if they are not otherwise used.
    23  var _ = proto.Marshal
    24  var _ = fmt.Errorf
    25  var _ = math.Inf
    26  
    27  // This is a compile-time assertion to ensure that this generated file
    28  // is compatible with the proto package it is being compiled against.
    29  // A compilation error at this line likely means your copy of the
    30  // proto package needs to be updated.
    31  const _ = proto.GoGoProtoPackageIsVersion2 // please upgrade the proto package
    32  
    33  // Split is emitted when a Replica commits a split trigger. It signals that the
    34  // Replica has prepared the on-disk state for both the left and right hand
    35  // sides of the split, and that the left hand side Replica should be updated as
    36  // well as the right hand side created.
    37  type Split struct {
    38  	roachpb.SplitTrigger `protobuf:"bytes,1,opt,name=trigger,proto3,embedded=trigger" json:"trigger"`
    39  	// RHSDelta holds the statistics for what was written to what is now the
    40  	// right-hand side of the split during the batch which executed it.
    41  	// The on-disk state of the right-hand side is already correct, but the
    42  	// Store must learn about this delta to update its counters appropriately.
    43  	RHSDelta enginepb.MVCCStats `protobuf:"bytes,2,opt,name=rhs_delta,json=rhsDelta,proto3" json:"rhs_delta"`
    44  }
    45  
    46  func (m *Split) Reset()         { *m = Split{} }
    47  func (m *Split) String() string { return proto.CompactTextString(m) }
    48  func (*Split) ProtoMessage()    {}
    49  func (*Split) Descriptor() ([]byte, []int) {
    50  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{0}
    51  }
    52  func (m *Split) XXX_Unmarshal(b []byte) error {
    53  	return m.Unmarshal(b)
    54  }
    55  func (m *Split) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
    56  	b = b[:cap(b)]
    57  	n, err := m.MarshalTo(b)
    58  	if err != nil {
    59  		return nil, err
    60  	}
    61  	return b[:n], nil
    62  }
    63  func (dst *Split) XXX_Merge(src proto.Message) {
    64  	xxx_messageInfo_Split.Merge(dst, src)
    65  }
    66  func (m *Split) XXX_Size() int {
    67  	return m.Size()
    68  }
    69  func (m *Split) XXX_DiscardUnknown() {
    70  	xxx_messageInfo_Split.DiscardUnknown(m)
    71  }
    72  
    73  var xxx_messageInfo_Split proto.InternalMessageInfo
    74  
    75  // Merge is emitted by a Replica which commits a transaction with
    76  // a MergeTrigger (i.e. absorbs its right neighbor).
    77  type Merge struct {
    78  	roachpb.MergeTrigger `protobuf:"bytes,1,opt,name=trigger,proto3,embedded=trigger" json:"trigger"`
    79  }
    80  
    81  func (m *Merge) Reset()         { *m = Merge{} }
    82  func (m *Merge) String() string { return proto.CompactTextString(m) }
    83  func (*Merge) ProtoMessage()    {}
    84  func (*Merge) Descriptor() ([]byte, []int) {
    85  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{1}
    86  }
    87  func (m *Merge) XXX_Unmarshal(b []byte) error {
    88  	return m.Unmarshal(b)
    89  }
    90  func (m *Merge) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
    91  	b = b[:cap(b)]
    92  	n, err := m.MarshalTo(b)
    93  	if err != nil {
    94  		return nil, err
    95  	}
    96  	return b[:n], nil
    97  }
    98  func (dst *Merge) XXX_Merge(src proto.Message) {
    99  	xxx_messageInfo_Merge.Merge(dst, src)
   100  }
   101  func (m *Merge) XXX_Size() int {
   102  	return m.Size()
   103  }
   104  func (m *Merge) XXX_DiscardUnknown() {
   105  	xxx_messageInfo_Merge.DiscardUnknown(m)
   106  }
   107  
   108  var xxx_messageInfo_Merge proto.InternalMessageInfo
   109  
   110  // ChangeReplicas is emitted by a Replica which commits a transaction with
   111  // a ChangeReplicasTrigger.
   112  type ChangeReplicas struct {
   113  	roachpb.ChangeReplicasTrigger `protobuf:"bytes,1,opt,name=trigger,proto3,embedded=trigger" json:"trigger"`
   114  }
   115  
   116  func (m *ChangeReplicas) Reset()      { *m = ChangeReplicas{} }
   117  func (*ChangeReplicas) ProtoMessage() {}
   118  func (*ChangeReplicas) Descriptor() ([]byte, []int) {
   119  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{2}
   120  }
   121  func (m *ChangeReplicas) XXX_Unmarshal(b []byte) error {
   122  	return m.Unmarshal(b)
   123  }
   124  func (m *ChangeReplicas) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   125  	b = b[:cap(b)]
   126  	n, err := m.MarshalTo(b)
   127  	if err != nil {
   128  		return nil, err
   129  	}
   130  	return b[:n], nil
   131  }
   132  func (dst *ChangeReplicas) XXX_Merge(src proto.Message) {
   133  	xxx_messageInfo_ChangeReplicas.Merge(dst, src)
   134  }
   135  func (m *ChangeReplicas) XXX_Size() int {
   136  	return m.Size()
   137  }
   138  func (m *ChangeReplicas) XXX_DiscardUnknown() {
   139  	xxx_messageInfo_ChangeReplicas.DiscardUnknown(m)
   140  }
   141  
   142  var xxx_messageInfo_ChangeReplicas proto.InternalMessageInfo
   143  
   144  // ComputeChecksum is emitted when a ComputeChecksum request is evaluated. It
   145  // instructs the replica to compute a checksum at the time the command is
   146  // applied.
   147  type ComputeChecksum struct {
   148  	// ChecksumID is a handle by which the checksum can be retrieved in a later
   149  	// CollectChecksum request.
   150  	ChecksumID github_com_cockroachdb_cockroach_pkg_util_uuid.UUID `protobuf:"bytes,1,opt,name=checksum_id,json=checksumId,proto3,customtype=github.com/cockroachdb/cockroach/pkg/util/uuid.UUID" json:"checksum_id"`
   151  	// The version used to pick the checksum method. Only when the version matches
   152  	// that hardcoded in the binary will a computation be carried out.
   153  	Version uint32 `protobuf:"varint,5,opt,name=version,proto3" json:"version,omitempty"`
   154  	// SaveSnapshot indicates that the snapshot used to compute the checksum
   155  	// should be saved so that a diff of divergent replicas can later be computed.
   156  	SaveSnapshot bool                 `protobuf:"varint,2,opt,name=save_snapshot,json=saveSnapshot,proto3" json:"save_snapshot,omitempty"`
   157  	Mode         roachpb.ChecksumMode `protobuf:"varint,3,opt,name=mode,proto3,enum=cockroach.roachpb.ChecksumMode" json:"mode,omitempty"`
   158  	// If set, a checkpoint (i.e. cheap backup) of the engine will be taken. This
   159  	// is expected to be set only if we already know that there is an
   160  	// inconsistency and we want to preserve as much state as possible.
   161  	Checkpoint bool `protobuf:"varint,4,opt,name=checkpoint,proto3" json:"checkpoint,omitempty"`
   162  	// Replicas processing this command which find themselves in this slice will
   163  	// terminate. See `CheckConsistencyRequest.Terminate`.
   164  	Terminate []roachpb.ReplicaDescriptor `protobuf:"bytes,6,rep,name=terminate,proto3" json:"terminate"`
   165  }
   166  
   167  func (m *ComputeChecksum) Reset()         { *m = ComputeChecksum{} }
   168  func (m *ComputeChecksum) String() string { return proto.CompactTextString(m) }
   169  func (*ComputeChecksum) ProtoMessage()    {}
   170  func (*ComputeChecksum) Descriptor() ([]byte, []int) {
   171  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{3}
   172  }
   173  func (m *ComputeChecksum) XXX_Unmarshal(b []byte) error {
   174  	return m.Unmarshal(b)
   175  }
   176  func (m *ComputeChecksum) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   177  	b = b[:cap(b)]
   178  	n, err := m.MarshalTo(b)
   179  	if err != nil {
   180  		return nil, err
   181  	}
   182  	return b[:n], nil
   183  }
   184  func (dst *ComputeChecksum) XXX_Merge(src proto.Message) {
   185  	xxx_messageInfo_ComputeChecksum.Merge(dst, src)
   186  }
   187  func (m *ComputeChecksum) XXX_Size() int {
   188  	return m.Size()
   189  }
   190  func (m *ComputeChecksum) XXX_DiscardUnknown() {
   191  	xxx_messageInfo_ComputeChecksum.DiscardUnknown(m)
   192  }
   193  
   194  var xxx_messageInfo_ComputeChecksum proto.InternalMessageInfo
   195  
   196  // Compaction holds core details about a suggested compaction.
   197  type Compaction struct {
   198  	// bytes indicates the expected space reclamation from compaction.
   199  	Bytes int64 `protobuf:"varint,1,opt,name=bytes,proto3" json:"bytes,omitempty"`
   200  	// suggested_at is nanoseconds since the epoch.
   201  	SuggestedAtNanos int64 `protobuf:"varint,2,opt,name=suggested_at_nanos,json=suggestedAtNanos,proto3" json:"suggested_at_nanos,omitempty"`
   202  }
   203  
   204  func (m *Compaction) Reset()         { *m = Compaction{} }
   205  func (m *Compaction) String() string { return proto.CompactTextString(m) }
   206  func (*Compaction) ProtoMessage()    {}
   207  func (*Compaction) Descriptor() ([]byte, []int) {
   208  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{4}
   209  }
   210  func (m *Compaction) XXX_Unmarshal(b []byte) error {
   211  	return m.Unmarshal(b)
   212  }
   213  func (m *Compaction) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   214  	b = b[:cap(b)]
   215  	n, err := m.MarshalTo(b)
   216  	if err != nil {
   217  		return nil, err
   218  	}
   219  	return b[:n], nil
   220  }
   221  func (dst *Compaction) XXX_Merge(src proto.Message) {
   222  	xxx_messageInfo_Compaction.Merge(dst, src)
   223  }
   224  func (m *Compaction) XXX_Size() int {
   225  	return m.Size()
   226  }
   227  func (m *Compaction) XXX_DiscardUnknown() {
   228  	xxx_messageInfo_Compaction.DiscardUnknown(m)
   229  }
   230  
   231  var xxx_messageInfo_Compaction proto.InternalMessageInfo
   232  
   233  // SuggestedCompaction holds start and end keys in conjunction with
   234  // the compaction details.
   235  type SuggestedCompaction struct {
   236  	StartKey   github_com_cockroachdb_cockroach_pkg_roachpb.Key `protobuf:"bytes,1,opt,name=start_key,json=startKey,proto3,casttype=github.com/cockroachdb/cockroach/pkg/roachpb.Key" json:"start_key,omitempty"`
   237  	EndKey     github_com_cockroachdb_cockroach_pkg_roachpb.Key `protobuf:"bytes,2,opt,name=end_key,json=endKey,proto3,casttype=github.com/cockroachdb/cockroach/pkg/roachpb.Key" json:"end_key,omitempty"`
   238  	Compaction `protobuf:"bytes,3,opt,name=compaction,proto3,embedded=compaction" json:"compaction"`
   239  }
   240  
   241  func (m *SuggestedCompaction) Reset()         { *m = SuggestedCompaction{} }
   242  func (m *SuggestedCompaction) String() string { return proto.CompactTextString(m) }
   243  func (*SuggestedCompaction) ProtoMessage()    {}
   244  func (*SuggestedCompaction) Descriptor() ([]byte, []int) {
   245  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{5}
   246  }
   247  func (m *SuggestedCompaction) XXX_Unmarshal(b []byte) error {
   248  	return m.Unmarshal(b)
   249  }
   250  func (m *SuggestedCompaction) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   251  	b = b[:cap(b)]
   252  	n, err := m.MarshalTo(b)
   253  	if err != nil {
   254  		return nil, err
   255  	}
   256  	return b[:n], nil
   257  }
   258  func (dst *SuggestedCompaction) XXX_Merge(src proto.Message) {
   259  	xxx_messageInfo_SuggestedCompaction.Merge(dst, src)
   260  }
   261  func (m *SuggestedCompaction) XXX_Size() int {
   262  	return m.Size()
   263  }
   264  func (m *SuggestedCompaction) XXX_DiscardUnknown() {
   265  	xxx_messageInfo_SuggestedCompaction.DiscardUnknown(m)
   266  }
   267  
   268  var xxx_messageInfo_SuggestedCompaction proto.InternalMessageInfo
   269  
   270  // ReplicatedEvalResult is the structured information which together with
   271  // a RocksDB WriteBatch constitutes the proposal payload in proposer-evaluated
   272  // KV. For the majority of proposals, we expect ReplicatedEvalResult to be
   273  // trivial; only changes to the metadata state (splits, merges, rebalances,
   274  // leases, log truncation, ...) of the Replica or certain special commands must
   275  // sideline information here based on which all Replicas must take action.
   276  type ReplicatedEvalResult struct {
   277  	// Updates to the Replica's ReplicaState. By convention and as outlined on
   278  	// the comment on the ReplicaState message, this field is sparsely populated
   279  	// and any field set overwrites the corresponding field in the state, perhaps
   280  	// with additional side effects (for instance on a descriptor update).
   281  	State           *ReplicaState    `protobuf:"bytes,2,opt,name=state,proto3" json:"state,omitempty"`
   282  	Split           *Split           `protobuf:"bytes,3,opt,name=split,proto3" json:"split,omitempty"`
   283  	Merge           *Merge           `protobuf:"bytes,4,opt,name=merge,proto3" json:"merge,omitempty"`
   284  	ComputeChecksum *ComputeChecksum `protobuf:"bytes,21,opt,name=compute_checksum,json=computeChecksum,proto3" json:"compute_checksum,omitempty"`
   285  	IsLeaseRequest  bool             `protobuf:"varint,6,opt,name=is_lease_request,json=isLeaseRequest,proto3" json:"is_lease_request,omitempty"`
   286  	// Duplicates BatchRequest.Timestamp for proposer-evaluated KV. Used
   287  	// to verify the validity of the command (for lease coverage and GC
   288  	// threshold).
   289  	Timestamp hlc.Timestamp `protobuf:"bytes,8,opt,name=timestamp,proto3" json:"timestamp"`
   290  	// The stats delta corresponding to the data in this WriteBatch. On
   291  	// a split, contains only the contributions to the left-hand side.
   292  	DeprecatedDelta *enginepb.MVCCStats              `protobuf:"bytes,10,opt,name=deprecated_delta,json=deprecatedDelta,proto3" json:"deprecated_delta,omitempty"`
   293  	Delta           enginepb.MVCCStatsDelta          `protobuf:"bytes,18,opt,name=delta,proto3" json:"delta"`
   294  	ChangeReplicas  *ChangeReplicas                  `protobuf:"bytes,12,opt,name=change_replicas,json=changeReplicas,proto3" json:"change_replicas,omitempty"`
   295  	RaftLogDelta    int64                            `protobuf:"varint,13,opt,name=raft_log_delta,json=raftLogDelta,proto3" json:"raft_log_delta,omitempty"`
   296  	AddSSTable      *ReplicatedEvalResult_AddSSTable `protobuf:"bytes,17,opt,name=add_sstable,json=addSstable,proto3" json:"add_sstable,omitempty"`
   297  	// suggested_compactions are sent to the engine's compactor to
   298  	// reclaim storage space after garbage collection or cleared /
   299  	// rebalanced ranges.
   300  	SuggestedCompactions []SuggestedCompaction `protobuf:"bytes,19,rep,name=suggested_compactions,json=suggestedCompactions,proto3" json:"suggested_compactions"`
   301  	// This is the proposal timestamp for the active lease while evaluating a lease request.
   302  	// It will be used to make sure we know if a lease was extended after we sent out the request
   303  	// but before we tried to apply it.
   304  	PrevLeaseProposal *hlc.Timestamp `protobuf:"bytes,20,opt,name=prev_lease_proposal,json=prevLeaseProposal,proto3" json:"prev_lease_proposal,omitempty"`
   305  }
   306  
   307  func (m *ReplicatedEvalResult) Reset()         { *m = ReplicatedEvalResult{} }
   308  func (m *ReplicatedEvalResult) String() string { return proto.CompactTextString(m) }
   309  func (*ReplicatedEvalResult) ProtoMessage()    {}
   310  func (*ReplicatedEvalResult) Descriptor() ([]byte, []int) {
   311  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{6}
   312  }
   313  func (m *ReplicatedEvalResult) XXX_Unmarshal(b []byte) error {
   314  	return m.Unmarshal(b)
   315  }
   316  func (m *ReplicatedEvalResult) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   317  	b = b[:cap(b)]
   318  	n, err := m.MarshalTo(b)
   319  	if err != nil {
   320  		return nil, err
   321  	}
   322  	return b[:n], nil
   323  }
   324  func (dst *ReplicatedEvalResult) XXX_Merge(src proto.Message) {
   325  	xxx_messageInfo_ReplicatedEvalResult.Merge(dst, src)
   326  }
   327  func (m *ReplicatedEvalResult) XXX_Size() int {
   328  	return m.Size()
   329  }
   330  func (m *ReplicatedEvalResult) XXX_DiscardUnknown() {
   331  	xxx_messageInfo_ReplicatedEvalResult.DiscardUnknown(m)
   332  }
   333  
   334  var xxx_messageInfo_ReplicatedEvalResult proto.InternalMessageInfo
   335  
   336  // AddSSTable is a side effect that must execute before the Raft application
   337  // is committed. It must be idempotent to account for an ill-timed crash after
   338  // applying the side effect, but before committing the batch.
   339  //
   340  // TODO(tschottdorf): additionally, after the crash, the node must not serve
   341  // traffic until the persisted committed log has fully applied. Otherwise, we
   342  // risk exposing data created through such a side effect whose corresponding
   343  // Raft command hasn't committed yet. This isn't so much an issue with AddSSTable
   344  // since these Ranges are not user-visible, but it is a general concern assuming
   345  // other such side effects are added.
   346  type ReplicatedEvalResult_AddSSTable struct {
   347  	Data  []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
   348  	CRC32 uint32 `protobuf:"varint,2,opt,name=crc32,proto3" json:"crc32,omitempty"`
   349  }
   350  
   351  func (m *ReplicatedEvalResult_AddSSTable) Reset()         { *m = ReplicatedEvalResult_AddSSTable{} }
   352  func (m *ReplicatedEvalResult_AddSSTable) String() string { return proto.CompactTextString(m) }
   353  func (*ReplicatedEvalResult_AddSSTable) ProtoMessage()    {}
   354  func (*ReplicatedEvalResult_AddSSTable) Descriptor() ([]byte, []int) {
   355  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{6, 0}
   356  }
   357  func (m *ReplicatedEvalResult_AddSSTable) XXX_Unmarshal(b []byte) error {
   358  	return m.Unmarshal(b)
   359  }
   360  func (m *ReplicatedEvalResult_AddSSTable) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   361  	b = b[:cap(b)]
   362  	n, err := m.MarshalTo(b)
   363  	if err != nil {
   364  		return nil, err
   365  	}
   366  	return b[:n], nil
   367  }
   368  func (dst *ReplicatedEvalResult_AddSSTable) XXX_Merge(src proto.Message) {
   369  	xxx_messageInfo_ReplicatedEvalResult_AddSSTable.Merge(dst, src)
   370  }
   371  func (m *ReplicatedEvalResult_AddSSTable) XXX_Size() int {
   372  	return m.Size()
   373  }
   374  func (m *ReplicatedEvalResult_AddSSTable) XXX_DiscardUnknown() {
   375  	xxx_messageInfo_ReplicatedEvalResult_AddSSTable.DiscardUnknown(m)
   376  }
   377  
   378  var xxx_messageInfo_ReplicatedEvalResult_AddSSTable proto.InternalMessageInfo
   379  
   380  // WriteBatch is the serialized representation of a RocksDB write
   381  // batch. A wrapper message is used so that the absence of the field
   382  // can be distinguished from a zero-length batch, and so structs
   383  // containing pointers to it can be compared with the == operator.
   384  type WriteBatch struct {
   385  	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
   386  }
   387  
   388  func (m *WriteBatch) Reset()         { *m = WriteBatch{} }
   389  func (m *WriteBatch) String() string { return proto.CompactTextString(m) }
   390  func (*WriteBatch) ProtoMessage()    {}
   391  func (*WriteBatch) Descriptor() ([]byte, []int) {
   392  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{7}
   393  }
   394  func (m *WriteBatch) XXX_Unmarshal(b []byte) error {
   395  	return m.Unmarshal(b)
   396  }
   397  func (m *WriteBatch) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   398  	b = b[:cap(b)]
   399  	n, err := m.MarshalTo(b)
   400  	if err != nil {
   401  		return nil, err
   402  	}
   403  	return b[:n], nil
   404  }
   405  func (dst *WriteBatch) XXX_Merge(src proto.Message) {
   406  	xxx_messageInfo_WriteBatch.Merge(dst, src)
   407  }
   408  func (m *WriteBatch) XXX_Size() int {
   409  	return m.Size()
   410  }
   411  func (m *WriteBatch) XXX_DiscardUnknown() {
   412  	xxx_messageInfo_WriteBatch.DiscardUnknown(m)
   413  }
   414  
   415  var xxx_messageInfo_WriteBatch proto.InternalMessageInfo
   416  
   417  // LogicalOpLog is a log of logical MVCC operations. A wrapper message
   418  // is used so that the absence of the field can be distinguished from a
   419  // zero-length batch, and so structs containing pointers to it can be
   420  // compared with the == operator.
   421  type LogicalOpLog struct {
   422  	Ops []enginepb.MVCCLogicalOp `protobuf:"bytes,1,rep,name=ops,proto3" json:"ops"`
   423  }
   424  
   425  func (m *LogicalOpLog) Reset()         { *m = LogicalOpLog{} }
   426  func (m *LogicalOpLog) String() string { return proto.CompactTextString(m) }
   427  func (*LogicalOpLog) ProtoMessage()    {}
   428  func (*LogicalOpLog) Descriptor() ([]byte, []int) {
   429  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{8}
   430  }
   431  func (m *LogicalOpLog) XXX_Unmarshal(b []byte) error {
   432  	return m.Unmarshal(b)
   433  }
   434  func (m *LogicalOpLog) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   435  	b = b[:cap(b)]
   436  	n, err := m.MarshalTo(b)
   437  	if err != nil {
   438  		return nil, err
   439  	}
   440  	return b[:n], nil
   441  }
   442  func (dst *LogicalOpLog) XXX_Merge(src proto.Message) {
   443  	xxx_messageInfo_LogicalOpLog.Merge(dst, src)
   444  }
   445  func (m *LogicalOpLog) XXX_Size() int {
   446  	return m.Size()
   447  }
   448  func (m *LogicalOpLog) XXX_DiscardUnknown() {
   449  	xxx_messageInfo_LogicalOpLog.DiscardUnknown(m)
   450  }
   451  
   452  var xxx_messageInfo_LogicalOpLog proto.InternalMessageInfo
   453  
   454  // RaftCommand is the message written to the raft log. It contains
   455  // some metadata about the proposal itself, then either a BatchRequest
   456  // (legacy mode) or a ReplicatedEvalResult + WriteBatch
   457  // (proposer-evaluated KV mode).
   458  type RaftCommand struct {
   459  	// proposer_lease_seq is provided to verify at raft command apply-time
   460  	// that the lease under which the command was proposed remains in effect.
   461  	//
   462  	// To see why lease verification downstream of Raft is required, consider the
   463  	// following example:
   464  	// - replica 1 receives a client request for a write
   465  	// - replica 1 checks the lease; the write is permitted
   466  	// - replica 1 proposes the command
   467  	// - time passes, replica 2 commits a new lease
   468  	// - the command applies on replica 1
   469  	// - replica 2 serves anomalous reads which don't see the write
   470  	// - the command applies on replica 2
   471  	ProposerLeaseSequence github_com_cockroachdb_cockroach_pkg_roachpb.LeaseSequence `protobuf:"varint,6,opt,name=proposer_lease_sequence,json=proposerLeaseSequence,proto3,casttype=github.com/cockroachdb/cockroach/pkg/roachpb.LeaseSequence" json:"proposer_lease_sequence,omitempty"`
   472  	// deprecated_proposer_lease served the same purpose as proposer_lease_seq.
   473  	// As of VersionLeaseSequence, it is no longer in use.
   474  	//
   475  	// However, unless we add a check that all existing Raft logs on all nodes
   476  	// in the cluster contain only "new" leases, we won't be able to remove the
   477  	// legacy code.
   478  	DeprecatedProposerLease *roachpb.Lease `protobuf:"bytes,5,opt,name=deprecated_proposer_lease,json=deprecatedProposerLease,proto3" json:"deprecated_proposer_lease,omitempty"`
   479  	// When the command is applied, its result is an error if the lease log
   480  	// counter has already reached (or exceeded) max_lease_index.
   481  	//
   482  	// The lease index is a reorder protection mechanism - we don't want Raft
   483  	// commands (proposed by a single node, the one with proposer_lease) executing
   484  	// in a different order than the one in which the corresponding KV requests
   485  	// were evaluated and the commands were proposed. This is important because
   486  	// latching does not fully serialize commands - mostly when it comes to
   487  	// updates to the internal state of the range (this should be re-evaluated
   488  	// once proposer-evaluated KV is completed - see #10413).
   489  	// Similar to the Raft applied index, it is strictly increasing, but may have
   490  	// gaps. A command will only apply successfully if its max_lease_index has not
   491  	// been surpassed by the Range's applied lease index (in which case the
   492  	// command may need to be retried, that is, regenerated with a higher
   493  	// max_lease_index). When the command applies, the new lease index will
   494  	// increase to max_lease_index (so a potential later replay will fail).
   495  	//
   496  	// This mechanism was introduced as a simpler alternative to using the Raft
   497  	// applied index, which is fraught with complexity due to the need to predict
   498  	// exactly the log position at which a command will apply, even when the Raft
   499  	// leader is not colocated with the lease holder (which usually proposes all
   500  	// commands).
   501  	//
   502  	// Pinning the lease-index to the assigned slot (as opposed to allowing gaps
   503  	// as we do now) is an interesting venue to explore from the standpoint of
   504  	// parallelization: One could hope to enforce command ordering in that way
   505  	// (without recourse to a higher-level locking primitive such as the command
   506  	// queue). This is a hard problem: First of all, managing the pending
   507  	// commands gets more involved; a command must not be removed if others have
   508  	// been added after it, and on removal, the assignment counters must be
   509  	// updated accordingly. Managing retry of proposals becomes trickier as
   510  	// well as that uproots whatever ordering was originally envisioned.
   511  	MaxLeaseIndex uint64 `protobuf:"varint,4,opt,name=max_lease_index,json=maxLeaseIndex,proto3" json:"max_lease_index,omitempty"`
   512  	// replicated_eval_result is a set of structured information that instructs
   513  	// replicated state changes to the part of a Range's replicated state machine
   514  	// that exists outside of RocksDB.
   515  	ReplicatedEvalResult ReplicatedEvalResult `protobuf:"bytes,13,opt,name=replicated_eval_result,json=replicatedEvalResult,proto3" json:"replicated_eval_result"`
   516  	// write_batch is a RocksDB WriteBatch that will be applied to RockDB during
   517  	// the application of the Raft command. The batch can be thought of as a
   518  	// series of replicated instructions that inform a RocksDB engine on how to
   519  	// change.
   520  	WriteBatch *WriteBatch `protobuf:"bytes,14,opt,name=write_batch,json=writeBatch,proto3" json:"write_batch,omitempty"`
   521  	// logical_op_log contains a series of logical MVCC operations that correspond
   522  	// to the physical operations being made in the write_batch.
   523  	LogicalOpLog *LogicalOpLog `protobuf:"bytes,15,opt,name=logical_op_log,json=logicalOpLog,proto3" json:"logical_op_log,omitempty"`
   524  	// trace_data, if not empty, contains details of proposer's trace as returned by
   525  	// Tracer.Inject(opentracing.TextMap). Used to create span for command
   526  	// application on all the replicas that "follow from" the proposer.
   527  	TraceData map[string]string `protobuf:"bytes,16,rep,name=trace_data,json=traceData,proto3" json:"trace_data,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"`
   528  }
   529  
   530  func (m *RaftCommand) Reset()         { *m = RaftCommand{} }
   531  func (m *RaftCommand) String() string { return proto.CompactTextString(m) }
   532  func (*RaftCommand) ProtoMessage()    {}
   533  func (*RaftCommand) Descriptor() ([]byte, []int) {
   534  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{9}
   535  }
   536  func (m *RaftCommand) XXX_Unmarshal(b []byte) error {
   537  	return m.Unmarshal(b)
   538  }
   539  func (m *RaftCommand) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   540  	b = b[:cap(b)]
   541  	n, err := m.MarshalTo(b)
   542  	if err != nil {
   543  		return nil, err
   544  	}
   545  	return b[:n], nil
   546  }
   547  func (dst *RaftCommand) XXX_Merge(src proto.Message) {
   548  	xxx_messageInfo_RaftCommand.Merge(dst, src)
   549  }
   550  func (m *RaftCommand) XXX_Size() int {
   551  	return m.Size()
   552  }
   553  func (m *RaftCommand) XXX_DiscardUnknown() {
   554  	xxx_messageInfo_RaftCommand.DiscardUnknown(m)
   555  }
   556  
   557  var xxx_messageInfo_RaftCommand proto.InternalMessageInfo
   558  
   559  // RaftCommandFooter contains a subset of the fields in RaftCommand. It is used
   560  // to optimize a pattern where most of the fields in RaftCommand are marshaled
   561  // outside of a heavily contended critical section, except for the fields in the
   562  // footer, which are assigned and marhsaled inside of the critical section and
   563  // appended to the marshaled byte buffer. This minimizes the memory allocation
   564  // and marshaling work performed under lock.
   565  type RaftCommandFooter struct {
   566  	MaxLeaseIndex uint64 `protobuf:"varint,4,opt,name=max_lease_index,json=maxLeaseIndex,proto3" json:"max_lease_index,omitempty"`
   567  }
   568  
   569  func (m *RaftCommandFooter) Reset()         { *m = RaftCommandFooter{} }
   570  func (m *RaftCommandFooter) String() string { return proto.CompactTextString(m) }
   571  func (*RaftCommandFooter) ProtoMessage()    {}
   572  func (*RaftCommandFooter) Descriptor() ([]byte, []int) {
   573  	return fileDescriptor_proposer_kv_baa0b8d6d33a3e71, []int{10}
   574  }
   575  func (m *RaftCommandFooter) XXX_Unmarshal(b []byte) error {
   576  	return m.Unmarshal(b)
   577  }
   578  func (m *RaftCommandFooter) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   579  	b = b[:cap(b)]
   580  	n, err := m.MarshalTo(b)
   581  	if err != nil {
   582  		return nil, err
   583  	}
   584  	return b[:n], nil
   585  }
   586  func (dst *RaftCommandFooter) XXX_Merge(src proto.Message) {
   587  	xxx_messageInfo_RaftCommandFooter.Merge(dst, src)
   588  }
   589  func (m *RaftCommandFooter) XXX_Size() int {
   590  	return m.Size()
   591  }
   592  func (m *RaftCommandFooter) XXX_DiscardUnknown() {
   593  	xxx_messageInfo_RaftCommandFooter.DiscardUnknown(m)
   594  }
   595  
   596  var xxx_messageInfo_RaftCommandFooter proto.InternalMessageInfo
   597  
   598  func init() {
   599  	proto.RegisterType((*Split)(nil), "cockroach.kv.kvserver.storagepb.Split")
   600  	proto.RegisterType((*Merge)(nil), "cockroach.kv.kvserver.storagepb.Merge")
   601  	proto.RegisterType((*ChangeReplicas)(nil), "cockroach.kv.kvserver.storagepb.ChangeReplicas")
   602  	proto.RegisterType((*ComputeChecksum)(nil), "cockroach.kv.kvserver.storagepb.ComputeChecksum")
   603  	proto.RegisterType((*Compaction)(nil), "cockroach.kv.kvserver.storagepb.Compaction")
   604  	proto.RegisterType((*SuggestedCompaction)(nil), "cockroach.kv.kvserver.storagepb.SuggestedCompaction")
   605  	proto.RegisterType((*ReplicatedEvalResult)(nil), "cockroach.kv.kvserver.storagepb.ReplicatedEvalResult")
   606  	proto.RegisterType((*ReplicatedEvalResult_AddSSTable)(nil), "cockroach.kv.kvserver.storagepb.ReplicatedEvalResult.AddSSTable")
   607  	proto.RegisterType((*WriteBatch)(nil), "cockroach.kv.kvserver.storagepb.WriteBatch")
   608  	proto.RegisterType((*LogicalOpLog)(nil), "cockroach.kv.kvserver.storagepb.LogicalOpLog")
   609  	proto.RegisterType((*RaftCommand)(nil), "cockroach.kv.kvserver.storagepb.RaftCommand")
   610  	proto.RegisterMapType((map[string]string)(nil), "cockroach.kv.kvserver.storagepb.RaftCommand.TraceDataEntry")
   611  	proto.RegisterType((*RaftCommandFooter)(nil), "cockroach.kv.kvserver.storagepb.RaftCommandFooter")
   612  }
   613  func (this *Split) Equal(that interface{}) bool {
   614  	if that == nil {
   615  		return this == nil
   616  	}
   617  
   618  	that1, ok := that.(*Split)
   619  	if !ok {
   620  		that2, ok := that.(Split)
   621  		if ok {
   622  			that1 = &that2
   623  		} else {
   624  			return false
   625  		}
   626  	}
   627  	if that1 == nil {
   628  		return this == nil
   629  	} else if this == nil {
   630  		return false
   631  	}
   632  	if !this.SplitTrigger.Equal(&that1.SplitTrigger) {
   633  		return false
   634  	}
   635  	if !this.RHSDelta.Equal(&that1.RHSDelta) {
   636  		return false
   637  	}
   638  	return true
   639  }
   640  func (this *Merge) Equal(that interface{}) bool {
   641  	if that == nil {
   642  		return this == nil
   643  	}
   644  
   645  	that1, ok := that.(*Merge)
   646  	if !ok {
   647  		that2, ok := that.(Merge)
   648  		if ok {
   649  			that1 = &that2
   650  		} else {
   651  			return false
   652  		}
   653  	}
   654  	if that1 == nil {
   655  		return this == nil
   656  	} else if this == nil {
   657  		return false
   658  	}
   659  	if !this.MergeTrigger.Equal(&that1.MergeTrigger) {
   660  		return false
   661  	}
   662  	return true
   663  }
   664  func (this *ChangeReplicas) Equal(that interface{}) bool {
   665  	if that == nil {
   666  		return this == nil
   667  	}
   668  
   669  	that1, ok := that.(*ChangeReplicas)
   670  	if !ok {
   671  		that2, ok := that.(ChangeReplicas)
   672  		if ok {
   673  			that1 = &that2
   674  		} else {
   675  			return false
   676  		}
   677  	}
   678  	if that1 == nil {
   679  		return this == nil
   680  	} else if this == nil {
   681  		return false
   682  	}
   683  	if !this.ChangeReplicasTrigger.Equal(&that1.ChangeReplicasTrigger) {
   684  		return false
   685  	}
   686  	return true
   687  }
   688  func (this *ComputeChecksum) Equal(that interface{}) bool {
   689  	if that == nil {
   690  		return this == nil
   691  	}
   692  
   693  	that1, ok := that.(*ComputeChecksum)
   694  	if !ok {
   695  		that2, ok := that.(ComputeChecksum)
   696  		if ok {
   697  			that1 = &that2
   698  		} else {
   699  			return false
   700  		}
   701  	}
   702  	if that1 == nil {
   703  		return this == nil
   704  	} else if this == nil {
   705  		return false
   706  	}
   707  	if !this.ChecksumID.Equal(that1.ChecksumID) {
   708  		return false
   709  	}
   710  	if this.Version != that1.Version {
   711  		return false
   712  	}
   713  	if this.SaveSnapshot != that1.SaveSnapshot {
   714  		return false
   715  	}
   716  	if this.Mode != that1.Mode {
   717  		return false
   718  	}
   719  	if this.Checkpoint != that1.Checkpoint {
   720  		return false
   721  	}
   722  	if len(this.Terminate) != len(that1.Terminate) {
   723  		return false
   724  	}
   725  	for i := range this.Terminate {
   726  		if !this.Terminate[i].Equal(&that1.Terminate[i]) {
   727  			return false
   728  		}
   729  	}
   730  	return true
   731  }
   732  func (this *Compaction) Equal(that interface{}) bool {
   733  	if that == nil {
   734  		return this == nil
   735  	}
   736  
   737  	that1, ok := that.(*Compaction)
   738  	if !ok {
   739  		that2, ok := that.(Compaction)
   740  		if ok {
   741  			that1 = &that2
   742  		} else {
   743  			return false
   744  		}
   745  	}
   746  	if that1 == nil {
   747  		return this == nil
   748  	} else if this == nil {
   749  		return false
   750  	}
   751  	if this.Bytes != that1.Bytes {
   752  		return false
   753  	}
   754  	if this.SuggestedAtNanos != that1.SuggestedAtNanos {
   755  		return false
   756  	}
   757  	return true
   758  }
   759  func (this *SuggestedCompaction) Equal(that interface{}) bool {
   760  	if that == nil {
   761  		return this == nil
   762  	}
   763  
   764  	that1, ok := that.(*SuggestedCompaction)
   765  	if !ok {
   766  		that2, ok := that.(SuggestedCompaction)
   767  		if ok {
   768  			that1 = &that2
   769  		} else {
   770  			return false
   771  		}
   772  	}
   773  	if that1 == nil {
   774  		return this == nil
   775  	} else if this == nil {
   776  		return false
   777  	}
   778  	if !bytes.Equal(this.StartKey, that1.StartKey) {
   779  		return false
   780  	}
   781  	if !bytes.Equal(this.EndKey, that1.EndKey) {
   782  		return false
   783  	}
   784  	if !this.Compaction.Equal(&that1.Compaction) {
   785  		return false
   786  	}
   787  	return true
   788  }
   789  func (this *ReplicatedEvalResult) Equal(that interface{}) bool {
   790  	if that == nil {
   791  		return this == nil
   792  	}
   793  
   794  	that1, ok := that.(*ReplicatedEvalResult)
   795  	if !ok {
   796  		that2, ok := that.(ReplicatedEvalResult)
   797  		if ok {
   798  			that1 = &that2
   799  		} else {
   800  			return false
   801  		}
   802  	}
   803  	if that1 == nil {
   804  		return this == nil
   805  	} else if this == nil {
   806  		return false
   807  	}
   808  	if !this.State.Equal(that1.State) {
   809  		return false
   810  	}
   811  	if !this.Split.Equal(that1.Split) {
   812  		return false
   813  	}
   814  	if !this.Merge.Equal(that1.Merge) {
   815  		return false
   816  	}
   817  	if !this.ComputeChecksum.Equal(that1.ComputeChecksum) {
   818  		return false
   819  	}
   820  	if this.IsLeaseRequest != that1.IsLeaseRequest {
   821  		return false
   822  	}
   823  	if !this.Timestamp.Equal(&that1.Timestamp) {
   824  		return false
   825  	}
   826  	if !this.DeprecatedDelta.Equal(that1.DeprecatedDelta) {
   827  		return false
   828  	}
   829  	if !this.Delta.Equal(&that1.Delta) {
   830  		return false
   831  	}
   832  	if !this.ChangeReplicas.Equal(that1.ChangeReplicas) {
   833  		return false
   834  	}
   835  	if this.RaftLogDelta != that1.RaftLogDelta {
   836  		return false
   837  	}
   838  	if !this.AddSSTable.Equal(that1.AddSSTable) {
   839  		return false
   840  	}
   841  	if len(this.SuggestedCompactions) != len(that1.SuggestedCompactions) {
   842  		return false
   843  	}
   844  	for i := range this.SuggestedCompactions {
   845  		if !this.SuggestedCompactions[i].Equal(&that1.SuggestedCompactions[i]) {
   846  			return false
   847  		}
   848  	}
   849  	if !this.PrevLeaseProposal.Equal(that1.PrevLeaseProposal) {
   850  		return false
   851  	}
   852  	return true
   853  }
   854  func (this *ReplicatedEvalResult_AddSSTable) Equal(that interface{}) bool {
   855  	if that == nil {
   856  		return this == nil
   857  	}
   858  
   859  	that1, ok := that.(*ReplicatedEvalResult_AddSSTable)
   860  	if !ok {
   861  		that2, ok := that.(ReplicatedEvalResult_AddSSTable)
   862  		if ok {
   863  			that1 = &that2
   864  		} else {
   865  			return false
   866  		}
   867  	}
   868  	if that1 == nil {
   869  		return this == nil
   870  	} else if this == nil {
   871  		return false
   872  	}
   873  	if !bytes.Equal(this.Data, that1.Data) {
   874  		return false
   875  	}
   876  	if this.CRC32 != that1.CRC32 {
   877  		return false
   878  	}
   879  	return true
   880  }
   881  func (m *Split) Marshal() (dAtA []byte, err error) {
   882  	size := m.Size()
   883  	dAtA = make([]byte, size)
   884  	n, err := m.MarshalTo(dAtA)
   885  	if err != nil {
   886  		return nil, err
   887  	}
   888  	return dAtA[:n], nil
   889  }
   890  
   891  func (m *Split) MarshalTo(dAtA []byte) (int, error) {
   892  	var i int
   893  	_ = i
   894  	var l int
   895  	_ = l
   896  	dAtA[i] = 0xa
   897  	i++
   898  	i = encodeVarintProposerKv(dAtA, i, uint64(m.SplitTrigger.Size()))
   899  	n1, err := m.SplitTrigger.MarshalTo(dAtA[i:])
   900  	if err != nil {
   901  		return 0, err
   902  	}
   903  	i += n1
   904  	dAtA[i] = 0x12
   905  	i++
   906  	i = encodeVarintProposerKv(dAtA, i, uint64(m.RHSDelta.Size()))
   907  	n2, err := m.RHSDelta.MarshalTo(dAtA[i:])
   908  	if err != nil {
   909  		return 0, err
   910  	}
   911  	i += n2
   912  	return i, nil
   913  }
   914  
   915  func (m *Merge) Marshal() (dAtA []byte, err error) {
   916  	size := m.Size()
   917  	dAtA = make([]byte, size)
   918  	n, err := m.MarshalTo(dAtA)
   919  	if err != nil {
   920  		return nil, err
   921  	}
   922  	return dAtA[:n], nil
   923  }
   924  
   925  func (m *Merge) MarshalTo(dAtA []byte) (int, error) {
   926  	var i int
   927  	_ = i
   928  	var l int
   929  	_ = l
   930  	dAtA[i] = 0xa
   931  	i++
   932  	i = encodeVarintProposerKv(dAtA, i, uint64(m.MergeTrigger.Size()))
   933  	n3, err := m.MergeTrigger.MarshalTo(dAtA[i:])
   934  	if err != nil {
   935  		return 0, err
   936  	}
   937  	i += n3
   938  	return i, nil
   939  }
   940  
   941  func (m *ChangeReplicas) Marshal() (dAtA []byte, err error) {
   942  	size := m.Size()
   943  	dAtA = make([]byte, size)
   944  	n, err := m.MarshalTo(dAtA)
   945  	if err != nil {
   946  		return nil, err
   947  	}
   948  	return dAtA[:n], nil
   949  }
   950  
   951  func (m *ChangeReplicas) MarshalTo(dAtA []byte) (int, error) {
   952  	var i int
   953  	_ = i
   954  	var l int
   955  	_ = l
   956  	dAtA[i] = 0xa
   957  	i++
   958  	i = encodeVarintProposerKv(dAtA, i, uint64(m.ChangeReplicasTrigger.Size()))
   959  	n4, err := m.ChangeReplicasTrigger.MarshalTo(dAtA[i:])
   960  	if err != nil {
   961  		return 0, err
   962  	}
   963  	i += n4
   964  	return i, nil
   965  }
   966  
   967  func (m *ComputeChecksum) Marshal() (dAtA []byte, err error) {
   968  	size := m.Size()
   969  	dAtA = make([]byte, size)
   970  	n, err := m.MarshalTo(dAtA)
   971  	if err != nil {
   972  		return nil, err
   973  	}
   974  	return dAtA[:n], nil
   975  }
   976  
   977  func (m *ComputeChecksum) MarshalTo(dAtA []byte) (int, error) {
   978  	var i int
   979  	_ = i
   980  	var l int
   981  	_ = l
   982  	dAtA[i] = 0xa
   983  	i++
   984  	i = encodeVarintProposerKv(dAtA, i, uint64(m.ChecksumID.Size()))
   985  	n5, err := m.ChecksumID.MarshalTo(dAtA[i:])
   986  	if err != nil {
   987  		return 0, err
   988  	}
   989  	i += n5
   990  	if m.SaveSnapshot {
   991  		dAtA[i] = 0x10
   992  		i++
   993  		if m.SaveSnapshot {
   994  			dAtA[i] = 1
   995  		} else {
   996  			dAtA[i] = 0
   997  		}
   998  		i++
   999  	}
  1000  	if m.Mode != 0 {
  1001  		dAtA[i] = 0x18
  1002  		i++
  1003  		i = encodeVarintProposerKv(dAtA, i, uint64(m.Mode))
  1004  	}
  1005  	if m.Checkpoint {
  1006  		dAtA[i] = 0x20
  1007  		i++
  1008  		if m.Checkpoint {
  1009  			dAtA[i] = 1
  1010  		} else {
  1011  			dAtA[i] = 0
  1012  		}
  1013  		i++
  1014  	}
  1015  	if m.Version != 0 {
  1016  		dAtA[i] = 0x28
  1017  		i++
  1018  		i = encodeVarintProposerKv(dAtA, i, uint64(m.Version))
  1019  	}
  1020  	if len(m.Terminate) > 0 {
  1021  		for _, msg := range m.Terminate {
  1022  			dAtA[i] = 0x32
  1023  			i++
  1024  			i = encodeVarintProposerKv(dAtA, i, uint64(msg.Size()))
  1025  			n, err := msg.MarshalTo(dAtA[i:])
  1026  			if err != nil {
  1027  				return 0, err
  1028  			}
  1029  			i += n
  1030  		}
  1031  	}
  1032  	return i, nil
  1033  }
  1034  
  1035  func (m *Compaction) Marshal() (dAtA []byte, err error) {
  1036  	size := m.Size()
  1037  	dAtA = make([]byte, size)
  1038  	n, err := m.MarshalTo(dAtA)
  1039  	if err != nil {
  1040  		return nil, err
  1041  	}
  1042  	return dAtA[:n], nil
  1043  }
  1044  
  1045  func (m *Compaction) MarshalTo(dAtA []byte) (int, error) {
  1046  	var i int
  1047  	_ = i
  1048  	var l int
  1049  	_ = l
  1050  	if m.Bytes != 0 {
  1051  		dAtA[i] = 0x8
  1052  		i++
  1053  		i = encodeVarintProposerKv(dAtA, i, uint64(m.Bytes))
  1054  	}
  1055  	if m.SuggestedAtNanos != 0 {
  1056  		dAtA[i] = 0x10
  1057  		i++
  1058  		i = encodeVarintProposerKv(dAtA, i, uint64(m.SuggestedAtNanos))
  1059  	}
  1060  	return i, nil
  1061  }
  1062  
  1063  func (m *SuggestedCompaction) Marshal() (dAtA []byte, err error) {
  1064  	size := m.Size()
  1065  	dAtA = make([]byte, size)
  1066  	n, err := m.MarshalTo(dAtA)
  1067  	if err != nil {
  1068  		return nil, err
  1069  	}
  1070  	return dAtA[:n], nil
  1071  }
  1072  
  1073  func (m *SuggestedCompaction) MarshalTo(dAtA []byte) (int, error) {
  1074  	var i int
  1075  	_ = i
  1076  	var l int
  1077  	_ = l
  1078  	if len(m.StartKey) > 0 {
  1079  		dAtA[i] = 0xa
  1080  		i++
  1081  		i = encodeVarintProposerKv(dAtA, i, uint64(len(m.StartKey)))
  1082  		i += copy(dAtA[i:], m.StartKey)
  1083  	}
  1084  	if len(m.EndKey) > 0 {
  1085  		dAtA[i] = 0x12
  1086  		i++
  1087  		i = encodeVarintProposerKv(dAtA, i, uint64(len(m.EndKey)))
  1088  		i += copy(dAtA[i:], m.EndKey)
  1089  	}
  1090  	dAtA[i] = 0x1a
  1091  	i++
  1092  	i = encodeVarintProposerKv(dAtA, i, uint64(m.Compaction.Size()))
  1093  	n6, err := m.Compaction.MarshalTo(dAtA[i:])
  1094  	if err != nil {
  1095  		return 0, err
  1096  	}
  1097  	i += n6
  1098  	return i, nil
  1099  }
  1100  
  1101  func (m *ReplicatedEvalResult) Marshal() (dAtA []byte, err error) {
  1102  	size := m.Size()
  1103  	dAtA = make([]byte, size)
  1104  	n, err := m.MarshalTo(dAtA)
  1105  	if err != nil {
  1106  		return nil, err
  1107  	}
  1108  	return dAtA[:n], nil
  1109  }
  1110  
  1111  func (m *ReplicatedEvalResult) MarshalTo(dAtA []byte) (int, error) {
  1112  	var i int
  1113  	_ = i
  1114  	var l int
  1115  	_ = l
  1116  	if m.State != nil {
  1117  		dAtA[i] = 0x12
  1118  		i++
  1119  		i = encodeVarintProposerKv(dAtA, i, uint64(m.State.Size()))
  1120  		n7, err := m.State.MarshalTo(dAtA[i:])
  1121  		if err != nil {
  1122  			return 0, err
  1123  		}
  1124  		i += n7
  1125  	}
  1126  	if m.Split != nil {
  1127  		dAtA[i] = 0x1a
  1128  		i++
  1129  		i = encodeVarintProposerKv(dAtA, i, uint64(m.Split.Size()))
  1130  		n8, err := m.Split.MarshalTo(dAtA[i:])
  1131  		if err != nil {
  1132  			return 0, err
  1133  		}
  1134  		i += n8
  1135  	}
  1136  	if m.Merge != nil {
  1137  		dAtA[i] = 0x22
  1138  		i++
  1139  		i = encodeVarintProposerKv(dAtA, i, uint64(m.Merge.Size()))
  1140  		n9, err := m.Merge.MarshalTo(dAtA[i:])
  1141  		if err != nil {
  1142  			return 0, err
  1143  		}
  1144  		i += n9
  1145  	}
  1146  	if m.IsLeaseRequest {
  1147  		dAtA[i] = 0x30
  1148  		i++
  1149  		if m.IsLeaseRequest {
  1150  			dAtA[i] = 1
  1151  		} else {
  1152  			dAtA[i] = 0
  1153  		}
  1154  		i++
  1155  	}
  1156  	dAtA[i] = 0x42
  1157  	i++
  1158  	i = encodeVarintProposerKv(dAtA, i, uint64(m.Timestamp.Size()))
  1159  	n10, err := m.Timestamp.MarshalTo(dAtA[i:])
  1160  	if err != nil {
  1161  		return 0, err
  1162  	}
  1163  	i += n10
  1164  	if m.DeprecatedDelta != nil {
  1165  		dAtA[i] = 0x52
  1166  		i++
  1167  		i = encodeVarintProposerKv(dAtA, i, uint64(m.DeprecatedDelta.Size()))
  1168  		n11, err := m.DeprecatedDelta.MarshalTo(dAtA[i:])
  1169  		if err != nil {
  1170  			return 0, err
  1171  		}
  1172  		i += n11
  1173  	}
  1174  	if m.ChangeReplicas != nil {
  1175  		dAtA[i] = 0x62
  1176  		i++
  1177  		i = encodeVarintProposerKv(dAtA, i, uint64(m.ChangeReplicas.Size()))
  1178  		n12, err := m.ChangeReplicas.MarshalTo(dAtA[i:])
  1179  		if err != nil {
  1180  			return 0, err
  1181  		}
  1182  		i += n12
  1183  	}
  1184  	if m.RaftLogDelta != 0 {
  1185  		dAtA[i] = 0x68
  1186  		i++
  1187  		i = encodeVarintProposerKv(dAtA, i, uint64(m.RaftLogDelta))
  1188  	}
  1189  	if m.AddSSTable != nil {
  1190  		dAtA[i] = 0x8a
  1191  		i++
  1192  		dAtA[i] = 0x1
  1193  		i++
  1194  		i = encodeVarintProposerKv(dAtA, i, uint64(m.AddSSTable.Size()))
  1195  		n13, err := m.AddSSTable.MarshalTo(dAtA[i:])
  1196  		if err != nil {
  1197  			return 0, err
  1198  		}
  1199  		i += n13
  1200  	}
  1201  	dAtA[i] = 0x92
  1202  	i++
  1203  	dAtA[i] = 0x1
  1204  	i++
  1205  	i = encodeVarintProposerKv(dAtA, i, uint64(m.Delta.Size()))
  1206  	n14, err := m.Delta.MarshalTo(dAtA[i:])
  1207  	if err != nil {
  1208  		return 0, err
  1209  	}
  1210  	i += n14
  1211  	if len(m.SuggestedCompactions) > 0 {
  1212  		for _, msg := range m.SuggestedCompactions {
  1213  			dAtA[i] = 0x9a
  1214  			i++
  1215  			dAtA[i] = 0x1
  1216  			i++
  1217  			i = encodeVarintProposerKv(dAtA, i, uint64(msg.Size()))
  1218  			n, err := msg.MarshalTo(dAtA[i:])
  1219  			if err != nil {
  1220  				return 0, err
  1221  			}
  1222  			i += n
  1223  		}
  1224  	}
  1225  	if m.PrevLeaseProposal != nil {
  1226  		dAtA[i] = 0xa2
  1227  		i++
  1228  		dAtA[i] = 0x1
  1229  		i++
  1230  		i = encodeVarintProposerKv(dAtA, i, uint64(m.PrevLeaseProposal.Size()))
  1231  		n15, err := m.PrevLeaseProposal.MarshalTo(dAtA[i:])
  1232  		if err != nil {
  1233  			return 0, err
  1234  		}
  1235  		i += n15
  1236  	}
  1237  	if m.ComputeChecksum != nil {
  1238  		dAtA[i] = 0xaa
  1239  		i++
  1240  		dAtA[i] = 0x1
  1241  		i++
  1242  		i = encodeVarintProposerKv(dAtA, i, uint64(m.ComputeChecksum.Size()))
  1243  		n16, err := m.ComputeChecksum.MarshalTo(dAtA[i:])
  1244  		if err != nil {
  1245  			return 0, err
  1246  		}
  1247  		i += n16
  1248  	}
  1249  	return i, nil
  1250  }
  1251  
  1252  func (m *ReplicatedEvalResult_AddSSTable) Marshal() (dAtA []byte, err error) {
  1253  	size := m.Size()
  1254  	dAtA = make([]byte, size)
  1255  	n, err := m.MarshalTo(dAtA)
  1256  	if err != nil {
  1257  		return nil, err
  1258  	}
  1259  	return dAtA[:n], nil
  1260  }
  1261  
  1262  func (m *ReplicatedEvalResult_AddSSTable) MarshalTo(dAtA []byte) (int, error) {
  1263  	var i int
  1264  	_ = i
  1265  	var l int
  1266  	_ = l
  1267  	if len(m.Data) > 0 {
  1268  		dAtA[i] = 0xa
  1269  		i++
  1270  		i = encodeVarintProposerKv(dAtA, i, uint64(len(m.Data)))
  1271  		i += copy(dAtA[i:], m.Data)
  1272  	}
  1273  	if m.CRC32 != 0 {
  1274  		dAtA[i] = 0x10
  1275  		i++
  1276  		i = encodeVarintProposerKv(dAtA, i, uint64(m.CRC32))
  1277  	}
  1278  	return i, nil
  1279  }
  1280  
  1281  func (m *WriteBatch) Marshal() (dAtA []byte, err error) {
  1282  	size := m.Size()
  1283  	dAtA = make([]byte, size)
  1284  	n, err := m.MarshalTo(dAtA)
  1285  	if err != nil {
  1286  		return nil, err
  1287  	}
  1288  	return dAtA[:n], nil
  1289  }
  1290  
  1291  func (m *WriteBatch) MarshalTo(dAtA []byte) (int, error) {
  1292  	var i int
  1293  	_ = i
  1294  	var l int
  1295  	_ = l
  1296  	if len(m.Data) > 0 {
  1297  		dAtA[i] = 0xa
  1298  		i++
  1299  		i = encodeVarintProposerKv(dAtA, i, uint64(len(m.Data)))
  1300  		i += copy(dAtA[i:], m.Data)
  1301  	}
  1302  	return i, nil
  1303  }
  1304  
  1305  func (m *LogicalOpLog) Marshal() (dAtA []byte, err error) {
  1306  	size := m.Size()
  1307  	dAtA = make([]byte, size)
  1308  	n, err := m.MarshalTo(dAtA)
  1309  	if err != nil {
  1310  		return nil, err
  1311  	}
  1312  	return dAtA[:n], nil
  1313  }
  1314  
  1315  func (m *LogicalOpLog) MarshalTo(dAtA []byte) (int, error) {
  1316  	var i int
  1317  	_ = i
  1318  	var l int
  1319  	_ = l
  1320  	if len(m.Ops) > 0 {
  1321  		for _, msg := range m.Ops {
  1322  			dAtA[i] = 0xa
  1323  			i++
  1324  			i = encodeVarintProposerKv(dAtA, i, uint64(msg.Size()))
  1325  			n, err := msg.MarshalTo(dAtA[i:])
  1326  			if err != nil {
  1327  				return 0, err
  1328  			}
  1329  			i += n
  1330  		}
  1331  	}
  1332  	return i, nil
  1333  }
  1334  
  1335  func (m *RaftCommand) Marshal() (dAtA []byte, err error) {
  1336  	size := m.Size()
  1337  	dAtA = make([]byte, size)
  1338  	n, err := m.MarshalTo(dAtA)
  1339  	if err != nil {
  1340  		return nil, err
  1341  	}
  1342  	return dAtA[:n], nil
  1343  }
  1344  
  1345  func (m *RaftCommand) MarshalTo(dAtA []byte) (int, error) {
  1346  	var i int
  1347  	_ = i
  1348  	var l int
  1349  	_ = l
  1350  	if m.MaxLeaseIndex != 0 {
  1351  		dAtA[i] = 0x20
  1352  		i++
  1353  		i = encodeVarintProposerKv(dAtA, i, uint64(m.MaxLeaseIndex))
  1354  	}
  1355  	if m.DeprecatedProposerLease != nil {
  1356  		dAtA[i] = 0x2a
  1357  		i++
  1358  		i = encodeVarintProposerKv(dAtA, i, uint64(m.DeprecatedProposerLease.Size()))
  1359  		n17, err := m.DeprecatedProposerLease.MarshalTo(dAtA[i:])
  1360  		if err != nil {
  1361  			return 0, err
  1362  		}
  1363  		i += n17
  1364  	}
  1365  	if m.ProposerLeaseSequence != 0 {
  1366  		dAtA[i] = 0x30
  1367  		i++
  1368  		i = encodeVarintProposerKv(dAtA, i, uint64(m.ProposerLeaseSequence))
  1369  	}
  1370  	dAtA[i] = 0x6a
  1371  	i++
  1372  	i = encodeVarintProposerKv(dAtA, i, uint64(m.ReplicatedEvalResult.Size()))
  1373  	n18, err := m.ReplicatedEvalResult.MarshalTo(dAtA[i:])
  1374  	if err != nil {
  1375  		return 0, err
  1376  	}
  1377  	i += n18
  1378  	if m.WriteBatch != nil {
  1379  		dAtA[i] = 0x72
  1380  		i++
  1381  		i = encodeVarintProposerKv(dAtA, i, uint64(m.WriteBatch.Size()))
  1382  		n19, err := m.WriteBatch.MarshalTo(dAtA[i:])
  1383  		if err != nil {
  1384  			return 0, err
  1385  		}
  1386  		i += n19
  1387  	}
  1388  	if m.LogicalOpLog != nil {
  1389  		dAtA[i] = 0x7a
  1390  		i++
  1391  		i = encodeVarintProposerKv(dAtA, i, uint64(m.LogicalOpLog.Size()))
  1392  		n20, err := m.LogicalOpLog.MarshalTo(dAtA[i:])
  1393  		if err != nil {
  1394  			return 0, err
  1395  		}
  1396  		i += n20
  1397  	}
  1398  	if len(m.TraceData) > 0 {
  1399  		keysForTraceData := make([]string, 0, len(m.TraceData))
  1400  		for k := range m.TraceData {
  1401  			keysForTraceData = append(keysForTraceData, string(k))
  1402  		}
  1403  		github_com_gogo_protobuf_sortkeys.Strings(keysForTraceData)
  1404  		for _, k := range keysForTraceData {
  1405  			dAtA[i] = 0x82
  1406  			i++
  1407  			dAtA[i] = 0x1
  1408  			i++
  1409  			v := m.TraceData[string(k)]
  1410  			mapSize := 1 + len(k) + sovProposerKv(uint64(len(k))) + 1 + len(v) + sovProposerKv(uint64(len(v)))
  1411  			i = encodeVarintProposerKv(dAtA, i, uint64(mapSize))
  1412  			dAtA[i] = 0xa
  1413  			i++
  1414  			i = encodeVarintProposerKv(dAtA, i, uint64(len(k)))
  1415  			i += copy(dAtA[i:], k)
  1416  			dAtA[i] = 0x12
  1417  			i++
  1418  			i = encodeVarintProposerKv(dAtA, i, uint64(len(v)))
  1419  			i += copy(dAtA[i:], v)
  1420  		}
  1421  	}
  1422  	return i, nil
  1423  }
  1424  
  1425  func (m *RaftCommandFooter) Marshal() (dAtA []byte, err error) {
  1426  	size := m.Size()
  1427  	dAtA = make([]byte, size)
  1428  	n, err := m.MarshalTo(dAtA)
  1429  	if err != nil {
  1430  		return nil, err
  1431  	}
  1432  	return dAtA[:n], nil
  1433  }
  1434  
  1435  func (m *RaftCommandFooter) MarshalTo(dAtA []byte) (int, error) {
  1436  	var i int
  1437  	_ = i
  1438  	var l int
  1439  	_ = l
  1440  	if m.MaxLeaseIndex != 0 {
  1441  		dAtA[i] = 0x20
  1442  		i++
  1443  		i = encodeVarintProposerKv(dAtA, i, uint64(m.MaxLeaseIndex))
  1444  	}
  1445  	return i, nil
  1446  }
  1447  
  1448  func encodeVarintProposerKv(dAtA []byte, offset int, v uint64) int {
  1449  	for v >= 1<<7 {
  1450  		dAtA[offset] = uint8(v&0x7f | 0x80)
  1451  		v >>= 7
  1452  		offset++
  1453  	}
  1454  	dAtA[offset] = uint8(v)
  1455  	return offset + 1
  1456  }
  1457  func (m *Split) Size() (n int) {
  1458  	if m == nil {
  1459  		return 0
  1460  	}
  1461  	var l int
  1462  	_ = l
  1463  	l = m.SplitTrigger.Size()
  1464  	n += 1 + l + sovProposerKv(uint64(l))
  1465  	l = m.RHSDelta.Size()
  1466  	n += 1 + l + sovProposerKv(uint64(l))
  1467  	return n
  1468  }
  1469  
  1470  func (m *Merge) Size() (n int) {
  1471  	if m == nil {
  1472  		return 0
  1473  	}
  1474  	var l int
  1475  	_ = l
  1476  	l = m.MergeTrigger.Size()
  1477  	n += 1 + l + sovProposerKv(uint64(l))
  1478  	return n
  1479  }
  1480  
  1481  func (m *ChangeReplicas) Size() (n int) {
  1482  	if m == nil {
  1483  		return 0
  1484  	}
  1485  	var l int
  1486  	_ = l
  1487  	l = m.ChangeReplicasTrigger.Size()
  1488  	n += 1 + l + sovProposerKv(uint64(l))
  1489  	return n
  1490  }
  1491  
  1492  func (m *ComputeChecksum) Size() (n int) {
  1493  	if m == nil {
  1494  		return 0
  1495  	}
  1496  	var l int
  1497  	_ = l
  1498  	l = m.ChecksumID.Size()
  1499  	n += 1 + l + sovProposerKv(uint64(l))
  1500  	if m.SaveSnapshot {
  1501  		n += 2
  1502  	}
  1503  	if m.Mode != 0 {
  1504  		n += 1 + sovProposerKv(uint64(m.Mode))
  1505  	}
  1506  	if m.Checkpoint {
  1507  		n += 2
  1508  	}
  1509  	if m.Version != 0 {
  1510  		n += 1 + sovProposerKv(uint64(m.Version))
  1511  	}
  1512  	if len(m.Terminate) > 0 {
  1513  		for _, e := range m.Terminate {
  1514  			l = e.Size()
  1515  			n += 1 + l + sovProposerKv(uint64(l))
  1516  		}
  1517  	}
  1518  	return n
  1519  }
  1520  
  1521  func (m *Compaction) Size() (n int) {
  1522  	if m == nil {
  1523  		return 0
  1524  	}
  1525  	var l int
  1526  	_ = l
  1527  	if m.Bytes != 0 {
  1528  		n += 1 + sovProposerKv(uint64(m.Bytes))
  1529  	}
  1530  	if m.SuggestedAtNanos != 0 {
  1531  		n += 1 + sovProposerKv(uint64(m.SuggestedAtNanos))
  1532  	}
  1533  	return n
  1534  }
  1535  
  1536  func (m *SuggestedCompaction) Size() (n int) {
  1537  	if m == nil {
  1538  		return 0
  1539  	}
  1540  	var l int
  1541  	_ = l
  1542  	l = len(m.StartKey)
  1543  	if l > 0 {
  1544  		n += 1 + l + sovProposerKv(uint64(l))
  1545  	}
  1546  	l = len(m.EndKey)
  1547  	if l > 0 {
  1548  		n += 1 + l + sovProposerKv(uint64(l))
  1549  	}
  1550  	l = m.Compaction.Size()
  1551  	n += 1 + l + sovProposerKv(uint64(l))
  1552  	return n
  1553  }
  1554  
  1555  func (m *ReplicatedEvalResult) Size() (n int) {
  1556  	if m == nil {
  1557  		return 0
  1558  	}
  1559  	var l int
  1560  	_ = l
  1561  	if m.State != nil {
  1562  		l = m.State.Size()
  1563  		n += 1 + l + sovProposerKv(uint64(l))
  1564  	}
  1565  	if m.Split != nil {
  1566  		l = m.Split.Size()
  1567  		n += 1 + l + sovProposerKv(uint64(l))
  1568  	}
  1569  	if m.Merge != nil {
  1570  		l = m.Merge.Size()
  1571  		n += 1 + l + sovProposerKv(uint64(l))
  1572  	}
  1573  	if m.IsLeaseRequest {
  1574  		n += 2
  1575  	}
  1576  	l = m.Timestamp.Size()
  1577  	n += 1 + l + sovProposerKv(uint64(l))
  1578  	if m.DeprecatedDelta != nil {
  1579  		l = m.DeprecatedDelta.Size()
  1580  		n += 1 + l + sovProposerKv(uint64(l))
  1581  	}
  1582  	if m.ChangeReplicas != nil {
  1583  		l = m.ChangeReplicas.Size()
  1584  		n += 1 + l + sovProposerKv(uint64(l))
  1585  	}
  1586  	if m.RaftLogDelta != 0 {
  1587  		n += 1 + sovProposerKv(uint64(m.RaftLogDelta))
  1588  	}
  1589  	if m.AddSSTable != nil {
  1590  		l = m.AddSSTable.Size()
  1591  		n += 2 + l + sovProposerKv(uint64(l))
  1592  	}
  1593  	l = m.Delta.Size()
  1594  	n += 2 + l + sovProposerKv(uint64(l))
  1595  	if len(m.SuggestedCompactions) > 0 {
  1596  		for _, e := range m.SuggestedCompactions {
  1597  			l = e.Size()
  1598  			n += 2 + l + sovProposerKv(uint64(l))
  1599  		}
  1600  	}
  1601  	if m.PrevLeaseProposal != nil {
  1602  		l = m.PrevLeaseProposal.Size()
  1603  		n += 2 + l + sovProposerKv(uint64(l))
  1604  	}
  1605  	if m.ComputeChecksum != nil {
  1606  		l = m.ComputeChecksum.Size()
  1607  		n += 2 + l + sovProposerKv(uint64(l))
  1608  	}
  1609  	return n
  1610  }
  1611  
  1612  func (m *ReplicatedEvalResult_AddSSTable) Size() (n int) {
  1613  	if m == nil {
  1614  		return 0
  1615  	}
  1616  	var l int
  1617  	_ = l
  1618  	l = len(m.Data)
  1619  	if l > 0 {
  1620  		n += 1 + l + sovProposerKv(uint64(l))
  1621  	}
  1622  	if m.CRC32 != 0 {
  1623  		n += 1 + sovProposerKv(uint64(m.CRC32))
  1624  	}
  1625  	return n
  1626  }
  1627  
  1628  func (m *WriteBatch) Size() (n int) {
  1629  	if m == nil {
  1630  		return 0
  1631  	}
  1632  	var l int
  1633  	_ = l
  1634  	l = len(m.Data)
  1635  	if l > 0 {
  1636  		n += 1 + l + sovProposerKv(uint64(l))
  1637  	}
  1638  	return n
  1639  }
  1640  
  1641  func (m *LogicalOpLog) Size() (n int) {
  1642  	if m == nil {
  1643  		return 0
  1644  	}
  1645  	var l int
  1646  	_ = l
  1647  	if len(m.Ops) > 0 {
  1648  		for _, e := range m.Ops {
  1649  			l = e.Size()
  1650  			n += 1 + l + sovProposerKv(uint64(l))
  1651  		}
  1652  	}
  1653  	return n
  1654  }
  1655  
  1656  func (m *RaftCommand) Size() (n int) {
  1657  	if m == nil {
  1658  		return 0
  1659  	}
  1660  	var l int
  1661  	_ = l
  1662  	if m.MaxLeaseIndex != 0 {
  1663  		n += 1 + sovProposerKv(uint64(m.MaxLeaseIndex))
  1664  	}
  1665  	if m.DeprecatedProposerLease != nil {
  1666  		l = m.DeprecatedProposerLease.Size()
  1667  		n += 1 + l + sovProposerKv(uint64(l))
  1668  	}
  1669  	if m.ProposerLeaseSequence != 0 {
  1670  		n += 1 + sovProposerKv(uint64(m.ProposerLeaseSequence))
  1671  	}
  1672  	l = m.ReplicatedEvalResult.Size()
  1673  	n += 1 + l + sovProposerKv(uint64(l))
  1674  	if m.WriteBatch != nil {
  1675  		l = m.WriteBatch.Size()
  1676  		n += 1 + l + sovProposerKv(uint64(l))
  1677  	}
  1678  	if m.LogicalOpLog != nil {
  1679  		l = m.LogicalOpLog.Size()
  1680  		n += 1 + l + sovProposerKv(uint64(l))
  1681  	}
  1682  	if len(m.TraceData) > 0 {
  1683  		for k, v := range m.TraceData {
  1684  			_ = k
  1685  			_ = v
  1686  			mapEntrySize := 1 + len(k) + sovProposerKv(uint64(len(k))) + 1 + len(v) + sovProposerKv(uint64(len(v)))
  1687  			n += mapEntrySize + 2 + sovProposerKv(uint64(mapEntrySize))
  1688  		}
  1689  	}
  1690  	return n
  1691  }
  1692  
  1693  func (m *RaftCommandFooter) Size() (n int) {
  1694  	if m == nil {
  1695  		return 0
  1696  	}
  1697  	var l int
  1698  	_ = l
  1699  	if m.MaxLeaseIndex != 0 {
  1700  		n += 1 + sovProposerKv(uint64(m.MaxLeaseIndex))
  1701  	}
  1702  	return n
  1703  }
  1704  
  1705  func sovProposerKv(x uint64) (n int) {
  1706  	for {
  1707  		n++
  1708  		x >>= 7
  1709  		if x == 0 {
  1710  			break
  1711  		}
  1712  	}
  1713  	return n
  1714  }
  1715  func sozProposerKv(x uint64) (n int) {
  1716  	return sovProposerKv(uint64((x << 1) ^ uint64((int64(x) >> 63))))
  1717  }
  1718  func (m *Split) Unmarshal(dAtA []byte) error {
  1719  	l := len(dAtA)
  1720  	iNdEx := 0
  1721  	for iNdEx < l {
  1722  		preIndex := iNdEx
  1723  		var wire uint64
  1724  		for shift := uint(0); ; shift += 7 {
  1725  			if shift >= 64 {
  1726  				return ErrIntOverflowProposerKv
  1727  			}
  1728  			if iNdEx >= l {
  1729  				return io.ErrUnexpectedEOF
  1730  			}
  1731  			b := dAtA[iNdEx]
  1732  			iNdEx++
  1733  			wire |= (uint64(b) & 0x7F) << shift
  1734  			if b < 0x80 {
  1735  				break
  1736  			}
  1737  		}
  1738  		fieldNum := int32(wire >> 3)
  1739  		wireType := int(wire & 0x7)
  1740  		if wireType == 4 {
  1741  			return fmt.Errorf("proto: Split: wiretype end group for non-group")
  1742  		}
  1743  		if fieldNum <= 0 {
  1744  			return fmt.Errorf("proto: Split: illegal tag %d (wire type %d)", fieldNum, wire)
  1745  		}
  1746  		switch fieldNum {
  1747  		case 1:
  1748  			if wireType != 2 {
  1749  				return fmt.Errorf("proto: wrong wireType = %d for field SplitTrigger", wireType)
  1750  			}
  1751  			var msglen int
  1752  			for shift := uint(0); ; shift += 7 {
  1753  				if shift >= 64 {
  1754  					return ErrIntOverflowProposerKv
  1755  				}
  1756  				if iNdEx >= l {
  1757  					return io.ErrUnexpectedEOF
  1758  				}
  1759  				b := dAtA[iNdEx]
  1760  				iNdEx++
  1761  				msglen |= (int(b) & 0x7F) << shift
  1762  				if b < 0x80 {
  1763  					break
  1764  				}
  1765  			}
  1766  			if msglen < 0 {
  1767  				return ErrInvalidLengthProposerKv
  1768  			}
  1769  			postIndex := iNdEx + msglen
  1770  			if postIndex > l {
  1771  				return io.ErrUnexpectedEOF
  1772  			}
  1773  			if err := m.SplitTrigger.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1774  				return err
  1775  			}
  1776  			iNdEx = postIndex
  1777  		case 2:
  1778  			if wireType != 2 {
  1779  				return fmt.Errorf("proto: wrong wireType = %d for field RHSDelta", wireType)
  1780  			}
  1781  			var msglen int
  1782  			for shift := uint(0); ; shift += 7 {
  1783  				if shift >= 64 {
  1784  					return ErrIntOverflowProposerKv
  1785  				}
  1786  				if iNdEx >= l {
  1787  					return io.ErrUnexpectedEOF
  1788  				}
  1789  				b := dAtA[iNdEx]
  1790  				iNdEx++
  1791  				msglen |= (int(b) & 0x7F) << shift
  1792  				if b < 0x80 {
  1793  					break
  1794  				}
  1795  			}
  1796  			if msglen < 0 {
  1797  				return ErrInvalidLengthProposerKv
  1798  			}
  1799  			postIndex := iNdEx + msglen
  1800  			if postIndex > l {
  1801  				return io.ErrUnexpectedEOF
  1802  			}
  1803  			if err := m.RHSDelta.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1804  				return err
  1805  			}
  1806  			iNdEx = postIndex
  1807  		default:
  1808  			iNdEx = preIndex
  1809  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  1810  			if err != nil {
  1811  				return err
  1812  			}
  1813  			if skippy < 0 {
  1814  				return ErrInvalidLengthProposerKv
  1815  			}
  1816  			if (iNdEx + skippy) > l {
  1817  				return io.ErrUnexpectedEOF
  1818  			}
  1819  			iNdEx += skippy
  1820  		}
  1821  	}
  1822  
  1823  	if iNdEx > l {
  1824  		return io.ErrUnexpectedEOF
  1825  	}
  1826  	return nil
  1827  }
  1828  func (m *Merge) Unmarshal(dAtA []byte) error {
  1829  	l := len(dAtA)
  1830  	iNdEx := 0
  1831  	for iNdEx < l {
  1832  		preIndex := iNdEx
  1833  		var wire uint64
  1834  		for shift := uint(0); ; shift += 7 {
  1835  			if shift >= 64 {
  1836  				return ErrIntOverflowProposerKv
  1837  			}
  1838  			if iNdEx >= l {
  1839  				return io.ErrUnexpectedEOF
  1840  			}
  1841  			b := dAtA[iNdEx]
  1842  			iNdEx++
  1843  			wire |= (uint64(b) & 0x7F) << shift
  1844  			if b < 0x80 {
  1845  				break
  1846  			}
  1847  		}
  1848  		fieldNum := int32(wire >> 3)
  1849  		wireType := int(wire & 0x7)
  1850  		if wireType == 4 {
  1851  			return fmt.Errorf("proto: Merge: wiretype end group for non-group")
  1852  		}
  1853  		if fieldNum <= 0 {
  1854  			return fmt.Errorf("proto: Merge: illegal tag %d (wire type %d)", fieldNum, wire)
  1855  		}
  1856  		switch fieldNum {
  1857  		case 1:
  1858  			if wireType != 2 {
  1859  				return fmt.Errorf("proto: wrong wireType = %d for field MergeTrigger", wireType)
  1860  			}
  1861  			var msglen int
  1862  			for shift := uint(0); ; shift += 7 {
  1863  				if shift >= 64 {
  1864  					return ErrIntOverflowProposerKv
  1865  				}
  1866  				if iNdEx >= l {
  1867  					return io.ErrUnexpectedEOF
  1868  				}
  1869  				b := dAtA[iNdEx]
  1870  				iNdEx++
  1871  				msglen |= (int(b) & 0x7F) << shift
  1872  				if b < 0x80 {
  1873  					break
  1874  				}
  1875  			}
  1876  			if msglen < 0 {
  1877  				return ErrInvalidLengthProposerKv
  1878  			}
  1879  			postIndex := iNdEx + msglen
  1880  			if postIndex > l {
  1881  				return io.ErrUnexpectedEOF
  1882  			}
  1883  			if err := m.MergeTrigger.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1884  				return err
  1885  			}
  1886  			iNdEx = postIndex
  1887  		default:
  1888  			iNdEx = preIndex
  1889  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  1890  			if err != nil {
  1891  				return err
  1892  			}
  1893  			if skippy < 0 {
  1894  				return ErrInvalidLengthProposerKv
  1895  			}
  1896  			if (iNdEx + skippy) > l {
  1897  				return io.ErrUnexpectedEOF
  1898  			}
  1899  			iNdEx += skippy
  1900  		}
  1901  	}
  1902  
  1903  	if iNdEx > l {
  1904  		return io.ErrUnexpectedEOF
  1905  	}
  1906  	return nil
  1907  }
  1908  func (m *ChangeReplicas) Unmarshal(dAtA []byte) error {
  1909  	l := len(dAtA)
  1910  	iNdEx := 0
  1911  	for iNdEx < l {
  1912  		preIndex := iNdEx
  1913  		var wire uint64
  1914  		for shift := uint(0); ; shift += 7 {
  1915  			if shift >= 64 {
  1916  				return ErrIntOverflowProposerKv
  1917  			}
  1918  			if iNdEx >= l {
  1919  				return io.ErrUnexpectedEOF
  1920  			}
  1921  			b := dAtA[iNdEx]
  1922  			iNdEx++
  1923  			wire |= (uint64(b) & 0x7F) << shift
  1924  			if b < 0x80 {
  1925  				break
  1926  			}
  1927  		}
  1928  		fieldNum := int32(wire >> 3)
  1929  		wireType := int(wire & 0x7)
  1930  		if wireType == 4 {
  1931  			return fmt.Errorf("proto: ChangeReplicas: wiretype end group for non-group")
  1932  		}
  1933  		if fieldNum <= 0 {
  1934  			return fmt.Errorf("proto: ChangeReplicas: illegal tag %d (wire type %d)", fieldNum, wire)
  1935  		}
  1936  		switch fieldNum {
  1937  		case 1:
  1938  			if wireType != 2 {
  1939  				return fmt.Errorf("proto: wrong wireType = %d for field ChangeReplicasTrigger", wireType)
  1940  			}
  1941  			var msglen int
  1942  			for shift := uint(0); ; shift += 7 {
  1943  				if shift >= 64 {
  1944  					return ErrIntOverflowProposerKv
  1945  				}
  1946  				if iNdEx >= l {
  1947  					return io.ErrUnexpectedEOF
  1948  				}
  1949  				b := dAtA[iNdEx]
  1950  				iNdEx++
  1951  				msglen |= (int(b) & 0x7F) << shift
  1952  				if b < 0x80 {
  1953  					break
  1954  				}
  1955  			}
  1956  			if msglen < 0 {
  1957  				return ErrInvalidLengthProposerKv
  1958  			}
  1959  			postIndex := iNdEx + msglen
  1960  			if postIndex > l {
  1961  				return io.ErrUnexpectedEOF
  1962  			}
  1963  			if err := m.ChangeReplicasTrigger.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1964  				return err
  1965  			}
  1966  			iNdEx = postIndex
  1967  		default:
  1968  			iNdEx = preIndex
  1969  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  1970  			if err != nil {
  1971  				return err
  1972  			}
  1973  			if skippy < 0 {
  1974  				return ErrInvalidLengthProposerKv
  1975  			}
  1976  			if (iNdEx + skippy) > l {
  1977  				return io.ErrUnexpectedEOF
  1978  			}
  1979  			iNdEx += skippy
  1980  		}
  1981  	}
  1982  
  1983  	if iNdEx > l {
  1984  		return io.ErrUnexpectedEOF
  1985  	}
  1986  	return nil
  1987  }
  1988  func (m *ComputeChecksum) Unmarshal(dAtA []byte) error {
  1989  	l := len(dAtA)
  1990  	iNdEx := 0
  1991  	for iNdEx < l {
  1992  		preIndex := iNdEx
  1993  		var wire uint64
  1994  		for shift := uint(0); ; shift += 7 {
  1995  			if shift >= 64 {
  1996  				return ErrIntOverflowProposerKv
  1997  			}
  1998  			if iNdEx >= l {
  1999  				return io.ErrUnexpectedEOF
  2000  			}
  2001  			b := dAtA[iNdEx]
  2002  			iNdEx++
  2003  			wire |= (uint64(b) & 0x7F) << shift
  2004  			if b < 0x80 {
  2005  				break
  2006  			}
  2007  		}
  2008  		fieldNum := int32(wire >> 3)
  2009  		wireType := int(wire & 0x7)
  2010  		if wireType == 4 {
  2011  			return fmt.Errorf("proto: ComputeChecksum: wiretype end group for non-group")
  2012  		}
  2013  		if fieldNum <= 0 {
  2014  			return fmt.Errorf("proto: ComputeChecksum: illegal tag %d (wire type %d)", fieldNum, wire)
  2015  		}
  2016  		switch fieldNum {
  2017  		case 1:
  2018  			if wireType != 2 {
  2019  				return fmt.Errorf("proto: wrong wireType = %d for field ChecksumID", wireType)
  2020  			}
  2021  			var byteLen int
  2022  			for shift := uint(0); ; shift += 7 {
  2023  				if shift >= 64 {
  2024  					return ErrIntOverflowProposerKv
  2025  				}
  2026  				if iNdEx >= l {
  2027  					return io.ErrUnexpectedEOF
  2028  				}
  2029  				b := dAtA[iNdEx]
  2030  				iNdEx++
  2031  				byteLen |= (int(b) & 0x7F) << shift
  2032  				if b < 0x80 {
  2033  					break
  2034  				}
  2035  			}
  2036  			if byteLen < 0 {
  2037  				return ErrInvalidLengthProposerKv
  2038  			}
  2039  			postIndex := iNdEx + byteLen
  2040  			if postIndex > l {
  2041  				return io.ErrUnexpectedEOF
  2042  			}
  2043  			if err := m.ChecksumID.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2044  				return err
  2045  			}
  2046  			iNdEx = postIndex
  2047  		case 2:
  2048  			if wireType != 0 {
  2049  				return fmt.Errorf("proto: wrong wireType = %d for field SaveSnapshot", wireType)
  2050  			}
  2051  			var v int
  2052  			for shift := uint(0); ; shift += 7 {
  2053  				if shift >= 64 {
  2054  					return ErrIntOverflowProposerKv
  2055  				}
  2056  				if iNdEx >= l {
  2057  					return io.ErrUnexpectedEOF
  2058  				}
  2059  				b := dAtA[iNdEx]
  2060  				iNdEx++
  2061  				v |= (int(b) & 0x7F) << shift
  2062  				if b < 0x80 {
  2063  					break
  2064  				}
  2065  			}
  2066  			m.SaveSnapshot = bool(v != 0)
  2067  		case 3:
  2068  			if wireType != 0 {
  2069  				return fmt.Errorf("proto: wrong wireType = %d for field Mode", wireType)
  2070  			}
  2071  			m.Mode = 0
  2072  			for shift := uint(0); ; shift += 7 {
  2073  				if shift >= 64 {
  2074  					return ErrIntOverflowProposerKv
  2075  				}
  2076  				if iNdEx >= l {
  2077  					return io.ErrUnexpectedEOF
  2078  				}
  2079  				b := dAtA[iNdEx]
  2080  				iNdEx++
  2081  				m.Mode |= (roachpb.ChecksumMode(b) & 0x7F) << shift
  2082  				if b < 0x80 {
  2083  					break
  2084  				}
  2085  			}
  2086  		case 4:
  2087  			if wireType != 0 {
  2088  				return fmt.Errorf("proto: wrong wireType = %d for field Checkpoint", wireType)
  2089  			}
  2090  			var v int
  2091  			for shift := uint(0); ; shift += 7 {
  2092  				if shift >= 64 {
  2093  					return ErrIntOverflowProposerKv
  2094  				}
  2095  				if iNdEx >= l {
  2096  					return io.ErrUnexpectedEOF
  2097  				}
  2098  				b := dAtA[iNdEx]
  2099  				iNdEx++
  2100  				v |= (int(b) & 0x7F) << shift
  2101  				if b < 0x80 {
  2102  					break
  2103  				}
  2104  			}
  2105  			m.Checkpoint = bool(v != 0)
  2106  		case 5:
  2107  			if wireType != 0 {
  2108  				return fmt.Errorf("proto: wrong wireType = %d for field Version", wireType)
  2109  			}
  2110  			m.Version = 0
  2111  			for shift := uint(0); ; shift += 7 {
  2112  				if shift >= 64 {
  2113  					return ErrIntOverflowProposerKv
  2114  				}
  2115  				if iNdEx >= l {
  2116  					return io.ErrUnexpectedEOF
  2117  				}
  2118  				b := dAtA[iNdEx]
  2119  				iNdEx++
  2120  				m.Version |= (uint32(b) & 0x7F) << shift
  2121  				if b < 0x80 {
  2122  					break
  2123  				}
  2124  			}
  2125  		case 6:
  2126  			if wireType != 2 {
  2127  				return fmt.Errorf("proto: wrong wireType = %d for field Terminate", wireType)
  2128  			}
  2129  			var msglen int
  2130  			for shift := uint(0); ; shift += 7 {
  2131  				if shift >= 64 {
  2132  					return ErrIntOverflowProposerKv
  2133  				}
  2134  				if iNdEx >= l {
  2135  					return io.ErrUnexpectedEOF
  2136  				}
  2137  				b := dAtA[iNdEx]
  2138  				iNdEx++
  2139  				msglen |= (int(b) & 0x7F) << shift
  2140  				if b < 0x80 {
  2141  					break
  2142  				}
  2143  			}
  2144  			if msglen < 0 {
  2145  				return ErrInvalidLengthProposerKv
  2146  			}
  2147  			postIndex := iNdEx + msglen
  2148  			if postIndex > l {
  2149  				return io.ErrUnexpectedEOF
  2150  			}
  2151  			m.Terminate = append(m.Terminate, roachpb.ReplicaDescriptor{})
  2152  			if err := m.Terminate[len(m.Terminate)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2153  				return err
  2154  			}
  2155  			iNdEx = postIndex
  2156  		default:
  2157  			iNdEx = preIndex
  2158  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  2159  			if err != nil {
  2160  				return err
  2161  			}
  2162  			if skippy < 0 {
  2163  				return ErrInvalidLengthProposerKv
  2164  			}
  2165  			if (iNdEx + skippy) > l {
  2166  				return io.ErrUnexpectedEOF
  2167  			}
  2168  			iNdEx += skippy
  2169  		}
  2170  	}
  2171  
  2172  	if iNdEx > l {
  2173  		return io.ErrUnexpectedEOF
  2174  	}
  2175  	return nil
  2176  }
  2177  func (m *Compaction) Unmarshal(dAtA []byte) error {
  2178  	l := len(dAtA)
  2179  	iNdEx := 0
  2180  	for iNdEx < l {
  2181  		preIndex := iNdEx
  2182  		var wire uint64
  2183  		for shift := uint(0); ; shift += 7 {
  2184  			if shift >= 64 {
  2185  				return ErrIntOverflowProposerKv
  2186  			}
  2187  			if iNdEx >= l {
  2188  				return io.ErrUnexpectedEOF
  2189  			}
  2190  			b := dAtA[iNdEx]
  2191  			iNdEx++
  2192  			wire |= (uint64(b) & 0x7F) << shift
  2193  			if b < 0x80 {
  2194  				break
  2195  			}
  2196  		}
  2197  		fieldNum := int32(wire >> 3)
  2198  		wireType := int(wire & 0x7)
  2199  		if wireType == 4 {
  2200  			return fmt.Errorf("proto: Compaction: wiretype end group for non-group")
  2201  		}
  2202  		if fieldNum <= 0 {
  2203  			return fmt.Errorf("proto: Compaction: illegal tag %d (wire type %d)", fieldNum, wire)
  2204  		}
  2205  		switch fieldNum {
  2206  		case 1:
  2207  			if wireType != 0 {
  2208  				return fmt.Errorf("proto: wrong wireType = %d for field Bytes", wireType)
  2209  			}
  2210  			m.Bytes = 0
  2211  			for shift := uint(0); ; shift += 7 {
  2212  				if shift >= 64 {
  2213  					return ErrIntOverflowProposerKv
  2214  				}
  2215  				if iNdEx >= l {
  2216  					return io.ErrUnexpectedEOF
  2217  				}
  2218  				b := dAtA[iNdEx]
  2219  				iNdEx++
  2220  				m.Bytes |= (int64(b) & 0x7F) << shift
  2221  				if b < 0x80 {
  2222  					break
  2223  				}
  2224  			}
  2225  		case 2:
  2226  			if wireType != 0 {
  2227  				return fmt.Errorf("proto: wrong wireType = %d for field SuggestedAtNanos", wireType)
  2228  			}
  2229  			m.SuggestedAtNanos = 0
  2230  			for shift := uint(0); ; shift += 7 {
  2231  				if shift >= 64 {
  2232  					return ErrIntOverflowProposerKv
  2233  				}
  2234  				if iNdEx >= l {
  2235  					return io.ErrUnexpectedEOF
  2236  				}
  2237  				b := dAtA[iNdEx]
  2238  				iNdEx++
  2239  				m.SuggestedAtNanos |= (int64(b) & 0x7F) << shift
  2240  				if b < 0x80 {
  2241  					break
  2242  				}
  2243  			}
  2244  		default:
  2245  			iNdEx = preIndex
  2246  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  2247  			if err != nil {
  2248  				return err
  2249  			}
  2250  			if skippy < 0 {
  2251  				return ErrInvalidLengthProposerKv
  2252  			}
  2253  			if (iNdEx + skippy) > l {
  2254  				return io.ErrUnexpectedEOF
  2255  			}
  2256  			iNdEx += skippy
  2257  		}
  2258  	}
  2259  
  2260  	if iNdEx > l {
  2261  		return io.ErrUnexpectedEOF
  2262  	}
  2263  	return nil
  2264  }
  2265  func (m *SuggestedCompaction) Unmarshal(dAtA []byte) error {
  2266  	l := len(dAtA)
  2267  	iNdEx := 0
  2268  	for iNdEx < l {
  2269  		preIndex := iNdEx
  2270  		var wire uint64
  2271  		for shift := uint(0); ; shift += 7 {
  2272  			if shift >= 64 {
  2273  				return ErrIntOverflowProposerKv
  2274  			}
  2275  			if iNdEx >= l {
  2276  				return io.ErrUnexpectedEOF
  2277  			}
  2278  			b := dAtA[iNdEx]
  2279  			iNdEx++
  2280  			wire |= (uint64(b) & 0x7F) << shift
  2281  			if b < 0x80 {
  2282  				break
  2283  			}
  2284  		}
  2285  		fieldNum := int32(wire >> 3)
  2286  		wireType := int(wire & 0x7)
  2287  		if wireType == 4 {
  2288  			return fmt.Errorf("proto: SuggestedCompaction: wiretype end group for non-group")
  2289  		}
  2290  		if fieldNum <= 0 {
  2291  			return fmt.Errorf("proto: SuggestedCompaction: illegal tag %d (wire type %d)", fieldNum, wire)
  2292  		}
  2293  		switch fieldNum {
  2294  		case 1:
  2295  			if wireType != 2 {
  2296  				return fmt.Errorf("proto: wrong wireType = %d for field StartKey", wireType)
  2297  			}
  2298  			var byteLen int
  2299  			for shift := uint(0); ; shift += 7 {
  2300  				if shift >= 64 {
  2301  					return ErrIntOverflowProposerKv
  2302  				}
  2303  				if iNdEx >= l {
  2304  					return io.ErrUnexpectedEOF
  2305  				}
  2306  				b := dAtA[iNdEx]
  2307  				iNdEx++
  2308  				byteLen |= (int(b) & 0x7F) << shift
  2309  				if b < 0x80 {
  2310  					break
  2311  				}
  2312  			}
  2313  			if byteLen < 0 {
  2314  				return ErrInvalidLengthProposerKv
  2315  			}
  2316  			postIndex := iNdEx + byteLen
  2317  			if postIndex > l {
  2318  				return io.ErrUnexpectedEOF
  2319  			}
  2320  			m.StartKey = append(m.StartKey[:0], dAtA[iNdEx:postIndex]...)
  2321  			if m.StartKey == nil {
  2322  				m.StartKey = []byte{}
  2323  			}
  2324  			iNdEx = postIndex
  2325  		case 2:
  2326  			if wireType != 2 {
  2327  				return fmt.Errorf("proto: wrong wireType = %d for field EndKey", wireType)
  2328  			}
  2329  			var byteLen int
  2330  			for shift := uint(0); ; shift += 7 {
  2331  				if shift >= 64 {
  2332  					return ErrIntOverflowProposerKv
  2333  				}
  2334  				if iNdEx >= l {
  2335  					return io.ErrUnexpectedEOF
  2336  				}
  2337  				b := dAtA[iNdEx]
  2338  				iNdEx++
  2339  				byteLen |= (int(b) & 0x7F) << shift
  2340  				if b < 0x80 {
  2341  					break
  2342  				}
  2343  			}
  2344  			if byteLen < 0 {
  2345  				return ErrInvalidLengthProposerKv
  2346  			}
  2347  			postIndex := iNdEx + byteLen
  2348  			if postIndex > l {
  2349  				return io.ErrUnexpectedEOF
  2350  			}
  2351  			m.EndKey = append(m.EndKey[:0], dAtA[iNdEx:postIndex]...)
  2352  			if m.EndKey == nil {
  2353  				m.EndKey = []byte{}
  2354  			}
  2355  			iNdEx = postIndex
  2356  		case 3:
  2357  			if wireType != 2 {
  2358  				return fmt.Errorf("proto: wrong wireType = %d for field Compaction", wireType)
  2359  			}
  2360  			var msglen int
  2361  			for shift := uint(0); ; shift += 7 {
  2362  				if shift >= 64 {
  2363  					return ErrIntOverflowProposerKv
  2364  				}
  2365  				if iNdEx >= l {
  2366  					return io.ErrUnexpectedEOF
  2367  				}
  2368  				b := dAtA[iNdEx]
  2369  				iNdEx++
  2370  				msglen |= (int(b) & 0x7F) << shift
  2371  				if b < 0x80 {
  2372  					break
  2373  				}
  2374  			}
  2375  			if msglen < 0 {
  2376  				return ErrInvalidLengthProposerKv
  2377  			}
  2378  			postIndex := iNdEx + msglen
  2379  			if postIndex > l {
  2380  				return io.ErrUnexpectedEOF
  2381  			}
  2382  			if err := m.Compaction.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2383  				return err
  2384  			}
  2385  			iNdEx = postIndex
  2386  		default:
  2387  			iNdEx = preIndex
  2388  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  2389  			if err != nil {
  2390  				return err
  2391  			}
  2392  			if skippy < 0 {
  2393  				return ErrInvalidLengthProposerKv
  2394  			}
  2395  			if (iNdEx + skippy) > l {
  2396  				return io.ErrUnexpectedEOF
  2397  			}
  2398  			iNdEx += skippy
  2399  		}
  2400  	}
  2401  
  2402  	if iNdEx > l {
  2403  		return io.ErrUnexpectedEOF
  2404  	}
  2405  	return nil
  2406  }
  2407  func (m *ReplicatedEvalResult) Unmarshal(dAtA []byte) error {
  2408  	l := len(dAtA)
  2409  	iNdEx := 0
  2410  	for iNdEx < l {
  2411  		preIndex := iNdEx
  2412  		var wire uint64
  2413  		for shift := uint(0); ; shift += 7 {
  2414  			if shift >= 64 {
  2415  				return ErrIntOverflowProposerKv
  2416  			}
  2417  			if iNdEx >= l {
  2418  				return io.ErrUnexpectedEOF
  2419  			}
  2420  			b := dAtA[iNdEx]
  2421  			iNdEx++
  2422  			wire |= (uint64(b) & 0x7F) << shift
  2423  			if b < 0x80 {
  2424  				break
  2425  			}
  2426  		}
  2427  		fieldNum := int32(wire >> 3)
  2428  		wireType := int(wire & 0x7)
  2429  		if wireType == 4 {
  2430  			return fmt.Errorf("proto: ReplicatedEvalResult: wiretype end group for non-group")
  2431  		}
  2432  		if fieldNum <= 0 {
  2433  			return fmt.Errorf("proto: ReplicatedEvalResult: illegal tag %d (wire type %d)", fieldNum, wire)
  2434  		}
  2435  		switch fieldNum {
  2436  		case 2:
  2437  			if wireType != 2 {
  2438  				return fmt.Errorf("proto: wrong wireType = %d for field State", wireType)
  2439  			}
  2440  			var msglen int
  2441  			for shift := uint(0); ; shift += 7 {
  2442  				if shift >= 64 {
  2443  					return ErrIntOverflowProposerKv
  2444  				}
  2445  				if iNdEx >= l {
  2446  					return io.ErrUnexpectedEOF
  2447  				}
  2448  				b := dAtA[iNdEx]
  2449  				iNdEx++
  2450  				msglen |= (int(b) & 0x7F) << shift
  2451  				if b < 0x80 {
  2452  					break
  2453  				}
  2454  			}
  2455  			if msglen < 0 {
  2456  				return ErrInvalidLengthProposerKv
  2457  			}
  2458  			postIndex := iNdEx + msglen
  2459  			if postIndex > l {
  2460  				return io.ErrUnexpectedEOF
  2461  			}
  2462  			if m.State == nil {
  2463  				m.State = &ReplicaState{}
  2464  			}
  2465  			if err := m.State.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2466  				return err
  2467  			}
  2468  			iNdEx = postIndex
  2469  		case 3:
  2470  			if wireType != 2 {
  2471  				return fmt.Errorf("proto: wrong wireType = %d for field Split", wireType)
  2472  			}
  2473  			var msglen int
  2474  			for shift := uint(0); ; shift += 7 {
  2475  				if shift >= 64 {
  2476  					return ErrIntOverflowProposerKv
  2477  				}
  2478  				if iNdEx >= l {
  2479  					return io.ErrUnexpectedEOF
  2480  				}
  2481  				b := dAtA[iNdEx]
  2482  				iNdEx++
  2483  				msglen |= (int(b) & 0x7F) << shift
  2484  				if b < 0x80 {
  2485  					break
  2486  				}
  2487  			}
  2488  			if msglen < 0 {
  2489  				return ErrInvalidLengthProposerKv
  2490  			}
  2491  			postIndex := iNdEx + msglen
  2492  			if postIndex > l {
  2493  				return io.ErrUnexpectedEOF
  2494  			}
  2495  			if m.Split == nil {
  2496  				m.Split = &Split{}
  2497  			}
  2498  			if err := m.Split.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2499  				return err
  2500  			}
  2501  			iNdEx = postIndex
  2502  		case 4:
  2503  			if wireType != 2 {
  2504  				return fmt.Errorf("proto: wrong wireType = %d for field Merge", wireType)
  2505  			}
  2506  			var msglen int
  2507  			for shift := uint(0); ; shift += 7 {
  2508  				if shift >= 64 {
  2509  					return ErrIntOverflowProposerKv
  2510  				}
  2511  				if iNdEx >= l {
  2512  					return io.ErrUnexpectedEOF
  2513  				}
  2514  				b := dAtA[iNdEx]
  2515  				iNdEx++
  2516  				msglen |= (int(b) & 0x7F) << shift
  2517  				if b < 0x80 {
  2518  					break
  2519  				}
  2520  			}
  2521  			if msglen < 0 {
  2522  				return ErrInvalidLengthProposerKv
  2523  			}
  2524  			postIndex := iNdEx + msglen
  2525  			if postIndex > l {
  2526  				return io.ErrUnexpectedEOF
  2527  			}
  2528  			if m.Merge == nil {
  2529  				m.Merge = &Merge{}
  2530  			}
  2531  			if err := m.Merge.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2532  				return err
  2533  			}
  2534  			iNdEx = postIndex
  2535  		case 6:
  2536  			if wireType != 0 {
  2537  				return fmt.Errorf("proto: wrong wireType = %d for field IsLeaseRequest", wireType)
  2538  			}
  2539  			var v int
  2540  			for shift := uint(0); ; shift += 7 {
  2541  				if shift >= 64 {
  2542  					return ErrIntOverflowProposerKv
  2543  				}
  2544  				if iNdEx >= l {
  2545  					return io.ErrUnexpectedEOF
  2546  				}
  2547  				b := dAtA[iNdEx]
  2548  				iNdEx++
  2549  				v |= (int(b) & 0x7F) << shift
  2550  				if b < 0x80 {
  2551  					break
  2552  				}
  2553  			}
  2554  			m.IsLeaseRequest = bool(v != 0)
  2555  		case 8:
  2556  			if wireType != 2 {
  2557  				return fmt.Errorf("proto: wrong wireType = %d for field Timestamp", wireType)
  2558  			}
  2559  			var msglen int
  2560  			for shift := uint(0); ; shift += 7 {
  2561  				if shift >= 64 {
  2562  					return ErrIntOverflowProposerKv
  2563  				}
  2564  				if iNdEx >= l {
  2565  					return io.ErrUnexpectedEOF
  2566  				}
  2567  				b := dAtA[iNdEx]
  2568  				iNdEx++
  2569  				msglen |= (int(b) & 0x7F) << shift
  2570  				if b < 0x80 {
  2571  					break
  2572  				}
  2573  			}
  2574  			if msglen < 0 {
  2575  				return ErrInvalidLengthProposerKv
  2576  			}
  2577  			postIndex := iNdEx + msglen
  2578  			if postIndex > l {
  2579  				return io.ErrUnexpectedEOF
  2580  			}
  2581  			if err := m.Timestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2582  				return err
  2583  			}
  2584  			iNdEx = postIndex
  2585  		case 10:
  2586  			if wireType != 2 {
  2587  				return fmt.Errorf("proto: wrong wireType = %d for field DeprecatedDelta", wireType)
  2588  			}
  2589  			var msglen int
  2590  			for shift := uint(0); ; shift += 7 {
  2591  				if shift >= 64 {
  2592  					return ErrIntOverflowProposerKv
  2593  				}
  2594  				if iNdEx >= l {
  2595  					return io.ErrUnexpectedEOF
  2596  				}
  2597  				b := dAtA[iNdEx]
  2598  				iNdEx++
  2599  				msglen |= (int(b) & 0x7F) << shift
  2600  				if b < 0x80 {
  2601  					break
  2602  				}
  2603  			}
  2604  			if msglen < 0 {
  2605  				return ErrInvalidLengthProposerKv
  2606  			}
  2607  			postIndex := iNdEx + msglen
  2608  			if postIndex > l {
  2609  				return io.ErrUnexpectedEOF
  2610  			}
  2611  			if m.DeprecatedDelta == nil {
  2612  				m.DeprecatedDelta = &enginepb.MVCCStats{}
  2613  			}
  2614  			if err := m.DeprecatedDelta.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2615  				return err
  2616  			}
  2617  			iNdEx = postIndex
  2618  		case 12:
  2619  			if wireType != 2 {
  2620  				return fmt.Errorf("proto: wrong wireType = %d for field ChangeReplicas", wireType)
  2621  			}
  2622  			var msglen int
  2623  			for shift := uint(0); ; shift += 7 {
  2624  				if shift >= 64 {
  2625  					return ErrIntOverflowProposerKv
  2626  				}
  2627  				if iNdEx >= l {
  2628  					return io.ErrUnexpectedEOF
  2629  				}
  2630  				b := dAtA[iNdEx]
  2631  				iNdEx++
  2632  				msglen |= (int(b) & 0x7F) << shift
  2633  				if b < 0x80 {
  2634  					break
  2635  				}
  2636  			}
  2637  			if msglen < 0 {
  2638  				return ErrInvalidLengthProposerKv
  2639  			}
  2640  			postIndex := iNdEx + msglen
  2641  			if postIndex > l {
  2642  				return io.ErrUnexpectedEOF
  2643  			}
  2644  			if m.ChangeReplicas == nil {
  2645  				m.ChangeReplicas = &ChangeReplicas{}
  2646  			}
  2647  			if err := m.ChangeReplicas.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2648  				return err
  2649  			}
  2650  			iNdEx = postIndex
  2651  		case 13:
  2652  			if wireType != 0 {
  2653  				return fmt.Errorf("proto: wrong wireType = %d for field RaftLogDelta", wireType)
  2654  			}
  2655  			m.RaftLogDelta = 0
  2656  			for shift := uint(0); ; shift += 7 {
  2657  				if shift >= 64 {
  2658  					return ErrIntOverflowProposerKv
  2659  				}
  2660  				if iNdEx >= l {
  2661  					return io.ErrUnexpectedEOF
  2662  				}
  2663  				b := dAtA[iNdEx]
  2664  				iNdEx++
  2665  				m.RaftLogDelta |= (int64(b) & 0x7F) << shift
  2666  				if b < 0x80 {
  2667  					break
  2668  				}
  2669  			}
  2670  		case 17:
  2671  			if wireType != 2 {
  2672  				return fmt.Errorf("proto: wrong wireType = %d for field AddSSTable", wireType)
  2673  			}
  2674  			var msglen int
  2675  			for shift := uint(0); ; shift += 7 {
  2676  				if shift >= 64 {
  2677  					return ErrIntOverflowProposerKv
  2678  				}
  2679  				if iNdEx >= l {
  2680  					return io.ErrUnexpectedEOF
  2681  				}
  2682  				b := dAtA[iNdEx]
  2683  				iNdEx++
  2684  				msglen |= (int(b) & 0x7F) << shift
  2685  				if b < 0x80 {
  2686  					break
  2687  				}
  2688  			}
  2689  			if msglen < 0 {
  2690  				return ErrInvalidLengthProposerKv
  2691  			}
  2692  			postIndex := iNdEx + msglen
  2693  			if postIndex > l {
  2694  				return io.ErrUnexpectedEOF
  2695  			}
  2696  			if m.AddSSTable == nil {
  2697  				m.AddSSTable = &ReplicatedEvalResult_AddSSTable{}
  2698  			}
  2699  			if err := m.AddSSTable.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2700  				return err
  2701  			}
  2702  			iNdEx = postIndex
  2703  		case 18:
  2704  			if wireType != 2 {
  2705  				return fmt.Errorf("proto: wrong wireType = %d for field Delta", wireType)
  2706  			}
  2707  			var msglen int
  2708  			for shift := uint(0); ; shift += 7 {
  2709  				if shift >= 64 {
  2710  					return ErrIntOverflowProposerKv
  2711  				}
  2712  				if iNdEx >= l {
  2713  					return io.ErrUnexpectedEOF
  2714  				}
  2715  				b := dAtA[iNdEx]
  2716  				iNdEx++
  2717  				msglen |= (int(b) & 0x7F) << shift
  2718  				if b < 0x80 {
  2719  					break
  2720  				}
  2721  			}
  2722  			if msglen < 0 {
  2723  				return ErrInvalidLengthProposerKv
  2724  			}
  2725  			postIndex := iNdEx + msglen
  2726  			if postIndex > l {
  2727  				return io.ErrUnexpectedEOF
  2728  			}
  2729  			if err := m.Delta.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2730  				return err
  2731  			}
  2732  			iNdEx = postIndex
  2733  		case 19:
  2734  			if wireType != 2 {
  2735  				return fmt.Errorf("proto: wrong wireType = %d for field SuggestedCompactions", wireType)
  2736  			}
  2737  			var msglen int
  2738  			for shift := uint(0); ; shift += 7 {
  2739  				if shift >= 64 {
  2740  					return ErrIntOverflowProposerKv
  2741  				}
  2742  				if iNdEx >= l {
  2743  					return io.ErrUnexpectedEOF
  2744  				}
  2745  				b := dAtA[iNdEx]
  2746  				iNdEx++
  2747  				msglen |= (int(b) & 0x7F) << shift
  2748  				if b < 0x80 {
  2749  					break
  2750  				}
  2751  			}
  2752  			if msglen < 0 {
  2753  				return ErrInvalidLengthProposerKv
  2754  			}
  2755  			postIndex := iNdEx + msglen
  2756  			if postIndex > l {
  2757  				return io.ErrUnexpectedEOF
  2758  			}
  2759  			m.SuggestedCompactions = append(m.SuggestedCompactions, SuggestedCompaction{})
  2760  			if err := m.SuggestedCompactions[len(m.SuggestedCompactions)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2761  				return err
  2762  			}
  2763  			iNdEx = postIndex
  2764  		case 20:
  2765  			if wireType != 2 {
  2766  				return fmt.Errorf("proto: wrong wireType = %d for field PrevLeaseProposal", wireType)
  2767  			}
  2768  			var msglen int
  2769  			for shift := uint(0); ; shift += 7 {
  2770  				if shift >= 64 {
  2771  					return ErrIntOverflowProposerKv
  2772  				}
  2773  				if iNdEx >= l {
  2774  					return io.ErrUnexpectedEOF
  2775  				}
  2776  				b := dAtA[iNdEx]
  2777  				iNdEx++
  2778  				msglen |= (int(b) & 0x7F) << shift
  2779  				if b < 0x80 {
  2780  					break
  2781  				}
  2782  			}
  2783  			if msglen < 0 {
  2784  				return ErrInvalidLengthProposerKv
  2785  			}
  2786  			postIndex := iNdEx + msglen
  2787  			if postIndex > l {
  2788  				return io.ErrUnexpectedEOF
  2789  			}
  2790  			if m.PrevLeaseProposal == nil {
  2791  				m.PrevLeaseProposal = &hlc.Timestamp{}
  2792  			}
  2793  			if err := m.PrevLeaseProposal.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2794  				return err
  2795  			}
  2796  			iNdEx = postIndex
  2797  		case 21:
  2798  			if wireType != 2 {
  2799  				return fmt.Errorf("proto: wrong wireType = %d for field ComputeChecksum", wireType)
  2800  			}
  2801  			var msglen int
  2802  			for shift := uint(0); ; shift += 7 {
  2803  				if shift >= 64 {
  2804  					return ErrIntOverflowProposerKv
  2805  				}
  2806  				if iNdEx >= l {
  2807  					return io.ErrUnexpectedEOF
  2808  				}
  2809  				b := dAtA[iNdEx]
  2810  				iNdEx++
  2811  				msglen |= (int(b) & 0x7F) << shift
  2812  				if b < 0x80 {
  2813  					break
  2814  				}
  2815  			}
  2816  			if msglen < 0 {
  2817  				return ErrInvalidLengthProposerKv
  2818  			}
  2819  			postIndex := iNdEx + msglen
  2820  			if postIndex > l {
  2821  				return io.ErrUnexpectedEOF
  2822  			}
  2823  			if m.ComputeChecksum == nil {
  2824  				m.ComputeChecksum = &ComputeChecksum{}
  2825  			}
  2826  			if err := m.ComputeChecksum.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2827  				return err
  2828  			}
  2829  			iNdEx = postIndex
  2830  		default:
  2831  			iNdEx = preIndex
  2832  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  2833  			if err != nil {
  2834  				return err
  2835  			}
  2836  			if skippy < 0 {
  2837  				return ErrInvalidLengthProposerKv
  2838  			}
  2839  			if (iNdEx + skippy) > l {
  2840  				return io.ErrUnexpectedEOF
  2841  			}
  2842  			iNdEx += skippy
  2843  		}
  2844  	}
  2845  
  2846  	if iNdEx > l {
  2847  		return io.ErrUnexpectedEOF
  2848  	}
  2849  	return nil
  2850  }
  2851  func (m *ReplicatedEvalResult_AddSSTable) Unmarshal(dAtA []byte) error {
  2852  	l := len(dAtA)
  2853  	iNdEx := 0
  2854  	for iNdEx < l {
  2855  		preIndex := iNdEx
  2856  		var wire uint64
  2857  		for shift := uint(0); ; shift += 7 {
  2858  			if shift >= 64 {
  2859  				return ErrIntOverflowProposerKv
  2860  			}
  2861  			if iNdEx >= l {
  2862  				return io.ErrUnexpectedEOF
  2863  			}
  2864  			b := dAtA[iNdEx]
  2865  			iNdEx++
  2866  			wire |= (uint64(b) & 0x7F) << shift
  2867  			if b < 0x80 {
  2868  				break
  2869  			}
  2870  		}
  2871  		fieldNum := int32(wire >> 3)
  2872  		wireType := int(wire & 0x7)
  2873  		if wireType == 4 {
  2874  			return fmt.Errorf("proto: AddSSTable: wiretype end group for non-group")
  2875  		}
  2876  		if fieldNum <= 0 {
  2877  			return fmt.Errorf("proto: AddSSTable: illegal tag %d (wire type %d)", fieldNum, wire)
  2878  		}
  2879  		switch fieldNum {
  2880  		case 1:
  2881  			if wireType != 2 {
  2882  				return fmt.Errorf("proto: wrong wireType = %d for field Data", wireType)
  2883  			}
  2884  			var byteLen int
  2885  			for shift := uint(0); ; shift += 7 {
  2886  				if shift >= 64 {
  2887  					return ErrIntOverflowProposerKv
  2888  				}
  2889  				if iNdEx >= l {
  2890  					return io.ErrUnexpectedEOF
  2891  				}
  2892  				b := dAtA[iNdEx]
  2893  				iNdEx++
  2894  				byteLen |= (int(b) & 0x7F) << shift
  2895  				if b < 0x80 {
  2896  					break
  2897  				}
  2898  			}
  2899  			if byteLen < 0 {
  2900  				return ErrInvalidLengthProposerKv
  2901  			}
  2902  			postIndex := iNdEx + byteLen
  2903  			if postIndex > l {
  2904  				return io.ErrUnexpectedEOF
  2905  			}
  2906  			m.Data = append(m.Data[:0], dAtA[iNdEx:postIndex]...)
  2907  			if m.Data == nil {
  2908  				m.Data = []byte{}
  2909  			}
  2910  			iNdEx = postIndex
  2911  		case 2:
  2912  			if wireType != 0 {
  2913  				return fmt.Errorf("proto: wrong wireType = %d for field CRC32", wireType)
  2914  			}
  2915  			m.CRC32 = 0
  2916  			for shift := uint(0); ; shift += 7 {
  2917  				if shift >= 64 {
  2918  					return ErrIntOverflowProposerKv
  2919  				}
  2920  				if iNdEx >= l {
  2921  					return io.ErrUnexpectedEOF
  2922  				}
  2923  				b := dAtA[iNdEx]
  2924  				iNdEx++
  2925  				m.CRC32 |= (uint32(b) & 0x7F) << shift
  2926  				if b < 0x80 {
  2927  					break
  2928  				}
  2929  			}
  2930  		default:
  2931  			iNdEx = preIndex
  2932  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  2933  			if err != nil {
  2934  				return err
  2935  			}
  2936  			if skippy < 0 {
  2937  				return ErrInvalidLengthProposerKv
  2938  			}
  2939  			if (iNdEx + skippy) > l {
  2940  				return io.ErrUnexpectedEOF
  2941  			}
  2942  			iNdEx += skippy
  2943  		}
  2944  	}
  2945  
  2946  	if iNdEx > l {
  2947  		return io.ErrUnexpectedEOF
  2948  	}
  2949  	return nil
  2950  }
  2951  func (m *WriteBatch) Unmarshal(dAtA []byte) error {
  2952  	l := len(dAtA)
  2953  	iNdEx := 0
  2954  	for iNdEx < l {
  2955  		preIndex := iNdEx
  2956  		var wire uint64
  2957  		for shift := uint(0); ; shift += 7 {
  2958  			if shift >= 64 {
  2959  				return ErrIntOverflowProposerKv
  2960  			}
  2961  			if iNdEx >= l {
  2962  				return io.ErrUnexpectedEOF
  2963  			}
  2964  			b := dAtA[iNdEx]
  2965  			iNdEx++
  2966  			wire |= (uint64(b) & 0x7F) << shift
  2967  			if b < 0x80 {
  2968  				break
  2969  			}
  2970  		}
  2971  		fieldNum := int32(wire >> 3)
  2972  		wireType := int(wire & 0x7)
  2973  		if wireType == 4 {
  2974  			return fmt.Errorf("proto: WriteBatch: wiretype end group for non-group")
  2975  		}
  2976  		if fieldNum <= 0 {
  2977  			return fmt.Errorf("proto: WriteBatch: illegal tag %d (wire type %d)", fieldNum, wire)
  2978  		}
  2979  		switch fieldNum {
  2980  		case 1:
  2981  			if wireType != 2 {
  2982  				return fmt.Errorf("proto: wrong wireType = %d for field Data", wireType)
  2983  			}
  2984  			var byteLen int
  2985  			for shift := uint(0); ; shift += 7 {
  2986  				if shift >= 64 {
  2987  					return ErrIntOverflowProposerKv
  2988  				}
  2989  				if iNdEx >= l {
  2990  					return io.ErrUnexpectedEOF
  2991  				}
  2992  				b := dAtA[iNdEx]
  2993  				iNdEx++
  2994  				byteLen |= (int(b) & 0x7F) << shift
  2995  				if b < 0x80 {
  2996  					break
  2997  				}
  2998  			}
  2999  			if byteLen < 0 {
  3000  				return ErrInvalidLengthProposerKv
  3001  			}
  3002  			postIndex := iNdEx + byteLen
  3003  			if postIndex > l {
  3004  				return io.ErrUnexpectedEOF
  3005  			}
  3006  			m.Data = append(m.Data[:0], dAtA[iNdEx:postIndex]...)
  3007  			if m.Data == nil {
  3008  				m.Data = []byte{}
  3009  			}
  3010  			iNdEx = postIndex
  3011  		default:
  3012  			iNdEx = preIndex
  3013  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  3014  			if err != nil {
  3015  				return err
  3016  			}
  3017  			if skippy < 0 {
  3018  				return ErrInvalidLengthProposerKv
  3019  			}
  3020  			if (iNdEx + skippy) > l {
  3021  				return io.ErrUnexpectedEOF
  3022  			}
  3023  			iNdEx += skippy
  3024  		}
  3025  	}
  3026  
  3027  	if iNdEx > l {
  3028  		return io.ErrUnexpectedEOF
  3029  	}
  3030  	return nil
  3031  }
  3032  func (m *LogicalOpLog) Unmarshal(dAtA []byte) error {
  3033  	l := len(dAtA)
  3034  	iNdEx := 0
  3035  	for iNdEx < l {
  3036  		preIndex := iNdEx
  3037  		var wire uint64
  3038  		for shift := uint(0); ; shift += 7 {
  3039  			if shift >= 64 {
  3040  				return ErrIntOverflowProposerKv
  3041  			}
  3042  			if iNdEx >= l {
  3043  				return io.ErrUnexpectedEOF
  3044  			}
  3045  			b := dAtA[iNdEx]
  3046  			iNdEx++
  3047  			wire |= (uint64(b) & 0x7F) << shift
  3048  			if b < 0x80 {
  3049  				break
  3050  			}
  3051  		}
  3052  		fieldNum := int32(wire >> 3)
  3053  		wireType := int(wire & 0x7)
  3054  		if wireType == 4 {
  3055  			return fmt.Errorf("proto: LogicalOpLog: wiretype end group for non-group")
  3056  		}
  3057  		if fieldNum <= 0 {
  3058  			return fmt.Errorf("proto: LogicalOpLog: illegal tag %d (wire type %d)", fieldNum, wire)
  3059  		}
  3060  		switch fieldNum {
  3061  		case 1:
  3062  			if wireType != 2 {
  3063  				return fmt.Errorf("proto: wrong wireType = %d for field Ops", wireType)
  3064  			}
  3065  			var msglen int
  3066  			for shift := uint(0); ; shift += 7 {
  3067  				if shift >= 64 {
  3068  					return ErrIntOverflowProposerKv
  3069  				}
  3070  				if iNdEx >= l {
  3071  					return io.ErrUnexpectedEOF
  3072  				}
  3073  				b := dAtA[iNdEx]
  3074  				iNdEx++
  3075  				msglen |= (int(b) & 0x7F) << shift
  3076  				if b < 0x80 {
  3077  					break
  3078  				}
  3079  			}
  3080  			if msglen < 0 {
  3081  				return ErrInvalidLengthProposerKv
  3082  			}
  3083  			postIndex := iNdEx + msglen
  3084  			if postIndex > l {
  3085  				return io.ErrUnexpectedEOF
  3086  			}
  3087  			m.Ops = append(m.Ops, enginepb.MVCCLogicalOp{})
  3088  			if err := m.Ops[len(m.Ops)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3089  				return err
  3090  			}
  3091  			iNdEx = postIndex
  3092  		default:
  3093  			iNdEx = preIndex
  3094  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  3095  			if err != nil {
  3096  				return err
  3097  			}
  3098  			if skippy < 0 {
  3099  				return ErrInvalidLengthProposerKv
  3100  			}
  3101  			if (iNdEx + skippy) > l {
  3102  				return io.ErrUnexpectedEOF
  3103  			}
  3104  			iNdEx += skippy
  3105  		}
  3106  	}
  3107  
  3108  	if iNdEx > l {
  3109  		return io.ErrUnexpectedEOF
  3110  	}
  3111  	return nil
  3112  }
  3113  func (m *RaftCommand) Unmarshal(dAtA []byte) error {
  3114  	l := len(dAtA)
  3115  	iNdEx := 0
  3116  	for iNdEx < l {
  3117  		preIndex := iNdEx
  3118  		var wire uint64
  3119  		for shift := uint(0); ; shift += 7 {
  3120  			if shift >= 64 {
  3121  				return ErrIntOverflowProposerKv
  3122  			}
  3123  			if iNdEx >= l {
  3124  				return io.ErrUnexpectedEOF
  3125  			}
  3126  			b := dAtA[iNdEx]
  3127  			iNdEx++
  3128  			wire |= (uint64(b) & 0x7F) << shift
  3129  			if b < 0x80 {
  3130  				break
  3131  			}
  3132  		}
  3133  		fieldNum := int32(wire >> 3)
  3134  		wireType := int(wire & 0x7)
  3135  		if wireType == 4 {
  3136  			return fmt.Errorf("proto: RaftCommand: wiretype end group for non-group")
  3137  		}
  3138  		if fieldNum <= 0 {
  3139  			return fmt.Errorf("proto: RaftCommand: illegal tag %d (wire type %d)", fieldNum, wire)
  3140  		}
  3141  		switch fieldNum {
  3142  		case 4:
  3143  			if wireType != 0 {
  3144  				return fmt.Errorf("proto: wrong wireType = %d for field MaxLeaseIndex", wireType)
  3145  			}
  3146  			m.MaxLeaseIndex = 0
  3147  			for shift := uint(0); ; shift += 7 {
  3148  				if shift >= 64 {
  3149  					return ErrIntOverflowProposerKv
  3150  				}
  3151  				if iNdEx >= l {
  3152  					return io.ErrUnexpectedEOF
  3153  				}
  3154  				b := dAtA[iNdEx]
  3155  				iNdEx++
  3156  				m.MaxLeaseIndex |= (uint64(b) & 0x7F) << shift
  3157  				if b < 0x80 {
  3158  					break
  3159  				}
  3160  			}
  3161  		case 5:
  3162  			if wireType != 2 {
  3163  				return fmt.Errorf("proto: wrong wireType = %d for field DeprecatedProposerLease", wireType)
  3164  			}
  3165  			var msglen int
  3166  			for shift := uint(0); ; shift += 7 {
  3167  				if shift >= 64 {
  3168  					return ErrIntOverflowProposerKv
  3169  				}
  3170  				if iNdEx >= l {
  3171  					return io.ErrUnexpectedEOF
  3172  				}
  3173  				b := dAtA[iNdEx]
  3174  				iNdEx++
  3175  				msglen |= (int(b) & 0x7F) << shift
  3176  				if b < 0x80 {
  3177  					break
  3178  				}
  3179  			}
  3180  			if msglen < 0 {
  3181  				return ErrInvalidLengthProposerKv
  3182  			}
  3183  			postIndex := iNdEx + msglen
  3184  			if postIndex > l {
  3185  				return io.ErrUnexpectedEOF
  3186  			}
  3187  			if m.DeprecatedProposerLease == nil {
  3188  				m.DeprecatedProposerLease = &roachpb.Lease{}
  3189  			}
  3190  			if err := m.DeprecatedProposerLease.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3191  				return err
  3192  			}
  3193  			iNdEx = postIndex
  3194  		case 6:
  3195  			if wireType != 0 {
  3196  				return fmt.Errorf("proto: wrong wireType = %d for field ProposerLeaseSequence", wireType)
  3197  			}
  3198  			m.ProposerLeaseSequence = 0
  3199  			for shift := uint(0); ; shift += 7 {
  3200  				if shift >= 64 {
  3201  					return ErrIntOverflowProposerKv
  3202  				}
  3203  				if iNdEx >= l {
  3204  					return io.ErrUnexpectedEOF
  3205  				}
  3206  				b := dAtA[iNdEx]
  3207  				iNdEx++
  3208  				m.ProposerLeaseSequence |= (github_com_cockroachdb_cockroach_pkg_roachpb.LeaseSequence(b) & 0x7F) << shift
  3209  				if b < 0x80 {
  3210  					break
  3211  				}
  3212  			}
  3213  		case 13:
  3214  			if wireType != 2 {
  3215  				return fmt.Errorf("proto: wrong wireType = %d for field ReplicatedEvalResult", wireType)
  3216  			}
  3217  			var msglen int
  3218  			for shift := uint(0); ; shift += 7 {
  3219  				if shift >= 64 {
  3220  					return ErrIntOverflowProposerKv
  3221  				}
  3222  				if iNdEx >= l {
  3223  					return io.ErrUnexpectedEOF
  3224  				}
  3225  				b := dAtA[iNdEx]
  3226  				iNdEx++
  3227  				msglen |= (int(b) & 0x7F) << shift
  3228  				if b < 0x80 {
  3229  					break
  3230  				}
  3231  			}
  3232  			if msglen < 0 {
  3233  				return ErrInvalidLengthProposerKv
  3234  			}
  3235  			postIndex := iNdEx + msglen
  3236  			if postIndex > l {
  3237  				return io.ErrUnexpectedEOF
  3238  			}
  3239  			if err := m.ReplicatedEvalResult.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3240  				return err
  3241  			}
  3242  			iNdEx = postIndex
  3243  		case 14:
  3244  			if wireType != 2 {
  3245  				return fmt.Errorf("proto: wrong wireType = %d for field WriteBatch", wireType)
  3246  			}
  3247  			var msglen int
  3248  			for shift := uint(0); ; shift += 7 {
  3249  				if shift >= 64 {
  3250  					return ErrIntOverflowProposerKv
  3251  				}
  3252  				if iNdEx >= l {
  3253  					return io.ErrUnexpectedEOF
  3254  				}
  3255  				b := dAtA[iNdEx]
  3256  				iNdEx++
  3257  				msglen |= (int(b) & 0x7F) << shift
  3258  				if b < 0x80 {
  3259  					break
  3260  				}
  3261  			}
  3262  			if msglen < 0 {
  3263  				return ErrInvalidLengthProposerKv
  3264  			}
  3265  			postIndex := iNdEx + msglen
  3266  			if postIndex > l {
  3267  				return io.ErrUnexpectedEOF
  3268  			}
  3269  			if m.WriteBatch == nil {
  3270  				m.WriteBatch = &WriteBatch{}
  3271  			}
  3272  			if err := m.WriteBatch.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3273  				return err
  3274  			}
  3275  			iNdEx = postIndex
  3276  		case 15:
  3277  			if wireType != 2 {
  3278  				return fmt.Errorf("proto: wrong wireType = %d for field LogicalOpLog", wireType)
  3279  			}
  3280  			var msglen int
  3281  			for shift := uint(0); ; shift += 7 {
  3282  				if shift >= 64 {
  3283  					return ErrIntOverflowProposerKv
  3284  				}
  3285  				if iNdEx >= l {
  3286  					return io.ErrUnexpectedEOF
  3287  				}
  3288  				b := dAtA[iNdEx]
  3289  				iNdEx++
  3290  				msglen |= (int(b) & 0x7F) << shift
  3291  				if b < 0x80 {
  3292  					break
  3293  				}
  3294  			}
  3295  			if msglen < 0 {
  3296  				return ErrInvalidLengthProposerKv
  3297  			}
  3298  			postIndex := iNdEx + msglen
  3299  			if postIndex > l {
  3300  				return io.ErrUnexpectedEOF
  3301  			}
  3302  			if m.LogicalOpLog == nil {
  3303  				m.LogicalOpLog = &LogicalOpLog{}
  3304  			}
  3305  			if err := m.LogicalOpLog.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3306  				return err
  3307  			}
  3308  			iNdEx = postIndex
  3309  		case 16:
  3310  			if wireType != 2 {
  3311  				return fmt.Errorf("proto: wrong wireType = %d for field TraceData", wireType)
  3312  			}
  3313  			var msglen int
  3314  			for shift := uint(0); ; shift += 7 {
  3315  				if shift >= 64 {
  3316  					return ErrIntOverflowProposerKv
  3317  				}
  3318  				if iNdEx >= l {
  3319  					return io.ErrUnexpectedEOF
  3320  				}
  3321  				b := dAtA[iNdEx]
  3322  				iNdEx++
  3323  				msglen |= (int(b) & 0x7F) << shift
  3324  				if b < 0x80 {
  3325  					break
  3326  				}
  3327  			}
  3328  			if msglen < 0 {
  3329  				return ErrInvalidLengthProposerKv
  3330  			}
  3331  			postIndex := iNdEx + msglen
  3332  			if postIndex > l {
  3333  				return io.ErrUnexpectedEOF
  3334  			}
  3335  			if m.TraceData == nil {
  3336  				m.TraceData = make(map[string]string)
  3337  			}
  3338  			var mapkey string
  3339  			var mapvalue string
  3340  			for iNdEx < postIndex {
  3341  				entryPreIndex := iNdEx
  3342  				var wire uint64
  3343  				for shift := uint(0); ; shift += 7 {
  3344  					if shift >= 64 {
  3345  						return ErrIntOverflowProposerKv
  3346  					}
  3347  					if iNdEx >= l {
  3348  						return io.ErrUnexpectedEOF
  3349  					}
  3350  					b := dAtA[iNdEx]
  3351  					iNdEx++
  3352  					wire |= (uint64(b) & 0x7F) << shift
  3353  					if b < 0x80 {
  3354  						break
  3355  					}
  3356  				}
  3357  				fieldNum := int32(wire >> 3)
  3358  				if fieldNum == 1 {
  3359  					var stringLenmapkey uint64
  3360  					for shift := uint(0); ; shift += 7 {
  3361  						if shift >= 64 {
  3362  							return ErrIntOverflowProposerKv
  3363  						}
  3364  						if iNdEx >= l {
  3365  							return io.ErrUnexpectedEOF
  3366  						}
  3367  						b := dAtA[iNdEx]
  3368  						iNdEx++
  3369  						stringLenmapkey |= (uint64(b) & 0x7F) << shift
  3370  						if b < 0x80 {
  3371  							break
  3372  						}
  3373  					}
  3374  					intStringLenmapkey := int(stringLenmapkey)
  3375  					if intStringLenmapkey < 0 {
  3376  						return ErrInvalidLengthProposerKv
  3377  					}
  3378  					postStringIndexmapkey := iNdEx + intStringLenmapkey
  3379  					if postStringIndexmapkey > l {
  3380  						return io.ErrUnexpectedEOF
  3381  					}
  3382  					mapkey = string(dAtA[iNdEx:postStringIndexmapkey])
  3383  					iNdEx = postStringIndexmapkey
  3384  				} else if fieldNum == 2 {
  3385  					var stringLenmapvalue uint64
  3386  					for shift := uint(0); ; shift += 7 {
  3387  						if shift >= 64 {
  3388  							return ErrIntOverflowProposerKv
  3389  						}
  3390  						if iNdEx >= l {
  3391  							return io.ErrUnexpectedEOF
  3392  						}
  3393  						b := dAtA[iNdEx]
  3394  						iNdEx++
  3395  						stringLenmapvalue |= (uint64(b) & 0x7F) << shift
  3396  						if b < 0x80 {
  3397  							break
  3398  						}
  3399  					}
  3400  					intStringLenmapvalue := int(stringLenmapvalue)
  3401  					if intStringLenmapvalue < 0 {
  3402  						return ErrInvalidLengthProposerKv
  3403  					}
  3404  					postStringIndexmapvalue := iNdEx + intStringLenmapvalue
  3405  					if postStringIndexmapvalue > l {
  3406  						return io.ErrUnexpectedEOF
  3407  					}
  3408  					mapvalue = string(dAtA[iNdEx:postStringIndexmapvalue])
  3409  					iNdEx = postStringIndexmapvalue
  3410  				} else {
  3411  					iNdEx = entryPreIndex
  3412  					skippy, err := skipProposerKv(dAtA[iNdEx:])
  3413  					if err != nil {
  3414  						return err
  3415  					}
  3416  					if skippy < 0 {
  3417  						return ErrInvalidLengthProposerKv
  3418  					}
  3419  					if (iNdEx + skippy) > postIndex {
  3420  						return io.ErrUnexpectedEOF
  3421  					}
  3422  					iNdEx += skippy
  3423  				}
  3424  			}
  3425  			m.TraceData[mapkey] = mapvalue
  3426  			iNdEx = postIndex
  3427  		default:
  3428  			iNdEx = preIndex
  3429  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  3430  			if err != nil {
  3431  				return err
  3432  			}
  3433  			if skippy < 0 {
  3434  				return ErrInvalidLengthProposerKv
  3435  			}
  3436  			if (iNdEx + skippy) > l {
  3437  				return io.ErrUnexpectedEOF
  3438  			}
  3439  			iNdEx += skippy
  3440  		}
  3441  	}
  3442  
  3443  	if iNdEx > l {
  3444  		return io.ErrUnexpectedEOF
  3445  	}
  3446  	return nil
  3447  }
  3448  func (m *RaftCommandFooter) Unmarshal(dAtA []byte) error {
  3449  	l := len(dAtA)
  3450  	iNdEx := 0
  3451  	for iNdEx < l {
  3452  		preIndex := iNdEx
  3453  		var wire uint64
  3454  		for shift := uint(0); ; shift += 7 {
  3455  			if shift >= 64 {
  3456  				return ErrIntOverflowProposerKv
  3457  			}
  3458  			if iNdEx >= l {
  3459  				return io.ErrUnexpectedEOF
  3460  			}
  3461  			b := dAtA[iNdEx]
  3462  			iNdEx++
  3463  			wire |= (uint64(b) & 0x7F) << shift
  3464  			if b < 0x80 {
  3465  				break
  3466  			}
  3467  		}
  3468  		fieldNum := int32(wire >> 3)
  3469  		wireType := int(wire & 0x7)
  3470  		if wireType == 4 {
  3471  			return fmt.Errorf("proto: RaftCommandFooter: wiretype end group for non-group")
  3472  		}
  3473  		if fieldNum <= 0 {
  3474  			return fmt.Errorf("proto: RaftCommandFooter: illegal tag %d (wire type %d)", fieldNum, wire)
  3475  		}
  3476  		switch fieldNum {
  3477  		case 4:
  3478  			if wireType != 0 {
  3479  				return fmt.Errorf("proto: wrong wireType = %d for field MaxLeaseIndex", wireType)
  3480  			}
  3481  			m.MaxLeaseIndex = 0
  3482  			for shift := uint(0); ; shift += 7 {
  3483  				if shift >= 64 {
  3484  					return ErrIntOverflowProposerKv
  3485  				}
  3486  				if iNdEx >= l {
  3487  					return io.ErrUnexpectedEOF
  3488  				}
  3489  				b := dAtA[iNdEx]
  3490  				iNdEx++
  3491  				m.MaxLeaseIndex |= (uint64(b) & 0x7F) << shift
  3492  				if b < 0x80 {
  3493  					break
  3494  				}
  3495  			}
  3496  		default:
  3497  			iNdEx = preIndex
  3498  			skippy, err := skipProposerKv(dAtA[iNdEx:])
  3499  			if err != nil {
  3500  				return err
  3501  			}
  3502  			if skippy < 0 {
  3503  				return ErrInvalidLengthProposerKv
  3504  			}
  3505  			if (iNdEx + skippy) > l {
  3506  				return io.ErrUnexpectedEOF
  3507  			}
  3508  			iNdEx += skippy
  3509  		}
  3510  	}
  3511  
  3512  	if iNdEx > l {
  3513  		return io.ErrUnexpectedEOF
  3514  	}
  3515  	return nil
  3516  }
  3517  func skipProposerKv(dAtA []byte) (n int, err error) {
  3518  	l := len(dAtA)
  3519  	iNdEx := 0
  3520  	for iNdEx < l {
  3521  		var wire uint64
  3522  		for shift := uint(0); ; shift += 7 {
  3523  			if shift >= 64 {
  3524  				return 0, ErrIntOverflowProposerKv
  3525  			}
  3526  			if iNdEx >= l {
  3527  				return 0, io.ErrUnexpectedEOF
  3528  			}
  3529  			b := dAtA[iNdEx]
  3530  			iNdEx++
  3531  			wire |= (uint64(b) & 0x7F) << shift
  3532  			if b < 0x80 {
  3533  				break
  3534  			}
  3535  		}
  3536  		wireType := int(wire & 0x7)
  3537  		switch wireType {
  3538  		case 0:
  3539  			for shift := uint(0); ; shift += 7 {
  3540  				if shift >= 64 {
  3541  					return 0, ErrIntOverflowProposerKv
  3542  				}
  3543  				if iNdEx >= l {
  3544  					return 0, io.ErrUnexpectedEOF
  3545  				}
  3546  				iNdEx++
  3547  				if dAtA[iNdEx-1] < 0x80 {
  3548  					break
  3549  				}
  3550  			}
  3551  			return iNdEx, nil
  3552  		case 1:
  3553  			iNdEx += 8
  3554  			return iNdEx, nil
  3555  		case 2:
  3556  			var length int
  3557  			for shift := uint(0); ; shift += 7 {
  3558  				if shift >= 64 {
  3559  					return 0, ErrIntOverflowProposerKv
  3560  				}
  3561  				if iNdEx >= l {
  3562  					return 0, io.ErrUnexpectedEOF
  3563  				}
  3564  				b := dAtA[iNdEx]
  3565  				iNdEx++
  3566  				length |= (int(b) & 0x7F) << shift
  3567  				if b < 0x80 {
  3568  					break
  3569  				}
  3570  			}
  3571  			iNdEx += length
  3572  			if length < 0 {
  3573  				return 0, ErrInvalidLengthProposerKv
  3574  			}
  3575  			return iNdEx, nil
  3576  		case 3:
  3577  			for {
  3578  				var innerWire uint64
  3579  				var start int = iNdEx
  3580  				for shift := uint(0); ; shift += 7 {
  3581  					if shift >= 64 {
  3582  						return 0, ErrIntOverflowProposerKv
  3583  					}
  3584  					if iNdEx >= l {
  3585  						return 0, io.ErrUnexpectedEOF
  3586  					}
  3587  					b := dAtA[iNdEx]
  3588  					iNdEx++
  3589  					innerWire |= (uint64(b) & 0x7F) << shift
  3590  					if b < 0x80 {
  3591  						break
  3592  					}
  3593  				}
  3594  				innerWireType := int(innerWire & 0x7)
  3595  				if innerWireType == 4 {
  3596  					break
  3597  				}
  3598  				next, err := skipProposerKv(dAtA[start:])
  3599  				if err != nil {
  3600  					return 0, err
  3601  				}
  3602  				iNdEx = start + next
  3603  			}
  3604  			return iNdEx, nil
  3605  		case 4:
  3606  			return iNdEx, nil
  3607  		case 5:
  3608  			iNdEx += 4
  3609  			return iNdEx, nil
  3610  		default:
  3611  			return 0, fmt.Errorf("proto: illegal wireType %d", wireType)
  3612  		}
  3613  	}
  3614  	panic("unreachable")
  3615  }
  3616  
  3617  var (
  3618  	ErrInvalidLengthProposerKv = fmt.Errorf("proto: negative length found during unmarshaling")
  3619  	ErrIntOverflowProposerKv   = fmt.Errorf("proto: integer overflow")
  3620  )
  3621  
  3622  func init() {
  3623  	proto.RegisterFile("kv/kvserver/kvserverpb/proposer_kv.proto", fileDescriptor_proposer_kv_baa0b8d6d33a3e71)
  3624  }
  3625  
  3626  var fileDescriptor_proposer_kv_baa0b8d6d33a3e71 = []byte{
  3627  	// 1430 bytes of a gzipped FileDescriptorProto
  3628  	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xa4, 0x57, 0xc1, 0x6f, 0x13, 0x47,
  3629  	0x17, 0x8f, 0x63, 0x3b, 0x59, 0x3f, 0x27, 0xf6, 0x66, 0x08, 0xb0, 0x5f, 0xbe, 0xef, 0xb3, 0xa3,
  3630  	0x7c, 0x7c, 0x28, 0x6d, 0xe9, 0x1a, 0x25, 0x54, 0xaa, 0x00, 0x55, 0x8d, 0x1d, 0x28, 0x31, 0x49,
  3631  	0x0a, 0xe3, 0x40, 0x2b, 0x7a, 0x58, 0x8d, 0x77, 0x87, 0xf5, 0xd6, 0xeb, 0xdd, 0x65, 0x67, 0x6c,
  3632  	0xc8, 0x7f, 0xd1, 0x4a, 0x3d, 0xf4, 0xd4, 0x72, 0xec, 0x9f, 0xc2, 0xa5, 0x12, 0x47, 0xd4, 0x83,
  3633  	0x55, 0xc2, 0xa5, 0xb7, 0xde, 0x39, 0x55, 0x33, 0x3b, 0x6b, 0x3b, 0x25, 0x34, 0xa6, 0xbd, 0x58,
  3634  	0xb3, 0x6f, 0xe6, 0xfd, 0xde, 0xcc, 0x7b, 0xbf, 0xf7, 0x9b, 0x31, 0xac, 0x77, 0x07, 0xb5, 0xee,
  3635  	0x80, 0xd1, 0x78, 0x40, 0xe3, 0xd1, 0x20, 0x6a, 0xd7, 0xa2, 0x38, 0x8c, 0x42, 0x46, 0x63, 0xab,
  3636  	0x3b, 0x30, 0xa3, 0x38, 0xe4, 0x21, 0xaa, 0xda, 0xa1, 0xdd, 0x8d, 0x43, 0x62, 0x77, 0xcc, 0xee,
  3637  	0xc0, 0x4c, 0x97, 0x9a, 0x8c, 0x87, 0x31, 0x71, 0x69, 0xd4, 0x5e, 0x59, 0x92, 0x93, 0x51, 0xbb,
  3638  	0x46, 0x22, 0x2f, 0xf1, 0x59, 0x41, 0xa9, 0xc9, 0x21, 0x9c, 0x28, 0xdb, 0xb9, 0xd4, 0xd6, 0xa3,
  3639  	0x9c, 0x4c, 0xd8, 0xff, 0xad, 0x90, 0x6a, 0x34, 0x70, 0xbd, 0x80, 0x8a, 0x05, 0x03, 0xdb, 0x56,
  3640  	0x93, 0xff, 0x39, 0x71, 0x72, 0x53, 0xcd, 0xae, 0xbd, 0xe5, 0x10, 0x8c, 0x13, 0x4e, 0xd5, 0x1a,
  3641  	0xa3, 0xcf, 0x3d, 0xbf, 0xd6, 0xf1, 0xed, 0x1a, 0xf7, 0x7a, 0x94, 0x71, 0xd2, 0x8b, 0xd4, 0xcc,
  3642  	0xb2, 0x1b, 0xba, 0xa1, 0x1c, 0xd6, 0xc4, 0x28, 0xb1, 0xae, 0xfd, 0x94, 0x81, 0x7c, 0x2b, 0xf2,
  3643  	0x3d, 0x8e, 0x1a, 0x30, 0xcf, 0x63, 0xcf, 0x75, 0x69, 0x6c, 0x64, 0x56, 0x33, 0xeb, 0xc5, 0x8d,
  3644  	0xaa, 0x39, 0x4e, 0x85, 0x3a, 0x8c, 0x29, 0x97, 0x1e, 0x24, 0xcb, 0xea, 0xda, 0xb3, 0x61, 0x75,
  3645  	0xe6, 0xf9, 0xb0, 0x9a, 0xc1, 0xa9, 0x27, 0x3a, 0x80, 0x42, 0xdc, 0x61, 0x96, 0x43, 0x7d, 0x4e,
  3646  	0x8c, 0x59, 0x09, 0xf3, 0xff, 0x09, 0x18, 0x75, 0x3c, 0x33, 0x3d, 0x9e, 0xb9, 0x77, 0xbf, 0xd1,
  3647  	0x68, 0x71, 0xc2, 0x59, 0x5d, 0x17, 0x60, 0x47, 0xc3, 0xaa, 0x86, 0x6f, 0xb5, 0xb6, 0x85, 0x3b,
  3648  	0xd6, 0xe2, 0x0e, 0x93, 0xa3, 0xab, 0xb9, 0xdf, 0x9e, 0x56, 0x33, 0x6b, 0x18, 0xf2, 0x7b, 0x34,
  3649  	0x76, 0xe9, 0x74, 0x3b, 0x95, 0x4b, 0xdf, 0xbe, 0x53, 0x85, 0xd9, 0x81, 0x52, 0xa3, 0x43, 0x02,
  3650  	0x97, 0x62, 0x1a, 0xf9, 0x9e, 0x4d, 0x18, 0xda, 0xfd, 0x33, 0xf8, 0xfa, 0x09, 0xe0, 0xc7, 0x7d,
  3651  	0xfe, 0x22, 0x8a, 0xf6, 0xfd, 0xd3, 0xea, 0x8c, 0x8c, 0xf4, 0x72, 0x16, 0xca, 0x8d, 0xb0, 0x17,
  3652  	0xf5, 0x39, 0x6d, 0x74, 0xa8, 0xdd, 0x65, 0xfd, 0x1e, 0xfa, 0x1a, 0x8a, 0xb6, 0x1a, 0x5b, 0x9e,
  3653  	0x23, 0xe3, 0x2d, 0xd4, 0x77, 0x04, 0xca, 0x2f, 0xc3, 0xea, 0xa6, 0xeb, 0xf1, 0x4e, 0xbf, 0x6d,
  3654  	0xda, 0x61, 0xaf, 0x36, 0xda, 0x81, 0xd3, 0x1e, 0x8f, 0x6b, 0x51, 0xd7, 0xad, 0xc9, 0x72, 0xf7,
  3655  	0xfb, 0x9e, 0x63, 0xde, 0xbb, 0xb7, 0xb3, 0x7d, 0x34, 0xac, 0x42, 0x8a, 0xbe, 0xb3, 0x8d, 0x21,
  3656  	0x45, 0xdf, 0x71, 0xd0, 0xff, 0x60, 0x91, 0x91, 0x01, 0xb5, 0x58, 0x40, 0x22, 0xd6, 0x09, 0xb9,
  3657  	0xac, 0x8e, 0x86, 0x17, 0x84, 0xb1, 0xa5, 0x6c, 0x68, 0x13, 0x72, 0xbd, 0xd0, 0xa1, 0x46, 0x76,
  3658  	0x35, 0xb3, 0x5e, 0x3a, 0x31, 0xad, 0x29, 0xfa, 0x5e, 0xe8, 0x50, 0x2c, 0x17, 0xa3, 0x0a, 0x24,
  3659  	0x71, 0xa2, 0xd0, 0x0b, 0xb8, 0x91, 0x93, 0xb0, 0x13, 0x16, 0x64, 0xc0, 0xfc, 0x80, 0xc6, 0xcc,
  3660  	0x0b, 0x03, 0x23, 0xbf, 0x9a, 0x59, 0x5f, 0xc4, 0xe9, 0x27, 0xba, 0x05, 0x05, 0x4e, 0xe3, 0x9e,
  3661  	0x17, 0x10, 0x4e, 0x8d, 0xb9, 0xd5, 0xec, 0x7a, 0x71, 0xe3, 0xc2, 0x09, 0x31, 0x55, 0x9e, 0xb7,
  3662  	0x29, 0xb3, 0x63, 0x2f, 0xe2, 0x61, 0x5c, 0xcf, 0x89, 0x1c, 0xe1, 0xb1, 0xb3, 0xaa, 0xe6, 0x7d,
  3663  	0x00, 0x91, 0x62, 0x62, 0x73, 0x81, 0xbe, 0x0c, 0xf9, 0xf6, 0x21, 0xa7, 0x4c, 0xe6, 0x35, 0x8b,
  3664  	0x93, 0x0f, 0x74, 0x09, 0x10, 0xeb, 0xbb, 0x2e, 0x65, 0x9c, 0x3a, 0x16, 0xe1, 0x56, 0x40, 0x82,
  3665  	0x90, 0xc9, 0x64, 0x64, 0xb1, 0x3e, 0x9a, 0xd9, 0xe2, 0xfb, 0xc2, 0xae, 0x70, 0xbf, 0x9b, 0x85,
  3666  	0x33, 0xad, 0x74, 0x6a, 0x22, 0xc2, 0x5d, 0x28, 0x30, 0x4e, 0x62, 0x6e, 0x75, 0xe9, 0xa1, 0xaa,
  3667  	0xde, 0x95, 0xd7, 0xc3, 0xea, 0xe5, 0xa9, 0x2a, 0x97, 0x9e, 0xee, 0x36, 0x3d, 0xc4, 0x9a, 0x84,
  3668  	0xb9, 0x4d, 0x0f, 0xd1, 0x1e, 0xcc, 0xd3, 0xc0, 0x91, 0x80, 0xb3, 0xff, 0x00, 0x70, 0x8e, 0x06,
  3669  	0x8e, 0x80, 0xbb, 0x07, 0x60, 0x8f, 0xf6, 0x2b, 0xcb, 0x5a, 0xdc, 0xf8, 0xc0, 0x3c, 0x45, 0xe2,
  3670  	0xcc, 0xf1, 0x11, 0x27, 0x38, 0x3d, 0x01, 0xa4, 0xd2, 0xf2, 0xbb, 0x06, 0xcb, 0xaa, 0x36, 0x9c,
  3671  	0x3a, 0x37, 0x06, 0xc4, 0xc7, 0x94, 0xf5, 0x7d, 0x21, 0x25, 0x79, 0xa9, 0x49, 0x4a, 0x01, 0x3e,
  3672  	0x3c, 0x35, 0xa0, 0x42, 0x11, 0x4a, 0x40, 0x71, 0xe2, 0x8b, 0xae, 0x43, 0x9e, 0x09, 0xb5, 0x51,
  3673  	0xbb, 0xbe, 0x78, 0x2a, 0x88, 0xd4, 0x26, 0x9c, 0x38, 0x09, 0xef, 0x9e, 0x50, 0x00, 0xc9, 0xc7,
  3674  	0x69, 0xbc, 0xa5, 0x5e, 0xe0, 0xc4, 0x09, 0xad, 0x83, 0xee, 0x31, 0xcb, 0xa7, 0x84, 0x51, 0x2b,
  3675  	0xa6, 0x8f, 0xfa, 0x94, 0x71, 0x63, 0x4e, 0x12, 0xbb, 0xe4, 0xb1, 0x5d, 0x61, 0xc6, 0x89, 0x15,
  3676  	0x6d, 0x41, 0x61, 0x24, 0xb4, 0x86, 0x26, 0x63, 0xfd, 0x77, 0x22, 0x96, 0x68, 0x4f, 0xb3, 0xe3,
  3677  	0xdb, 0xe6, 0x41, 0xba, 0x68, 0xc4, 0xdd, 0xd4, 0x80, 0xee, 0x80, 0xee, 0xd0, 0x28, 0xa6, 0x32,
  3678  	0x8b, 0x4a, 0x3a, 0xe1, 0x1d, 0xa4, 0x13, 0x97, 0xc7, 0xee, 0x52, 0x2f, 0xd1, 0x97, 0x50, 0xb6,
  3679  	0xa5, 0x42, 0x59, 0xb1, 0x92, 0x28, 0x63, 0x41, 0x02, 0xd6, 0x4e, 0x2f, 0xfd, 0x31, 0x65, 0xc3,
  3680  	0x25, 0xfb, 0xb8, 0x3a, 0x5e, 0x80, 0x52, 0x4c, 0x1e, 0x72, 0xcb, 0x0f, 0x5d, 0xb5, 0xd3, 0x45,
  3681  	0xd9, 0x39, 0x0b, 0xc2, 0xba, 0x1b, 0xba, 0x49, 0xfc, 0x47, 0x50, 0x24, 0x8e, 0x63, 0x31, 0xc6,
  3682  	0x49, 0xdb, 0xa7, 0xc6, 0x92, 0x8c, 0xfd, 0xe9, 0xb4, 0x2c, 0x38, 0xc6, 0x25, 0x73, 0xcb, 0x71,
  3683  	0x5a, 0xad, 0x03, 0x81, 0x53, 0x2f, 0x09, 0x79, 0x1b, 0x7f, 0x63, 0x20, 0x8e, 0xd3, 0x4a, 0x62,
  3684  	0xa0, 0x9b, 0x90, 0x4f, 0xf6, 0x83, 0x64, 0xb0, 0xf7, 0xa7, 0xca, 0x9c, 0xdc, 0xad, 0x2a, 0x48,
  3685  	0xe2, 0x8e, 0x42, 0x38, 0x3b, 0x96, 0x87, 0x31, 0xe3, 0x99, 0x71, 0x46, 0xca, 0xd3, 0x95, 0xd3,
  3686  	0x59, 0xf8, 0xa6, 0x4e, 0xa8, 0x08, 0xcb, 0xec, 0xcd, 0x29, 0x86, 0xf6, 0xe0, 0x4c, 0x14, 0xd3,
  3687  	0x81, 0x22, 0x5b, 0xf2, 0x1e, 0x21, 0xbe, 0xb1, 0x3c, 0x05, 0x95, 0xf0, 0x92, 0xf0, 0x94, 0x74,
  3688  	0xbc, 0xa3, 0xfc, 0xd0, 0x57, 0xa0, 0xdb, 0xc9, 0x2d, 0x63, 0xa5, 0xe2, 0x6f, 0x9c, 0x95, 0x58,
  3689  	0x97, 0xa7, 0x6a, 0xfb, 0x89, 0xeb, 0x09, 0x97, 0xed, 0xe3, 0x86, 0x95, 0xcf, 0x60, 0x22, 0xfd,
  3690  	0x08, 0x41, 0x4e, 0xbc, 0x6b, 0x12, 0xe1, 0xc3, 0x72, 0x8c, 0xaa, 0x90, 0xb7, 0x63, 0x7b, 0x73,
  3691  	0x43, 0x76, 0xfe, 0x62, 0xbd, 0x70, 0x34, 0xac, 0xe6, 0x1b, 0xb8, 0xb1, 0xb9, 0x81, 0x13, 0x7b,
  3692  	0xa2, 0x1c, 0xc9, 0x6f, 0x33, 0xa7, 0x65, 0xf4, 0xd9, 0x66, 0x4e, 0xcb, 0xeb, 0x73, 0xcd, 0x9c,
  3693  	0x36, 0xaf, 0x6b, 0xcd, 0x9c, 0x56, 0xd0, 0xa1, 0x99, 0xd3, 0x4a, 0x7a, 0xb9, 0x99, 0xd3, 0xca,
  3694  	0xba, 0xde, 0xcc, 0x69, 0xba, 0xbe, 0xd4, 0x9c, 0xd3, 0xbe, 0xdd, 0xd7, 0x7f, 0xd8, 0x5f, 0x5b,
  3695  	0x05, 0xf8, 0x22, 0xf6, 0x38, 0xad, 0x13, 0x6e, 0x77, 0x4e, 0xda, 0xc0, 0xda, 0x5d, 0x58, 0xd8,
  3696  	0x0d, 0x5d, 0xcf, 0x26, 0xfe, 0xe7, 0xd1, 0x6e, 0xe8, 0xa2, 0x2d, 0xc8, 0x86, 0x91, 0xb8, 0x02,
  3697  	0x44, 0xf5, 0xde, 0x3b, 0x8d, 0x15, 0x23, 0x57, 0x55, 0x32, 0xe1, 0xbb, 0xf6, 0x73, 0x1e, 0x8a,
  3698  	0x98, 0x3c, 0xe4, 0x8d, 0xb0, 0xd7, 0x23, 0x81, 0x83, 0x2e, 0x42, 0xb9, 0x47, 0x9e, 0xa8, 0x82,
  3699  	0x79, 0x81, 0x43, 0x9f, 0x48, 0x91, 0xc9, 0xe1, 0xc5, 0x1e, 0x79, 0x22, 0xab, 0xb1, 0x23, 0x8c,
  3700  	0xe8, 0x00, 0xfe, 0x35, 0xd1, 0xd7, 0xa3, 0x97, 0xa6, 0xf4, 0x93, 0x37, 0x61, 0x71, 0xc3, 0x38,
  3701  	0xe1, 0xb6, 0x4b, 0xe4, 0xe5, 0xfc, 0xd8, 0xf5, 0x8e, 0xf2, 0x94, 0x13, 0x68, 0x00, 0xe7, 0x8f,
  3702  	0x43, 0x59, 0x4c, 0x48, 0x51, 0x60, 0x53, 0xa9, 0x50, 0xd9, 0xfa, 0x27, 0xaf, 0x87, 0xd5, 0xab,
  3703  	0xef, 0x74, 0x61, 0x48, 0xe0, 0x96, 0x42, 0xc1, 0x67, 0xa3, 0xc9, 0x78, 0xa9, 0x19, 0x3d, 0x82,
  3704  	0x73, 0xf1, 0xa8, 0x3f, 0x2d, 0x3a, 0x20, 0xbe, 0x15, 0xcb, 0x0e, 0x95, 0x0a, 0x50, 0xdc, 0xf8,
  3705  	0xe8, 0x6f, 0xb5, 0x77, 0xda, 0x1a, 0xf1, 0x49, 0xd7, 0xc8, 0x2e, 0x14, 0x1f, 0x8b, 0x6a, 0x5b,
  3706  	0x6d, 0x51, 0x6e, 0xa3, 0x34, 0xe5, 0xed, 0x35, 0x66, 0x08, 0x86, 0xc7, 0x63, 0xb6, 0xb4, 0xa0,
  3707  	0xe4, 0x27, 0xe5, 0xb5, 0xc2, 0x48, 0x08, 0x98, 0x51, 0x9e, 0xf2, 0x76, 0x9a, 0x24, 0x14, 0x5e,
  3708  	0xf0, 0x27, 0xe9, 0xf5, 0x00, 0x80, 0xc7, 0xc4, 0xa6, 0x96, 0x24, 0xa2, 0x2e, 0x59, 0x76, 0xed,
  3709  	0xf4, 0x4c, 0x8c, 0xd9, 0x64, 0x1e, 0x08, 0xf7, 0x6d, 0xc2, 0xc9, 0x8d, 0x80, 0xc7, 0x87, 0xb8,
  3710  	0xc0, 0xd3, 0xef, 0x95, 0xeb, 0x50, 0x3a, 0x3e, 0x89, 0x74, 0xc8, 0xa6, 0x2f, 0x8d, 0x02, 0x16,
  3711  	0x43, 0xf1, 0xc6, 0x19, 0x10, 0xbf, 0x9f, 0xdc, 0xb4, 0x05, 0x9c, 0x7c, 0x5c, 0x9d, 0xfd, 0x58,
  3712  	0x34, 0x57, 0x56, 0xcf, 0x8d, 0x5a, 0x6c, 0x56, 0xcf, 0x26, 0x4d, 0xf4, 0xe3, 0xfe, 0xda, 0x35,
  3713  	0x58, 0x9a, 0xd8, 0xc0, 0xcd, 0x30, 0xe4, 0x34, 0x9e, 0x96, 0xd4, 0xf5, 0x4b, 0xcf, 0x5e, 0x56,
  3714  	0x66, 0x9e, 0x1d, 0x55, 0x32, 0xcf, 0x8f, 0x2a, 0x99, 0x17, 0x47, 0x95, 0xcc, 0xaf, 0x47, 0x95,
  3715  	0xcc, 0x37, 0xaf, 0x2a, 0x33, 0xcf, 0x5f, 0x55, 0x66, 0x5e, 0xbc, 0xaa, 0xcc, 0x3c, 0x80, 0xf1,
  3716  	0x3f, 0x93, 0xf6, 0x9c, 0xfc, 0x93, 0xb1, 0xf9, 0x47, 0x00, 0x00, 0x00, 0xff, 0xff, 0x5d, 0x94,
  3717  	0x36, 0x44, 0x7f, 0x0d, 0x00, 0x00,
  3718  }