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

     1  // Code generated by protoc-gen-gogo. DO NOT EDIT.
     2  // source: kv/kvserver/kvserverpb/state.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_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    14  
    15  import io "io"
    16  
    17  // Reference imports to suppress errors if they are not otherwise used.
    18  var _ = proto.Marshal
    19  var _ = fmt.Errorf
    20  var _ = math.Inf
    21  
    22  // This is a compile-time assertion to ensure that this generated file
    23  // is compatible with the proto package it is being compiled against.
    24  // A compilation error at this line likely means your copy of the
    25  // proto package needs to be updated.
    26  const _ = proto.GoGoProtoPackageIsVersion2 // please upgrade the proto package
    27  
    28  // ReplicaState is the part of the Range Raft state machine which is cached in
    29  // memory and which is manipulated exclusively through consensus.
    30  //
    31  // The struct is also used to transfer state to Replicas in the context of
    32  // proposer-evaluated Raft, in which case it does not represent a complete
    33  // state but instead an update to be applied to an existing state, with each
    34  // field specified in the update overwriting its counterpart on the receiving
    35  // ReplicaState.
    36  //
    37  // For the ReplicaState persisted on the Replica, all optional fields are
    38  // populated (i.e. no nil pointers or enums with the default value).
    39  type ReplicaState struct {
    40  	// The highest (and last) index applied to the state machine.
    41  	RaftAppliedIndex uint64 `protobuf:"varint,1,opt,name=raft_applied_index,json=raftAppliedIndex,proto3" json:"raft_applied_index,omitempty"`
    42  	// The highest (and last) lease index applied to the state machine.
    43  	LeaseAppliedIndex uint64 `protobuf:"varint,2,opt,name=lease_applied_index,json=leaseAppliedIndex,proto3" json:"lease_applied_index,omitempty"`
    44  	// The Range descriptor.
    45  	// The pointer may change, but the referenced RangeDescriptor struct itself
    46  	// must be treated as immutable; it is leaked out of the lock.
    47  	//
    48  	// Changes of the descriptor should always go through one of the
    49  	// (*Replica).setDesc* methods.
    50  	Desc *roachpb.RangeDescriptor `protobuf:"bytes,3,opt,name=desc,proto3" json:"desc,omitempty"`
    51  	// The latest range lease.
    52  	//
    53  	// Note that this message is both sent over the network and used to model
    54  	// replica state in memory. In memory (storage.Replica.mu.state), the lease
    55  	// is never nil (and never zero-valued), but it may be nil when sent over
    56  	// the network as part of ReplicatedEvalResult.
    57  	Lease *roachpb.Lease `protobuf:"bytes,4,opt,name=lease,proto3" json:"lease,omitempty"`
    58  	// The truncation state of the Raft log.
    59  	TruncatedState *roachpb.RaftTruncatedState `protobuf:"bytes,5,opt,name=truncated_state,json=truncatedState,proto3" json:"truncated_state,omitempty"`
    60  	// gcThreshold is the GC threshold of the Range, typically updated when keys
    61  	// are garbage collected. Reads and writes at timestamps <= this time will
    62  	// not be served.
    63  	GCThreshold *hlc.Timestamp      `protobuf:"bytes,6,opt,name=gc_threshold,json=gcThreshold,proto3" json:"gc_threshold,omitempty"`
    64  	Stats       *enginepb.MVCCStats `protobuf:"bytes,7,opt,name=stats,proto3" json:"stats,omitempty"`
    65  	// using_applied_state_key specifies whether the Range has been upgraded
    66  	// to begin using the RangeAppliedState key. This key holds a combination
    67  	// of the Raft applied index, the lease applied index, and the MVCC stats.
    68  	//
    69  	// When set to true in a ReplicatedEvalResult, the flag indicates that the
    70  	// range should begin using the RangeAppliedState key. Handling of this flag
    71  	// is idempotent by Replica state machines, meaning that it is ok for multiple
    72  	// Raft commands to set it to true.
    73  	UsingAppliedStateKey bool `protobuf:"varint,11,opt,name=using_applied_state_key,json=usingAppliedStateKey,proto3" json:"using_applied_state_key,omitempty"`
    74  }
    75  
    76  func (m *ReplicaState) Reset()         { *m = ReplicaState{} }
    77  func (m *ReplicaState) String() string { return proto.CompactTextString(m) }
    78  func (*ReplicaState) ProtoMessage()    {}
    79  func (*ReplicaState) Descriptor() ([]byte, []int) {
    80  	return fileDescriptor_state_e26e666ce309a848, []int{0}
    81  }
    82  func (m *ReplicaState) XXX_Unmarshal(b []byte) error {
    83  	return m.Unmarshal(b)
    84  }
    85  func (m *ReplicaState) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
    86  	b = b[:cap(b)]
    87  	n, err := m.MarshalTo(b)
    88  	if err != nil {
    89  		return nil, err
    90  	}
    91  	return b[:n], nil
    92  }
    93  func (dst *ReplicaState) XXX_Merge(src proto.Message) {
    94  	xxx_messageInfo_ReplicaState.Merge(dst, src)
    95  }
    96  func (m *ReplicaState) XXX_Size() int {
    97  	return m.Size()
    98  }
    99  func (m *ReplicaState) XXX_DiscardUnknown() {
   100  	xxx_messageInfo_ReplicaState.DiscardUnknown(m)
   101  }
   102  
   103  var xxx_messageInfo_ReplicaState proto.InternalMessageInfo
   104  
   105  // RangeInfo is used for reporting status information about a range out through
   106  // the status server.
   107  type RangeInfo struct {
   108  	ReplicaState `protobuf:"bytes,1,opt,name=state,proto3,embedded=state" json:"state"`
   109  	// The highest (and last) index in the Raft log.
   110  	LastIndex  uint64 `protobuf:"varint,2,opt,name=last_index,json=lastIndex,proto3" json:"last_index,omitempty"`
   111  	NumPending uint64 `protobuf:"varint,3,opt,name=num_pending,json=numPending,proto3" json:"num_pending,omitempty"`
   112  	NumDropped uint64 `protobuf:"varint,5,opt,name=num_dropped,json=numDropped,proto3" json:"num_dropped,omitempty"`
   113  	// raft_log_size may be inaccurate, see storage.Replica.mu.raftLogSizeTrusted.
   114  	RaftLogSize        int64 `protobuf:"varint,6,opt,name=raft_log_size,json=raftLogSize,proto3" json:"raft_log_size,omitempty"`
   115  	RaftLogSizeTrusted bool  `protobuf:"varint,10,opt,name=raft_log_size_trusted,json=raftLogSizeTrusted,proto3" json:"raft_log_size_trusted,omitempty"`
   116  	// Approximately the amount of quota available.
   117  	ApproximateProposalQuota int64 `protobuf:"varint,7,opt,name=approximate_proposal_quota,json=approximateProposalQuota,proto3" json:"approximate_proposal_quota,omitempty"`
   118  	// Index for which quota has already been released.
   119  	ProposalQuotaBaseIndex int64 `protobuf:"varint,14,opt,name=proposal_quota_base_index,json=proposalQuotaBaseIndex,proto3" json:"proposal_quota_base_index,omitempty"`
   120  	// Quota amounts for commands which the leader has applied but for which we're
   121  	// still waiting for followers to ack the corresponding entries. First entry
   122  	// corresponds to base_index+1 above.
   123  	ProposalQuotaReleaseQueue []int64 `protobuf:"varint,15,rep,packed,name=proposal_quota_release_queue,json=proposalQuotaReleaseQueue,proto3" json:"proposal_quota_release_queue,omitempty"`
   124  	// The max size the range can grow to before it will be split.
   125  	RangeMaxBytes int64 `protobuf:"varint,8,opt,name=range_max_bytes,json=rangeMaxBytes,proto3" json:"range_max_bytes,omitempty"`
   126  	// The highest closed timestamp known to have data for this replica, taken
   127  	// across the data received from all nodes. This does not reflect whether
   128  	// the replica can use this closed timestamp (it may, for example, not have
   129  	// caught up sufficiently to do so).
   130  	NewestClosedTimestamp RangeInfo_CTEntry `protobuf:"bytes,11,opt,name=newest_closed_timestamp,json=newestClosedTimestamp,proto3" json:"newest_closed_timestamp"`
   131  	// The closed timestamp active on the replica when the info was generated.
   132  	// This is the actual timestamp at or below which requests can be served from
   133  	// this replica at this moment (assuming it is not the leaseholder). This takes
   134  	// into account the lease start time, the current lease applied index, and the
   135  	// closed timestamp information received from other nodes, among other things.
   136  	// In practice, this should not usually trail newest_closed_timestamp except
   137  	// for a short moment after newest_closed_timestamp gets updated.
   138  	ActiveClosedTimestamp hlc.Timestamp `protobuf:"bytes,12,opt,name=active_closed_timestamp,json=activeClosedTimestamp,proto3" json:"active_closed_timestamp"`
   139  	// The number of Rangefeed registrations attached to the Replica.
   140  	RangefeedRegistrations int64 `protobuf:"varint,13,opt,name=rangefeed_registrations,json=rangefeedRegistrations,proto3" json:"rangefeed_registrations,omitempty"`
   141  }
   142  
   143  func (m *RangeInfo) Reset()         { *m = RangeInfo{} }
   144  func (m *RangeInfo) String() string { return proto.CompactTextString(m) }
   145  func (*RangeInfo) ProtoMessage()    {}
   146  func (*RangeInfo) Descriptor() ([]byte, []int) {
   147  	return fileDescriptor_state_e26e666ce309a848, []int{1}
   148  }
   149  func (m *RangeInfo) XXX_Unmarshal(b []byte) error {
   150  	return m.Unmarshal(b)
   151  }
   152  func (m *RangeInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   153  	b = b[:cap(b)]
   154  	n, err := m.MarshalTo(b)
   155  	if err != nil {
   156  		return nil, err
   157  	}
   158  	return b[:n], nil
   159  }
   160  func (dst *RangeInfo) XXX_Merge(src proto.Message) {
   161  	xxx_messageInfo_RangeInfo.Merge(dst, src)
   162  }
   163  func (m *RangeInfo) XXX_Size() int {
   164  	return m.Size()
   165  }
   166  func (m *RangeInfo) XXX_DiscardUnknown() {
   167  	xxx_messageInfo_RangeInfo.DiscardUnknown(m)
   168  }
   169  
   170  var xxx_messageInfo_RangeInfo proto.InternalMessageInfo
   171  
   172  type RangeInfo_CTEntry struct {
   173  	NodeID          github_com_cockroachdb_cockroach_pkg_roachpb.NodeID `protobuf:"varint,1,opt,name=node_id,json=nodeId,proto3,casttype=github.com/cockroachdb/cockroach/pkg/roachpb.NodeID" json:"node_id,omitempty"`
   174  	ClosedTimestamp hlc.Timestamp                                       `protobuf:"bytes,2,opt,name=closed_timestamp,json=closedTimestamp,proto3" json:"closed_timestamp"`
   175  	MLAI            int64                                               `protobuf:"varint,3,opt,name=mlai,proto3" json:"mlai,omitempty"`
   176  	Epoch           int64                                               `protobuf:"varint,4,opt,name=epoch,proto3" json:"epoch,omitempty"`
   177  }
   178  
   179  func (m *RangeInfo_CTEntry) Reset()         { *m = RangeInfo_CTEntry{} }
   180  func (m *RangeInfo_CTEntry) String() string { return proto.CompactTextString(m) }
   181  func (*RangeInfo_CTEntry) ProtoMessage()    {}
   182  func (*RangeInfo_CTEntry) Descriptor() ([]byte, []int) {
   183  	return fileDescriptor_state_e26e666ce309a848, []int{1, 0}
   184  }
   185  func (m *RangeInfo_CTEntry) XXX_Unmarshal(b []byte) error {
   186  	return m.Unmarshal(b)
   187  }
   188  func (m *RangeInfo_CTEntry) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   189  	b = b[:cap(b)]
   190  	n, err := m.MarshalTo(b)
   191  	if err != nil {
   192  		return nil, err
   193  	}
   194  	return b[:n], nil
   195  }
   196  func (dst *RangeInfo_CTEntry) XXX_Merge(src proto.Message) {
   197  	xxx_messageInfo_RangeInfo_CTEntry.Merge(dst, src)
   198  }
   199  func (m *RangeInfo_CTEntry) XXX_Size() int {
   200  	return m.Size()
   201  }
   202  func (m *RangeInfo_CTEntry) XXX_DiscardUnknown() {
   203  	xxx_messageInfo_RangeInfo_CTEntry.DiscardUnknown(m)
   204  }
   205  
   206  var xxx_messageInfo_RangeInfo_CTEntry proto.InternalMessageInfo
   207  
   208  // LatchManagerInfo is used for reporting status information about a spanlatch
   209  // manager out through the status server.
   210  type LatchManagerInfo struct {
   211  	ReadCount  int64 `protobuf:"varint,1,opt,name=read_count,json=readCount,proto3" json:"read_count,omitempty"`
   212  	WriteCount int64 `protobuf:"varint,2,opt,name=write_count,json=writeCount,proto3" json:"write_count,omitempty"`
   213  }
   214  
   215  func (m *LatchManagerInfo) Reset()         { *m = LatchManagerInfo{} }
   216  func (m *LatchManagerInfo) String() string { return proto.CompactTextString(m) }
   217  func (*LatchManagerInfo) ProtoMessage()    {}
   218  func (*LatchManagerInfo) Descriptor() ([]byte, []int) {
   219  	return fileDescriptor_state_e26e666ce309a848, []int{2}
   220  }
   221  func (m *LatchManagerInfo) XXX_Unmarshal(b []byte) error {
   222  	return m.Unmarshal(b)
   223  }
   224  func (m *LatchManagerInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   225  	b = b[:cap(b)]
   226  	n, err := m.MarshalTo(b)
   227  	if err != nil {
   228  		return nil, err
   229  	}
   230  	return b[:n], nil
   231  }
   232  func (dst *LatchManagerInfo) XXX_Merge(src proto.Message) {
   233  	xxx_messageInfo_LatchManagerInfo.Merge(dst, src)
   234  }
   235  func (m *LatchManagerInfo) XXX_Size() int {
   236  	return m.Size()
   237  }
   238  func (m *LatchManagerInfo) XXX_DiscardUnknown() {
   239  	xxx_messageInfo_LatchManagerInfo.DiscardUnknown(m)
   240  }
   241  
   242  var xxx_messageInfo_LatchManagerInfo proto.InternalMessageInfo
   243  
   244  func init() {
   245  	proto.RegisterType((*ReplicaState)(nil), "cockroach.kv.kvserver.storagepb.ReplicaState")
   246  	proto.RegisterType((*RangeInfo)(nil), "cockroach.kv.kvserver.storagepb.RangeInfo")
   247  	proto.RegisterType((*RangeInfo_CTEntry)(nil), "cockroach.kv.kvserver.storagepb.RangeInfo.CTEntry")
   248  	proto.RegisterType((*LatchManagerInfo)(nil), "cockroach.kv.kvserver.storagepb.LatchManagerInfo")
   249  }
   250  func (this *ReplicaState) Equal(that interface{}) bool {
   251  	if that == nil {
   252  		return this == nil
   253  	}
   254  
   255  	that1, ok := that.(*ReplicaState)
   256  	if !ok {
   257  		that2, ok := that.(ReplicaState)
   258  		if ok {
   259  			that1 = &that2
   260  		} else {
   261  			return false
   262  		}
   263  	}
   264  	if that1 == nil {
   265  		return this == nil
   266  	} else if this == nil {
   267  		return false
   268  	}
   269  	if this.RaftAppliedIndex != that1.RaftAppliedIndex {
   270  		return false
   271  	}
   272  	if this.LeaseAppliedIndex != that1.LeaseAppliedIndex {
   273  		return false
   274  	}
   275  	if !this.Desc.Equal(that1.Desc) {
   276  		return false
   277  	}
   278  	if !this.Lease.Equal(that1.Lease) {
   279  		return false
   280  	}
   281  	if !this.TruncatedState.Equal(that1.TruncatedState) {
   282  		return false
   283  	}
   284  	if !this.GCThreshold.Equal(that1.GCThreshold) {
   285  		return false
   286  	}
   287  	if !this.Stats.Equal(that1.Stats) {
   288  		return false
   289  	}
   290  	if this.UsingAppliedStateKey != that1.UsingAppliedStateKey {
   291  		return false
   292  	}
   293  	return true
   294  }
   295  func (this *RangeInfo) Equal(that interface{}) bool {
   296  	if that == nil {
   297  		return this == nil
   298  	}
   299  
   300  	that1, ok := that.(*RangeInfo)
   301  	if !ok {
   302  		that2, ok := that.(RangeInfo)
   303  		if ok {
   304  			that1 = &that2
   305  		} else {
   306  			return false
   307  		}
   308  	}
   309  	if that1 == nil {
   310  		return this == nil
   311  	} else if this == nil {
   312  		return false
   313  	}
   314  	if !this.ReplicaState.Equal(&that1.ReplicaState) {
   315  		return false
   316  	}
   317  	if this.LastIndex != that1.LastIndex {
   318  		return false
   319  	}
   320  	if this.NumPending != that1.NumPending {
   321  		return false
   322  	}
   323  	if this.NumDropped != that1.NumDropped {
   324  		return false
   325  	}
   326  	if this.RaftLogSize != that1.RaftLogSize {
   327  		return false
   328  	}
   329  	if this.RaftLogSizeTrusted != that1.RaftLogSizeTrusted {
   330  		return false
   331  	}
   332  	if this.ApproximateProposalQuota != that1.ApproximateProposalQuota {
   333  		return false
   334  	}
   335  	if this.ProposalQuotaBaseIndex != that1.ProposalQuotaBaseIndex {
   336  		return false
   337  	}
   338  	if len(this.ProposalQuotaReleaseQueue) != len(that1.ProposalQuotaReleaseQueue) {
   339  		return false
   340  	}
   341  	for i := range this.ProposalQuotaReleaseQueue {
   342  		if this.ProposalQuotaReleaseQueue[i] != that1.ProposalQuotaReleaseQueue[i] {
   343  			return false
   344  		}
   345  	}
   346  	if this.RangeMaxBytes != that1.RangeMaxBytes {
   347  		return false
   348  	}
   349  	if !this.NewestClosedTimestamp.Equal(&that1.NewestClosedTimestamp) {
   350  		return false
   351  	}
   352  	if !this.ActiveClosedTimestamp.Equal(&that1.ActiveClosedTimestamp) {
   353  		return false
   354  	}
   355  	if this.RangefeedRegistrations != that1.RangefeedRegistrations {
   356  		return false
   357  	}
   358  	return true
   359  }
   360  func (this *RangeInfo_CTEntry) Equal(that interface{}) bool {
   361  	if that == nil {
   362  		return this == nil
   363  	}
   364  
   365  	that1, ok := that.(*RangeInfo_CTEntry)
   366  	if !ok {
   367  		that2, ok := that.(RangeInfo_CTEntry)
   368  		if ok {
   369  			that1 = &that2
   370  		} else {
   371  			return false
   372  		}
   373  	}
   374  	if that1 == nil {
   375  		return this == nil
   376  	} else if this == nil {
   377  		return false
   378  	}
   379  	if this.NodeID != that1.NodeID {
   380  		return false
   381  	}
   382  	if !this.ClosedTimestamp.Equal(&that1.ClosedTimestamp) {
   383  		return false
   384  	}
   385  	if this.MLAI != that1.MLAI {
   386  		return false
   387  	}
   388  	if this.Epoch != that1.Epoch {
   389  		return false
   390  	}
   391  	return true
   392  }
   393  func (m *ReplicaState) Marshal() (dAtA []byte, err error) {
   394  	size := m.Size()
   395  	dAtA = make([]byte, size)
   396  	n, err := m.MarshalTo(dAtA)
   397  	if err != nil {
   398  		return nil, err
   399  	}
   400  	return dAtA[:n], nil
   401  }
   402  
   403  func (m *ReplicaState) MarshalTo(dAtA []byte) (int, error) {
   404  	var i int
   405  	_ = i
   406  	var l int
   407  	_ = l
   408  	if m.RaftAppliedIndex != 0 {
   409  		dAtA[i] = 0x8
   410  		i++
   411  		i = encodeVarintState(dAtA, i, uint64(m.RaftAppliedIndex))
   412  	}
   413  	if m.LeaseAppliedIndex != 0 {
   414  		dAtA[i] = 0x10
   415  		i++
   416  		i = encodeVarintState(dAtA, i, uint64(m.LeaseAppliedIndex))
   417  	}
   418  	if m.Desc != nil {
   419  		dAtA[i] = 0x1a
   420  		i++
   421  		i = encodeVarintState(dAtA, i, uint64(m.Desc.Size()))
   422  		n1, err := m.Desc.MarshalTo(dAtA[i:])
   423  		if err != nil {
   424  			return 0, err
   425  		}
   426  		i += n1
   427  	}
   428  	if m.Lease != nil {
   429  		dAtA[i] = 0x22
   430  		i++
   431  		i = encodeVarintState(dAtA, i, uint64(m.Lease.Size()))
   432  		n2, err := m.Lease.MarshalTo(dAtA[i:])
   433  		if err != nil {
   434  			return 0, err
   435  		}
   436  		i += n2
   437  	}
   438  	if m.TruncatedState != nil {
   439  		dAtA[i] = 0x2a
   440  		i++
   441  		i = encodeVarintState(dAtA, i, uint64(m.TruncatedState.Size()))
   442  		n3, err := m.TruncatedState.MarshalTo(dAtA[i:])
   443  		if err != nil {
   444  			return 0, err
   445  		}
   446  		i += n3
   447  	}
   448  	if m.GCThreshold != nil {
   449  		dAtA[i] = 0x32
   450  		i++
   451  		i = encodeVarintState(dAtA, i, uint64(m.GCThreshold.Size()))
   452  		n4, err := m.GCThreshold.MarshalTo(dAtA[i:])
   453  		if err != nil {
   454  			return 0, err
   455  		}
   456  		i += n4
   457  	}
   458  	if m.Stats != nil {
   459  		dAtA[i] = 0x3a
   460  		i++
   461  		i = encodeVarintState(dAtA, i, uint64(m.Stats.Size()))
   462  		n5, err := m.Stats.MarshalTo(dAtA[i:])
   463  		if err != nil {
   464  			return 0, err
   465  		}
   466  		i += n5
   467  	}
   468  	if m.UsingAppliedStateKey {
   469  		dAtA[i] = 0x58
   470  		i++
   471  		if m.UsingAppliedStateKey {
   472  			dAtA[i] = 1
   473  		} else {
   474  			dAtA[i] = 0
   475  		}
   476  		i++
   477  	}
   478  	return i, nil
   479  }
   480  
   481  func (m *RangeInfo) Marshal() (dAtA []byte, err error) {
   482  	size := m.Size()
   483  	dAtA = make([]byte, size)
   484  	n, err := m.MarshalTo(dAtA)
   485  	if err != nil {
   486  		return nil, err
   487  	}
   488  	return dAtA[:n], nil
   489  }
   490  
   491  func (m *RangeInfo) MarshalTo(dAtA []byte) (int, error) {
   492  	var i int
   493  	_ = i
   494  	var l int
   495  	_ = l
   496  	dAtA[i] = 0xa
   497  	i++
   498  	i = encodeVarintState(dAtA, i, uint64(m.ReplicaState.Size()))
   499  	n6, err := m.ReplicaState.MarshalTo(dAtA[i:])
   500  	if err != nil {
   501  		return 0, err
   502  	}
   503  	i += n6
   504  	if m.LastIndex != 0 {
   505  		dAtA[i] = 0x10
   506  		i++
   507  		i = encodeVarintState(dAtA, i, uint64(m.LastIndex))
   508  	}
   509  	if m.NumPending != 0 {
   510  		dAtA[i] = 0x18
   511  		i++
   512  		i = encodeVarintState(dAtA, i, uint64(m.NumPending))
   513  	}
   514  	if m.NumDropped != 0 {
   515  		dAtA[i] = 0x28
   516  		i++
   517  		i = encodeVarintState(dAtA, i, uint64(m.NumDropped))
   518  	}
   519  	if m.RaftLogSize != 0 {
   520  		dAtA[i] = 0x30
   521  		i++
   522  		i = encodeVarintState(dAtA, i, uint64(m.RaftLogSize))
   523  	}
   524  	if m.ApproximateProposalQuota != 0 {
   525  		dAtA[i] = 0x38
   526  		i++
   527  		i = encodeVarintState(dAtA, i, uint64(m.ApproximateProposalQuota))
   528  	}
   529  	if m.RangeMaxBytes != 0 {
   530  		dAtA[i] = 0x40
   531  		i++
   532  		i = encodeVarintState(dAtA, i, uint64(m.RangeMaxBytes))
   533  	}
   534  	if m.RaftLogSizeTrusted {
   535  		dAtA[i] = 0x50
   536  		i++
   537  		if m.RaftLogSizeTrusted {
   538  			dAtA[i] = 1
   539  		} else {
   540  			dAtA[i] = 0
   541  		}
   542  		i++
   543  	}
   544  	dAtA[i] = 0x5a
   545  	i++
   546  	i = encodeVarintState(dAtA, i, uint64(m.NewestClosedTimestamp.Size()))
   547  	n7, err := m.NewestClosedTimestamp.MarshalTo(dAtA[i:])
   548  	if err != nil {
   549  		return 0, err
   550  	}
   551  	i += n7
   552  	dAtA[i] = 0x62
   553  	i++
   554  	i = encodeVarintState(dAtA, i, uint64(m.ActiveClosedTimestamp.Size()))
   555  	n8, err := m.ActiveClosedTimestamp.MarshalTo(dAtA[i:])
   556  	if err != nil {
   557  		return 0, err
   558  	}
   559  	i += n8
   560  	if m.RangefeedRegistrations != 0 {
   561  		dAtA[i] = 0x68
   562  		i++
   563  		i = encodeVarintState(dAtA, i, uint64(m.RangefeedRegistrations))
   564  	}
   565  	if m.ProposalQuotaBaseIndex != 0 {
   566  		dAtA[i] = 0x70
   567  		i++
   568  		i = encodeVarintState(dAtA, i, uint64(m.ProposalQuotaBaseIndex))
   569  	}
   570  	if len(m.ProposalQuotaReleaseQueue) > 0 {
   571  		dAtA10 := make([]byte, len(m.ProposalQuotaReleaseQueue)*10)
   572  		var j9 int
   573  		for _, num1 := range m.ProposalQuotaReleaseQueue {
   574  			num := uint64(num1)
   575  			for num >= 1<<7 {
   576  				dAtA10[j9] = uint8(uint64(num)&0x7f | 0x80)
   577  				num >>= 7
   578  				j9++
   579  			}
   580  			dAtA10[j9] = uint8(num)
   581  			j9++
   582  		}
   583  		dAtA[i] = 0x7a
   584  		i++
   585  		i = encodeVarintState(dAtA, i, uint64(j9))
   586  		i += copy(dAtA[i:], dAtA10[:j9])
   587  	}
   588  	return i, nil
   589  }
   590  
   591  func (m *RangeInfo_CTEntry) Marshal() (dAtA []byte, err error) {
   592  	size := m.Size()
   593  	dAtA = make([]byte, size)
   594  	n, err := m.MarshalTo(dAtA)
   595  	if err != nil {
   596  		return nil, err
   597  	}
   598  	return dAtA[:n], nil
   599  }
   600  
   601  func (m *RangeInfo_CTEntry) MarshalTo(dAtA []byte) (int, error) {
   602  	var i int
   603  	_ = i
   604  	var l int
   605  	_ = l
   606  	if m.NodeID != 0 {
   607  		dAtA[i] = 0x8
   608  		i++
   609  		i = encodeVarintState(dAtA, i, uint64(m.NodeID))
   610  	}
   611  	dAtA[i] = 0x12
   612  	i++
   613  	i = encodeVarintState(dAtA, i, uint64(m.ClosedTimestamp.Size()))
   614  	n11, err := m.ClosedTimestamp.MarshalTo(dAtA[i:])
   615  	if err != nil {
   616  		return 0, err
   617  	}
   618  	i += n11
   619  	if m.MLAI != 0 {
   620  		dAtA[i] = 0x18
   621  		i++
   622  		i = encodeVarintState(dAtA, i, uint64(m.MLAI))
   623  	}
   624  	if m.Epoch != 0 {
   625  		dAtA[i] = 0x20
   626  		i++
   627  		i = encodeVarintState(dAtA, i, uint64(m.Epoch))
   628  	}
   629  	return i, nil
   630  }
   631  
   632  func (m *LatchManagerInfo) Marshal() (dAtA []byte, err error) {
   633  	size := m.Size()
   634  	dAtA = make([]byte, size)
   635  	n, err := m.MarshalTo(dAtA)
   636  	if err != nil {
   637  		return nil, err
   638  	}
   639  	return dAtA[:n], nil
   640  }
   641  
   642  func (m *LatchManagerInfo) MarshalTo(dAtA []byte) (int, error) {
   643  	var i int
   644  	_ = i
   645  	var l int
   646  	_ = l
   647  	if m.ReadCount != 0 {
   648  		dAtA[i] = 0x8
   649  		i++
   650  		i = encodeVarintState(dAtA, i, uint64(m.ReadCount))
   651  	}
   652  	if m.WriteCount != 0 {
   653  		dAtA[i] = 0x10
   654  		i++
   655  		i = encodeVarintState(dAtA, i, uint64(m.WriteCount))
   656  	}
   657  	return i, nil
   658  }
   659  
   660  func encodeVarintState(dAtA []byte, offset int, v uint64) int {
   661  	for v >= 1<<7 {
   662  		dAtA[offset] = uint8(v&0x7f | 0x80)
   663  		v >>= 7
   664  		offset++
   665  	}
   666  	dAtA[offset] = uint8(v)
   667  	return offset + 1
   668  }
   669  func (m *ReplicaState) Size() (n int) {
   670  	if m == nil {
   671  		return 0
   672  	}
   673  	var l int
   674  	_ = l
   675  	if m.RaftAppliedIndex != 0 {
   676  		n += 1 + sovState(uint64(m.RaftAppliedIndex))
   677  	}
   678  	if m.LeaseAppliedIndex != 0 {
   679  		n += 1 + sovState(uint64(m.LeaseAppliedIndex))
   680  	}
   681  	if m.Desc != nil {
   682  		l = m.Desc.Size()
   683  		n += 1 + l + sovState(uint64(l))
   684  	}
   685  	if m.Lease != nil {
   686  		l = m.Lease.Size()
   687  		n += 1 + l + sovState(uint64(l))
   688  	}
   689  	if m.TruncatedState != nil {
   690  		l = m.TruncatedState.Size()
   691  		n += 1 + l + sovState(uint64(l))
   692  	}
   693  	if m.GCThreshold != nil {
   694  		l = m.GCThreshold.Size()
   695  		n += 1 + l + sovState(uint64(l))
   696  	}
   697  	if m.Stats != nil {
   698  		l = m.Stats.Size()
   699  		n += 1 + l + sovState(uint64(l))
   700  	}
   701  	if m.UsingAppliedStateKey {
   702  		n += 2
   703  	}
   704  	return n
   705  }
   706  
   707  func (m *RangeInfo) Size() (n int) {
   708  	if m == nil {
   709  		return 0
   710  	}
   711  	var l int
   712  	_ = l
   713  	l = m.ReplicaState.Size()
   714  	n += 1 + l + sovState(uint64(l))
   715  	if m.LastIndex != 0 {
   716  		n += 1 + sovState(uint64(m.LastIndex))
   717  	}
   718  	if m.NumPending != 0 {
   719  		n += 1 + sovState(uint64(m.NumPending))
   720  	}
   721  	if m.NumDropped != 0 {
   722  		n += 1 + sovState(uint64(m.NumDropped))
   723  	}
   724  	if m.RaftLogSize != 0 {
   725  		n += 1 + sovState(uint64(m.RaftLogSize))
   726  	}
   727  	if m.ApproximateProposalQuota != 0 {
   728  		n += 1 + sovState(uint64(m.ApproximateProposalQuota))
   729  	}
   730  	if m.RangeMaxBytes != 0 {
   731  		n += 1 + sovState(uint64(m.RangeMaxBytes))
   732  	}
   733  	if m.RaftLogSizeTrusted {
   734  		n += 2
   735  	}
   736  	l = m.NewestClosedTimestamp.Size()
   737  	n += 1 + l + sovState(uint64(l))
   738  	l = m.ActiveClosedTimestamp.Size()
   739  	n += 1 + l + sovState(uint64(l))
   740  	if m.RangefeedRegistrations != 0 {
   741  		n += 1 + sovState(uint64(m.RangefeedRegistrations))
   742  	}
   743  	if m.ProposalQuotaBaseIndex != 0 {
   744  		n += 1 + sovState(uint64(m.ProposalQuotaBaseIndex))
   745  	}
   746  	if len(m.ProposalQuotaReleaseQueue) > 0 {
   747  		l = 0
   748  		for _, e := range m.ProposalQuotaReleaseQueue {
   749  			l += sovState(uint64(e))
   750  		}
   751  		n += 1 + sovState(uint64(l)) + l
   752  	}
   753  	return n
   754  }
   755  
   756  func (m *RangeInfo_CTEntry) Size() (n int) {
   757  	if m == nil {
   758  		return 0
   759  	}
   760  	var l int
   761  	_ = l
   762  	if m.NodeID != 0 {
   763  		n += 1 + sovState(uint64(m.NodeID))
   764  	}
   765  	l = m.ClosedTimestamp.Size()
   766  	n += 1 + l + sovState(uint64(l))
   767  	if m.MLAI != 0 {
   768  		n += 1 + sovState(uint64(m.MLAI))
   769  	}
   770  	if m.Epoch != 0 {
   771  		n += 1 + sovState(uint64(m.Epoch))
   772  	}
   773  	return n
   774  }
   775  
   776  func (m *LatchManagerInfo) Size() (n int) {
   777  	if m == nil {
   778  		return 0
   779  	}
   780  	var l int
   781  	_ = l
   782  	if m.ReadCount != 0 {
   783  		n += 1 + sovState(uint64(m.ReadCount))
   784  	}
   785  	if m.WriteCount != 0 {
   786  		n += 1 + sovState(uint64(m.WriteCount))
   787  	}
   788  	return n
   789  }
   790  
   791  func sovState(x uint64) (n int) {
   792  	for {
   793  		n++
   794  		x >>= 7
   795  		if x == 0 {
   796  			break
   797  		}
   798  	}
   799  	return n
   800  }
   801  func sozState(x uint64) (n int) {
   802  	return sovState(uint64((x << 1) ^ uint64((int64(x) >> 63))))
   803  }
   804  func (m *ReplicaState) Unmarshal(dAtA []byte) error {
   805  	l := len(dAtA)
   806  	iNdEx := 0
   807  	for iNdEx < l {
   808  		preIndex := iNdEx
   809  		var wire uint64
   810  		for shift := uint(0); ; shift += 7 {
   811  			if shift >= 64 {
   812  				return ErrIntOverflowState
   813  			}
   814  			if iNdEx >= l {
   815  				return io.ErrUnexpectedEOF
   816  			}
   817  			b := dAtA[iNdEx]
   818  			iNdEx++
   819  			wire |= (uint64(b) & 0x7F) << shift
   820  			if b < 0x80 {
   821  				break
   822  			}
   823  		}
   824  		fieldNum := int32(wire >> 3)
   825  		wireType := int(wire & 0x7)
   826  		if wireType == 4 {
   827  			return fmt.Errorf("proto: ReplicaState: wiretype end group for non-group")
   828  		}
   829  		if fieldNum <= 0 {
   830  			return fmt.Errorf("proto: ReplicaState: illegal tag %d (wire type %d)", fieldNum, wire)
   831  		}
   832  		switch fieldNum {
   833  		case 1:
   834  			if wireType != 0 {
   835  				return fmt.Errorf("proto: wrong wireType = %d for field RaftAppliedIndex", wireType)
   836  			}
   837  			m.RaftAppliedIndex = 0
   838  			for shift := uint(0); ; shift += 7 {
   839  				if shift >= 64 {
   840  					return ErrIntOverflowState
   841  				}
   842  				if iNdEx >= l {
   843  					return io.ErrUnexpectedEOF
   844  				}
   845  				b := dAtA[iNdEx]
   846  				iNdEx++
   847  				m.RaftAppliedIndex |= (uint64(b) & 0x7F) << shift
   848  				if b < 0x80 {
   849  					break
   850  				}
   851  			}
   852  		case 2:
   853  			if wireType != 0 {
   854  				return fmt.Errorf("proto: wrong wireType = %d for field LeaseAppliedIndex", wireType)
   855  			}
   856  			m.LeaseAppliedIndex = 0
   857  			for shift := uint(0); ; shift += 7 {
   858  				if shift >= 64 {
   859  					return ErrIntOverflowState
   860  				}
   861  				if iNdEx >= l {
   862  					return io.ErrUnexpectedEOF
   863  				}
   864  				b := dAtA[iNdEx]
   865  				iNdEx++
   866  				m.LeaseAppliedIndex |= (uint64(b) & 0x7F) << shift
   867  				if b < 0x80 {
   868  					break
   869  				}
   870  			}
   871  		case 3:
   872  			if wireType != 2 {
   873  				return fmt.Errorf("proto: wrong wireType = %d for field Desc", wireType)
   874  			}
   875  			var msglen int
   876  			for shift := uint(0); ; shift += 7 {
   877  				if shift >= 64 {
   878  					return ErrIntOverflowState
   879  				}
   880  				if iNdEx >= l {
   881  					return io.ErrUnexpectedEOF
   882  				}
   883  				b := dAtA[iNdEx]
   884  				iNdEx++
   885  				msglen |= (int(b) & 0x7F) << shift
   886  				if b < 0x80 {
   887  					break
   888  				}
   889  			}
   890  			if msglen < 0 {
   891  				return ErrInvalidLengthState
   892  			}
   893  			postIndex := iNdEx + msglen
   894  			if postIndex > l {
   895  				return io.ErrUnexpectedEOF
   896  			}
   897  			if m.Desc == nil {
   898  				m.Desc = &roachpb.RangeDescriptor{}
   899  			}
   900  			if err := m.Desc.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
   901  				return err
   902  			}
   903  			iNdEx = postIndex
   904  		case 4:
   905  			if wireType != 2 {
   906  				return fmt.Errorf("proto: wrong wireType = %d for field Lease", wireType)
   907  			}
   908  			var msglen int
   909  			for shift := uint(0); ; shift += 7 {
   910  				if shift >= 64 {
   911  					return ErrIntOverflowState
   912  				}
   913  				if iNdEx >= l {
   914  					return io.ErrUnexpectedEOF
   915  				}
   916  				b := dAtA[iNdEx]
   917  				iNdEx++
   918  				msglen |= (int(b) & 0x7F) << shift
   919  				if b < 0x80 {
   920  					break
   921  				}
   922  			}
   923  			if msglen < 0 {
   924  				return ErrInvalidLengthState
   925  			}
   926  			postIndex := iNdEx + msglen
   927  			if postIndex > l {
   928  				return io.ErrUnexpectedEOF
   929  			}
   930  			if m.Lease == nil {
   931  				m.Lease = &roachpb.Lease{}
   932  			}
   933  			if err := m.Lease.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
   934  				return err
   935  			}
   936  			iNdEx = postIndex
   937  		case 5:
   938  			if wireType != 2 {
   939  				return fmt.Errorf("proto: wrong wireType = %d for field TruncatedState", wireType)
   940  			}
   941  			var msglen int
   942  			for shift := uint(0); ; shift += 7 {
   943  				if shift >= 64 {
   944  					return ErrIntOverflowState
   945  				}
   946  				if iNdEx >= l {
   947  					return io.ErrUnexpectedEOF
   948  				}
   949  				b := dAtA[iNdEx]
   950  				iNdEx++
   951  				msglen |= (int(b) & 0x7F) << shift
   952  				if b < 0x80 {
   953  					break
   954  				}
   955  			}
   956  			if msglen < 0 {
   957  				return ErrInvalidLengthState
   958  			}
   959  			postIndex := iNdEx + msglen
   960  			if postIndex > l {
   961  				return io.ErrUnexpectedEOF
   962  			}
   963  			if m.TruncatedState == nil {
   964  				m.TruncatedState = &roachpb.RaftTruncatedState{}
   965  			}
   966  			if err := m.TruncatedState.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
   967  				return err
   968  			}
   969  			iNdEx = postIndex
   970  		case 6:
   971  			if wireType != 2 {
   972  				return fmt.Errorf("proto: wrong wireType = %d for field GCThreshold", wireType)
   973  			}
   974  			var msglen int
   975  			for shift := uint(0); ; shift += 7 {
   976  				if shift >= 64 {
   977  					return ErrIntOverflowState
   978  				}
   979  				if iNdEx >= l {
   980  					return io.ErrUnexpectedEOF
   981  				}
   982  				b := dAtA[iNdEx]
   983  				iNdEx++
   984  				msglen |= (int(b) & 0x7F) << shift
   985  				if b < 0x80 {
   986  					break
   987  				}
   988  			}
   989  			if msglen < 0 {
   990  				return ErrInvalidLengthState
   991  			}
   992  			postIndex := iNdEx + msglen
   993  			if postIndex > l {
   994  				return io.ErrUnexpectedEOF
   995  			}
   996  			if m.GCThreshold == nil {
   997  				m.GCThreshold = &hlc.Timestamp{}
   998  			}
   999  			if err := m.GCThreshold.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1000  				return err
  1001  			}
  1002  			iNdEx = postIndex
  1003  		case 7:
  1004  			if wireType != 2 {
  1005  				return fmt.Errorf("proto: wrong wireType = %d for field Stats", wireType)
  1006  			}
  1007  			var msglen int
  1008  			for shift := uint(0); ; shift += 7 {
  1009  				if shift >= 64 {
  1010  					return ErrIntOverflowState
  1011  				}
  1012  				if iNdEx >= l {
  1013  					return io.ErrUnexpectedEOF
  1014  				}
  1015  				b := dAtA[iNdEx]
  1016  				iNdEx++
  1017  				msglen |= (int(b) & 0x7F) << shift
  1018  				if b < 0x80 {
  1019  					break
  1020  				}
  1021  			}
  1022  			if msglen < 0 {
  1023  				return ErrInvalidLengthState
  1024  			}
  1025  			postIndex := iNdEx + msglen
  1026  			if postIndex > l {
  1027  				return io.ErrUnexpectedEOF
  1028  			}
  1029  			if m.Stats == nil {
  1030  				m.Stats = &enginepb.MVCCStats{}
  1031  			}
  1032  			if err := m.Stats.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1033  				return err
  1034  			}
  1035  			iNdEx = postIndex
  1036  		case 11:
  1037  			if wireType != 0 {
  1038  				return fmt.Errorf("proto: wrong wireType = %d for field UsingAppliedStateKey", wireType)
  1039  			}
  1040  			var v int
  1041  			for shift := uint(0); ; shift += 7 {
  1042  				if shift >= 64 {
  1043  					return ErrIntOverflowState
  1044  				}
  1045  				if iNdEx >= l {
  1046  					return io.ErrUnexpectedEOF
  1047  				}
  1048  				b := dAtA[iNdEx]
  1049  				iNdEx++
  1050  				v |= (int(b) & 0x7F) << shift
  1051  				if b < 0x80 {
  1052  					break
  1053  				}
  1054  			}
  1055  			m.UsingAppliedStateKey = bool(v != 0)
  1056  		default:
  1057  			iNdEx = preIndex
  1058  			skippy, err := skipState(dAtA[iNdEx:])
  1059  			if err != nil {
  1060  				return err
  1061  			}
  1062  			if skippy < 0 {
  1063  				return ErrInvalidLengthState
  1064  			}
  1065  			if (iNdEx + skippy) > l {
  1066  				return io.ErrUnexpectedEOF
  1067  			}
  1068  			iNdEx += skippy
  1069  		}
  1070  	}
  1071  
  1072  	if iNdEx > l {
  1073  		return io.ErrUnexpectedEOF
  1074  	}
  1075  	return nil
  1076  }
  1077  func (m *RangeInfo) Unmarshal(dAtA []byte) error {
  1078  	l := len(dAtA)
  1079  	iNdEx := 0
  1080  	for iNdEx < l {
  1081  		preIndex := iNdEx
  1082  		var wire uint64
  1083  		for shift := uint(0); ; shift += 7 {
  1084  			if shift >= 64 {
  1085  				return ErrIntOverflowState
  1086  			}
  1087  			if iNdEx >= l {
  1088  				return io.ErrUnexpectedEOF
  1089  			}
  1090  			b := dAtA[iNdEx]
  1091  			iNdEx++
  1092  			wire |= (uint64(b) & 0x7F) << shift
  1093  			if b < 0x80 {
  1094  				break
  1095  			}
  1096  		}
  1097  		fieldNum := int32(wire >> 3)
  1098  		wireType := int(wire & 0x7)
  1099  		if wireType == 4 {
  1100  			return fmt.Errorf("proto: RangeInfo: wiretype end group for non-group")
  1101  		}
  1102  		if fieldNum <= 0 {
  1103  			return fmt.Errorf("proto: RangeInfo: illegal tag %d (wire type %d)", fieldNum, wire)
  1104  		}
  1105  		switch fieldNum {
  1106  		case 1:
  1107  			if wireType != 2 {
  1108  				return fmt.Errorf("proto: wrong wireType = %d for field ReplicaState", wireType)
  1109  			}
  1110  			var msglen int
  1111  			for shift := uint(0); ; shift += 7 {
  1112  				if shift >= 64 {
  1113  					return ErrIntOverflowState
  1114  				}
  1115  				if iNdEx >= l {
  1116  					return io.ErrUnexpectedEOF
  1117  				}
  1118  				b := dAtA[iNdEx]
  1119  				iNdEx++
  1120  				msglen |= (int(b) & 0x7F) << shift
  1121  				if b < 0x80 {
  1122  					break
  1123  				}
  1124  			}
  1125  			if msglen < 0 {
  1126  				return ErrInvalidLengthState
  1127  			}
  1128  			postIndex := iNdEx + msglen
  1129  			if postIndex > l {
  1130  				return io.ErrUnexpectedEOF
  1131  			}
  1132  			if err := m.ReplicaState.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1133  				return err
  1134  			}
  1135  			iNdEx = postIndex
  1136  		case 2:
  1137  			if wireType != 0 {
  1138  				return fmt.Errorf("proto: wrong wireType = %d for field LastIndex", wireType)
  1139  			}
  1140  			m.LastIndex = 0
  1141  			for shift := uint(0); ; shift += 7 {
  1142  				if shift >= 64 {
  1143  					return ErrIntOverflowState
  1144  				}
  1145  				if iNdEx >= l {
  1146  					return io.ErrUnexpectedEOF
  1147  				}
  1148  				b := dAtA[iNdEx]
  1149  				iNdEx++
  1150  				m.LastIndex |= (uint64(b) & 0x7F) << shift
  1151  				if b < 0x80 {
  1152  					break
  1153  				}
  1154  			}
  1155  		case 3:
  1156  			if wireType != 0 {
  1157  				return fmt.Errorf("proto: wrong wireType = %d for field NumPending", wireType)
  1158  			}
  1159  			m.NumPending = 0
  1160  			for shift := uint(0); ; shift += 7 {
  1161  				if shift >= 64 {
  1162  					return ErrIntOverflowState
  1163  				}
  1164  				if iNdEx >= l {
  1165  					return io.ErrUnexpectedEOF
  1166  				}
  1167  				b := dAtA[iNdEx]
  1168  				iNdEx++
  1169  				m.NumPending |= (uint64(b) & 0x7F) << shift
  1170  				if b < 0x80 {
  1171  					break
  1172  				}
  1173  			}
  1174  		case 5:
  1175  			if wireType != 0 {
  1176  				return fmt.Errorf("proto: wrong wireType = %d for field NumDropped", wireType)
  1177  			}
  1178  			m.NumDropped = 0
  1179  			for shift := uint(0); ; shift += 7 {
  1180  				if shift >= 64 {
  1181  					return ErrIntOverflowState
  1182  				}
  1183  				if iNdEx >= l {
  1184  					return io.ErrUnexpectedEOF
  1185  				}
  1186  				b := dAtA[iNdEx]
  1187  				iNdEx++
  1188  				m.NumDropped |= (uint64(b) & 0x7F) << shift
  1189  				if b < 0x80 {
  1190  					break
  1191  				}
  1192  			}
  1193  		case 6:
  1194  			if wireType != 0 {
  1195  				return fmt.Errorf("proto: wrong wireType = %d for field RaftLogSize", wireType)
  1196  			}
  1197  			m.RaftLogSize = 0
  1198  			for shift := uint(0); ; shift += 7 {
  1199  				if shift >= 64 {
  1200  					return ErrIntOverflowState
  1201  				}
  1202  				if iNdEx >= l {
  1203  					return io.ErrUnexpectedEOF
  1204  				}
  1205  				b := dAtA[iNdEx]
  1206  				iNdEx++
  1207  				m.RaftLogSize |= (int64(b) & 0x7F) << shift
  1208  				if b < 0x80 {
  1209  					break
  1210  				}
  1211  			}
  1212  		case 7:
  1213  			if wireType != 0 {
  1214  				return fmt.Errorf("proto: wrong wireType = %d for field ApproximateProposalQuota", wireType)
  1215  			}
  1216  			m.ApproximateProposalQuota = 0
  1217  			for shift := uint(0); ; shift += 7 {
  1218  				if shift >= 64 {
  1219  					return ErrIntOverflowState
  1220  				}
  1221  				if iNdEx >= l {
  1222  					return io.ErrUnexpectedEOF
  1223  				}
  1224  				b := dAtA[iNdEx]
  1225  				iNdEx++
  1226  				m.ApproximateProposalQuota |= (int64(b) & 0x7F) << shift
  1227  				if b < 0x80 {
  1228  					break
  1229  				}
  1230  			}
  1231  		case 8:
  1232  			if wireType != 0 {
  1233  				return fmt.Errorf("proto: wrong wireType = %d for field RangeMaxBytes", wireType)
  1234  			}
  1235  			m.RangeMaxBytes = 0
  1236  			for shift := uint(0); ; shift += 7 {
  1237  				if shift >= 64 {
  1238  					return ErrIntOverflowState
  1239  				}
  1240  				if iNdEx >= l {
  1241  					return io.ErrUnexpectedEOF
  1242  				}
  1243  				b := dAtA[iNdEx]
  1244  				iNdEx++
  1245  				m.RangeMaxBytes |= (int64(b) & 0x7F) << shift
  1246  				if b < 0x80 {
  1247  					break
  1248  				}
  1249  			}
  1250  		case 10:
  1251  			if wireType != 0 {
  1252  				return fmt.Errorf("proto: wrong wireType = %d for field RaftLogSizeTrusted", wireType)
  1253  			}
  1254  			var v int
  1255  			for shift := uint(0); ; shift += 7 {
  1256  				if shift >= 64 {
  1257  					return ErrIntOverflowState
  1258  				}
  1259  				if iNdEx >= l {
  1260  					return io.ErrUnexpectedEOF
  1261  				}
  1262  				b := dAtA[iNdEx]
  1263  				iNdEx++
  1264  				v |= (int(b) & 0x7F) << shift
  1265  				if b < 0x80 {
  1266  					break
  1267  				}
  1268  			}
  1269  			m.RaftLogSizeTrusted = bool(v != 0)
  1270  		case 11:
  1271  			if wireType != 2 {
  1272  				return fmt.Errorf("proto: wrong wireType = %d for field NewestClosedTimestamp", wireType)
  1273  			}
  1274  			var msglen int
  1275  			for shift := uint(0); ; shift += 7 {
  1276  				if shift >= 64 {
  1277  					return ErrIntOverflowState
  1278  				}
  1279  				if iNdEx >= l {
  1280  					return io.ErrUnexpectedEOF
  1281  				}
  1282  				b := dAtA[iNdEx]
  1283  				iNdEx++
  1284  				msglen |= (int(b) & 0x7F) << shift
  1285  				if b < 0x80 {
  1286  					break
  1287  				}
  1288  			}
  1289  			if msglen < 0 {
  1290  				return ErrInvalidLengthState
  1291  			}
  1292  			postIndex := iNdEx + msglen
  1293  			if postIndex > l {
  1294  				return io.ErrUnexpectedEOF
  1295  			}
  1296  			if err := m.NewestClosedTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1297  				return err
  1298  			}
  1299  			iNdEx = postIndex
  1300  		case 12:
  1301  			if wireType != 2 {
  1302  				return fmt.Errorf("proto: wrong wireType = %d for field ActiveClosedTimestamp", wireType)
  1303  			}
  1304  			var msglen int
  1305  			for shift := uint(0); ; shift += 7 {
  1306  				if shift >= 64 {
  1307  					return ErrIntOverflowState
  1308  				}
  1309  				if iNdEx >= l {
  1310  					return io.ErrUnexpectedEOF
  1311  				}
  1312  				b := dAtA[iNdEx]
  1313  				iNdEx++
  1314  				msglen |= (int(b) & 0x7F) << shift
  1315  				if b < 0x80 {
  1316  					break
  1317  				}
  1318  			}
  1319  			if msglen < 0 {
  1320  				return ErrInvalidLengthState
  1321  			}
  1322  			postIndex := iNdEx + msglen
  1323  			if postIndex > l {
  1324  				return io.ErrUnexpectedEOF
  1325  			}
  1326  			if err := m.ActiveClosedTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1327  				return err
  1328  			}
  1329  			iNdEx = postIndex
  1330  		case 13:
  1331  			if wireType != 0 {
  1332  				return fmt.Errorf("proto: wrong wireType = %d for field RangefeedRegistrations", wireType)
  1333  			}
  1334  			m.RangefeedRegistrations = 0
  1335  			for shift := uint(0); ; shift += 7 {
  1336  				if shift >= 64 {
  1337  					return ErrIntOverflowState
  1338  				}
  1339  				if iNdEx >= l {
  1340  					return io.ErrUnexpectedEOF
  1341  				}
  1342  				b := dAtA[iNdEx]
  1343  				iNdEx++
  1344  				m.RangefeedRegistrations |= (int64(b) & 0x7F) << shift
  1345  				if b < 0x80 {
  1346  					break
  1347  				}
  1348  			}
  1349  		case 14:
  1350  			if wireType != 0 {
  1351  				return fmt.Errorf("proto: wrong wireType = %d for field ProposalQuotaBaseIndex", wireType)
  1352  			}
  1353  			m.ProposalQuotaBaseIndex = 0
  1354  			for shift := uint(0); ; shift += 7 {
  1355  				if shift >= 64 {
  1356  					return ErrIntOverflowState
  1357  				}
  1358  				if iNdEx >= l {
  1359  					return io.ErrUnexpectedEOF
  1360  				}
  1361  				b := dAtA[iNdEx]
  1362  				iNdEx++
  1363  				m.ProposalQuotaBaseIndex |= (int64(b) & 0x7F) << shift
  1364  				if b < 0x80 {
  1365  					break
  1366  				}
  1367  			}
  1368  		case 15:
  1369  			if wireType == 0 {
  1370  				var v int64
  1371  				for shift := uint(0); ; shift += 7 {
  1372  					if shift >= 64 {
  1373  						return ErrIntOverflowState
  1374  					}
  1375  					if iNdEx >= l {
  1376  						return io.ErrUnexpectedEOF
  1377  					}
  1378  					b := dAtA[iNdEx]
  1379  					iNdEx++
  1380  					v |= (int64(b) & 0x7F) << shift
  1381  					if b < 0x80 {
  1382  						break
  1383  					}
  1384  				}
  1385  				m.ProposalQuotaReleaseQueue = append(m.ProposalQuotaReleaseQueue, v)
  1386  			} else if wireType == 2 {
  1387  				var packedLen int
  1388  				for shift := uint(0); ; shift += 7 {
  1389  					if shift >= 64 {
  1390  						return ErrIntOverflowState
  1391  					}
  1392  					if iNdEx >= l {
  1393  						return io.ErrUnexpectedEOF
  1394  					}
  1395  					b := dAtA[iNdEx]
  1396  					iNdEx++
  1397  					packedLen |= (int(b) & 0x7F) << shift
  1398  					if b < 0x80 {
  1399  						break
  1400  					}
  1401  				}
  1402  				if packedLen < 0 {
  1403  					return ErrInvalidLengthState
  1404  				}
  1405  				postIndex := iNdEx + packedLen
  1406  				if postIndex > l {
  1407  					return io.ErrUnexpectedEOF
  1408  				}
  1409  				var elementCount int
  1410  				var count int
  1411  				for _, integer := range dAtA {
  1412  					if integer < 128 {
  1413  						count++
  1414  					}
  1415  				}
  1416  				elementCount = count
  1417  				if elementCount != 0 && len(m.ProposalQuotaReleaseQueue) == 0 {
  1418  					m.ProposalQuotaReleaseQueue = make([]int64, 0, elementCount)
  1419  				}
  1420  				for iNdEx < postIndex {
  1421  					var v int64
  1422  					for shift := uint(0); ; shift += 7 {
  1423  						if shift >= 64 {
  1424  							return ErrIntOverflowState
  1425  						}
  1426  						if iNdEx >= l {
  1427  							return io.ErrUnexpectedEOF
  1428  						}
  1429  						b := dAtA[iNdEx]
  1430  						iNdEx++
  1431  						v |= (int64(b) & 0x7F) << shift
  1432  						if b < 0x80 {
  1433  							break
  1434  						}
  1435  					}
  1436  					m.ProposalQuotaReleaseQueue = append(m.ProposalQuotaReleaseQueue, v)
  1437  				}
  1438  			} else {
  1439  				return fmt.Errorf("proto: wrong wireType = %d for field ProposalQuotaReleaseQueue", wireType)
  1440  			}
  1441  		default:
  1442  			iNdEx = preIndex
  1443  			skippy, err := skipState(dAtA[iNdEx:])
  1444  			if err != nil {
  1445  				return err
  1446  			}
  1447  			if skippy < 0 {
  1448  				return ErrInvalidLengthState
  1449  			}
  1450  			if (iNdEx + skippy) > l {
  1451  				return io.ErrUnexpectedEOF
  1452  			}
  1453  			iNdEx += skippy
  1454  		}
  1455  	}
  1456  
  1457  	if iNdEx > l {
  1458  		return io.ErrUnexpectedEOF
  1459  	}
  1460  	return nil
  1461  }
  1462  func (m *RangeInfo_CTEntry) Unmarshal(dAtA []byte) error {
  1463  	l := len(dAtA)
  1464  	iNdEx := 0
  1465  	for iNdEx < l {
  1466  		preIndex := iNdEx
  1467  		var wire uint64
  1468  		for shift := uint(0); ; shift += 7 {
  1469  			if shift >= 64 {
  1470  				return ErrIntOverflowState
  1471  			}
  1472  			if iNdEx >= l {
  1473  				return io.ErrUnexpectedEOF
  1474  			}
  1475  			b := dAtA[iNdEx]
  1476  			iNdEx++
  1477  			wire |= (uint64(b) & 0x7F) << shift
  1478  			if b < 0x80 {
  1479  				break
  1480  			}
  1481  		}
  1482  		fieldNum := int32(wire >> 3)
  1483  		wireType := int(wire & 0x7)
  1484  		if wireType == 4 {
  1485  			return fmt.Errorf("proto: CTEntry: wiretype end group for non-group")
  1486  		}
  1487  		if fieldNum <= 0 {
  1488  			return fmt.Errorf("proto: CTEntry: illegal tag %d (wire type %d)", fieldNum, wire)
  1489  		}
  1490  		switch fieldNum {
  1491  		case 1:
  1492  			if wireType != 0 {
  1493  				return fmt.Errorf("proto: wrong wireType = %d for field NodeID", wireType)
  1494  			}
  1495  			m.NodeID = 0
  1496  			for shift := uint(0); ; shift += 7 {
  1497  				if shift >= 64 {
  1498  					return ErrIntOverflowState
  1499  				}
  1500  				if iNdEx >= l {
  1501  					return io.ErrUnexpectedEOF
  1502  				}
  1503  				b := dAtA[iNdEx]
  1504  				iNdEx++
  1505  				m.NodeID |= (github_com_cockroachdb_cockroach_pkg_roachpb.NodeID(b) & 0x7F) << shift
  1506  				if b < 0x80 {
  1507  					break
  1508  				}
  1509  			}
  1510  		case 2:
  1511  			if wireType != 2 {
  1512  				return fmt.Errorf("proto: wrong wireType = %d for field ClosedTimestamp", wireType)
  1513  			}
  1514  			var msglen int
  1515  			for shift := uint(0); ; shift += 7 {
  1516  				if shift >= 64 {
  1517  					return ErrIntOverflowState
  1518  				}
  1519  				if iNdEx >= l {
  1520  					return io.ErrUnexpectedEOF
  1521  				}
  1522  				b := dAtA[iNdEx]
  1523  				iNdEx++
  1524  				msglen |= (int(b) & 0x7F) << shift
  1525  				if b < 0x80 {
  1526  					break
  1527  				}
  1528  			}
  1529  			if msglen < 0 {
  1530  				return ErrInvalidLengthState
  1531  			}
  1532  			postIndex := iNdEx + msglen
  1533  			if postIndex > l {
  1534  				return io.ErrUnexpectedEOF
  1535  			}
  1536  			if err := m.ClosedTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1537  				return err
  1538  			}
  1539  			iNdEx = postIndex
  1540  		case 3:
  1541  			if wireType != 0 {
  1542  				return fmt.Errorf("proto: wrong wireType = %d for field MLAI", wireType)
  1543  			}
  1544  			m.MLAI = 0
  1545  			for shift := uint(0); ; shift += 7 {
  1546  				if shift >= 64 {
  1547  					return ErrIntOverflowState
  1548  				}
  1549  				if iNdEx >= l {
  1550  					return io.ErrUnexpectedEOF
  1551  				}
  1552  				b := dAtA[iNdEx]
  1553  				iNdEx++
  1554  				m.MLAI |= (int64(b) & 0x7F) << shift
  1555  				if b < 0x80 {
  1556  					break
  1557  				}
  1558  			}
  1559  		case 4:
  1560  			if wireType != 0 {
  1561  				return fmt.Errorf("proto: wrong wireType = %d for field Epoch", wireType)
  1562  			}
  1563  			m.Epoch = 0
  1564  			for shift := uint(0); ; shift += 7 {
  1565  				if shift >= 64 {
  1566  					return ErrIntOverflowState
  1567  				}
  1568  				if iNdEx >= l {
  1569  					return io.ErrUnexpectedEOF
  1570  				}
  1571  				b := dAtA[iNdEx]
  1572  				iNdEx++
  1573  				m.Epoch |= (int64(b) & 0x7F) << shift
  1574  				if b < 0x80 {
  1575  					break
  1576  				}
  1577  			}
  1578  		default:
  1579  			iNdEx = preIndex
  1580  			skippy, err := skipState(dAtA[iNdEx:])
  1581  			if err != nil {
  1582  				return err
  1583  			}
  1584  			if skippy < 0 {
  1585  				return ErrInvalidLengthState
  1586  			}
  1587  			if (iNdEx + skippy) > l {
  1588  				return io.ErrUnexpectedEOF
  1589  			}
  1590  			iNdEx += skippy
  1591  		}
  1592  	}
  1593  
  1594  	if iNdEx > l {
  1595  		return io.ErrUnexpectedEOF
  1596  	}
  1597  	return nil
  1598  }
  1599  func (m *LatchManagerInfo) Unmarshal(dAtA []byte) error {
  1600  	l := len(dAtA)
  1601  	iNdEx := 0
  1602  	for iNdEx < l {
  1603  		preIndex := iNdEx
  1604  		var wire uint64
  1605  		for shift := uint(0); ; shift += 7 {
  1606  			if shift >= 64 {
  1607  				return ErrIntOverflowState
  1608  			}
  1609  			if iNdEx >= l {
  1610  				return io.ErrUnexpectedEOF
  1611  			}
  1612  			b := dAtA[iNdEx]
  1613  			iNdEx++
  1614  			wire |= (uint64(b) & 0x7F) << shift
  1615  			if b < 0x80 {
  1616  				break
  1617  			}
  1618  		}
  1619  		fieldNum := int32(wire >> 3)
  1620  		wireType := int(wire & 0x7)
  1621  		if wireType == 4 {
  1622  			return fmt.Errorf("proto: LatchManagerInfo: wiretype end group for non-group")
  1623  		}
  1624  		if fieldNum <= 0 {
  1625  			return fmt.Errorf("proto: LatchManagerInfo: illegal tag %d (wire type %d)", fieldNum, wire)
  1626  		}
  1627  		switch fieldNum {
  1628  		case 1:
  1629  			if wireType != 0 {
  1630  				return fmt.Errorf("proto: wrong wireType = %d for field ReadCount", wireType)
  1631  			}
  1632  			m.ReadCount = 0
  1633  			for shift := uint(0); ; shift += 7 {
  1634  				if shift >= 64 {
  1635  					return ErrIntOverflowState
  1636  				}
  1637  				if iNdEx >= l {
  1638  					return io.ErrUnexpectedEOF
  1639  				}
  1640  				b := dAtA[iNdEx]
  1641  				iNdEx++
  1642  				m.ReadCount |= (int64(b) & 0x7F) << shift
  1643  				if b < 0x80 {
  1644  					break
  1645  				}
  1646  			}
  1647  		case 2:
  1648  			if wireType != 0 {
  1649  				return fmt.Errorf("proto: wrong wireType = %d for field WriteCount", wireType)
  1650  			}
  1651  			m.WriteCount = 0
  1652  			for shift := uint(0); ; shift += 7 {
  1653  				if shift >= 64 {
  1654  					return ErrIntOverflowState
  1655  				}
  1656  				if iNdEx >= l {
  1657  					return io.ErrUnexpectedEOF
  1658  				}
  1659  				b := dAtA[iNdEx]
  1660  				iNdEx++
  1661  				m.WriteCount |= (int64(b) & 0x7F) << shift
  1662  				if b < 0x80 {
  1663  					break
  1664  				}
  1665  			}
  1666  		default:
  1667  			iNdEx = preIndex
  1668  			skippy, err := skipState(dAtA[iNdEx:])
  1669  			if err != nil {
  1670  				return err
  1671  			}
  1672  			if skippy < 0 {
  1673  				return ErrInvalidLengthState
  1674  			}
  1675  			if (iNdEx + skippy) > l {
  1676  				return io.ErrUnexpectedEOF
  1677  			}
  1678  			iNdEx += skippy
  1679  		}
  1680  	}
  1681  
  1682  	if iNdEx > l {
  1683  		return io.ErrUnexpectedEOF
  1684  	}
  1685  	return nil
  1686  }
  1687  func skipState(dAtA []byte) (n int, err error) {
  1688  	l := len(dAtA)
  1689  	iNdEx := 0
  1690  	for iNdEx < l {
  1691  		var wire uint64
  1692  		for shift := uint(0); ; shift += 7 {
  1693  			if shift >= 64 {
  1694  				return 0, ErrIntOverflowState
  1695  			}
  1696  			if iNdEx >= l {
  1697  				return 0, io.ErrUnexpectedEOF
  1698  			}
  1699  			b := dAtA[iNdEx]
  1700  			iNdEx++
  1701  			wire |= (uint64(b) & 0x7F) << shift
  1702  			if b < 0x80 {
  1703  				break
  1704  			}
  1705  		}
  1706  		wireType := int(wire & 0x7)
  1707  		switch wireType {
  1708  		case 0:
  1709  			for shift := uint(0); ; shift += 7 {
  1710  				if shift >= 64 {
  1711  					return 0, ErrIntOverflowState
  1712  				}
  1713  				if iNdEx >= l {
  1714  					return 0, io.ErrUnexpectedEOF
  1715  				}
  1716  				iNdEx++
  1717  				if dAtA[iNdEx-1] < 0x80 {
  1718  					break
  1719  				}
  1720  			}
  1721  			return iNdEx, nil
  1722  		case 1:
  1723  			iNdEx += 8
  1724  			return iNdEx, nil
  1725  		case 2:
  1726  			var length int
  1727  			for shift := uint(0); ; shift += 7 {
  1728  				if shift >= 64 {
  1729  					return 0, ErrIntOverflowState
  1730  				}
  1731  				if iNdEx >= l {
  1732  					return 0, io.ErrUnexpectedEOF
  1733  				}
  1734  				b := dAtA[iNdEx]
  1735  				iNdEx++
  1736  				length |= (int(b) & 0x7F) << shift
  1737  				if b < 0x80 {
  1738  					break
  1739  				}
  1740  			}
  1741  			iNdEx += length
  1742  			if length < 0 {
  1743  				return 0, ErrInvalidLengthState
  1744  			}
  1745  			return iNdEx, nil
  1746  		case 3:
  1747  			for {
  1748  				var innerWire uint64
  1749  				var start int = iNdEx
  1750  				for shift := uint(0); ; shift += 7 {
  1751  					if shift >= 64 {
  1752  						return 0, ErrIntOverflowState
  1753  					}
  1754  					if iNdEx >= l {
  1755  						return 0, io.ErrUnexpectedEOF
  1756  					}
  1757  					b := dAtA[iNdEx]
  1758  					iNdEx++
  1759  					innerWire |= (uint64(b) & 0x7F) << shift
  1760  					if b < 0x80 {
  1761  						break
  1762  					}
  1763  				}
  1764  				innerWireType := int(innerWire & 0x7)
  1765  				if innerWireType == 4 {
  1766  					break
  1767  				}
  1768  				next, err := skipState(dAtA[start:])
  1769  				if err != nil {
  1770  					return 0, err
  1771  				}
  1772  				iNdEx = start + next
  1773  			}
  1774  			return iNdEx, nil
  1775  		case 4:
  1776  			return iNdEx, nil
  1777  		case 5:
  1778  			iNdEx += 4
  1779  			return iNdEx, nil
  1780  		default:
  1781  			return 0, fmt.Errorf("proto: illegal wireType %d", wireType)
  1782  		}
  1783  	}
  1784  	panic("unreachable")
  1785  }
  1786  
  1787  var (
  1788  	ErrInvalidLengthState = fmt.Errorf("proto: negative length found during unmarshaling")
  1789  	ErrIntOverflowState   = fmt.Errorf("proto: integer overflow")
  1790  )
  1791  
  1792  func init() {
  1793  	proto.RegisterFile("kv/kvserver/kvserverpb/state.proto", fileDescriptor_state_e26e666ce309a848)
  1794  }
  1795  
  1796  var fileDescriptor_state_e26e666ce309a848 = []byte{
  1797  	// 993 bytes of a gzipped FileDescriptorProto
  1798  	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x8c, 0x55, 0x4f, 0x6f, 0xdb, 0xc6,
  1799  	0x13, 0x35, 0x2d, 0xca, 0x96, 0x57, 0x76, 0xac, 0xdf, 0xfe, 0x9c, 0x98, 0x71, 0x62, 0xc9, 0x10,
  1800  	0xd0, 0xc2, 0x87, 0x94, 0x44, 0x1d, 0xb4, 0x45, 0xff, 0x00, 0x85, 0x25, 0x17, 0x85, 0x5d, 0xdb,
  1801  	0x88, 0x19, 0xa1, 0x87, 0xf4, 0x40, 0xac, 0xc8, 0x31, 0x45, 0x88, 0xe2, 0x6e, 0x76, 0x97, 0x8a,
  1802  	0x9d, 0x53, 0x81, 0x7e, 0x81, 0x7e, 0x84, 0x7e, 0x1c, 0x1f, 0x7d, 0xcc, 0x49, 0x68, 0xe5, 0x4b,
  1803  	0x6f, 0xbd, 0xf7, 0x54, 0xec, 0x2e, 0x25, 0x4b, 0x76, 0x80, 0xe4, 0xb6, 0x7c, 0xef, 0xcd, 0x70,
  1804  	0xf6, 0xcd, 0x70, 0x88, 0x9a, 0xfd, 0xa1, 0xd7, 0x1f, 0x0a, 0xe0, 0x43, 0xe0, 0xd3, 0x03, 0xeb,
  1805  	0x7a, 0x42, 0x12, 0x09, 0x2e, 0xe3, 0x54, 0x52, 0xdc, 0x08, 0x69, 0xd8, 0xe7, 0x94, 0x84, 0x3d,
  1806  	0xb7, 0x3f, 0x74, 0x27, 0x22, 0x57, 0x48, 0xca, 0x49, 0x0c, 0xac, 0xbb, 0xf5, 0xa4, 0x38, 0x7a,
  1807  	0x90, 0xc5, 0x49, 0x06, 0xac, 0xeb, 0x0d, 0x86, 0x61, 0x68, 0xa2, 0xb7, 0x9e, 0xe8, 0x48, 0xd6,
  1808  	0xf5, 0x92, 0x4c, 0x02, 0xcf, 0x48, 0x1a, 0x70, 0x72, 0x2e, 0x0b, 0xf2, 0xd1, 0x84, 0x1c, 0x80,
  1809  	0x24, 0x11, 0x91, 0xa4, 0xc0, 0xf1, 0x04, 0x9f, 0xc1, 0x9c, 0x5c, 0x26, 0xa9, 0xd7, 0x4b, 0x43,
  1810  	0x4f, 0x26, 0x03, 0x10, 0x92, 0x0c, 0x58, 0xc1, 0x6c, 0xc4, 0x34, 0xa6, 0xfa, 0xe8, 0xa9, 0x93,
  1811  	0x41, 0x9b, 0xbf, 0xd9, 0x68, 0xd5, 0x07, 0x96, 0x26, 0x21, 0x79, 0xa9, 0x6e, 0x83, 0x9f, 0x21,
  1812  	0xac, 0x5e, 0x1d, 0x10, 0xc6, 0xd2, 0x04, 0xa2, 0x20, 0xc9, 0x22, 0xb8, 0x70, 0xac, 0x1d, 0x6b,
  1813  	0xd7, 0xf6, 0x6b, 0x8a, 0xd9, 0x37, 0xc4, 0xa1, 0xc2, 0xb1, 0x8b, 0xfe, 0x9f, 0x02, 0x11, 0x70,
  1814  	0x47, 0xbe, 0xa8, 0xe5, 0xff, 0xd3, 0xd4, 0x9c, 0xfe, 0x4b, 0x64, 0x47, 0x20, 0x42, 0xa7, 0xb4,
  1815  	0x63, 0xed, 0x56, 0xf7, 0x9a, 0xee, 0xad, 0x69, 0xc5, 0x5d, 0x5c, 0x9f, 0x64, 0x31, 0x1c, 0x80,
  1816  	0x08, 0x79, 0xc2, 0x24, 0xe5, 0xbe, 0xd6, 0x63, 0x17, 0x95, 0x75, 0x32, 0xc7, 0xd6, 0x81, 0xce,
  1817  	0x7b, 0x02, 0x8f, 0x15, 0xef, 0x1b, 0x19, 0x3e, 0x45, 0xeb, 0x92, 0xe7, 0x59, 0x48, 0x24, 0x44,
  1818  	0x81, 0x6e, 0x93, 0x53, 0xd6, 0x91, 0x9f, 0xbc, 0xf7, 0x95, 0xe7, 0xb2, 0x33, 0x51, 0x6b, 0x17,
  1819  	0xfc, 0x07, 0x72, 0xee, 0x19, 0x9f, 0xa1, 0xd5, 0x38, 0x0c, 0x64, 0x8f, 0x83, 0xe8, 0xd1, 0x34,
  1820  	0x72, 0x96, 0x74, 0xb2, 0xed, 0x99, 0x64, 0xca, 0x77, 0xb7, 0x97, 0x86, 0x6e, 0x67, 0xe2, 0x7b,
  1821  	0x6b, 0x7d, 0x3c, 0x6a, 0x54, 0x7f, 0x6c, 0x77, 0x26, 0x51, 0x7e, 0x35, 0x0e, 0xa7, 0x0f, 0xf8,
  1822  	0x5b, 0x54, 0x56, 0x85, 0x09, 0x67, 0xf9, 0x5e, 0x61, 0xc5, 0xa4, 0xb8, 0x93, 0x49, 0x71, 0x4f,
  1823  	0x7e, 0x6e, 0xb7, 0x55, 0x21, 0xc2, 0x37, 0x31, 0xf8, 0x0b, 0xb4, 0x99, 0x8b, 0x24, 0x8b, 0xa7,
  1824  	0xbe, 0xeb, 0x3b, 0x06, 0x7d, 0xb8, 0x74, 0xaa, 0x3b, 0xd6, 0x6e, 0xc5, 0xdf, 0xd0, 0x74, 0xe1,
  1825  	0xbd, 0xbe, 0xc3, 0x4f, 0x70, 0xf9, 0x8d, 0xfd, 0xf7, 0x1f, 0x0d, 0xeb, 0xc8, 0xae, 0x54, 0x6a,
  1826  	0x2b, 0x47, 0x76, 0x65, 0xa5, 0x86, 0x8e, 0xec, 0x0a, 0xaa, 0x55, 0x9b, 0xbf, 0x56, 0xd0, 0x8a,
  1827  	0x36, 0xfe, 0x30, 0x3b, 0xa7, 0xf8, 0xc4, 0x54, 0x06, 0xba, 0xeb, 0xd5, 0xbd, 0xcf, 0xdc, 0x0f,
  1828  	0x8c, 0xb6, 0x3b, 0x3b, 0x40, 0xad, 0xca, 0xd5, 0xa8, 0xb1, 0x70, 0x3d, 0x6a, 0x58, 0xa6, 0x56,
  1829  	0xc0, 0xdb, 0x08, 0xa5, 0x44, 0xc8, 0xb9, 0xd1, 0x58, 0x51, 0x88, 0x19, 0x89, 0x06, 0xaa, 0x66,
  1830  	0xf9, 0x20, 0x60, 0x90, 0x45, 0x49, 0x16, 0xeb, 0xc9, 0xb0, 0x7d, 0x94, 0xe5, 0x83, 0x17, 0x06,
  1831  	0x99, 0x08, 0x22, 0x4e, 0x19, 0x83, 0x48, 0xf7, 0xd1, 0x08, 0x0e, 0x0c, 0x82, 0x9b, 0x68, 0x4d,
  1832  	0x8f, 0x6c, 0x4a, 0xe3, 0x40, 0x24, 0x6f, 0x41, 0x77, 0xa7, 0xe4, 0x57, 0x15, 0x78, 0x4c, 0xe3,
  1833  	0x97, 0xc9, 0x5b, 0xc0, 0xdf, 0xa1, 0x2d, 0xc2, 0x18, 0xa7, 0x17, 0xc9, 0x40, 0x19, 0xc5, 0x38,
  1834  	0x65, 0x54, 0x90, 0x34, 0x78, 0x9d, 0x53, 0x49, 0x74, 0x0b, 0x4a, 0xbe, 0x33, 0xa3, 0x78, 0x51,
  1835  	0x08, 0xce, 0x14, 0x8f, 0x3f, 0x45, 0xeb, 0x5c, 0xd9, 0x13, 0x0c, 0xc8, 0x45, 0xd0, 0xbd, 0x94,
  1836  	0x20, 0x9c, 0x8a, 0x0e, 0x59, 0xd3, 0xf0, 0x09, 0xb9, 0x68, 0x29, 0x10, 0x7f, 0x8e, 0x1e, 0xce,
  1837  	0x55, 0x12, 0x48, 0x9e, 0x0b, 0x09, 0x91, 0x83, 0x74, 0x53, 0xf0, 0x4c, 0x45, 0x1d, 0xc3, 0x60,
  1838  	0x86, 0x36, 0x33, 0x78, 0x03, 0x42, 0x06, 0x61, 0x4a, 0x05, 0x44, 0xc1, 0xf4, 0xbb, 0xd5, 0x9d,
  1839  	0xac, 0xee, 0xed, 0x7d, 0xd8, 0xfe, 0x49, 0xe7, 0xdc, 0x76, 0xe7, 0x87, 0x4c, 0xf2, 0xcb, 0x96,
  1840  	0xad, 0x7a, 0xe0, 0x3f, 0x34, 0x89, 0xdb, 0x3a, 0xef, 0x74, 0x2c, 0xf1, 0x2f, 0x68, 0x93, 0x84,
  1841  	0x32, 0x19, 0xc2, 0xfd, 0x37, 0xae, 0x7e, 0xcc, 0x58, 0x17, 0xc9, 0x4d, 0x8e, 0xbb, 0xc9, 0xbf,
  1842  	0x42, 0x9b, 0xda, 0x92, 0x73, 0x80, 0x28, 0xe0, 0x10, 0x27, 0x42, 0x72, 0x22, 0x13, 0x9a, 0x09,
  1843  	0x67, 0x4d, 0x3b, 0xf6, 0x68, 0x4a, 0xfb, 0xb3, 0x2c, 0xfe, 0x1a, 0x3d, 0x9e, 0x6f, 0x4a, 0xd0,
  1844  	0x55, 0x7b, 0xc5, 0x0c, 0xcd, 0x03, 0x13, 0xca, 0x66, 0x9b, 0xd2, 0x22, 0x02, 0xcc, 0x04, 0x7d,
  1845  	0x8f, 0x9e, 0xde, 0x09, 0xe5, 0x60, 0xb6, 0xd2, 0xeb, 0x1c, 0x72, 0x70, 0xd6, 0x77, 0x4a, 0xbb,
  1846  	0x25, 0xff, 0xf1, 0x5c, 0xb4, 0x6f, 0x14, 0x67, 0x4a, 0xb0, 0xf5, 0x8f, 0x85, 0x96, 0x0b, 0xeb,
  1847  	0xf0, 0x2b, 0xb4, 0x9c, 0xd1, 0x08, 0x82, 0x24, 0xd2, 0xe3, 0x5f, 0x6e, 0xed, 0x8f, 0x47, 0x8d,
  1848  	0xa5, 0x53, 0x1a, 0xc1, 0xe1, 0xc1, 0xbf, 0xa3, 0xc6, 0xf3, 0x38, 0x91, 0xbd, 0xbc, 0xeb, 0x86,
  1849  	0x74, 0xe0, 0x4d, 0x5d, 0x8a, 0xba, 0xb7, 0x67, 0x8f, 0xf5, 0x63, 0x6f, 0xb2, 0x59, 0x4c, 0x98,
  1850  	0xbf, 0xa4, 0x32, 0x1e, 0x46, 0xf8, 0x14, 0xd5, 0xee, 0x59, 0xbe, 0xf8, 0xf1, 0x96, 0xaf, 0x87,
  1851  	0x77, 0xcc, 0x7e, 0x8a, 0xec, 0x41, 0x4a, 0x12, 0xfd, 0xcd, 0x94, 0x5a, 0x95, 0xf1, 0xa8, 0x61,
  1852  	0x9f, 0x1c, 0xef, 0x1f, 0xfa, 0x1a, 0xc5, 0x1b, 0xa8, 0x0c, 0x8c, 0x86, 0x3d, 0xbd, 0x33, 0x4b,
  1853  	0xbe, 0x79, 0x30, 0x2b, 0x60, 0xba, 0x08, 0xec, 0x5a, 0xd9, 0x2c, 0x82, 0xa6, 0x8f, 0x6a, 0xc7,
  1854  	0x44, 0x86, 0xbd, 0x13, 0x92, 0x91, 0x18, 0xb8, 0x5e, 0x04, 0xdb, 0x08, 0x71, 0x20, 0x51, 0x10,
  1855  	0xd2, 0x3c, 0x93, 0xda, 0x8e, 0x92, 0xbf, 0xa2, 0x90, 0xb6, 0x02, 0xd4, 0x87, 0xf9, 0x86, 0x27,
  1856  	0x12, 0x0a, 0x7e, 0x51, 0xf3, 0x48, 0x43, 0x5a, 0xd0, 0x7a, 0x76, 0xf5, 0x57, 0x7d, 0xe1, 0x6a,
  1857  	0x5c, 0xb7, 0xae, 0xc7, 0x75, 0xeb, 0xdd, 0xb8, 0x6e, 0xfd, 0x39, 0xae, 0x5b, 0xbf, 0xdf, 0xd4,
  1858  	0x17, 0xae, 0x6f, 0xea, 0x0b, 0xef, 0x6e, 0xea, 0x0b, 0xaf, 0xd0, 0xed, 0xdf, 0xb4, 0xbb, 0xa4,
  1859  	0xff, 0x48, 0xcf, 0xff, 0x0b, 0x00, 0x00, 0xff, 0xff, 0xab, 0xb2, 0x53, 0xe6, 0x6e, 0x07, 0x00,
  1860  	0x00,
  1861  }