github.com/cockroachdb/cockroach@v20.2.0-alpha.1+incompatible/pkg/roachpb/errors.pb.go (about)

     1  // Code generated by protoc-gen-gogo. DO NOT EDIT.
     2  // source: roachpb/errors.proto
     3  
     4  package roachpb
     5  
     6  import proto "github.com/gogo/protobuf/proto"
     7  import fmt "fmt"
     8  import math "math"
     9  import hlc "github.com/cockroachdb/cockroach/pkg/util/hlc"
    10  
    11  import github_com_cockroachdb_cockroach_pkg_util_uuid "github.com/cockroachdb/cockroach/pkg/util/uuid"
    12  
    13  import bytes "bytes"
    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  // TransactionAbortedReason specifies what caused a TransactionAbortedError.
    29  // The reasons below are not necessarily disjoint - they describe where the
    30  // error was generated, but generally it's possible that a
    31  // TransactionAbortedError would have been generated somewhere else if the
    32  // client would have performed different operations.
    33  type TransactionAbortedReason int32
    34  
    35  const (
    36  	// For backwards compatibility.
    37  	ABORT_REASON_UNKNOWN TransactionAbortedReason = 0
    38  	// A HeartbeatTxn or EndTxn(commit=true) request found an aborted transaction
    39  	// record. Another txn must have written this record - that other txn probably
    40  	// ran into one of our intents and pushed our transaction record successfully.
    41  	// Either a high-priority transaction simply pushed us or we failed to
    42  	// heartbeat for a while and another txn (of any priority) considered us
    43  	// abandoned and pushed us.
    44  	ABORT_REASON_ABORTED_RECORD_FOUND TransactionAbortedReason = 1
    45  	// The client is trying to use a transaction that's already been aborted. The
    46  	// TxnCoordSender detects this. Either the client is misusing a txn, or the
    47  	// TxnCoordSender found out about the transaction being aborted async through
    48  	// the heartbeat loop.
    49  	ABORT_REASON_CLIENT_REJECT TransactionAbortedReason = 3
    50  	// The txn was trying to push another and found out that it itself got aborted
    51  	// somehow while waiting for the push.
    52  	ABORT_REASON_PUSHER_ABORTED TransactionAbortedReason = 4
    53  	// The txn ran into the "abort span" - it was trying to read from a range
    54  	// where it had previously laid down intents that have been cleaned up in the
    55  	// meantime because the transaction was aborted.
    56  	ABORT_REASON_ABORT_SPAN TransactionAbortedReason = 5
    57  	// A request attempting to create a transaction record encountered a write
    58  	// timestamp cache entry for the txn key, and the entry identifies this
    59  	// transaction. This means that the transaction definitely committed or rolled
    60  	// back before. So, this request is either a delayed replay of some sort, or
    61  	// it raced with an async abort and lost. If a client gets this
    62  	// TransactionAbortedError (without it being wrapped in an ambiguous error),
    63  	// it must be the latter case, and the transaction can be retried.
    64  	ABORT_REASON_ALREADY_COMMITTED_OR_ROLLED_BACK_POSSIBLE_REPLAY TransactionAbortedReason = 6
    65  	// A request attempting to create a transaction record is not allowed to
    66  	// proceed by the timestamp cache because it cannot be verified that the
    67  	// respective transaction record did not previously exist. As opposed to the
    68  	// case above, the timestamp cache does not have a txn id in it, but the lease
    69  	// under which the request is evaluated is newer than the transaction's
    70  	// minimum timestamp (see CanCreateTxnRecord()). A new lease wipes the
    71  	// timestamp cache, so transaction record creation is bound to fail for
    72  	// transactions that spanned a lease acquisition.
    73  	// As above, if the error has not been converted by the time it reaches a
    74  	// client, then it's not a replay.
    75  	ABORT_REASON_NEW_LEASE_PREVENTS_TXN TransactionAbortedReason = 8
    76  	// Like the above, the timestamp cache rejects the creation of a transaction
    77  	// record. But there's no txn id in the ts cache, and also the lease is not
    78  	// new. The timestamp cache has lost accuracy because of a range merge or
    79  	// because of its memory limit.
    80  	// As above, if the error has not been converted by the time it reaches a
    81  	// client, then it's not a replay.
    82  	//
    83  	// TODO(andrei): We should be able to identify the range merge case by saving
    84  	// a bit more info in the timestamp cache.
    85  	ABORT_REASON_TIMESTAMP_CACHE_REJECTED TransactionAbortedReason = 7
    86  )
    87  
    88  var TransactionAbortedReason_name = map[int32]string{
    89  	0: "ABORT_REASON_UNKNOWN",
    90  	1: "ABORT_REASON_ABORTED_RECORD_FOUND",
    91  	3: "ABORT_REASON_CLIENT_REJECT",
    92  	4: "ABORT_REASON_PUSHER_ABORTED",
    93  	5: "ABORT_REASON_ABORT_SPAN",
    94  	6: "ABORT_REASON_ALREADY_COMMITTED_OR_ROLLED_BACK_POSSIBLE_REPLAY",
    95  	8: "ABORT_REASON_NEW_LEASE_PREVENTS_TXN",
    96  	7: "ABORT_REASON_TIMESTAMP_CACHE_REJECTED",
    97  }
    98  var TransactionAbortedReason_value = map[string]int32{
    99  	"ABORT_REASON_UNKNOWN":                                          0,
   100  	"ABORT_REASON_ABORTED_RECORD_FOUND":                             1,
   101  	"ABORT_REASON_CLIENT_REJECT":                                    3,
   102  	"ABORT_REASON_PUSHER_ABORTED":                                   4,
   103  	"ABORT_REASON_ABORT_SPAN":                                       5,
   104  	"ABORT_REASON_ALREADY_COMMITTED_OR_ROLLED_BACK_POSSIBLE_REPLAY": 6,
   105  	"ABORT_REASON_NEW_LEASE_PREVENTS_TXN":                           8,
   106  	"ABORT_REASON_TIMESTAMP_CACHE_REJECTED":                         7,
   107  }
   108  
   109  func (x TransactionAbortedReason) Enum() *TransactionAbortedReason {
   110  	p := new(TransactionAbortedReason)
   111  	*p = x
   112  	return p
   113  }
   114  func (x TransactionAbortedReason) String() string {
   115  	return proto.EnumName(TransactionAbortedReason_name, int32(x))
   116  }
   117  func (x *TransactionAbortedReason) UnmarshalJSON(data []byte) error {
   118  	value, err := proto.UnmarshalJSONEnum(TransactionAbortedReason_value, data, "TransactionAbortedReason")
   119  	if err != nil {
   120  		return err
   121  	}
   122  	*x = TransactionAbortedReason(value)
   123  	return nil
   124  }
   125  func (TransactionAbortedReason) EnumDescriptor() ([]byte, []int) {
   126  	return fileDescriptor_errors_4401e49350ed5ee8, []int{0}
   127  }
   128  
   129  // TransactionRetryReason specifies what caused a transaction retry.
   130  type TransactionRetryReason int32
   131  
   132  const (
   133  	// For backwards compatibility.
   134  	RETRY_REASON_UNKNOWN TransactionRetryReason = 0
   135  	// A concurrent writer finished first, causing restart.
   136  	RETRY_WRITE_TOO_OLD TransactionRetryReason = 1
   137  	// A SERIALIZABLE transaction had its timestamp moved forward.
   138  	RETRY_SERIALIZABLE TransactionRetryReason = 3
   139  	// An asynchronous write was observed to have failed.
   140  	RETRY_ASYNC_WRITE_FAILURE TransactionRetryReason = 5
   141  	// The transaction exceeded its deadline.
   142  	RETRY_COMMIT_DEADLINE_EXCEEDED TransactionRetryReason = 6
   143  )
   144  
   145  var TransactionRetryReason_name = map[int32]string{
   146  	0: "RETRY_REASON_UNKNOWN",
   147  	1: "RETRY_WRITE_TOO_OLD",
   148  	3: "RETRY_SERIALIZABLE",
   149  	5: "RETRY_ASYNC_WRITE_FAILURE",
   150  	6: "RETRY_COMMIT_DEADLINE_EXCEEDED",
   151  }
   152  var TransactionRetryReason_value = map[string]int32{
   153  	"RETRY_REASON_UNKNOWN":           0,
   154  	"RETRY_WRITE_TOO_OLD":            1,
   155  	"RETRY_SERIALIZABLE":             3,
   156  	"RETRY_ASYNC_WRITE_FAILURE":      5,
   157  	"RETRY_COMMIT_DEADLINE_EXCEEDED": 6,
   158  }
   159  
   160  func (x TransactionRetryReason) Enum() *TransactionRetryReason {
   161  	p := new(TransactionRetryReason)
   162  	*p = x
   163  	return p
   164  }
   165  func (x TransactionRetryReason) String() string {
   166  	return proto.EnumName(TransactionRetryReason_name, int32(x))
   167  }
   168  func (x *TransactionRetryReason) UnmarshalJSON(data []byte) error {
   169  	value, err := proto.UnmarshalJSONEnum(TransactionRetryReason_value, data, "TransactionRetryReason")
   170  	if err != nil {
   171  		return err
   172  	}
   173  	*x = TransactionRetryReason(value)
   174  	return nil
   175  }
   176  func (TransactionRetryReason) EnumDescriptor() ([]byte, []int) {
   177  	return fileDescriptor_errors_4401e49350ed5ee8, []int{1}
   178  }
   179  
   180  // TransactionRestart indicates how an error should be handled in a
   181  // transactional context.
   182  type TransactionRestart int32
   183  
   184  const (
   185  	// NONE (the default) is used for errors which have no effect on the
   186  	// transaction state. That is, a transactional operation which receives such
   187  	// an error is still PENDING and does not need to restart (at least not as a
   188  	// result of the error). Examples are a CPut whose condition wasn't met, or
   189  	// a spurious RPC error.
   190  	TransactionRestart_NONE TransactionRestart = 0
   191  	// BACKOFF is for errors that can retried by restarting the transaction
   192  	// after an exponential backoff.
   193  	// Note: Deprecated.
   194  	TransactionRestart_BACKOFF TransactionRestart = 1
   195  	// IMMEDIATE is for errors that can be retried by restarting the
   196  	// transaction immediately.
   197  	TransactionRestart_IMMEDIATE TransactionRestart = 2
   198  )
   199  
   200  var TransactionRestart_name = map[int32]string{
   201  	0: "NONE",
   202  	1: "BACKOFF",
   203  	2: "IMMEDIATE",
   204  }
   205  var TransactionRestart_value = map[string]int32{
   206  	"NONE":      0,
   207  	"BACKOFF":   1,
   208  	"IMMEDIATE": 2,
   209  }
   210  
   211  func (x TransactionRestart) Enum() *TransactionRestart {
   212  	p := new(TransactionRestart)
   213  	*p = x
   214  	return p
   215  }
   216  func (x TransactionRestart) String() string {
   217  	return proto.EnumName(TransactionRestart_name, int32(x))
   218  }
   219  func (x *TransactionRestart) UnmarshalJSON(data []byte) error {
   220  	value, err := proto.UnmarshalJSONEnum(TransactionRestart_value, data, "TransactionRestart")
   221  	if err != nil {
   222  		return err
   223  	}
   224  	*x = TransactionRestart(value)
   225  	return nil
   226  }
   227  func (TransactionRestart) EnumDescriptor() ([]byte, []int) {
   228  	return fileDescriptor_errors_4401e49350ed5ee8, []int{2}
   229  }
   230  
   231  // Reason specifies what caused the error.
   232  type TransactionStatusError_Reason int32
   233  
   234  const (
   235  	// For backwards compatibility.
   236  	TransactionStatusError_REASON_UNKNOWN TransactionStatusError_Reason = 0
   237  	// A committed transaction record was found.
   238  	TransactionStatusError_REASON_TXN_COMMITTED TransactionStatusError_Reason = 2
   239  )
   240  
   241  var TransactionStatusError_Reason_name = map[int32]string{
   242  	0: "REASON_UNKNOWN",
   243  	2: "REASON_TXN_COMMITTED",
   244  }
   245  var TransactionStatusError_Reason_value = map[string]int32{
   246  	"REASON_UNKNOWN":       0,
   247  	"REASON_TXN_COMMITTED": 2,
   248  }
   249  
   250  func (x TransactionStatusError_Reason) Enum() *TransactionStatusError_Reason {
   251  	p := new(TransactionStatusError_Reason)
   252  	*p = x
   253  	return p
   254  }
   255  func (x TransactionStatusError_Reason) String() string {
   256  	return proto.EnumName(TransactionStatusError_Reason_name, int32(x))
   257  }
   258  func (x *TransactionStatusError_Reason) UnmarshalJSON(data []byte) error {
   259  	value, err := proto.UnmarshalJSONEnum(TransactionStatusError_Reason_value, data, "TransactionStatusError_Reason")
   260  	if err != nil {
   261  		return err
   262  	}
   263  	*x = TransactionStatusError_Reason(value)
   264  	return nil
   265  }
   266  func (TransactionStatusError_Reason) EnumDescriptor() ([]byte, []int) {
   267  	return fileDescriptor_errors_4401e49350ed5ee8, []int{9, 0}
   268  }
   269  
   270  // Reason specifies what caused the error.
   271  type RangeFeedRetryError_Reason int32
   272  
   273  const (
   274  	// The replica was removed from its store.
   275  	RangeFeedRetryError_REASON_REPLICA_REMOVED RangeFeedRetryError_Reason = 0
   276  	// The range was split in two.
   277  	RangeFeedRetryError_REASON_RANGE_SPLIT RangeFeedRetryError_Reason = 1
   278  	// The range was merged into another.
   279  	RangeFeedRetryError_REASON_RANGE_MERGED RangeFeedRetryError_Reason = 2
   280  	// A Raft snapshot applied on the replica.
   281  	RangeFeedRetryError_REASON_RAFT_SNAPSHOT RangeFeedRetryError_Reason = 3
   282  	// A Raft command was missing a logical operation log.
   283  	RangeFeedRetryError_REASON_LOGICAL_OPS_MISSING RangeFeedRetryError_Reason = 4
   284  	// The consumer was processing events too slowly to keep up with live raft
   285  	// events.
   286  	RangeFeedRetryError_REASON_SLOW_CONSUMER RangeFeedRetryError_Reason = 5
   287  )
   288  
   289  var RangeFeedRetryError_Reason_name = map[int32]string{
   290  	0: "REASON_REPLICA_REMOVED",
   291  	1: "REASON_RANGE_SPLIT",
   292  	2: "REASON_RANGE_MERGED",
   293  	3: "REASON_RAFT_SNAPSHOT",
   294  	4: "REASON_LOGICAL_OPS_MISSING",
   295  	5: "REASON_SLOW_CONSUMER",
   296  }
   297  var RangeFeedRetryError_Reason_value = map[string]int32{
   298  	"REASON_REPLICA_REMOVED":     0,
   299  	"REASON_RANGE_SPLIT":         1,
   300  	"REASON_RANGE_MERGED":        2,
   301  	"REASON_RAFT_SNAPSHOT":       3,
   302  	"REASON_LOGICAL_OPS_MISSING": 4,
   303  	"REASON_SLOW_CONSUMER":       5,
   304  }
   305  
   306  func (x RangeFeedRetryError_Reason) Enum() *RangeFeedRetryError_Reason {
   307  	p := new(RangeFeedRetryError_Reason)
   308  	*p = x
   309  	return p
   310  }
   311  func (x RangeFeedRetryError_Reason) String() string {
   312  	return proto.EnumName(RangeFeedRetryError_Reason_name, int32(x))
   313  }
   314  func (x *RangeFeedRetryError_Reason) UnmarshalJSON(data []byte) error {
   315  	value, err := proto.UnmarshalJSONEnum(RangeFeedRetryError_Reason_value, data, "RangeFeedRetryError_Reason")
   316  	if err != nil {
   317  		return err
   318  	}
   319  	*x = RangeFeedRetryError_Reason(value)
   320  	return nil
   321  }
   322  func (RangeFeedRetryError_Reason) EnumDescriptor() ([]byte, []int) {
   323  	return fileDescriptor_errors_4401e49350ed5ee8, []int{28, 0}
   324  }
   325  
   326  // A NotLeaseHolderError indicates that the current range is not the lease
   327  // holder. If the lease holder is known, its Replica is set in the error.
   328  type NotLeaseHolderError struct {
   329  	// The replica the error originated from. Used in the error's string
   330  	// representation, if known.
   331  	Replica ReplicaDescriptor `protobuf:"bytes,1,opt,name=replica" json:"replica"`
   332  	// The lease holder, if known.
   333  	LeaseHolder *ReplicaDescriptor `protobuf:"bytes,2,opt,name=lease_holder,json=leaseHolder" json:"lease_holder,omitempty"`
   334  	// The current lease, if known. This might be nil even when lease_holder is
   335  	// set, as sometimes one can create this error without actually knowing the
   336  	// current lease, but having a guess about who the leader is.
   337  	Lease   *Lease  `protobuf:"bytes,4,opt,name=lease" json:"lease,omitempty"`
   338  	RangeID RangeID `protobuf:"varint,3,opt,name=range_id,json=rangeId,casttype=RangeID" json:"range_id"`
   339  	// If set, the Error() method will return this instead of composing its
   340  	// regular spiel. Useful because we reuse this error when rejecting a command
   341  	// because the lease under which its application was attempted is different
   342  	// than the lease under which it had been proposed.
   343  	CustomMsg string `protobuf:"bytes,5,opt,name=custom_msg,json=customMsg" json:"custom_msg"`
   344  }
   345  
   346  func (m *NotLeaseHolderError) Reset()         { *m = NotLeaseHolderError{} }
   347  func (m *NotLeaseHolderError) String() string { return proto.CompactTextString(m) }
   348  func (*NotLeaseHolderError) ProtoMessage()    {}
   349  func (*NotLeaseHolderError) Descriptor() ([]byte, []int) {
   350  	return fileDescriptor_errors_4401e49350ed5ee8, []int{0}
   351  }
   352  func (m *NotLeaseHolderError) XXX_Unmarshal(b []byte) error {
   353  	return m.Unmarshal(b)
   354  }
   355  func (m *NotLeaseHolderError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   356  	b = b[:cap(b)]
   357  	n, err := m.MarshalTo(b)
   358  	if err != nil {
   359  		return nil, err
   360  	}
   361  	return b[:n], nil
   362  }
   363  func (dst *NotLeaseHolderError) XXX_Merge(src proto.Message) {
   364  	xxx_messageInfo_NotLeaseHolderError.Merge(dst, src)
   365  }
   366  func (m *NotLeaseHolderError) XXX_Size() int {
   367  	return m.Size()
   368  }
   369  func (m *NotLeaseHolderError) XXX_DiscardUnknown() {
   370  	xxx_messageInfo_NotLeaseHolderError.DiscardUnknown(m)
   371  }
   372  
   373  var xxx_messageInfo_NotLeaseHolderError proto.InternalMessageInfo
   374  
   375  // A NodeUnavailableError indicates that the sending gateway can
   376  // not process requests at the time, and that the client should
   377  // retry the request with another peer.
   378  type NodeUnavailableError struct {
   379  }
   380  
   381  func (m *NodeUnavailableError) Reset()         { *m = NodeUnavailableError{} }
   382  func (m *NodeUnavailableError) String() string { return proto.CompactTextString(m) }
   383  func (*NodeUnavailableError) ProtoMessage()    {}
   384  func (*NodeUnavailableError) Descriptor() ([]byte, []int) {
   385  	return fileDescriptor_errors_4401e49350ed5ee8, []int{1}
   386  }
   387  func (m *NodeUnavailableError) XXX_Unmarshal(b []byte) error {
   388  	return m.Unmarshal(b)
   389  }
   390  func (m *NodeUnavailableError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   391  	b = b[:cap(b)]
   392  	n, err := m.MarshalTo(b)
   393  	if err != nil {
   394  		return nil, err
   395  	}
   396  	return b[:n], nil
   397  }
   398  func (dst *NodeUnavailableError) XXX_Merge(src proto.Message) {
   399  	xxx_messageInfo_NodeUnavailableError.Merge(dst, src)
   400  }
   401  func (m *NodeUnavailableError) XXX_Size() int {
   402  	return m.Size()
   403  }
   404  func (m *NodeUnavailableError) XXX_DiscardUnknown() {
   405  	xxx_messageInfo_NodeUnavailableError.DiscardUnknown(m)
   406  }
   407  
   408  var xxx_messageInfo_NodeUnavailableError proto.InternalMessageInfo
   409  
   410  // An UnsupportedRequestError indicates that the recipient node
   411  // does not know how to handle the type of request received.
   412  type UnsupportedRequestError struct {
   413  }
   414  
   415  func (m *UnsupportedRequestError) Reset()         { *m = UnsupportedRequestError{} }
   416  func (m *UnsupportedRequestError) String() string { return proto.CompactTextString(m) }
   417  func (*UnsupportedRequestError) ProtoMessage()    {}
   418  func (*UnsupportedRequestError) Descriptor() ([]byte, []int) {
   419  	return fileDescriptor_errors_4401e49350ed5ee8, []int{2}
   420  }
   421  func (m *UnsupportedRequestError) XXX_Unmarshal(b []byte) error {
   422  	return m.Unmarshal(b)
   423  }
   424  func (m *UnsupportedRequestError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   425  	b = b[:cap(b)]
   426  	n, err := m.MarshalTo(b)
   427  	if err != nil {
   428  		return nil, err
   429  	}
   430  	return b[:n], nil
   431  }
   432  func (dst *UnsupportedRequestError) XXX_Merge(src proto.Message) {
   433  	xxx_messageInfo_UnsupportedRequestError.Merge(dst, src)
   434  }
   435  func (m *UnsupportedRequestError) XXX_Size() int {
   436  	return m.Size()
   437  }
   438  func (m *UnsupportedRequestError) XXX_DiscardUnknown() {
   439  	xxx_messageInfo_UnsupportedRequestError.DiscardUnknown(m)
   440  }
   441  
   442  var xxx_messageInfo_UnsupportedRequestError proto.InternalMessageInfo
   443  
   444  // A RangeNotFoundError indicates that a command was sent to a range
   445  // which is not hosted on this store.
   446  type RangeNotFoundError struct {
   447  	RangeID RangeID `protobuf:"varint,1,opt,name=range_id,json=rangeId,casttype=RangeID" json:"range_id"`
   448  	// store_id is nonzero only if the error originated on a Store.
   449  	StoreID StoreID `protobuf:"varint,2,opt,name=store_id,json=storeId,casttype=StoreID" json:"store_id"`
   450  }
   451  
   452  func (m *RangeNotFoundError) Reset()         { *m = RangeNotFoundError{} }
   453  func (m *RangeNotFoundError) String() string { return proto.CompactTextString(m) }
   454  func (*RangeNotFoundError) ProtoMessage()    {}
   455  func (*RangeNotFoundError) Descriptor() ([]byte, []int) {
   456  	return fileDescriptor_errors_4401e49350ed5ee8, []int{3}
   457  }
   458  func (m *RangeNotFoundError) XXX_Unmarshal(b []byte) error {
   459  	return m.Unmarshal(b)
   460  }
   461  func (m *RangeNotFoundError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   462  	b = b[:cap(b)]
   463  	n, err := m.MarshalTo(b)
   464  	if err != nil {
   465  		return nil, err
   466  	}
   467  	return b[:n], nil
   468  }
   469  func (dst *RangeNotFoundError) XXX_Merge(src proto.Message) {
   470  	xxx_messageInfo_RangeNotFoundError.Merge(dst, src)
   471  }
   472  func (m *RangeNotFoundError) XXX_Size() int {
   473  	return m.Size()
   474  }
   475  func (m *RangeNotFoundError) XXX_DiscardUnknown() {
   476  	xxx_messageInfo_RangeNotFoundError.DiscardUnknown(m)
   477  }
   478  
   479  var xxx_messageInfo_RangeNotFoundError proto.InternalMessageInfo
   480  
   481  // A RangeKeyMismatchError indicates that a command was sent to a
   482  // range which did not contain the key(s) specified by the command.
   483  type RangeKeyMismatchError struct {
   484  	RequestStartKey Key `protobuf:"bytes,1,opt,name=request_start_key,json=requestStartKey,casttype=Key" json:"request_start_key,omitempty"`
   485  	RequestEndKey   Key `protobuf:"bytes,2,opt,name=request_end_key,json=requestEndKey,casttype=Key" json:"request_end_key,omitempty"`
   486  	// mismatched_range is the range that the command was incorrectly sent to.
   487  	// It is used to update the sender's range cache without an additional range
   488  	// lookup.
   489  	MismatchedRange RangeDescriptor `protobuf:"bytes,3,opt,name=mismatched_range,json=mismatchedRange" json:"mismatched_range"`
   490  	// suggested_range is a hint to the sender of a command about the range
   491  	// they may be looking for. It is only populated when the recipient has
   492  	// authoritative knowledge of the range requested by the sender.
   493  	SuggestedRange *RangeDescriptor `protobuf:"bytes,4,opt,name=suggested_range,json=suggestedRange" json:"suggested_range,omitempty"`
   494  }
   495  
   496  func (m *RangeKeyMismatchError) Reset()         { *m = RangeKeyMismatchError{} }
   497  func (m *RangeKeyMismatchError) String() string { return proto.CompactTextString(m) }
   498  func (*RangeKeyMismatchError) ProtoMessage()    {}
   499  func (*RangeKeyMismatchError) Descriptor() ([]byte, []int) {
   500  	return fileDescriptor_errors_4401e49350ed5ee8, []int{4}
   501  }
   502  func (m *RangeKeyMismatchError) XXX_Unmarshal(b []byte) error {
   503  	return m.Unmarshal(b)
   504  }
   505  func (m *RangeKeyMismatchError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   506  	b = b[:cap(b)]
   507  	n, err := m.MarshalTo(b)
   508  	if err != nil {
   509  		return nil, err
   510  	}
   511  	return b[:n], nil
   512  }
   513  func (dst *RangeKeyMismatchError) XXX_Merge(src proto.Message) {
   514  	xxx_messageInfo_RangeKeyMismatchError.Merge(dst, src)
   515  }
   516  func (m *RangeKeyMismatchError) XXX_Size() int {
   517  	return m.Size()
   518  }
   519  func (m *RangeKeyMismatchError) XXX_DiscardUnknown() {
   520  	xxx_messageInfo_RangeKeyMismatchError.DiscardUnknown(m)
   521  }
   522  
   523  var xxx_messageInfo_RangeKeyMismatchError proto.InternalMessageInfo
   524  
   525  // A ReadWithinUncertaintyIntervalError indicates that a read at timestamp
   526  // encountered a write within the uncertainty interval of the reader.
   527  // The read should be retried at a higher timestamp; the timestamps contained
   528  // within are purely informational, though typically existing_timestamp is a
   529  // lower bound for a new timestamp at which at least the read producing
   530  // this error would succeed on retry.
   531  type ReadWithinUncertaintyIntervalError struct {
   532  	// This data below is purely informational and used to tailor the
   533  	// error message.
   534  	ReadTimestamp     hlc.Timestamp `protobuf:"bytes,1,opt,name=read_timestamp,json=readTimestamp" json:"read_timestamp"`
   535  	ExistingTimestamp hlc.Timestamp `protobuf:"bytes,2,opt,name=existing_timestamp,json=existingTimestamp" json:"existing_timestamp"`
   536  	// The remaining fields may be missing when running in clusters that have
   537  	// members at below CockroachDB v2.0.
   538  	MaxTimestamp       *hlc.Timestamp      `protobuf:"bytes,3,opt,name=max_timestamp,json=maxTimestamp" json:"max_timestamp,omitempty"`
   539  	ObservedTimestamps []ObservedTimestamp `protobuf:"bytes,4,rep,name=observed_timestamps,json=observedTimestamps" json:"observed_timestamps"`
   540  }
   541  
   542  func (m *ReadWithinUncertaintyIntervalError) Reset()         { *m = ReadWithinUncertaintyIntervalError{} }
   543  func (m *ReadWithinUncertaintyIntervalError) String() string { return proto.CompactTextString(m) }
   544  func (*ReadWithinUncertaintyIntervalError) ProtoMessage()    {}
   545  func (*ReadWithinUncertaintyIntervalError) Descriptor() ([]byte, []int) {
   546  	return fileDescriptor_errors_4401e49350ed5ee8, []int{5}
   547  }
   548  func (m *ReadWithinUncertaintyIntervalError) XXX_Unmarshal(b []byte) error {
   549  	return m.Unmarshal(b)
   550  }
   551  func (m *ReadWithinUncertaintyIntervalError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   552  	b = b[:cap(b)]
   553  	n, err := m.MarshalTo(b)
   554  	if err != nil {
   555  		return nil, err
   556  	}
   557  	return b[:n], nil
   558  }
   559  func (dst *ReadWithinUncertaintyIntervalError) XXX_Merge(src proto.Message) {
   560  	xxx_messageInfo_ReadWithinUncertaintyIntervalError.Merge(dst, src)
   561  }
   562  func (m *ReadWithinUncertaintyIntervalError) XXX_Size() int {
   563  	return m.Size()
   564  }
   565  func (m *ReadWithinUncertaintyIntervalError) XXX_DiscardUnknown() {
   566  	xxx_messageInfo_ReadWithinUncertaintyIntervalError.DiscardUnknown(m)
   567  }
   568  
   569  var xxx_messageInfo_ReadWithinUncertaintyIntervalError proto.InternalMessageInfo
   570  
   571  // A TransactionAbortedError indicates that the client should retry the
   572  // transaction (and use a different txn id, as opposed to
   573  // TransactionRetryError). This most often happens when the transaction was
   574  // aborted by another concurrent transaction. Upon seeing this error, the client
   575  // is supposed to reset its Transaction proto and try the transaction again.
   576  //
   577  // In contrast with other errors, the Transaction that the client gets in the
   578  // pErr carrying this ErrorDetail is not supposed to be used as is by the
   579  // client; the ID should be checked and then attributes like the timestamp
   580  // should be used in creating a new txn.
   581  type TransactionAbortedError struct {
   582  	Reason TransactionAbortedReason `protobuf:"varint,1,opt,name=reason,enum=cockroach.roachpb.TransactionAbortedReason" json:"reason"`
   583  }
   584  
   585  func (m *TransactionAbortedError) Reset()         { *m = TransactionAbortedError{} }
   586  func (m *TransactionAbortedError) String() string { return proto.CompactTextString(m) }
   587  func (*TransactionAbortedError) ProtoMessage()    {}
   588  func (*TransactionAbortedError) Descriptor() ([]byte, []int) {
   589  	return fileDescriptor_errors_4401e49350ed5ee8, []int{6}
   590  }
   591  func (m *TransactionAbortedError) XXX_Unmarshal(b []byte) error {
   592  	return m.Unmarshal(b)
   593  }
   594  func (m *TransactionAbortedError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   595  	b = b[:cap(b)]
   596  	n, err := m.MarshalTo(b)
   597  	if err != nil {
   598  		return nil, err
   599  	}
   600  	return b[:n], nil
   601  }
   602  func (dst *TransactionAbortedError) XXX_Merge(src proto.Message) {
   603  	xxx_messageInfo_TransactionAbortedError.Merge(dst, src)
   604  }
   605  func (m *TransactionAbortedError) XXX_Size() int {
   606  	return m.Size()
   607  }
   608  func (m *TransactionAbortedError) XXX_DiscardUnknown() {
   609  	xxx_messageInfo_TransactionAbortedError.DiscardUnknown(m)
   610  }
   611  
   612  var xxx_messageInfo_TransactionAbortedError proto.InternalMessageInfo
   613  
   614  // A TransactionPushError indicates that the transaction could not
   615  // continue because it encountered a write intent from another
   616  // transaction which it was unable to push.
   617  type TransactionPushError struct {
   618  	PusheeTxn Transaction `protobuf:"bytes,1,opt,name=pushee_txn,json=pusheeTxn" json:"pushee_txn"`
   619  }
   620  
   621  func (m *TransactionPushError) Reset()         { *m = TransactionPushError{} }
   622  func (m *TransactionPushError) String() string { return proto.CompactTextString(m) }
   623  func (*TransactionPushError) ProtoMessage()    {}
   624  func (*TransactionPushError) Descriptor() ([]byte, []int) {
   625  	return fileDescriptor_errors_4401e49350ed5ee8, []int{7}
   626  }
   627  func (m *TransactionPushError) XXX_Unmarshal(b []byte) error {
   628  	return m.Unmarshal(b)
   629  }
   630  func (m *TransactionPushError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   631  	b = b[:cap(b)]
   632  	n, err := m.MarshalTo(b)
   633  	if err != nil {
   634  		return nil, err
   635  	}
   636  	return b[:n], nil
   637  }
   638  func (dst *TransactionPushError) XXX_Merge(src proto.Message) {
   639  	xxx_messageInfo_TransactionPushError.Merge(dst, src)
   640  }
   641  func (m *TransactionPushError) XXX_Size() int {
   642  	return m.Size()
   643  }
   644  func (m *TransactionPushError) XXX_DiscardUnknown() {
   645  	xxx_messageInfo_TransactionPushError.DiscardUnknown(m)
   646  }
   647  
   648  var xxx_messageInfo_TransactionPushError proto.InternalMessageInfo
   649  
   650  // A TransactionRetryError indicates that the transaction must be
   651  // retried, usually with an increased transaction timestamp.
   652  type TransactionRetryError struct {
   653  	Reason   TransactionRetryReason `protobuf:"varint,1,opt,name=reason,enum=cockroach.roachpb.TransactionRetryReason" json:"reason"`
   654  	ExtraMsg string                 `protobuf:"bytes,2,opt,name=extra_msg,json=extraMsg" json:"extra_msg"`
   655  }
   656  
   657  func (m *TransactionRetryError) Reset()         { *m = TransactionRetryError{} }
   658  func (m *TransactionRetryError) String() string { return proto.CompactTextString(m) }
   659  func (*TransactionRetryError) ProtoMessage()    {}
   660  func (*TransactionRetryError) Descriptor() ([]byte, []int) {
   661  	return fileDescriptor_errors_4401e49350ed5ee8, []int{8}
   662  }
   663  func (m *TransactionRetryError) XXX_Unmarshal(b []byte) error {
   664  	return m.Unmarshal(b)
   665  }
   666  func (m *TransactionRetryError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   667  	b = b[:cap(b)]
   668  	n, err := m.MarshalTo(b)
   669  	if err != nil {
   670  		return nil, err
   671  	}
   672  	return b[:n], nil
   673  }
   674  func (dst *TransactionRetryError) XXX_Merge(src proto.Message) {
   675  	xxx_messageInfo_TransactionRetryError.Merge(dst, src)
   676  }
   677  func (m *TransactionRetryError) XXX_Size() int {
   678  	return m.Size()
   679  }
   680  func (m *TransactionRetryError) XXX_DiscardUnknown() {
   681  	xxx_messageInfo_TransactionRetryError.DiscardUnknown(m)
   682  }
   683  
   684  var xxx_messageInfo_TransactionRetryError proto.InternalMessageInfo
   685  
   686  // A TransactionStatusError indicates that the transaction status is
   687  // incompatible with the requested operation. This might mean the
   688  // transaction has already been committed. It might also be the case
   689  // that the request to modify the transaction failed due to a
   690  // regression in transaction epoch or timestamp, both of which may
   691  // only monotonically increase.
   692  type TransactionStatusError struct {
   693  	Msg    string                        `protobuf:"bytes,1,opt,name=msg" json:"msg"`
   694  	Reason TransactionStatusError_Reason `protobuf:"varint,2,opt,name=reason,enum=cockroach.roachpb.TransactionStatusError_Reason" json:"reason"`
   695  }
   696  
   697  func (m *TransactionStatusError) Reset()         { *m = TransactionStatusError{} }
   698  func (m *TransactionStatusError) String() string { return proto.CompactTextString(m) }
   699  func (*TransactionStatusError) ProtoMessage()    {}
   700  func (*TransactionStatusError) Descriptor() ([]byte, []int) {
   701  	return fileDescriptor_errors_4401e49350ed5ee8, []int{9}
   702  }
   703  func (m *TransactionStatusError) XXX_Unmarshal(b []byte) error {
   704  	return m.Unmarshal(b)
   705  }
   706  func (m *TransactionStatusError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   707  	b = b[:cap(b)]
   708  	n, err := m.MarshalTo(b)
   709  	if err != nil {
   710  		return nil, err
   711  	}
   712  	return b[:n], nil
   713  }
   714  func (dst *TransactionStatusError) XXX_Merge(src proto.Message) {
   715  	xxx_messageInfo_TransactionStatusError.Merge(dst, src)
   716  }
   717  func (m *TransactionStatusError) XXX_Size() int {
   718  	return m.Size()
   719  }
   720  func (m *TransactionStatusError) XXX_DiscardUnknown() {
   721  	xxx_messageInfo_TransactionStatusError.DiscardUnknown(m)
   722  }
   723  
   724  var xxx_messageInfo_TransactionStatusError proto.InternalMessageInfo
   725  
   726  // A WriteIntentError indicates that one or more write intent
   727  // belonging to another transaction were encountered leading to a
   728  // read/write or write/write conflict. The keys at which the intent
   729  // was encountered are set, as are the txn records for the intents'
   730  // transactions.
   731  type WriteIntentError struct {
   732  	Intents []Intent `protobuf:"bytes,1,rep,name=intents" json:"intents"`
   733  }
   734  
   735  func (m *WriteIntentError) Reset()         { *m = WriteIntentError{} }
   736  func (m *WriteIntentError) String() string { return proto.CompactTextString(m) }
   737  func (*WriteIntentError) ProtoMessage()    {}
   738  func (*WriteIntentError) Descriptor() ([]byte, []int) {
   739  	return fileDescriptor_errors_4401e49350ed5ee8, []int{10}
   740  }
   741  func (m *WriteIntentError) XXX_Unmarshal(b []byte) error {
   742  	return m.Unmarshal(b)
   743  }
   744  func (m *WriteIntentError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   745  	b = b[:cap(b)]
   746  	n, err := m.MarshalTo(b)
   747  	if err != nil {
   748  		return nil, err
   749  	}
   750  	return b[:n], nil
   751  }
   752  func (dst *WriteIntentError) XXX_Merge(src proto.Message) {
   753  	xxx_messageInfo_WriteIntentError.Merge(dst, src)
   754  }
   755  func (m *WriteIntentError) XXX_Size() int {
   756  	return m.Size()
   757  }
   758  func (m *WriteIntentError) XXX_DiscardUnknown() {
   759  	xxx_messageInfo_WriteIntentError.DiscardUnknown(m)
   760  }
   761  
   762  var xxx_messageInfo_WriteIntentError proto.InternalMessageInfo
   763  
   764  // A WriteTooOldError indicates that a write encountered a versioned
   765  // value newer than its timestamp, making it impossible to rewrite
   766  // history. The write is instead done at actual timestamp, which is
   767  // the timestamp of the existing version+1.
   768  type WriteTooOldError struct {
   769  	Timestamp       hlc.Timestamp `protobuf:"bytes,1,opt,name=timestamp" json:"timestamp"`
   770  	ActualTimestamp hlc.Timestamp `protobuf:"bytes,2,opt,name=actual_timestamp,json=actualTimestamp" json:"actual_timestamp"`
   771  }
   772  
   773  func (m *WriteTooOldError) Reset()         { *m = WriteTooOldError{} }
   774  func (m *WriteTooOldError) String() string { return proto.CompactTextString(m) }
   775  func (*WriteTooOldError) ProtoMessage()    {}
   776  func (*WriteTooOldError) Descriptor() ([]byte, []int) {
   777  	return fileDescriptor_errors_4401e49350ed5ee8, []int{11}
   778  }
   779  func (m *WriteTooOldError) XXX_Unmarshal(b []byte) error {
   780  	return m.Unmarshal(b)
   781  }
   782  func (m *WriteTooOldError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   783  	b = b[:cap(b)]
   784  	n, err := m.MarshalTo(b)
   785  	if err != nil {
   786  		return nil, err
   787  	}
   788  	return b[:n], nil
   789  }
   790  func (dst *WriteTooOldError) XXX_Merge(src proto.Message) {
   791  	xxx_messageInfo_WriteTooOldError.Merge(dst, src)
   792  }
   793  func (m *WriteTooOldError) XXX_Size() int {
   794  	return m.Size()
   795  }
   796  func (m *WriteTooOldError) XXX_DiscardUnknown() {
   797  	xxx_messageInfo_WriteTooOldError.DiscardUnknown(m)
   798  }
   799  
   800  var xxx_messageInfo_WriteTooOldError proto.InternalMessageInfo
   801  
   802  // An OpRequiresTxnError indicates that a command required to be
   803  // carried out in a transactional context but was not.
   804  // For example, a Scan which spans ranges requires a transaction.
   805  // The operation should be retried inside of a transaction.
   806  type OpRequiresTxnError struct {
   807  }
   808  
   809  func (m *OpRequiresTxnError) Reset()         { *m = OpRequiresTxnError{} }
   810  func (m *OpRequiresTxnError) String() string { return proto.CompactTextString(m) }
   811  func (*OpRequiresTxnError) ProtoMessage()    {}
   812  func (*OpRequiresTxnError) Descriptor() ([]byte, []int) {
   813  	return fileDescriptor_errors_4401e49350ed5ee8, []int{12}
   814  }
   815  func (m *OpRequiresTxnError) XXX_Unmarshal(b []byte) error {
   816  	return m.Unmarshal(b)
   817  }
   818  func (m *OpRequiresTxnError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   819  	b = b[:cap(b)]
   820  	n, err := m.MarshalTo(b)
   821  	if err != nil {
   822  		return nil, err
   823  	}
   824  	return b[:n], nil
   825  }
   826  func (dst *OpRequiresTxnError) XXX_Merge(src proto.Message) {
   827  	xxx_messageInfo_OpRequiresTxnError.Merge(dst, src)
   828  }
   829  func (m *OpRequiresTxnError) XXX_Size() int {
   830  	return m.Size()
   831  }
   832  func (m *OpRequiresTxnError) XXX_DiscardUnknown() {
   833  	xxx_messageInfo_OpRequiresTxnError.DiscardUnknown(m)
   834  }
   835  
   836  var xxx_messageInfo_OpRequiresTxnError proto.InternalMessageInfo
   837  
   838  // A ConditionFailedError indicates that the expected value
   839  // of a ConditionalPutRequest was not found, either
   840  // because it was missing or was not equal. The error will
   841  // contain the actual value found.
   842  type ConditionFailedError struct {
   843  	ActualValue *Value `protobuf:"bytes,1,opt,name=actual_value,json=actualValue" json:"actual_value,omitempty"`
   844  }
   845  
   846  func (m *ConditionFailedError) Reset()         { *m = ConditionFailedError{} }
   847  func (m *ConditionFailedError) String() string { return proto.CompactTextString(m) }
   848  func (*ConditionFailedError) ProtoMessage()    {}
   849  func (*ConditionFailedError) Descriptor() ([]byte, []int) {
   850  	return fileDescriptor_errors_4401e49350ed5ee8, []int{13}
   851  }
   852  func (m *ConditionFailedError) XXX_Unmarshal(b []byte) error {
   853  	return m.Unmarshal(b)
   854  }
   855  func (m *ConditionFailedError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   856  	b = b[:cap(b)]
   857  	n, err := m.MarshalTo(b)
   858  	if err != nil {
   859  		return nil, err
   860  	}
   861  	return b[:n], nil
   862  }
   863  func (dst *ConditionFailedError) XXX_Merge(src proto.Message) {
   864  	xxx_messageInfo_ConditionFailedError.Merge(dst, src)
   865  }
   866  func (m *ConditionFailedError) XXX_Size() int {
   867  	return m.Size()
   868  }
   869  func (m *ConditionFailedError) XXX_DiscardUnknown() {
   870  	xxx_messageInfo_ConditionFailedError.DiscardUnknown(m)
   871  }
   872  
   873  var xxx_messageInfo_ConditionFailedError proto.InternalMessageInfo
   874  
   875  // A LeaseRejectedError indicates that the requested replica could
   876  // not acquire the desired lease because of an existing range lease.
   877  type LeaseRejectedError struct {
   878  	Message   string `protobuf:"bytes,1,opt,name=message" json:"message"`
   879  	Requested Lease  `protobuf:"bytes,2,opt,name=requested" json:"requested"`
   880  	Existing  Lease  `protobuf:"bytes,3,opt,name=existing" json:"existing"`
   881  }
   882  
   883  func (m *LeaseRejectedError) Reset()         { *m = LeaseRejectedError{} }
   884  func (m *LeaseRejectedError) String() string { return proto.CompactTextString(m) }
   885  func (*LeaseRejectedError) ProtoMessage()    {}
   886  func (*LeaseRejectedError) Descriptor() ([]byte, []int) {
   887  	return fileDescriptor_errors_4401e49350ed5ee8, []int{14}
   888  }
   889  func (m *LeaseRejectedError) XXX_Unmarshal(b []byte) error {
   890  	return m.Unmarshal(b)
   891  }
   892  func (m *LeaseRejectedError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   893  	b = b[:cap(b)]
   894  	n, err := m.MarshalTo(b)
   895  	if err != nil {
   896  		return nil, err
   897  	}
   898  	return b[:n], nil
   899  }
   900  func (dst *LeaseRejectedError) XXX_Merge(src proto.Message) {
   901  	xxx_messageInfo_LeaseRejectedError.Merge(dst, src)
   902  }
   903  func (m *LeaseRejectedError) XXX_Size() int {
   904  	return m.Size()
   905  }
   906  func (m *LeaseRejectedError) XXX_DiscardUnknown() {
   907  	xxx_messageInfo_LeaseRejectedError.DiscardUnknown(m)
   908  }
   909  
   910  var xxx_messageInfo_LeaseRejectedError proto.InternalMessageInfo
   911  
   912  // A SendError indicates that there was a problem communicating with a replica
   913  // that can evaluate the request. It's possible that the request was, in fact,
   914  // evaluated by a replica successfully but then the server connection dropped.
   915  //
   916  // This error is produced by the DistSender. Note that the DistSender generates
   917  // AmbiguousResultError instead of SendError when there's an EndTxn(commit) in
   918  // the BatchRequest. But also note that the sever can return
   919  // AmbiguousResultErrors too, in which case the DistSender will pipe it through.
   920  // TODO(andrei): clean up this stuff and tighten the meaning of the different
   921  // errors.
   922  type SendError struct {
   923  	Message string `protobuf:"bytes,1,opt,name=message" json:"message"`
   924  }
   925  
   926  func (m *SendError) Reset()         { *m = SendError{} }
   927  func (m *SendError) String() string { return proto.CompactTextString(m) }
   928  func (*SendError) ProtoMessage()    {}
   929  func (*SendError) Descriptor() ([]byte, []int) {
   930  	return fileDescriptor_errors_4401e49350ed5ee8, []int{15}
   931  }
   932  func (m *SendError) XXX_Unmarshal(b []byte) error {
   933  	return m.Unmarshal(b)
   934  }
   935  func (m *SendError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   936  	b = b[:cap(b)]
   937  	n, err := m.MarshalTo(b)
   938  	if err != nil {
   939  		return nil, err
   940  	}
   941  	return b[:n], nil
   942  }
   943  func (dst *SendError) XXX_Merge(src proto.Message) {
   944  	xxx_messageInfo_SendError.Merge(dst, src)
   945  }
   946  func (m *SendError) XXX_Size() int {
   947  	return m.Size()
   948  }
   949  func (m *SendError) XXX_DiscardUnknown() {
   950  	xxx_messageInfo_SendError.DiscardUnknown(m)
   951  }
   952  
   953  var xxx_messageInfo_SendError proto.InternalMessageInfo
   954  
   955  // An AmbiguousResultError indicates that a request may have succeeded or
   956  // failed, but the response was not received and the final result is ambiguous.
   957  //
   958  // Also see SendError.
   959  type AmbiguousResultError struct {
   960  	Message string `protobuf:"bytes,1,opt,name=message" json:"message"`
   961  	// This can be set to give extra information about which error was converted
   962  	// into an AmbiguousResultError. Useful for tests.
   963  	WrappedErr *Error `protobuf:"bytes,2,opt,name=wrapped_err,json=wrappedErr" json:"wrapped_err,omitempty"`
   964  }
   965  
   966  func (m *AmbiguousResultError) Reset()         { *m = AmbiguousResultError{} }
   967  func (m *AmbiguousResultError) String() string { return proto.CompactTextString(m) }
   968  func (*AmbiguousResultError) ProtoMessage()    {}
   969  func (*AmbiguousResultError) Descriptor() ([]byte, []int) {
   970  	return fileDescriptor_errors_4401e49350ed5ee8, []int{16}
   971  }
   972  func (m *AmbiguousResultError) XXX_Unmarshal(b []byte) error {
   973  	return m.Unmarshal(b)
   974  }
   975  func (m *AmbiguousResultError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   976  	b = b[:cap(b)]
   977  	n, err := m.MarshalTo(b)
   978  	if err != nil {
   979  		return nil, err
   980  	}
   981  	return b[:n], nil
   982  }
   983  func (dst *AmbiguousResultError) XXX_Merge(src proto.Message) {
   984  	xxx_messageInfo_AmbiguousResultError.Merge(dst, src)
   985  }
   986  func (m *AmbiguousResultError) XXX_Size() int {
   987  	return m.Size()
   988  }
   989  func (m *AmbiguousResultError) XXX_DiscardUnknown() {
   990  	xxx_messageInfo_AmbiguousResultError.DiscardUnknown(m)
   991  }
   992  
   993  var xxx_messageInfo_AmbiguousResultError proto.InternalMessageInfo
   994  
   995  // A RaftGroupDeletedError indicates a raft group has been deleted for
   996  // the replica.
   997  type RaftGroupDeletedError struct {
   998  }
   999  
  1000  func (m *RaftGroupDeletedError) Reset()         { *m = RaftGroupDeletedError{} }
  1001  func (m *RaftGroupDeletedError) String() string { return proto.CompactTextString(m) }
  1002  func (*RaftGroupDeletedError) ProtoMessage()    {}
  1003  func (*RaftGroupDeletedError) Descriptor() ([]byte, []int) {
  1004  	return fileDescriptor_errors_4401e49350ed5ee8, []int{17}
  1005  }
  1006  func (m *RaftGroupDeletedError) XXX_Unmarshal(b []byte) error {
  1007  	return m.Unmarshal(b)
  1008  }
  1009  func (m *RaftGroupDeletedError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1010  	b = b[:cap(b)]
  1011  	n, err := m.MarshalTo(b)
  1012  	if err != nil {
  1013  		return nil, err
  1014  	}
  1015  	return b[:n], nil
  1016  }
  1017  func (dst *RaftGroupDeletedError) XXX_Merge(src proto.Message) {
  1018  	xxx_messageInfo_RaftGroupDeletedError.Merge(dst, src)
  1019  }
  1020  func (m *RaftGroupDeletedError) XXX_Size() int {
  1021  	return m.Size()
  1022  }
  1023  func (m *RaftGroupDeletedError) XXX_DiscardUnknown() {
  1024  	xxx_messageInfo_RaftGroupDeletedError.DiscardUnknown(m)
  1025  }
  1026  
  1027  var xxx_messageInfo_RaftGroupDeletedError proto.InternalMessageInfo
  1028  
  1029  // A ReplicaCorruptionError indicates that the replica has experienced
  1030  // an error which puts its integrity at risk.
  1031  type ReplicaCorruptionError struct {
  1032  	ErrorMsg string `protobuf:"bytes,1,opt,name=error_msg,json=errorMsg" json:"error_msg"`
  1033  	// processed indicates that the error has been taken into account and
  1034  	// necessary steps will be taken. For now, required for testing.
  1035  	Processed bool `protobuf:"varint,2,opt,name=processed" json:"processed"`
  1036  }
  1037  
  1038  func (m *ReplicaCorruptionError) Reset()         { *m = ReplicaCorruptionError{} }
  1039  func (m *ReplicaCorruptionError) String() string { return proto.CompactTextString(m) }
  1040  func (*ReplicaCorruptionError) ProtoMessage()    {}
  1041  func (*ReplicaCorruptionError) Descriptor() ([]byte, []int) {
  1042  	return fileDescriptor_errors_4401e49350ed5ee8, []int{18}
  1043  }
  1044  func (m *ReplicaCorruptionError) XXX_Unmarshal(b []byte) error {
  1045  	return m.Unmarshal(b)
  1046  }
  1047  func (m *ReplicaCorruptionError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1048  	b = b[:cap(b)]
  1049  	n, err := m.MarshalTo(b)
  1050  	if err != nil {
  1051  		return nil, err
  1052  	}
  1053  	return b[:n], nil
  1054  }
  1055  func (dst *ReplicaCorruptionError) XXX_Merge(src proto.Message) {
  1056  	xxx_messageInfo_ReplicaCorruptionError.Merge(dst, src)
  1057  }
  1058  func (m *ReplicaCorruptionError) XXX_Size() int {
  1059  	return m.Size()
  1060  }
  1061  func (m *ReplicaCorruptionError) XXX_DiscardUnknown() {
  1062  	xxx_messageInfo_ReplicaCorruptionError.DiscardUnknown(m)
  1063  }
  1064  
  1065  var xxx_messageInfo_ReplicaCorruptionError proto.InternalMessageInfo
  1066  
  1067  // ReplicaTooOldError is sent in response to a raft message when the
  1068  // recipient of the raft message believes the sender of the raft
  1069  // message to have been removed from the raft group
  1070  type ReplicaTooOldError struct {
  1071  	// replica_id is the ID of the replica that is too old.
  1072  	ReplicaID ReplicaID `protobuf:"varint,1,opt,name=replica_id,json=replicaId,casttype=ReplicaID" json:"replica_id"`
  1073  }
  1074  
  1075  func (m *ReplicaTooOldError) Reset()         { *m = ReplicaTooOldError{} }
  1076  func (m *ReplicaTooOldError) String() string { return proto.CompactTextString(m) }
  1077  func (*ReplicaTooOldError) ProtoMessage()    {}
  1078  func (*ReplicaTooOldError) Descriptor() ([]byte, []int) {
  1079  	return fileDescriptor_errors_4401e49350ed5ee8, []int{19}
  1080  }
  1081  func (m *ReplicaTooOldError) XXX_Unmarshal(b []byte) error {
  1082  	return m.Unmarshal(b)
  1083  }
  1084  func (m *ReplicaTooOldError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1085  	b = b[:cap(b)]
  1086  	n, err := m.MarshalTo(b)
  1087  	if err != nil {
  1088  		return nil, err
  1089  	}
  1090  	return b[:n], nil
  1091  }
  1092  func (dst *ReplicaTooOldError) XXX_Merge(src proto.Message) {
  1093  	xxx_messageInfo_ReplicaTooOldError.Merge(dst, src)
  1094  }
  1095  func (m *ReplicaTooOldError) XXX_Size() int {
  1096  	return m.Size()
  1097  }
  1098  func (m *ReplicaTooOldError) XXX_DiscardUnknown() {
  1099  	xxx_messageInfo_ReplicaTooOldError.DiscardUnknown(m)
  1100  }
  1101  
  1102  var xxx_messageInfo_ReplicaTooOldError proto.InternalMessageInfo
  1103  
  1104  // A StoreNotFoundError indicates that a command was sent to a store
  1105  // which is not hosted on this node.
  1106  type StoreNotFoundError struct {
  1107  	StoreID StoreID `protobuf:"varint,1,opt,name=store_id,json=storeId,casttype=StoreID" json:"store_id"`
  1108  }
  1109  
  1110  func (m *StoreNotFoundError) Reset()         { *m = StoreNotFoundError{} }
  1111  func (m *StoreNotFoundError) String() string { return proto.CompactTextString(m) }
  1112  func (*StoreNotFoundError) ProtoMessage()    {}
  1113  func (*StoreNotFoundError) Descriptor() ([]byte, []int) {
  1114  	return fileDescriptor_errors_4401e49350ed5ee8, []int{20}
  1115  }
  1116  func (m *StoreNotFoundError) XXX_Unmarshal(b []byte) error {
  1117  	return m.Unmarshal(b)
  1118  }
  1119  func (m *StoreNotFoundError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1120  	b = b[:cap(b)]
  1121  	n, err := m.MarshalTo(b)
  1122  	if err != nil {
  1123  		return nil, err
  1124  	}
  1125  	return b[:n], nil
  1126  }
  1127  func (dst *StoreNotFoundError) XXX_Merge(src proto.Message) {
  1128  	xxx_messageInfo_StoreNotFoundError.Merge(dst, src)
  1129  }
  1130  func (m *StoreNotFoundError) XXX_Size() int {
  1131  	return m.Size()
  1132  }
  1133  func (m *StoreNotFoundError) XXX_DiscardUnknown() {
  1134  	xxx_messageInfo_StoreNotFoundError.DiscardUnknown(m)
  1135  }
  1136  
  1137  var xxx_messageInfo_StoreNotFoundError proto.InternalMessageInfo
  1138  
  1139  // UnhandledRetryableError tells the recipient that a KV request must be
  1140  // retried. In case the request was transactional, the whole transaction needs
  1141  // to be retried. This is returned generally as a result of a transaction
  1142  // conflict.
  1143  //
  1144  // This error is generated by pErr.GoError() in case of a retryable
  1145  // error (other than TransactionRetryWithProtoRefreshError). For transactional
  1146  // requests, the TxnCoordSender handles retryable pErrs and transforms
  1147  // them into TransactionRetryWithProtoRefreshError. For non-transactional requests,
  1148  // this error will be observed by layers above the TxnCoordSender.
  1149  type UnhandledRetryableError struct {
  1150  	// The underlying storage error that is being marshaled.
  1151  	// pErr.TransactionRestart is expected to be set, and the error
  1152  	// detail is one of the retryable ones.
  1153  	PErr Error `protobuf:"bytes,1,opt,name=pErr" json:"pErr"`
  1154  }
  1155  
  1156  func (m *UnhandledRetryableError) Reset()         { *m = UnhandledRetryableError{} }
  1157  func (m *UnhandledRetryableError) String() string { return proto.CompactTextString(m) }
  1158  func (*UnhandledRetryableError) ProtoMessage()    {}
  1159  func (*UnhandledRetryableError) Descriptor() ([]byte, []int) {
  1160  	return fileDescriptor_errors_4401e49350ed5ee8, []int{21}
  1161  }
  1162  func (m *UnhandledRetryableError) XXX_Unmarshal(b []byte) error {
  1163  	return m.Unmarshal(b)
  1164  }
  1165  func (m *UnhandledRetryableError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1166  	b = b[:cap(b)]
  1167  	n, err := m.MarshalTo(b)
  1168  	if err != nil {
  1169  		return nil, err
  1170  	}
  1171  	return b[:n], nil
  1172  }
  1173  func (dst *UnhandledRetryableError) XXX_Merge(src proto.Message) {
  1174  	xxx_messageInfo_UnhandledRetryableError.Merge(dst, src)
  1175  }
  1176  func (m *UnhandledRetryableError) XXX_Size() int {
  1177  	return m.Size()
  1178  }
  1179  func (m *UnhandledRetryableError) XXX_DiscardUnknown() {
  1180  	xxx_messageInfo_UnhandledRetryableError.DiscardUnknown(m)
  1181  }
  1182  
  1183  var xxx_messageInfo_UnhandledRetryableError proto.InternalMessageInfo
  1184  
  1185  // TransactionRetryWithProtoRefreshError is an error detail representing a retryable error
  1186  // that has been "handled" by the TxnCoordSender. This error is produced by the
  1187  // TxnCoordSender and is only produced for transactional requests.
  1188  //
  1189  // It contains the final form of the Transaction proto that should be used on
  1190  // next attempts. After being produced by the TxnCoordSender, this error is
  1191  // handled first by the client.Txn, which uses the Transaction inside to update
  1192  // its state, and then passed along to SQL in a pErr (through the
  1193  // client.Sender() interface).
  1194  type TransactionRetryWithProtoRefreshError struct {
  1195  	// A user-readable message.
  1196  	Msg string `protobuf:"bytes,1,opt,name=msg" json:"msg"`
  1197  	// The ID of the transaction being restarted. The client is supposed to check
  1198  	// this against the ID of its transaction and make sure the retryable error
  1199  	// is meant for its level and didn't escape from some inner transaction.
  1200  	TxnID github_com_cockroachdb_cockroach_pkg_util_uuid.UUID `protobuf:"bytes,2,opt,name=txn_id,json=txnId,customtype=github.com/cockroachdb/cockroach/pkg/util/uuid.UUID" json:"txn_id"`
  1201  	// The Transaction that should be used by next attempts. Depending on the
  1202  	// original cause of this method, this can either be the same Transaction as
  1203  	// before, but with an incremented epoch and timestamp, or a completely new
  1204  	// Transaction.
  1205  	Transaction Transaction `protobuf:"bytes,3,opt,name=transaction" json:"transaction"`
  1206  }
  1207  
  1208  func (m *TransactionRetryWithProtoRefreshError) Reset()         { *m = TransactionRetryWithProtoRefreshError{} }
  1209  func (m *TransactionRetryWithProtoRefreshError) String() string { return proto.CompactTextString(m) }
  1210  func (*TransactionRetryWithProtoRefreshError) ProtoMessage()    {}
  1211  func (*TransactionRetryWithProtoRefreshError) Descriptor() ([]byte, []int) {
  1212  	return fileDescriptor_errors_4401e49350ed5ee8, []int{22}
  1213  }
  1214  func (m *TransactionRetryWithProtoRefreshError) XXX_Unmarshal(b []byte) error {
  1215  	return m.Unmarshal(b)
  1216  }
  1217  func (m *TransactionRetryWithProtoRefreshError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1218  	b = b[:cap(b)]
  1219  	n, err := m.MarshalTo(b)
  1220  	if err != nil {
  1221  		return nil, err
  1222  	}
  1223  	return b[:n], nil
  1224  }
  1225  func (dst *TransactionRetryWithProtoRefreshError) XXX_Merge(src proto.Message) {
  1226  	xxx_messageInfo_TransactionRetryWithProtoRefreshError.Merge(dst, src)
  1227  }
  1228  func (m *TransactionRetryWithProtoRefreshError) XXX_Size() int {
  1229  	return m.Size()
  1230  }
  1231  func (m *TransactionRetryWithProtoRefreshError) XXX_DiscardUnknown() {
  1232  	xxx_messageInfo_TransactionRetryWithProtoRefreshError.DiscardUnknown(m)
  1233  }
  1234  
  1235  var xxx_messageInfo_TransactionRetryWithProtoRefreshError proto.InternalMessageInfo
  1236  
  1237  // TxnAlreadyEncounteredErrorError indicates that an operation tried to use a
  1238  // transaction that already received an error from a previous request. Once that
  1239  // happens, client.Txn rejects future requests.
  1240  type TxnAlreadyEncounteredErrorError struct {
  1241  	// prev_error is the message from the error that the txn encountered
  1242  	// previously.
  1243  	PrevError string `protobuf:"bytes,1,opt,name=prev_error,json=prevError" json:"prev_error"`
  1244  }
  1245  
  1246  func (m *TxnAlreadyEncounteredErrorError) Reset()         { *m = TxnAlreadyEncounteredErrorError{} }
  1247  func (m *TxnAlreadyEncounteredErrorError) String() string { return proto.CompactTextString(m) }
  1248  func (*TxnAlreadyEncounteredErrorError) ProtoMessage()    {}
  1249  func (*TxnAlreadyEncounteredErrorError) Descriptor() ([]byte, []int) {
  1250  	return fileDescriptor_errors_4401e49350ed5ee8, []int{23}
  1251  }
  1252  func (m *TxnAlreadyEncounteredErrorError) XXX_Unmarshal(b []byte) error {
  1253  	return m.Unmarshal(b)
  1254  }
  1255  func (m *TxnAlreadyEncounteredErrorError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1256  	b = b[:cap(b)]
  1257  	n, err := m.MarshalTo(b)
  1258  	if err != nil {
  1259  		return nil, err
  1260  	}
  1261  	return b[:n], nil
  1262  }
  1263  func (dst *TxnAlreadyEncounteredErrorError) XXX_Merge(src proto.Message) {
  1264  	xxx_messageInfo_TxnAlreadyEncounteredErrorError.Merge(dst, src)
  1265  }
  1266  func (m *TxnAlreadyEncounteredErrorError) XXX_Size() int {
  1267  	return m.Size()
  1268  }
  1269  func (m *TxnAlreadyEncounteredErrorError) XXX_DiscardUnknown() {
  1270  	xxx_messageInfo_TxnAlreadyEncounteredErrorError.DiscardUnknown(m)
  1271  }
  1272  
  1273  var xxx_messageInfo_TxnAlreadyEncounteredErrorError proto.InternalMessageInfo
  1274  
  1275  // An IntegerOverflowError indicates that an operation was aborted because
  1276  // it would have caused an integeter overflow.
  1277  type IntegerOverflowError struct {
  1278  	Key            Key   `protobuf:"bytes,1,opt,name=key,casttype=Key" json:"key,omitempty"`
  1279  	CurrentValue   int64 `protobuf:"varint,2,opt,name=current_value,json=currentValue" json:"current_value"`
  1280  	IncrementValue int64 `protobuf:"varint,3,opt,name=increment_value,json=incrementValue" json:"increment_value"`
  1281  }
  1282  
  1283  func (m *IntegerOverflowError) Reset()         { *m = IntegerOverflowError{} }
  1284  func (m *IntegerOverflowError) String() string { return proto.CompactTextString(m) }
  1285  func (*IntegerOverflowError) ProtoMessage()    {}
  1286  func (*IntegerOverflowError) Descriptor() ([]byte, []int) {
  1287  	return fileDescriptor_errors_4401e49350ed5ee8, []int{24}
  1288  }
  1289  func (m *IntegerOverflowError) XXX_Unmarshal(b []byte) error {
  1290  	return m.Unmarshal(b)
  1291  }
  1292  func (m *IntegerOverflowError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1293  	b = b[:cap(b)]
  1294  	n, err := m.MarshalTo(b)
  1295  	if err != nil {
  1296  		return nil, err
  1297  	}
  1298  	return b[:n], nil
  1299  }
  1300  func (dst *IntegerOverflowError) XXX_Merge(src proto.Message) {
  1301  	xxx_messageInfo_IntegerOverflowError.Merge(dst, src)
  1302  }
  1303  func (m *IntegerOverflowError) XXX_Size() int {
  1304  	return m.Size()
  1305  }
  1306  func (m *IntegerOverflowError) XXX_DiscardUnknown() {
  1307  	xxx_messageInfo_IntegerOverflowError.DiscardUnknown(m)
  1308  }
  1309  
  1310  var xxx_messageInfo_IntegerOverflowError proto.InternalMessageInfo
  1311  
  1312  // A BatchTimestampBeforeGCError indicates that a request's timestamp was
  1313  // before the GC threshold.
  1314  type BatchTimestampBeforeGCError struct {
  1315  	Timestamp hlc.Timestamp `protobuf:"bytes,1,opt,name=Timestamp" json:"Timestamp"`
  1316  	Threshold hlc.Timestamp `protobuf:"bytes,2,opt,name=Threshold" json:"Threshold"`
  1317  }
  1318  
  1319  func (m *BatchTimestampBeforeGCError) Reset()         { *m = BatchTimestampBeforeGCError{} }
  1320  func (m *BatchTimestampBeforeGCError) String() string { return proto.CompactTextString(m) }
  1321  func (*BatchTimestampBeforeGCError) ProtoMessage()    {}
  1322  func (*BatchTimestampBeforeGCError) Descriptor() ([]byte, []int) {
  1323  	return fileDescriptor_errors_4401e49350ed5ee8, []int{25}
  1324  }
  1325  func (m *BatchTimestampBeforeGCError) XXX_Unmarshal(b []byte) error {
  1326  	return m.Unmarshal(b)
  1327  }
  1328  func (m *BatchTimestampBeforeGCError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1329  	b = b[:cap(b)]
  1330  	n, err := m.MarshalTo(b)
  1331  	if err != nil {
  1332  		return nil, err
  1333  	}
  1334  	return b[:n], nil
  1335  }
  1336  func (dst *BatchTimestampBeforeGCError) XXX_Merge(src proto.Message) {
  1337  	xxx_messageInfo_BatchTimestampBeforeGCError.Merge(dst, src)
  1338  }
  1339  func (m *BatchTimestampBeforeGCError) XXX_Size() int {
  1340  	return m.Size()
  1341  }
  1342  func (m *BatchTimestampBeforeGCError) XXX_DiscardUnknown() {
  1343  	xxx_messageInfo_BatchTimestampBeforeGCError.DiscardUnknown(m)
  1344  }
  1345  
  1346  var xxx_messageInfo_BatchTimestampBeforeGCError proto.InternalMessageInfo
  1347  
  1348  // An IntentMissingError indicates that a QueryIntent request expected
  1349  // an intent to be present at its specified key but the intent was
  1350  // not there.
  1351  type IntentMissingError struct {
  1352  	// The non-matching intent that was found at that key, if any.
  1353  	WrongIntent *Intent `protobuf:"bytes,1,opt,name=wrong_intent,json=wrongIntent" json:"wrong_intent,omitempty"`
  1354  	// The key where the intent was expected.
  1355  	Key Key `protobuf:"bytes,2,opt,name=key,casttype=Key" json:"key,omitempty"`
  1356  }
  1357  
  1358  func (m *IntentMissingError) Reset()         { *m = IntentMissingError{} }
  1359  func (m *IntentMissingError) String() string { return proto.CompactTextString(m) }
  1360  func (*IntentMissingError) ProtoMessage()    {}
  1361  func (*IntentMissingError) Descriptor() ([]byte, []int) {
  1362  	return fileDescriptor_errors_4401e49350ed5ee8, []int{26}
  1363  }
  1364  func (m *IntentMissingError) XXX_Unmarshal(b []byte) error {
  1365  	return m.Unmarshal(b)
  1366  }
  1367  func (m *IntentMissingError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1368  	b = b[:cap(b)]
  1369  	n, err := m.MarshalTo(b)
  1370  	if err != nil {
  1371  		return nil, err
  1372  	}
  1373  	return b[:n], nil
  1374  }
  1375  func (dst *IntentMissingError) XXX_Merge(src proto.Message) {
  1376  	xxx_messageInfo_IntentMissingError.Merge(dst, src)
  1377  }
  1378  func (m *IntentMissingError) XXX_Size() int {
  1379  	return m.Size()
  1380  }
  1381  func (m *IntentMissingError) XXX_DiscardUnknown() {
  1382  	xxx_messageInfo_IntentMissingError.DiscardUnknown(m)
  1383  }
  1384  
  1385  var xxx_messageInfo_IntentMissingError proto.InternalMessageInfo
  1386  
  1387  // A MergeInProgressError indicates that the request could not be completed
  1388  // because the replica is being merged into its left-hand neighbor. The request
  1389  // should be resubmitted after the merge completes.
  1390  //
  1391  // This error is handled by the Store and should not escape to higher levels.
  1392  type MergeInProgressError struct {
  1393  }
  1394  
  1395  func (m *MergeInProgressError) Reset()         { *m = MergeInProgressError{} }
  1396  func (m *MergeInProgressError) String() string { return proto.CompactTextString(m) }
  1397  func (*MergeInProgressError) ProtoMessage()    {}
  1398  func (*MergeInProgressError) Descriptor() ([]byte, []int) {
  1399  	return fileDescriptor_errors_4401e49350ed5ee8, []int{27}
  1400  }
  1401  func (m *MergeInProgressError) XXX_Unmarshal(b []byte) error {
  1402  	return m.Unmarshal(b)
  1403  }
  1404  func (m *MergeInProgressError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1405  	b = b[:cap(b)]
  1406  	n, err := m.MarshalTo(b)
  1407  	if err != nil {
  1408  		return nil, err
  1409  	}
  1410  	return b[:n], nil
  1411  }
  1412  func (dst *MergeInProgressError) XXX_Merge(src proto.Message) {
  1413  	xxx_messageInfo_MergeInProgressError.Merge(dst, src)
  1414  }
  1415  func (m *MergeInProgressError) XXX_Size() int {
  1416  	return m.Size()
  1417  }
  1418  func (m *MergeInProgressError) XXX_DiscardUnknown() {
  1419  	xxx_messageInfo_MergeInProgressError.DiscardUnknown(m)
  1420  }
  1421  
  1422  var xxx_messageInfo_MergeInProgressError proto.InternalMessageInfo
  1423  
  1424  // A RangeFeedRetryError indicates that a rangefeed was disconnected, often
  1425  // because of a range lifecycle event, and can be retried.
  1426  type RangeFeedRetryError struct {
  1427  	Reason RangeFeedRetryError_Reason `protobuf:"varint,1,opt,name=reason,enum=cockroach.roachpb.RangeFeedRetryError_Reason" json:"reason"`
  1428  }
  1429  
  1430  func (m *RangeFeedRetryError) Reset()         { *m = RangeFeedRetryError{} }
  1431  func (m *RangeFeedRetryError) String() string { return proto.CompactTextString(m) }
  1432  func (*RangeFeedRetryError) ProtoMessage()    {}
  1433  func (*RangeFeedRetryError) Descriptor() ([]byte, []int) {
  1434  	return fileDescriptor_errors_4401e49350ed5ee8, []int{28}
  1435  }
  1436  func (m *RangeFeedRetryError) XXX_Unmarshal(b []byte) error {
  1437  	return m.Unmarshal(b)
  1438  }
  1439  func (m *RangeFeedRetryError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1440  	b = b[:cap(b)]
  1441  	n, err := m.MarshalTo(b)
  1442  	if err != nil {
  1443  		return nil, err
  1444  	}
  1445  	return b[:n], nil
  1446  }
  1447  func (dst *RangeFeedRetryError) XXX_Merge(src proto.Message) {
  1448  	xxx_messageInfo_RangeFeedRetryError.Merge(dst, src)
  1449  }
  1450  func (m *RangeFeedRetryError) XXX_Size() int {
  1451  	return m.Size()
  1452  }
  1453  func (m *RangeFeedRetryError) XXX_DiscardUnknown() {
  1454  	xxx_messageInfo_RangeFeedRetryError.DiscardUnknown(m)
  1455  }
  1456  
  1457  var xxx_messageInfo_RangeFeedRetryError proto.InternalMessageInfo
  1458  
  1459  // A IndeterminateCommitError indicates that a transaction was encountered with
  1460  // a STAGING status. In this state, it is unclear by observing the transaction
  1461  // record alone whether the transaction should be committed or aborted. To make
  1462  // this determination, the transaction recovery process must be initiated. This
  1463  // process makes a ruling on the final state of the transaction based on the
  1464  // outcome of its in-flight writes at the time of staging.
  1465  type IndeterminateCommitError struct {
  1466  	StagingTxn Transaction `protobuf:"bytes,1,opt,name=staging_txn,json=stagingTxn" json:"staging_txn"`
  1467  }
  1468  
  1469  func (m *IndeterminateCommitError) Reset()         { *m = IndeterminateCommitError{} }
  1470  func (m *IndeterminateCommitError) String() string { return proto.CompactTextString(m) }
  1471  func (*IndeterminateCommitError) ProtoMessage()    {}
  1472  func (*IndeterminateCommitError) Descriptor() ([]byte, []int) {
  1473  	return fileDescriptor_errors_4401e49350ed5ee8, []int{29}
  1474  }
  1475  func (m *IndeterminateCommitError) XXX_Unmarshal(b []byte) error {
  1476  	return m.Unmarshal(b)
  1477  }
  1478  func (m *IndeterminateCommitError) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1479  	b = b[:cap(b)]
  1480  	n, err := m.MarshalTo(b)
  1481  	if err != nil {
  1482  		return nil, err
  1483  	}
  1484  	return b[:n], nil
  1485  }
  1486  func (dst *IndeterminateCommitError) XXX_Merge(src proto.Message) {
  1487  	xxx_messageInfo_IndeterminateCommitError.Merge(dst, src)
  1488  }
  1489  func (m *IndeterminateCommitError) XXX_Size() int {
  1490  	return m.Size()
  1491  }
  1492  func (m *IndeterminateCommitError) XXX_DiscardUnknown() {
  1493  	xxx_messageInfo_IndeterminateCommitError.DiscardUnknown(m)
  1494  }
  1495  
  1496  var xxx_messageInfo_IndeterminateCommitError proto.InternalMessageInfo
  1497  
  1498  // ErrorDetail is a union type containing all available errors.
  1499  type ErrorDetail struct {
  1500  	// Types that are valid to be assigned to Value:
  1501  	//	*ErrorDetail_NotLeaseHolder
  1502  	//	*ErrorDetail_RangeNotFound
  1503  	//	*ErrorDetail_RangeKeyMismatch
  1504  	//	*ErrorDetail_ReadWithinUncertaintyInterval
  1505  	//	*ErrorDetail_TransactionAborted
  1506  	//	*ErrorDetail_TransactionPush
  1507  	//	*ErrorDetail_TransactionRetry
  1508  	//	*ErrorDetail_TransactionStatus
  1509  	//	*ErrorDetail_WriteIntent
  1510  	//	*ErrorDetail_WriteTooOld
  1511  	//	*ErrorDetail_OpRequiresTxn
  1512  	//	*ErrorDetail_ConditionFailed
  1513  	//	*ErrorDetail_LeaseRejected
  1514  	//	*ErrorDetail_NodeUnavailable
  1515  	//	*ErrorDetail_Send
  1516  	//	*ErrorDetail_RaftGroupDeleted
  1517  	//	*ErrorDetail_ReplicaCorruption
  1518  	//	*ErrorDetail_ReplicaTooOld
  1519  	//	*ErrorDetail_AmbiguousResult
  1520  	//	*ErrorDetail_StoreNotFound
  1521  	//	*ErrorDetail_TransactionRetryWithProtoRefresh
  1522  	//	*ErrorDetail_IntegerOverflow
  1523  	//	*ErrorDetail_UnsupportedRequest
  1524  	//	*ErrorDetail_TimestampBefore
  1525  	//	*ErrorDetail_TxnAlreadyEncounteredError
  1526  	//	*ErrorDetail_IntentMissing
  1527  	//	*ErrorDetail_MergeInProgress
  1528  	//	*ErrorDetail_RangefeedRetry
  1529  	//	*ErrorDetail_IndeterminateCommit
  1530  	Value isErrorDetail_Value `protobuf_oneof:"value"`
  1531  }
  1532  
  1533  func (m *ErrorDetail) Reset()         { *m = ErrorDetail{} }
  1534  func (m *ErrorDetail) String() string { return proto.CompactTextString(m) }
  1535  func (*ErrorDetail) ProtoMessage()    {}
  1536  func (*ErrorDetail) Descriptor() ([]byte, []int) {
  1537  	return fileDescriptor_errors_4401e49350ed5ee8, []int{30}
  1538  }
  1539  func (m *ErrorDetail) XXX_Unmarshal(b []byte) error {
  1540  	return m.Unmarshal(b)
  1541  }
  1542  func (m *ErrorDetail) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1543  	b = b[:cap(b)]
  1544  	n, err := m.MarshalTo(b)
  1545  	if err != nil {
  1546  		return nil, err
  1547  	}
  1548  	return b[:n], nil
  1549  }
  1550  func (dst *ErrorDetail) XXX_Merge(src proto.Message) {
  1551  	xxx_messageInfo_ErrorDetail.Merge(dst, src)
  1552  }
  1553  func (m *ErrorDetail) XXX_Size() int {
  1554  	return m.Size()
  1555  }
  1556  func (m *ErrorDetail) XXX_DiscardUnknown() {
  1557  	xxx_messageInfo_ErrorDetail.DiscardUnknown(m)
  1558  }
  1559  
  1560  var xxx_messageInfo_ErrorDetail proto.InternalMessageInfo
  1561  
  1562  type isErrorDetail_Value interface {
  1563  	isErrorDetail_Value()
  1564  	Equal(interface{}) bool
  1565  	MarshalTo([]byte) (int, error)
  1566  	Size() int
  1567  }
  1568  
  1569  type ErrorDetail_NotLeaseHolder struct {
  1570  	NotLeaseHolder *NotLeaseHolderError `protobuf:"bytes,1,opt,name=not_lease_holder,json=notLeaseHolder,oneof"`
  1571  }
  1572  type ErrorDetail_RangeNotFound struct {
  1573  	RangeNotFound *RangeNotFoundError `protobuf:"bytes,2,opt,name=range_not_found,json=rangeNotFound,oneof"`
  1574  }
  1575  type ErrorDetail_RangeKeyMismatch struct {
  1576  	RangeKeyMismatch *RangeKeyMismatchError `protobuf:"bytes,3,opt,name=range_key_mismatch,json=rangeKeyMismatch,oneof"`
  1577  }
  1578  type ErrorDetail_ReadWithinUncertaintyInterval struct {
  1579  	ReadWithinUncertaintyInterval *ReadWithinUncertaintyIntervalError `protobuf:"bytes,4,opt,name=read_within_uncertainty_interval,json=readWithinUncertaintyInterval,oneof"`
  1580  }
  1581  type ErrorDetail_TransactionAborted struct {
  1582  	TransactionAborted *TransactionAbortedError `protobuf:"bytes,5,opt,name=transaction_aborted,json=transactionAborted,oneof"`
  1583  }
  1584  type ErrorDetail_TransactionPush struct {
  1585  	TransactionPush *TransactionPushError `protobuf:"bytes,6,opt,name=transaction_push,json=transactionPush,oneof"`
  1586  }
  1587  type ErrorDetail_TransactionRetry struct {
  1588  	TransactionRetry *TransactionRetryError `protobuf:"bytes,7,opt,name=transaction_retry,json=transactionRetry,oneof"`
  1589  }
  1590  type ErrorDetail_TransactionStatus struct {
  1591  	TransactionStatus *TransactionStatusError `protobuf:"bytes,8,opt,name=transaction_status,json=transactionStatus,oneof"`
  1592  }
  1593  type ErrorDetail_WriteIntent struct {
  1594  	WriteIntent *WriteIntentError `protobuf:"bytes,9,opt,name=write_intent,json=writeIntent,oneof"`
  1595  }
  1596  type ErrorDetail_WriteTooOld struct {
  1597  	WriteTooOld *WriteTooOldError `protobuf:"bytes,10,opt,name=write_too_old,json=writeTooOld,oneof"`
  1598  }
  1599  type ErrorDetail_OpRequiresTxn struct {
  1600  	OpRequiresTxn *OpRequiresTxnError `protobuf:"bytes,11,opt,name=op_requires_txn,json=opRequiresTxn,oneof"`
  1601  }
  1602  type ErrorDetail_ConditionFailed struct {
  1603  	ConditionFailed *ConditionFailedError `protobuf:"bytes,12,opt,name=condition_failed,json=conditionFailed,oneof"`
  1604  }
  1605  type ErrorDetail_LeaseRejected struct {
  1606  	LeaseRejected *LeaseRejectedError `protobuf:"bytes,13,opt,name=lease_rejected,json=leaseRejected,oneof"`
  1607  }
  1608  type ErrorDetail_NodeUnavailable struct {
  1609  	NodeUnavailable *NodeUnavailableError `protobuf:"bytes,14,opt,name=node_unavailable,json=nodeUnavailable,oneof"`
  1610  }
  1611  type ErrorDetail_Send struct {
  1612  	Send *SendError `protobuf:"bytes,15,opt,name=send,oneof"`
  1613  }
  1614  type ErrorDetail_RaftGroupDeleted struct {
  1615  	RaftGroupDeleted *RaftGroupDeletedError `protobuf:"bytes,16,opt,name=raft_group_deleted,json=raftGroupDeleted,oneof"`
  1616  }
  1617  type ErrorDetail_ReplicaCorruption struct {
  1618  	ReplicaCorruption *ReplicaCorruptionError `protobuf:"bytes,17,opt,name=replica_corruption,json=replicaCorruption,oneof"`
  1619  }
  1620  type ErrorDetail_ReplicaTooOld struct {
  1621  	ReplicaTooOld *ReplicaTooOldError `protobuf:"bytes,18,opt,name=replica_too_old,json=replicaTooOld,oneof"`
  1622  }
  1623  type ErrorDetail_AmbiguousResult struct {
  1624  	AmbiguousResult *AmbiguousResultError `protobuf:"bytes,26,opt,name=ambiguous_result,json=ambiguousResult,oneof"`
  1625  }
  1626  type ErrorDetail_StoreNotFound struct {
  1627  	StoreNotFound *StoreNotFoundError `protobuf:"bytes,27,opt,name=store_not_found,json=storeNotFound,oneof"`
  1628  }
  1629  type ErrorDetail_TransactionRetryWithProtoRefresh struct {
  1630  	TransactionRetryWithProtoRefresh *TransactionRetryWithProtoRefreshError `protobuf:"bytes,28,opt,name=transaction_retry_with_proto_refresh,json=transactionRetryWithProtoRefresh,oneof"`
  1631  }
  1632  type ErrorDetail_IntegerOverflow struct {
  1633  	IntegerOverflow *IntegerOverflowError `protobuf:"bytes,31,opt,name=integer_overflow,json=integerOverflow,oneof"`
  1634  }
  1635  type ErrorDetail_UnsupportedRequest struct {
  1636  	UnsupportedRequest *UnsupportedRequestError `protobuf:"bytes,32,opt,name=unsupported_request,json=unsupportedRequest,oneof"`
  1637  }
  1638  type ErrorDetail_TimestampBefore struct {
  1639  	TimestampBefore *BatchTimestampBeforeGCError `protobuf:"bytes,34,opt,name=timestamp_before,json=timestampBefore,oneof"`
  1640  }
  1641  type ErrorDetail_TxnAlreadyEncounteredError struct {
  1642  	TxnAlreadyEncounteredError *TxnAlreadyEncounteredErrorError `protobuf:"bytes,35,opt,name=txn_already_encountered_error,json=txnAlreadyEncounteredError,oneof"`
  1643  }
  1644  type ErrorDetail_IntentMissing struct {
  1645  	IntentMissing *IntentMissingError `protobuf:"bytes,36,opt,name=intent_missing,json=intentMissing,oneof"`
  1646  }
  1647  type ErrorDetail_MergeInProgress struct {
  1648  	MergeInProgress *MergeInProgressError `protobuf:"bytes,37,opt,name=merge_in_progress,json=mergeInProgress,oneof"`
  1649  }
  1650  type ErrorDetail_RangefeedRetry struct {
  1651  	RangefeedRetry *RangeFeedRetryError `protobuf:"bytes,38,opt,name=rangefeed_retry,json=rangefeedRetry,oneof"`
  1652  }
  1653  type ErrorDetail_IndeterminateCommit struct {
  1654  	IndeterminateCommit *IndeterminateCommitError `protobuf:"bytes,39,opt,name=indeterminate_commit,json=indeterminateCommit,oneof"`
  1655  }
  1656  
  1657  func (*ErrorDetail_NotLeaseHolder) isErrorDetail_Value()                   {}
  1658  func (*ErrorDetail_RangeNotFound) isErrorDetail_Value()                    {}
  1659  func (*ErrorDetail_RangeKeyMismatch) isErrorDetail_Value()                 {}
  1660  func (*ErrorDetail_ReadWithinUncertaintyInterval) isErrorDetail_Value()    {}
  1661  func (*ErrorDetail_TransactionAborted) isErrorDetail_Value()               {}
  1662  func (*ErrorDetail_TransactionPush) isErrorDetail_Value()                  {}
  1663  func (*ErrorDetail_TransactionRetry) isErrorDetail_Value()                 {}
  1664  func (*ErrorDetail_TransactionStatus) isErrorDetail_Value()                {}
  1665  func (*ErrorDetail_WriteIntent) isErrorDetail_Value()                      {}
  1666  func (*ErrorDetail_WriteTooOld) isErrorDetail_Value()                      {}
  1667  func (*ErrorDetail_OpRequiresTxn) isErrorDetail_Value()                    {}
  1668  func (*ErrorDetail_ConditionFailed) isErrorDetail_Value()                  {}
  1669  func (*ErrorDetail_LeaseRejected) isErrorDetail_Value()                    {}
  1670  func (*ErrorDetail_NodeUnavailable) isErrorDetail_Value()                  {}
  1671  func (*ErrorDetail_Send) isErrorDetail_Value()                             {}
  1672  func (*ErrorDetail_RaftGroupDeleted) isErrorDetail_Value()                 {}
  1673  func (*ErrorDetail_ReplicaCorruption) isErrorDetail_Value()                {}
  1674  func (*ErrorDetail_ReplicaTooOld) isErrorDetail_Value()                    {}
  1675  func (*ErrorDetail_AmbiguousResult) isErrorDetail_Value()                  {}
  1676  func (*ErrorDetail_StoreNotFound) isErrorDetail_Value()                    {}
  1677  func (*ErrorDetail_TransactionRetryWithProtoRefresh) isErrorDetail_Value() {}
  1678  func (*ErrorDetail_IntegerOverflow) isErrorDetail_Value()                  {}
  1679  func (*ErrorDetail_UnsupportedRequest) isErrorDetail_Value()               {}
  1680  func (*ErrorDetail_TimestampBefore) isErrorDetail_Value()                  {}
  1681  func (*ErrorDetail_TxnAlreadyEncounteredError) isErrorDetail_Value()       {}
  1682  func (*ErrorDetail_IntentMissing) isErrorDetail_Value()                    {}
  1683  func (*ErrorDetail_MergeInProgress) isErrorDetail_Value()                  {}
  1684  func (*ErrorDetail_RangefeedRetry) isErrorDetail_Value()                   {}
  1685  func (*ErrorDetail_IndeterminateCommit) isErrorDetail_Value()              {}
  1686  
  1687  func (m *ErrorDetail) GetValue() isErrorDetail_Value {
  1688  	if m != nil {
  1689  		return m.Value
  1690  	}
  1691  	return nil
  1692  }
  1693  
  1694  func (m *ErrorDetail) GetNotLeaseHolder() *NotLeaseHolderError {
  1695  	if x, ok := m.GetValue().(*ErrorDetail_NotLeaseHolder); ok {
  1696  		return x.NotLeaseHolder
  1697  	}
  1698  	return nil
  1699  }
  1700  
  1701  func (m *ErrorDetail) GetRangeNotFound() *RangeNotFoundError {
  1702  	if x, ok := m.GetValue().(*ErrorDetail_RangeNotFound); ok {
  1703  		return x.RangeNotFound
  1704  	}
  1705  	return nil
  1706  }
  1707  
  1708  func (m *ErrorDetail) GetRangeKeyMismatch() *RangeKeyMismatchError {
  1709  	if x, ok := m.GetValue().(*ErrorDetail_RangeKeyMismatch); ok {
  1710  		return x.RangeKeyMismatch
  1711  	}
  1712  	return nil
  1713  }
  1714  
  1715  func (m *ErrorDetail) GetReadWithinUncertaintyInterval() *ReadWithinUncertaintyIntervalError {
  1716  	if x, ok := m.GetValue().(*ErrorDetail_ReadWithinUncertaintyInterval); ok {
  1717  		return x.ReadWithinUncertaintyInterval
  1718  	}
  1719  	return nil
  1720  }
  1721  
  1722  func (m *ErrorDetail) GetTransactionAborted() *TransactionAbortedError {
  1723  	if x, ok := m.GetValue().(*ErrorDetail_TransactionAborted); ok {
  1724  		return x.TransactionAborted
  1725  	}
  1726  	return nil
  1727  }
  1728  
  1729  func (m *ErrorDetail) GetTransactionPush() *TransactionPushError {
  1730  	if x, ok := m.GetValue().(*ErrorDetail_TransactionPush); ok {
  1731  		return x.TransactionPush
  1732  	}
  1733  	return nil
  1734  }
  1735  
  1736  func (m *ErrorDetail) GetTransactionRetry() *TransactionRetryError {
  1737  	if x, ok := m.GetValue().(*ErrorDetail_TransactionRetry); ok {
  1738  		return x.TransactionRetry
  1739  	}
  1740  	return nil
  1741  }
  1742  
  1743  func (m *ErrorDetail) GetTransactionStatus() *TransactionStatusError {
  1744  	if x, ok := m.GetValue().(*ErrorDetail_TransactionStatus); ok {
  1745  		return x.TransactionStatus
  1746  	}
  1747  	return nil
  1748  }
  1749  
  1750  func (m *ErrorDetail) GetWriteIntent() *WriteIntentError {
  1751  	if x, ok := m.GetValue().(*ErrorDetail_WriteIntent); ok {
  1752  		return x.WriteIntent
  1753  	}
  1754  	return nil
  1755  }
  1756  
  1757  func (m *ErrorDetail) GetWriteTooOld() *WriteTooOldError {
  1758  	if x, ok := m.GetValue().(*ErrorDetail_WriteTooOld); ok {
  1759  		return x.WriteTooOld
  1760  	}
  1761  	return nil
  1762  }
  1763  
  1764  func (m *ErrorDetail) GetOpRequiresTxn() *OpRequiresTxnError {
  1765  	if x, ok := m.GetValue().(*ErrorDetail_OpRequiresTxn); ok {
  1766  		return x.OpRequiresTxn
  1767  	}
  1768  	return nil
  1769  }
  1770  
  1771  func (m *ErrorDetail) GetConditionFailed() *ConditionFailedError {
  1772  	if x, ok := m.GetValue().(*ErrorDetail_ConditionFailed); ok {
  1773  		return x.ConditionFailed
  1774  	}
  1775  	return nil
  1776  }
  1777  
  1778  func (m *ErrorDetail) GetLeaseRejected() *LeaseRejectedError {
  1779  	if x, ok := m.GetValue().(*ErrorDetail_LeaseRejected); ok {
  1780  		return x.LeaseRejected
  1781  	}
  1782  	return nil
  1783  }
  1784  
  1785  func (m *ErrorDetail) GetNodeUnavailable() *NodeUnavailableError {
  1786  	if x, ok := m.GetValue().(*ErrorDetail_NodeUnavailable); ok {
  1787  		return x.NodeUnavailable
  1788  	}
  1789  	return nil
  1790  }
  1791  
  1792  func (m *ErrorDetail) GetSend() *SendError {
  1793  	if x, ok := m.GetValue().(*ErrorDetail_Send); ok {
  1794  		return x.Send
  1795  	}
  1796  	return nil
  1797  }
  1798  
  1799  func (m *ErrorDetail) GetRaftGroupDeleted() *RaftGroupDeletedError {
  1800  	if x, ok := m.GetValue().(*ErrorDetail_RaftGroupDeleted); ok {
  1801  		return x.RaftGroupDeleted
  1802  	}
  1803  	return nil
  1804  }
  1805  
  1806  func (m *ErrorDetail) GetReplicaCorruption() *ReplicaCorruptionError {
  1807  	if x, ok := m.GetValue().(*ErrorDetail_ReplicaCorruption); ok {
  1808  		return x.ReplicaCorruption
  1809  	}
  1810  	return nil
  1811  }
  1812  
  1813  func (m *ErrorDetail) GetReplicaTooOld() *ReplicaTooOldError {
  1814  	if x, ok := m.GetValue().(*ErrorDetail_ReplicaTooOld); ok {
  1815  		return x.ReplicaTooOld
  1816  	}
  1817  	return nil
  1818  }
  1819  
  1820  func (m *ErrorDetail) GetAmbiguousResult() *AmbiguousResultError {
  1821  	if x, ok := m.GetValue().(*ErrorDetail_AmbiguousResult); ok {
  1822  		return x.AmbiguousResult
  1823  	}
  1824  	return nil
  1825  }
  1826  
  1827  func (m *ErrorDetail) GetStoreNotFound() *StoreNotFoundError {
  1828  	if x, ok := m.GetValue().(*ErrorDetail_StoreNotFound); ok {
  1829  		return x.StoreNotFound
  1830  	}
  1831  	return nil
  1832  }
  1833  
  1834  func (m *ErrorDetail) GetTransactionRetryWithProtoRefresh() *TransactionRetryWithProtoRefreshError {
  1835  	if x, ok := m.GetValue().(*ErrorDetail_TransactionRetryWithProtoRefresh); ok {
  1836  		return x.TransactionRetryWithProtoRefresh
  1837  	}
  1838  	return nil
  1839  }
  1840  
  1841  func (m *ErrorDetail) GetIntegerOverflow() *IntegerOverflowError {
  1842  	if x, ok := m.GetValue().(*ErrorDetail_IntegerOverflow); ok {
  1843  		return x.IntegerOverflow
  1844  	}
  1845  	return nil
  1846  }
  1847  
  1848  func (m *ErrorDetail) GetUnsupportedRequest() *UnsupportedRequestError {
  1849  	if x, ok := m.GetValue().(*ErrorDetail_UnsupportedRequest); ok {
  1850  		return x.UnsupportedRequest
  1851  	}
  1852  	return nil
  1853  }
  1854  
  1855  func (m *ErrorDetail) GetTimestampBefore() *BatchTimestampBeforeGCError {
  1856  	if x, ok := m.GetValue().(*ErrorDetail_TimestampBefore); ok {
  1857  		return x.TimestampBefore
  1858  	}
  1859  	return nil
  1860  }
  1861  
  1862  func (m *ErrorDetail) GetTxnAlreadyEncounteredError() *TxnAlreadyEncounteredErrorError {
  1863  	if x, ok := m.GetValue().(*ErrorDetail_TxnAlreadyEncounteredError); ok {
  1864  		return x.TxnAlreadyEncounteredError
  1865  	}
  1866  	return nil
  1867  }
  1868  
  1869  func (m *ErrorDetail) GetIntentMissing() *IntentMissingError {
  1870  	if x, ok := m.GetValue().(*ErrorDetail_IntentMissing); ok {
  1871  		return x.IntentMissing
  1872  	}
  1873  	return nil
  1874  }
  1875  
  1876  func (m *ErrorDetail) GetMergeInProgress() *MergeInProgressError {
  1877  	if x, ok := m.GetValue().(*ErrorDetail_MergeInProgress); ok {
  1878  		return x.MergeInProgress
  1879  	}
  1880  	return nil
  1881  }
  1882  
  1883  func (m *ErrorDetail) GetRangefeedRetry() *RangeFeedRetryError {
  1884  	if x, ok := m.GetValue().(*ErrorDetail_RangefeedRetry); ok {
  1885  		return x.RangefeedRetry
  1886  	}
  1887  	return nil
  1888  }
  1889  
  1890  func (m *ErrorDetail) GetIndeterminateCommit() *IndeterminateCommitError {
  1891  	if x, ok := m.GetValue().(*ErrorDetail_IndeterminateCommit); ok {
  1892  		return x.IndeterminateCommit
  1893  	}
  1894  	return nil
  1895  }
  1896  
  1897  // XXX_OneofFuncs is for the internal use of the proto package.
  1898  func (*ErrorDetail) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{}) {
  1899  	return _ErrorDetail_OneofMarshaler, _ErrorDetail_OneofUnmarshaler, _ErrorDetail_OneofSizer, []interface{}{
  1900  		(*ErrorDetail_NotLeaseHolder)(nil),
  1901  		(*ErrorDetail_RangeNotFound)(nil),
  1902  		(*ErrorDetail_RangeKeyMismatch)(nil),
  1903  		(*ErrorDetail_ReadWithinUncertaintyInterval)(nil),
  1904  		(*ErrorDetail_TransactionAborted)(nil),
  1905  		(*ErrorDetail_TransactionPush)(nil),
  1906  		(*ErrorDetail_TransactionRetry)(nil),
  1907  		(*ErrorDetail_TransactionStatus)(nil),
  1908  		(*ErrorDetail_WriteIntent)(nil),
  1909  		(*ErrorDetail_WriteTooOld)(nil),
  1910  		(*ErrorDetail_OpRequiresTxn)(nil),
  1911  		(*ErrorDetail_ConditionFailed)(nil),
  1912  		(*ErrorDetail_LeaseRejected)(nil),
  1913  		(*ErrorDetail_NodeUnavailable)(nil),
  1914  		(*ErrorDetail_Send)(nil),
  1915  		(*ErrorDetail_RaftGroupDeleted)(nil),
  1916  		(*ErrorDetail_ReplicaCorruption)(nil),
  1917  		(*ErrorDetail_ReplicaTooOld)(nil),
  1918  		(*ErrorDetail_AmbiguousResult)(nil),
  1919  		(*ErrorDetail_StoreNotFound)(nil),
  1920  		(*ErrorDetail_TransactionRetryWithProtoRefresh)(nil),
  1921  		(*ErrorDetail_IntegerOverflow)(nil),
  1922  		(*ErrorDetail_UnsupportedRequest)(nil),
  1923  		(*ErrorDetail_TimestampBefore)(nil),
  1924  		(*ErrorDetail_TxnAlreadyEncounteredError)(nil),
  1925  		(*ErrorDetail_IntentMissing)(nil),
  1926  		(*ErrorDetail_MergeInProgress)(nil),
  1927  		(*ErrorDetail_RangefeedRetry)(nil),
  1928  		(*ErrorDetail_IndeterminateCommit)(nil),
  1929  	}
  1930  }
  1931  
  1932  func _ErrorDetail_OneofMarshaler(msg proto.Message, b *proto.Buffer) error {
  1933  	m := msg.(*ErrorDetail)
  1934  	// value
  1935  	switch x := m.Value.(type) {
  1936  	case *ErrorDetail_NotLeaseHolder:
  1937  		_ = b.EncodeVarint(1<<3 | proto.WireBytes)
  1938  		if err := b.EncodeMessage(x.NotLeaseHolder); err != nil {
  1939  			return err
  1940  		}
  1941  	case *ErrorDetail_RangeNotFound:
  1942  		_ = b.EncodeVarint(2<<3 | proto.WireBytes)
  1943  		if err := b.EncodeMessage(x.RangeNotFound); err != nil {
  1944  			return err
  1945  		}
  1946  	case *ErrorDetail_RangeKeyMismatch:
  1947  		_ = b.EncodeVarint(3<<3 | proto.WireBytes)
  1948  		if err := b.EncodeMessage(x.RangeKeyMismatch); err != nil {
  1949  			return err
  1950  		}
  1951  	case *ErrorDetail_ReadWithinUncertaintyInterval:
  1952  		_ = b.EncodeVarint(4<<3 | proto.WireBytes)
  1953  		if err := b.EncodeMessage(x.ReadWithinUncertaintyInterval); err != nil {
  1954  			return err
  1955  		}
  1956  	case *ErrorDetail_TransactionAborted:
  1957  		_ = b.EncodeVarint(5<<3 | proto.WireBytes)
  1958  		if err := b.EncodeMessage(x.TransactionAborted); err != nil {
  1959  			return err
  1960  		}
  1961  	case *ErrorDetail_TransactionPush:
  1962  		_ = b.EncodeVarint(6<<3 | proto.WireBytes)
  1963  		if err := b.EncodeMessage(x.TransactionPush); err != nil {
  1964  			return err
  1965  		}
  1966  	case *ErrorDetail_TransactionRetry:
  1967  		_ = b.EncodeVarint(7<<3 | proto.WireBytes)
  1968  		if err := b.EncodeMessage(x.TransactionRetry); err != nil {
  1969  			return err
  1970  		}
  1971  	case *ErrorDetail_TransactionStatus:
  1972  		_ = b.EncodeVarint(8<<3 | proto.WireBytes)
  1973  		if err := b.EncodeMessage(x.TransactionStatus); err != nil {
  1974  			return err
  1975  		}
  1976  	case *ErrorDetail_WriteIntent:
  1977  		_ = b.EncodeVarint(9<<3 | proto.WireBytes)
  1978  		if err := b.EncodeMessage(x.WriteIntent); err != nil {
  1979  			return err
  1980  		}
  1981  	case *ErrorDetail_WriteTooOld:
  1982  		_ = b.EncodeVarint(10<<3 | proto.WireBytes)
  1983  		if err := b.EncodeMessage(x.WriteTooOld); err != nil {
  1984  			return err
  1985  		}
  1986  	case *ErrorDetail_OpRequiresTxn:
  1987  		_ = b.EncodeVarint(11<<3 | proto.WireBytes)
  1988  		if err := b.EncodeMessage(x.OpRequiresTxn); err != nil {
  1989  			return err
  1990  		}
  1991  	case *ErrorDetail_ConditionFailed:
  1992  		_ = b.EncodeVarint(12<<3 | proto.WireBytes)
  1993  		if err := b.EncodeMessage(x.ConditionFailed); err != nil {
  1994  			return err
  1995  		}
  1996  	case *ErrorDetail_LeaseRejected:
  1997  		_ = b.EncodeVarint(13<<3 | proto.WireBytes)
  1998  		if err := b.EncodeMessage(x.LeaseRejected); err != nil {
  1999  			return err
  2000  		}
  2001  	case *ErrorDetail_NodeUnavailable:
  2002  		_ = b.EncodeVarint(14<<3 | proto.WireBytes)
  2003  		if err := b.EncodeMessage(x.NodeUnavailable); err != nil {
  2004  			return err
  2005  		}
  2006  	case *ErrorDetail_Send:
  2007  		_ = b.EncodeVarint(15<<3 | proto.WireBytes)
  2008  		if err := b.EncodeMessage(x.Send); err != nil {
  2009  			return err
  2010  		}
  2011  	case *ErrorDetail_RaftGroupDeleted:
  2012  		_ = b.EncodeVarint(16<<3 | proto.WireBytes)
  2013  		if err := b.EncodeMessage(x.RaftGroupDeleted); err != nil {
  2014  			return err
  2015  		}
  2016  	case *ErrorDetail_ReplicaCorruption:
  2017  		_ = b.EncodeVarint(17<<3 | proto.WireBytes)
  2018  		if err := b.EncodeMessage(x.ReplicaCorruption); err != nil {
  2019  			return err
  2020  		}
  2021  	case *ErrorDetail_ReplicaTooOld:
  2022  		_ = b.EncodeVarint(18<<3 | proto.WireBytes)
  2023  		if err := b.EncodeMessage(x.ReplicaTooOld); err != nil {
  2024  			return err
  2025  		}
  2026  	case *ErrorDetail_AmbiguousResult:
  2027  		_ = b.EncodeVarint(26<<3 | proto.WireBytes)
  2028  		if err := b.EncodeMessage(x.AmbiguousResult); err != nil {
  2029  			return err
  2030  		}
  2031  	case *ErrorDetail_StoreNotFound:
  2032  		_ = b.EncodeVarint(27<<3 | proto.WireBytes)
  2033  		if err := b.EncodeMessage(x.StoreNotFound); err != nil {
  2034  			return err
  2035  		}
  2036  	case *ErrorDetail_TransactionRetryWithProtoRefresh:
  2037  		_ = b.EncodeVarint(28<<3 | proto.WireBytes)
  2038  		if err := b.EncodeMessage(x.TransactionRetryWithProtoRefresh); err != nil {
  2039  			return err
  2040  		}
  2041  	case *ErrorDetail_IntegerOverflow:
  2042  		_ = b.EncodeVarint(31<<3 | proto.WireBytes)
  2043  		if err := b.EncodeMessage(x.IntegerOverflow); err != nil {
  2044  			return err
  2045  		}
  2046  	case *ErrorDetail_UnsupportedRequest:
  2047  		_ = b.EncodeVarint(32<<3 | proto.WireBytes)
  2048  		if err := b.EncodeMessage(x.UnsupportedRequest); err != nil {
  2049  			return err
  2050  		}
  2051  	case *ErrorDetail_TimestampBefore:
  2052  		_ = b.EncodeVarint(34<<3 | proto.WireBytes)
  2053  		if err := b.EncodeMessage(x.TimestampBefore); err != nil {
  2054  			return err
  2055  		}
  2056  	case *ErrorDetail_TxnAlreadyEncounteredError:
  2057  		_ = b.EncodeVarint(35<<3 | proto.WireBytes)
  2058  		if err := b.EncodeMessage(x.TxnAlreadyEncounteredError); err != nil {
  2059  			return err
  2060  		}
  2061  	case *ErrorDetail_IntentMissing:
  2062  		_ = b.EncodeVarint(36<<3 | proto.WireBytes)
  2063  		if err := b.EncodeMessage(x.IntentMissing); err != nil {
  2064  			return err
  2065  		}
  2066  	case *ErrorDetail_MergeInProgress:
  2067  		_ = b.EncodeVarint(37<<3 | proto.WireBytes)
  2068  		if err := b.EncodeMessage(x.MergeInProgress); err != nil {
  2069  			return err
  2070  		}
  2071  	case *ErrorDetail_RangefeedRetry:
  2072  		_ = b.EncodeVarint(38<<3 | proto.WireBytes)
  2073  		if err := b.EncodeMessage(x.RangefeedRetry); err != nil {
  2074  			return err
  2075  		}
  2076  	case *ErrorDetail_IndeterminateCommit:
  2077  		_ = b.EncodeVarint(39<<3 | proto.WireBytes)
  2078  		if err := b.EncodeMessage(x.IndeterminateCommit); err != nil {
  2079  			return err
  2080  		}
  2081  	case nil:
  2082  	default:
  2083  		return fmt.Errorf("ErrorDetail.Value has unexpected type %T", x)
  2084  	}
  2085  	return nil
  2086  }
  2087  
  2088  func _ErrorDetail_OneofUnmarshaler(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error) {
  2089  	m := msg.(*ErrorDetail)
  2090  	switch tag {
  2091  	case 1: // value.not_lease_holder
  2092  		if wire != proto.WireBytes {
  2093  			return true, proto.ErrInternalBadWireType
  2094  		}
  2095  		msg := new(NotLeaseHolderError)
  2096  		err := b.DecodeMessage(msg)
  2097  		m.Value = &ErrorDetail_NotLeaseHolder{msg}
  2098  		return true, err
  2099  	case 2: // value.range_not_found
  2100  		if wire != proto.WireBytes {
  2101  			return true, proto.ErrInternalBadWireType
  2102  		}
  2103  		msg := new(RangeNotFoundError)
  2104  		err := b.DecodeMessage(msg)
  2105  		m.Value = &ErrorDetail_RangeNotFound{msg}
  2106  		return true, err
  2107  	case 3: // value.range_key_mismatch
  2108  		if wire != proto.WireBytes {
  2109  			return true, proto.ErrInternalBadWireType
  2110  		}
  2111  		msg := new(RangeKeyMismatchError)
  2112  		err := b.DecodeMessage(msg)
  2113  		m.Value = &ErrorDetail_RangeKeyMismatch{msg}
  2114  		return true, err
  2115  	case 4: // value.read_within_uncertainty_interval
  2116  		if wire != proto.WireBytes {
  2117  			return true, proto.ErrInternalBadWireType
  2118  		}
  2119  		msg := new(ReadWithinUncertaintyIntervalError)
  2120  		err := b.DecodeMessage(msg)
  2121  		m.Value = &ErrorDetail_ReadWithinUncertaintyInterval{msg}
  2122  		return true, err
  2123  	case 5: // value.transaction_aborted
  2124  		if wire != proto.WireBytes {
  2125  			return true, proto.ErrInternalBadWireType
  2126  		}
  2127  		msg := new(TransactionAbortedError)
  2128  		err := b.DecodeMessage(msg)
  2129  		m.Value = &ErrorDetail_TransactionAborted{msg}
  2130  		return true, err
  2131  	case 6: // value.transaction_push
  2132  		if wire != proto.WireBytes {
  2133  			return true, proto.ErrInternalBadWireType
  2134  		}
  2135  		msg := new(TransactionPushError)
  2136  		err := b.DecodeMessage(msg)
  2137  		m.Value = &ErrorDetail_TransactionPush{msg}
  2138  		return true, err
  2139  	case 7: // value.transaction_retry
  2140  		if wire != proto.WireBytes {
  2141  			return true, proto.ErrInternalBadWireType
  2142  		}
  2143  		msg := new(TransactionRetryError)
  2144  		err := b.DecodeMessage(msg)
  2145  		m.Value = &ErrorDetail_TransactionRetry{msg}
  2146  		return true, err
  2147  	case 8: // value.transaction_status
  2148  		if wire != proto.WireBytes {
  2149  			return true, proto.ErrInternalBadWireType
  2150  		}
  2151  		msg := new(TransactionStatusError)
  2152  		err := b.DecodeMessage(msg)
  2153  		m.Value = &ErrorDetail_TransactionStatus{msg}
  2154  		return true, err
  2155  	case 9: // value.write_intent
  2156  		if wire != proto.WireBytes {
  2157  			return true, proto.ErrInternalBadWireType
  2158  		}
  2159  		msg := new(WriteIntentError)
  2160  		err := b.DecodeMessage(msg)
  2161  		m.Value = &ErrorDetail_WriteIntent{msg}
  2162  		return true, err
  2163  	case 10: // value.write_too_old
  2164  		if wire != proto.WireBytes {
  2165  			return true, proto.ErrInternalBadWireType
  2166  		}
  2167  		msg := new(WriteTooOldError)
  2168  		err := b.DecodeMessage(msg)
  2169  		m.Value = &ErrorDetail_WriteTooOld{msg}
  2170  		return true, err
  2171  	case 11: // value.op_requires_txn
  2172  		if wire != proto.WireBytes {
  2173  			return true, proto.ErrInternalBadWireType
  2174  		}
  2175  		msg := new(OpRequiresTxnError)
  2176  		err := b.DecodeMessage(msg)
  2177  		m.Value = &ErrorDetail_OpRequiresTxn{msg}
  2178  		return true, err
  2179  	case 12: // value.condition_failed
  2180  		if wire != proto.WireBytes {
  2181  			return true, proto.ErrInternalBadWireType
  2182  		}
  2183  		msg := new(ConditionFailedError)
  2184  		err := b.DecodeMessage(msg)
  2185  		m.Value = &ErrorDetail_ConditionFailed{msg}
  2186  		return true, err
  2187  	case 13: // value.lease_rejected
  2188  		if wire != proto.WireBytes {
  2189  			return true, proto.ErrInternalBadWireType
  2190  		}
  2191  		msg := new(LeaseRejectedError)
  2192  		err := b.DecodeMessage(msg)
  2193  		m.Value = &ErrorDetail_LeaseRejected{msg}
  2194  		return true, err
  2195  	case 14: // value.node_unavailable
  2196  		if wire != proto.WireBytes {
  2197  			return true, proto.ErrInternalBadWireType
  2198  		}
  2199  		msg := new(NodeUnavailableError)
  2200  		err := b.DecodeMessage(msg)
  2201  		m.Value = &ErrorDetail_NodeUnavailable{msg}
  2202  		return true, err
  2203  	case 15: // value.send
  2204  		if wire != proto.WireBytes {
  2205  			return true, proto.ErrInternalBadWireType
  2206  		}
  2207  		msg := new(SendError)
  2208  		err := b.DecodeMessage(msg)
  2209  		m.Value = &ErrorDetail_Send{msg}
  2210  		return true, err
  2211  	case 16: // value.raft_group_deleted
  2212  		if wire != proto.WireBytes {
  2213  			return true, proto.ErrInternalBadWireType
  2214  		}
  2215  		msg := new(RaftGroupDeletedError)
  2216  		err := b.DecodeMessage(msg)
  2217  		m.Value = &ErrorDetail_RaftGroupDeleted{msg}
  2218  		return true, err
  2219  	case 17: // value.replica_corruption
  2220  		if wire != proto.WireBytes {
  2221  			return true, proto.ErrInternalBadWireType
  2222  		}
  2223  		msg := new(ReplicaCorruptionError)
  2224  		err := b.DecodeMessage(msg)
  2225  		m.Value = &ErrorDetail_ReplicaCorruption{msg}
  2226  		return true, err
  2227  	case 18: // value.replica_too_old
  2228  		if wire != proto.WireBytes {
  2229  			return true, proto.ErrInternalBadWireType
  2230  		}
  2231  		msg := new(ReplicaTooOldError)
  2232  		err := b.DecodeMessage(msg)
  2233  		m.Value = &ErrorDetail_ReplicaTooOld{msg}
  2234  		return true, err
  2235  	case 26: // value.ambiguous_result
  2236  		if wire != proto.WireBytes {
  2237  			return true, proto.ErrInternalBadWireType
  2238  		}
  2239  		msg := new(AmbiguousResultError)
  2240  		err := b.DecodeMessage(msg)
  2241  		m.Value = &ErrorDetail_AmbiguousResult{msg}
  2242  		return true, err
  2243  	case 27: // value.store_not_found
  2244  		if wire != proto.WireBytes {
  2245  			return true, proto.ErrInternalBadWireType
  2246  		}
  2247  		msg := new(StoreNotFoundError)
  2248  		err := b.DecodeMessage(msg)
  2249  		m.Value = &ErrorDetail_StoreNotFound{msg}
  2250  		return true, err
  2251  	case 28: // value.transaction_retry_with_proto_refresh
  2252  		if wire != proto.WireBytes {
  2253  			return true, proto.ErrInternalBadWireType
  2254  		}
  2255  		msg := new(TransactionRetryWithProtoRefreshError)
  2256  		err := b.DecodeMessage(msg)
  2257  		m.Value = &ErrorDetail_TransactionRetryWithProtoRefresh{msg}
  2258  		return true, err
  2259  	case 31: // value.integer_overflow
  2260  		if wire != proto.WireBytes {
  2261  			return true, proto.ErrInternalBadWireType
  2262  		}
  2263  		msg := new(IntegerOverflowError)
  2264  		err := b.DecodeMessage(msg)
  2265  		m.Value = &ErrorDetail_IntegerOverflow{msg}
  2266  		return true, err
  2267  	case 32: // value.unsupported_request
  2268  		if wire != proto.WireBytes {
  2269  			return true, proto.ErrInternalBadWireType
  2270  		}
  2271  		msg := new(UnsupportedRequestError)
  2272  		err := b.DecodeMessage(msg)
  2273  		m.Value = &ErrorDetail_UnsupportedRequest{msg}
  2274  		return true, err
  2275  	case 34: // value.timestamp_before
  2276  		if wire != proto.WireBytes {
  2277  			return true, proto.ErrInternalBadWireType
  2278  		}
  2279  		msg := new(BatchTimestampBeforeGCError)
  2280  		err := b.DecodeMessage(msg)
  2281  		m.Value = &ErrorDetail_TimestampBefore{msg}
  2282  		return true, err
  2283  	case 35: // value.txn_already_encountered_error
  2284  		if wire != proto.WireBytes {
  2285  			return true, proto.ErrInternalBadWireType
  2286  		}
  2287  		msg := new(TxnAlreadyEncounteredErrorError)
  2288  		err := b.DecodeMessage(msg)
  2289  		m.Value = &ErrorDetail_TxnAlreadyEncounteredError{msg}
  2290  		return true, err
  2291  	case 36: // value.intent_missing
  2292  		if wire != proto.WireBytes {
  2293  			return true, proto.ErrInternalBadWireType
  2294  		}
  2295  		msg := new(IntentMissingError)
  2296  		err := b.DecodeMessage(msg)
  2297  		m.Value = &ErrorDetail_IntentMissing{msg}
  2298  		return true, err
  2299  	case 37: // value.merge_in_progress
  2300  		if wire != proto.WireBytes {
  2301  			return true, proto.ErrInternalBadWireType
  2302  		}
  2303  		msg := new(MergeInProgressError)
  2304  		err := b.DecodeMessage(msg)
  2305  		m.Value = &ErrorDetail_MergeInProgress{msg}
  2306  		return true, err
  2307  	case 38: // value.rangefeed_retry
  2308  		if wire != proto.WireBytes {
  2309  			return true, proto.ErrInternalBadWireType
  2310  		}
  2311  		msg := new(RangeFeedRetryError)
  2312  		err := b.DecodeMessage(msg)
  2313  		m.Value = &ErrorDetail_RangefeedRetry{msg}
  2314  		return true, err
  2315  	case 39: // value.indeterminate_commit
  2316  		if wire != proto.WireBytes {
  2317  			return true, proto.ErrInternalBadWireType
  2318  		}
  2319  		msg := new(IndeterminateCommitError)
  2320  		err := b.DecodeMessage(msg)
  2321  		m.Value = &ErrorDetail_IndeterminateCommit{msg}
  2322  		return true, err
  2323  	default:
  2324  		return false, nil
  2325  	}
  2326  }
  2327  
  2328  func _ErrorDetail_OneofSizer(msg proto.Message) (n int) {
  2329  	m := msg.(*ErrorDetail)
  2330  	// value
  2331  	switch x := m.Value.(type) {
  2332  	case *ErrorDetail_NotLeaseHolder:
  2333  		s := proto.Size(x.NotLeaseHolder)
  2334  		n += 1 // tag and wire
  2335  		n += proto.SizeVarint(uint64(s))
  2336  		n += s
  2337  	case *ErrorDetail_RangeNotFound:
  2338  		s := proto.Size(x.RangeNotFound)
  2339  		n += 1 // tag and wire
  2340  		n += proto.SizeVarint(uint64(s))
  2341  		n += s
  2342  	case *ErrorDetail_RangeKeyMismatch:
  2343  		s := proto.Size(x.RangeKeyMismatch)
  2344  		n += 1 // tag and wire
  2345  		n += proto.SizeVarint(uint64(s))
  2346  		n += s
  2347  	case *ErrorDetail_ReadWithinUncertaintyInterval:
  2348  		s := proto.Size(x.ReadWithinUncertaintyInterval)
  2349  		n += 1 // tag and wire
  2350  		n += proto.SizeVarint(uint64(s))
  2351  		n += s
  2352  	case *ErrorDetail_TransactionAborted:
  2353  		s := proto.Size(x.TransactionAborted)
  2354  		n += 1 // tag and wire
  2355  		n += proto.SizeVarint(uint64(s))
  2356  		n += s
  2357  	case *ErrorDetail_TransactionPush:
  2358  		s := proto.Size(x.TransactionPush)
  2359  		n += 1 // tag and wire
  2360  		n += proto.SizeVarint(uint64(s))
  2361  		n += s
  2362  	case *ErrorDetail_TransactionRetry:
  2363  		s := proto.Size(x.TransactionRetry)
  2364  		n += 1 // tag and wire
  2365  		n += proto.SizeVarint(uint64(s))
  2366  		n += s
  2367  	case *ErrorDetail_TransactionStatus:
  2368  		s := proto.Size(x.TransactionStatus)
  2369  		n += 1 // tag and wire
  2370  		n += proto.SizeVarint(uint64(s))
  2371  		n += s
  2372  	case *ErrorDetail_WriteIntent:
  2373  		s := proto.Size(x.WriteIntent)
  2374  		n += 1 // tag and wire
  2375  		n += proto.SizeVarint(uint64(s))
  2376  		n += s
  2377  	case *ErrorDetail_WriteTooOld:
  2378  		s := proto.Size(x.WriteTooOld)
  2379  		n += 1 // tag and wire
  2380  		n += proto.SizeVarint(uint64(s))
  2381  		n += s
  2382  	case *ErrorDetail_OpRequiresTxn:
  2383  		s := proto.Size(x.OpRequiresTxn)
  2384  		n += 1 // tag and wire
  2385  		n += proto.SizeVarint(uint64(s))
  2386  		n += s
  2387  	case *ErrorDetail_ConditionFailed:
  2388  		s := proto.Size(x.ConditionFailed)
  2389  		n += 1 // tag and wire
  2390  		n += proto.SizeVarint(uint64(s))
  2391  		n += s
  2392  	case *ErrorDetail_LeaseRejected:
  2393  		s := proto.Size(x.LeaseRejected)
  2394  		n += 1 // tag and wire
  2395  		n += proto.SizeVarint(uint64(s))
  2396  		n += s
  2397  	case *ErrorDetail_NodeUnavailable:
  2398  		s := proto.Size(x.NodeUnavailable)
  2399  		n += 1 // tag and wire
  2400  		n += proto.SizeVarint(uint64(s))
  2401  		n += s
  2402  	case *ErrorDetail_Send:
  2403  		s := proto.Size(x.Send)
  2404  		n += 1 // tag and wire
  2405  		n += proto.SizeVarint(uint64(s))
  2406  		n += s
  2407  	case *ErrorDetail_RaftGroupDeleted:
  2408  		s := proto.Size(x.RaftGroupDeleted)
  2409  		n += 2 // tag and wire
  2410  		n += proto.SizeVarint(uint64(s))
  2411  		n += s
  2412  	case *ErrorDetail_ReplicaCorruption:
  2413  		s := proto.Size(x.ReplicaCorruption)
  2414  		n += 2 // tag and wire
  2415  		n += proto.SizeVarint(uint64(s))
  2416  		n += s
  2417  	case *ErrorDetail_ReplicaTooOld:
  2418  		s := proto.Size(x.ReplicaTooOld)
  2419  		n += 2 // tag and wire
  2420  		n += proto.SizeVarint(uint64(s))
  2421  		n += s
  2422  	case *ErrorDetail_AmbiguousResult:
  2423  		s := proto.Size(x.AmbiguousResult)
  2424  		n += 2 // tag and wire
  2425  		n += proto.SizeVarint(uint64(s))
  2426  		n += s
  2427  	case *ErrorDetail_StoreNotFound:
  2428  		s := proto.Size(x.StoreNotFound)
  2429  		n += 2 // tag and wire
  2430  		n += proto.SizeVarint(uint64(s))
  2431  		n += s
  2432  	case *ErrorDetail_TransactionRetryWithProtoRefresh:
  2433  		s := proto.Size(x.TransactionRetryWithProtoRefresh)
  2434  		n += 2 // tag and wire
  2435  		n += proto.SizeVarint(uint64(s))
  2436  		n += s
  2437  	case *ErrorDetail_IntegerOverflow:
  2438  		s := proto.Size(x.IntegerOverflow)
  2439  		n += 2 // tag and wire
  2440  		n += proto.SizeVarint(uint64(s))
  2441  		n += s
  2442  	case *ErrorDetail_UnsupportedRequest:
  2443  		s := proto.Size(x.UnsupportedRequest)
  2444  		n += 2 // tag and wire
  2445  		n += proto.SizeVarint(uint64(s))
  2446  		n += s
  2447  	case *ErrorDetail_TimestampBefore:
  2448  		s := proto.Size(x.TimestampBefore)
  2449  		n += 2 // tag and wire
  2450  		n += proto.SizeVarint(uint64(s))
  2451  		n += s
  2452  	case *ErrorDetail_TxnAlreadyEncounteredError:
  2453  		s := proto.Size(x.TxnAlreadyEncounteredError)
  2454  		n += 2 // tag and wire
  2455  		n += proto.SizeVarint(uint64(s))
  2456  		n += s
  2457  	case *ErrorDetail_IntentMissing:
  2458  		s := proto.Size(x.IntentMissing)
  2459  		n += 2 // tag and wire
  2460  		n += proto.SizeVarint(uint64(s))
  2461  		n += s
  2462  	case *ErrorDetail_MergeInProgress:
  2463  		s := proto.Size(x.MergeInProgress)
  2464  		n += 2 // tag and wire
  2465  		n += proto.SizeVarint(uint64(s))
  2466  		n += s
  2467  	case *ErrorDetail_RangefeedRetry:
  2468  		s := proto.Size(x.RangefeedRetry)
  2469  		n += 2 // tag and wire
  2470  		n += proto.SizeVarint(uint64(s))
  2471  		n += s
  2472  	case *ErrorDetail_IndeterminateCommit:
  2473  		s := proto.Size(x.IndeterminateCommit)
  2474  		n += 2 // tag and wire
  2475  		n += proto.SizeVarint(uint64(s))
  2476  		n += s
  2477  	case nil:
  2478  	default:
  2479  		panic(fmt.Sprintf("proto: unexpected type %T in oneof", x))
  2480  	}
  2481  	return n
  2482  }
  2483  
  2484  // ErrPosition describes the position of an error in a Batch. A simple nullable
  2485  // primitive field would break compatibility with proto3, where primitive fields
  2486  // are no longer allowed to be nullable.
  2487  type ErrPosition struct {
  2488  	Index int32 `protobuf:"varint,1,opt,name=index" json:"index"`
  2489  }
  2490  
  2491  func (m *ErrPosition) Reset()         { *m = ErrPosition{} }
  2492  func (m *ErrPosition) String() string { return proto.CompactTextString(m) }
  2493  func (*ErrPosition) ProtoMessage()    {}
  2494  func (*ErrPosition) Descriptor() ([]byte, []int) {
  2495  	return fileDescriptor_errors_4401e49350ed5ee8, []int{31}
  2496  }
  2497  func (m *ErrPosition) XXX_Unmarshal(b []byte) error {
  2498  	return m.Unmarshal(b)
  2499  }
  2500  func (m *ErrPosition) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  2501  	b = b[:cap(b)]
  2502  	n, err := m.MarshalTo(b)
  2503  	if err != nil {
  2504  		return nil, err
  2505  	}
  2506  	return b[:n], nil
  2507  }
  2508  func (dst *ErrPosition) XXX_Merge(src proto.Message) {
  2509  	xxx_messageInfo_ErrPosition.Merge(dst, src)
  2510  }
  2511  func (m *ErrPosition) XXX_Size() int {
  2512  	return m.Size()
  2513  }
  2514  func (m *ErrPosition) XXX_DiscardUnknown() {
  2515  	xxx_messageInfo_ErrPosition.DiscardUnknown(m)
  2516  }
  2517  
  2518  var xxx_messageInfo_ErrPosition proto.InternalMessageInfo
  2519  
  2520  // Error is a generic representation including a string message
  2521  // and information about retryability.
  2522  type Error struct {
  2523  	// message is a human-readable error message.
  2524  	Message string `protobuf:"bytes,1,opt,name=message" json:"message"`
  2525  	// If transaction_restart is not ABORT, the error condition may be handled by
  2526  	// restarting the transaction.
  2527  	TransactionRestart TransactionRestart `protobuf:"varint,3,opt,name=transaction_restart,json=transactionRestart,enum=cockroach.roachpb.TransactionRestart" json:"transaction_restart"`
  2528  	// An optional updated transaction. This is to be used by the client in case
  2529  	// of retryable errors.
  2530  	//
  2531  	// Not to be accessed directly - use Error.GetTxn().
  2532  	UnexposedTxn *Transaction `protobuf:"bytes,4,opt,name=unexposed_txn,json=unexposedTxn" json:"unexposed_txn,omitempty"`
  2533  	// Node at which the error was generated (zero if does not apply).
  2534  	OriginNode NodeID `protobuf:"varint,5,opt,name=origin_node,json=originNode,casttype=NodeID" json:"origin_node"`
  2535  	// If an ErrorDetail is present, it may contain additional structured data
  2536  	// about the error.
  2537  	Detail ErrorDetail `protobuf:"bytes,6,opt,name=detail" json:"detail"`
  2538  	// The index, if given, contains the index of the request (in the batch)
  2539  	// whose execution caused the error.
  2540  	Index *ErrPosition `protobuf:"bytes,7,opt,name=index" json:"index,omitempty"`
  2541  	// now is the current time at the node sending the response,
  2542  	// which can be used by the receiver to update its local HLC.
  2543  	Now hlc.Timestamp `protobuf:"bytes,8,opt,name=now" json:"now"`
  2544  }
  2545  
  2546  func (m *Error) Reset()      { *m = Error{} }
  2547  func (*Error) ProtoMessage() {}
  2548  func (*Error) Descriptor() ([]byte, []int) {
  2549  	return fileDescriptor_errors_4401e49350ed5ee8, []int{32}
  2550  }
  2551  func (m *Error) XXX_Unmarshal(b []byte) error {
  2552  	return m.Unmarshal(b)
  2553  }
  2554  func (m *Error) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  2555  	b = b[:cap(b)]
  2556  	n, err := m.MarshalTo(b)
  2557  	if err != nil {
  2558  		return nil, err
  2559  	}
  2560  	return b[:n], nil
  2561  }
  2562  func (dst *Error) XXX_Merge(src proto.Message) {
  2563  	xxx_messageInfo_Error.Merge(dst, src)
  2564  }
  2565  func (m *Error) XXX_Size() int {
  2566  	return m.Size()
  2567  }
  2568  func (m *Error) XXX_DiscardUnknown() {
  2569  	xxx_messageInfo_Error.DiscardUnknown(m)
  2570  }
  2571  
  2572  var xxx_messageInfo_Error proto.InternalMessageInfo
  2573  
  2574  func init() {
  2575  	proto.RegisterType((*NotLeaseHolderError)(nil), "cockroach.roachpb.NotLeaseHolderError")
  2576  	proto.RegisterType((*NodeUnavailableError)(nil), "cockroach.roachpb.NodeUnavailableError")
  2577  	proto.RegisterType((*UnsupportedRequestError)(nil), "cockroach.roachpb.UnsupportedRequestError")
  2578  	proto.RegisterType((*RangeNotFoundError)(nil), "cockroach.roachpb.RangeNotFoundError")
  2579  	proto.RegisterType((*RangeKeyMismatchError)(nil), "cockroach.roachpb.RangeKeyMismatchError")
  2580  	proto.RegisterType((*ReadWithinUncertaintyIntervalError)(nil), "cockroach.roachpb.ReadWithinUncertaintyIntervalError")
  2581  	proto.RegisterType((*TransactionAbortedError)(nil), "cockroach.roachpb.TransactionAbortedError")
  2582  	proto.RegisterType((*TransactionPushError)(nil), "cockroach.roachpb.TransactionPushError")
  2583  	proto.RegisterType((*TransactionRetryError)(nil), "cockroach.roachpb.TransactionRetryError")
  2584  	proto.RegisterType((*TransactionStatusError)(nil), "cockroach.roachpb.TransactionStatusError")
  2585  	proto.RegisterType((*WriteIntentError)(nil), "cockroach.roachpb.WriteIntentError")
  2586  	proto.RegisterType((*WriteTooOldError)(nil), "cockroach.roachpb.WriteTooOldError")
  2587  	proto.RegisterType((*OpRequiresTxnError)(nil), "cockroach.roachpb.OpRequiresTxnError")
  2588  	proto.RegisterType((*ConditionFailedError)(nil), "cockroach.roachpb.ConditionFailedError")
  2589  	proto.RegisterType((*LeaseRejectedError)(nil), "cockroach.roachpb.LeaseRejectedError")
  2590  	proto.RegisterType((*SendError)(nil), "cockroach.roachpb.SendError")
  2591  	proto.RegisterType((*AmbiguousResultError)(nil), "cockroach.roachpb.AmbiguousResultError")
  2592  	proto.RegisterType((*RaftGroupDeletedError)(nil), "cockroach.roachpb.RaftGroupDeletedError")
  2593  	proto.RegisterType((*ReplicaCorruptionError)(nil), "cockroach.roachpb.ReplicaCorruptionError")
  2594  	proto.RegisterType((*ReplicaTooOldError)(nil), "cockroach.roachpb.ReplicaTooOldError")
  2595  	proto.RegisterType((*StoreNotFoundError)(nil), "cockroach.roachpb.StoreNotFoundError")
  2596  	proto.RegisterType((*UnhandledRetryableError)(nil), "cockroach.roachpb.UnhandledRetryableError")
  2597  	proto.RegisterType((*TransactionRetryWithProtoRefreshError)(nil), "cockroach.roachpb.TransactionRetryWithProtoRefreshError")
  2598  	proto.RegisterType((*TxnAlreadyEncounteredErrorError)(nil), "cockroach.roachpb.TxnAlreadyEncounteredErrorError")
  2599  	proto.RegisterType((*IntegerOverflowError)(nil), "cockroach.roachpb.IntegerOverflowError")
  2600  	proto.RegisterType((*BatchTimestampBeforeGCError)(nil), "cockroach.roachpb.BatchTimestampBeforeGCError")
  2601  	proto.RegisterType((*IntentMissingError)(nil), "cockroach.roachpb.IntentMissingError")
  2602  	proto.RegisterType((*MergeInProgressError)(nil), "cockroach.roachpb.MergeInProgressError")
  2603  	proto.RegisterType((*RangeFeedRetryError)(nil), "cockroach.roachpb.RangeFeedRetryError")
  2604  	proto.RegisterType((*IndeterminateCommitError)(nil), "cockroach.roachpb.IndeterminateCommitError")
  2605  	proto.RegisterType((*ErrorDetail)(nil), "cockroach.roachpb.ErrorDetail")
  2606  	proto.RegisterType((*ErrPosition)(nil), "cockroach.roachpb.ErrPosition")
  2607  	proto.RegisterType((*Error)(nil), "cockroach.roachpb.Error")
  2608  	proto.RegisterEnum("cockroach.roachpb.TransactionAbortedReason", TransactionAbortedReason_name, TransactionAbortedReason_value)
  2609  	proto.RegisterEnum("cockroach.roachpb.TransactionRetryReason", TransactionRetryReason_name, TransactionRetryReason_value)
  2610  	proto.RegisterEnum("cockroach.roachpb.TransactionRestart", TransactionRestart_name, TransactionRestart_value)
  2611  	proto.RegisterEnum("cockroach.roachpb.TransactionStatusError_Reason", TransactionStatusError_Reason_name, TransactionStatusError_Reason_value)
  2612  	proto.RegisterEnum("cockroach.roachpb.RangeFeedRetryError_Reason", RangeFeedRetryError_Reason_name, RangeFeedRetryError_Reason_value)
  2613  }
  2614  func (this *NotLeaseHolderError) Equal(that interface{}) bool {
  2615  	if that == nil {
  2616  		return this == nil
  2617  	}
  2618  
  2619  	that1, ok := that.(*NotLeaseHolderError)
  2620  	if !ok {
  2621  		that2, ok := that.(NotLeaseHolderError)
  2622  		if ok {
  2623  			that1 = &that2
  2624  		} else {
  2625  			return false
  2626  		}
  2627  	}
  2628  	if that1 == nil {
  2629  		return this == nil
  2630  	} else if this == nil {
  2631  		return false
  2632  	}
  2633  	if !this.Replica.Equal(&that1.Replica) {
  2634  		return false
  2635  	}
  2636  	if !this.LeaseHolder.Equal(that1.LeaseHolder) {
  2637  		return false
  2638  	}
  2639  	if !this.Lease.Equal(that1.Lease) {
  2640  		return false
  2641  	}
  2642  	if this.RangeID != that1.RangeID {
  2643  		return false
  2644  	}
  2645  	if this.CustomMsg != that1.CustomMsg {
  2646  		return false
  2647  	}
  2648  	return true
  2649  }
  2650  func (this *NodeUnavailableError) Equal(that interface{}) bool {
  2651  	if that == nil {
  2652  		return this == nil
  2653  	}
  2654  
  2655  	that1, ok := that.(*NodeUnavailableError)
  2656  	if !ok {
  2657  		that2, ok := that.(NodeUnavailableError)
  2658  		if ok {
  2659  			that1 = &that2
  2660  		} else {
  2661  			return false
  2662  		}
  2663  	}
  2664  	if that1 == nil {
  2665  		return this == nil
  2666  	} else if this == nil {
  2667  		return false
  2668  	}
  2669  	return true
  2670  }
  2671  func (this *UnsupportedRequestError) Equal(that interface{}) bool {
  2672  	if that == nil {
  2673  		return this == nil
  2674  	}
  2675  
  2676  	that1, ok := that.(*UnsupportedRequestError)
  2677  	if !ok {
  2678  		that2, ok := that.(UnsupportedRequestError)
  2679  		if ok {
  2680  			that1 = &that2
  2681  		} else {
  2682  			return false
  2683  		}
  2684  	}
  2685  	if that1 == nil {
  2686  		return this == nil
  2687  	} else if this == nil {
  2688  		return false
  2689  	}
  2690  	return true
  2691  }
  2692  func (this *RangeNotFoundError) Equal(that interface{}) bool {
  2693  	if that == nil {
  2694  		return this == nil
  2695  	}
  2696  
  2697  	that1, ok := that.(*RangeNotFoundError)
  2698  	if !ok {
  2699  		that2, ok := that.(RangeNotFoundError)
  2700  		if ok {
  2701  			that1 = &that2
  2702  		} else {
  2703  			return false
  2704  		}
  2705  	}
  2706  	if that1 == nil {
  2707  		return this == nil
  2708  	} else if this == nil {
  2709  		return false
  2710  	}
  2711  	if this.RangeID != that1.RangeID {
  2712  		return false
  2713  	}
  2714  	if this.StoreID != that1.StoreID {
  2715  		return false
  2716  	}
  2717  	return true
  2718  }
  2719  func (this *RangeKeyMismatchError) Equal(that interface{}) bool {
  2720  	if that == nil {
  2721  		return this == nil
  2722  	}
  2723  
  2724  	that1, ok := that.(*RangeKeyMismatchError)
  2725  	if !ok {
  2726  		that2, ok := that.(RangeKeyMismatchError)
  2727  		if ok {
  2728  			that1 = &that2
  2729  		} else {
  2730  			return false
  2731  		}
  2732  	}
  2733  	if that1 == nil {
  2734  		return this == nil
  2735  	} else if this == nil {
  2736  		return false
  2737  	}
  2738  	if !bytes.Equal(this.RequestStartKey, that1.RequestStartKey) {
  2739  		return false
  2740  	}
  2741  	if !bytes.Equal(this.RequestEndKey, that1.RequestEndKey) {
  2742  		return false
  2743  	}
  2744  	if !this.MismatchedRange.Equal(&that1.MismatchedRange) {
  2745  		return false
  2746  	}
  2747  	if !this.SuggestedRange.Equal(that1.SuggestedRange) {
  2748  		return false
  2749  	}
  2750  	return true
  2751  }
  2752  func (this *ReadWithinUncertaintyIntervalError) Equal(that interface{}) bool {
  2753  	if that == nil {
  2754  		return this == nil
  2755  	}
  2756  
  2757  	that1, ok := that.(*ReadWithinUncertaintyIntervalError)
  2758  	if !ok {
  2759  		that2, ok := that.(ReadWithinUncertaintyIntervalError)
  2760  		if ok {
  2761  			that1 = &that2
  2762  		} else {
  2763  			return false
  2764  		}
  2765  	}
  2766  	if that1 == nil {
  2767  		return this == nil
  2768  	} else if this == nil {
  2769  		return false
  2770  	}
  2771  	if !this.ReadTimestamp.Equal(&that1.ReadTimestamp) {
  2772  		return false
  2773  	}
  2774  	if !this.ExistingTimestamp.Equal(&that1.ExistingTimestamp) {
  2775  		return false
  2776  	}
  2777  	if !this.MaxTimestamp.Equal(that1.MaxTimestamp) {
  2778  		return false
  2779  	}
  2780  	if len(this.ObservedTimestamps) != len(that1.ObservedTimestamps) {
  2781  		return false
  2782  	}
  2783  	for i := range this.ObservedTimestamps {
  2784  		if !this.ObservedTimestamps[i].Equal(&that1.ObservedTimestamps[i]) {
  2785  			return false
  2786  		}
  2787  	}
  2788  	return true
  2789  }
  2790  func (this *TransactionAbortedError) Equal(that interface{}) bool {
  2791  	if that == nil {
  2792  		return this == nil
  2793  	}
  2794  
  2795  	that1, ok := that.(*TransactionAbortedError)
  2796  	if !ok {
  2797  		that2, ok := that.(TransactionAbortedError)
  2798  		if ok {
  2799  			that1 = &that2
  2800  		} else {
  2801  			return false
  2802  		}
  2803  	}
  2804  	if that1 == nil {
  2805  		return this == nil
  2806  	} else if this == nil {
  2807  		return false
  2808  	}
  2809  	if this.Reason != that1.Reason {
  2810  		return false
  2811  	}
  2812  	return true
  2813  }
  2814  func (this *TransactionPushError) Equal(that interface{}) bool {
  2815  	if that == nil {
  2816  		return this == nil
  2817  	}
  2818  
  2819  	that1, ok := that.(*TransactionPushError)
  2820  	if !ok {
  2821  		that2, ok := that.(TransactionPushError)
  2822  		if ok {
  2823  			that1 = &that2
  2824  		} else {
  2825  			return false
  2826  		}
  2827  	}
  2828  	if that1 == nil {
  2829  		return this == nil
  2830  	} else if this == nil {
  2831  		return false
  2832  	}
  2833  	if !this.PusheeTxn.Equal(&that1.PusheeTxn) {
  2834  		return false
  2835  	}
  2836  	return true
  2837  }
  2838  func (this *TransactionRetryError) Equal(that interface{}) bool {
  2839  	if that == nil {
  2840  		return this == nil
  2841  	}
  2842  
  2843  	that1, ok := that.(*TransactionRetryError)
  2844  	if !ok {
  2845  		that2, ok := that.(TransactionRetryError)
  2846  		if ok {
  2847  			that1 = &that2
  2848  		} else {
  2849  			return false
  2850  		}
  2851  	}
  2852  	if that1 == nil {
  2853  		return this == nil
  2854  	} else if this == nil {
  2855  		return false
  2856  	}
  2857  	if this.Reason != that1.Reason {
  2858  		return false
  2859  	}
  2860  	if this.ExtraMsg != that1.ExtraMsg {
  2861  		return false
  2862  	}
  2863  	return true
  2864  }
  2865  func (this *TransactionStatusError) Equal(that interface{}) bool {
  2866  	if that == nil {
  2867  		return this == nil
  2868  	}
  2869  
  2870  	that1, ok := that.(*TransactionStatusError)
  2871  	if !ok {
  2872  		that2, ok := that.(TransactionStatusError)
  2873  		if ok {
  2874  			that1 = &that2
  2875  		} else {
  2876  			return false
  2877  		}
  2878  	}
  2879  	if that1 == nil {
  2880  		return this == nil
  2881  	} else if this == nil {
  2882  		return false
  2883  	}
  2884  	if this.Msg != that1.Msg {
  2885  		return false
  2886  	}
  2887  	if this.Reason != that1.Reason {
  2888  		return false
  2889  	}
  2890  	return true
  2891  }
  2892  func (this *WriteIntentError) Equal(that interface{}) bool {
  2893  	if that == nil {
  2894  		return this == nil
  2895  	}
  2896  
  2897  	that1, ok := that.(*WriteIntentError)
  2898  	if !ok {
  2899  		that2, ok := that.(WriteIntentError)
  2900  		if ok {
  2901  			that1 = &that2
  2902  		} else {
  2903  			return false
  2904  		}
  2905  	}
  2906  	if that1 == nil {
  2907  		return this == nil
  2908  	} else if this == nil {
  2909  		return false
  2910  	}
  2911  	if len(this.Intents) != len(that1.Intents) {
  2912  		return false
  2913  	}
  2914  	for i := range this.Intents {
  2915  		if !this.Intents[i].Equal(&that1.Intents[i]) {
  2916  			return false
  2917  		}
  2918  	}
  2919  	return true
  2920  }
  2921  func (this *WriteTooOldError) Equal(that interface{}) bool {
  2922  	if that == nil {
  2923  		return this == nil
  2924  	}
  2925  
  2926  	that1, ok := that.(*WriteTooOldError)
  2927  	if !ok {
  2928  		that2, ok := that.(WriteTooOldError)
  2929  		if ok {
  2930  			that1 = &that2
  2931  		} else {
  2932  			return false
  2933  		}
  2934  	}
  2935  	if that1 == nil {
  2936  		return this == nil
  2937  	} else if this == nil {
  2938  		return false
  2939  	}
  2940  	if !this.Timestamp.Equal(&that1.Timestamp) {
  2941  		return false
  2942  	}
  2943  	if !this.ActualTimestamp.Equal(&that1.ActualTimestamp) {
  2944  		return false
  2945  	}
  2946  	return true
  2947  }
  2948  func (this *OpRequiresTxnError) Equal(that interface{}) bool {
  2949  	if that == nil {
  2950  		return this == nil
  2951  	}
  2952  
  2953  	that1, ok := that.(*OpRequiresTxnError)
  2954  	if !ok {
  2955  		that2, ok := that.(OpRequiresTxnError)
  2956  		if ok {
  2957  			that1 = &that2
  2958  		} else {
  2959  			return false
  2960  		}
  2961  	}
  2962  	if that1 == nil {
  2963  		return this == nil
  2964  	} else if this == nil {
  2965  		return false
  2966  	}
  2967  	return true
  2968  }
  2969  func (this *ConditionFailedError) Equal(that interface{}) bool {
  2970  	if that == nil {
  2971  		return this == nil
  2972  	}
  2973  
  2974  	that1, ok := that.(*ConditionFailedError)
  2975  	if !ok {
  2976  		that2, ok := that.(ConditionFailedError)
  2977  		if ok {
  2978  			that1 = &that2
  2979  		} else {
  2980  			return false
  2981  		}
  2982  	}
  2983  	if that1 == nil {
  2984  		return this == nil
  2985  	} else if this == nil {
  2986  		return false
  2987  	}
  2988  	if !this.ActualValue.Equal(that1.ActualValue) {
  2989  		return false
  2990  	}
  2991  	return true
  2992  }
  2993  func (this *LeaseRejectedError) Equal(that interface{}) bool {
  2994  	if that == nil {
  2995  		return this == nil
  2996  	}
  2997  
  2998  	that1, ok := that.(*LeaseRejectedError)
  2999  	if !ok {
  3000  		that2, ok := that.(LeaseRejectedError)
  3001  		if ok {
  3002  			that1 = &that2
  3003  		} else {
  3004  			return false
  3005  		}
  3006  	}
  3007  	if that1 == nil {
  3008  		return this == nil
  3009  	} else if this == nil {
  3010  		return false
  3011  	}
  3012  	if this.Message != that1.Message {
  3013  		return false
  3014  	}
  3015  	if !this.Requested.Equal(&that1.Requested) {
  3016  		return false
  3017  	}
  3018  	if !this.Existing.Equal(&that1.Existing) {
  3019  		return false
  3020  	}
  3021  	return true
  3022  }
  3023  func (this *SendError) Equal(that interface{}) bool {
  3024  	if that == nil {
  3025  		return this == nil
  3026  	}
  3027  
  3028  	that1, ok := that.(*SendError)
  3029  	if !ok {
  3030  		that2, ok := that.(SendError)
  3031  		if ok {
  3032  			that1 = &that2
  3033  		} else {
  3034  			return false
  3035  		}
  3036  	}
  3037  	if that1 == nil {
  3038  		return this == nil
  3039  	} else if this == nil {
  3040  		return false
  3041  	}
  3042  	if this.Message != that1.Message {
  3043  		return false
  3044  	}
  3045  	return true
  3046  }
  3047  func (this *AmbiguousResultError) Equal(that interface{}) bool {
  3048  	if that == nil {
  3049  		return this == nil
  3050  	}
  3051  
  3052  	that1, ok := that.(*AmbiguousResultError)
  3053  	if !ok {
  3054  		that2, ok := that.(AmbiguousResultError)
  3055  		if ok {
  3056  			that1 = &that2
  3057  		} else {
  3058  			return false
  3059  		}
  3060  	}
  3061  	if that1 == nil {
  3062  		return this == nil
  3063  	} else if this == nil {
  3064  		return false
  3065  	}
  3066  	if this.Message != that1.Message {
  3067  		return false
  3068  	}
  3069  	if !this.WrappedErr.Equal(that1.WrappedErr) {
  3070  		return false
  3071  	}
  3072  	return true
  3073  }
  3074  func (this *RaftGroupDeletedError) Equal(that interface{}) bool {
  3075  	if that == nil {
  3076  		return this == nil
  3077  	}
  3078  
  3079  	that1, ok := that.(*RaftGroupDeletedError)
  3080  	if !ok {
  3081  		that2, ok := that.(RaftGroupDeletedError)
  3082  		if ok {
  3083  			that1 = &that2
  3084  		} else {
  3085  			return false
  3086  		}
  3087  	}
  3088  	if that1 == nil {
  3089  		return this == nil
  3090  	} else if this == nil {
  3091  		return false
  3092  	}
  3093  	return true
  3094  }
  3095  func (this *ReplicaCorruptionError) Equal(that interface{}) bool {
  3096  	if that == nil {
  3097  		return this == nil
  3098  	}
  3099  
  3100  	that1, ok := that.(*ReplicaCorruptionError)
  3101  	if !ok {
  3102  		that2, ok := that.(ReplicaCorruptionError)
  3103  		if ok {
  3104  			that1 = &that2
  3105  		} else {
  3106  			return false
  3107  		}
  3108  	}
  3109  	if that1 == nil {
  3110  		return this == nil
  3111  	} else if this == nil {
  3112  		return false
  3113  	}
  3114  	if this.ErrorMsg != that1.ErrorMsg {
  3115  		return false
  3116  	}
  3117  	if this.Processed != that1.Processed {
  3118  		return false
  3119  	}
  3120  	return true
  3121  }
  3122  func (this *ReplicaTooOldError) Equal(that interface{}) bool {
  3123  	if that == nil {
  3124  		return this == nil
  3125  	}
  3126  
  3127  	that1, ok := that.(*ReplicaTooOldError)
  3128  	if !ok {
  3129  		that2, ok := that.(ReplicaTooOldError)
  3130  		if ok {
  3131  			that1 = &that2
  3132  		} else {
  3133  			return false
  3134  		}
  3135  	}
  3136  	if that1 == nil {
  3137  		return this == nil
  3138  	} else if this == nil {
  3139  		return false
  3140  	}
  3141  	if this.ReplicaID != that1.ReplicaID {
  3142  		return false
  3143  	}
  3144  	return true
  3145  }
  3146  func (this *StoreNotFoundError) Equal(that interface{}) bool {
  3147  	if that == nil {
  3148  		return this == nil
  3149  	}
  3150  
  3151  	that1, ok := that.(*StoreNotFoundError)
  3152  	if !ok {
  3153  		that2, ok := that.(StoreNotFoundError)
  3154  		if ok {
  3155  			that1 = &that2
  3156  		} else {
  3157  			return false
  3158  		}
  3159  	}
  3160  	if that1 == nil {
  3161  		return this == nil
  3162  	} else if this == nil {
  3163  		return false
  3164  	}
  3165  	if this.StoreID != that1.StoreID {
  3166  		return false
  3167  	}
  3168  	return true
  3169  }
  3170  func (this *TransactionRetryWithProtoRefreshError) Equal(that interface{}) bool {
  3171  	if that == nil {
  3172  		return this == nil
  3173  	}
  3174  
  3175  	that1, ok := that.(*TransactionRetryWithProtoRefreshError)
  3176  	if !ok {
  3177  		that2, ok := that.(TransactionRetryWithProtoRefreshError)
  3178  		if ok {
  3179  			that1 = &that2
  3180  		} else {
  3181  			return false
  3182  		}
  3183  	}
  3184  	if that1 == nil {
  3185  		return this == nil
  3186  	} else if this == nil {
  3187  		return false
  3188  	}
  3189  	if this.Msg != that1.Msg {
  3190  		return false
  3191  	}
  3192  	if !this.TxnID.Equal(that1.TxnID) {
  3193  		return false
  3194  	}
  3195  	if !this.Transaction.Equal(&that1.Transaction) {
  3196  		return false
  3197  	}
  3198  	return true
  3199  }
  3200  func (this *TxnAlreadyEncounteredErrorError) Equal(that interface{}) bool {
  3201  	if that == nil {
  3202  		return this == nil
  3203  	}
  3204  
  3205  	that1, ok := that.(*TxnAlreadyEncounteredErrorError)
  3206  	if !ok {
  3207  		that2, ok := that.(TxnAlreadyEncounteredErrorError)
  3208  		if ok {
  3209  			that1 = &that2
  3210  		} else {
  3211  			return false
  3212  		}
  3213  	}
  3214  	if that1 == nil {
  3215  		return this == nil
  3216  	} else if this == nil {
  3217  		return false
  3218  	}
  3219  	if this.PrevError != that1.PrevError {
  3220  		return false
  3221  	}
  3222  	return true
  3223  }
  3224  func (this *IntegerOverflowError) Equal(that interface{}) bool {
  3225  	if that == nil {
  3226  		return this == nil
  3227  	}
  3228  
  3229  	that1, ok := that.(*IntegerOverflowError)
  3230  	if !ok {
  3231  		that2, ok := that.(IntegerOverflowError)
  3232  		if ok {
  3233  			that1 = &that2
  3234  		} else {
  3235  			return false
  3236  		}
  3237  	}
  3238  	if that1 == nil {
  3239  		return this == nil
  3240  	} else if this == nil {
  3241  		return false
  3242  	}
  3243  	if !bytes.Equal(this.Key, that1.Key) {
  3244  		return false
  3245  	}
  3246  	if this.CurrentValue != that1.CurrentValue {
  3247  		return false
  3248  	}
  3249  	if this.IncrementValue != that1.IncrementValue {
  3250  		return false
  3251  	}
  3252  	return true
  3253  }
  3254  func (this *BatchTimestampBeforeGCError) Equal(that interface{}) bool {
  3255  	if that == nil {
  3256  		return this == nil
  3257  	}
  3258  
  3259  	that1, ok := that.(*BatchTimestampBeforeGCError)
  3260  	if !ok {
  3261  		that2, ok := that.(BatchTimestampBeforeGCError)
  3262  		if ok {
  3263  			that1 = &that2
  3264  		} else {
  3265  			return false
  3266  		}
  3267  	}
  3268  	if that1 == nil {
  3269  		return this == nil
  3270  	} else if this == nil {
  3271  		return false
  3272  	}
  3273  	if !this.Timestamp.Equal(&that1.Timestamp) {
  3274  		return false
  3275  	}
  3276  	if !this.Threshold.Equal(&that1.Threshold) {
  3277  		return false
  3278  	}
  3279  	return true
  3280  }
  3281  func (this *IntentMissingError) Equal(that interface{}) bool {
  3282  	if that == nil {
  3283  		return this == nil
  3284  	}
  3285  
  3286  	that1, ok := that.(*IntentMissingError)
  3287  	if !ok {
  3288  		that2, ok := that.(IntentMissingError)
  3289  		if ok {
  3290  			that1 = &that2
  3291  		} else {
  3292  			return false
  3293  		}
  3294  	}
  3295  	if that1 == nil {
  3296  		return this == nil
  3297  	} else if this == nil {
  3298  		return false
  3299  	}
  3300  	if !this.WrongIntent.Equal(that1.WrongIntent) {
  3301  		return false
  3302  	}
  3303  	if !bytes.Equal(this.Key, that1.Key) {
  3304  		return false
  3305  	}
  3306  	return true
  3307  }
  3308  func (this *MergeInProgressError) Equal(that interface{}) bool {
  3309  	if that == nil {
  3310  		return this == nil
  3311  	}
  3312  
  3313  	that1, ok := that.(*MergeInProgressError)
  3314  	if !ok {
  3315  		that2, ok := that.(MergeInProgressError)
  3316  		if ok {
  3317  			that1 = &that2
  3318  		} else {
  3319  			return false
  3320  		}
  3321  	}
  3322  	if that1 == nil {
  3323  		return this == nil
  3324  	} else if this == nil {
  3325  		return false
  3326  	}
  3327  	return true
  3328  }
  3329  func (this *RangeFeedRetryError) Equal(that interface{}) bool {
  3330  	if that == nil {
  3331  		return this == nil
  3332  	}
  3333  
  3334  	that1, ok := that.(*RangeFeedRetryError)
  3335  	if !ok {
  3336  		that2, ok := that.(RangeFeedRetryError)
  3337  		if ok {
  3338  			that1 = &that2
  3339  		} else {
  3340  			return false
  3341  		}
  3342  	}
  3343  	if that1 == nil {
  3344  		return this == nil
  3345  	} else if this == nil {
  3346  		return false
  3347  	}
  3348  	if this.Reason != that1.Reason {
  3349  		return false
  3350  	}
  3351  	return true
  3352  }
  3353  func (this *IndeterminateCommitError) Equal(that interface{}) bool {
  3354  	if that == nil {
  3355  		return this == nil
  3356  	}
  3357  
  3358  	that1, ok := that.(*IndeterminateCommitError)
  3359  	if !ok {
  3360  		that2, ok := that.(IndeterminateCommitError)
  3361  		if ok {
  3362  			that1 = &that2
  3363  		} else {
  3364  			return false
  3365  		}
  3366  	}
  3367  	if that1 == nil {
  3368  		return this == nil
  3369  	} else if this == nil {
  3370  		return false
  3371  	}
  3372  	if !this.StagingTxn.Equal(&that1.StagingTxn) {
  3373  		return false
  3374  	}
  3375  	return true
  3376  }
  3377  func (this *ErrorDetail) Equal(that interface{}) bool {
  3378  	if that == nil {
  3379  		return this == nil
  3380  	}
  3381  
  3382  	that1, ok := that.(*ErrorDetail)
  3383  	if !ok {
  3384  		that2, ok := that.(ErrorDetail)
  3385  		if ok {
  3386  			that1 = &that2
  3387  		} else {
  3388  			return false
  3389  		}
  3390  	}
  3391  	if that1 == nil {
  3392  		return this == nil
  3393  	} else if this == nil {
  3394  		return false
  3395  	}
  3396  	if that1.Value == nil {
  3397  		if this.Value != nil {
  3398  			return false
  3399  		}
  3400  	} else if this.Value == nil {
  3401  		return false
  3402  	} else if !this.Value.Equal(that1.Value) {
  3403  		return false
  3404  	}
  3405  	return true
  3406  }
  3407  func (this *ErrorDetail_NotLeaseHolder) Equal(that interface{}) bool {
  3408  	if that == nil {
  3409  		return this == nil
  3410  	}
  3411  
  3412  	that1, ok := that.(*ErrorDetail_NotLeaseHolder)
  3413  	if !ok {
  3414  		that2, ok := that.(ErrorDetail_NotLeaseHolder)
  3415  		if ok {
  3416  			that1 = &that2
  3417  		} else {
  3418  			return false
  3419  		}
  3420  	}
  3421  	if that1 == nil {
  3422  		return this == nil
  3423  	} else if this == nil {
  3424  		return false
  3425  	}
  3426  	if !this.NotLeaseHolder.Equal(that1.NotLeaseHolder) {
  3427  		return false
  3428  	}
  3429  	return true
  3430  }
  3431  func (this *ErrorDetail_RangeNotFound) Equal(that interface{}) bool {
  3432  	if that == nil {
  3433  		return this == nil
  3434  	}
  3435  
  3436  	that1, ok := that.(*ErrorDetail_RangeNotFound)
  3437  	if !ok {
  3438  		that2, ok := that.(ErrorDetail_RangeNotFound)
  3439  		if ok {
  3440  			that1 = &that2
  3441  		} else {
  3442  			return false
  3443  		}
  3444  	}
  3445  	if that1 == nil {
  3446  		return this == nil
  3447  	} else if this == nil {
  3448  		return false
  3449  	}
  3450  	if !this.RangeNotFound.Equal(that1.RangeNotFound) {
  3451  		return false
  3452  	}
  3453  	return true
  3454  }
  3455  func (this *ErrorDetail_RangeKeyMismatch) Equal(that interface{}) bool {
  3456  	if that == nil {
  3457  		return this == nil
  3458  	}
  3459  
  3460  	that1, ok := that.(*ErrorDetail_RangeKeyMismatch)
  3461  	if !ok {
  3462  		that2, ok := that.(ErrorDetail_RangeKeyMismatch)
  3463  		if ok {
  3464  			that1 = &that2
  3465  		} else {
  3466  			return false
  3467  		}
  3468  	}
  3469  	if that1 == nil {
  3470  		return this == nil
  3471  	} else if this == nil {
  3472  		return false
  3473  	}
  3474  	if !this.RangeKeyMismatch.Equal(that1.RangeKeyMismatch) {
  3475  		return false
  3476  	}
  3477  	return true
  3478  }
  3479  func (this *ErrorDetail_ReadWithinUncertaintyInterval) Equal(that interface{}) bool {
  3480  	if that == nil {
  3481  		return this == nil
  3482  	}
  3483  
  3484  	that1, ok := that.(*ErrorDetail_ReadWithinUncertaintyInterval)
  3485  	if !ok {
  3486  		that2, ok := that.(ErrorDetail_ReadWithinUncertaintyInterval)
  3487  		if ok {
  3488  			that1 = &that2
  3489  		} else {
  3490  			return false
  3491  		}
  3492  	}
  3493  	if that1 == nil {
  3494  		return this == nil
  3495  	} else if this == nil {
  3496  		return false
  3497  	}
  3498  	if !this.ReadWithinUncertaintyInterval.Equal(that1.ReadWithinUncertaintyInterval) {
  3499  		return false
  3500  	}
  3501  	return true
  3502  }
  3503  func (this *ErrorDetail_TransactionAborted) Equal(that interface{}) bool {
  3504  	if that == nil {
  3505  		return this == nil
  3506  	}
  3507  
  3508  	that1, ok := that.(*ErrorDetail_TransactionAborted)
  3509  	if !ok {
  3510  		that2, ok := that.(ErrorDetail_TransactionAborted)
  3511  		if ok {
  3512  			that1 = &that2
  3513  		} else {
  3514  			return false
  3515  		}
  3516  	}
  3517  	if that1 == nil {
  3518  		return this == nil
  3519  	} else if this == nil {
  3520  		return false
  3521  	}
  3522  	if !this.TransactionAborted.Equal(that1.TransactionAborted) {
  3523  		return false
  3524  	}
  3525  	return true
  3526  }
  3527  func (this *ErrorDetail_TransactionPush) Equal(that interface{}) bool {
  3528  	if that == nil {
  3529  		return this == nil
  3530  	}
  3531  
  3532  	that1, ok := that.(*ErrorDetail_TransactionPush)
  3533  	if !ok {
  3534  		that2, ok := that.(ErrorDetail_TransactionPush)
  3535  		if ok {
  3536  			that1 = &that2
  3537  		} else {
  3538  			return false
  3539  		}
  3540  	}
  3541  	if that1 == nil {
  3542  		return this == nil
  3543  	} else if this == nil {
  3544  		return false
  3545  	}
  3546  	if !this.TransactionPush.Equal(that1.TransactionPush) {
  3547  		return false
  3548  	}
  3549  	return true
  3550  }
  3551  func (this *ErrorDetail_TransactionRetry) Equal(that interface{}) bool {
  3552  	if that == nil {
  3553  		return this == nil
  3554  	}
  3555  
  3556  	that1, ok := that.(*ErrorDetail_TransactionRetry)
  3557  	if !ok {
  3558  		that2, ok := that.(ErrorDetail_TransactionRetry)
  3559  		if ok {
  3560  			that1 = &that2
  3561  		} else {
  3562  			return false
  3563  		}
  3564  	}
  3565  	if that1 == nil {
  3566  		return this == nil
  3567  	} else if this == nil {
  3568  		return false
  3569  	}
  3570  	if !this.TransactionRetry.Equal(that1.TransactionRetry) {
  3571  		return false
  3572  	}
  3573  	return true
  3574  }
  3575  func (this *ErrorDetail_TransactionStatus) Equal(that interface{}) bool {
  3576  	if that == nil {
  3577  		return this == nil
  3578  	}
  3579  
  3580  	that1, ok := that.(*ErrorDetail_TransactionStatus)
  3581  	if !ok {
  3582  		that2, ok := that.(ErrorDetail_TransactionStatus)
  3583  		if ok {
  3584  			that1 = &that2
  3585  		} else {
  3586  			return false
  3587  		}
  3588  	}
  3589  	if that1 == nil {
  3590  		return this == nil
  3591  	} else if this == nil {
  3592  		return false
  3593  	}
  3594  	if !this.TransactionStatus.Equal(that1.TransactionStatus) {
  3595  		return false
  3596  	}
  3597  	return true
  3598  }
  3599  func (this *ErrorDetail_WriteIntent) Equal(that interface{}) bool {
  3600  	if that == nil {
  3601  		return this == nil
  3602  	}
  3603  
  3604  	that1, ok := that.(*ErrorDetail_WriteIntent)
  3605  	if !ok {
  3606  		that2, ok := that.(ErrorDetail_WriteIntent)
  3607  		if ok {
  3608  			that1 = &that2
  3609  		} else {
  3610  			return false
  3611  		}
  3612  	}
  3613  	if that1 == nil {
  3614  		return this == nil
  3615  	} else if this == nil {
  3616  		return false
  3617  	}
  3618  	if !this.WriteIntent.Equal(that1.WriteIntent) {
  3619  		return false
  3620  	}
  3621  	return true
  3622  }
  3623  func (this *ErrorDetail_WriteTooOld) Equal(that interface{}) bool {
  3624  	if that == nil {
  3625  		return this == nil
  3626  	}
  3627  
  3628  	that1, ok := that.(*ErrorDetail_WriteTooOld)
  3629  	if !ok {
  3630  		that2, ok := that.(ErrorDetail_WriteTooOld)
  3631  		if ok {
  3632  			that1 = &that2
  3633  		} else {
  3634  			return false
  3635  		}
  3636  	}
  3637  	if that1 == nil {
  3638  		return this == nil
  3639  	} else if this == nil {
  3640  		return false
  3641  	}
  3642  	if !this.WriteTooOld.Equal(that1.WriteTooOld) {
  3643  		return false
  3644  	}
  3645  	return true
  3646  }
  3647  func (this *ErrorDetail_OpRequiresTxn) Equal(that interface{}) bool {
  3648  	if that == nil {
  3649  		return this == nil
  3650  	}
  3651  
  3652  	that1, ok := that.(*ErrorDetail_OpRequiresTxn)
  3653  	if !ok {
  3654  		that2, ok := that.(ErrorDetail_OpRequiresTxn)
  3655  		if ok {
  3656  			that1 = &that2
  3657  		} else {
  3658  			return false
  3659  		}
  3660  	}
  3661  	if that1 == nil {
  3662  		return this == nil
  3663  	} else if this == nil {
  3664  		return false
  3665  	}
  3666  	if !this.OpRequiresTxn.Equal(that1.OpRequiresTxn) {
  3667  		return false
  3668  	}
  3669  	return true
  3670  }
  3671  func (this *ErrorDetail_ConditionFailed) Equal(that interface{}) bool {
  3672  	if that == nil {
  3673  		return this == nil
  3674  	}
  3675  
  3676  	that1, ok := that.(*ErrorDetail_ConditionFailed)
  3677  	if !ok {
  3678  		that2, ok := that.(ErrorDetail_ConditionFailed)
  3679  		if ok {
  3680  			that1 = &that2
  3681  		} else {
  3682  			return false
  3683  		}
  3684  	}
  3685  	if that1 == nil {
  3686  		return this == nil
  3687  	} else if this == nil {
  3688  		return false
  3689  	}
  3690  	if !this.ConditionFailed.Equal(that1.ConditionFailed) {
  3691  		return false
  3692  	}
  3693  	return true
  3694  }
  3695  func (this *ErrorDetail_LeaseRejected) Equal(that interface{}) bool {
  3696  	if that == nil {
  3697  		return this == nil
  3698  	}
  3699  
  3700  	that1, ok := that.(*ErrorDetail_LeaseRejected)
  3701  	if !ok {
  3702  		that2, ok := that.(ErrorDetail_LeaseRejected)
  3703  		if ok {
  3704  			that1 = &that2
  3705  		} else {
  3706  			return false
  3707  		}
  3708  	}
  3709  	if that1 == nil {
  3710  		return this == nil
  3711  	} else if this == nil {
  3712  		return false
  3713  	}
  3714  	if !this.LeaseRejected.Equal(that1.LeaseRejected) {
  3715  		return false
  3716  	}
  3717  	return true
  3718  }
  3719  func (this *ErrorDetail_NodeUnavailable) Equal(that interface{}) bool {
  3720  	if that == nil {
  3721  		return this == nil
  3722  	}
  3723  
  3724  	that1, ok := that.(*ErrorDetail_NodeUnavailable)
  3725  	if !ok {
  3726  		that2, ok := that.(ErrorDetail_NodeUnavailable)
  3727  		if ok {
  3728  			that1 = &that2
  3729  		} else {
  3730  			return false
  3731  		}
  3732  	}
  3733  	if that1 == nil {
  3734  		return this == nil
  3735  	} else if this == nil {
  3736  		return false
  3737  	}
  3738  	if !this.NodeUnavailable.Equal(that1.NodeUnavailable) {
  3739  		return false
  3740  	}
  3741  	return true
  3742  }
  3743  func (this *ErrorDetail_Send) Equal(that interface{}) bool {
  3744  	if that == nil {
  3745  		return this == nil
  3746  	}
  3747  
  3748  	that1, ok := that.(*ErrorDetail_Send)
  3749  	if !ok {
  3750  		that2, ok := that.(ErrorDetail_Send)
  3751  		if ok {
  3752  			that1 = &that2
  3753  		} else {
  3754  			return false
  3755  		}
  3756  	}
  3757  	if that1 == nil {
  3758  		return this == nil
  3759  	} else if this == nil {
  3760  		return false
  3761  	}
  3762  	if !this.Send.Equal(that1.Send) {
  3763  		return false
  3764  	}
  3765  	return true
  3766  }
  3767  func (this *ErrorDetail_RaftGroupDeleted) Equal(that interface{}) bool {
  3768  	if that == nil {
  3769  		return this == nil
  3770  	}
  3771  
  3772  	that1, ok := that.(*ErrorDetail_RaftGroupDeleted)
  3773  	if !ok {
  3774  		that2, ok := that.(ErrorDetail_RaftGroupDeleted)
  3775  		if ok {
  3776  			that1 = &that2
  3777  		} else {
  3778  			return false
  3779  		}
  3780  	}
  3781  	if that1 == nil {
  3782  		return this == nil
  3783  	} else if this == nil {
  3784  		return false
  3785  	}
  3786  	if !this.RaftGroupDeleted.Equal(that1.RaftGroupDeleted) {
  3787  		return false
  3788  	}
  3789  	return true
  3790  }
  3791  func (this *ErrorDetail_ReplicaCorruption) Equal(that interface{}) bool {
  3792  	if that == nil {
  3793  		return this == nil
  3794  	}
  3795  
  3796  	that1, ok := that.(*ErrorDetail_ReplicaCorruption)
  3797  	if !ok {
  3798  		that2, ok := that.(ErrorDetail_ReplicaCorruption)
  3799  		if ok {
  3800  			that1 = &that2
  3801  		} else {
  3802  			return false
  3803  		}
  3804  	}
  3805  	if that1 == nil {
  3806  		return this == nil
  3807  	} else if this == nil {
  3808  		return false
  3809  	}
  3810  	if !this.ReplicaCorruption.Equal(that1.ReplicaCorruption) {
  3811  		return false
  3812  	}
  3813  	return true
  3814  }
  3815  func (this *ErrorDetail_ReplicaTooOld) Equal(that interface{}) bool {
  3816  	if that == nil {
  3817  		return this == nil
  3818  	}
  3819  
  3820  	that1, ok := that.(*ErrorDetail_ReplicaTooOld)
  3821  	if !ok {
  3822  		that2, ok := that.(ErrorDetail_ReplicaTooOld)
  3823  		if ok {
  3824  			that1 = &that2
  3825  		} else {
  3826  			return false
  3827  		}
  3828  	}
  3829  	if that1 == nil {
  3830  		return this == nil
  3831  	} else if this == nil {
  3832  		return false
  3833  	}
  3834  	if !this.ReplicaTooOld.Equal(that1.ReplicaTooOld) {
  3835  		return false
  3836  	}
  3837  	return true
  3838  }
  3839  func (this *ErrorDetail_AmbiguousResult) Equal(that interface{}) bool {
  3840  	if that == nil {
  3841  		return this == nil
  3842  	}
  3843  
  3844  	that1, ok := that.(*ErrorDetail_AmbiguousResult)
  3845  	if !ok {
  3846  		that2, ok := that.(ErrorDetail_AmbiguousResult)
  3847  		if ok {
  3848  			that1 = &that2
  3849  		} else {
  3850  			return false
  3851  		}
  3852  	}
  3853  	if that1 == nil {
  3854  		return this == nil
  3855  	} else if this == nil {
  3856  		return false
  3857  	}
  3858  	if !this.AmbiguousResult.Equal(that1.AmbiguousResult) {
  3859  		return false
  3860  	}
  3861  	return true
  3862  }
  3863  func (this *ErrorDetail_StoreNotFound) Equal(that interface{}) bool {
  3864  	if that == nil {
  3865  		return this == nil
  3866  	}
  3867  
  3868  	that1, ok := that.(*ErrorDetail_StoreNotFound)
  3869  	if !ok {
  3870  		that2, ok := that.(ErrorDetail_StoreNotFound)
  3871  		if ok {
  3872  			that1 = &that2
  3873  		} else {
  3874  			return false
  3875  		}
  3876  	}
  3877  	if that1 == nil {
  3878  		return this == nil
  3879  	} else if this == nil {
  3880  		return false
  3881  	}
  3882  	if !this.StoreNotFound.Equal(that1.StoreNotFound) {
  3883  		return false
  3884  	}
  3885  	return true
  3886  }
  3887  func (this *ErrorDetail_TransactionRetryWithProtoRefresh) Equal(that interface{}) bool {
  3888  	if that == nil {
  3889  		return this == nil
  3890  	}
  3891  
  3892  	that1, ok := that.(*ErrorDetail_TransactionRetryWithProtoRefresh)
  3893  	if !ok {
  3894  		that2, ok := that.(ErrorDetail_TransactionRetryWithProtoRefresh)
  3895  		if ok {
  3896  			that1 = &that2
  3897  		} else {
  3898  			return false
  3899  		}
  3900  	}
  3901  	if that1 == nil {
  3902  		return this == nil
  3903  	} else if this == nil {
  3904  		return false
  3905  	}
  3906  	if !this.TransactionRetryWithProtoRefresh.Equal(that1.TransactionRetryWithProtoRefresh) {
  3907  		return false
  3908  	}
  3909  	return true
  3910  }
  3911  func (this *ErrorDetail_IntegerOverflow) Equal(that interface{}) bool {
  3912  	if that == nil {
  3913  		return this == nil
  3914  	}
  3915  
  3916  	that1, ok := that.(*ErrorDetail_IntegerOverflow)
  3917  	if !ok {
  3918  		that2, ok := that.(ErrorDetail_IntegerOverflow)
  3919  		if ok {
  3920  			that1 = &that2
  3921  		} else {
  3922  			return false
  3923  		}
  3924  	}
  3925  	if that1 == nil {
  3926  		return this == nil
  3927  	} else if this == nil {
  3928  		return false
  3929  	}
  3930  	if !this.IntegerOverflow.Equal(that1.IntegerOverflow) {
  3931  		return false
  3932  	}
  3933  	return true
  3934  }
  3935  func (this *ErrorDetail_UnsupportedRequest) Equal(that interface{}) bool {
  3936  	if that == nil {
  3937  		return this == nil
  3938  	}
  3939  
  3940  	that1, ok := that.(*ErrorDetail_UnsupportedRequest)
  3941  	if !ok {
  3942  		that2, ok := that.(ErrorDetail_UnsupportedRequest)
  3943  		if ok {
  3944  			that1 = &that2
  3945  		} else {
  3946  			return false
  3947  		}
  3948  	}
  3949  	if that1 == nil {
  3950  		return this == nil
  3951  	} else if this == nil {
  3952  		return false
  3953  	}
  3954  	if !this.UnsupportedRequest.Equal(that1.UnsupportedRequest) {
  3955  		return false
  3956  	}
  3957  	return true
  3958  }
  3959  func (this *ErrorDetail_TimestampBefore) Equal(that interface{}) bool {
  3960  	if that == nil {
  3961  		return this == nil
  3962  	}
  3963  
  3964  	that1, ok := that.(*ErrorDetail_TimestampBefore)
  3965  	if !ok {
  3966  		that2, ok := that.(ErrorDetail_TimestampBefore)
  3967  		if ok {
  3968  			that1 = &that2
  3969  		} else {
  3970  			return false
  3971  		}
  3972  	}
  3973  	if that1 == nil {
  3974  		return this == nil
  3975  	} else if this == nil {
  3976  		return false
  3977  	}
  3978  	if !this.TimestampBefore.Equal(that1.TimestampBefore) {
  3979  		return false
  3980  	}
  3981  	return true
  3982  }
  3983  func (this *ErrorDetail_TxnAlreadyEncounteredError) Equal(that interface{}) bool {
  3984  	if that == nil {
  3985  		return this == nil
  3986  	}
  3987  
  3988  	that1, ok := that.(*ErrorDetail_TxnAlreadyEncounteredError)
  3989  	if !ok {
  3990  		that2, ok := that.(ErrorDetail_TxnAlreadyEncounteredError)
  3991  		if ok {
  3992  			that1 = &that2
  3993  		} else {
  3994  			return false
  3995  		}
  3996  	}
  3997  	if that1 == nil {
  3998  		return this == nil
  3999  	} else if this == nil {
  4000  		return false
  4001  	}
  4002  	if !this.TxnAlreadyEncounteredError.Equal(that1.TxnAlreadyEncounteredError) {
  4003  		return false
  4004  	}
  4005  	return true
  4006  }
  4007  func (this *ErrorDetail_IntentMissing) Equal(that interface{}) bool {
  4008  	if that == nil {
  4009  		return this == nil
  4010  	}
  4011  
  4012  	that1, ok := that.(*ErrorDetail_IntentMissing)
  4013  	if !ok {
  4014  		that2, ok := that.(ErrorDetail_IntentMissing)
  4015  		if ok {
  4016  			that1 = &that2
  4017  		} else {
  4018  			return false
  4019  		}
  4020  	}
  4021  	if that1 == nil {
  4022  		return this == nil
  4023  	} else if this == nil {
  4024  		return false
  4025  	}
  4026  	if !this.IntentMissing.Equal(that1.IntentMissing) {
  4027  		return false
  4028  	}
  4029  	return true
  4030  }
  4031  func (this *ErrorDetail_MergeInProgress) Equal(that interface{}) bool {
  4032  	if that == nil {
  4033  		return this == nil
  4034  	}
  4035  
  4036  	that1, ok := that.(*ErrorDetail_MergeInProgress)
  4037  	if !ok {
  4038  		that2, ok := that.(ErrorDetail_MergeInProgress)
  4039  		if ok {
  4040  			that1 = &that2
  4041  		} else {
  4042  			return false
  4043  		}
  4044  	}
  4045  	if that1 == nil {
  4046  		return this == nil
  4047  	} else if this == nil {
  4048  		return false
  4049  	}
  4050  	if !this.MergeInProgress.Equal(that1.MergeInProgress) {
  4051  		return false
  4052  	}
  4053  	return true
  4054  }
  4055  func (this *ErrorDetail_RangefeedRetry) Equal(that interface{}) bool {
  4056  	if that == nil {
  4057  		return this == nil
  4058  	}
  4059  
  4060  	that1, ok := that.(*ErrorDetail_RangefeedRetry)
  4061  	if !ok {
  4062  		that2, ok := that.(ErrorDetail_RangefeedRetry)
  4063  		if ok {
  4064  			that1 = &that2
  4065  		} else {
  4066  			return false
  4067  		}
  4068  	}
  4069  	if that1 == nil {
  4070  		return this == nil
  4071  	} else if this == nil {
  4072  		return false
  4073  	}
  4074  	if !this.RangefeedRetry.Equal(that1.RangefeedRetry) {
  4075  		return false
  4076  	}
  4077  	return true
  4078  }
  4079  func (this *ErrorDetail_IndeterminateCommit) Equal(that interface{}) bool {
  4080  	if that == nil {
  4081  		return this == nil
  4082  	}
  4083  
  4084  	that1, ok := that.(*ErrorDetail_IndeterminateCommit)
  4085  	if !ok {
  4086  		that2, ok := that.(ErrorDetail_IndeterminateCommit)
  4087  		if ok {
  4088  			that1 = &that2
  4089  		} else {
  4090  			return false
  4091  		}
  4092  	}
  4093  	if that1 == nil {
  4094  		return this == nil
  4095  	} else if this == nil {
  4096  		return false
  4097  	}
  4098  	if !this.IndeterminateCommit.Equal(that1.IndeterminateCommit) {
  4099  		return false
  4100  	}
  4101  	return true
  4102  }
  4103  func (this *ErrPosition) Equal(that interface{}) bool {
  4104  	if that == nil {
  4105  		return this == nil
  4106  	}
  4107  
  4108  	that1, ok := that.(*ErrPosition)
  4109  	if !ok {
  4110  		that2, ok := that.(ErrPosition)
  4111  		if ok {
  4112  			that1 = &that2
  4113  		} else {
  4114  			return false
  4115  		}
  4116  	}
  4117  	if that1 == nil {
  4118  		return this == nil
  4119  	} else if this == nil {
  4120  		return false
  4121  	}
  4122  	if this.Index != that1.Index {
  4123  		return false
  4124  	}
  4125  	return true
  4126  }
  4127  func (this *Error) Equal(that interface{}) bool {
  4128  	if that == nil {
  4129  		return this == nil
  4130  	}
  4131  
  4132  	that1, ok := that.(*Error)
  4133  	if !ok {
  4134  		that2, ok := that.(Error)
  4135  		if ok {
  4136  			that1 = &that2
  4137  		} else {
  4138  			return false
  4139  		}
  4140  	}
  4141  	if that1 == nil {
  4142  		return this == nil
  4143  	} else if this == nil {
  4144  		return false
  4145  	}
  4146  	if this.Message != that1.Message {
  4147  		return false
  4148  	}
  4149  	if this.TransactionRestart != that1.TransactionRestart {
  4150  		return false
  4151  	}
  4152  	if !this.UnexposedTxn.Equal(that1.UnexposedTxn) {
  4153  		return false
  4154  	}
  4155  	if this.OriginNode != that1.OriginNode {
  4156  		return false
  4157  	}
  4158  	if !this.Detail.Equal(&that1.Detail) {
  4159  		return false
  4160  	}
  4161  	if !this.Index.Equal(that1.Index) {
  4162  		return false
  4163  	}
  4164  	if !this.Now.Equal(&that1.Now) {
  4165  		return false
  4166  	}
  4167  	return true
  4168  }
  4169  func (m *NotLeaseHolderError) Marshal() (dAtA []byte, err error) {
  4170  	size := m.Size()
  4171  	dAtA = make([]byte, size)
  4172  	n, err := m.MarshalTo(dAtA)
  4173  	if err != nil {
  4174  		return nil, err
  4175  	}
  4176  	return dAtA[:n], nil
  4177  }
  4178  
  4179  func (m *NotLeaseHolderError) MarshalTo(dAtA []byte) (int, error) {
  4180  	var i int
  4181  	_ = i
  4182  	var l int
  4183  	_ = l
  4184  	dAtA[i] = 0xa
  4185  	i++
  4186  	i = encodeVarintErrors(dAtA, i, uint64(m.Replica.Size()))
  4187  	n1, err := m.Replica.MarshalTo(dAtA[i:])
  4188  	if err != nil {
  4189  		return 0, err
  4190  	}
  4191  	i += n1
  4192  	if m.LeaseHolder != nil {
  4193  		dAtA[i] = 0x12
  4194  		i++
  4195  		i = encodeVarintErrors(dAtA, i, uint64(m.LeaseHolder.Size()))
  4196  		n2, err := m.LeaseHolder.MarshalTo(dAtA[i:])
  4197  		if err != nil {
  4198  			return 0, err
  4199  		}
  4200  		i += n2
  4201  	}
  4202  	dAtA[i] = 0x18
  4203  	i++
  4204  	i = encodeVarintErrors(dAtA, i, uint64(m.RangeID))
  4205  	if m.Lease != nil {
  4206  		dAtA[i] = 0x22
  4207  		i++
  4208  		i = encodeVarintErrors(dAtA, i, uint64(m.Lease.Size()))
  4209  		n3, err := m.Lease.MarshalTo(dAtA[i:])
  4210  		if err != nil {
  4211  			return 0, err
  4212  		}
  4213  		i += n3
  4214  	}
  4215  	dAtA[i] = 0x2a
  4216  	i++
  4217  	i = encodeVarintErrors(dAtA, i, uint64(len(m.CustomMsg)))
  4218  	i += copy(dAtA[i:], m.CustomMsg)
  4219  	return i, nil
  4220  }
  4221  
  4222  func (m *NodeUnavailableError) Marshal() (dAtA []byte, err error) {
  4223  	size := m.Size()
  4224  	dAtA = make([]byte, size)
  4225  	n, err := m.MarshalTo(dAtA)
  4226  	if err != nil {
  4227  		return nil, err
  4228  	}
  4229  	return dAtA[:n], nil
  4230  }
  4231  
  4232  func (m *NodeUnavailableError) MarshalTo(dAtA []byte) (int, error) {
  4233  	var i int
  4234  	_ = i
  4235  	var l int
  4236  	_ = l
  4237  	return i, nil
  4238  }
  4239  
  4240  func (m *UnsupportedRequestError) Marshal() (dAtA []byte, err error) {
  4241  	size := m.Size()
  4242  	dAtA = make([]byte, size)
  4243  	n, err := m.MarshalTo(dAtA)
  4244  	if err != nil {
  4245  		return nil, err
  4246  	}
  4247  	return dAtA[:n], nil
  4248  }
  4249  
  4250  func (m *UnsupportedRequestError) MarshalTo(dAtA []byte) (int, error) {
  4251  	var i int
  4252  	_ = i
  4253  	var l int
  4254  	_ = l
  4255  	return i, nil
  4256  }
  4257  
  4258  func (m *RangeNotFoundError) Marshal() (dAtA []byte, err error) {
  4259  	size := m.Size()
  4260  	dAtA = make([]byte, size)
  4261  	n, err := m.MarshalTo(dAtA)
  4262  	if err != nil {
  4263  		return nil, err
  4264  	}
  4265  	return dAtA[:n], nil
  4266  }
  4267  
  4268  func (m *RangeNotFoundError) MarshalTo(dAtA []byte) (int, error) {
  4269  	var i int
  4270  	_ = i
  4271  	var l int
  4272  	_ = l
  4273  	dAtA[i] = 0x8
  4274  	i++
  4275  	i = encodeVarintErrors(dAtA, i, uint64(m.RangeID))
  4276  	dAtA[i] = 0x10
  4277  	i++
  4278  	i = encodeVarintErrors(dAtA, i, uint64(m.StoreID))
  4279  	return i, nil
  4280  }
  4281  
  4282  func (m *RangeKeyMismatchError) Marshal() (dAtA []byte, err error) {
  4283  	size := m.Size()
  4284  	dAtA = make([]byte, size)
  4285  	n, err := m.MarshalTo(dAtA)
  4286  	if err != nil {
  4287  		return nil, err
  4288  	}
  4289  	return dAtA[:n], nil
  4290  }
  4291  
  4292  func (m *RangeKeyMismatchError) MarshalTo(dAtA []byte) (int, error) {
  4293  	var i int
  4294  	_ = i
  4295  	var l int
  4296  	_ = l
  4297  	if m.RequestStartKey != nil {
  4298  		dAtA[i] = 0xa
  4299  		i++
  4300  		i = encodeVarintErrors(dAtA, i, uint64(len(m.RequestStartKey)))
  4301  		i += copy(dAtA[i:], m.RequestStartKey)
  4302  	}
  4303  	if m.RequestEndKey != nil {
  4304  		dAtA[i] = 0x12
  4305  		i++
  4306  		i = encodeVarintErrors(dAtA, i, uint64(len(m.RequestEndKey)))
  4307  		i += copy(dAtA[i:], m.RequestEndKey)
  4308  	}
  4309  	dAtA[i] = 0x1a
  4310  	i++
  4311  	i = encodeVarintErrors(dAtA, i, uint64(m.MismatchedRange.Size()))
  4312  	n4, err := m.MismatchedRange.MarshalTo(dAtA[i:])
  4313  	if err != nil {
  4314  		return 0, err
  4315  	}
  4316  	i += n4
  4317  	if m.SuggestedRange != nil {
  4318  		dAtA[i] = 0x22
  4319  		i++
  4320  		i = encodeVarintErrors(dAtA, i, uint64(m.SuggestedRange.Size()))
  4321  		n5, err := m.SuggestedRange.MarshalTo(dAtA[i:])
  4322  		if err != nil {
  4323  			return 0, err
  4324  		}
  4325  		i += n5
  4326  	}
  4327  	return i, nil
  4328  }
  4329  
  4330  func (m *ReadWithinUncertaintyIntervalError) Marshal() (dAtA []byte, err error) {
  4331  	size := m.Size()
  4332  	dAtA = make([]byte, size)
  4333  	n, err := m.MarshalTo(dAtA)
  4334  	if err != nil {
  4335  		return nil, err
  4336  	}
  4337  	return dAtA[:n], nil
  4338  }
  4339  
  4340  func (m *ReadWithinUncertaintyIntervalError) MarshalTo(dAtA []byte) (int, error) {
  4341  	var i int
  4342  	_ = i
  4343  	var l int
  4344  	_ = l
  4345  	dAtA[i] = 0xa
  4346  	i++
  4347  	i = encodeVarintErrors(dAtA, i, uint64(m.ReadTimestamp.Size()))
  4348  	n6, err := m.ReadTimestamp.MarshalTo(dAtA[i:])
  4349  	if err != nil {
  4350  		return 0, err
  4351  	}
  4352  	i += n6
  4353  	dAtA[i] = 0x12
  4354  	i++
  4355  	i = encodeVarintErrors(dAtA, i, uint64(m.ExistingTimestamp.Size()))
  4356  	n7, err := m.ExistingTimestamp.MarshalTo(dAtA[i:])
  4357  	if err != nil {
  4358  		return 0, err
  4359  	}
  4360  	i += n7
  4361  	if m.MaxTimestamp != nil {
  4362  		dAtA[i] = 0x1a
  4363  		i++
  4364  		i = encodeVarintErrors(dAtA, i, uint64(m.MaxTimestamp.Size()))
  4365  		n8, err := m.MaxTimestamp.MarshalTo(dAtA[i:])
  4366  		if err != nil {
  4367  			return 0, err
  4368  		}
  4369  		i += n8
  4370  	}
  4371  	if len(m.ObservedTimestamps) > 0 {
  4372  		for _, msg := range m.ObservedTimestamps {
  4373  			dAtA[i] = 0x22
  4374  			i++
  4375  			i = encodeVarintErrors(dAtA, i, uint64(msg.Size()))
  4376  			n, err := msg.MarshalTo(dAtA[i:])
  4377  			if err != nil {
  4378  				return 0, err
  4379  			}
  4380  			i += n
  4381  		}
  4382  	}
  4383  	return i, nil
  4384  }
  4385  
  4386  func (m *TransactionAbortedError) Marshal() (dAtA []byte, err error) {
  4387  	size := m.Size()
  4388  	dAtA = make([]byte, size)
  4389  	n, err := m.MarshalTo(dAtA)
  4390  	if err != nil {
  4391  		return nil, err
  4392  	}
  4393  	return dAtA[:n], nil
  4394  }
  4395  
  4396  func (m *TransactionAbortedError) MarshalTo(dAtA []byte) (int, error) {
  4397  	var i int
  4398  	_ = i
  4399  	var l int
  4400  	_ = l
  4401  	dAtA[i] = 0x8
  4402  	i++
  4403  	i = encodeVarintErrors(dAtA, i, uint64(m.Reason))
  4404  	return i, nil
  4405  }
  4406  
  4407  func (m *TransactionPushError) Marshal() (dAtA []byte, err error) {
  4408  	size := m.Size()
  4409  	dAtA = make([]byte, size)
  4410  	n, err := m.MarshalTo(dAtA)
  4411  	if err != nil {
  4412  		return nil, err
  4413  	}
  4414  	return dAtA[:n], nil
  4415  }
  4416  
  4417  func (m *TransactionPushError) MarshalTo(dAtA []byte) (int, error) {
  4418  	var i int
  4419  	_ = i
  4420  	var l int
  4421  	_ = l
  4422  	dAtA[i] = 0xa
  4423  	i++
  4424  	i = encodeVarintErrors(dAtA, i, uint64(m.PusheeTxn.Size()))
  4425  	n9, err := m.PusheeTxn.MarshalTo(dAtA[i:])
  4426  	if err != nil {
  4427  		return 0, err
  4428  	}
  4429  	i += n9
  4430  	return i, nil
  4431  }
  4432  
  4433  func (m *TransactionRetryError) Marshal() (dAtA []byte, err error) {
  4434  	size := m.Size()
  4435  	dAtA = make([]byte, size)
  4436  	n, err := m.MarshalTo(dAtA)
  4437  	if err != nil {
  4438  		return nil, err
  4439  	}
  4440  	return dAtA[:n], nil
  4441  }
  4442  
  4443  func (m *TransactionRetryError) MarshalTo(dAtA []byte) (int, error) {
  4444  	var i int
  4445  	_ = i
  4446  	var l int
  4447  	_ = l
  4448  	dAtA[i] = 0x8
  4449  	i++
  4450  	i = encodeVarintErrors(dAtA, i, uint64(m.Reason))
  4451  	dAtA[i] = 0x12
  4452  	i++
  4453  	i = encodeVarintErrors(dAtA, i, uint64(len(m.ExtraMsg)))
  4454  	i += copy(dAtA[i:], m.ExtraMsg)
  4455  	return i, nil
  4456  }
  4457  
  4458  func (m *TransactionStatusError) Marshal() (dAtA []byte, err error) {
  4459  	size := m.Size()
  4460  	dAtA = make([]byte, size)
  4461  	n, err := m.MarshalTo(dAtA)
  4462  	if err != nil {
  4463  		return nil, err
  4464  	}
  4465  	return dAtA[:n], nil
  4466  }
  4467  
  4468  func (m *TransactionStatusError) MarshalTo(dAtA []byte) (int, error) {
  4469  	var i int
  4470  	_ = i
  4471  	var l int
  4472  	_ = l
  4473  	dAtA[i] = 0xa
  4474  	i++
  4475  	i = encodeVarintErrors(dAtA, i, uint64(len(m.Msg)))
  4476  	i += copy(dAtA[i:], m.Msg)
  4477  	dAtA[i] = 0x10
  4478  	i++
  4479  	i = encodeVarintErrors(dAtA, i, uint64(m.Reason))
  4480  	return i, nil
  4481  }
  4482  
  4483  func (m *WriteIntentError) Marshal() (dAtA []byte, err error) {
  4484  	size := m.Size()
  4485  	dAtA = make([]byte, size)
  4486  	n, err := m.MarshalTo(dAtA)
  4487  	if err != nil {
  4488  		return nil, err
  4489  	}
  4490  	return dAtA[:n], nil
  4491  }
  4492  
  4493  func (m *WriteIntentError) MarshalTo(dAtA []byte) (int, error) {
  4494  	var i int
  4495  	_ = i
  4496  	var l int
  4497  	_ = l
  4498  	if len(m.Intents) > 0 {
  4499  		for _, msg := range m.Intents {
  4500  			dAtA[i] = 0xa
  4501  			i++
  4502  			i = encodeVarintErrors(dAtA, i, uint64(msg.Size()))
  4503  			n, err := msg.MarshalTo(dAtA[i:])
  4504  			if err != nil {
  4505  				return 0, err
  4506  			}
  4507  			i += n
  4508  		}
  4509  	}
  4510  	return i, nil
  4511  }
  4512  
  4513  func (m *WriteTooOldError) Marshal() (dAtA []byte, err error) {
  4514  	size := m.Size()
  4515  	dAtA = make([]byte, size)
  4516  	n, err := m.MarshalTo(dAtA)
  4517  	if err != nil {
  4518  		return nil, err
  4519  	}
  4520  	return dAtA[:n], nil
  4521  }
  4522  
  4523  func (m *WriteTooOldError) MarshalTo(dAtA []byte) (int, error) {
  4524  	var i int
  4525  	_ = i
  4526  	var l int
  4527  	_ = l
  4528  	dAtA[i] = 0xa
  4529  	i++
  4530  	i = encodeVarintErrors(dAtA, i, uint64(m.Timestamp.Size()))
  4531  	n10, err := m.Timestamp.MarshalTo(dAtA[i:])
  4532  	if err != nil {
  4533  		return 0, err
  4534  	}
  4535  	i += n10
  4536  	dAtA[i] = 0x12
  4537  	i++
  4538  	i = encodeVarintErrors(dAtA, i, uint64(m.ActualTimestamp.Size()))
  4539  	n11, err := m.ActualTimestamp.MarshalTo(dAtA[i:])
  4540  	if err != nil {
  4541  		return 0, err
  4542  	}
  4543  	i += n11
  4544  	return i, nil
  4545  }
  4546  
  4547  func (m *OpRequiresTxnError) Marshal() (dAtA []byte, err error) {
  4548  	size := m.Size()
  4549  	dAtA = make([]byte, size)
  4550  	n, err := m.MarshalTo(dAtA)
  4551  	if err != nil {
  4552  		return nil, err
  4553  	}
  4554  	return dAtA[:n], nil
  4555  }
  4556  
  4557  func (m *OpRequiresTxnError) MarshalTo(dAtA []byte) (int, error) {
  4558  	var i int
  4559  	_ = i
  4560  	var l int
  4561  	_ = l
  4562  	return i, nil
  4563  }
  4564  
  4565  func (m *ConditionFailedError) Marshal() (dAtA []byte, err error) {
  4566  	size := m.Size()
  4567  	dAtA = make([]byte, size)
  4568  	n, err := m.MarshalTo(dAtA)
  4569  	if err != nil {
  4570  		return nil, err
  4571  	}
  4572  	return dAtA[:n], nil
  4573  }
  4574  
  4575  func (m *ConditionFailedError) MarshalTo(dAtA []byte) (int, error) {
  4576  	var i int
  4577  	_ = i
  4578  	var l int
  4579  	_ = l
  4580  	if m.ActualValue != nil {
  4581  		dAtA[i] = 0xa
  4582  		i++
  4583  		i = encodeVarintErrors(dAtA, i, uint64(m.ActualValue.Size()))
  4584  		n12, err := m.ActualValue.MarshalTo(dAtA[i:])
  4585  		if err != nil {
  4586  			return 0, err
  4587  		}
  4588  		i += n12
  4589  	}
  4590  	return i, nil
  4591  }
  4592  
  4593  func (m *LeaseRejectedError) Marshal() (dAtA []byte, err error) {
  4594  	size := m.Size()
  4595  	dAtA = make([]byte, size)
  4596  	n, err := m.MarshalTo(dAtA)
  4597  	if err != nil {
  4598  		return nil, err
  4599  	}
  4600  	return dAtA[:n], nil
  4601  }
  4602  
  4603  func (m *LeaseRejectedError) MarshalTo(dAtA []byte) (int, error) {
  4604  	var i int
  4605  	_ = i
  4606  	var l int
  4607  	_ = l
  4608  	dAtA[i] = 0xa
  4609  	i++
  4610  	i = encodeVarintErrors(dAtA, i, uint64(len(m.Message)))
  4611  	i += copy(dAtA[i:], m.Message)
  4612  	dAtA[i] = 0x12
  4613  	i++
  4614  	i = encodeVarintErrors(dAtA, i, uint64(m.Requested.Size()))
  4615  	n13, err := m.Requested.MarshalTo(dAtA[i:])
  4616  	if err != nil {
  4617  		return 0, err
  4618  	}
  4619  	i += n13
  4620  	dAtA[i] = 0x1a
  4621  	i++
  4622  	i = encodeVarintErrors(dAtA, i, uint64(m.Existing.Size()))
  4623  	n14, err := m.Existing.MarshalTo(dAtA[i:])
  4624  	if err != nil {
  4625  		return 0, err
  4626  	}
  4627  	i += n14
  4628  	return i, nil
  4629  }
  4630  
  4631  func (m *SendError) Marshal() (dAtA []byte, err error) {
  4632  	size := m.Size()
  4633  	dAtA = make([]byte, size)
  4634  	n, err := m.MarshalTo(dAtA)
  4635  	if err != nil {
  4636  		return nil, err
  4637  	}
  4638  	return dAtA[:n], nil
  4639  }
  4640  
  4641  func (m *SendError) MarshalTo(dAtA []byte) (int, error) {
  4642  	var i int
  4643  	_ = i
  4644  	var l int
  4645  	_ = l
  4646  	dAtA[i] = 0xa
  4647  	i++
  4648  	i = encodeVarintErrors(dAtA, i, uint64(len(m.Message)))
  4649  	i += copy(dAtA[i:], m.Message)
  4650  	return i, nil
  4651  }
  4652  
  4653  func (m *AmbiguousResultError) Marshal() (dAtA []byte, err error) {
  4654  	size := m.Size()
  4655  	dAtA = make([]byte, size)
  4656  	n, err := m.MarshalTo(dAtA)
  4657  	if err != nil {
  4658  		return nil, err
  4659  	}
  4660  	return dAtA[:n], nil
  4661  }
  4662  
  4663  func (m *AmbiguousResultError) MarshalTo(dAtA []byte) (int, error) {
  4664  	var i int
  4665  	_ = i
  4666  	var l int
  4667  	_ = l
  4668  	dAtA[i] = 0xa
  4669  	i++
  4670  	i = encodeVarintErrors(dAtA, i, uint64(len(m.Message)))
  4671  	i += copy(dAtA[i:], m.Message)
  4672  	if m.WrappedErr != nil {
  4673  		dAtA[i] = 0x12
  4674  		i++
  4675  		i = encodeVarintErrors(dAtA, i, uint64(m.WrappedErr.Size()))
  4676  		n15, err := m.WrappedErr.MarshalTo(dAtA[i:])
  4677  		if err != nil {
  4678  			return 0, err
  4679  		}
  4680  		i += n15
  4681  	}
  4682  	return i, nil
  4683  }
  4684  
  4685  func (m *RaftGroupDeletedError) Marshal() (dAtA []byte, err error) {
  4686  	size := m.Size()
  4687  	dAtA = make([]byte, size)
  4688  	n, err := m.MarshalTo(dAtA)
  4689  	if err != nil {
  4690  		return nil, err
  4691  	}
  4692  	return dAtA[:n], nil
  4693  }
  4694  
  4695  func (m *RaftGroupDeletedError) MarshalTo(dAtA []byte) (int, error) {
  4696  	var i int
  4697  	_ = i
  4698  	var l int
  4699  	_ = l
  4700  	return i, nil
  4701  }
  4702  
  4703  func (m *ReplicaCorruptionError) Marshal() (dAtA []byte, err error) {
  4704  	size := m.Size()
  4705  	dAtA = make([]byte, size)
  4706  	n, err := m.MarshalTo(dAtA)
  4707  	if err != nil {
  4708  		return nil, err
  4709  	}
  4710  	return dAtA[:n], nil
  4711  }
  4712  
  4713  func (m *ReplicaCorruptionError) MarshalTo(dAtA []byte) (int, error) {
  4714  	var i int
  4715  	_ = i
  4716  	var l int
  4717  	_ = l
  4718  	dAtA[i] = 0xa
  4719  	i++
  4720  	i = encodeVarintErrors(dAtA, i, uint64(len(m.ErrorMsg)))
  4721  	i += copy(dAtA[i:], m.ErrorMsg)
  4722  	dAtA[i] = 0x10
  4723  	i++
  4724  	if m.Processed {
  4725  		dAtA[i] = 1
  4726  	} else {
  4727  		dAtA[i] = 0
  4728  	}
  4729  	i++
  4730  	return i, nil
  4731  }
  4732  
  4733  func (m *ReplicaTooOldError) Marshal() (dAtA []byte, err error) {
  4734  	size := m.Size()
  4735  	dAtA = make([]byte, size)
  4736  	n, err := m.MarshalTo(dAtA)
  4737  	if err != nil {
  4738  		return nil, err
  4739  	}
  4740  	return dAtA[:n], nil
  4741  }
  4742  
  4743  func (m *ReplicaTooOldError) MarshalTo(dAtA []byte) (int, error) {
  4744  	var i int
  4745  	_ = i
  4746  	var l int
  4747  	_ = l
  4748  	dAtA[i] = 0x8
  4749  	i++
  4750  	i = encodeVarintErrors(dAtA, i, uint64(m.ReplicaID))
  4751  	return i, nil
  4752  }
  4753  
  4754  func (m *StoreNotFoundError) Marshal() (dAtA []byte, err error) {
  4755  	size := m.Size()
  4756  	dAtA = make([]byte, size)
  4757  	n, err := m.MarshalTo(dAtA)
  4758  	if err != nil {
  4759  		return nil, err
  4760  	}
  4761  	return dAtA[:n], nil
  4762  }
  4763  
  4764  func (m *StoreNotFoundError) MarshalTo(dAtA []byte) (int, error) {
  4765  	var i int
  4766  	_ = i
  4767  	var l int
  4768  	_ = l
  4769  	dAtA[i] = 0x8
  4770  	i++
  4771  	i = encodeVarintErrors(dAtA, i, uint64(m.StoreID))
  4772  	return i, nil
  4773  }
  4774  
  4775  func (m *UnhandledRetryableError) Marshal() (dAtA []byte, err error) {
  4776  	size := m.Size()
  4777  	dAtA = make([]byte, size)
  4778  	n, err := m.MarshalTo(dAtA)
  4779  	if err != nil {
  4780  		return nil, err
  4781  	}
  4782  	return dAtA[:n], nil
  4783  }
  4784  
  4785  func (m *UnhandledRetryableError) MarshalTo(dAtA []byte) (int, error) {
  4786  	var i int
  4787  	_ = i
  4788  	var l int
  4789  	_ = l
  4790  	dAtA[i] = 0xa
  4791  	i++
  4792  	i = encodeVarintErrors(dAtA, i, uint64(m.PErr.Size()))
  4793  	n16, err := m.PErr.MarshalTo(dAtA[i:])
  4794  	if err != nil {
  4795  		return 0, err
  4796  	}
  4797  	i += n16
  4798  	return i, nil
  4799  }
  4800  
  4801  func (m *TransactionRetryWithProtoRefreshError) Marshal() (dAtA []byte, err error) {
  4802  	size := m.Size()
  4803  	dAtA = make([]byte, size)
  4804  	n, err := m.MarshalTo(dAtA)
  4805  	if err != nil {
  4806  		return nil, err
  4807  	}
  4808  	return dAtA[:n], nil
  4809  }
  4810  
  4811  func (m *TransactionRetryWithProtoRefreshError) MarshalTo(dAtA []byte) (int, error) {
  4812  	var i int
  4813  	_ = i
  4814  	var l int
  4815  	_ = l
  4816  	dAtA[i] = 0xa
  4817  	i++
  4818  	i = encodeVarintErrors(dAtA, i, uint64(len(m.Msg)))
  4819  	i += copy(dAtA[i:], m.Msg)
  4820  	dAtA[i] = 0x12
  4821  	i++
  4822  	i = encodeVarintErrors(dAtA, i, uint64(m.TxnID.Size()))
  4823  	n17, err := m.TxnID.MarshalTo(dAtA[i:])
  4824  	if err != nil {
  4825  		return 0, err
  4826  	}
  4827  	i += n17
  4828  	dAtA[i] = 0x1a
  4829  	i++
  4830  	i = encodeVarintErrors(dAtA, i, uint64(m.Transaction.Size()))
  4831  	n18, err := m.Transaction.MarshalTo(dAtA[i:])
  4832  	if err != nil {
  4833  		return 0, err
  4834  	}
  4835  	i += n18
  4836  	return i, nil
  4837  }
  4838  
  4839  func (m *TxnAlreadyEncounteredErrorError) Marshal() (dAtA []byte, err error) {
  4840  	size := m.Size()
  4841  	dAtA = make([]byte, size)
  4842  	n, err := m.MarshalTo(dAtA)
  4843  	if err != nil {
  4844  		return nil, err
  4845  	}
  4846  	return dAtA[:n], nil
  4847  }
  4848  
  4849  func (m *TxnAlreadyEncounteredErrorError) MarshalTo(dAtA []byte) (int, error) {
  4850  	var i int
  4851  	_ = i
  4852  	var l int
  4853  	_ = l
  4854  	dAtA[i] = 0xa
  4855  	i++
  4856  	i = encodeVarintErrors(dAtA, i, uint64(len(m.PrevError)))
  4857  	i += copy(dAtA[i:], m.PrevError)
  4858  	return i, nil
  4859  }
  4860  
  4861  func (m *IntegerOverflowError) Marshal() (dAtA []byte, err error) {
  4862  	size := m.Size()
  4863  	dAtA = make([]byte, size)
  4864  	n, err := m.MarshalTo(dAtA)
  4865  	if err != nil {
  4866  		return nil, err
  4867  	}
  4868  	return dAtA[:n], nil
  4869  }
  4870  
  4871  func (m *IntegerOverflowError) MarshalTo(dAtA []byte) (int, error) {
  4872  	var i int
  4873  	_ = i
  4874  	var l int
  4875  	_ = l
  4876  	if m.Key != nil {
  4877  		dAtA[i] = 0xa
  4878  		i++
  4879  		i = encodeVarintErrors(dAtA, i, uint64(len(m.Key)))
  4880  		i += copy(dAtA[i:], m.Key)
  4881  	}
  4882  	dAtA[i] = 0x10
  4883  	i++
  4884  	i = encodeVarintErrors(dAtA, i, uint64(m.CurrentValue))
  4885  	dAtA[i] = 0x18
  4886  	i++
  4887  	i = encodeVarintErrors(dAtA, i, uint64(m.IncrementValue))
  4888  	return i, nil
  4889  }
  4890  
  4891  func (m *BatchTimestampBeforeGCError) Marshal() (dAtA []byte, err error) {
  4892  	size := m.Size()
  4893  	dAtA = make([]byte, size)
  4894  	n, err := m.MarshalTo(dAtA)
  4895  	if err != nil {
  4896  		return nil, err
  4897  	}
  4898  	return dAtA[:n], nil
  4899  }
  4900  
  4901  func (m *BatchTimestampBeforeGCError) MarshalTo(dAtA []byte) (int, error) {
  4902  	var i int
  4903  	_ = i
  4904  	var l int
  4905  	_ = l
  4906  	dAtA[i] = 0xa
  4907  	i++
  4908  	i = encodeVarintErrors(dAtA, i, uint64(m.Timestamp.Size()))
  4909  	n19, err := m.Timestamp.MarshalTo(dAtA[i:])
  4910  	if err != nil {
  4911  		return 0, err
  4912  	}
  4913  	i += n19
  4914  	dAtA[i] = 0x12
  4915  	i++
  4916  	i = encodeVarintErrors(dAtA, i, uint64(m.Threshold.Size()))
  4917  	n20, err := m.Threshold.MarshalTo(dAtA[i:])
  4918  	if err != nil {
  4919  		return 0, err
  4920  	}
  4921  	i += n20
  4922  	return i, nil
  4923  }
  4924  
  4925  func (m *IntentMissingError) Marshal() (dAtA []byte, err error) {
  4926  	size := m.Size()
  4927  	dAtA = make([]byte, size)
  4928  	n, err := m.MarshalTo(dAtA)
  4929  	if err != nil {
  4930  		return nil, err
  4931  	}
  4932  	return dAtA[:n], nil
  4933  }
  4934  
  4935  func (m *IntentMissingError) MarshalTo(dAtA []byte) (int, error) {
  4936  	var i int
  4937  	_ = i
  4938  	var l int
  4939  	_ = l
  4940  	if m.WrongIntent != nil {
  4941  		dAtA[i] = 0xa
  4942  		i++
  4943  		i = encodeVarintErrors(dAtA, i, uint64(m.WrongIntent.Size()))
  4944  		n21, err := m.WrongIntent.MarshalTo(dAtA[i:])
  4945  		if err != nil {
  4946  			return 0, err
  4947  		}
  4948  		i += n21
  4949  	}
  4950  	if m.Key != nil {
  4951  		dAtA[i] = 0x12
  4952  		i++
  4953  		i = encodeVarintErrors(dAtA, i, uint64(len(m.Key)))
  4954  		i += copy(dAtA[i:], m.Key)
  4955  	}
  4956  	return i, nil
  4957  }
  4958  
  4959  func (m *MergeInProgressError) Marshal() (dAtA []byte, err error) {
  4960  	size := m.Size()
  4961  	dAtA = make([]byte, size)
  4962  	n, err := m.MarshalTo(dAtA)
  4963  	if err != nil {
  4964  		return nil, err
  4965  	}
  4966  	return dAtA[:n], nil
  4967  }
  4968  
  4969  func (m *MergeInProgressError) MarshalTo(dAtA []byte) (int, error) {
  4970  	var i int
  4971  	_ = i
  4972  	var l int
  4973  	_ = l
  4974  	return i, nil
  4975  }
  4976  
  4977  func (m *RangeFeedRetryError) Marshal() (dAtA []byte, err error) {
  4978  	size := m.Size()
  4979  	dAtA = make([]byte, size)
  4980  	n, err := m.MarshalTo(dAtA)
  4981  	if err != nil {
  4982  		return nil, err
  4983  	}
  4984  	return dAtA[:n], nil
  4985  }
  4986  
  4987  func (m *RangeFeedRetryError) MarshalTo(dAtA []byte) (int, error) {
  4988  	var i int
  4989  	_ = i
  4990  	var l int
  4991  	_ = l
  4992  	dAtA[i] = 0x8
  4993  	i++
  4994  	i = encodeVarintErrors(dAtA, i, uint64(m.Reason))
  4995  	return i, nil
  4996  }
  4997  
  4998  func (m *IndeterminateCommitError) Marshal() (dAtA []byte, err error) {
  4999  	size := m.Size()
  5000  	dAtA = make([]byte, size)
  5001  	n, err := m.MarshalTo(dAtA)
  5002  	if err != nil {
  5003  		return nil, err
  5004  	}
  5005  	return dAtA[:n], nil
  5006  }
  5007  
  5008  func (m *IndeterminateCommitError) MarshalTo(dAtA []byte) (int, error) {
  5009  	var i int
  5010  	_ = i
  5011  	var l int
  5012  	_ = l
  5013  	dAtA[i] = 0xa
  5014  	i++
  5015  	i = encodeVarintErrors(dAtA, i, uint64(m.StagingTxn.Size()))
  5016  	n22, err := m.StagingTxn.MarshalTo(dAtA[i:])
  5017  	if err != nil {
  5018  		return 0, err
  5019  	}
  5020  	i += n22
  5021  	return i, nil
  5022  }
  5023  
  5024  func (m *ErrorDetail) Marshal() (dAtA []byte, err error) {
  5025  	size := m.Size()
  5026  	dAtA = make([]byte, size)
  5027  	n, err := m.MarshalTo(dAtA)
  5028  	if err != nil {
  5029  		return nil, err
  5030  	}
  5031  	return dAtA[:n], nil
  5032  }
  5033  
  5034  func (m *ErrorDetail) MarshalTo(dAtA []byte) (int, error) {
  5035  	var i int
  5036  	_ = i
  5037  	var l int
  5038  	_ = l
  5039  	if m.Value != nil {
  5040  		nn23, err := m.Value.MarshalTo(dAtA[i:])
  5041  		if err != nil {
  5042  			return 0, err
  5043  		}
  5044  		i += nn23
  5045  	}
  5046  	return i, nil
  5047  }
  5048  
  5049  func (m *ErrorDetail_NotLeaseHolder) MarshalTo(dAtA []byte) (int, error) {
  5050  	i := 0
  5051  	if m.NotLeaseHolder != nil {
  5052  		dAtA[i] = 0xa
  5053  		i++
  5054  		i = encodeVarintErrors(dAtA, i, uint64(m.NotLeaseHolder.Size()))
  5055  		n24, err := m.NotLeaseHolder.MarshalTo(dAtA[i:])
  5056  		if err != nil {
  5057  			return 0, err
  5058  		}
  5059  		i += n24
  5060  	}
  5061  	return i, nil
  5062  }
  5063  func (m *ErrorDetail_RangeNotFound) MarshalTo(dAtA []byte) (int, error) {
  5064  	i := 0
  5065  	if m.RangeNotFound != nil {
  5066  		dAtA[i] = 0x12
  5067  		i++
  5068  		i = encodeVarintErrors(dAtA, i, uint64(m.RangeNotFound.Size()))
  5069  		n25, err := m.RangeNotFound.MarshalTo(dAtA[i:])
  5070  		if err != nil {
  5071  			return 0, err
  5072  		}
  5073  		i += n25
  5074  	}
  5075  	return i, nil
  5076  }
  5077  func (m *ErrorDetail_RangeKeyMismatch) MarshalTo(dAtA []byte) (int, error) {
  5078  	i := 0
  5079  	if m.RangeKeyMismatch != nil {
  5080  		dAtA[i] = 0x1a
  5081  		i++
  5082  		i = encodeVarintErrors(dAtA, i, uint64(m.RangeKeyMismatch.Size()))
  5083  		n26, err := m.RangeKeyMismatch.MarshalTo(dAtA[i:])
  5084  		if err != nil {
  5085  			return 0, err
  5086  		}
  5087  		i += n26
  5088  	}
  5089  	return i, nil
  5090  }
  5091  func (m *ErrorDetail_ReadWithinUncertaintyInterval) MarshalTo(dAtA []byte) (int, error) {
  5092  	i := 0
  5093  	if m.ReadWithinUncertaintyInterval != nil {
  5094  		dAtA[i] = 0x22
  5095  		i++
  5096  		i = encodeVarintErrors(dAtA, i, uint64(m.ReadWithinUncertaintyInterval.Size()))
  5097  		n27, err := m.ReadWithinUncertaintyInterval.MarshalTo(dAtA[i:])
  5098  		if err != nil {
  5099  			return 0, err
  5100  		}
  5101  		i += n27
  5102  	}
  5103  	return i, nil
  5104  }
  5105  func (m *ErrorDetail_TransactionAborted) MarshalTo(dAtA []byte) (int, error) {
  5106  	i := 0
  5107  	if m.TransactionAborted != nil {
  5108  		dAtA[i] = 0x2a
  5109  		i++
  5110  		i = encodeVarintErrors(dAtA, i, uint64(m.TransactionAborted.Size()))
  5111  		n28, err := m.TransactionAborted.MarshalTo(dAtA[i:])
  5112  		if err != nil {
  5113  			return 0, err
  5114  		}
  5115  		i += n28
  5116  	}
  5117  	return i, nil
  5118  }
  5119  func (m *ErrorDetail_TransactionPush) MarshalTo(dAtA []byte) (int, error) {
  5120  	i := 0
  5121  	if m.TransactionPush != nil {
  5122  		dAtA[i] = 0x32
  5123  		i++
  5124  		i = encodeVarintErrors(dAtA, i, uint64(m.TransactionPush.Size()))
  5125  		n29, err := m.TransactionPush.MarshalTo(dAtA[i:])
  5126  		if err != nil {
  5127  			return 0, err
  5128  		}
  5129  		i += n29
  5130  	}
  5131  	return i, nil
  5132  }
  5133  func (m *ErrorDetail_TransactionRetry) MarshalTo(dAtA []byte) (int, error) {
  5134  	i := 0
  5135  	if m.TransactionRetry != nil {
  5136  		dAtA[i] = 0x3a
  5137  		i++
  5138  		i = encodeVarintErrors(dAtA, i, uint64(m.TransactionRetry.Size()))
  5139  		n30, err := m.TransactionRetry.MarshalTo(dAtA[i:])
  5140  		if err != nil {
  5141  			return 0, err
  5142  		}
  5143  		i += n30
  5144  	}
  5145  	return i, nil
  5146  }
  5147  func (m *ErrorDetail_TransactionStatus) MarshalTo(dAtA []byte) (int, error) {
  5148  	i := 0
  5149  	if m.TransactionStatus != nil {
  5150  		dAtA[i] = 0x42
  5151  		i++
  5152  		i = encodeVarintErrors(dAtA, i, uint64(m.TransactionStatus.Size()))
  5153  		n31, err := m.TransactionStatus.MarshalTo(dAtA[i:])
  5154  		if err != nil {
  5155  			return 0, err
  5156  		}
  5157  		i += n31
  5158  	}
  5159  	return i, nil
  5160  }
  5161  func (m *ErrorDetail_WriteIntent) MarshalTo(dAtA []byte) (int, error) {
  5162  	i := 0
  5163  	if m.WriteIntent != nil {
  5164  		dAtA[i] = 0x4a
  5165  		i++
  5166  		i = encodeVarintErrors(dAtA, i, uint64(m.WriteIntent.Size()))
  5167  		n32, err := m.WriteIntent.MarshalTo(dAtA[i:])
  5168  		if err != nil {
  5169  			return 0, err
  5170  		}
  5171  		i += n32
  5172  	}
  5173  	return i, nil
  5174  }
  5175  func (m *ErrorDetail_WriteTooOld) MarshalTo(dAtA []byte) (int, error) {
  5176  	i := 0
  5177  	if m.WriteTooOld != nil {
  5178  		dAtA[i] = 0x52
  5179  		i++
  5180  		i = encodeVarintErrors(dAtA, i, uint64(m.WriteTooOld.Size()))
  5181  		n33, err := m.WriteTooOld.MarshalTo(dAtA[i:])
  5182  		if err != nil {
  5183  			return 0, err
  5184  		}
  5185  		i += n33
  5186  	}
  5187  	return i, nil
  5188  }
  5189  func (m *ErrorDetail_OpRequiresTxn) MarshalTo(dAtA []byte) (int, error) {
  5190  	i := 0
  5191  	if m.OpRequiresTxn != nil {
  5192  		dAtA[i] = 0x5a
  5193  		i++
  5194  		i = encodeVarintErrors(dAtA, i, uint64(m.OpRequiresTxn.Size()))
  5195  		n34, err := m.OpRequiresTxn.MarshalTo(dAtA[i:])
  5196  		if err != nil {
  5197  			return 0, err
  5198  		}
  5199  		i += n34
  5200  	}
  5201  	return i, nil
  5202  }
  5203  func (m *ErrorDetail_ConditionFailed) MarshalTo(dAtA []byte) (int, error) {
  5204  	i := 0
  5205  	if m.ConditionFailed != nil {
  5206  		dAtA[i] = 0x62
  5207  		i++
  5208  		i = encodeVarintErrors(dAtA, i, uint64(m.ConditionFailed.Size()))
  5209  		n35, err := m.ConditionFailed.MarshalTo(dAtA[i:])
  5210  		if err != nil {
  5211  			return 0, err
  5212  		}
  5213  		i += n35
  5214  	}
  5215  	return i, nil
  5216  }
  5217  func (m *ErrorDetail_LeaseRejected) MarshalTo(dAtA []byte) (int, error) {
  5218  	i := 0
  5219  	if m.LeaseRejected != nil {
  5220  		dAtA[i] = 0x6a
  5221  		i++
  5222  		i = encodeVarintErrors(dAtA, i, uint64(m.LeaseRejected.Size()))
  5223  		n36, err := m.LeaseRejected.MarshalTo(dAtA[i:])
  5224  		if err != nil {
  5225  			return 0, err
  5226  		}
  5227  		i += n36
  5228  	}
  5229  	return i, nil
  5230  }
  5231  func (m *ErrorDetail_NodeUnavailable) MarshalTo(dAtA []byte) (int, error) {
  5232  	i := 0
  5233  	if m.NodeUnavailable != nil {
  5234  		dAtA[i] = 0x72
  5235  		i++
  5236  		i = encodeVarintErrors(dAtA, i, uint64(m.NodeUnavailable.Size()))
  5237  		n37, err := m.NodeUnavailable.MarshalTo(dAtA[i:])
  5238  		if err != nil {
  5239  			return 0, err
  5240  		}
  5241  		i += n37
  5242  	}
  5243  	return i, nil
  5244  }
  5245  func (m *ErrorDetail_Send) MarshalTo(dAtA []byte) (int, error) {
  5246  	i := 0
  5247  	if m.Send != nil {
  5248  		dAtA[i] = 0x7a
  5249  		i++
  5250  		i = encodeVarintErrors(dAtA, i, uint64(m.Send.Size()))
  5251  		n38, err := m.Send.MarshalTo(dAtA[i:])
  5252  		if err != nil {
  5253  			return 0, err
  5254  		}
  5255  		i += n38
  5256  	}
  5257  	return i, nil
  5258  }
  5259  func (m *ErrorDetail_RaftGroupDeleted) MarshalTo(dAtA []byte) (int, error) {
  5260  	i := 0
  5261  	if m.RaftGroupDeleted != nil {
  5262  		dAtA[i] = 0x82
  5263  		i++
  5264  		dAtA[i] = 0x1
  5265  		i++
  5266  		i = encodeVarintErrors(dAtA, i, uint64(m.RaftGroupDeleted.Size()))
  5267  		n39, err := m.RaftGroupDeleted.MarshalTo(dAtA[i:])
  5268  		if err != nil {
  5269  			return 0, err
  5270  		}
  5271  		i += n39
  5272  	}
  5273  	return i, nil
  5274  }
  5275  func (m *ErrorDetail_ReplicaCorruption) MarshalTo(dAtA []byte) (int, error) {
  5276  	i := 0
  5277  	if m.ReplicaCorruption != nil {
  5278  		dAtA[i] = 0x8a
  5279  		i++
  5280  		dAtA[i] = 0x1
  5281  		i++
  5282  		i = encodeVarintErrors(dAtA, i, uint64(m.ReplicaCorruption.Size()))
  5283  		n40, err := m.ReplicaCorruption.MarshalTo(dAtA[i:])
  5284  		if err != nil {
  5285  			return 0, err
  5286  		}
  5287  		i += n40
  5288  	}
  5289  	return i, nil
  5290  }
  5291  func (m *ErrorDetail_ReplicaTooOld) MarshalTo(dAtA []byte) (int, error) {
  5292  	i := 0
  5293  	if m.ReplicaTooOld != nil {
  5294  		dAtA[i] = 0x92
  5295  		i++
  5296  		dAtA[i] = 0x1
  5297  		i++
  5298  		i = encodeVarintErrors(dAtA, i, uint64(m.ReplicaTooOld.Size()))
  5299  		n41, err := m.ReplicaTooOld.MarshalTo(dAtA[i:])
  5300  		if err != nil {
  5301  			return 0, err
  5302  		}
  5303  		i += n41
  5304  	}
  5305  	return i, nil
  5306  }
  5307  func (m *ErrorDetail_AmbiguousResult) MarshalTo(dAtA []byte) (int, error) {
  5308  	i := 0
  5309  	if m.AmbiguousResult != nil {
  5310  		dAtA[i] = 0xd2
  5311  		i++
  5312  		dAtA[i] = 0x1
  5313  		i++
  5314  		i = encodeVarintErrors(dAtA, i, uint64(m.AmbiguousResult.Size()))
  5315  		n42, err := m.AmbiguousResult.MarshalTo(dAtA[i:])
  5316  		if err != nil {
  5317  			return 0, err
  5318  		}
  5319  		i += n42
  5320  	}
  5321  	return i, nil
  5322  }
  5323  func (m *ErrorDetail_StoreNotFound) MarshalTo(dAtA []byte) (int, error) {
  5324  	i := 0
  5325  	if m.StoreNotFound != nil {
  5326  		dAtA[i] = 0xda
  5327  		i++
  5328  		dAtA[i] = 0x1
  5329  		i++
  5330  		i = encodeVarintErrors(dAtA, i, uint64(m.StoreNotFound.Size()))
  5331  		n43, err := m.StoreNotFound.MarshalTo(dAtA[i:])
  5332  		if err != nil {
  5333  			return 0, err
  5334  		}
  5335  		i += n43
  5336  	}
  5337  	return i, nil
  5338  }
  5339  func (m *ErrorDetail_TransactionRetryWithProtoRefresh) MarshalTo(dAtA []byte) (int, error) {
  5340  	i := 0
  5341  	if m.TransactionRetryWithProtoRefresh != nil {
  5342  		dAtA[i] = 0xe2
  5343  		i++
  5344  		dAtA[i] = 0x1
  5345  		i++
  5346  		i = encodeVarintErrors(dAtA, i, uint64(m.TransactionRetryWithProtoRefresh.Size()))
  5347  		n44, err := m.TransactionRetryWithProtoRefresh.MarshalTo(dAtA[i:])
  5348  		if err != nil {
  5349  			return 0, err
  5350  		}
  5351  		i += n44
  5352  	}
  5353  	return i, nil
  5354  }
  5355  func (m *ErrorDetail_IntegerOverflow) MarshalTo(dAtA []byte) (int, error) {
  5356  	i := 0
  5357  	if m.IntegerOverflow != nil {
  5358  		dAtA[i] = 0xfa
  5359  		i++
  5360  		dAtA[i] = 0x1
  5361  		i++
  5362  		i = encodeVarintErrors(dAtA, i, uint64(m.IntegerOverflow.Size()))
  5363  		n45, err := m.IntegerOverflow.MarshalTo(dAtA[i:])
  5364  		if err != nil {
  5365  			return 0, err
  5366  		}
  5367  		i += n45
  5368  	}
  5369  	return i, nil
  5370  }
  5371  func (m *ErrorDetail_UnsupportedRequest) MarshalTo(dAtA []byte) (int, error) {
  5372  	i := 0
  5373  	if m.UnsupportedRequest != nil {
  5374  		dAtA[i] = 0x82
  5375  		i++
  5376  		dAtA[i] = 0x2
  5377  		i++
  5378  		i = encodeVarintErrors(dAtA, i, uint64(m.UnsupportedRequest.Size()))
  5379  		n46, err := m.UnsupportedRequest.MarshalTo(dAtA[i:])
  5380  		if err != nil {
  5381  			return 0, err
  5382  		}
  5383  		i += n46
  5384  	}
  5385  	return i, nil
  5386  }
  5387  func (m *ErrorDetail_TimestampBefore) MarshalTo(dAtA []byte) (int, error) {
  5388  	i := 0
  5389  	if m.TimestampBefore != nil {
  5390  		dAtA[i] = 0x92
  5391  		i++
  5392  		dAtA[i] = 0x2
  5393  		i++
  5394  		i = encodeVarintErrors(dAtA, i, uint64(m.TimestampBefore.Size()))
  5395  		n47, err := m.TimestampBefore.MarshalTo(dAtA[i:])
  5396  		if err != nil {
  5397  			return 0, err
  5398  		}
  5399  		i += n47
  5400  	}
  5401  	return i, nil
  5402  }
  5403  func (m *ErrorDetail_TxnAlreadyEncounteredError) MarshalTo(dAtA []byte) (int, error) {
  5404  	i := 0
  5405  	if m.TxnAlreadyEncounteredError != nil {
  5406  		dAtA[i] = 0x9a
  5407  		i++
  5408  		dAtA[i] = 0x2
  5409  		i++
  5410  		i = encodeVarintErrors(dAtA, i, uint64(m.TxnAlreadyEncounteredError.Size()))
  5411  		n48, err := m.TxnAlreadyEncounteredError.MarshalTo(dAtA[i:])
  5412  		if err != nil {
  5413  			return 0, err
  5414  		}
  5415  		i += n48
  5416  	}
  5417  	return i, nil
  5418  }
  5419  func (m *ErrorDetail_IntentMissing) MarshalTo(dAtA []byte) (int, error) {
  5420  	i := 0
  5421  	if m.IntentMissing != nil {
  5422  		dAtA[i] = 0xa2
  5423  		i++
  5424  		dAtA[i] = 0x2
  5425  		i++
  5426  		i = encodeVarintErrors(dAtA, i, uint64(m.IntentMissing.Size()))
  5427  		n49, err := m.IntentMissing.MarshalTo(dAtA[i:])
  5428  		if err != nil {
  5429  			return 0, err
  5430  		}
  5431  		i += n49
  5432  	}
  5433  	return i, nil
  5434  }
  5435  func (m *ErrorDetail_MergeInProgress) MarshalTo(dAtA []byte) (int, error) {
  5436  	i := 0
  5437  	if m.MergeInProgress != nil {
  5438  		dAtA[i] = 0xaa
  5439  		i++
  5440  		dAtA[i] = 0x2
  5441  		i++
  5442  		i = encodeVarintErrors(dAtA, i, uint64(m.MergeInProgress.Size()))
  5443  		n50, err := m.MergeInProgress.MarshalTo(dAtA[i:])
  5444  		if err != nil {
  5445  			return 0, err
  5446  		}
  5447  		i += n50
  5448  	}
  5449  	return i, nil
  5450  }
  5451  func (m *ErrorDetail_RangefeedRetry) MarshalTo(dAtA []byte) (int, error) {
  5452  	i := 0
  5453  	if m.RangefeedRetry != nil {
  5454  		dAtA[i] = 0xb2
  5455  		i++
  5456  		dAtA[i] = 0x2
  5457  		i++
  5458  		i = encodeVarintErrors(dAtA, i, uint64(m.RangefeedRetry.Size()))
  5459  		n51, err := m.RangefeedRetry.MarshalTo(dAtA[i:])
  5460  		if err != nil {
  5461  			return 0, err
  5462  		}
  5463  		i += n51
  5464  	}
  5465  	return i, nil
  5466  }
  5467  func (m *ErrorDetail_IndeterminateCommit) MarshalTo(dAtA []byte) (int, error) {
  5468  	i := 0
  5469  	if m.IndeterminateCommit != nil {
  5470  		dAtA[i] = 0xba
  5471  		i++
  5472  		dAtA[i] = 0x2
  5473  		i++
  5474  		i = encodeVarintErrors(dAtA, i, uint64(m.IndeterminateCommit.Size()))
  5475  		n52, err := m.IndeterminateCommit.MarshalTo(dAtA[i:])
  5476  		if err != nil {
  5477  			return 0, err
  5478  		}
  5479  		i += n52
  5480  	}
  5481  	return i, nil
  5482  }
  5483  func (m *ErrPosition) Marshal() (dAtA []byte, err error) {
  5484  	size := m.Size()
  5485  	dAtA = make([]byte, size)
  5486  	n, err := m.MarshalTo(dAtA)
  5487  	if err != nil {
  5488  		return nil, err
  5489  	}
  5490  	return dAtA[:n], nil
  5491  }
  5492  
  5493  func (m *ErrPosition) MarshalTo(dAtA []byte) (int, error) {
  5494  	var i int
  5495  	_ = i
  5496  	var l int
  5497  	_ = l
  5498  	dAtA[i] = 0x8
  5499  	i++
  5500  	i = encodeVarintErrors(dAtA, i, uint64(m.Index))
  5501  	return i, nil
  5502  }
  5503  
  5504  func (m *Error) Marshal() (dAtA []byte, err error) {
  5505  	size := m.Size()
  5506  	dAtA = make([]byte, size)
  5507  	n, err := m.MarshalTo(dAtA)
  5508  	if err != nil {
  5509  		return nil, err
  5510  	}
  5511  	return dAtA[:n], nil
  5512  }
  5513  
  5514  func (m *Error) MarshalTo(dAtA []byte) (int, error) {
  5515  	var i int
  5516  	_ = i
  5517  	var l int
  5518  	_ = l
  5519  	dAtA[i] = 0xa
  5520  	i++
  5521  	i = encodeVarintErrors(dAtA, i, uint64(len(m.Message)))
  5522  	i += copy(dAtA[i:], m.Message)
  5523  	dAtA[i] = 0x18
  5524  	i++
  5525  	i = encodeVarintErrors(dAtA, i, uint64(m.TransactionRestart))
  5526  	if m.UnexposedTxn != nil {
  5527  		dAtA[i] = 0x22
  5528  		i++
  5529  		i = encodeVarintErrors(dAtA, i, uint64(m.UnexposedTxn.Size()))
  5530  		n53, err := m.UnexposedTxn.MarshalTo(dAtA[i:])
  5531  		if err != nil {
  5532  			return 0, err
  5533  		}
  5534  		i += n53
  5535  	}
  5536  	dAtA[i] = 0x28
  5537  	i++
  5538  	i = encodeVarintErrors(dAtA, i, uint64(m.OriginNode))
  5539  	dAtA[i] = 0x32
  5540  	i++
  5541  	i = encodeVarintErrors(dAtA, i, uint64(m.Detail.Size()))
  5542  	n54, err := m.Detail.MarshalTo(dAtA[i:])
  5543  	if err != nil {
  5544  		return 0, err
  5545  	}
  5546  	i += n54
  5547  	if m.Index != nil {
  5548  		dAtA[i] = 0x3a
  5549  		i++
  5550  		i = encodeVarintErrors(dAtA, i, uint64(m.Index.Size()))
  5551  		n55, err := m.Index.MarshalTo(dAtA[i:])
  5552  		if err != nil {
  5553  			return 0, err
  5554  		}
  5555  		i += n55
  5556  	}
  5557  	dAtA[i] = 0x42
  5558  	i++
  5559  	i = encodeVarintErrors(dAtA, i, uint64(m.Now.Size()))
  5560  	n56, err := m.Now.MarshalTo(dAtA[i:])
  5561  	if err != nil {
  5562  		return 0, err
  5563  	}
  5564  	i += n56
  5565  	return i, nil
  5566  }
  5567  
  5568  func encodeVarintErrors(dAtA []byte, offset int, v uint64) int {
  5569  	for v >= 1<<7 {
  5570  		dAtA[offset] = uint8(v&0x7f | 0x80)
  5571  		v >>= 7
  5572  		offset++
  5573  	}
  5574  	dAtA[offset] = uint8(v)
  5575  	return offset + 1
  5576  }
  5577  func (m *NotLeaseHolderError) Size() (n int) {
  5578  	if m == nil {
  5579  		return 0
  5580  	}
  5581  	var l int
  5582  	_ = l
  5583  	l = m.Replica.Size()
  5584  	n += 1 + l + sovErrors(uint64(l))
  5585  	if m.LeaseHolder != nil {
  5586  		l = m.LeaseHolder.Size()
  5587  		n += 1 + l + sovErrors(uint64(l))
  5588  	}
  5589  	n += 1 + sovErrors(uint64(m.RangeID))
  5590  	if m.Lease != nil {
  5591  		l = m.Lease.Size()
  5592  		n += 1 + l + sovErrors(uint64(l))
  5593  	}
  5594  	l = len(m.CustomMsg)
  5595  	n += 1 + l + sovErrors(uint64(l))
  5596  	return n
  5597  }
  5598  
  5599  func (m *NodeUnavailableError) Size() (n int) {
  5600  	if m == nil {
  5601  		return 0
  5602  	}
  5603  	var l int
  5604  	_ = l
  5605  	return n
  5606  }
  5607  
  5608  func (m *UnsupportedRequestError) Size() (n int) {
  5609  	if m == nil {
  5610  		return 0
  5611  	}
  5612  	var l int
  5613  	_ = l
  5614  	return n
  5615  }
  5616  
  5617  func (m *RangeNotFoundError) Size() (n int) {
  5618  	if m == nil {
  5619  		return 0
  5620  	}
  5621  	var l int
  5622  	_ = l
  5623  	n += 1 + sovErrors(uint64(m.RangeID))
  5624  	n += 1 + sovErrors(uint64(m.StoreID))
  5625  	return n
  5626  }
  5627  
  5628  func (m *RangeKeyMismatchError) Size() (n int) {
  5629  	if m == nil {
  5630  		return 0
  5631  	}
  5632  	var l int
  5633  	_ = l
  5634  	if m.RequestStartKey != nil {
  5635  		l = len(m.RequestStartKey)
  5636  		n += 1 + l + sovErrors(uint64(l))
  5637  	}
  5638  	if m.RequestEndKey != nil {
  5639  		l = len(m.RequestEndKey)
  5640  		n += 1 + l + sovErrors(uint64(l))
  5641  	}
  5642  	l = m.MismatchedRange.Size()
  5643  	n += 1 + l + sovErrors(uint64(l))
  5644  	if m.SuggestedRange != nil {
  5645  		l = m.SuggestedRange.Size()
  5646  		n += 1 + l + sovErrors(uint64(l))
  5647  	}
  5648  	return n
  5649  }
  5650  
  5651  func (m *ReadWithinUncertaintyIntervalError) Size() (n int) {
  5652  	if m == nil {
  5653  		return 0
  5654  	}
  5655  	var l int
  5656  	_ = l
  5657  	l = m.ReadTimestamp.Size()
  5658  	n += 1 + l + sovErrors(uint64(l))
  5659  	l = m.ExistingTimestamp.Size()
  5660  	n += 1 + l + sovErrors(uint64(l))
  5661  	if m.MaxTimestamp != nil {
  5662  		l = m.MaxTimestamp.Size()
  5663  		n += 1 + l + sovErrors(uint64(l))
  5664  	}
  5665  	if len(m.ObservedTimestamps) > 0 {
  5666  		for _, e := range m.ObservedTimestamps {
  5667  			l = e.Size()
  5668  			n += 1 + l + sovErrors(uint64(l))
  5669  		}
  5670  	}
  5671  	return n
  5672  }
  5673  
  5674  func (m *TransactionAbortedError) Size() (n int) {
  5675  	if m == nil {
  5676  		return 0
  5677  	}
  5678  	var l int
  5679  	_ = l
  5680  	n += 1 + sovErrors(uint64(m.Reason))
  5681  	return n
  5682  }
  5683  
  5684  func (m *TransactionPushError) Size() (n int) {
  5685  	if m == nil {
  5686  		return 0
  5687  	}
  5688  	var l int
  5689  	_ = l
  5690  	l = m.PusheeTxn.Size()
  5691  	n += 1 + l + sovErrors(uint64(l))
  5692  	return n
  5693  }
  5694  
  5695  func (m *TransactionRetryError) Size() (n int) {
  5696  	if m == nil {
  5697  		return 0
  5698  	}
  5699  	var l int
  5700  	_ = l
  5701  	n += 1 + sovErrors(uint64(m.Reason))
  5702  	l = len(m.ExtraMsg)
  5703  	n += 1 + l + sovErrors(uint64(l))
  5704  	return n
  5705  }
  5706  
  5707  func (m *TransactionStatusError) Size() (n int) {
  5708  	if m == nil {
  5709  		return 0
  5710  	}
  5711  	var l int
  5712  	_ = l
  5713  	l = len(m.Msg)
  5714  	n += 1 + l + sovErrors(uint64(l))
  5715  	n += 1 + sovErrors(uint64(m.Reason))
  5716  	return n
  5717  }
  5718  
  5719  func (m *WriteIntentError) Size() (n int) {
  5720  	if m == nil {
  5721  		return 0
  5722  	}
  5723  	var l int
  5724  	_ = l
  5725  	if len(m.Intents) > 0 {
  5726  		for _, e := range m.Intents {
  5727  			l = e.Size()
  5728  			n += 1 + l + sovErrors(uint64(l))
  5729  		}
  5730  	}
  5731  	return n
  5732  }
  5733  
  5734  func (m *WriteTooOldError) Size() (n int) {
  5735  	if m == nil {
  5736  		return 0
  5737  	}
  5738  	var l int
  5739  	_ = l
  5740  	l = m.Timestamp.Size()
  5741  	n += 1 + l + sovErrors(uint64(l))
  5742  	l = m.ActualTimestamp.Size()
  5743  	n += 1 + l + sovErrors(uint64(l))
  5744  	return n
  5745  }
  5746  
  5747  func (m *OpRequiresTxnError) Size() (n int) {
  5748  	if m == nil {
  5749  		return 0
  5750  	}
  5751  	var l int
  5752  	_ = l
  5753  	return n
  5754  }
  5755  
  5756  func (m *ConditionFailedError) Size() (n int) {
  5757  	if m == nil {
  5758  		return 0
  5759  	}
  5760  	var l int
  5761  	_ = l
  5762  	if m.ActualValue != nil {
  5763  		l = m.ActualValue.Size()
  5764  		n += 1 + l + sovErrors(uint64(l))
  5765  	}
  5766  	return n
  5767  }
  5768  
  5769  func (m *LeaseRejectedError) Size() (n int) {
  5770  	if m == nil {
  5771  		return 0
  5772  	}
  5773  	var l int
  5774  	_ = l
  5775  	l = len(m.Message)
  5776  	n += 1 + l + sovErrors(uint64(l))
  5777  	l = m.Requested.Size()
  5778  	n += 1 + l + sovErrors(uint64(l))
  5779  	l = m.Existing.Size()
  5780  	n += 1 + l + sovErrors(uint64(l))
  5781  	return n
  5782  }
  5783  
  5784  func (m *SendError) Size() (n int) {
  5785  	if m == nil {
  5786  		return 0
  5787  	}
  5788  	var l int
  5789  	_ = l
  5790  	l = len(m.Message)
  5791  	n += 1 + l + sovErrors(uint64(l))
  5792  	return n
  5793  }
  5794  
  5795  func (m *AmbiguousResultError) Size() (n int) {
  5796  	if m == nil {
  5797  		return 0
  5798  	}
  5799  	var l int
  5800  	_ = l
  5801  	l = len(m.Message)
  5802  	n += 1 + l + sovErrors(uint64(l))
  5803  	if m.WrappedErr != nil {
  5804  		l = m.WrappedErr.Size()
  5805  		n += 1 + l + sovErrors(uint64(l))
  5806  	}
  5807  	return n
  5808  }
  5809  
  5810  func (m *RaftGroupDeletedError) Size() (n int) {
  5811  	if m == nil {
  5812  		return 0
  5813  	}
  5814  	var l int
  5815  	_ = l
  5816  	return n
  5817  }
  5818  
  5819  func (m *ReplicaCorruptionError) Size() (n int) {
  5820  	if m == nil {
  5821  		return 0
  5822  	}
  5823  	var l int
  5824  	_ = l
  5825  	l = len(m.ErrorMsg)
  5826  	n += 1 + l + sovErrors(uint64(l))
  5827  	n += 2
  5828  	return n
  5829  }
  5830  
  5831  func (m *ReplicaTooOldError) Size() (n int) {
  5832  	if m == nil {
  5833  		return 0
  5834  	}
  5835  	var l int
  5836  	_ = l
  5837  	n += 1 + sovErrors(uint64(m.ReplicaID))
  5838  	return n
  5839  }
  5840  
  5841  func (m *StoreNotFoundError) Size() (n int) {
  5842  	if m == nil {
  5843  		return 0
  5844  	}
  5845  	var l int
  5846  	_ = l
  5847  	n += 1 + sovErrors(uint64(m.StoreID))
  5848  	return n
  5849  }
  5850  
  5851  func (m *UnhandledRetryableError) Size() (n int) {
  5852  	if m == nil {
  5853  		return 0
  5854  	}
  5855  	var l int
  5856  	_ = l
  5857  	l = m.PErr.Size()
  5858  	n += 1 + l + sovErrors(uint64(l))
  5859  	return n
  5860  }
  5861  
  5862  func (m *TransactionRetryWithProtoRefreshError) Size() (n int) {
  5863  	if m == nil {
  5864  		return 0
  5865  	}
  5866  	var l int
  5867  	_ = l
  5868  	l = len(m.Msg)
  5869  	n += 1 + l + sovErrors(uint64(l))
  5870  	l = m.TxnID.Size()
  5871  	n += 1 + l + sovErrors(uint64(l))
  5872  	l = m.Transaction.Size()
  5873  	n += 1 + l + sovErrors(uint64(l))
  5874  	return n
  5875  }
  5876  
  5877  func (m *TxnAlreadyEncounteredErrorError) Size() (n int) {
  5878  	if m == nil {
  5879  		return 0
  5880  	}
  5881  	var l int
  5882  	_ = l
  5883  	l = len(m.PrevError)
  5884  	n += 1 + l + sovErrors(uint64(l))
  5885  	return n
  5886  }
  5887  
  5888  func (m *IntegerOverflowError) Size() (n int) {
  5889  	if m == nil {
  5890  		return 0
  5891  	}
  5892  	var l int
  5893  	_ = l
  5894  	if m.Key != nil {
  5895  		l = len(m.Key)
  5896  		n += 1 + l + sovErrors(uint64(l))
  5897  	}
  5898  	n += 1 + sovErrors(uint64(m.CurrentValue))
  5899  	n += 1 + sovErrors(uint64(m.IncrementValue))
  5900  	return n
  5901  }
  5902  
  5903  func (m *BatchTimestampBeforeGCError) Size() (n int) {
  5904  	if m == nil {
  5905  		return 0
  5906  	}
  5907  	var l int
  5908  	_ = l
  5909  	l = m.Timestamp.Size()
  5910  	n += 1 + l + sovErrors(uint64(l))
  5911  	l = m.Threshold.Size()
  5912  	n += 1 + l + sovErrors(uint64(l))
  5913  	return n
  5914  }
  5915  
  5916  func (m *IntentMissingError) Size() (n int) {
  5917  	if m == nil {
  5918  		return 0
  5919  	}
  5920  	var l int
  5921  	_ = l
  5922  	if m.WrongIntent != nil {
  5923  		l = m.WrongIntent.Size()
  5924  		n += 1 + l + sovErrors(uint64(l))
  5925  	}
  5926  	if m.Key != nil {
  5927  		l = len(m.Key)
  5928  		n += 1 + l + sovErrors(uint64(l))
  5929  	}
  5930  	return n
  5931  }
  5932  
  5933  func (m *MergeInProgressError) Size() (n int) {
  5934  	if m == nil {
  5935  		return 0
  5936  	}
  5937  	var l int
  5938  	_ = l
  5939  	return n
  5940  }
  5941  
  5942  func (m *RangeFeedRetryError) Size() (n int) {
  5943  	if m == nil {
  5944  		return 0
  5945  	}
  5946  	var l int
  5947  	_ = l
  5948  	n += 1 + sovErrors(uint64(m.Reason))
  5949  	return n
  5950  }
  5951  
  5952  func (m *IndeterminateCommitError) Size() (n int) {
  5953  	if m == nil {
  5954  		return 0
  5955  	}
  5956  	var l int
  5957  	_ = l
  5958  	l = m.StagingTxn.Size()
  5959  	n += 1 + l + sovErrors(uint64(l))
  5960  	return n
  5961  }
  5962  
  5963  func (m *ErrorDetail) Size() (n int) {
  5964  	if m == nil {
  5965  		return 0
  5966  	}
  5967  	var l int
  5968  	_ = l
  5969  	if m.Value != nil {
  5970  		n += m.Value.Size()
  5971  	}
  5972  	return n
  5973  }
  5974  
  5975  func (m *ErrorDetail_NotLeaseHolder) Size() (n int) {
  5976  	if m == nil {
  5977  		return 0
  5978  	}
  5979  	var l int
  5980  	_ = l
  5981  	if m.NotLeaseHolder != nil {
  5982  		l = m.NotLeaseHolder.Size()
  5983  		n += 1 + l + sovErrors(uint64(l))
  5984  	}
  5985  	return n
  5986  }
  5987  func (m *ErrorDetail_RangeNotFound) Size() (n int) {
  5988  	if m == nil {
  5989  		return 0
  5990  	}
  5991  	var l int
  5992  	_ = l
  5993  	if m.RangeNotFound != nil {
  5994  		l = m.RangeNotFound.Size()
  5995  		n += 1 + l + sovErrors(uint64(l))
  5996  	}
  5997  	return n
  5998  }
  5999  func (m *ErrorDetail_RangeKeyMismatch) Size() (n int) {
  6000  	if m == nil {
  6001  		return 0
  6002  	}
  6003  	var l int
  6004  	_ = l
  6005  	if m.RangeKeyMismatch != nil {
  6006  		l = m.RangeKeyMismatch.Size()
  6007  		n += 1 + l + sovErrors(uint64(l))
  6008  	}
  6009  	return n
  6010  }
  6011  func (m *ErrorDetail_ReadWithinUncertaintyInterval) Size() (n int) {
  6012  	if m == nil {
  6013  		return 0
  6014  	}
  6015  	var l int
  6016  	_ = l
  6017  	if m.ReadWithinUncertaintyInterval != nil {
  6018  		l = m.ReadWithinUncertaintyInterval.Size()
  6019  		n += 1 + l + sovErrors(uint64(l))
  6020  	}
  6021  	return n
  6022  }
  6023  func (m *ErrorDetail_TransactionAborted) Size() (n int) {
  6024  	if m == nil {
  6025  		return 0
  6026  	}
  6027  	var l int
  6028  	_ = l
  6029  	if m.TransactionAborted != nil {
  6030  		l = m.TransactionAborted.Size()
  6031  		n += 1 + l + sovErrors(uint64(l))
  6032  	}
  6033  	return n
  6034  }
  6035  func (m *ErrorDetail_TransactionPush) Size() (n int) {
  6036  	if m == nil {
  6037  		return 0
  6038  	}
  6039  	var l int
  6040  	_ = l
  6041  	if m.TransactionPush != nil {
  6042  		l = m.TransactionPush.Size()
  6043  		n += 1 + l + sovErrors(uint64(l))
  6044  	}
  6045  	return n
  6046  }
  6047  func (m *ErrorDetail_TransactionRetry) Size() (n int) {
  6048  	if m == nil {
  6049  		return 0
  6050  	}
  6051  	var l int
  6052  	_ = l
  6053  	if m.TransactionRetry != nil {
  6054  		l = m.TransactionRetry.Size()
  6055  		n += 1 + l + sovErrors(uint64(l))
  6056  	}
  6057  	return n
  6058  }
  6059  func (m *ErrorDetail_TransactionStatus) Size() (n int) {
  6060  	if m == nil {
  6061  		return 0
  6062  	}
  6063  	var l int
  6064  	_ = l
  6065  	if m.TransactionStatus != nil {
  6066  		l = m.TransactionStatus.Size()
  6067  		n += 1 + l + sovErrors(uint64(l))
  6068  	}
  6069  	return n
  6070  }
  6071  func (m *ErrorDetail_WriteIntent) Size() (n int) {
  6072  	if m == nil {
  6073  		return 0
  6074  	}
  6075  	var l int
  6076  	_ = l
  6077  	if m.WriteIntent != nil {
  6078  		l = m.WriteIntent.Size()
  6079  		n += 1 + l + sovErrors(uint64(l))
  6080  	}
  6081  	return n
  6082  }
  6083  func (m *ErrorDetail_WriteTooOld) Size() (n int) {
  6084  	if m == nil {
  6085  		return 0
  6086  	}
  6087  	var l int
  6088  	_ = l
  6089  	if m.WriteTooOld != nil {
  6090  		l = m.WriteTooOld.Size()
  6091  		n += 1 + l + sovErrors(uint64(l))
  6092  	}
  6093  	return n
  6094  }
  6095  func (m *ErrorDetail_OpRequiresTxn) Size() (n int) {
  6096  	if m == nil {
  6097  		return 0
  6098  	}
  6099  	var l int
  6100  	_ = l
  6101  	if m.OpRequiresTxn != nil {
  6102  		l = m.OpRequiresTxn.Size()
  6103  		n += 1 + l + sovErrors(uint64(l))
  6104  	}
  6105  	return n
  6106  }
  6107  func (m *ErrorDetail_ConditionFailed) Size() (n int) {
  6108  	if m == nil {
  6109  		return 0
  6110  	}
  6111  	var l int
  6112  	_ = l
  6113  	if m.ConditionFailed != nil {
  6114  		l = m.ConditionFailed.Size()
  6115  		n += 1 + l + sovErrors(uint64(l))
  6116  	}
  6117  	return n
  6118  }
  6119  func (m *ErrorDetail_LeaseRejected) Size() (n int) {
  6120  	if m == nil {
  6121  		return 0
  6122  	}
  6123  	var l int
  6124  	_ = l
  6125  	if m.LeaseRejected != nil {
  6126  		l = m.LeaseRejected.Size()
  6127  		n += 1 + l + sovErrors(uint64(l))
  6128  	}
  6129  	return n
  6130  }
  6131  func (m *ErrorDetail_NodeUnavailable) Size() (n int) {
  6132  	if m == nil {
  6133  		return 0
  6134  	}
  6135  	var l int
  6136  	_ = l
  6137  	if m.NodeUnavailable != nil {
  6138  		l = m.NodeUnavailable.Size()
  6139  		n += 1 + l + sovErrors(uint64(l))
  6140  	}
  6141  	return n
  6142  }
  6143  func (m *ErrorDetail_Send) Size() (n int) {
  6144  	if m == nil {
  6145  		return 0
  6146  	}
  6147  	var l int
  6148  	_ = l
  6149  	if m.Send != nil {
  6150  		l = m.Send.Size()
  6151  		n += 1 + l + sovErrors(uint64(l))
  6152  	}
  6153  	return n
  6154  }
  6155  func (m *ErrorDetail_RaftGroupDeleted) Size() (n int) {
  6156  	if m == nil {
  6157  		return 0
  6158  	}
  6159  	var l int
  6160  	_ = l
  6161  	if m.RaftGroupDeleted != nil {
  6162  		l = m.RaftGroupDeleted.Size()
  6163  		n += 2 + l + sovErrors(uint64(l))
  6164  	}
  6165  	return n
  6166  }
  6167  func (m *ErrorDetail_ReplicaCorruption) Size() (n int) {
  6168  	if m == nil {
  6169  		return 0
  6170  	}
  6171  	var l int
  6172  	_ = l
  6173  	if m.ReplicaCorruption != nil {
  6174  		l = m.ReplicaCorruption.Size()
  6175  		n += 2 + l + sovErrors(uint64(l))
  6176  	}
  6177  	return n
  6178  }
  6179  func (m *ErrorDetail_ReplicaTooOld) Size() (n int) {
  6180  	if m == nil {
  6181  		return 0
  6182  	}
  6183  	var l int
  6184  	_ = l
  6185  	if m.ReplicaTooOld != nil {
  6186  		l = m.ReplicaTooOld.Size()
  6187  		n += 2 + l + sovErrors(uint64(l))
  6188  	}
  6189  	return n
  6190  }
  6191  func (m *ErrorDetail_AmbiguousResult) Size() (n int) {
  6192  	if m == nil {
  6193  		return 0
  6194  	}
  6195  	var l int
  6196  	_ = l
  6197  	if m.AmbiguousResult != nil {
  6198  		l = m.AmbiguousResult.Size()
  6199  		n += 2 + l + sovErrors(uint64(l))
  6200  	}
  6201  	return n
  6202  }
  6203  func (m *ErrorDetail_StoreNotFound) Size() (n int) {
  6204  	if m == nil {
  6205  		return 0
  6206  	}
  6207  	var l int
  6208  	_ = l
  6209  	if m.StoreNotFound != nil {
  6210  		l = m.StoreNotFound.Size()
  6211  		n += 2 + l + sovErrors(uint64(l))
  6212  	}
  6213  	return n
  6214  }
  6215  func (m *ErrorDetail_TransactionRetryWithProtoRefresh) Size() (n int) {
  6216  	if m == nil {
  6217  		return 0
  6218  	}
  6219  	var l int
  6220  	_ = l
  6221  	if m.TransactionRetryWithProtoRefresh != nil {
  6222  		l = m.TransactionRetryWithProtoRefresh.Size()
  6223  		n += 2 + l + sovErrors(uint64(l))
  6224  	}
  6225  	return n
  6226  }
  6227  func (m *ErrorDetail_IntegerOverflow) Size() (n int) {
  6228  	if m == nil {
  6229  		return 0
  6230  	}
  6231  	var l int
  6232  	_ = l
  6233  	if m.IntegerOverflow != nil {
  6234  		l = m.IntegerOverflow.Size()
  6235  		n += 2 + l + sovErrors(uint64(l))
  6236  	}
  6237  	return n
  6238  }
  6239  func (m *ErrorDetail_UnsupportedRequest) Size() (n int) {
  6240  	if m == nil {
  6241  		return 0
  6242  	}
  6243  	var l int
  6244  	_ = l
  6245  	if m.UnsupportedRequest != nil {
  6246  		l = m.UnsupportedRequest.Size()
  6247  		n += 2 + l + sovErrors(uint64(l))
  6248  	}
  6249  	return n
  6250  }
  6251  func (m *ErrorDetail_TimestampBefore) Size() (n int) {
  6252  	if m == nil {
  6253  		return 0
  6254  	}
  6255  	var l int
  6256  	_ = l
  6257  	if m.TimestampBefore != nil {
  6258  		l = m.TimestampBefore.Size()
  6259  		n += 2 + l + sovErrors(uint64(l))
  6260  	}
  6261  	return n
  6262  }
  6263  func (m *ErrorDetail_TxnAlreadyEncounteredError) Size() (n int) {
  6264  	if m == nil {
  6265  		return 0
  6266  	}
  6267  	var l int
  6268  	_ = l
  6269  	if m.TxnAlreadyEncounteredError != nil {
  6270  		l = m.TxnAlreadyEncounteredError.Size()
  6271  		n += 2 + l + sovErrors(uint64(l))
  6272  	}
  6273  	return n
  6274  }
  6275  func (m *ErrorDetail_IntentMissing) Size() (n int) {
  6276  	if m == nil {
  6277  		return 0
  6278  	}
  6279  	var l int
  6280  	_ = l
  6281  	if m.IntentMissing != nil {
  6282  		l = m.IntentMissing.Size()
  6283  		n += 2 + l + sovErrors(uint64(l))
  6284  	}
  6285  	return n
  6286  }
  6287  func (m *ErrorDetail_MergeInProgress) Size() (n int) {
  6288  	if m == nil {
  6289  		return 0
  6290  	}
  6291  	var l int
  6292  	_ = l
  6293  	if m.MergeInProgress != nil {
  6294  		l = m.MergeInProgress.Size()
  6295  		n += 2 + l + sovErrors(uint64(l))
  6296  	}
  6297  	return n
  6298  }
  6299  func (m *ErrorDetail_RangefeedRetry) Size() (n int) {
  6300  	if m == nil {
  6301  		return 0
  6302  	}
  6303  	var l int
  6304  	_ = l
  6305  	if m.RangefeedRetry != nil {
  6306  		l = m.RangefeedRetry.Size()
  6307  		n += 2 + l + sovErrors(uint64(l))
  6308  	}
  6309  	return n
  6310  }
  6311  func (m *ErrorDetail_IndeterminateCommit) Size() (n int) {
  6312  	if m == nil {
  6313  		return 0
  6314  	}
  6315  	var l int
  6316  	_ = l
  6317  	if m.IndeterminateCommit != nil {
  6318  		l = m.IndeterminateCommit.Size()
  6319  		n += 2 + l + sovErrors(uint64(l))
  6320  	}
  6321  	return n
  6322  }
  6323  func (m *ErrPosition) Size() (n int) {
  6324  	if m == nil {
  6325  		return 0
  6326  	}
  6327  	var l int
  6328  	_ = l
  6329  	n += 1 + sovErrors(uint64(m.Index))
  6330  	return n
  6331  }
  6332  
  6333  func (m *Error) Size() (n int) {
  6334  	if m == nil {
  6335  		return 0
  6336  	}
  6337  	var l int
  6338  	_ = l
  6339  	l = len(m.Message)
  6340  	n += 1 + l + sovErrors(uint64(l))
  6341  	n += 1 + sovErrors(uint64(m.TransactionRestart))
  6342  	if m.UnexposedTxn != nil {
  6343  		l = m.UnexposedTxn.Size()
  6344  		n += 1 + l + sovErrors(uint64(l))
  6345  	}
  6346  	n += 1 + sovErrors(uint64(m.OriginNode))
  6347  	l = m.Detail.Size()
  6348  	n += 1 + l + sovErrors(uint64(l))
  6349  	if m.Index != nil {
  6350  		l = m.Index.Size()
  6351  		n += 1 + l + sovErrors(uint64(l))
  6352  	}
  6353  	l = m.Now.Size()
  6354  	n += 1 + l + sovErrors(uint64(l))
  6355  	return n
  6356  }
  6357  
  6358  func sovErrors(x uint64) (n int) {
  6359  	for {
  6360  		n++
  6361  		x >>= 7
  6362  		if x == 0 {
  6363  			break
  6364  		}
  6365  	}
  6366  	return n
  6367  }
  6368  func sozErrors(x uint64) (n int) {
  6369  	return sovErrors(uint64((x << 1) ^ uint64((int64(x) >> 63))))
  6370  }
  6371  func (m *NotLeaseHolderError) Unmarshal(dAtA []byte) error {
  6372  	l := len(dAtA)
  6373  	iNdEx := 0
  6374  	for iNdEx < l {
  6375  		preIndex := iNdEx
  6376  		var wire uint64
  6377  		for shift := uint(0); ; shift += 7 {
  6378  			if shift >= 64 {
  6379  				return ErrIntOverflowErrors
  6380  			}
  6381  			if iNdEx >= l {
  6382  				return io.ErrUnexpectedEOF
  6383  			}
  6384  			b := dAtA[iNdEx]
  6385  			iNdEx++
  6386  			wire |= (uint64(b) & 0x7F) << shift
  6387  			if b < 0x80 {
  6388  				break
  6389  			}
  6390  		}
  6391  		fieldNum := int32(wire >> 3)
  6392  		wireType := int(wire & 0x7)
  6393  		if wireType == 4 {
  6394  			return fmt.Errorf("proto: NotLeaseHolderError: wiretype end group for non-group")
  6395  		}
  6396  		if fieldNum <= 0 {
  6397  			return fmt.Errorf("proto: NotLeaseHolderError: illegal tag %d (wire type %d)", fieldNum, wire)
  6398  		}
  6399  		switch fieldNum {
  6400  		case 1:
  6401  			if wireType != 2 {
  6402  				return fmt.Errorf("proto: wrong wireType = %d for field Replica", wireType)
  6403  			}
  6404  			var msglen int
  6405  			for shift := uint(0); ; shift += 7 {
  6406  				if shift >= 64 {
  6407  					return ErrIntOverflowErrors
  6408  				}
  6409  				if iNdEx >= l {
  6410  					return io.ErrUnexpectedEOF
  6411  				}
  6412  				b := dAtA[iNdEx]
  6413  				iNdEx++
  6414  				msglen |= (int(b) & 0x7F) << shift
  6415  				if b < 0x80 {
  6416  					break
  6417  				}
  6418  			}
  6419  			if msglen < 0 {
  6420  				return ErrInvalidLengthErrors
  6421  			}
  6422  			postIndex := iNdEx + msglen
  6423  			if postIndex > l {
  6424  				return io.ErrUnexpectedEOF
  6425  			}
  6426  			if err := m.Replica.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  6427  				return err
  6428  			}
  6429  			iNdEx = postIndex
  6430  		case 2:
  6431  			if wireType != 2 {
  6432  				return fmt.Errorf("proto: wrong wireType = %d for field LeaseHolder", wireType)
  6433  			}
  6434  			var msglen int
  6435  			for shift := uint(0); ; shift += 7 {
  6436  				if shift >= 64 {
  6437  					return ErrIntOverflowErrors
  6438  				}
  6439  				if iNdEx >= l {
  6440  					return io.ErrUnexpectedEOF
  6441  				}
  6442  				b := dAtA[iNdEx]
  6443  				iNdEx++
  6444  				msglen |= (int(b) & 0x7F) << shift
  6445  				if b < 0x80 {
  6446  					break
  6447  				}
  6448  			}
  6449  			if msglen < 0 {
  6450  				return ErrInvalidLengthErrors
  6451  			}
  6452  			postIndex := iNdEx + msglen
  6453  			if postIndex > l {
  6454  				return io.ErrUnexpectedEOF
  6455  			}
  6456  			if m.LeaseHolder == nil {
  6457  				m.LeaseHolder = &ReplicaDescriptor{}
  6458  			}
  6459  			if err := m.LeaseHolder.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  6460  				return err
  6461  			}
  6462  			iNdEx = postIndex
  6463  		case 3:
  6464  			if wireType != 0 {
  6465  				return fmt.Errorf("proto: wrong wireType = %d for field RangeID", wireType)
  6466  			}
  6467  			m.RangeID = 0
  6468  			for shift := uint(0); ; shift += 7 {
  6469  				if shift >= 64 {
  6470  					return ErrIntOverflowErrors
  6471  				}
  6472  				if iNdEx >= l {
  6473  					return io.ErrUnexpectedEOF
  6474  				}
  6475  				b := dAtA[iNdEx]
  6476  				iNdEx++
  6477  				m.RangeID |= (RangeID(b) & 0x7F) << shift
  6478  				if b < 0x80 {
  6479  					break
  6480  				}
  6481  			}
  6482  		case 4:
  6483  			if wireType != 2 {
  6484  				return fmt.Errorf("proto: wrong wireType = %d for field Lease", wireType)
  6485  			}
  6486  			var msglen int
  6487  			for shift := uint(0); ; shift += 7 {
  6488  				if shift >= 64 {
  6489  					return ErrIntOverflowErrors
  6490  				}
  6491  				if iNdEx >= l {
  6492  					return io.ErrUnexpectedEOF
  6493  				}
  6494  				b := dAtA[iNdEx]
  6495  				iNdEx++
  6496  				msglen |= (int(b) & 0x7F) << shift
  6497  				if b < 0x80 {
  6498  					break
  6499  				}
  6500  			}
  6501  			if msglen < 0 {
  6502  				return ErrInvalidLengthErrors
  6503  			}
  6504  			postIndex := iNdEx + msglen
  6505  			if postIndex > l {
  6506  				return io.ErrUnexpectedEOF
  6507  			}
  6508  			if m.Lease == nil {
  6509  				m.Lease = &Lease{}
  6510  			}
  6511  			if err := m.Lease.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  6512  				return err
  6513  			}
  6514  			iNdEx = postIndex
  6515  		case 5:
  6516  			if wireType != 2 {
  6517  				return fmt.Errorf("proto: wrong wireType = %d for field CustomMsg", wireType)
  6518  			}
  6519  			var stringLen uint64
  6520  			for shift := uint(0); ; shift += 7 {
  6521  				if shift >= 64 {
  6522  					return ErrIntOverflowErrors
  6523  				}
  6524  				if iNdEx >= l {
  6525  					return io.ErrUnexpectedEOF
  6526  				}
  6527  				b := dAtA[iNdEx]
  6528  				iNdEx++
  6529  				stringLen |= (uint64(b) & 0x7F) << shift
  6530  				if b < 0x80 {
  6531  					break
  6532  				}
  6533  			}
  6534  			intStringLen := int(stringLen)
  6535  			if intStringLen < 0 {
  6536  				return ErrInvalidLengthErrors
  6537  			}
  6538  			postIndex := iNdEx + intStringLen
  6539  			if postIndex > l {
  6540  				return io.ErrUnexpectedEOF
  6541  			}
  6542  			m.CustomMsg = string(dAtA[iNdEx:postIndex])
  6543  			iNdEx = postIndex
  6544  		default:
  6545  			iNdEx = preIndex
  6546  			skippy, err := skipErrors(dAtA[iNdEx:])
  6547  			if err != nil {
  6548  				return err
  6549  			}
  6550  			if skippy < 0 {
  6551  				return ErrInvalidLengthErrors
  6552  			}
  6553  			if (iNdEx + skippy) > l {
  6554  				return io.ErrUnexpectedEOF
  6555  			}
  6556  			iNdEx += skippy
  6557  		}
  6558  	}
  6559  
  6560  	if iNdEx > l {
  6561  		return io.ErrUnexpectedEOF
  6562  	}
  6563  	return nil
  6564  }
  6565  func (m *NodeUnavailableError) Unmarshal(dAtA []byte) error {
  6566  	l := len(dAtA)
  6567  	iNdEx := 0
  6568  	for iNdEx < l {
  6569  		preIndex := iNdEx
  6570  		var wire uint64
  6571  		for shift := uint(0); ; shift += 7 {
  6572  			if shift >= 64 {
  6573  				return ErrIntOverflowErrors
  6574  			}
  6575  			if iNdEx >= l {
  6576  				return io.ErrUnexpectedEOF
  6577  			}
  6578  			b := dAtA[iNdEx]
  6579  			iNdEx++
  6580  			wire |= (uint64(b) & 0x7F) << shift
  6581  			if b < 0x80 {
  6582  				break
  6583  			}
  6584  		}
  6585  		fieldNum := int32(wire >> 3)
  6586  		wireType := int(wire & 0x7)
  6587  		if wireType == 4 {
  6588  			return fmt.Errorf("proto: NodeUnavailableError: wiretype end group for non-group")
  6589  		}
  6590  		if fieldNum <= 0 {
  6591  			return fmt.Errorf("proto: NodeUnavailableError: illegal tag %d (wire type %d)", fieldNum, wire)
  6592  		}
  6593  		switch fieldNum {
  6594  		default:
  6595  			iNdEx = preIndex
  6596  			skippy, err := skipErrors(dAtA[iNdEx:])
  6597  			if err != nil {
  6598  				return err
  6599  			}
  6600  			if skippy < 0 {
  6601  				return ErrInvalidLengthErrors
  6602  			}
  6603  			if (iNdEx + skippy) > l {
  6604  				return io.ErrUnexpectedEOF
  6605  			}
  6606  			iNdEx += skippy
  6607  		}
  6608  	}
  6609  
  6610  	if iNdEx > l {
  6611  		return io.ErrUnexpectedEOF
  6612  	}
  6613  	return nil
  6614  }
  6615  func (m *UnsupportedRequestError) Unmarshal(dAtA []byte) error {
  6616  	l := len(dAtA)
  6617  	iNdEx := 0
  6618  	for iNdEx < l {
  6619  		preIndex := iNdEx
  6620  		var wire uint64
  6621  		for shift := uint(0); ; shift += 7 {
  6622  			if shift >= 64 {
  6623  				return ErrIntOverflowErrors
  6624  			}
  6625  			if iNdEx >= l {
  6626  				return io.ErrUnexpectedEOF
  6627  			}
  6628  			b := dAtA[iNdEx]
  6629  			iNdEx++
  6630  			wire |= (uint64(b) & 0x7F) << shift
  6631  			if b < 0x80 {
  6632  				break
  6633  			}
  6634  		}
  6635  		fieldNum := int32(wire >> 3)
  6636  		wireType := int(wire & 0x7)
  6637  		if wireType == 4 {
  6638  			return fmt.Errorf("proto: UnsupportedRequestError: wiretype end group for non-group")
  6639  		}
  6640  		if fieldNum <= 0 {
  6641  			return fmt.Errorf("proto: UnsupportedRequestError: illegal tag %d (wire type %d)", fieldNum, wire)
  6642  		}
  6643  		switch fieldNum {
  6644  		default:
  6645  			iNdEx = preIndex
  6646  			skippy, err := skipErrors(dAtA[iNdEx:])
  6647  			if err != nil {
  6648  				return err
  6649  			}
  6650  			if skippy < 0 {
  6651  				return ErrInvalidLengthErrors
  6652  			}
  6653  			if (iNdEx + skippy) > l {
  6654  				return io.ErrUnexpectedEOF
  6655  			}
  6656  			iNdEx += skippy
  6657  		}
  6658  	}
  6659  
  6660  	if iNdEx > l {
  6661  		return io.ErrUnexpectedEOF
  6662  	}
  6663  	return nil
  6664  }
  6665  func (m *RangeNotFoundError) Unmarshal(dAtA []byte) error {
  6666  	l := len(dAtA)
  6667  	iNdEx := 0
  6668  	for iNdEx < l {
  6669  		preIndex := iNdEx
  6670  		var wire uint64
  6671  		for shift := uint(0); ; shift += 7 {
  6672  			if shift >= 64 {
  6673  				return ErrIntOverflowErrors
  6674  			}
  6675  			if iNdEx >= l {
  6676  				return io.ErrUnexpectedEOF
  6677  			}
  6678  			b := dAtA[iNdEx]
  6679  			iNdEx++
  6680  			wire |= (uint64(b) & 0x7F) << shift
  6681  			if b < 0x80 {
  6682  				break
  6683  			}
  6684  		}
  6685  		fieldNum := int32(wire >> 3)
  6686  		wireType := int(wire & 0x7)
  6687  		if wireType == 4 {
  6688  			return fmt.Errorf("proto: RangeNotFoundError: wiretype end group for non-group")
  6689  		}
  6690  		if fieldNum <= 0 {
  6691  			return fmt.Errorf("proto: RangeNotFoundError: illegal tag %d (wire type %d)", fieldNum, wire)
  6692  		}
  6693  		switch fieldNum {
  6694  		case 1:
  6695  			if wireType != 0 {
  6696  				return fmt.Errorf("proto: wrong wireType = %d for field RangeID", wireType)
  6697  			}
  6698  			m.RangeID = 0
  6699  			for shift := uint(0); ; shift += 7 {
  6700  				if shift >= 64 {
  6701  					return ErrIntOverflowErrors
  6702  				}
  6703  				if iNdEx >= l {
  6704  					return io.ErrUnexpectedEOF
  6705  				}
  6706  				b := dAtA[iNdEx]
  6707  				iNdEx++
  6708  				m.RangeID |= (RangeID(b) & 0x7F) << shift
  6709  				if b < 0x80 {
  6710  					break
  6711  				}
  6712  			}
  6713  		case 2:
  6714  			if wireType != 0 {
  6715  				return fmt.Errorf("proto: wrong wireType = %d for field StoreID", wireType)
  6716  			}
  6717  			m.StoreID = 0
  6718  			for shift := uint(0); ; shift += 7 {
  6719  				if shift >= 64 {
  6720  					return ErrIntOverflowErrors
  6721  				}
  6722  				if iNdEx >= l {
  6723  					return io.ErrUnexpectedEOF
  6724  				}
  6725  				b := dAtA[iNdEx]
  6726  				iNdEx++
  6727  				m.StoreID |= (StoreID(b) & 0x7F) << shift
  6728  				if b < 0x80 {
  6729  					break
  6730  				}
  6731  			}
  6732  		default:
  6733  			iNdEx = preIndex
  6734  			skippy, err := skipErrors(dAtA[iNdEx:])
  6735  			if err != nil {
  6736  				return err
  6737  			}
  6738  			if skippy < 0 {
  6739  				return ErrInvalidLengthErrors
  6740  			}
  6741  			if (iNdEx + skippy) > l {
  6742  				return io.ErrUnexpectedEOF
  6743  			}
  6744  			iNdEx += skippy
  6745  		}
  6746  	}
  6747  
  6748  	if iNdEx > l {
  6749  		return io.ErrUnexpectedEOF
  6750  	}
  6751  	return nil
  6752  }
  6753  func (m *RangeKeyMismatchError) Unmarshal(dAtA []byte) error {
  6754  	l := len(dAtA)
  6755  	iNdEx := 0
  6756  	for iNdEx < l {
  6757  		preIndex := iNdEx
  6758  		var wire uint64
  6759  		for shift := uint(0); ; shift += 7 {
  6760  			if shift >= 64 {
  6761  				return ErrIntOverflowErrors
  6762  			}
  6763  			if iNdEx >= l {
  6764  				return io.ErrUnexpectedEOF
  6765  			}
  6766  			b := dAtA[iNdEx]
  6767  			iNdEx++
  6768  			wire |= (uint64(b) & 0x7F) << shift
  6769  			if b < 0x80 {
  6770  				break
  6771  			}
  6772  		}
  6773  		fieldNum := int32(wire >> 3)
  6774  		wireType := int(wire & 0x7)
  6775  		if wireType == 4 {
  6776  			return fmt.Errorf("proto: RangeKeyMismatchError: wiretype end group for non-group")
  6777  		}
  6778  		if fieldNum <= 0 {
  6779  			return fmt.Errorf("proto: RangeKeyMismatchError: illegal tag %d (wire type %d)", fieldNum, wire)
  6780  		}
  6781  		switch fieldNum {
  6782  		case 1:
  6783  			if wireType != 2 {
  6784  				return fmt.Errorf("proto: wrong wireType = %d for field RequestStartKey", wireType)
  6785  			}
  6786  			var byteLen int
  6787  			for shift := uint(0); ; shift += 7 {
  6788  				if shift >= 64 {
  6789  					return ErrIntOverflowErrors
  6790  				}
  6791  				if iNdEx >= l {
  6792  					return io.ErrUnexpectedEOF
  6793  				}
  6794  				b := dAtA[iNdEx]
  6795  				iNdEx++
  6796  				byteLen |= (int(b) & 0x7F) << shift
  6797  				if b < 0x80 {
  6798  					break
  6799  				}
  6800  			}
  6801  			if byteLen < 0 {
  6802  				return ErrInvalidLengthErrors
  6803  			}
  6804  			postIndex := iNdEx + byteLen
  6805  			if postIndex > l {
  6806  				return io.ErrUnexpectedEOF
  6807  			}
  6808  			m.RequestStartKey = append(m.RequestStartKey[:0], dAtA[iNdEx:postIndex]...)
  6809  			if m.RequestStartKey == nil {
  6810  				m.RequestStartKey = []byte{}
  6811  			}
  6812  			iNdEx = postIndex
  6813  		case 2:
  6814  			if wireType != 2 {
  6815  				return fmt.Errorf("proto: wrong wireType = %d for field RequestEndKey", wireType)
  6816  			}
  6817  			var byteLen int
  6818  			for shift := uint(0); ; shift += 7 {
  6819  				if shift >= 64 {
  6820  					return ErrIntOverflowErrors
  6821  				}
  6822  				if iNdEx >= l {
  6823  					return io.ErrUnexpectedEOF
  6824  				}
  6825  				b := dAtA[iNdEx]
  6826  				iNdEx++
  6827  				byteLen |= (int(b) & 0x7F) << shift
  6828  				if b < 0x80 {
  6829  					break
  6830  				}
  6831  			}
  6832  			if byteLen < 0 {
  6833  				return ErrInvalidLengthErrors
  6834  			}
  6835  			postIndex := iNdEx + byteLen
  6836  			if postIndex > l {
  6837  				return io.ErrUnexpectedEOF
  6838  			}
  6839  			m.RequestEndKey = append(m.RequestEndKey[:0], dAtA[iNdEx:postIndex]...)
  6840  			if m.RequestEndKey == nil {
  6841  				m.RequestEndKey = []byte{}
  6842  			}
  6843  			iNdEx = postIndex
  6844  		case 3:
  6845  			if wireType != 2 {
  6846  				return fmt.Errorf("proto: wrong wireType = %d for field MismatchedRange", wireType)
  6847  			}
  6848  			var msglen int
  6849  			for shift := uint(0); ; shift += 7 {
  6850  				if shift >= 64 {
  6851  					return ErrIntOverflowErrors
  6852  				}
  6853  				if iNdEx >= l {
  6854  					return io.ErrUnexpectedEOF
  6855  				}
  6856  				b := dAtA[iNdEx]
  6857  				iNdEx++
  6858  				msglen |= (int(b) & 0x7F) << shift
  6859  				if b < 0x80 {
  6860  					break
  6861  				}
  6862  			}
  6863  			if msglen < 0 {
  6864  				return ErrInvalidLengthErrors
  6865  			}
  6866  			postIndex := iNdEx + msglen
  6867  			if postIndex > l {
  6868  				return io.ErrUnexpectedEOF
  6869  			}
  6870  			if err := m.MismatchedRange.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  6871  				return err
  6872  			}
  6873  			iNdEx = postIndex
  6874  		case 4:
  6875  			if wireType != 2 {
  6876  				return fmt.Errorf("proto: wrong wireType = %d for field SuggestedRange", wireType)
  6877  			}
  6878  			var msglen int
  6879  			for shift := uint(0); ; shift += 7 {
  6880  				if shift >= 64 {
  6881  					return ErrIntOverflowErrors
  6882  				}
  6883  				if iNdEx >= l {
  6884  					return io.ErrUnexpectedEOF
  6885  				}
  6886  				b := dAtA[iNdEx]
  6887  				iNdEx++
  6888  				msglen |= (int(b) & 0x7F) << shift
  6889  				if b < 0x80 {
  6890  					break
  6891  				}
  6892  			}
  6893  			if msglen < 0 {
  6894  				return ErrInvalidLengthErrors
  6895  			}
  6896  			postIndex := iNdEx + msglen
  6897  			if postIndex > l {
  6898  				return io.ErrUnexpectedEOF
  6899  			}
  6900  			if m.SuggestedRange == nil {
  6901  				m.SuggestedRange = &RangeDescriptor{}
  6902  			}
  6903  			if err := m.SuggestedRange.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  6904  				return err
  6905  			}
  6906  			iNdEx = postIndex
  6907  		default:
  6908  			iNdEx = preIndex
  6909  			skippy, err := skipErrors(dAtA[iNdEx:])
  6910  			if err != nil {
  6911  				return err
  6912  			}
  6913  			if skippy < 0 {
  6914  				return ErrInvalidLengthErrors
  6915  			}
  6916  			if (iNdEx + skippy) > l {
  6917  				return io.ErrUnexpectedEOF
  6918  			}
  6919  			iNdEx += skippy
  6920  		}
  6921  	}
  6922  
  6923  	if iNdEx > l {
  6924  		return io.ErrUnexpectedEOF
  6925  	}
  6926  	return nil
  6927  }
  6928  func (m *ReadWithinUncertaintyIntervalError) Unmarshal(dAtA []byte) error {
  6929  	l := len(dAtA)
  6930  	iNdEx := 0
  6931  	for iNdEx < l {
  6932  		preIndex := iNdEx
  6933  		var wire uint64
  6934  		for shift := uint(0); ; shift += 7 {
  6935  			if shift >= 64 {
  6936  				return ErrIntOverflowErrors
  6937  			}
  6938  			if iNdEx >= l {
  6939  				return io.ErrUnexpectedEOF
  6940  			}
  6941  			b := dAtA[iNdEx]
  6942  			iNdEx++
  6943  			wire |= (uint64(b) & 0x7F) << shift
  6944  			if b < 0x80 {
  6945  				break
  6946  			}
  6947  		}
  6948  		fieldNum := int32(wire >> 3)
  6949  		wireType := int(wire & 0x7)
  6950  		if wireType == 4 {
  6951  			return fmt.Errorf("proto: ReadWithinUncertaintyIntervalError: wiretype end group for non-group")
  6952  		}
  6953  		if fieldNum <= 0 {
  6954  			return fmt.Errorf("proto: ReadWithinUncertaintyIntervalError: illegal tag %d (wire type %d)", fieldNum, wire)
  6955  		}
  6956  		switch fieldNum {
  6957  		case 1:
  6958  			if wireType != 2 {
  6959  				return fmt.Errorf("proto: wrong wireType = %d for field ReadTimestamp", wireType)
  6960  			}
  6961  			var msglen int
  6962  			for shift := uint(0); ; shift += 7 {
  6963  				if shift >= 64 {
  6964  					return ErrIntOverflowErrors
  6965  				}
  6966  				if iNdEx >= l {
  6967  					return io.ErrUnexpectedEOF
  6968  				}
  6969  				b := dAtA[iNdEx]
  6970  				iNdEx++
  6971  				msglen |= (int(b) & 0x7F) << shift
  6972  				if b < 0x80 {
  6973  					break
  6974  				}
  6975  			}
  6976  			if msglen < 0 {
  6977  				return ErrInvalidLengthErrors
  6978  			}
  6979  			postIndex := iNdEx + msglen
  6980  			if postIndex > l {
  6981  				return io.ErrUnexpectedEOF
  6982  			}
  6983  			if err := m.ReadTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  6984  				return err
  6985  			}
  6986  			iNdEx = postIndex
  6987  		case 2:
  6988  			if wireType != 2 {
  6989  				return fmt.Errorf("proto: wrong wireType = %d for field ExistingTimestamp", wireType)
  6990  			}
  6991  			var msglen int
  6992  			for shift := uint(0); ; shift += 7 {
  6993  				if shift >= 64 {
  6994  					return ErrIntOverflowErrors
  6995  				}
  6996  				if iNdEx >= l {
  6997  					return io.ErrUnexpectedEOF
  6998  				}
  6999  				b := dAtA[iNdEx]
  7000  				iNdEx++
  7001  				msglen |= (int(b) & 0x7F) << shift
  7002  				if b < 0x80 {
  7003  					break
  7004  				}
  7005  			}
  7006  			if msglen < 0 {
  7007  				return ErrInvalidLengthErrors
  7008  			}
  7009  			postIndex := iNdEx + msglen
  7010  			if postIndex > l {
  7011  				return io.ErrUnexpectedEOF
  7012  			}
  7013  			if err := m.ExistingTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7014  				return err
  7015  			}
  7016  			iNdEx = postIndex
  7017  		case 3:
  7018  			if wireType != 2 {
  7019  				return fmt.Errorf("proto: wrong wireType = %d for field MaxTimestamp", wireType)
  7020  			}
  7021  			var msglen int
  7022  			for shift := uint(0); ; shift += 7 {
  7023  				if shift >= 64 {
  7024  					return ErrIntOverflowErrors
  7025  				}
  7026  				if iNdEx >= l {
  7027  					return io.ErrUnexpectedEOF
  7028  				}
  7029  				b := dAtA[iNdEx]
  7030  				iNdEx++
  7031  				msglen |= (int(b) & 0x7F) << shift
  7032  				if b < 0x80 {
  7033  					break
  7034  				}
  7035  			}
  7036  			if msglen < 0 {
  7037  				return ErrInvalidLengthErrors
  7038  			}
  7039  			postIndex := iNdEx + msglen
  7040  			if postIndex > l {
  7041  				return io.ErrUnexpectedEOF
  7042  			}
  7043  			if m.MaxTimestamp == nil {
  7044  				m.MaxTimestamp = &hlc.Timestamp{}
  7045  			}
  7046  			if err := m.MaxTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7047  				return err
  7048  			}
  7049  			iNdEx = postIndex
  7050  		case 4:
  7051  			if wireType != 2 {
  7052  				return fmt.Errorf("proto: wrong wireType = %d for field ObservedTimestamps", wireType)
  7053  			}
  7054  			var msglen int
  7055  			for shift := uint(0); ; shift += 7 {
  7056  				if shift >= 64 {
  7057  					return ErrIntOverflowErrors
  7058  				}
  7059  				if iNdEx >= l {
  7060  					return io.ErrUnexpectedEOF
  7061  				}
  7062  				b := dAtA[iNdEx]
  7063  				iNdEx++
  7064  				msglen |= (int(b) & 0x7F) << shift
  7065  				if b < 0x80 {
  7066  					break
  7067  				}
  7068  			}
  7069  			if msglen < 0 {
  7070  				return ErrInvalidLengthErrors
  7071  			}
  7072  			postIndex := iNdEx + msglen
  7073  			if postIndex > l {
  7074  				return io.ErrUnexpectedEOF
  7075  			}
  7076  			m.ObservedTimestamps = append(m.ObservedTimestamps, ObservedTimestamp{})
  7077  			if err := m.ObservedTimestamps[len(m.ObservedTimestamps)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7078  				return err
  7079  			}
  7080  			iNdEx = postIndex
  7081  		default:
  7082  			iNdEx = preIndex
  7083  			skippy, err := skipErrors(dAtA[iNdEx:])
  7084  			if err != nil {
  7085  				return err
  7086  			}
  7087  			if skippy < 0 {
  7088  				return ErrInvalidLengthErrors
  7089  			}
  7090  			if (iNdEx + skippy) > l {
  7091  				return io.ErrUnexpectedEOF
  7092  			}
  7093  			iNdEx += skippy
  7094  		}
  7095  	}
  7096  
  7097  	if iNdEx > l {
  7098  		return io.ErrUnexpectedEOF
  7099  	}
  7100  	return nil
  7101  }
  7102  func (m *TransactionAbortedError) Unmarshal(dAtA []byte) error {
  7103  	l := len(dAtA)
  7104  	iNdEx := 0
  7105  	for iNdEx < l {
  7106  		preIndex := iNdEx
  7107  		var wire uint64
  7108  		for shift := uint(0); ; shift += 7 {
  7109  			if shift >= 64 {
  7110  				return ErrIntOverflowErrors
  7111  			}
  7112  			if iNdEx >= l {
  7113  				return io.ErrUnexpectedEOF
  7114  			}
  7115  			b := dAtA[iNdEx]
  7116  			iNdEx++
  7117  			wire |= (uint64(b) & 0x7F) << shift
  7118  			if b < 0x80 {
  7119  				break
  7120  			}
  7121  		}
  7122  		fieldNum := int32(wire >> 3)
  7123  		wireType := int(wire & 0x7)
  7124  		if wireType == 4 {
  7125  			return fmt.Errorf("proto: TransactionAbortedError: wiretype end group for non-group")
  7126  		}
  7127  		if fieldNum <= 0 {
  7128  			return fmt.Errorf("proto: TransactionAbortedError: illegal tag %d (wire type %d)", fieldNum, wire)
  7129  		}
  7130  		switch fieldNum {
  7131  		case 1:
  7132  			if wireType != 0 {
  7133  				return fmt.Errorf("proto: wrong wireType = %d for field Reason", wireType)
  7134  			}
  7135  			m.Reason = 0
  7136  			for shift := uint(0); ; shift += 7 {
  7137  				if shift >= 64 {
  7138  					return ErrIntOverflowErrors
  7139  				}
  7140  				if iNdEx >= l {
  7141  					return io.ErrUnexpectedEOF
  7142  				}
  7143  				b := dAtA[iNdEx]
  7144  				iNdEx++
  7145  				m.Reason |= (TransactionAbortedReason(b) & 0x7F) << shift
  7146  				if b < 0x80 {
  7147  					break
  7148  				}
  7149  			}
  7150  		default:
  7151  			iNdEx = preIndex
  7152  			skippy, err := skipErrors(dAtA[iNdEx:])
  7153  			if err != nil {
  7154  				return err
  7155  			}
  7156  			if skippy < 0 {
  7157  				return ErrInvalidLengthErrors
  7158  			}
  7159  			if (iNdEx + skippy) > l {
  7160  				return io.ErrUnexpectedEOF
  7161  			}
  7162  			iNdEx += skippy
  7163  		}
  7164  	}
  7165  
  7166  	if iNdEx > l {
  7167  		return io.ErrUnexpectedEOF
  7168  	}
  7169  	return nil
  7170  }
  7171  func (m *TransactionPushError) Unmarshal(dAtA []byte) error {
  7172  	l := len(dAtA)
  7173  	iNdEx := 0
  7174  	for iNdEx < l {
  7175  		preIndex := iNdEx
  7176  		var wire uint64
  7177  		for shift := uint(0); ; shift += 7 {
  7178  			if shift >= 64 {
  7179  				return ErrIntOverflowErrors
  7180  			}
  7181  			if iNdEx >= l {
  7182  				return io.ErrUnexpectedEOF
  7183  			}
  7184  			b := dAtA[iNdEx]
  7185  			iNdEx++
  7186  			wire |= (uint64(b) & 0x7F) << shift
  7187  			if b < 0x80 {
  7188  				break
  7189  			}
  7190  		}
  7191  		fieldNum := int32(wire >> 3)
  7192  		wireType := int(wire & 0x7)
  7193  		if wireType == 4 {
  7194  			return fmt.Errorf("proto: TransactionPushError: wiretype end group for non-group")
  7195  		}
  7196  		if fieldNum <= 0 {
  7197  			return fmt.Errorf("proto: TransactionPushError: illegal tag %d (wire type %d)", fieldNum, wire)
  7198  		}
  7199  		switch fieldNum {
  7200  		case 1:
  7201  			if wireType != 2 {
  7202  				return fmt.Errorf("proto: wrong wireType = %d for field PusheeTxn", wireType)
  7203  			}
  7204  			var msglen int
  7205  			for shift := uint(0); ; shift += 7 {
  7206  				if shift >= 64 {
  7207  					return ErrIntOverflowErrors
  7208  				}
  7209  				if iNdEx >= l {
  7210  					return io.ErrUnexpectedEOF
  7211  				}
  7212  				b := dAtA[iNdEx]
  7213  				iNdEx++
  7214  				msglen |= (int(b) & 0x7F) << shift
  7215  				if b < 0x80 {
  7216  					break
  7217  				}
  7218  			}
  7219  			if msglen < 0 {
  7220  				return ErrInvalidLengthErrors
  7221  			}
  7222  			postIndex := iNdEx + msglen
  7223  			if postIndex > l {
  7224  				return io.ErrUnexpectedEOF
  7225  			}
  7226  			if err := m.PusheeTxn.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7227  				return err
  7228  			}
  7229  			iNdEx = postIndex
  7230  		default:
  7231  			iNdEx = preIndex
  7232  			skippy, err := skipErrors(dAtA[iNdEx:])
  7233  			if err != nil {
  7234  				return err
  7235  			}
  7236  			if skippy < 0 {
  7237  				return ErrInvalidLengthErrors
  7238  			}
  7239  			if (iNdEx + skippy) > l {
  7240  				return io.ErrUnexpectedEOF
  7241  			}
  7242  			iNdEx += skippy
  7243  		}
  7244  	}
  7245  
  7246  	if iNdEx > l {
  7247  		return io.ErrUnexpectedEOF
  7248  	}
  7249  	return nil
  7250  }
  7251  func (m *TransactionRetryError) Unmarshal(dAtA []byte) error {
  7252  	l := len(dAtA)
  7253  	iNdEx := 0
  7254  	for iNdEx < l {
  7255  		preIndex := iNdEx
  7256  		var wire uint64
  7257  		for shift := uint(0); ; shift += 7 {
  7258  			if shift >= 64 {
  7259  				return ErrIntOverflowErrors
  7260  			}
  7261  			if iNdEx >= l {
  7262  				return io.ErrUnexpectedEOF
  7263  			}
  7264  			b := dAtA[iNdEx]
  7265  			iNdEx++
  7266  			wire |= (uint64(b) & 0x7F) << shift
  7267  			if b < 0x80 {
  7268  				break
  7269  			}
  7270  		}
  7271  		fieldNum := int32(wire >> 3)
  7272  		wireType := int(wire & 0x7)
  7273  		if wireType == 4 {
  7274  			return fmt.Errorf("proto: TransactionRetryError: wiretype end group for non-group")
  7275  		}
  7276  		if fieldNum <= 0 {
  7277  			return fmt.Errorf("proto: TransactionRetryError: illegal tag %d (wire type %d)", fieldNum, wire)
  7278  		}
  7279  		switch fieldNum {
  7280  		case 1:
  7281  			if wireType != 0 {
  7282  				return fmt.Errorf("proto: wrong wireType = %d for field Reason", wireType)
  7283  			}
  7284  			m.Reason = 0
  7285  			for shift := uint(0); ; shift += 7 {
  7286  				if shift >= 64 {
  7287  					return ErrIntOverflowErrors
  7288  				}
  7289  				if iNdEx >= l {
  7290  					return io.ErrUnexpectedEOF
  7291  				}
  7292  				b := dAtA[iNdEx]
  7293  				iNdEx++
  7294  				m.Reason |= (TransactionRetryReason(b) & 0x7F) << shift
  7295  				if b < 0x80 {
  7296  					break
  7297  				}
  7298  			}
  7299  		case 2:
  7300  			if wireType != 2 {
  7301  				return fmt.Errorf("proto: wrong wireType = %d for field ExtraMsg", wireType)
  7302  			}
  7303  			var stringLen uint64
  7304  			for shift := uint(0); ; shift += 7 {
  7305  				if shift >= 64 {
  7306  					return ErrIntOverflowErrors
  7307  				}
  7308  				if iNdEx >= l {
  7309  					return io.ErrUnexpectedEOF
  7310  				}
  7311  				b := dAtA[iNdEx]
  7312  				iNdEx++
  7313  				stringLen |= (uint64(b) & 0x7F) << shift
  7314  				if b < 0x80 {
  7315  					break
  7316  				}
  7317  			}
  7318  			intStringLen := int(stringLen)
  7319  			if intStringLen < 0 {
  7320  				return ErrInvalidLengthErrors
  7321  			}
  7322  			postIndex := iNdEx + intStringLen
  7323  			if postIndex > l {
  7324  				return io.ErrUnexpectedEOF
  7325  			}
  7326  			m.ExtraMsg = string(dAtA[iNdEx:postIndex])
  7327  			iNdEx = postIndex
  7328  		default:
  7329  			iNdEx = preIndex
  7330  			skippy, err := skipErrors(dAtA[iNdEx:])
  7331  			if err != nil {
  7332  				return err
  7333  			}
  7334  			if skippy < 0 {
  7335  				return ErrInvalidLengthErrors
  7336  			}
  7337  			if (iNdEx + skippy) > l {
  7338  				return io.ErrUnexpectedEOF
  7339  			}
  7340  			iNdEx += skippy
  7341  		}
  7342  	}
  7343  
  7344  	if iNdEx > l {
  7345  		return io.ErrUnexpectedEOF
  7346  	}
  7347  	return nil
  7348  }
  7349  func (m *TransactionStatusError) Unmarshal(dAtA []byte) error {
  7350  	l := len(dAtA)
  7351  	iNdEx := 0
  7352  	for iNdEx < l {
  7353  		preIndex := iNdEx
  7354  		var wire uint64
  7355  		for shift := uint(0); ; shift += 7 {
  7356  			if shift >= 64 {
  7357  				return ErrIntOverflowErrors
  7358  			}
  7359  			if iNdEx >= l {
  7360  				return io.ErrUnexpectedEOF
  7361  			}
  7362  			b := dAtA[iNdEx]
  7363  			iNdEx++
  7364  			wire |= (uint64(b) & 0x7F) << shift
  7365  			if b < 0x80 {
  7366  				break
  7367  			}
  7368  		}
  7369  		fieldNum := int32(wire >> 3)
  7370  		wireType := int(wire & 0x7)
  7371  		if wireType == 4 {
  7372  			return fmt.Errorf("proto: TransactionStatusError: wiretype end group for non-group")
  7373  		}
  7374  		if fieldNum <= 0 {
  7375  			return fmt.Errorf("proto: TransactionStatusError: illegal tag %d (wire type %d)", fieldNum, wire)
  7376  		}
  7377  		switch fieldNum {
  7378  		case 1:
  7379  			if wireType != 2 {
  7380  				return fmt.Errorf("proto: wrong wireType = %d for field Msg", wireType)
  7381  			}
  7382  			var stringLen uint64
  7383  			for shift := uint(0); ; shift += 7 {
  7384  				if shift >= 64 {
  7385  					return ErrIntOverflowErrors
  7386  				}
  7387  				if iNdEx >= l {
  7388  					return io.ErrUnexpectedEOF
  7389  				}
  7390  				b := dAtA[iNdEx]
  7391  				iNdEx++
  7392  				stringLen |= (uint64(b) & 0x7F) << shift
  7393  				if b < 0x80 {
  7394  					break
  7395  				}
  7396  			}
  7397  			intStringLen := int(stringLen)
  7398  			if intStringLen < 0 {
  7399  				return ErrInvalidLengthErrors
  7400  			}
  7401  			postIndex := iNdEx + intStringLen
  7402  			if postIndex > l {
  7403  				return io.ErrUnexpectedEOF
  7404  			}
  7405  			m.Msg = string(dAtA[iNdEx:postIndex])
  7406  			iNdEx = postIndex
  7407  		case 2:
  7408  			if wireType != 0 {
  7409  				return fmt.Errorf("proto: wrong wireType = %d for field Reason", wireType)
  7410  			}
  7411  			m.Reason = 0
  7412  			for shift := uint(0); ; shift += 7 {
  7413  				if shift >= 64 {
  7414  					return ErrIntOverflowErrors
  7415  				}
  7416  				if iNdEx >= l {
  7417  					return io.ErrUnexpectedEOF
  7418  				}
  7419  				b := dAtA[iNdEx]
  7420  				iNdEx++
  7421  				m.Reason |= (TransactionStatusError_Reason(b) & 0x7F) << shift
  7422  				if b < 0x80 {
  7423  					break
  7424  				}
  7425  			}
  7426  		default:
  7427  			iNdEx = preIndex
  7428  			skippy, err := skipErrors(dAtA[iNdEx:])
  7429  			if err != nil {
  7430  				return err
  7431  			}
  7432  			if skippy < 0 {
  7433  				return ErrInvalidLengthErrors
  7434  			}
  7435  			if (iNdEx + skippy) > l {
  7436  				return io.ErrUnexpectedEOF
  7437  			}
  7438  			iNdEx += skippy
  7439  		}
  7440  	}
  7441  
  7442  	if iNdEx > l {
  7443  		return io.ErrUnexpectedEOF
  7444  	}
  7445  	return nil
  7446  }
  7447  func (m *WriteIntentError) Unmarshal(dAtA []byte) error {
  7448  	l := len(dAtA)
  7449  	iNdEx := 0
  7450  	for iNdEx < l {
  7451  		preIndex := iNdEx
  7452  		var wire uint64
  7453  		for shift := uint(0); ; shift += 7 {
  7454  			if shift >= 64 {
  7455  				return ErrIntOverflowErrors
  7456  			}
  7457  			if iNdEx >= l {
  7458  				return io.ErrUnexpectedEOF
  7459  			}
  7460  			b := dAtA[iNdEx]
  7461  			iNdEx++
  7462  			wire |= (uint64(b) & 0x7F) << shift
  7463  			if b < 0x80 {
  7464  				break
  7465  			}
  7466  		}
  7467  		fieldNum := int32(wire >> 3)
  7468  		wireType := int(wire & 0x7)
  7469  		if wireType == 4 {
  7470  			return fmt.Errorf("proto: WriteIntentError: wiretype end group for non-group")
  7471  		}
  7472  		if fieldNum <= 0 {
  7473  			return fmt.Errorf("proto: WriteIntentError: illegal tag %d (wire type %d)", fieldNum, wire)
  7474  		}
  7475  		switch fieldNum {
  7476  		case 1:
  7477  			if wireType != 2 {
  7478  				return fmt.Errorf("proto: wrong wireType = %d for field Intents", wireType)
  7479  			}
  7480  			var msglen int
  7481  			for shift := uint(0); ; shift += 7 {
  7482  				if shift >= 64 {
  7483  					return ErrIntOverflowErrors
  7484  				}
  7485  				if iNdEx >= l {
  7486  					return io.ErrUnexpectedEOF
  7487  				}
  7488  				b := dAtA[iNdEx]
  7489  				iNdEx++
  7490  				msglen |= (int(b) & 0x7F) << shift
  7491  				if b < 0x80 {
  7492  					break
  7493  				}
  7494  			}
  7495  			if msglen < 0 {
  7496  				return ErrInvalidLengthErrors
  7497  			}
  7498  			postIndex := iNdEx + msglen
  7499  			if postIndex > l {
  7500  				return io.ErrUnexpectedEOF
  7501  			}
  7502  			m.Intents = append(m.Intents, Intent{})
  7503  			if err := m.Intents[len(m.Intents)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7504  				return err
  7505  			}
  7506  			iNdEx = postIndex
  7507  		default:
  7508  			iNdEx = preIndex
  7509  			skippy, err := skipErrors(dAtA[iNdEx:])
  7510  			if err != nil {
  7511  				return err
  7512  			}
  7513  			if skippy < 0 {
  7514  				return ErrInvalidLengthErrors
  7515  			}
  7516  			if (iNdEx + skippy) > l {
  7517  				return io.ErrUnexpectedEOF
  7518  			}
  7519  			iNdEx += skippy
  7520  		}
  7521  	}
  7522  
  7523  	if iNdEx > l {
  7524  		return io.ErrUnexpectedEOF
  7525  	}
  7526  	return nil
  7527  }
  7528  func (m *WriteTooOldError) Unmarshal(dAtA []byte) error {
  7529  	l := len(dAtA)
  7530  	iNdEx := 0
  7531  	for iNdEx < l {
  7532  		preIndex := iNdEx
  7533  		var wire uint64
  7534  		for shift := uint(0); ; shift += 7 {
  7535  			if shift >= 64 {
  7536  				return ErrIntOverflowErrors
  7537  			}
  7538  			if iNdEx >= l {
  7539  				return io.ErrUnexpectedEOF
  7540  			}
  7541  			b := dAtA[iNdEx]
  7542  			iNdEx++
  7543  			wire |= (uint64(b) & 0x7F) << shift
  7544  			if b < 0x80 {
  7545  				break
  7546  			}
  7547  		}
  7548  		fieldNum := int32(wire >> 3)
  7549  		wireType := int(wire & 0x7)
  7550  		if wireType == 4 {
  7551  			return fmt.Errorf("proto: WriteTooOldError: wiretype end group for non-group")
  7552  		}
  7553  		if fieldNum <= 0 {
  7554  			return fmt.Errorf("proto: WriteTooOldError: illegal tag %d (wire type %d)", fieldNum, wire)
  7555  		}
  7556  		switch fieldNum {
  7557  		case 1:
  7558  			if wireType != 2 {
  7559  				return fmt.Errorf("proto: wrong wireType = %d for field Timestamp", wireType)
  7560  			}
  7561  			var msglen int
  7562  			for shift := uint(0); ; shift += 7 {
  7563  				if shift >= 64 {
  7564  					return ErrIntOverflowErrors
  7565  				}
  7566  				if iNdEx >= l {
  7567  					return io.ErrUnexpectedEOF
  7568  				}
  7569  				b := dAtA[iNdEx]
  7570  				iNdEx++
  7571  				msglen |= (int(b) & 0x7F) << shift
  7572  				if b < 0x80 {
  7573  					break
  7574  				}
  7575  			}
  7576  			if msglen < 0 {
  7577  				return ErrInvalidLengthErrors
  7578  			}
  7579  			postIndex := iNdEx + msglen
  7580  			if postIndex > l {
  7581  				return io.ErrUnexpectedEOF
  7582  			}
  7583  			if err := m.Timestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7584  				return err
  7585  			}
  7586  			iNdEx = postIndex
  7587  		case 2:
  7588  			if wireType != 2 {
  7589  				return fmt.Errorf("proto: wrong wireType = %d for field ActualTimestamp", wireType)
  7590  			}
  7591  			var msglen int
  7592  			for shift := uint(0); ; shift += 7 {
  7593  				if shift >= 64 {
  7594  					return ErrIntOverflowErrors
  7595  				}
  7596  				if iNdEx >= l {
  7597  					return io.ErrUnexpectedEOF
  7598  				}
  7599  				b := dAtA[iNdEx]
  7600  				iNdEx++
  7601  				msglen |= (int(b) & 0x7F) << shift
  7602  				if b < 0x80 {
  7603  					break
  7604  				}
  7605  			}
  7606  			if msglen < 0 {
  7607  				return ErrInvalidLengthErrors
  7608  			}
  7609  			postIndex := iNdEx + msglen
  7610  			if postIndex > l {
  7611  				return io.ErrUnexpectedEOF
  7612  			}
  7613  			if err := m.ActualTimestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7614  				return err
  7615  			}
  7616  			iNdEx = postIndex
  7617  		default:
  7618  			iNdEx = preIndex
  7619  			skippy, err := skipErrors(dAtA[iNdEx:])
  7620  			if err != nil {
  7621  				return err
  7622  			}
  7623  			if skippy < 0 {
  7624  				return ErrInvalidLengthErrors
  7625  			}
  7626  			if (iNdEx + skippy) > l {
  7627  				return io.ErrUnexpectedEOF
  7628  			}
  7629  			iNdEx += skippy
  7630  		}
  7631  	}
  7632  
  7633  	if iNdEx > l {
  7634  		return io.ErrUnexpectedEOF
  7635  	}
  7636  	return nil
  7637  }
  7638  func (m *OpRequiresTxnError) Unmarshal(dAtA []byte) error {
  7639  	l := len(dAtA)
  7640  	iNdEx := 0
  7641  	for iNdEx < l {
  7642  		preIndex := iNdEx
  7643  		var wire uint64
  7644  		for shift := uint(0); ; shift += 7 {
  7645  			if shift >= 64 {
  7646  				return ErrIntOverflowErrors
  7647  			}
  7648  			if iNdEx >= l {
  7649  				return io.ErrUnexpectedEOF
  7650  			}
  7651  			b := dAtA[iNdEx]
  7652  			iNdEx++
  7653  			wire |= (uint64(b) & 0x7F) << shift
  7654  			if b < 0x80 {
  7655  				break
  7656  			}
  7657  		}
  7658  		fieldNum := int32(wire >> 3)
  7659  		wireType := int(wire & 0x7)
  7660  		if wireType == 4 {
  7661  			return fmt.Errorf("proto: OpRequiresTxnError: wiretype end group for non-group")
  7662  		}
  7663  		if fieldNum <= 0 {
  7664  			return fmt.Errorf("proto: OpRequiresTxnError: illegal tag %d (wire type %d)", fieldNum, wire)
  7665  		}
  7666  		switch fieldNum {
  7667  		default:
  7668  			iNdEx = preIndex
  7669  			skippy, err := skipErrors(dAtA[iNdEx:])
  7670  			if err != nil {
  7671  				return err
  7672  			}
  7673  			if skippy < 0 {
  7674  				return ErrInvalidLengthErrors
  7675  			}
  7676  			if (iNdEx + skippy) > l {
  7677  				return io.ErrUnexpectedEOF
  7678  			}
  7679  			iNdEx += skippy
  7680  		}
  7681  	}
  7682  
  7683  	if iNdEx > l {
  7684  		return io.ErrUnexpectedEOF
  7685  	}
  7686  	return nil
  7687  }
  7688  func (m *ConditionFailedError) Unmarshal(dAtA []byte) error {
  7689  	l := len(dAtA)
  7690  	iNdEx := 0
  7691  	for iNdEx < l {
  7692  		preIndex := iNdEx
  7693  		var wire uint64
  7694  		for shift := uint(0); ; shift += 7 {
  7695  			if shift >= 64 {
  7696  				return ErrIntOverflowErrors
  7697  			}
  7698  			if iNdEx >= l {
  7699  				return io.ErrUnexpectedEOF
  7700  			}
  7701  			b := dAtA[iNdEx]
  7702  			iNdEx++
  7703  			wire |= (uint64(b) & 0x7F) << shift
  7704  			if b < 0x80 {
  7705  				break
  7706  			}
  7707  		}
  7708  		fieldNum := int32(wire >> 3)
  7709  		wireType := int(wire & 0x7)
  7710  		if wireType == 4 {
  7711  			return fmt.Errorf("proto: ConditionFailedError: wiretype end group for non-group")
  7712  		}
  7713  		if fieldNum <= 0 {
  7714  			return fmt.Errorf("proto: ConditionFailedError: illegal tag %d (wire type %d)", fieldNum, wire)
  7715  		}
  7716  		switch fieldNum {
  7717  		case 1:
  7718  			if wireType != 2 {
  7719  				return fmt.Errorf("proto: wrong wireType = %d for field ActualValue", wireType)
  7720  			}
  7721  			var msglen int
  7722  			for shift := uint(0); ; shift += 7 {
  7723  				if shift >= 64 {
  7724  					return ErrIntOverflowErrors
  7725  				}
  7726  				if iNdEx >= l {
  7727  					return io.ErrUnexpectedEOF
  7728  				}
  7729  				b := dAtA[iNdEx]
  7730  				iNdEx++
  7731  				msglen |= (int(b) & 0x7F) << shift
  7732  				if b < 0x80 {
  7733  					break
  7734  				}
  7735  			}
  7736  			if msglen < 0 {
  7737  				return ErrInvalidLengthErrors
  7738  			}
  7739  			postIndex := iNdEx + msglen
  7740  			if postIndex > l {
  7741  				return io.ErrUnexpectedEOF
  7742  			}
  7743  			if m.ActualValue == nil {
  7744  				m.ActualValue = &Value{}
  7745  			}
  7746  			if err := m.ActualValue.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7747  				return err
  7748  			}
  7749  			iNdEx = postIndex
  7750  		default:
  7751  			iNdEx = preIndex
  7752  			skippy, err := skipErrors(dAtA[iNdEx:])
  7753  			if err != nil {
  7754  				return err
  7755  			}
  7756  			if skippy < 0 {
  7757  				return ErrInvalidLengthErrors
  7758  			}
  7759  			if (iNdEx + skippy) > l {
  7760  				return io.ErrUnexpectedEOF
  7761  			}
  7762  			iNdEx += skippy
  7763  		}
  7764  	}
  7765  
  7766  	if iNdEx > l {
  7767  		return io.ErrUnexpectedEOF
  7768  	}
  7769  	return nil
  7770  }
  7771  func (m *LeaseRejectedError) Unmarshal(dAtA []byte) error {
  7772  	l := len(dAtA)
  7773  	iNdEx := 0
  7774  	for iNdEx < l {
  7775  		preIndex := iNdEx
  7776  		var wire uint64
  7777  		for shift := uint(0); ; shift += 7 {
  7778  			if shift >= 64 {
  7779  				return ErrIntOverflowErrors
  7780  			}
  7781  			if iNdEx >= l {
  7782  				return io.ErrUnexpectedEOF
  7783  			}
  7784  			b := dAtA[iNdEx]
  7785  			iNdEx++
  7786  			wire |= (uint64(b) & 0x7F) << shift
  7787  			if b < 0x80 {
  7788  				break
  7789  			}
  7790  		}
  7791  		fieldNum := int32(wire >> 3)
  7792  		wireType := int(wire & 0x7)
  7793  		if wireType == 4 {
  7794  			return fmt.Errorf("proto: LeaseRejectedError: wiretype end group for non-group")
  7795  		}
  7796  		if fieldNum <= 0 {
  7797  			return fmt.Errorf("proto: LeaseRejectedError: illegal tag %d (wire type %d)", fieldNum, wire)
  7798  		}
  7799  		switch fieldNum {
  7800  		case 1:
  7801  			if wireType != 2 {
  7802  				return fmt.Errorf("proto: wrong wireType = %d for field Message", wireType)
  7803  			}
  7804  			var stringLen uint64
  7805  			for shift := uint(0); ; shift += 7 {
  7806  				if shift >= 64 {
  7807  					return ErrIntOverflowErrors
  7808  				}
  7809  				if iNdEx >= l {
  7810  					return io.ErrUnexpectedEOF
  7811  				}
  7812  				b := dAtA[iNdEx]
  7813  				iNdEx++
  7814  				stringLen |= (uint64(b) & 0x7F) << shift
  7815  				if b < 0x80 {
  7816  					break
  7817  				}
  7818  			}
  7819  			intStringLen := int(stringLen)
  7820  			if intStringLen < 0 {
  7821  				return ErrInvalidLengthErrors
  7822  			}
  7823  			postIndex := iNdEx + intStringLen
  7824  			if postIndex > l {
  7825  				return io.ErrUnexpectedEOF
  7826  			}
  7827  			m.Message = string(dAtA[iNdEx:postIndex])
  7828  			iNdEx = postIndex
  7829  		case 2:
  7830  			if wireType != 2 {
  7831  				return fmt.Errorf("proto: wrong wireType = %d for field Requested", wireType)
  7832  			}
  7833  			var msglen int
  7834  			for shift := uint(0); ; shift += 7 {
  7835  				if shift >= 64 {
  7836  					return ErrIntOverflowErrors
  7837  				}
  7838  				if iNdEx >= l {
  7839  					return io.ErrUnexpectedEOF
  7840  				}
  7841  				b := dAtA[iNdEx]
  7842  				iNdEx++
  7843  				msglen |= (int(b) & 0x7F) << shift
  7844  				if b < 0x80 {
  7845  					break
  7846  				}
  7847  			}
  7848  			if msglen < 0 {
  7849  				return ErrInvalidLengthErrors
  7850  			}
  7851  			postIndex := iNdEx + msglen
  7852  			if postIndex > l {
  7853  				return io.ErrUnexpectedEOF
  7854  			}
  7855  			if err := m.Requested.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7856  				return err
  7857  			}
  7858  			iNdEx = postIndex
  7859  		case 3:
  7860  			if wireType != 2 {
  7861  				return fmt.Errorf("proto: wrong wireType = %d for field Existing", wireType)
  7862  			}
  7863  			var msglen int
  7864  			for shift := uint(0); ; shift += 7 {
  7865  				if shift >= 64 {
  7866  					return ErrIntOverflowErrors
  7867  				}
  7868  				if iNdEx >= l {
  7869  					return io.ErrUnexpectedEOF
  7870  				}
  7871  				b := dAtA[iNdEx]
  7872  				iNdEx++
  7873  				msglen |= (int(b) & 0x7F) << shift
  7874  				if b < 0x80 {
  7875  					break
  7876  				}
  7877  			}
  7878  			if msglen < 0 {
  7879  				return ErrInvalidLengthErrors
  7880  			}
  7881  			postIndex := iNdEx + msglen
  7882  			if postIndex > l {
  7883  				return io.ErrUnexpectedEOF
  7884  			}
  7885  			if err := m.Existing.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  7886  				return err
  7887  			}
  7888  			iNdEx = postIndex
  7889  		default:
  7890  			iNdEx = preIndex
  7891  			skippy, err := skipErrors(dAtA[iNdEx:])
  7892  			if err != nil {
  7893  				return err
  7894  			}
  7895  			if skippy < 0 {
  7896  				return ErrInvalidLengthErrors
  7897  			}
  7898  			if (iNdEx + skippy) > l {
  7899  				return io.ErrUnexpectedEOF
  7900  			}
  7901  			iNdEx += skippy
  7902  		}
  7903  	}
  7904  
  7905  	if iNdEx > l {
  7906  		return io.ErrUnexpectedEOF
  7907  	}
  7908  	return nil
  7909  }
  7910  func (m *SendError) Unmarshal(dAtA []byte) error {
  7911  	l := len(dAtA)
  7912  	iNdEx := 0
  7913  	for iNdEx < l {
  7914  		preIndex := iNdEx
  7915  		var wire uint64
  7916  		for shift := uint(0); ; shift += 7 {
  7917  			if shift >= 64 {
  7918  				return ErrIntOverflowErrors
  7919  			}
  7920  			if iNdEx >= l {
  7921  				return io.ErrUnexpectedEOF
  7922  			}
  7923  			b := dAtA[iNdEx]
  7924  			iNdEx++
  7925  			wire |= (uint64(b) & 0x7F) << shift
  7926  			if b < 0x80 {
  7927  				break
  7928  			}
  7929  		}
  7930  		fieldNum := int32(wire >> 3)
  7931  		wireType := int(wire & 0x7)
  7932  		if wireType == 4 {
  7933  			return fmt.Errorf("proto: SendError: wiretype end group for non-group")
  7934  		}
  7935  		if fieldNum <= 0 {
  7936  			return fmt.Errorf("proto: SendError: illegal tag %d (wire type %d)", fieldNum, wire)
  7937  		}
  7938  		switch fieldNum {
  7939  		case 1:
  7940  			if wireType != 2 {
  7941  				return fmt.Errorf("proto: wrong wireType = %d for field Message", wireType)
  7942  			}
  7943  			var stringLen uint64
  7944  			for shift := uint(0); ; shift += 7 {
  7945  				if shift >= 64 {
  7946  					return ErrIntOverflowErrors
  7947  				}
  7948  				if iNdEx >= l {
  7949  					return io.ErrUnexpectedEOF
  7950  				}
  7951  				b := dAtA[iNdEx]
  7952  				iNdEx++
  7953  				stringLen |= (uint64(b) & 0x7F) << shift
  7954  				if b < 0x80 {
  7955  					break
  7956  				}
  7957  			}
  7958  			intStringLen := int(stringLen)
  7959  			if intStringLen < 0 {
  7960  				return ErrInvalidLengthErrors
  7961  			}
  7962  			postIndex := iNdEx + intStringLen
  7963  			if postIndex > l {
  7964  				return io.ErrUnexpectedEOF
  7965  			}
  7966  			m.Message = string(dAtA[iNdEx:postIndex])
  7967  			iNdEx = postIndex
  7968  		default:
  7969  			iNdEx = preIndex
  7970  			skippy, err := skipErrors(dAtA[iNdEx:])
  7971  			if err != nil {
  7972  				return err
  7973  			}
  7974  			if skippy < 0 {
  7975  				return ErrInvalidLengthErrors
  7976  			}
  7977  			if (iNdEx + skippy) > l {
  7978  				return io.ErrUnexpectedEOF
  7979  			}
  7980  			iNdEx += skippy
  7981  		}
  7982  	}
  7983  
  7984  	if iNdEx > l {
  7985  		return io.ErrUnexpectedEOF
  7986  	}
  7987  	return nil
  7988  }
  7989  func (m *AmbiguousResultError) Unmarshal(dAtA []byte) error {
  7990  	l := len(dAtA)
  7991  	iNdEx := 0
  7992  	for iNdEx < l {
  7993  		preIndex := iNdEx
  7994  		var wire uint64
  7995  		for shift := uint(0); ; shift += 7 {
  7996  			if shift >= 64 {
  7997  				return ErrIntOverflowErrors
  7998  			}
  7999  			if iNdEx >= l {
  8000  				return io.ErrUnexpectedEOF
  8001  			}
  8002  			b := dAtA[iNdEx]
  8003  			iNdEx++
  8004  			wire |= (uint64(b) & 0x7F) << shift
  8005  			if b < 0x80 {
  8006  				break
  8007  			}
  8008  		}
  8009  		fieldNum := int32(wire >> 3)
  8010  		wireType := int(wire & 0x7)
  8011  		if wireType == 4 {
  8012  			return fmt.Errorf("proto: AmbiguousResultError: wiretype end group for non-group")
  8013  		}
  8014  		if fieldNum <= 0 {
  8015  			return fmt.Errorf("proto: AmbiguousResultError: illegal tag %d (wire type %d)", fieldNum, wire)
  8016  		}
  8017  		switch fieldNum {
  8018  		case 1:
  8019  			if wireType != 2 {
  8020  				return fmt.Errorf("proto: wrong wireType = %d for field Message", wireType)
  8021  			}
  8022  			var stringLen uint64
  8023  			for shift := uint(0); ; shift += 7 {
  8024  				if shift >= 64 {
  8025  					return ErrIntOverflowErrors
  8026  				}
  8027  				if iNdEx >= l {
  8028  					return io.ErrUnexpectedEOF
  8029  				}
  8030  				b := dAtA[iNdEx]
  8031  				iNdEx++
  8032  				stringLen |= (uint64(b) & 0x7F) << shift
  8033  				if b < 0x80 {
  8034  					break
  8035  				}
  8036  			}
  8037  			intStringLen := int(stringLen)
  8038  			if intStringLen < 0 {
  8039  				return ErrInvalidLengthErrors
  8040  			}
  8041  			postIndex := iNdEx + intStringLen
  8042  			if postIndex > l {
  8043  				return io.ErrUnexpectedEOF
  8044  			}
  8045  			m.Message = string(dAtA[iNdEx:postIndex])
  8046  			iNdEx = postIndex
  8047  		case 2:
  8048  			if wireType != 2 {
  8049  				return fmt.Errorf("proto: wrong wireType = %d for field WrappedErr", wireType)
  8050  			}
  8051  			var msglen int
  8052  			for shift := uint(0); ; shift += 7 {
  8053  				if shift >= 64 {
  8054  					return ErrIntOverflowErrors
  8055  				}
  8056  				if iNdEx >= l {
  8057  					return io.ErrUnexpectedEOF
  8058  				}
  8059  				b := dAtA[iNdEx]
  8060  				iNdEx++
  8061  				msglen |= (int(b) & 0x7F) << shift
  8062  				if b < 0x80 {
  8063  					break
  8064  				}
  8065  			}
  8066  			if msglen < 0 {
  8067  				return ErrInvalidLengthErrors
  8068  			}
  8069  			postIndex := iNdEx + msglen
  8070  			if postIndex > l {
  8071  				return io.ErrUnexpectedEOF
  8072  			}
  8073  			if m.WrappedErr == nil {
  8074  				m.WrappedErr = &Error{}
  8075  			}
  8076  			if err := m.WrappedErr.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8077  				return err
  8078  			}
  8079  			iNdEx = postIndex
  8080  		default:
  8081  			iNdEx = preIndex
  8082  			skippy, err := skipErrors(dAtA[iNdEx:])
  8083  			if err != nil {
  8084  				return err
  8085  			}
  8086  			if skippy < 0 {
  8087  				return ErrInvalidLengthErrors
  8088  			}
  8089  			if (iNdEx + skippy) > l {
  8090  				return io.ErrUnexpectedEOF
  8091  			}
  8092  			iNdEx += skippy
  8093  		}
  8094  	}
  8095  
  8096  	if iNdEx > l {
  8097  		return io.ErrUnexpectedEOF
  8098  	}
  8099  	return nil
  8100  }
  8101  func (m *RaftGroupDeletedError) Unmarshal(dAtA []byte) error {
  8102  	l := len(dAtA)
  8103  	iNdEx := 0
  8104  	for iNdEx < l {
  8105  		preIndex := iNdEx
  8106  		var wire uint64
  8107  		for shift := uint(0); ; shift += 7 {
  8108  			if shift >= 64 {
  8109  				return ErrIntOverflowErrors
  8110  			}
  8111  			if iNdEx >= l {
  8112  				return io.ErrUnexpectedEOF
  8113  			}
  8114  			b := dAtA[iNdEx]
  8115  			iNdEx++
  8116  			wire |= (uint64(b) & 0x7F) << shift
  8117  			if b < 0x80 {
  8118  				break
  8119  			}
  8120  		}
  8121  		fieldNum := int32(wire >> 3)
  8122  		wireType := int(wire & 0x7)
  8123  		if wireType == 4 {
  8124  			return fmt.Errorf("proto: RaftGroupDeletedError: wiretype end group for non-group")
  8125  		}
  8126  		if fieldNum <= 0 {
  8127  			return fmt.Errorf("proto: RaftGroupDeletedError: illegal tag %d (wire type %d)", fieldNum, wire)
  8128  		}
  8129  		switch fieldNum {
  8130  		default:
  8131  			iNdEx = preIndex
  8132  			skippy, err := skipErrors(dAtA[iNdEx:])
  8133  			if err != nil {
  8134  				return err
  8135  			}
  8136  			if skippy < 0 {
  8137  				return ErrInvalidLengthErrors
  8138  			}
  8139  			if (iNdEx + skippy) > l {
  8140  				return io.ErrUnexpectedEOF
  8141  			}
  8142  			iNdEx += skippy
  8143  		}
  8144  	}
  8145  
  8146  	if iNdEx > l {
  8147  		return io.ErrUnexpectedEOF
  8148  	}
  8149  	return nil
  8150  }
  8151  func (m *ReplicaCorruptionError) Unmarshal(dAtA []byte) error {
  8152  	l := len(dAtA)
  8153  	iNdEx := 0
  8154  	for iNdEx < l {
  8155  		preIndex := iNdEx
  8156  		var wire uint64
  8157  		for shift := uint(0); ; shift += 7 {
  8158  			if shift >= 64 {
  8159  				return ErrIntOverflowErrors
  8160  			}
  8161  			if iNdEx >= l {
  8162  				return io.ErrUnexpectedEOF
  8163  			}
  8164  			b := dAtA[iNdEx]
  8165  			iNdEx++
  8166  			wire |= (uint64(b) & 0x7F) << shift
  8167  			if b < 0x80 {
  8168  				break
  8169  			}
  8170  		}
  8171  		fieldNum := int32(wire >> 3)
  8172  		wireType := int(wire & 0x7)
  8173  		if wireType == 4 {
  8174  			return fmt.Errorf("proto: ReplicaCorruptionError: wiretype end group for non-group")
  8175  		}
  8176  		if fieldNum <= 0 {
  8177  			return fmt.Errorf("proto: ReplicaCorruptionError: illegal tag %d (wire type %d)", fieldNum, wire)
  8178  		}
  8179  		switch fieldNum {
  8180  		case 1:
  8181  			if wireType != 2 {
  8182  				return fmt.Errorf("proto: wrong wireType = %d for field ErrorMsg", wireType)
  8183  			}
  8184  			var stringLen uint64
  8185  			for shift := uint(0); ; shift += 7 {
  8186  				if shift >= 64 {
  8187  					return ErrIntOverflowErrors
  8188  				}
  8189  				if iNdEx >= l {
  8190  					return io.ErrUnexpectedEOF
  8191  				}
  8192  				b := dAtA[iNdEx]
  8193  				iNdEx++
  8194  				stringLen |= (uint64(b) & 0x7F) << shift
  8195  				if b < 0x80 {
  8196  					break
  8197  				}
  8198  			}
  8199  			intStringLen := int(stringLen)
  8200  			if intStringLen < 0 {
  8201  				return ErrInvalidLengthErrors
  8202  			}
  8203  			postIndex := iNdEx + intStringLen
  8204  			if postIndex > l {
  8205  				return io.ErrUnexpectedEOF
  8206  			}
  8207  			m.ErrorMsg = string(dAtA[iNdEx:postIndex])
  8208  			iNdEx = postIndex
  8209  		case 2:
  8210  			if wireType != 0 {
  8211  				return fmt.Errorf("proto: wrong wireType = %d for field Processed", wireType)
  8212  			}
  8213  			var v int
  8214  			for shift := uint(0); ; shift += 7 {
  8215  				if shift >= 64 {
  8216  					return ErrIntOverflowErrors
  8217  				}
  8218  				if iNdEx >= l {
  8219  					return io.ErrUnexpectedEOF
  8220  				}
  8221  				b := dAtA[iNdEx]
  8222  				iNdEx++
  8223  				v |= (int(b) & 0x7F) << shift
  8224  				if b < 0x80 {
  8225  					break
  8226  				}
  8227  			}
  8228  			m.Processed = bool(v != 0)
  8229  		default:
  8230  			iNdEx = preIndex
  8231  			skippy, err := skipErrors(dAtA[iNdEx:])
  8232  			if err != nil {
  8233  				return err
  8234  			}
  8235  			if skippy < 0 {
  8236  				return ErrInvalidLengthErrors
  8237  			}
  8238  			if (iNdEx + skippy) > l {
  8239  				return io.ErrUnexpectedEOF
  8240  			}
  8241  			iNdEx += skippy
  8242  		}
  8243  	}
  8244  
  8245  	if iNdEx > l {
  8246  		return io.ErrUnexpectedEOF
  8247  	}
  8248  	return nil
  8249  }
  8250  func (m *ReplicaTooOldError) Unmarshal(dAtA []byte) error {
  8251  	l := len(dAtA)
  8252  	iNdEx := 0
  8253  	for iNdEx < l {
  8254  		preIndex := iNdEx
  8255  		var wire uint64
  8256  		for shift := uint(0); ; shift += 7 {
  8257  			if shift >= 64 {
  8258  				return ErrIntOverflowErrors
  8259  			}
  8260  			if iNdEx >= l {
  8261  				return io.ErrUnexpectedEOF
  8262  			}
  8263  			b := dAtA[iNdEx]
  8264  			iNdEx++
  8265  			wire |= (uint64(b) & 0x7F) << shift
  8266  			if b < 0x80 {
  8267  				break
  8268  			}
  8269  		}
  8270  		fieldNum := int32(wire >> 3)
  8271  		wireType := int(wire & 0x7)
  8272  		if wireType == 4 {
  8273  			return fmt.Errorf("proto: ReplicaTooOldError: wiretype end group for non-group")
  8274  		}
  8275  		if fieldNum <= 0 {
  8276  			return fmt.Errorf("proto: ReplicaTooOldError: illegal tag %d (wire type %d)", fieldNum, wire)
  8277  		}
  8278  		switch fieldNum {
  8279  		case 1:
  8280  			if wireType != 0 {
  8281  				return fmt.Errorf("proto: wrong wireType = %d for field ReplicaID", wireType)
  8282  			}
  8283  			m.ReplicaID = 0
  8284  			for shift := uint(0); ; shift += 7 {
  8285  				if shift >= 64 {
  8286  					return ErrIntOverflowErrors
  8287  				}
  8288  				if iNdEx >= l {
  8289  					return io.ErrUnexpectedEOF
  8290  				}
  8291  				b := dAtA[iNdEx]
  8292  				iNdEx++
  8293  				m.ReplicaID |= (ReplicaID(b) & 0x7F) << shift
  8294  				if b < 0x80 {
  8295  					break
  8296  				}
  8297  			}
  8298  		default:
  8299  			iNdEx = preIndex
  8300  			skippy, err := skipErrors(dAtA[iNdEx:])
  8301  			if err != nil {
  8302  				return err
  8303  			}
  8304  			if skippy < 0 {
  8305  				return ErrInvalidLengthErrors
  8306  			}
  8307  			if (iNdEx + skippy) > l {
  8308  				return io.ErrUnexpectedEOF
  8309  			}
  8310  			iNdEx += skippy
  8311  		}
  8312  	}
  8313  
  8314  	if iNdEx > l {
  8315  		return io.ErrUnexpectedEOF
  8316  	}
  8317  	return nil
  8318  }
  8319  func (m *StoreNotFoundError) Unmarshal(dAtA []byte) error {
  8320  	l := len(dAtA)
  8321  	iNdEx := 0
  8322  	for iNdEx < l {
  8323  		preIndex := iNdEx
  8324  		var wire uint64
  8325  		for shift := uint(0); ; shift += 7 {
  8326  			if shift >= 64 {
  8327  				return ErrIntOverflowErrors
  8328  			}
  8329  			if iNdEx >= l {
  8330  				return io.ErrUnexpectedEOF
  8331  			}
  8332  			b := dAtA[iNdEx]
  8333  			iNdEx++
  8334  			wire |= (uint64(b) & 0x7F) << shift
  8335  			if b < 0x80 {
  8336  				break
  8337  			}
  8338  		}
  8339  		fieldNum := int32(wire >> 3)
  8340  		wireType := int(wire & 0x7)
  8341  		if wireType == 4 {
  8342  			return fmt.Errorf("proto: StoreNotFoundError: wiretype end group for non-group")
  8343  		}
  8344  		if fieldNum <= 0 {
  8345  			return fmt.Errorf("proto: StoreNotFoundError: illegal tag %d (wire type %d)", fieldNum, wire)
  8346  		}
  8347  		switch fieldNum {
  8348  		case 1:
  8349  			if wireType != 0 {
  8350  				return fmt.Errorf("proto: wrong wireType = %d for field StoreID", wireType)
  8351  			}
  8352  			m.StoreID = 0
  8353  			for shift := uint(0); ; shift += 7 {
  8354  				if shift >= 64 {
  8355  					return ErrIntOverflowErrors
  8356  				}
  8357  				if iNdEx >= l {
  8358  					return io.ErrUnexpectedEOF
  8359  				}
  8360  				b := dAtA[iNdEx]
  8361  				iNdEx++
  8362  				m.StoreID |= (StoreID(b) & 0x7F) << shift
  8363  				if b < 0x80 {
  8364  					break
  8365  				}
  8366  			}
  8367  		default:
  8368  			iNdEx = preIndex
  8369  			skippy, err := skipErrors(dAtA[iNdEx:])
  8370  			if err != nil {
  8371  				return err
  8372  			}
  8373  			if skippy < 0 {
  8374  				return ErrInvalidLengthErrors
  8375  			}
  8376  			if (iNdEx + skippy) > l {
  8377  				return io.ErrUnexpectedEOF
  8378  			}
  8379  			iNdEx += skippy
  8380  		}
  8381  	}
  8382  
  8383  	if iNdEx > l {
  8384  		return io.ErrUnexpectedEOF
  8385  	}
  8386  	return nil
  8387  }
  8388  func (m *UnhandledRetryableError) Unmarshal(dAtA []byte) error {
  8389  	l := len(dAtA)
  8390  	iNdEx := 0
  8391  	for iNdEx < l {
  8392  		preIndex := iNdEx
  8393  		var wire uint64
  8394  		for shift := uint(0); ; shift += 7 {
  8395  			if shift >= 64 {
  8396  				return ErrIntOverflowErrors
  8397  			}
  8398  			if iNdEx >= l {
  8399  				return io.ErrUnexpectedEOF
  8400  			}
  8401  			b := dAtA[iNdEx]
  8402  			iNdEx++
  8403  			wire |= (uint64(b) & 0x7F) << shift
  8404  			if b < 0x80 {
  8405  				break
  8406  			}
  8407  		}
  8408  		fieldNum := int32(wire >> 3)
  8409  		wireType := int(wire & 0x7)
  8410  		if wireType == 4 {
  8411  			return fmt.Errorf("proto: UnhandledRetryableError: wiretype end group for non-group")
  8412  		}
  8413  		if fieldNum <= 0 {
  8414  			return fmt.Errorf("proto: UnhandledRetryableError: illegal tag %d (wire type %d)", fieldNum, wire)
  8415  		}
  8416  		switch fieldNum {
  8417  		case 1:
  8418  			if wireType != 2 {
  8419  				return fmt.Errorf("proto: wrong wireType = %d for field PErr", wireType)
  8420  			}
  8421  			var msglen int
  8422  			for shift := uint(0); ; shift += 7 {
  8423  				if shift >= 64 {
  8424  					return ErrIntOverflowErrors
  8425  				}
  8426  				if iNdEx >= l {
  8427  					return io.ErrUnexpectedEOF
  8428  				}
  8429  				b := dAtA[iNdEx]
  8430  				iNdEx++
  8431  				msglen |= (int(b) & 0x7F) << shift
  8432  				if b < 0x80 {
  8433  					break
  8434  				}
  8435  			}
  8436  			if msglen < 0 {
  8437  				return ErrInvalidLengthErrors
  8438  			}
  8439  			postIndex := iNdEx + msglen
  8440  			if postIndex > l {
  8441  				return io.ErrUnexpectedEOF
  8442  			}
  8443  			if err := m.PErr.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8444  				return err
  8445  			}
  8446  			iNdEx = postIndex
  8447  		default:
  8448  			iNdEx = preIndex
  8449  			skippy, err := skipErrors(dAtA[iNdEx:])
  8450  			if err != nil {
  8451  				return err
  8452  			}
  8453  			if skippy < 0 {
  8454  				return ErrInvalidLengthErrors
  8455  			}
  8456  			if (iNdEx + skippy) > l {
  8457  				return io.ErrUnexpectedEOF
  8458  			}
  8459  			iNdEx += skippy
  8460  		}
  8461  	}
  8462  
  8463  	if iNdEx > l {
  8464  		return io.ErrUnexpectedEOF
  8465  	}
  8466  	return nil
  8467  }
  8468  func (m *TransactionRetryWithProtoRefreshError) Unmarshal(dAtA []byte) error {
  8469  	l := len(dAtA)
  8470  	iNdEx := 0
  8471  	for iNdEx < l {
  8472  		preIndex := iNdEx
  8473  		var wire uint64
  8474  		for shift := uint(0); ; shift += 7 {
  8475  			if shift >= 64 {
  8476  				return ErrIntOverflowErrors
  8477  			}
  8478  			if iNdEx >= l {
  8479  				return io.ErrUnexpectedEOF
  8480  			}
  8481  			b := dAtA[iNdEx]
  8482  			iNdEx++
  8483  			wire |= (uint64(b) & 0x7F) << shift
  8484  			if b < 0x80 {
  8485  				break
  8486  			}
  8487  		}
  8488  		fieldNum := int32(wire >> 3)
  8489  		wireType := int(wire & 0x7)
  8490  		if wireType == 4 {
  8491  			return fmt.Errorf("proto: TransactionRetryWithProtoRefreshError: wiretype end group for non-group")
  8492  		}
  8493  		if fieldNum <= 0 {
  8494  			return fmt.Errorf("proto: TransactionRetryWithProtoRefreshError: illegal tag %d (wire type %d)", fieldNum, wire)
  8495  		}
  8496  		switch fieldNum {
  8497  		case 1:
  8498  			if wireType != 2 {
  8499  				return fmt.Errorf("proto: wrong wireType = %d for field Msg", wireType)
  8500  			}
  8501  			var stringLen uint64
  8502  			for shift := uint(0); ; shift += 7 {
  8503  				if shift >= 64 {
  8504  					return ErrIntOverflowErrors
  8505  				}
  8506  				if iNdEx >= l {
  8507  					return io.ErrUnexpectedEOF
  8508  				}
  8509  				b := dAtA[iNdEx]
  8510  				iNdEx++
  8511  				stringLen |= (uint64(b) & 0x7F) << shift
  8512  				if b < 0x80 {
  8513  					break
  8514  				}
  8515  			}
  8516  			intStringLen := int(stringLen)
  8517  			if intStringLen < 0 {
  8518  				return ErrInvalidLengthErrors
  8519  			}
  8520  			postIndex := iNdEx + intStringLen
  8521  			if postIndex > l {
  8522  				return io.ErrUnexpectedEOF
  8523  			}
  8524  			m.Msg = string(dAtA[iNdEx:postIndex])
  8525  			iNdEx = postIndex
  8526  		case 2:
  8527  			if wireType != 2 {
  8528  				return fmt.Errorf("proto: wrong wireType = %d for field TxnID", wireType)
  8529  			}
  8530  			var byteLen int
  8531  			for shift := uint(0); ; shift += 7 {
  8532  				if shift >= 64 {
  8533  					return ErrIntOverflowErrors
  8534  				}
  8535  				if iNdEx >= l {
  8536  					return io.ErrUnexpectedEOF
  8537  				}
  8538  				b := dAtA[iNdEx]
  8539  				iNdEx++
  8540  				byteLen |= (int(b) & 0x7F) << shift
  8541  				if b < 0x80 {
  8542  					break
  8543  				}
  8544  			}
  8545  			if byteLen < 0 {
  8546  				return ErrInvalidLengthErrors
  8547  			}
  8548  			postIndex := iNdEx + byteLen
  8549  			if postIndex > l {
  8550  				return io.ErrUnexpectedEOF
  8551  			}
  8552  			if err := m.TxnID.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8553  				return err
  8554  			}
  8555  			iNdEx = postIndex
  8556  		case 3:
  8557  			if wireType != 2 {
  8558  				return fmt.Errorf("proto: wrong wireType = %d for field Transaction", wireType)
  8559  			}
  8560  			var msglen int
  8561  			for shift := uint(0); ; shift += 7 {
  8562  				if shift >= 64 {
  8563  					return ErrIntOverflowErrors
  8564  				}
  8565  				if iNdEx >= l {
  8566  					return io.ErrUnexpectedEOF
  8567  				}
  8568  				b := dAtA[iNdEx]
  8569  				iNdEx++
  8570  				msglen |= (int(b) & 0x7F) << shift
  8571  				if b < 0x80 {
  8572  					break
  8573  				}
  8574  			}
  8575  			if msglen < 0 {
  8576  				return ErrInvalidLengthErrors
  8577  			}
  8578  			postIndex := iNdEx + msglen
  8579  			if postIndex > l {
  8580  				return io.ErrUnexpectedEOF
  8581  			}
  8582  			if err := m.Transaction.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8583  				return err
  8584  			}
  8585  			iNdEx = postIndex
  8586  		default:
  8587  			iNdEx = preIndex
  8588  			skippy, err := skipErrors(dAtA[iNdEx:])
  8589  			if err != nil {
  8590  				return err
  8591  			}
  8592  			if skippy < 0 {
  8593  				return ErrInvalidLengthErrors
  8594  			}
  8595  			if (iNdEx + skippy) > l {
  8596  				return io.ErrUnexpectedEOF
  8597  			}
  8598  			iNdEx += skippy
  8599  		}
  8600  	}
  8601  
  8602  	if iNdEx > l {
  8603  		return io.ErrUnexpectedEOF
  8604  	}
  8605  	return nil
  8606  }
  8607  func (m *TxnAlreadyEncounteredErrorError) Unmarshal(dAtA []byte) error {
  8608  	l := len(dAtA)
  8609  	iNdEx := 0
  8610  	for iNdEx < l {
  8611  		preIndex := iNdEx
  8612  		var wire uint64
  8613  		for shift := uint(0); ; shift += 7 {
  8614  			if shift >= 64 {
  8615  				return ErrIntOverflowErrors
  8616  			}
  8617  			if iNdEx >= l {
  8618  				return io.ErrUnexpectedEOF
  8619  			}
  8620  			b := dAtA[iNdEx]
  8621  			iNdEx++
  8622  			wire |= (uint64(b) & 0x7F) << shift
  8623  			if b < 0x80 {
  8624  				break
  8625  			}
  8626  		}
  8627  		fieldNum := int32(wire >> 3)
  8628  		wireType := int(wire & 0x7)
  8629  		if wireType == 4 {
  8630  			return fmt.Errorf("proto: TxnAlreadyEncounteredErrorError: wiretype end group for non-group")
  8631  		}
  8632  		if fieldNum <= 0 {
  8633  			return fmt.Errorf("proto: TxnAlreadyEncounteredErrorError: illegal tag %d (wire type %d)", fieldNum, wire)
  8634  		}
  8635  		switch fieldNum {
  8636  		case 1:
  8637  			if wireType != 2 {
  8638  				return fmt.Errorf("proto: wrong wireType = %d for field PrevError", wireType)
  8639  			}
  8640  			var stringLen uint64
  8641  			for shift := uint(0); ; shift += 7 {
  8642  				if shift >= 64 {
  8643  					return ErrIntOverflowErrors
  8644  				}
  8645  				if iNdEx >= l {
  8646  					return io.ErrUnexpectedEOF
  8647  				}
  8648  				b := dAtA[iNdEx]
  8649  				iNdEx++
  8650  				stringLen |= (uint64(b) & 0x7F) << shift
  8651  				if b < 0x80 {
  8652  					break
  8653  				}
  8654  			}
  8655  			intStringLen := int(stringLen)
  8656  			if intStringLen < 0 {
  8657  				return ErrInvalidLengthErrors
  8658  			}
  8659  			postIndex := iNdEx + intStringLen
  8660  			if postIndex > l {
  8661  				return io.ErrUnexpectedEOF
  8662  			}
  8663  			m.PrevError = string(dAtA[iNdEx:postIndex])
  8664  			iNdEx = postIndex
  8665  		default:
  8666  			iNdEx = preIndex
  8667  			skippy, err := skipErrors(dAtA[iNdEx:])
  8668  			if err != nil {
  8669  				return err
  8670  			}
  8671  			if skippy < 0 {
  8672  				return ErrInvalidLengthErrors
  8673  			}
  8674  			if (iNdEx + skippy) > l {
  8675  				return io.ErrUnexpectedEOF
  8676  			}
  8677  			iNdEx += skippy
  8678  		}
  8679  	}
  8680  
  8681  	if iNdEx > l {
  8682  		return io.ErrUnexpectedEOF
  8683  	}
  8684  	return nil
  8685  }
  8686  func (m *IntegerOverflowError) Unmarshal(dAtA []byte) error {
  8687  	l := len(dAtA)
  8688  	iNdEx := 0
  8689  	for iNdEx < l {
  8690  		preIndex := iNdEx
  8691  		var wire uint64
  8692  		for shift := uint(0); ; shift += 7 {
  8693  			if shift >= 64 {
  8694  				return ErrIntOverflowErrors
  8695  			}
  8696  			if iNdEx >= l {
  8697  				return io.ErrUnexpectedEOF
  8698  			}
  8699  			b := dAtA[iNdEx]
  8700  			iNdEx++
  8701  			wire |= (uint64(b) & 0x7F) << shift
  8702  			if b < 0x80 {
  8703  				break
  8704  			}
  8705  		}
  8706  		fieldNum := int32(wire >> 3)
  8707  		wireType := int(wire & 0x7)
  8708  		if wireType == 4 {
  8709  			return fmt.Errorf("proto: IntegerOverflowError: wiretype end group for non-group")
  8710  		}
  8711  		if fieldNum <= 0 {
  8712  			return fmt.Errorf("proto: IntegerOverflowError: illegal tag %d (wire type %d)", fieldNum, wire)
  8713  		}
  8714  		switch fieldNum {
  8715  		case 1:
  8716  			if wireType != 2 {
  8717  				return fmt.Errorf("proto: wrong wireType = %d for field Key", wireType)
  8718  			}
  8719  			var byteLen int
  8720  			for shift := uint(0); ; shift += 7 {
  8721  				if shift >= 64 {
  8722  					return ErrIntOverflowErrors
  8723  				}
  8724  				if iNdEx >= l {
  8725  					return io.ErrUnexpectedEOF
  8726  				}
  8727  				b := dAtA[iNdEx]
  8728  				iNdEx++
  8729  				byteLen |= (int(b) & 0x7F) << shift
  8730  				if b < 0x80 {
  8731  					break
  8732  				}
  8733  			}
  8734  			if byteLen < 0 {
  8735  				return ErrInvalidLengthErrors
  8736  			}
  8737  			postIndex := iNdEx + byteLen
  8738  			if postIndex > l {
  8739  				return io.ErrUnexpectedEOF
  8740  			}
  8741  			m.Key = append(m.Key[:0], dAtA[iNdEx:postIndex]...)
  8742  			if m.Key == nil {
  8743  				m.Key = []byte{}
  8744  			}
  8745  			iNdEx = postIndex
  8746  		case 2:
  8747  			if wireType != 0 {
  8748  				return fmt.Errorf("proto: wrong wireType = %d for field CurrentValue", wireType)
  8749  			}
  8750  			m.CurrentValue = 0
  8751  			for shift := uint(0); ; shift += 7 {
  8752  				if shift >= 64 {
  8753  					return ErrIntOverflowErrors
  8754  				}
  8755  				if iNdEx >= l {
  8756  					return io.ErrUnexpectedEOF
  8757  				}
  8758  				b := dAtA[iNdEx]
  8759  				iNdEx++
  8760  				m.CurrentValue |= (int64(b) & 0x7F) << shift
  8761  				if b < 0x80 {
  8762  					break
  8763  				}
  8764  			}
  8765  		case 3:
  8766  			if wireType != 0 {
  8767  				return fmt.Errorf("proto: wrong wireType = %d for field IncrementValue", wireType)
  8768  			}
  8769  			m.IncrementValue = 0
  8770  			for shift := uint(0); ; shift += 7 {
  8771  				if shift >= 64 {
  8772  					return ErrIntOverflowErrors
  8773  				}
  8774  				if iNdEx >= l {
  8775  					return io.ErrUnexpectedEOF
  8776  				}
  8777  				b := dAtA[iNdEx]
  8778  				iNdEx++
  8779  				m.IncrementValue |= (int64(b) & 0x7F) << shift
  8780  				if b < 0x80 {
  8781  					break
  8782  				}
  8783  			}
  8784  		default:
  8785  			iNdEx = preIndex
  8786  			skippy, err := skipErrors(dAtA[iNdEx:])
  8787  			if err != nil {
  8788  				return err
  8789  			}
  8790  			if skippy < 0 {
  8791  				return ErrInvalidLengthErrors
  8792  			}
  8793  			if (iNdEx + skippy) > l {
  8794  				return io.ErrUnexpectedEOF
  8795  			}
  8796  			iNdEx += skippy
  8797  		}
  8798  	}
  8799  
  8800  	if iNdEx > l {
  8801  		return io.ErrUnexpectedEOF
  8802  	}
  8803  	return nil
  8804  }
  8805  func (m *BatchTimestampBeforeGCError) Unmarshal(dAtA []byte) error {
  8806  	l := len(dAtA)
  8807  	iNdEx := 0
  8808  	for iNdEx < l {
  8809  		preIndex := iNdEx
  8810  		var wire uint64
  8811  		for shift := uint(0); ; shift += 7 {
  8812  			if shift >= 64 {
  8813  				return ErrIntOverflowErrors
  8814  			}
  8815  			if iNdEx >= l {
  8816  				return io.ErrUnexpectedEOF
  8817  			}
  8818  			b := dAtA[iNdEx]
  8819  			iNdEx++
  8820  			wire |= (uint64(b) & 0x7F) << shift
  8821  			if b < 0x80 {
  8822  				break
  8823  			}
  8824  		}
  8825  		fieldNum := int32(wire >> 3)
  8826  		wireType := int(wire & 0x7)
  8827  		if wireType == 4 {
  8828  			return fmt.Errorf("proto: BatchTimestampBeforeGCError: wiretype end group for non-group")
  8829  		}
  8830  		if fieldNum <= 0 {
  8831  			return fmt.Errorf("proto: BatchTimestampBeforeGCError: illegal tag %d (wire type %d)", fieldNum, wire)
  8832  		}
  8833  		switch fieldNum {
  8834  		case 1:
  8835  			if wireType != 2 {
  8836  				return fmt.Errorf("proto: wrong wireType = %d for field Timestamp", wireType)
  8837  			}
  8838  			var msglen int
  8839  			for shift := uint(0); ; shift += 7 {
  8840  				if shift >= 64 {
  8841  					return ErrIntOverflowErrors
  8842  				}
  8843  				if iNdEx >= l {
  8844  					return io.ErrUnexpectedEOF
  8845  				}
  8846  				b := dAtA[iNdEx]
  8847  				iNdEx++
  8848  				msglen |= (int(b) & 0x7F) << shift
  8849  				if b < 0x80 {
  8850  					break
  8851  				}
  8852  			}
  8853  			if msglen < 0 {
  8854  				return ErrInvalidLengthErrors
  8855  			}
  8856  			postIndex := iNdEx + msglen
  8857  			if postIndex > l {
  8858  				return io.ErrUnexpectedEOF
  8859  			}
  8860  			if err := m.Timestamp.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8861  				return err
  8862  			}
  8863  			iNdEx = postIndex
  8864  		case 2:
  8865  			if wireType != 2 {
  8866  				return fmt.Errorf("proto: wrong wireType = %d for field Threshold", wireType)
  8867  			}
  8868  			var msglen int
  8869  			for shift := uint(0); ; shift += 7 {
  8870  				if shift >= 64 {
  8871  					return ErrIntOverflowErrors
  8872  				}
  8873  				if iNdEx >= l {
  8874  					return io.ErrUnexpectedEOF
  8875  				}
  8876  				b := dAtA[iNdEx]
  8877  				iNdEx++
  8878  				msglen |= (int(b) & 0x7F) << shift
  8879  				if b < 0x80 {
  8880  					break
  8881  				}
  8882  			}
  8883  			if msglen < 0 {
  8884  				return ErrInvalidLengthErrors
  8885  			}
  8886  			postIndex := iNdEx + msglen
  8887  			if postIndex > l {
  8888  				return io.ErrUnexpectedEOF
  8889  			}
  8890  			if err := m.Threshold.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8891  				return err
  8892  			}
  8893  			iNdEx = postIndex
  8894  		default:
  8895  			iNdEx = preIndex
  8896  			skippy, err := skipErrors(dAtA[iNdEx:])
  8897  			if err != nil {
  8898  				return err
  8899  			}
  8900  			if skippy < 0 {
  8901  				return ErrInvalidLengthErrors
  8902  			}
  8903  			if (iNdEx + skippy) > l {
  8904  				return io.ErrUnexpectedEOF
  8905  			}
  8906  			iNdEx += skippy
  8907  		}
  8908  	}
  8909  
  8910  	if iNdEx > l {
  8911  		return io.ErrUnexpectedEOF
  8912  	}
  8913  	return nil
  8914  }
  8915  func (m *IntentMissingError) Unmarshal(dAtA []byte) error {
  8916  	l := len(dAtA)
  8917  	iNdEx := 0
  8918  	for iNdEx < l {
  8919  		preIndex := iNdEx
  8920  		var wire uint64
  8921  		for shift := uint(0); ; shift += 7 {
  8922  			if shift >= 64 {
  8923  				return ErrIntOverflowErrors
  8924  			}
  8925  			if iNdEx >= l {
  8926  				return io.ErrUnexpectedEOF
  8927  			}
  8928  			b := dAtA[iNdEx]
  8929  			iNdEx++
  8930  			wire |= (uint64(b) & 0x7F) << shift
  8931  			if b < 0x80 {
  8932  				break
  8933  			}
  8934  		}
  8935  		fieldNum := int32(wire >> 3)
  8936  		wireType := int(wire & 0x7)
  8937  		if wireType == 4 {
  8938  			return fmt.Errorf("proto: IntentMissingError: wiretype end group for non-group")
  8939  		}
  8940  		if fieldNum <= 0 {
  8941  			return fmt.Errorf("proto: IntentMissingError: illegal tag %d (wire type %d)", fieldNum, wire)
  8942  		}
  8943  		switch fieldNum {
  8944  		case 1:
  8945  			if wireType != 2 {
  8946  				return fmt.Errorf("proto: wrong wireType = %d for field WrongIntent", wireType)
  8947  			}
  8948  			var msglen int
  8949  			for shift := uint(0); ; shift += 7 {
  8950  				if shift >= 64 {
  8951  					return ErrIntOverflowErrors
  8952  				}
  8953  				if iNdEx >= l {
  8954  					return io.ErrUnexpectedEOF
  8955  				}
  8956  				b := dAtA[iNdEx]
  8957  				iNdEx++
  8958  				msglen |= (int(b) & 0x7F) << shift
  8959  				if b < 0x80 {
  8960  					break
  8961  				}
  8962  			}
  8963  			if msglen < 0 {
  8964  				return ErrInvalidLengthErrors
  8965  			}
  8966  			postIndex := iNdEx + msglen
  8967  			if postIndex > l {
  8968  				return io.ErrUnexpectedEOF
  8969  			}
  8970  			if m.WrongIntent == nil {
  8971  				m.WrongIntent = &Intent{}
  8972  			}
  8973  			if err := m.WrongIntent.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  8974  				return err
  8975  			}
  8976  			iNdEx = postIndex
  8977  		case 2:
  8978  			if wireType != 2 {
  8979  				return fmt.Errorf("proto: wrong wireType = %d for field Key", wireType)
  8980  			}
  8981  			var byteLen int
  8982  			for shift := uint(0); ; shift += 7 {
  8983  				if shift >= 64 {
  8984  					return ErrIntOverflowErrors
  8985  				}
  8986  				if iNdEx >= l {
  8987  					return io.ErrUnexpectedEOF
  8988  				}
  8989  				b := dAtA[iNdEx]
  8990  				iNdEx++
  8991  				byteLen |= (int(b) & 0x7F) << shift
  8992  				if b < 0x80 {
  8993  					break
  8994  				}
  8995  			}
  8996  			if byteLen < 0 {
  8997  				return ErrInvalidLengthErrors
  8998  			}
  8999  			postIndex := iNdEx + byteLen
  9000  			if postIndex > l {
  9001  				return io.ErrUnexpectedEOF
  9002  			}
  9003  			m.Key = append(m.Key[:0], dAtA[iNdEx:postIndex]...)
  9004  			if m.Key == nil {
  9005  				m.Key = []byte{}
  9006  			}
  9007  			iNdEx = postIndex
  9008  		default:
  9009  			iNdEx = preIndex
  9010  			skippy, err := skipErrors(dAtA[iNdEx:])
  9011  			if err != nil {
  9012  				return err
  9013  			}
  9014  			if skippy < 0 {
  9015  				return ErrInvalidLengthErrors
  9016  			}
  9017  			if (iNdEx + skippy) > l {
  9018  				return io.ErrUnexpectedEOF
  9019  			}
  9020  			iNdEx += skippy
  9021  		}
  9022  	}
  9023  
  9024  	if iNdEx > l {
  9025  		return io.ErrUnexpectedEOF
  9026  	}
  9027  	return nil
  9028  }
  9029  func (m *MergeInProgressError) Unmarshal(dAtA []byte) error {
  9030  	l := len(dAtA)
  9031  	iNdEx := 0
  9032  	for iNdEx < l {
  9033  		preIndex := iNdEx
  9034  		var wire uint64
  9035  		for shift := uint(0); ; shift += 7 {
  9036  			if shift >= 64 {
  9037  				return ErrIntOverflowErrors
  9038  			}
  9039  			if iNdEx >= l {
  9040  				return io.ErrUnexpectedEOF
  9041  			}
  9042  			b := dAtA[iNdEx]
  9043  			iNdEx++
  9044  			wire |= (uint64(b) & 0x7F) << shift
  9045  			if b < 0x80 {
  9046  				break
  9047  			}
  9048  		}
  9049  		fieldNum := int32(wire >> 3)
  9050  		wireType := int(wire & 0x7)
  9051  		if wireType == 4 {
  9052  			return fmt.Errorf("proto: MergeInProgressError: wiretype end group for non-group")
  9053  		}
  9054  		if fieldNum <= 0 {
  9055  			return fmt.Errorf("proto: MergeInProgressError: illegal tag %d (wire type %d)", fieldNum, wire)
  9056  		}
  9057  		switch fieldNum {
  9058  		default:
  9059  			iNdEx = preIndex
  9060  			skippy, err := skipErrors(dAtA[iNdEx:])
  9061  			if err != nil {
  9062  				return err
  9063  			}
  9064  			if skippy < 0 {
  9065  				return ErrInvalidLengthErrors
  9066  			}
  9067  			if (iNdEx + skippy) > l {
  9068  				return io.ErrUnexpectedEOF
  9069  			}
  9070  			iNdEx += skippy
  9071  		}
  9072  	}
  9073  
  9074  	if iNdEx > l {
  9075  		return io.ErrUnexpectedEOF
  9076  	}
  9077  	return nil
  9078  }
  9079  func (m *RangeFeedRetryError) Unmarshal(dAtA []byte) error {
  9080  	l := len(dAtA)
  9081  	iNdEx := 0
  9082  	for iNdEx < l {
  9083  		preIndex := iNdEx
  9084  		var wire uint64
  9085  		for shift := uint(0); ; shift += 7 {
  9086  			if shift >= 64 {
  9087  				return ErrIntOverflowErrors
  9088  			}
  9089  			if iNdEx >= l {
  9090  				return io.ErrUnexpectedEOF
  9091  			}
  9092  			b := dAtA[iNdEx]
  9093  			iNdEx++
  9094  			wire |= (uint64(b) & 0x7F) << shift
  9095  			if b < 0x80 {
  9096  				break
  9097  			}
  9098  		}
  9099  		fieldNum := int32(wire >> 3)
  9100  		wireType := int(wire & 0x7)
  9101  		if wireType == 4 {
  9102  			return fmt.Errorf("proto: RangeFeedRetryError: wiretype end group for non-group")
  9103  		}
  9104  		if fieldNum <= 0 {
  9105  			return fmt.Errorf("proto: RangeFeedRetryError: illegal tag %d (wire type %d)", fieldNum, wire)
  9106  		}
  9107  		switch fieldNum {
  9108  		case 1:
  9109  			if wireType != 0 {
  9110  				return fmt.Errorf("proto: wrong wireType = %d for field Reason", wireType)
  9111  			}
  9112  			m.Reason = 0
  9113  			for shift := uint(0); ; shift += 7 {
  9114  				if shift >= 64 {
  9115  					return ErrIntOverflowErrors
  9116  				}
  9117  				if iNdEx >= l {
  9118  					return io.ErrUnexpectedEOF
  9119  				}
  9120  				b := dAtA[iNdEx]
  9121  				iNdEx++
  9122  				m.Reason |= (RangeFeedRetryError_Reason(b) & 0x7F) << shift
  9123  				if b < 0x80 {
  9124  					break
  9125  				}
  9126  			}
  9127  		default:
  9128  			iNdEx = preIndex
  9129  			skippy, err := skipErrors(dAtA[iNdEx:])
  9130  			if err != nil {
  9131  				return err
  9132  			}
  9133  			if skippy < 0 {
  9134  				return ErrInvalidLengthErrors
  9135  			}
  9136  			if (iNdEx + skippy) > l {
  9137  				return io.ErrUnexpectedEOF
  9138  			}
  9139  			iNdEx += skippy
  9140  		}
  9141  	}
  9142  
  9143  	if iNdEx > l {
  9144  		return io.ErrUnexpectedEOF
  9145  	}
  9146  	return nil
  9147  }
  9148  func (m *IndeterminateCommitError) Unmarshal(dAtA []byte) error {
  9149  	l := len(dAtA)
  9150  	iNdEx := 0
  9151  	for iNdEx < l {
  9152  		preIndex := iNdEx
  9153  		var wire uint64
  9154  		for shift := uint(0); ; shift += 7 {
  9155  			if shift >= 64 {
  9156  				return ErrIntOverflowErrors
  9157  			}
  9158  			if iNdEx >= l {
  9159  				return io.ErrUnexpectedEOF
  9160  			}
  9161  			b := dAtA[iNdEx]
  9162  			iNdEx++
  9163  			wire |= (uint64(b) & 0x7F) << shift
  9164  			if b < 0x80 {
  9165  				break
  9166  			}
  9167  		}
  9168  		fieldNum := int32(wire >> 3)
  9169  		wireType := int(wire & 0x7)
  9170  		if wireType == 4 {
  9171  			return fmt.Errorf("proto: IndeterminateCommitError: wiretype end group for non-group")
  9172  		}
  9173  		if fieldNum <= 0 {
  9174  			return fmt.Errorf("proto: IndeterminateCommitError: illegal tag %d (wire type %d)", fieldNum, wire)
  9175  		}
  9176  		switch fieldNum {
  9177  		case 1:
  9178  			if wireType != 2 {
  9179  				return fmt.Errorf("proto: wrong wireType = %d for field StagingTxn", wireType)
  9180  			}
  9181  			var msglen int
  9182  			for shift := uint(0); ; shift += 7 {
  9183  				if shift >= 64 {
  9184  					return ErrIntOverflowErrors
  9185  				}
  9186  				if iNdEx >= l {
  9187  					return io.ErrUnexpectedEOF
  9188  				}
  9189  				b := dAtA[iNdEx]
  9190  				iNdEx++
  9191  				msglen |= (int(b) & 0x7F) << shift
  9192  				if b < 0x80 {
  9193  					break
  9194  				}
  9195  			}
  9196  			if msglen < 0 {
  9197  				return ErrInvalidLengthErrors
  9198  			}
  9199  			postIndex := iNdEx + msglen
  9200  			if postIndex > l {
  9201  				return io.ErrUnexpectedEOF
  9202  			}
  9203  			if err := m.StagingTxn.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9204  				return err
  9205  			}
  9206  			iNdEx = postIndex
  9207  		default:
  9208  			iNdEx = preIndex
  9209  			skippy, err := skipErrors(dAtA[iNdEx:])
  9210  			if err != nil {
  9211  				return err
  9212  			}
  9213  			if skippy < 0 {
  9214  				return ErrInvalidLengthErrors
  9215  			}
  9216  			if (iNdEx + skippy) > l {
  9217  				return io.ErrUnexpectedEOF
  9218  			}
  9219  			iNdEx += skippy
  9220  		}
  9221  	}
  9222  
  9223  	if iNdEx > l {
  9224  		return io.ErrUnexpectedEOF
  9225  	}
  9226  	return nil
  9227  }
  9228  func (m *ErrorDetail) Unmarshal(dAtA []byte) error {
  9229  	l := len(dAtA)
  9230  	iNdEx := 0
  9231  	for iNdEx < l {
  9232  		preIndex := iNdEx
  9233  		var wire uint64
  9234  		for shift := uint(0); ; shift += 7 {
  9235  			if shift >= 64 {
  9236  				return ErrIntOverflowErrors
  9237  			}
  9238  			if iNdEx >= l {
  9239  				return io.ErrUnexpectedEOF
  9240  			}
  9241  			b := dAtA[iNdEx]
  9242  			iNdEx++
  9243  			wire |= (uint64(b) & 0x7F) << shift
  9244  			if b < 0x80 {
  9245  				break
  9246  			}
  9247  		}
  9248  		fieldNum := int32(wire >> 3)
  9249  		wireType := int(wire & 0x7)
  9250  		if wireType == 4 {
  9251  			return fmt.Errorf("proto: ErrorDetail: wiretype end group for non-group")
  9252  		}
  9253  		if fieldNum <= 0 {
  9254  			return fmt.Errorf("proto: ErrorDetail: illegal tag %d (wire type %d)", fieldNum, wire)
  9255  		}
  9256  		switch fieldNum {
  9257  		case 1:
  9258  			if wireType != 2 {
  9259  				return fmt.Errorf("proto: wrong wireType = %d for field NotLeaseHolder", wireType)
  9260  			}
  9261  			var msglen int
  9262  			for shift := uint(0); ; shift += 7 {
  9263  				if shift >= 64 {
  9264  					return ErrIntOverflowErrors
  9265  				}
  9266  				if iNdEx >= l {
  9267  					return io.ErrUnexpectedEOF
  9268  				}
  9269  				b := dAtA[iNdEx]
  9270  				iNdEx++
  9271  				msglen |= (int(b) & 0x7F) << shift
  9272  				if b < 0x80 {
  9273  					break
  9274  				}
  9275  			}
  9276  			if msglen < 0 {
  9277  				return ErrInvalidLengthErrors
  9278  			}
  9279  			postIndex := iNdEx + msglen
  9280  			if postIndex > l {
  9281  				return io.ErrUnexpectedEOF
  9282  			}
  9283  			v := &NotLeaseHolderError{}
  9284  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9285  				return err
  9286  			}
  9287  			m.Value = &ErrorDetail_NotLeaseHolder{v}
  9288  			iNdEx = postIndex
  9289  		case 2:
  9290  			if wireType != 2 {
  9291  				return fmt.Errorf("proto: wrong wireType = %d for field RangeNotFound", wireType)
  9292  			}
  9293  			var msglen int
  9294  			for shift := uint(0); ; shift += 7 {
  9295  				if shift >= 64 {
  9296  					return ErrIntOverflowErrors
  9297  				}
  9298  				if iNdEx >= l {
  9299  					return io.ErrUnexpectedEOF
  9300  				}
  9301  				b := dAtA[iNdEx]
  9302  				iNdEx++
  9303  				msglen |= (int(b) & 0x7F) << shift
  9304  				if b < 0x80 {
  9305  					break
  9306  				}
  9307  			}
  9308  			if msglen < 0 {
  9309  				return ErrInvalidLengthErrors
  9310  			}
  9311  			postIndex := iNdEx + msglen
  9312  			if postIndex > l {
  9313  				return io.ErrUnexpectedEOF
  9314  			}
  9315  			v := &RangeNotFoundError{}
  9316  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9317  				return err
  9318  			}
  9319  			m.Value = &ErrorDetail_RangeNotFound{v}
  9320  			iNdEx = postIndex
  9321  		case 3:
  9322  			if wireType != 2 {
  9323  				return fmt.Errorf("proto: wrong wireType = %d for field RangeKeyMismatch", wireType)
  9324  			}
  9325  			var msglen int
  9326  			for shift := uint(0); ; shift += 7 {
  9327  				if shift >= 64 {
  9328  					return ErrIntOverflowErrors
  9329  				}
  9330  				if iNdEx >= l {
  9331  					return io.ErrUnexpectedEOF
  9332  				}
  9333  				b := dAtA[iNdEx]
  9334  				iNdEx++
  9335  				msglen |= (int(b) & 0x7F) << shift
  9336  				if b < 0x80 {
  9337  					break
  9338  				}
  9339  			}
  9340  			if msglen < 0 {
  9341  				return ErrInvalidLengthErrors
  9342  			}
  9343  			postIndex := iNdEx + msglen
  9344  			if postIndex > l {
  9345  				return io.ErrUnexpectedEOF
  9346  			}
  9347  			v := &RangeKeyMismatchError{}
  9348  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9349  				return err
  9350  			}
  9351  			m.Value = &ErrorDetail_RangeKeyMismatch{v}
  9352  			iNdEx = postIndex
  9353  		case 4:
  9354  			if wireType != 2 {
  9355  				return fmt.Errorf("proto: wrong wireType = %d for field ReadWithinUncertaintyInterval", wireType)
  9356  			}
  9357  			var msglen int
  9358  			for shift := uint(0); ; shift += 7 {
  9359  				if shift >= 64 {
  9360  					return ErrIntOverflowErrors
  9361  				}
  9362  				if iNdEx >= l {
  9363  					return io.ErrUnexpectedEOF
  9364  				}
  9365  				b := dAtA[iNdEx]
  9366  				iNdEx++
  9367  				msglen |= (int(b) & 0x7F) << shift
  9368  				if b < 0x80 {
  9369  					break
  9370  				}
  9371  			}
  9372  			if msglen < 0 {
  9373  				return ErrInvalidLengthErrors
  9374  			}
  9375  			postIndex := iNdEx + msglen
  9376  			if postIndex > l {
  9377  				return io.ErrUnexpectedEOF
  9378  			}
  9379  			v := &ReadWithinUncertaintyIntervalError{}
  9380  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9381  				return err
  9382  			}
  9383  			m.Value = &ErrorDetail_ReadWithinUncertaintyInterval{v}
  9384  			iNdEx = postIndex
  9385  		case 5:
  9386  			if wireType != 2 {
  9387  				return fmt.Errorf("proto: wrong wireType = %d for field TransactionAborted", wireType)
  9388  			}
  9389  			var msglen int
  9390  			for shift := uint(0); ; shift += 7 {
  9391  				if shift >= 64 {
  9392  					return ErrIntOverflowErrors
  9393  				}
  9394  				if iNdEx >= l {
  9395  					return io.ErrUnexpectedEOF
  9396  				}
  9397  				b := dAtA[iNdEx]
  9398  				iNdEx++
  9399  				msglen |= (int(b) & 0x7F) << shift
  9400  				if b < 0x80 {
  9401  					break
  9402  				}
  9403  			}
  9404  			if msglen < 0 {
  9405  				return ErrInvalidLengthErrors
  9406  			}
  9407  			postIndex := iNdEx + msglen
  9408  			if postIndex > l {
  9409  				return io.ErrUnexpectedEOF
  9410  			}
  9411  			v := &TransactionAbortedError{}
  9412  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9413  				return err
  9414  			}
  9415  			m.Value = &ErrorDetail_TransactionAborted{v}
  9416  			iNdEx = postIndex
  9417  		case 6:
  9418  			if wireType != 2 {
  9419  				return fmt.Errorf("proto: wrong wireType = %d for field TransactionPush", wireType)
  9420  			}
  9421  			var msglen int
  9422  			for shift := uint(0); ; shift += 7 {
  9423  				if shift >= 64 {
  9424  					return ErrIntOverflowErrors
  9425  				}
  9426  				if iNdEx >= l {
  9427  					return io.ErrUnexpectedEOF
  9428  				}
  9429  				b := dAtA[iNdEx]
  9430  				iNdEx++
  9431  				msglen |= (int(b) & 0x7F) << shift
  9432  				if b < 0x80 {
  9433  					break
  9434  				}
  9435  			}
  9436  			if msglen < 0 {
  9437  				return ErrInvalidLengthErrors
  9438  			}
  9439  			postIndex := iNdEx + msglen
  9440  			if postIndex > l {
  9441  				return io.ErrUnexpectedEOF
  9442  			}
  9443  			v := &TransactionPushError{}
  9444  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9445  				return err
  9446  			}
  9447  			m.Value = &ErrorDetail_TransactionPush{v}
  9448  			iNdEx = postIndex
  9449  		case 7:
  9450  			if wireType != 2 {
  9451  				return fmt.Errorf("proto: wrong wireType = %d for field TransactionRetry", wireType)
  9452  			}
  9453  			var msglen int
  9454  			for shift := uint(0); ; shift += 7 {
  9455  				if shift >= 64 {
  9456  					return ErrIntOverflowErrors
  9457  				}
  9458  				if iNdEx >= l {
  9459  					return io.ErrUnexpectedEOF
  9460  				}
  9461  				b := dAtA[iNdEx]
  9462  				iNdEx++
  9463  				msglen |= (int(b) & 0x7F) << shift
  9464  				if b < 0x80 {
  9465  					break
  9466  				}
  9467  			}
  9468  			if msglen < 0 {
  9469  				return ErrInvalidLengthErrors
  9470  			}
  9471  			postIndex := iNdEx + msglen
  9472  			if postIndex > l {
  9473  				return io.ErrUnexpectedEOF
  9474  			}
  9475  			v := &TransactionRetryError{}
  9476  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9477  				return err
  9478  			}
  9479  			m.Value = &ErrorDetail_TransactionRetry{v}
  9480  			iNdEx = postIndex
  9481  		case 8:
  9482  			if wireType != 2 {
  9483  				return fmt.Errorf("proto: wrong wireType = %d for field TransactionStatus", wireType)
  9484  			}
  9485  			var msglen int
  9486  			for shift := uint(0); ; shift += 7 {
  9487  				if shift >= 64 {
  9488  					return ErrIntOverflowErrors
  9489  				}
  9490  				if iNdEx >= l {
  9491  					return io.ErrUnexpectedEOF
  9492  				}
  9493  				b := dAtA[iNdEx]
  9494  				iNdEx++
  9495  				msglen |= (int(b) & 0x7F) << shift
  9496  				if b < 0x80 {
  9497  					break
  9498  				}
  9499  			}
  9500  			if msglen < 0 {
  9501  				return ErrInvalidLengthErrors
  9502  			}
  9503  			postIndex := iNdEx + msglen
  9504  			if postIndex > l {
  9505  				return io.ErrUnexpectedEOF
  9506  			}
  9507  			v := &TransactionStatusError{}
  9508  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9509  				return err
  9510  			}
  9511  			m.Value = &ErrorDetail_TransactionStatus{v}
  9512  			iNdEx = postIndex
  9513  		case 9:
  9514  			if wireType != 2 {
  9515  				return fmt.Errorf("proto: wrong wireType = %d for field WriteIntent", wireType)
  9516  			}
  9517  			var msglen int
  9518  			for shift := uint(0); ; shift += 7 {
  9519  				if shift >= 64 {
  9520  					return ErrIntOverflowErrors
  9521  				}
  9522  				if iNdEx >= l {
  9523  					return io.ErrUnexpectedEOF
  9524  				}
  9525  				b := dAtA[iNdEx]
  9526  				iNdEx++
  9527  				msglen |= (int(b) & 0x7F) << shift
  9528  				if b < 0x80 {
  9529  					break
  9530  				}
  9531  			}
  9532  			if msglen < 0 {
  9533  				return ErrInvalidLengthErrors
  9534  			}
  9535  			postIndex := iNdEx + msglen
  9536  			if postIndex > l {
  9537  				return io.ErrUnexpectedEOF
  9538  			}
  9539  			v := &WriteIntentError{}
  9540  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9541  				return err
  9542  			}
  9543  			m.Value = &ErrorDetail_WriteIntent{v}
  9544  			iNdEx = postIndex
  9545  		case 10:
  9546  			if wireType != 2 {
  9547  				return fmt.Errorf("proto: wrong wireType = %d for field WriteTooOld", wireType)
  9548  			}
  9549  			var msglen int
  9550  			for shift := uint(0); ; shift += 7 {
  9551  				if shift >= 64 {
  9552  					return ErrIntOverflowErrors
  9553  				}
  9554  				if iNdEx >= l {
  9555  					return io.ErrUnexpectedEOF
  9556  				}
  9557  				b := dAtA[iNdEx]
  9558  				iNdEx++
  9559  				msglen |= (int(b) & 0x7F) << shift
  9560  				if b < 0x80 {
  9561  					break
  9562  				}
  9563  			}
  9564  			if msglen < 0 {
  9565  				return ErrInvalidLengthErrors
  9566  			}
  9567  			postIndex := iNdEx + msglen
  9568  			if postIndex > l {
  9569  				return io.ErrUnexpectedEOF
  9570  			}
  9571  			v := &WriteTooOldError{}
  9572  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9573  				return err
  9574  			}
  9575  			m.Value = &ErrorDetail_WriteTooOld{v}
  9576  			iNdEx = postIndex
  9577  		case 11:
  9578  			if wireType != 2 {
  9579  				return fmt.Errorf("proto: wrong wireType = %d for field OpRequiresTxn", wireType)
  9580  			}
  9581  			var msglen int
  9582  			for shift := uint(0); ; shift += 7 {
  9583  				if shift >= 64 {
  9584  					return ErrIntOverflowErrors
  9585  				}
  9586  				if iNdEx >= l {
  9587  					return io.ErrUnexpectedEOF
  9588  				}
  9589  				b := dAtA[iNdEx]
  9590  				iNdEx++
  9591  				msglen |= (int(b) & 0x7F) << shift
  9592  				if b < 0x80 {
  9593  					break
  9594  				}
  9595  			}
  9596  			if msglen < 0 {
  9597  				return ErrInvalidLengthErrors
  9598  			}
  9599  			postIndex := iNdEx + msglen
  9600  			if postIndex > l {
  9601  				return io.ErrUnexpectedEOF
  9602  			}
  9603  			v := &OpRequiresTxnError{}
  9604  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9605  				return err
  9606  			}
  9607  			m.Value = &ErrorDetail_OpRequiresTxn{v}
  9608  			iNdEx = postIndex
  9609  		case 12:
  9610  			if wireType != 2 {
  9611  				return fmt.Errorf("proto: wrong wireType = %d for field ConditionFailed", wireType)
  9612  			}
  9613  			var msglen int
  9614  			for shift := uint(0); ; shift += 7 {
  9615  				if shift >= 64 {
  9616  					return ErrIntOverflowErrors
  9617  				}
  9618  				if iNdEx >= l {
  9619  					return io.ErrUnexpectedEOF
  9620  				}
  9621  				b := dAtA[iNdEx]
  9622  				iNdEx++
  9623  				msglen |= (int(b) & 0x7F) << shift
  9624  				if b < 0x80 {
  9625  					break
  9626  				}
  9627  			}
  9628  			if msglen < 0 {
  9629  				return ErrInvalidLengthErrors
  9630  			}
  9631  			postIndex := iNdEx + msglen
  9632  			if postIndex > l {
  9633  				return io.ErrUnexpectedEOF
  9634  			}
  9635  			v := &ConditionFailedError{}
  9636  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9637  				return err
  9638  			}
  9639  			m.Value = &ErrorDetail_ConditionFailed{v}
  9640  			iNdEx = postIndex
  9641  		case 13:
  9642  			if wireType != 2 {
  9643  				return fmt.Errorf("proto: wrong wireType = %d for field LeaseRejected", wireType)
  9644  			}
  9645  			var msglen int
  9646  			for shift := uint(0); ; shift += 7 {
  9647  				if shift >= 64 {
  9648  					return ErrIntOverflowErrors
  9649  				}
  9650  				if iNdEx >= l {
  9651  					return io.ErrUnexpectedEOF
  9652  				}
  9653  				b := dAtA[iNdEx]
  9654  				iNdEx++
  9655  				msglen |= (int(b) & 0x7F) << shift
  9656  				if b < 0x80 {
  9657  					break
  9658  				}
  9659  			}
  9660  			if msglen < 0 {
  9661  				return ErrInvalidLengthErrors
  9662  			}
  9663  			postIndex := iNdEx + msglen
  9664  			if postIndex > l {
  9665  				return io.ErrUnexpectedEOF
  9666  			}
  9667  			v := &LeaseRejectedError{}
  9668  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9669  				return err
  9670  			}
  9671  			m.Value = &ErrorDetail_LeaseRejected{v}
  9672  			iNdEx = postIndex
  9673  		case 14:
  9674  			if wireType != 2 {
  9675  				return fmt.Errorf("proto: wrong wireType = %d for field NodeUnavailable", wireType)
  9676  			}
  9677  			var msglen int
  9678  			for shift := uint(0); ; shift += 7 {
  9679  				if shift >= 64 {
  9680  					return ErrIntOverflowErrors
  9681  				}
  9682  				if iNdEx >= l {
  9683  					return io.ErrUnexpectedEOF
  9684  				}
  9685  				b := dAtA[iNdEx]
  9686  				iNdEx++
  9687  				msglen |= (int(b) & 0x7F) << shift
  9688  				if b < 0x80 {
  9689  					break
  9690  				}
  9691  			}
  9692  			if msglen < 0 {
  9693  				return ErrInvalidLengthErrors
  9694  			}
  9695  			postIndex := iNdEx + msglen
  9696  			if postIndex > l {
  9697  				return io.ErrUnexpectedEOF
  9698  			}
  9699  			v := &NodeUnavailableError{}
  9700  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9701  				return err
  9702  			}
  9703  			m.Value = &ErrorDetail_NodeUnavailable{v}
  9704  			iNdEx = postIndex
  9705  		case 15:
  9706  			if wireType != 2 {
  9707  				return fmt.Errorf("proto: wrong wireType = %d for field Send", wireType)
  9708  			}
  9709  			var msglen int
  9710  			for shift := uint(0); ; shift += 7 {
  9711  				if shift >= 64 {
  9712  					return ErrIntOverflowErrors
  9713  				}
  9714  				if iNdEx >= l {
  9715  					return io.ErrUnexpectedEOF
  9716  				}
  9717  				b := dAtA[iNdEx]
  9718  				iNdEx++
  9719  				msglen |= (int(b) & 0x7F) << shift
  9720  				if b < 0x80 {
  9721  					break
  9722  				}
  9723  			}
  9724  			if msglen < 0 {
  9725  				return ErrInvalidLengthErrors
  9726  			}
  9727  			postIndex := iNdEx + msglen
  9728  			if postIndex > l {
  9729  				return io.ErrUnexpectedEOF
  9730  			}
  9731  			v := &SendError{}
  9732  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9733  				return err
  9734  			}
  9735  			m.Value = &ErrorDetail_Send{v}
  9736  			iNdEx = postIndex
  9737  		case 16:
  9738  			if wireType != 2 {
  9739  				return fmt.Errorf("proto: wrong wireType = %d for field RaftGroupDeleted", wireType)
  9740  			}
  9741  			var msglen int
  9742  			for shift := uint(0); ; shift += 7 {
  9743  				if shift >= 64 {
  9744  					return ErrIntOverflowErrors
  9745  				}
  9746  				if iNdEx >= l {
  9747  					return io.ErrUnexpectedEOF
  9748  				}
  9749  				b := dAtA[iNdEx]
  9750  				iNdEx++
  9751  				msglen |= (int(b) & 0x7F) << shift
  9752  				if b < 0x80 {
  9753  					break
  9754  				}
  9755  			}
  9756  			if msglen < 0 {
  9757  				return ErrInvalidLengthErrors
  9758  			}
  9759  			postIndex := iNdEx + msglen
  9760  			if postIndex > l {
  9761  				return io.ErrUnexpectedEOF
  9762  			}
  9763  			v := &RaftGroupDeletedError{}
  9764  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9765  				return err
  9766  			}
  9767  			m.Value = &ErrorDetail_RaftGroupDeleted{v}
  9768  			iNdEx = postIndex
  9769  		case 17:
  9770  			if wireType != 2 {
  9771  				return fmt.Errorf("proto: wrong wireType = %d for field ReplicaCorruption", wireType)
  9772  			}
  9773  			var msglen int
  9774  			for shift := uint(0); ; shift += 7 {
  9775  				if shift >= 64 {
  9776  					return ErrIntOverflowErrors
  9777  				}
  9778  				if iNdEx >= l {
  9779  					return io.ErrUnexpectedEOF
  9780  				}
  9781  				b := dAtA[iNdEx]
  9782  				iNdEx++
  9783  				msglen |= (int(b) & 0x7F) << shift
  9784  				if b < 0x80 {
  9785  					break
  9786  				}
  9787  			}
  9788  			if msglen < 0 {
  9789  				return ErrInvalidLengthErrors
  9790  			}
  9791  			postIndex := iNdEx + msglen
  9792  			if postIndex > l {
  9793  				return io.ErrUnexpectedEOF
  9794  			}
  9795  			v := &ReplicaCorruptionError{}
  9796  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9797  				return err
  9798  			}
  9799  			m.Value = &ErrorDetail_ReplicaCorruption{v}
  9800  			iNdEx = postIndex
  9801  		case 18:
  9802  			if wireType != 2 {
  9803  				return fmt.Errorf("proto: wrong wireType = %d for field ReplicaTooOld", wireType)
  9804  			}
  9805  			var msglen int
  9806  			for shift := uint(0); ; shift += 7 {
  9807  				if shift >= 64 {
  9808  					return ErrIntOverflowErrors
  9809  				}
  9810  				if iNdEx >= l {
  9811  					return io.ErrUnexpectedEOF
  9812  				}
  9813  				b := dAtA[iNdEx]
  9814  				iNdEx++
  9815  				msglen |= (int(b) & 0x7F) << shift
  9816  				if b < 0x80 {
  9817  					break
  9818  				}
  9819  			}
  9820  			if msglen < 0 {
  9821  				return ErrInvalidLengthErrors
  9822  			}
  9823  			postIndex := iNdEx + msglen
  9824  			if postIndex > l {
  9825  				return io.ErrUnexpectedEOF
  9826  			}
  9827  			v := &ReplicaTooOldError{}
  9828  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9829  				return err
  9830  			}
  9831  			m.Value = &ErrorDetail_ReplicaTooOld{v}
  9832  			iNdEx = postIndex
  9833  		case 26:
  9834  			if wireType != 2 {
  9835  				return fmt.Errorf("proto: wrong wireType = %d for field AmbiguousResult", wireType)
  9836  			}
  9837  			var msglen int
  9838  			for shift := uint(0); ; shift += 7 {
  9839  				if shift >= 64 {
  9840  					return ErrIntOverflowErrors
  9841  				}
  9842  				if iNdEx >= l {
  9843  					return io.ErrUnexpectedEOF
  9844  				}
  9845  				b := dAtA[iNdEx]
  9846  				iNdEx++
  9847  				msglen |= (int(b) & 0x7F) << shift
  9848  				if b < 0x80 {
  9849  					break
  9850  				}
  9851  			}
  9852  			if msglen < 0 {
  9853  				return ErrInvalidLengthErrors
  9854  			}
  9855  			postIndex := iNdEx + msglen
  9856  			if postIndex > l {
  9857  				return io.ErrUnexpectedEOF
  9858  			}
  9859  			v := &AmbiguousResultError{}
  9860  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9861  				return err
  9862  			}
  9863  			m.Value = &ErrorDetail_AmbiguousResult{v}
  9864  			iNdEx = postIndex
  9865  		case 27:
  9866  			if wireType != 2 {
  9867  				return fmt.Errorf("proto: wrong wireType = %d for field StoreNotFound", wireType)
  9868  			}
  9869  			var msglen int
  9870  			for shift := uint(0); ; shift += 7 {
  9871  				if shift >= 64 {
  9872  					return ErrIntOverflowErrors
  9873  				}
  9874  				if iNdEx >= l {
  9875  					return io.ErrUnexpectedEOF
  9876  				}
  9877  				b := dAtA[iNdEx]
  9878  				iNdEx++
  9879  				msglen |= (int(b) & 0x7F) << shift
  9880  				if b < 0x80 {
  9881  					break
  9882  				}
  9883  			}
  9884  			if msglen < 0 {
  9885  				return ErrInvalidLengthErrors
  9886  			}
  9887  			postIndex := iNdEx + msglen
  9888  			if postIndex > l {
  9889  				return io.ErrUnexpectedEOF
  9890  			}
  9891  			v := &StoreNotFoundError{}
  9892  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9893  				return err
  9894  			}
  9895  			m.Value = &ErrorDetail_StoreNotFound{v}
  9896  			iNdEx = postIndex
  9897  		case 28:
  9898  			if wireType != 2 {
  9899  				return fmt.Errorf("proto: wrong wireType = %d for field TransactionRetryWithProtoRefresh", wireType)
  9900  			}
  9901  			var msglen int
  9902  			for shift := uint(0); ; shift += 7 {
  9903  				if shift >= 64 {
  9904  					return ErrIntOverflowErrors
  9905  				}
  9906  				if iNdEx >= l {
  9907  					return io.ErrUnexpectedEOF
  9908  				}
  9909  				b := dAtA[iNdEx]
  9910  				iNdEx++
  9911  				msglen |= (int(b) & 0x7F) << shift
  9912  				if b < 0x80 {
  9913  					break
  9914  				}
  9915  			}
  9916  			if msglen < 0 {
  9917  				return ErrInvalidLengthErrors
  9918  			}
  9919  			postIndex := iNdEx + msglen
  9920  			if postIndex > l {
  9921  				return io.ErrUnexpectedEOF
  9922  			}
  9923  			v := &TransactionRetryWithProtoRefreshError{}
  9924  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9925  				return err
  9926  			}
  9927  			m.Value = &ErrorDetail_TransactionRetryWithProtoRefresh{v}
  9928  			iNdEx = postIndex
  9929  		case 31:
  9930  			if wireType != 2 {
  9931  				return fmt.Errorf("proto: wrong wireType = %d for field IntegerOverflow", wireType)
  9932  			}
  9933  			var msglen int
  9934  			for shift := uint(0); ; shift += 7 {
  9935  				if shift >= 64 {
  9936  					return ErrIntOverflowErrors
  9937  				}
  9938  				if iNdEx >= l {
  9939  					return io.ErrUnexpectedEOF
  9940  				}
  9941  				b := dAtA[iNdEx]
  9942  				iNdEx++
  9943  				msglen |= (int(b) & 0x7F) << shift
  9944  				if b < 0x80 {
  9945  					break
  9946  				}
  9947  			}
  9948  			if msglen < 0 {
  9949  				return ErrInvalidLengthErrors
  9950  			}
  9951  			postIndex := iNdEx + msglen
  9952  			if postIndex > l {
  9953  				return io.ErrUnexpectedEOF
  9954  			}
  9955  			v := &IntegerOverflowError{}
  9956  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9957  				return err
  9958  			}
  9959  			m.Value = &ErrorDetail_IntegerOverflow{v}
  9960  			iNdEx = postIndex
  9961  		case 32:
  9962  			if wireType != 2 {
  9963  				return fmt.Errorf("proto: wrong wireType = %d for field UnsupportedRequest", wireType)
  9964  			}
  9965  			var msglen int
  9966  			for shift := uint(0); ; shift += 7 {
  9967  				if shift >= 64 {
  9968  					return ErrIntOverflowErrors
  9969  				}
  9970  				if iNdEx >= l {
  9971  					return io.ErrUnexpectedEOF
  9972  				}
  9973  				b := dAtA[iNdEx]
  9974  				iNdEx++
  9975  				msglen |= (int(b) & 0x7F) << shift
  9976  				if b < 0x80 {
  9977  					break
  9978  				}
  9979  			}
  9980  			if msglen < 0 {
  9981  				return ErrInvalidLengthErrors
  9982  			}
  9983  			postIndex := iNdEx + msglen
  9984  			if postIndex > l {
  9985  				return io.ErrUnexpectedEOF
  9986  			}
  9987  			v := &UnsupportedRequestError{}
  9988  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  9989  				return err
  9990  			}
  9991  			m.Value = &ErrorDetail_UnsupportedRequest{v}
  9992  			iNdEx = postIndex
  9993  		case 34:
  9994  			if wireType != 2 {
  9995  				return fmt.Errorf("proto: wrong wireType = %d for field TimestampBefore", wireType)
  9996  			}
  9997  			var msglen int
  9998  			for shift := uint(0); ; shift += 7 {
  9999  				if shift >= 64 {
 10000  					return ErrIntOverflowErrors
 10001  				}
 10002  				if iNdEx >= l {
 10003  					return io.ErrUnexpectedEOF
 10004  				}
 10005  				b := dAtA[iNdEx]
 10006  				iNdEx++
 10007  				msglen |= (int(b) & 0x7F) << shift
 10008  				if b < 0x80 {
 10009  					break
 10010  				}
 10011  			}
 10012  			if msglen < 0 {
 10013  				return ErrInvalidLengthErrors
 10014  			}
 10015  			postIndex := iNdEx + msglen
 10016  			if postIndex > l {
 10017  				return io.ErrUnexpectedEOF
 10018  			}
 10019  			v := &BatchTimestampBeforeGCError{}
 10020  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10021  				return err
 10022  			}
 10023  			m.Value = &ErrorDetail_TimestampBefore{v}
 10024  			iNdEx = postIndex
 10025  		case 35:
 10026  			if wireType != 2 {
 10027  				return fmt.Errorf("proto: wrong wireType = %d for field TxnAlreadyEncounteredError", wireType)
 10028  			}
 10029  			var msglen int
 10030  			for shift := uint(0); ; shift += 7 {
 10031  				if shift >= 64 {
 10032  					return ErrIntOverflowErrors
 10033  				}
 10034  				if iNdEx >= l {
 10035  					return io.ErrUnexpectedEOF
 10036  				}
 10037  				b := dAtA[iNdEx]
 10038  				iNdEx++
 10039  				msglen |= (int(b) & 0x7F) << shift
 10040  				if b < 0x80 {
 10041  					break
 10042  				}
 10043  			}
 10044  			if msglen < 0 {
 10045  				return ErrInvalidLengthErrors
 10046  			}
 10047  			postIndex := iNdEx + msglen
 10048  			if postIndex > l {
 10049  				return io.ErrUnexpectedEOF
 10050  			}
 10051  			v := &TxnAlreadyEncounteredErrorError{}
 10052  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10053  				return err
 10054  			}
 10055  			m.Value = &ErrorDetail_TxnAlreadyEncounteredError{v}
 10056  			iNdEx = postIndex
 10057  		case 36:
 10058  			if wireType != 2 {
 10059  				return fmt.Errorf("proto: wrong wireType = %d for field IntentMissing", wireType)
 10060  			}
 10061  			var msglen int
 10062  			for shift := uint(0); ; shift += 7 {
 10063  				if shift >= 64 {
 10064  					return ErrIntOverflowErrors
 10065  				}
 10066  				if iNdEx >= l {
 10067  					return io.ErrUnexpectedEOF
 10068  				}
 10069  				b := dAtA[iNdEx]
 10070  				iNdEx++
 10071  				msglen |= (int(b) & 0x7F) << shift
 10072  				if b < 0x80 {
 10073  					break
 10074  				}
 10075  			}
 10076  			if msglen < 0 {
 10077  				return ErrInvalidLengthErrors
 10078  			}
 10079  			postIndex := iNdEx + msglen
 10080  			if postIndex > l {
 10081  				return io.ErrUnexpectedEOF
 10082  			}
 10083  			v := &IntentMissingError{}
 10084  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10085  				return err
 10086  			}
 10087  			m.Value = &ErrorDetail_IntentMissing{v}
 10088  			iNdEx = postIndex
 10089  		case 37:
 10090  			if wireType != 2 {
 10091  				return fmt.Errorf("proto: wrong wireType = %d for field MergeInProgress", wireType)
 10092  			}
 10093  			var msglen int
 10094  			for shift := uint(0); ; shift += 7 {
 10095  				if shift >= 64 {
 10096  					return ErrIntOverflowErrors
 10097  				}
 10098  				if iNdEx >= l {
 10099  					return io.ErrUnexpectedEOF
 10100  				}
 10101  				b := dAtA[iNdEx]
 10102  				iNdEx++
 10103  				msglen |= (int(b) & 0x7F) << shift
 10104  				if b < 0x80 {
 10105  					break
 10106  				}
 10107  			}
 10108  			if msglen < 0 {
 10109  				return ErrInvalidLengthErrors
 10110  			}
 10111  			postIndex := iNdEx + msglen
 10112  			if postIndex > l {
 10113  				return io.ErrUnexpectedEOF
 10114  			}
 10115  			v := &MergeInProgressError{}
 10116  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10117  				return err
 10118  			}
 10119  			m.Value = &ErrorDetail_MergeInProgress{v}
 10120  			iNdEx = postIndex
 10121  		case 38:
 10122  			if wireType != 2 {
 10123  				return fmt.Errorf("proto: wrong wireType = %d for field RangefeedRetry", wireType)
 10124  			}
 10125  			var msglen int
 10126  			for shift := uint(0); ; shift += 7 {
 10127  				if shift >= 64 {
 10128  					return ErrIntOverflowErrors
 10129  				}
 10130  				if iNdEx >= l {
 10131  					return io.ErrUnexpectedEOF
 10132  				}
 10133  				b := dAtA[iNdEx]
 10134  				iNdEx++
 10135  				msglen |= (int(b) & 0x7F) << shift
 10136  				if b < 0x80 {
 10137  					break
 10138  				}
 10139  			}
 10140  			if msglen < 0 {
 10141  				return ErrInvalidLengthErrors
 10142  			}
 10143  			postIndex := iNdEx + msglen
 10144  			if postIndex > l {
 10145  				return io.ErrUnexpectedEOF
 10146  			}
 10147  			v := &RangeFeedRetryError{}
 10148  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10149  				return err
 10150  			}
 10151  			m.Value = &ErrorDetail_RangefeedRetry{v}
 10152  			iNdEx = postIndex
 10153  		case 39:
 10154  			if wireType != 2 {
 10155  				return fmt.Errorf("proto: wrong wireType = %d for field IndeterminateCommit", wireType)
 10156  			}
 10157  			var msglen int
 10158  			for shift := uint(0); ; shift += 7 {
 10159  				if shift >= 64 {
 10160  					return ErrIntOverflowErrors
 10161  				}
 10162  				if iNdEx >= l {
 10163  					return io.ErrUnexpectedEOF
 10164  				}
 10165  				b := dAtA[iNdEx]
 10166  				iNdEx++
 10167  				msglen |= (int(b) & 0x7F) << shift
 10168  				if b < 0x80 {
 10169  					break
 10170  				}
 10171  			}
 10172  			if msglen < 0 {
 10173  				return ErrInvalidLengthErrors
 10174  			}
 10175  			postIndex := iNdEx + msglen
 10176  			if postIndex > l {
 10177  				return io.ErrUnexpectedEOF
 10178  			}
 10179  			v := &IndeterminateCommitError{}
 10180  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10181  				return err
 10182  			}
 10183  			m.Value = &ErrorDetail_IndeterminateCommit{v}
 10184  			iNdEx = postIndex
 10185  		default:
 10186  			iNdEx = preIndex
 10187  			skippy, err := skipErrors(dAtA[iNdEx:])
 10188  			if err != nil {
 10189  				return err
 10190  			}
 10191  			if skippy < 0 {
 10192  				return ErrInvalidLengthErrors
 10193  			}
 10194  			if (iNdEx + skippy) > l {
 10195  				return io.ErrUnexpectedEOF
 10196  			}
 10197  			iNdEx += skippy
 10198  		}
 10199  	}
 10200  
 10201  	if iNdEx > l {
 10202  		return io.ErrUnexpectedEOF
 10203  	}
 10204  	return nil
 10205  }
 10206  func (m *ErrPosition) Unmarshal(dAtA []byte) error {
 10207  	l := len(dAtA)
 10208  	iNdEx := 0
 10209  	for iNdEx < l {
 10210  		preIndex := iNdEx
 10211  		var wire uint64
 10212  		for shift := uint(0); ; shift += 7 {
 10213  			if shift >= 64 {
 10214  				return ErrIntOverflowErrors
 10215  			}
 10216  			if iNdEx >= l {
 10217  				return io.ErrUnexpectedEOF
 10218  			}
 10219  			b := dAtA[iNdEx]
 10220  			iNdEx++
 10221  			wire |= (uint64(b) & 0x7F) << shift
 10222  			if b < 0x80 {
 10223  				break
 10224  			}
 10225  		}
 10226  		fieldNum := int32(wire >> 3)
 10227  		wireType := int(wire & 0x7)
 10228  		if wireType == 4 {
 10229  			return fmt.Errorf("proto: ErrPosition: wiretype end group for non-group")
 10230  		}
 10231  		if fieldNum <= 0 {
 10232  			return fmt.Errorf("proto: ErrPosition: illegal tag %d (wire type %d)", fieldNum, wire)
 10233  		}
 10234  		switch fieldNum {
 10235  		case 1:
 10236  			if wireType != 0 {
 10237  				return fmt.Errorf("proto: wrong wireType = %d for field Index", wireType)
 10238  			}
 10239  			m.Index = 0
 10240  			for shift := uint(0); ; shift += 7 {
 10241  				if shift >= 64 {
 10242  					return ErrIntOverflowErrors
 10243  				}
 10244  				if iNdEx >= l {
 10245  					return io.ErrUnexpectedEOF
 10246  				}
 10247  				b := dAtA[iNdEx]
 10248  				iNdEx++
 10249  				m.Index |= (int32(b) & 0x7F) << shift
 10250  				if b < 0x80 {
 10251  					break
 10252  				}
 10253  			}
 10254  		default:
 10255  			iNdEx = preIndex
 10256  			skippy, err := skipErrors(dAtA[iNdEx:])
 10257  			if err != nil {
 10258  				return err
 10259  			}
 10260  			if skippy < 0 {
 10261  				return ErrInvalidLengthErrors
 10262  			}
 10263  			if (iNdEx + skippy) > l {
 10264  				return io.ErrUnexpectedEOF
 10265  			}
 10266  			iNdEx += skippy
 10267  		}
 10268  	}
 10269  
 10270  	if iNdEx > l {
 10271  		return io.ErrUnexpectedEOF
 10272  	}
 10273  	return nil
 10274  }
 10275  func (m *Error) Unmarshal(dAtA []byte) error {
 10276  	l := len(dAtA)
 10277  	iNdEx := 0
 10278  	for iNdEx < l {
 10279  		preIndex := iNdEx
 10280  		var wire uint64
 10281  		for shift := uint(0); ; shift += 7 {
 10282  			if shift >= 64 {
 10283  				return ErrIntOverflowErrors
 10284  			}
 10285  			if iNdEx >= l {
 10286  				return io.ErrUnexpectedEOF
 10287  			}
 10288  			b := dAtA[iNdEx]
 10289  			iNdEx++
 10290  			wire |= (uint64(b) & 0x7F) << shift
 10291  			if b < 0x80 {
 10292  				break
 10293  			}
 10294  		}
 10295  		fieldNum := int32(wire >> 3)
 10296  		wireType := int(wire & 0x7)
 10297  		if wireType == 4 {
 10298  			return fmt.Errorf("proto: Error: wiretype end group for non-group")
 10299  		}
 10300  		if fieldNum <= 0 {
 10301  			return fmt.Errorf("proto: Error: illegal tag %d (wire type %d)", fieldNum, wire)
 10302  		}
 10303  		switch fieldNum {
 10304  		case 1:
 10305  			if wireType != 2 {
 10306  				return fmt.Errorf("proto: wrong wireType = %d for field Message", wireType)
 10307  			}
 10308  			var stringLen uint64
 10309  			for shift := uint(0); ; shift += 7 {
 10310  				if shift >= 64 {
 10311  					return ErrIntOverflowErrors
 10312  				}
 10313  				if iNdEx >= l {
 10314  					return io.ErrUnexpectedEOF
 10315  				}
 10316  				b := dAtA[iNdEx]
 10317  				iNdEx++
 10318  				stringLen |= (uint64(b) & 0x7F) << shift
 10319  				if b < 0x80 {
 10320  					break
 10321  				}
 10322  			}
 10323  			intStringLen := int(stringLen)
 10324  			if intStringLen < 0 {
 10325  				return ErrInvalidLengthErrors
 10326  			}
 10327  			postIndex := iNdEx + intStringLen
 10328  			if postIndex > l {
 10329  				return io.ErrUnexpectedEOF
 10330  			}
 10331  			m.Message = string(dAtA[iNdEx:postIndex])
 10332  			iNdEx = postIndex
 10333  		case 3:
 10334  			if wireType != 0 {
 10335  				return fmt.Errorf("proto: wrong wireType = %d for field TransactionRestart", wireType)
 10336  			}
 10337  			m.TransactionRestart = 0
 10338  			for shift := uint(0); ; shift += 7 {
 10339  				if shift >= 64 {
 10340  					return ErrIntOverflowErrors
 10341  				}
 10342  				if iNdEx >= l {
 10343  					return io.ErrUnexpectedEOF
 10344  				}
 10345  				b := dAtA[iNdEx]
 10346  				iNdEx++
 10347  				m.TransactionRestart |= (TransactionRestart(b) & 0x7F) << shift
 10348  				if b < 0x80 {
 10349  					break
 10350  				}
 10351  			}
 10352  		case 4:
 10353  			if wireType != 2 {
 10354  				return fmt.Errorf("proto: wrong wireType = %d for field UnexposedTxn", wireType)
 10355  			}
 10356  			var msglen int
 10357  			for shift := uint(0); ; shift += 7 {
 10358  				if shift >= 64 {
 10359  					return ErrIntOverflowErrors
 10360  				}
 10361  				if iNdEx >= l {
 10362  					return io.ErrUnexpectedEOF
 10363  				}
 10364  				b := dAtA[iNdEx]
 10365  				iNdEx++
 10366  				msglen |= (int(b) & 0x7F) << shift
 10367  				if b < 0x80 {
 10368  					break
 10369  				}
 10370  			}
 10371  			if msglen < 0 {
 10372  				return ErrInvalidLengthErrors
 10373  			}
 10374  			postIndex := iNdEx + msglen
 10375  			if postIndex > l {
 10376  				return io.ErrUnexpectedEOF
 10377  			}
 10378  			if m.UnexposedTxn == nil {
 10379  				m.UnexposedTxn = &Transaction{}
 10380  			}
 10381  			if err := m.UnexposedTxn.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10382  				return err
 10383  			}
 10384  			iNdEx = postIndex
 10385  		case 5:
 10386  			if wireType != 0 {
 10387  				return fmt.Errorf("proto: wrong wireType = %d for field OriginNode", wireType)
 10388  			}
 10389  			m.OriginNode = 0
 10390  			for shift := uint(0); ; shift += 7 {
 10391  				if shift >= 64 {
 10392  					return ErrIntOverflowErrors
 10393  				}
 10394  				if iNdEx >= l {
 10395  					return io.ErrUnexpectedEOF
 10396  				}
 10397  				b := dAtA[iNdEx]
 10398  				iNdEx++
 10399  				m.OriginNode |= (NodeID(b) & 0x7F) << shift
 10400  				if b < 0x80 {
 10401  					break
 10402  				}
 10403  			}
 10404  		case 6:
 10405  			if wireType != 2 {
 10406  				return fmt.Errorf("proto: wrong wireType = %d for field Detail", wireType)
 10407  			}
 10408  			var msglen int
 10409  			for shift := uint(0); ; shift += 7 {
 10410  				if shift >= 64 {
 10411  					return ErrIntOverflowErrors
 10412  				}
 10413  				if iNdEx >= l {
 10414  					return io.ErrUnexpectedEOF
 10415  				}
 10416  				b := dAtA[iNdEx]
 10417  				iNdEx++
 10418  				msglen |= (int(b) & 0x7F) << shift
 10419  				if b < 0x80 {
 10420  					break
 10421  				}
 10422  			}
 10423  			if msglen < 0 {
 10424  				return ErrInvalidLengthErrors
 10425  			}
 10426  			postIndex := iNdEx + msglen
 10427  			if postIndex > l {
 10428  				return io.ErrUnexpectedEOF
 10429  			}
 10430  			if err := m.Detail.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10431  				return err
 10432  			}
 10433  			iNdEx = postIndex
 10434  		case 7:
 10435  			if wireType != 2 {
 10436  				return fmt.Errorf("proto: wrong wireType = %d for field Index", wireType)
 10437  			}
 10438  			var msglen int
 10439  			for shift := uint(0); ; shift += 7 {
 10440  				if shift >= 64 {
 10441  					return ErrIntOverflowErrors
 10442  				}
 10443  				if iNdEx >= l {
 10444  					return io.ErrUnexpectedEOF
 10445  				}
 10446  				b := dAtA[iNdEx]
 10447  				iNdEx++
 10448  				msglen |= (int(b) & 0x7F) << shift
 10449  				if b < 0x80 {
 10450  					break
 10451  				}
 10452  			}
 10453  			if msglen < 0 {
 10454  				return ErrInvalidLengthErrors
 10455  			}
 10456  			postIndex := iNdEx + msglen
 10457  			if postIndex > l {
 10458  				return io.ErrUnexpectedEOF
 10459  			}
 10460  			if m.Index == nil {
 10461  				m.Index = &ErrPosition{}
 10462  			}
 10463  			if err := m.Index.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10464  				return err
 10465  			}
 10466  			iNdEx = postIndex
 10467  		case 8:
 10468  			if wireType != 2 {
 10469  				return fmt.Errorf("proto: wrong wireType = %d for field Now", wireType)
 10470  			}
 10471  			var msglen int
 10472  			for shift := uint(0); ; shift += 7 {
 10473  				if shift >= 64 {
 10474  					return ErrIntOverflowErrors
 10475  				}
 10476  				if iNdEx >= l {
 10477  					return io.ErrUnexpectedEOF
 10478  				}
 10479  				b := dAtA[iNdEx]
 10480  				iNdEx++
 10481  				msglen |= (int(b) & 0x7F) << shift
 10482  				if b < 0x80 {
 10483  					break
 10484  				}
 10485  			}
 10486  			if msglen < 0 {
 10487  				return ErrInvalidLengthErrors
 10488  			}
 10489  			postIndex := iNdEx + msglen
 10490  			if postIndex > l {
 10491  				return io.ErrUnexpectedEOF
 10492  			}
 10493  			if err := m.Now.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
 10494  				return err
 10495  			}
 10496  			iNdEx = postIndex
 10497  		default:
 10498  			iNdEx = preIndex
 10499  			skippy, err := skipErrors(dAtA[iNdEx:])
 10500  			if err != nil {
 10501  				return err
 10502  			}
 10503  			if skippy < 0 {
 10504  				return ErrInvalidLengthErrors
 10505  			}
 10506  			if (iNdEx + skippy) > l {
 10507  				return io.ErrUnexpectedEOF
 10508  			}
 10509  			iNdEx += skippy
 10510  		}
 10511  	}
 10512  
 10513  	if iNdEx > l {
 10514  		return io.ErrUnexpectedEOF
 10515  	}
 10516  	return nil
 10517  }
 10518  func skipErrors(dAtA []byte) (n int, err error) {
 10519  	l := len(dAtA)
 10520  	iNdEx := 0
 10521  	for iNdEx < l {
 10522  		var wire uint64
 10523  		for shift := uint(0); ; shift += 7 {
 10524  			if shift >= 64 {
 10525  				return 0, ErrIntOverflowErrors
 10526  			}
 10527  			if iNdEx >= l {
 10528  				return 0, io.ErrUnexpectedEOF
 10529  			}
 10530  			b := dAtA[iNdEx]
 10531  			iNdEx++
 10532  			wire |= (uint64(b) & 0x7F) << shift
 10533  			if b < 0x80 {
 10534  				break
 10535  			}
 10536  		}
 10537  		wireType := int(wire & 0x7)
 10538  		switch wireType {
 10539  		case 0:
 10540  			for shift := uint(0); ; shift += 7 {
 10541  				if shift >= 64 {
 10542  					return 0, ErrIntOverflowErrors
 10543  				}
 10544  				if iNdEx >= l {
 10545  					return 0, io.ErrUnexpectedEOF
 10546  				}
 10547  				iNdEx++
 10548  				if dAtA[iNdEx-1] < 0x80 {
 10549  					break
 10550  				}
 10551  			}
 10552  			return iNdEx, nil
 10553  		case 1:
 10554  			iNdEx += 8
 10555  			return iNdEx, nil
 10556  		case 2:
 10557  			var length int
 10558  			for shift := uint(0); ; shift += 7 {
 10559  				if shift >= 64 {
 10560  					return 0, ErrIntOverflowErrors
 10561  				}
 10562  				if iNdEx >= l {
 10563  					return 0, io.ErrUnexpectedEOF
 10564  				}
 10565  				b := dAtA[iNdEx]
 10566  				iNdEx++
 10567  				length |= (int(b) & 0x7F) << shift
 10568  				if b < 0x80 {
 10569  					break
 10570  				}
 10571  			}
 10572  			iNdEx += length
 10573  			if length < 0 {
 10574  				return 0, ErrInvalidLengthErrors
 10575  			}
 10576  			return iNdEx, nil
 10577  		case 3:
 10578  			for {
 10579  				var innerWire uint64
 10580  				var start int = iNdEx
 10581  				for shift := uint(0); ; shift += 7 {
 10582  					if shift >= 64 {
 10583  						return 0, ErrIntOverflowErrors
 10584  					}
 10585  					if iNdEx >= l {
 10586  						return 0, io.ErrUnexpectedEOF
 10587  					}
 10588  					b := dAtA[iNdEx]
 10589  					iNdEx++
 10590  					innerWire |= (uint64(b) & 0x7F) << shift
 10591  					if b < 0x80 {
 10592  						break
 10593  					}
 10594  				}
 10595  				innerWireType := int(innerWire & 0x7)
 10596  				if innerWireType == 4 {
 10597  					break
 10598  				}
 10599  				next, err := skipErrors(dAtA[start:])
 10600  				if err != nil {
 10601  					return 0, err
 10602  				}
 10603  				iNdEx = start + next
 10604  			}
 10605  			return iNdEx, nil
 10606  		case 4:
 10607  			return iNdEx, nil
 10608  		case 5:
 10609  			iNdEx += 4
 10610  			return iNdEx, nil
 10611  		default:
 10612  			return 0, fmt.Errorf("proto: illegal wireType %d", wireType)
 10613  		}
 10614  	}
 10615  	panic("unreachable")
 10616  }
 10617  
 10618  var (
 10619  	ErrInvalidLengthErrors = fmt.Errorf("proto: negative length found during unmarshaling")
 10620  	ErrIntOverflowErrors   = fmt.Errorf("proto: integer overflow")
 10621  )
 10622  
 10623  func init() { proto.RegisterFile("roachpb/errors.proto", fileDescriptor_errors_4401e49350ed5ee8) }
 10624  
 10625  var fileDescriptor_errors_4401e49350ed5ee8 = []byte{
 10626  	// 2870 bytes of a gzipped FileDescriptorProto
 10627  	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x9c, 0x59, 0xcd, 0x73, 0xdb, 0xc6,
 10628  	0x15, 0x27, 0x28, 0x4a, 0xa2, 0x9e, 0xbe, 0xe0, 0xb5, 0x22, 0xc3, 0x72, 0x4c, 0x29, 0x74, 0x9c,
 10629  	0xd8, 0xce, 0x44, 0xea, 0x38, 0xf5, 0xb4, 0x71, 0x9d, 0x03, 0x3f, 0x20, 0x11, 0x12, 0x3f, 0x14,
 10630  	0x90, 0x8a, 0xec, 0xa4, 0x9d, 0x2d, 0x44, 0xae, 0x28, 0xc4, 0x24, 0xc0, 0x2e, 0x40, 0x4b, 0xba,
 10631  	0xf5, 0x98, 0xf6, 0xd4, 0xce, 0xf4, 0xd0, 0x63, 0x66, 0x3a, 0x3d, 0x64, 0xda, 0x63, 0x27, 0x7f,
 10632  	0x41, 0x0f, 0x39, 0xe6, 0x98, 0xe9, 0x74, 0x34, 0xad, 0x73, 0xe9, 0xb4, 0xff, 0x41, 0x4e, 0x9d,
 10633  	0xfd, 0x00, 0x09, 0x88, 0xa0, 0xc2, 0xf8, 0x46, 0xbc, 0x8f, 0xdf, 0xbe, 0x7d, 0xbb, 0xfb, 0xf6,
 10634  	0xf7, 0x96, 0xb0, 0x42, 0x5d, 0xab, 0x79, 0xd2, 0x3b, 0xda, 0x22, 0x94, 0xba, 0xd4, 0xdb, 0xec,
 10635  	0x51, 0xd7, 0x77, 0xd1, 0xb5, 0xa6, 0xdb, 0x7c, 0xce, 0x35, 0x9b, 0x52, 0xbf, 0x86, 0x02, 0xc3,
 10636  	0x96, 0xe5, 0x5b, 0xc2, 0x6c, 0x6d, 0x35, 0x90, 0x75, 0x89, 0x6f, 0x85, 0xe4, 0x5a, 0xdf, 0xb7,
 10637  	0x3b, 0x5b, 0x27, 0x9d, 0xe6, 0x96, 0x6f, 0x77, 0x89, 0xe7, 0x5b, 0xdd, 0x9e, 0xd4, 0xac, 0xb4,
 10638  	0xdd, 0xb6, 0xcb, 0x7f, 0x6e, 0xb1, 0x5f, 0x42, 0x9a, 0xfd, 0x32, 0x09, 0xd7, 0xab, 0xae, 0x5f,
 10639  	0x26, 0x96, 0x47, 0x4a, 0x6e, 0xa7, 0x45, 0xa8, 0xce, 0xa2, 0x41, 0x45, 0x98, 0xa5, 0xa4, 0xd7,
 10640  	0xb1, 0x9b, 0x96, 0xa6, 0x6c, 0x28, 0xf7, 0xe6, 0x1f, 0xbe, 0xb9, 0x39, 0x12, 0xd8, 0xa6, 0x29,
 10641  	0x2c, 0x8a, 0xc4, 0x6b, 0x52, 0xbb, 0xe7, 0xbb, 0x34, 0x9f, 0xfa, 0xea, 0x62, 0x3d, 0x61, 0x06,
 10642  	0xae, 0x68, 0x07, 0x16, 0x3a, 0x0c, 0x19, 0x9f, 0x70, 0x68, 0x2d, 0x39, 0x39, 0x94, 0x39, 0xdf,
 10643  	0x19, 0xc6, 0x84, 0x1e, 0x41, 0x9a, 0x5a, 0x4e, 0x9b, 0x60, 0xbb, 0xa5, 0x4d, 0x6d, 0x28, 0xf7,
 10644  	0xa6, 0xf2, 0x6b, 0x6c, 0xa4, 0x97, 0x17, 0xeb, 0xb3, 0x26, 0x93, 0x1b, 0xc5, 0xef, 0x86, 0x3f,
 10645  	0xcd, 0x59, 0x6e, 0x6b, 0xb4, 0xd0, 0x26, 0x4c, 0x73, 0x14, 0x2d, 0xc5, 0x07, 0xd6, 0x62, 0x06,
 10646  	0xe6, 0x33, 0x37, 0x85, 0x19, 0xba, 0x03, 0xd0, 0xec, 0x7b, 0xbe, 0xdb, 0xc5, 0x5d, 0xaf, 0xad,
 10647  	0x4d, 0x6f, 0x28, 0xf7, 0xe6, 0xe4, 0x94, 0xe6, 0x84, 0xbc, 0xe2, 0xb5, 0x1f, 0xa7, 0xfe, 0xf3,
 10648  	0xf9, 0xba, 0x92, 0x7d, 0x1d, 0x56, 0xaa, 0x6e, 0x8b, 0x1c, 0x38, 0xd6, 0x0b, 0xcb, 0xee, 0x58,
 10649  	0x47, 0x1d, 0xc2, 0x13, 0x27, 0xb5, 0xeb, 0x70, 0xe3, 0xc0, 0xf1, 0xfa, 0xbd, 0x9e, 0x4b, 0x7d,
 10650  	0xd2, 0x32, 0xc9, 0xaf, 0xfa, 0xc4, 0xf3, 0xc3, 0x06, 0x9f, 0x29, 0x80, 0x78, 0xb8, 0x55, 0xd7,
 10651  	0xdf, 0x76, 0xfb, 0x4e, 0x4b, 0xa4, 0x3d, 0x3c, 0x4f, 0x65, 0xf2, 0x79, 0x3e, 0x82, 0xb4, 0xe7,
 10652  	0xbb, 0x94, 0xbb, 0x25, 0xa3, 0x6e, 0x75, 0x26, 0x17, 0x6e, 0xf2, 0xa7, 0x39, 0xcb, 0x6d, 0x8d,
 10653  	0x96, 0x0c, 0xe5, 0xcf, 0x49, 0x78, 0x8d, 0x23, 0xee, 0x91, 0xf3, 0x8a, 0xed, 0x75, 0x2d, 0xbf,
 10654  	0x79, 0x22, 0xa2, 0x79, 0x0f, 0xae, 0x51, 0x11, 0x3a, 0xf6, 0x7c, 0x8b, 0xfa, 0xf8, 0x39, 0x39,
 10655  	0xe7, 0x61, 0x2d, 0xe4, 0x67, 0xbf, 0xbb, 0x58, 0x9f, 0xda, 0x23, 0xe7, 0xe6, 0xb2, 0xb4, 0xa8,
 10656  	0x33, 0x83, 0x3d, 0x72, 0x8e, 0xb6, 0x20, 0x10, 0x61, 0xe2, 0xb4, 0xb8, 0x4b, 0x32, 0xea, 0xb2,
 10657  	0x28, 0xf5, 0xba, 0xd3, 0x62, 0x0e, 0x75, 0x50, 0xbb, 0x72, 0x58, 0xd2, 0xc2, 0x7c, 0x4a, 0x7c,
 10658  	0x8d, 0xe7, 0x1f, 0x66, 0xe3, 0x36, 0x0a, 0xd3, 0x8f, 0xec, 0xb8, 0xe5, 0x21, 0x02, 0x37, 0x40,
 10659  	0x7b, 0xb0, 0xec, 0xf5, 0xdb, 0x6d, 0xe2, 0xf9, 0x03, 0xcc, 0xd4, 0xa4, 0x98, 0xe6, 0xd2, 0xc0,
 10660  	0x95, 0x6b, 0x64, 0x9e, 0xfe, 0x97, 0x84, 0xac, 0x49, 0xac, 0xd6, 0xa1, 0xed, 0x9f, 0xd8, 0xce,
 10661  	0x81, 0xd3, 0x24, 0xd4, 0xb7, 0x6c, 0xc7, 0x3f, 0x37, 0x1c, 0x9f, 0xd0, 0x17, 0x56, 0x47, 0x24,
 10662  	0x6d, 0x17, 0x96, 0x28, 0xb1, 0x5a, 0x78, 0x70, 0xfe, 0xe4, 0x01, 0xba, 0x1d, 0x1a, 0x98, 0x1d,
 10663  	0xd2, 0xcd, 0x93, 0x4e, 0x73, 0xb3, 0x11, 0x18, 0xc9, 0x79, 0x2c, 0x32, 0xd7, 0x81, 0x10, 0x99,
 10664  	0x80, 0xc8, 0x99, 0xed, 0xf9, 0xb6, 0xd3, 0x0e, 0xe1, 0x25, 0x27, 0xc7, 0xbb, 0x16, 0xb8, 0x0f,
 10665  	0x31, 0xf3, 0xb0, 0xd8, 0xb5, 0xce, 0x42, 0x70, 0x53, 0x13, 0xc0, 0x99, 0x0b, 0x5d, 0xeb, 0x6c,
 10666  	0x88, 0xf1, 0x09, 0x5c, 0x77, 0x8f, 0x3c, 0x42, 0x5f, 0x90, 0xd0, 0x3c, 0x3d, 0x2d, 0xb5, 0x31,
 10667  	0x35, 0xe6, 0x78, 0xd7, 0xa4, 0xf5, 0xe5, 0xf8, 0x90, 0x7b, 0x59, 0xe1, 0xc9, 0x6c, 0x7f, 0x0a,
 10668  	0x37, 0x1a, 0xd4, 0x72, 0x3c, 0xab, 0xe9, 0xdb, 0xae, 0x93, 0x3b, 0xe2, 0x07, 0x49, 0x64, 0xd8,
 10669  	0x80, 0x19, 0x4a, 0x2c, 0xcf, 0x75, 0x78, 0x66, 0x97, 0x1e, 0xbe, 0x13, 0x33, 0xe0, 0xa8, 0xaf,
 10670  	0xc9, 0x5d, 0xe4, 0xb8, 0x12, 0x40, 0x8e, 0x65, 0xc1, 0x4a, 0xc8, 0x7e, 0xbf, 0xef, 0xc9, 0xfd,
 10671  	0x5f, 0x00, 0xe8, 0xf5, 0xbd, 0x13, 0x42, 0xb0, 0x7f, 0xe6, 0xc8, 0x65, 0xcc, 0x5c, 0x3d, 0x58,
 10672  	0x50, 0x2e, 0x84, 0x5f, 0xe3, 0x2c, 0x18, 0xe2, 0x37, 0x0a, 0xbc, 0x16, 0x32, 0x33, 0x89, 0x4f,
 10673  	0xcf, 0xc5, 0x20, 0x3b, 0x97, 0x66, 0x73, 0xff, 0xea, 0x01, 0xb8, 0x67, 0xdc, 0x5c, 0xd0, 0x1b,
 10674  	0x30, 0x47, 0xce, 0x7c, 0x6a, 0xf1, 0xda, 0x95, 0x0c, 0xd5, 0xae, 0x34, 0x17, 0x0f, 0x4b, 0xd7,
 10675  	0xdf, 0x15, 0x58, 0x0d, 0x21, 0xd6, 0x7d, 0xcb, 0xef, 0x7b, 0x22, 0x98, 0x55, 0x98, 0x62, 0xde,
 10676  	0x4a, 0xc8, 0x9b, 0x09, 0x50, 0x75, 0x10, 0x64, 0x92, 0x07, 0xf9, 0xa3, 0xab, 0x83, 0x0c, 0x41,
 10677  	0x6e, 0xc6, 0xc5, 0x9a, 0x7d, 0x02, 0x33, 0x42, 0x8e, 0x10, 0x2c, 0x99, 0x7a, 0xae, 0x5e, 0xab,
 10678  	0xe2, 0x83, 0xea, 0x5e, 0xb5, 0x76, 0x58, 0x55, 0x13, 0x48, 0x83, 0x15, 0x29, 0x6b, 0x3c, 0xad,
 10679  	0xe2, 0x42, 0xad, 0x52, 0x31, 0x1a, 0x0d, 0xbd, 0xa8, 0x26, 0xb3, 0xa9, 0xb4, 0xa2, 0x2a, 0x72,
 10680  	0x1a, 0xcf, 0x40, 0x3d, 0xa4, 0xb6, 0x4f, 0xd8, 0xf1, 0x73, 0x44, 0x71, 0x45, 0xef, 0xc3, 0xac,
 10681  	0xcd, 0x3f, 0x3d, 0x4d, 0xe1, 0x9b, 0xf1, 0x66, 0x4c, 0xa0, 0xc2, 0x21, 0xb8, 0xab, 0xa4, 0xbd,
 10682  	0x00, 0xdd, 0x4d, 0xa5, 0x93, 0xea, 0x54, 0xf6, 0x2f, 0x8a, 0xc4, 0x6e, 0xb8, 0x6e, 0xad, 0x23,
 10683  	0xb7, 0x5d, 0x0e, 0xe6, 0x5e, 0xe9, 0x4c, 0x0f, 0xbd, 0x50, 0x15, 0x54, 0xab, 0xe9, 0xf7, 0xad,
 10684  	0xce, 0xab, 0x9d, 0xe6, 0x65, 0xe1, 0x3c, 0x10, 0xcb, 0x44, 0xac, 0x01, 0xaa, 0xf5, 0xd8, 0x1d,
 10685  	0x63, 0x53, 0xe2, 0x35, 0xce, 0x9c, 0xf0, 0x3d, 0xf3, 0x0c, 0x56, 0x0a, 0xae, 0xd3, 0xb2, 0xd9,
 10686  	0xaa, 0x6c, 0x5b, 0x76, 0x27, 0x38, 0x43, 0x3f, 0x83, 0x05, 0x19, 0xc9, 0x0b, 0xab, 0xd3, 0x27,
 10687  	0x72, 0x3e, 0x71, 0x17, 0xe4, 0x47, 0x4c, 0x6f, 0xce, 0x0b, 0x6b, 0xfe, 0x21, 0xa1, 0xff, 0xa6,
 10688  	0x00, 0x12, 0xb7, 0x27, 0xf9, 0x94, 0x34, 0x07, 0xa7, 0x33, 0x03, 0xb3, 0x5d, 0xe2, 0x79, 0x56,
 10689  	0x9b, 0x44, 0xb6, 0x51, 0x20, 0x44, 0x4f, 0x60, 0x4e, 0xd6, 0x7f, 0xd2, 0x92, 0x93, 0x1f, 0x7b,
 10690  	0x2f, 0x07, 0x19, 0x1c, 0x38, 0xa0, 0xc7, 0x90, 0x0e, 0x4a, 0x9a, 0x2c, 0x5c, 0xdf, 0xe7, 0x3c,
 10691  	0xb0, 0x97, 0x61, 0xff, 0x04, 0xe6, 0xea, 0xc4, 0x99, 0x2c, 0xd8, 0xc8, 0xa6, 0x38, 0x85, 0x95,
 10692  	0x5c, 0xf7, 0xc8, 0x6e, 0xf7, 0xdd, 0xbe, 0x67, 0x12, 0xaf, 0xdf, 0xf1, 0x27, 0x9b, 0xf0, 0xfb,
 10693  	0x30, 0x7f, 0x4a, 0xad, 0x5e, 0x8f, 0xb4, 0x30, 0xa1, 0xf4, 0x8a, 0x29, 0x73, 0x38, 0x13, 0xa4,
 10694  	0xb1, 0x4e, 0x83, 0x35, 0xbc, 0xcd, 0xee, 0xe7, 0x63, 0x7f, 0x87, 0xba, 0xfd, 0x5e, 0x91, 0x74,
 10695  	0x48, 0x90, 0x6a, 0xa9, 0x26, 0xb0, 0x2a, 0xd9, 0x53, 0xc1, 0xa5, 0xb4, 0xdf, 0x63, 0x4b, 0x2d,
 10696  	0x22, 0x63, 0x15, 0x81, 0xfd, 0xc0, 0x97, 0xcf, 0x74, 0x9a, 0x8b, 0x2b, 0x5e, 0x1b, 0x65, 0x61,
 10697  	0xae, 0x47, 0xdd, 0x26, 0xf1, 0x3c, 0xb9, 0x1a, 0xe9, 0x41, 0x05, 0x0b, 0xc4, 0x83, 0x9d, 0x84,
 10698  	0xe4, 0x30, 0xe1, 0x43, 0xf1, 0x01, 0x80, 0x24, 0x7b, 0x01, 0x65, 0x99, 0xce, 0x67, 0x24, 0xf7,
 10699  	0x98, 0x93, 0xf6, 0x9c, 0x7d, 0x0c, 0x3f, 0xd8, 0x72, 0x8a, 0x9f, 0x01, 0xf4, 0x87, 0x80, 0x38,
 10700  	0x37, 0x19, 0xe1, 0x42, 0x03, 0x52, 0xa3, 0xfc, 0x50, 0x52, 0x53, 0x61, 0x04, 0xec, 0xc4, 0x72,
 10701  	0x5a, 0x1d, 0x56, 0xf9, 0x7d, 0x7a, 0x3e, 0x60, 0x68, 0xe8, 0x21, 0xa4, 0x7a, 0x3a, 0xa5, 0x57,
 10702  	0x6c, 0x79, 0x6e, 0x27, 0xf3, 0xc0, 0x6d, 0xb3, 0xff, 0x55, 0xe0, 0xee, 0xe5, 0x22, 0xcc, 0x78,
 10703  	0xc0, 0x3e, 0x23, 0xd1, 0x26, 0x39, 0xa6, 0x24, 0xb8, 0x33, 0xc6, 0x55, 0xd0, 0x4f, 0x60, 0xc6,
 10704  	0x3f, 0x73, 0x02, 0x82, 0xb6, 0x90, 0x2f, 0x32, 0xd5, 0x3f, 0x2e, 0xd6, 0xdf, 0x6b, 0xdb, 0xfe,
 10705  	0x49, 0xff, 0x68, 0xb3, 0xe9, 0x76, 0xb7, 0x06, 0x91, 0xb4, 0x8e, 0x86, 0xbf, 0xb7, 0x7a, 0xcf,
 10706  	0xdb, 0x5b, 0x9c, 0xd5, 0xf7, 0xfb, 0x76, 0x6b, 0xf3, 0xe0, 0xc0, 0x28, 0xbe, 0xbc, 0x58, 0x9f,
 10707  	0x6e, 0x9c, 0x39, 0x46, 0xd1, 0x9c, 0xf6, 0xcf, 0x1c, 0xa3, 0x85, 0xb6, 0x61, 0xde, 0x1f, 0x46,
 10708  	0x27, 0x0f, 0xc6, 0x64, 0x37, 0x55, 0xd8, 0x51, 0xe6, 0xae, 0x0c, 0xeb, 0x8d, 0x33, 0x27, 0xd7,
 10709  	0x61, 0x5c, 0xe4, 0x5c, 0x77, 0x9a, 0x6e, 0x9f, 0x11, 0x1c, 0xb9, 0xe9, 0xc4, 0x2c, 0xef, 0x00,
 10710  	0xf4, 0x28, 0x79, 0x81, 0xf9, 0x3e, 0x8a, 0x4c, 0x76, 0x8e, 0xc9, 0xc3, 0xdb, 0xf3, 0xf7, 0x0a,
 10711  	0xac, 0xb0, 0x8a, 0xdb, 0x26, 0xb4, 0xf6, 0x82, 0xd0, 0xe3, 0x8e, 0x7b, 0x2a, 0x30, 0x6e, 0xc2,
 10712  	0x54, 0x0c, 0x9f, 0x64, 0x32, 0x74, 0x1f, 0x16, 0x9b, 0x7d, 0x4a, 0x89, 0xe3, 0xcb, 0xf2, 0x24,
 10713  	0x48, 0xad, 0x18, 0x61, 0x41, 0xaa, 0x78, 0x2d, 0x42, 0xef, 0xc2, 0xb2, 0xed, 0x34, 0x29, 0xe9,
 10714  	0x0e, 0x8d, 0xa7, 0x42, 0xc6, 0x4b, 0x03, 0x65, 0xb8, 0x74, 0x7d, 0xa1, 0xc0, 0xad, 0x3c, 0xa3,
 10715  	0x8b, 0xc3, 0x0a, 0x4b, 0x8e, 0x5d, 0x4a, 0x76, 0x0a, 0x83, 0x52, 0xdf, 0x78, 0xa5, 0x52, 0x3f,
 10716  	0xa4, 0x48, 0x0c, 0xe2, 0x84, 0x6d, 0x0b, 0xb7, 0xd3, 0xfa, 0x21, 0x35, 0x7e, 0xe8, 0x25, 0x63,
 10717  	0xf5, 0x00, 0x89, 0x0b, 0xab, 0x62, 0x7b, 0x9e, 0xed, 0xb4, 0x45, 0x84, 0x4f, 0x60, 0xe1, 0x94,
 10718  	0xba, 0x4e, 0x1b, 0x8b, 0xeb, 0x4b, 0x06, 0x39, 0xfe, 0xb6, 0x33, 0xe7, 0xb9, 0xb9, 0xf8, 0x08,
 10719  	0x52, 0x9f, 0x1c, 0x4d, 0xfd, 0xb0, 0xbb, 0xa9, 0x10, 0xda, 0x26, 0x86, 0xb3, 0x4f, 0xdd, 0x36,
 10720  	0x25, 0x9e, 0x17, 0x5e, 0xd2, 0x3f, 0x24, 0xe1, 0x3a, 0x67, 0xc6, 0xdb, 0x44, 0x9e, 0x2e, 0x11,
 10721  	0xd4, 0xde, 0x25, 0x2a, 0xf3, 0xee, 0x38, 0xae, 0x1d, 0xf5, 0x8b, 0xa7, 0x08, 0x5f, 0x28, 0x03,
 10722  	0x8e, 0xb0, 0x06, 0xab, 0x92, 0x0f, 0x98, 0xfa, 0x7e, 0xd9, 0x28, 0xe4, 0xb0, 0xa9, 0x57, 0x6a,
 10723  	0x1f, 0xe9, 0x45, 0x35, 0x81, 0x56, 0x01, 0x05, 0xba, 0x5c, 0x75, 0x47, 0xc7, 0xf5, 0xfd, 0xb2,
 10724  	0xd1, 0x50, 0x15, 0x74, 0x03, 0xae, 0x47, 0xe4, 0x15, 0xdd, 0xdc, 0x61, 0x14, 0x22, 0x44, 0x2e,
 10725  	0xcc, 0xdc, 0x76, 0x03, 0xd7, 0xab, 0xb9, 0xfd, 0x7a, 0xa9, 0xd6, 0x50, 0xa7, 0x50, 0x06, 0xd6,
 10726  	0xa4, 0xa6, 0x5c, 0xdb, 0x31, 0x0a, 0xb9, 0x32, 0xae, 0xed, 0xd7, 0x71, 0xc5, 0xa8, 0xd7, 0x8d,
 10727  	0xea, 0x8e, 0x9a, 0x0a, 0x79, 0xd6, 0xcb, 0xb5, 0x43, 0x5c, 0xa8, 0x55, 0xeb, 0x07, 0x15, 0xdd,
 10728  	0x54, 0xa7, 0x65, 0x5a, 0xda, 0xa0, 0x19, 0x4e, 0x8b, 0xf8, 0x84, 0x76, 0x6d, 0xc7, 0xf2, 0x49,
 10729  	0xc1, 0xed, 0x76, 0x6d, 0x79, 0x49, 0xe8, 0x30, 0xef, 0xf9, 0x56, 0x9b, 0x13, 0xf9, 0x1f, 0xc8,
 10730  	0x25, 0x41, 0x3a, 0x0e, 0xc9, 0xe4, 0xc5, 0x0a, 0xcc, 0x73, 0xd8, 0x22, 0xf1, 0x2d, 0xbb, 0x83,
 10731  	0x4c, 0x50, 0x1d, 0xd7, 0xc7, 0x91, 0x56, 0x5b, 0x8c, 0xf0, 0x56, 0xcc, 0x08, 0x31, 0xed, 0x7e,
 10732  	0x29, 0x61, 0x2e, 0x39, 0x11, 0x31, 0xaa, 0xc1, 0xb2, 0xe8, 0x44, 0x19, 0xf2, 0x31, 0xab, 0xca,
 10733  	0x72, 0x17, 0xdf, 0x1d, 0xb7, 0xa8, 0x91, 0xea, 0x5d, 0x62, 0xbd, 0x4c, 0x58, 0x8a, 0x9e, 0x02,
 10734  	0x12, 0x80, 0xcf, 0xc9, 0x39, 0x0e, 0xda, 0x35, 0x59, 0xaa, 0xee, 0x8d, 0xc3, 0xbc, 0xdc, 0x92,
 10735  	0x96, 0x12, 0xa6, 0x4a, 0x2f, 0x29, 0xd0, 0xaf, 0x15, 0xd8, 0xe0, 0x2d, 0xd7, 0x29, 0xef, 0xcc,
 10736  	0x70, 0x7f, 0xd8, 0x9a, 0xf1, 0xe3, 0xc1, 0x7a, 0x33, 0xd9, 0xfd, 0x3d, 0x8a, 0x7d, 0x7a, 0xf8,
 10737  	0xbe, 0x9e, 0xae, 0x94, 0x30, 0x6f, 0xd3, 0xab, 0xac, 0xd0, 0x2f, 0xe0, 0x7a, 0xa8, 0x8e, 0x62,
 10738  	0x4b, 0xb4, 0x1c, 0xfc, 0x05, 0x61, 0xfe, 0xe1, 0x83, 0x89, 0xfa, 0x93, 0x60, 0x24, 0xe4, 0x8f,
 10739  	0xa8, 0x50, 0x03, 0xd4, 0x30, 0x3c, 0x6b, 0x2e, 0xb4, 0x19, 0x8e, 0xfd, 0xf6, 0xd5, 0xd8, 0x83,
 10740  	0x5e, 0xa6, 0x94, 0x30, 0x97, 0xfd, 0xa8, 0x1c, 0x1d, 0xc2, 0xb5, 0x30, 0x2a, 0x65, 0x07, 0x52,
 10741  	0x9b, 0x1d, 0xbb, 0x20, 0xb1, 0xed, 0x0b, 0x5b, 0x10, 0xff, 0x92, 0x02, 0x7d, 0x0c, 0xe1, 0x49,
 10742  	0x60, 0x8f, 0x77, 0x03, 0x5a, 0x9a, 0x23, 0xdf, 0x9f, 0xb8, 0x73, 0x28, 0x25, 0xcc, 0x70, 0x7c,
 10743  	0x42, 0x83, 0x4a, 0xac, 0xf0, 0xd9, 0x3e, 0x09, 0x0a, 0xdf, 0x1c, 0x47, 0xbd, 0x13, 0x83, 0x7a,
 10744  	0xb9, 0x39, 0x28, 0x25, 0x58, 0x11, 0x1c, 0xc8, 0x90, 0x01, 0x8b, 0x02, 0xc9, 0x77, 0x5d, 0xcc,
 10745  	0xaa, 0x34, 0x5c, 0x0d, 0x15, 0xa2, 0x3d, 0x03, 0x28, 0x21, 0x63, 0x87, 0xc5, 0xed, 0x61, 0x2a,
 10746  	0x29, 0x38, 0x3f, 0xe1, 0xf3, 0x63, 0x0f, 0xcb, 0x28, 0x57, 0x67, 0x87, 0xc5, 0x0d, 0x4b, 0xd9,
 10747  	0x82, 0x37, 0x03, 0xda, 0x8e, 0x8f, 0x39, 0x6f, 0xd7, 0x16, 0xc6, 0x2e, 0x78, 0x1c, 0xc3, 0x67,
 10748  	0x0b, 0xde, 0x8c, 0xca, 0x51, 0x15, 0x96, 0x44, 0x8d, 0xa0, 0x92, 0xb1, 0x6b, 0x8b, 0x63, 0xa3,
 10749  	0x1c, 0x65, 0xf6, 0x2c, 0xca, 0x4e, 0x58, 0xca, 0xa2, 0x74, 0xdc, 0x16, 0xc1, 0xfd, 0xe1, 0x23,
 10750  	0x98, 0xb6, 0x34, 0x36, 0xca, 0xb8, 0xe7, 0x32, 0x16, 0xa5, 0x13, 0x95, 0x33, 0x7e, 0xe6, 0x11,
 10751  	0xa7, 0xa5, 0x2d, 0x73, 0xa4, 0xd7, 0x63, 0x90, 0x06, 0xfc, 0xbd, 0x94, 0x30, 0xb9, 0xad, 0x28,
 10752  	0x2e, 0xc7, 0x3e, 0x6e, 0x33, 0x8e, 0x8c, 0x5b, 0x82, 0x24, 0x6b, 0xea, 0x15, 0xc5, 0x25, 0x86,
 10753  	0x4f, 0x8b, 0xe2, 0x12, 0x55, 0xb0, 0xbd, 0x1c, 0x10, 0xdc, 0xe6, 0x80, 0x5e, 0x6b, 0xd7, 0xc6,
 10754  	0xee, 0xe5, 0x78, 0x2a, 0xce, 0xf6, 0x32, 0xbd, 0xac, 0xe1, 0x35, 0x56, 0x62, 0x07, 0x7b, 0x10,
 10755  	0x8d, 0xaf, 0xb1, 0x23, 0xe4, 0x9b, 0xd7, 0xd8, 0xb0, 0x94, 0x2d, 0x88, 0x15, 0xb4, 0x28, 0x98,
 10756  	0xf2, 0x1e, 0x45, 0x5b, 0x1b, 0xbb, 0x20, 0x71, 0xdd, 0x0c, 0x5b, 0x10, 0x2b, 0x2a, 0x67, 0x61,
 10757  	0x0a, 0x22, 0x3e, 0xbc, 0x0a, 0x6e, 0x8d, 0x0d, 0x73, 0x94, 0xc8, 0xb3, 0x30, 0xbd, 0xb0, 0x14,
 10758  	0xfd, 0x56, 0x81, 0x37, 0x47, 0x2a, 0x0f, 0xaf, 0xde, 0x98, 0xbf, 0x4a, 0x63, 0x2a, 0x18, 0xb5,
 10759  	0xf6, 0x3a, 0x1f, 0xe6, 0xa7, 0x13, 0x14, 0xa3, 0x58, 0x32, 0x5e, 0x4a, 0x98, 0x1b, 0xfe, 0xf7,
 10760  	0x18, 0xb2, 0x9c, 0xd9, 0x82, 0x9e, 0x62, 0x57, 0xf2, 0x53, 0x6d, 0x7d, 0x6c, 0xce, 0xe2, 0x98,
 10761  	0x2c, 0xcb, 0x99, 0x1d, 0x95, 0xb3, 0x0b, 0xa1, 0x3f, 0x7c, 0x00, 0xc6, 0xb2, 0x81, 0xd5, 0x36,
 10762  	0xc6, 0x5e, 0x08, 0x63, 0x9e, 0x8b, 0xd9, 0x85, 0xd0, 0x1f, 0x51, 0xa1, 0x4f, 0x40, 0x1d, 0xbc,
 10763  	0x20, 0xe0, 0x23, 0xce, 0x5d, 0xb5, 0x2c, 0xc7, 0xde, 0x8c, 0xc1, 0xbe, 0x82, 0xea, 0xf2, 0x7b,
 10764  	0x21, 0xaa, 0x41, 0xa7, 0x70, 0x9b, 0xb5, 0x2a, 0x96, 0x68, 0x00, 0x30, 0x19, 0x76, 0x00, 0x92,
 10765  	0xef, 0xdf, 0xe1, 0x23, 0x3d, 0x8c, 0x5b, 0x96, 0xab, 0xfb, 0x86, 0x52, 0xc2, 0x5c, 0xf3, 0xc7,
 10766  	0x9a, 0xb0, 0xfa, 0x24, 0xaa, 0x3a, 0xe3, 0x07, 0x8c, 0xeb, 0x6a, 0x6f, 0x8e, 0xdd, 0x67, 0xa3,
 10767  	0x9c, 0x98, 0xed, 0x33, 0x3b, 0x2c, 0x45, 0x07, 0x70, 0xad, 0xcb, 0x58, 0x2c, 0xb6, 0x1d, 0xb6,
 10768  	0xb1, 0x38, 0x8f, 0xd5, 0xee, 0x8e, 0x5d, 0xdb, 0x38, 0xc6, 0xcb, 0xf2, 0xd3, 0x8d, 0xca, 0xd1,
 10769  	0x87, 0x92, 0x1a, 0x1d, 0x13, 0xbe, 0xb2, 0xec, 0xd6, 0x7c, 0x6b, 0x2c, 0xdb, 0x8a, 0xe1, 0xbb,
 10770  	0x8c, 0x6d, 0x0d, 0x00, 0xc4, 0x8d, 0xf9, 0x4b, 0x58, 0xb1, 0xc3, 0xd4, 0x11, 0x37, 0x39, 0x77,
 10771  	0xd4, 0xde, 0xe6, 0xb8, 0xef, 0xc4, 0xce, 0x3f, 0x9e, 0x69, 0x96, 0x12, 0xe6, 0x75, 0x7b, 0x54,
 10772  	0x27, 0x98, 0x63, 0x7e, 0x16, 0xa6, 0x79, 0x8f, 0xb4, 0x9b, 0x4a, 0xaf, 0xaa, 0x37, 0x76, 0x53,
 10773  	0xe9, 0x9b, 0xea, 0xda, 0x6e, 0x2a, 0x7d, 0x5b, 0xcd, 0xec, 0xa6, 0xd2, 0x19, 0x75, 0x7d, 0x37,
 10774  	0x95, 0x7e, 0x43, 0xcd, 0x66, 0xb7, 0x38, 0xbf, 0xdc, 0x77, 0x3d, 0x7e, 0x7b, 0xa0, 0x35, 0x98,
 10775  	0x66, 0x90, 0x67, 0xb2, 0xbf, 0x17, 0xb4, 0x54, 0x88, 0x24, 0x23, 0xfd, 0x72, 0x0a, 0xa6, 0x27,
 10776  	0x7b, 0x0d, 0xf9, 0x79, 0x94, 0x29, 0x51, 0xc2, 0xff, 0x59, 0xe0, 0x3c, 0x70, 0x29, 0x76, 0xa1,
 10777  	0x23, 0x27, 0x9d, 0x1b, 0x07, 0x6f, 0xc7, 0xfe, 0x88, 0x06, 0x15, 0x60, 0xb1, 0xef, 0x90, 0xb3,
 10778  	0x9e, 0xeb, 0x91, 0x16, 0xbf, 0x86, 0x53, 0x93, 0x10, 0x6d, 0x73, 0x61, 0xe0, 0xc4, 0x2e, 0xdf,
 10779  	0x2d, 0x98, 0x77, 0xa9, 0xdd, 0xb6, 0x1d, 0xcc, 0xae, 0x26, 0x4e, 0xe2, 0xa6, 0xf3, 0x4b, 0x6c,
 10780  	0xcc, 0xef, 0x2e, 0xd6, 0x67, 0xd8, 0x35, 0x66, 0x14, 0x4d, 0x10, 0x26, 0xec, 0x0b, 0x3d, 0x81,
 10781  	0x99, 0x16, 0x67, 0xe2, 0x92, 0x94, 0x65, 0xc6, 0xbd, 0x29, 0x08, 0xbe, 0x1e, 0x34, 0x3a, 0xc2,
 10782  	0x07, 0xfd, 0x38, 0xc8, 0xee, 0xec, 0x55, 0xce, 0xc1, 0x62, 0xc8, 0xbc, 0xa3, 0x47, 0x30, 0xe5,
 10783  	0xb8, 0xa7, 0x92, 0x54, 0x4d, 0xd4, 0x59, 0x32, 0xfb, 0xc7, 0xe9, 0x3f, 0x7e, 0xbe, 0x9e, 0x18,
 10784  	0x3e, 0x6a, 0x3d, 0xf8, 0x67, 0x12, 0xb4, 0x71, 0x6f, 0xe5, 0xac, 0xe1, 0xc9, 0xe5, 0x6b, 0x66,
 10785  	0x03, 0x8f, 0xbc, 0xd0, 0xde, 0x85, 0x37, 0x22, 0x1a, 0xfe, 0xa1, 0x17, 0xb1, 0xa9, 0x17, 0x6a,
 10786  	0x66, 0x11, 0x6f, 0xd7, 0x0e, 0xaa, 0x45, 0x55, 0x61, 0x1d, 0x55, 0xc4, 0xac, 0x50, 0x36, 0xf4,
 10787  	0x2a, 0xfb, 0xda, 0xd5, 0x0b, 0xac, 0xe3, 0x5a, 0x87, 0x5b, 0x11, 0xfd, 0xfe, 0x41, 0xbd, 0xa4,
 10788  	0x9b, 0x01, 0x9a, 0x9a, 0x42, 0xb7, 0xe0, 0xc6, 0xe8, 0x38, 0xb8, 0xbe, 0x9f, 0xab, 0xaa, 0xd3,
 10789  	0x28, 0x07, 0x1f, 0x44, 0x95, 0x65, 0x53, 0xcf, 0x15, 0x9f, 0x0d, 0x1f, 0x8c, 0x71, 0xcd, 0xc4,
 10790  	0x66, 0xad, 0x5c, 0xd6, 0x8b, 0x38, 0x9f, 0x2b, 0xec, 0xe1, 0xfd, 0x5a, 0xbd, 0x6e, 0xe4, 0xcb,
 10791  	0x3a, 0x6f, 0x23, 0x73, 0xcf, 0xd4, 0x19, 0xf4, 0x36, 0xdc, 0x89, 0x40, 0x54, 0xf5, 0x43, 0x5c,
 10792  	0xd6, 0x73, 0x75, 0x1d, 0xef, 0x9b, 0xfa, 0x47, 0x7a, 0xb5, 0x51, 0xc7, 0x8d, 0xa7, 0x55, 0x35,
 10793  	0x8d, 0xee, 0xc3, 0xdd, 0x88, 0x61, 0xc3, 0xa8, 0xe8, 0xf5, 0x46, 0xae, 0xb2, 0x8f, 0x0b, 0xb9,
 10794  	0x42, 0x49, 0x97, 0x53, 0xd2, 0x8b, 0xea, 0xec, 0x5a, 0xea, 0xb3, 0x3f, 0x65, 0x12, 0x59, 0x96,
 10795  	0xde, 0xe4, 0x83, 0xbf, 0x46, 0x9f, 0xda, 0x43, 0x8f, 0xf7, 0xa2, 0x9b, 0x6c, 0x98, 0xcf, 0x46,
 10796  	0x93, 0xcb, 0x5b, 0x57, 0xa6, 0x39, 0x34, 0x8d, 0x86, 0x8e, 0x1b, 0xb5, 0x1a, 0xae, 0x95, 0x59,
 10797  	0x3a, 0x79, 0xaf, 0xcb, 0x14, 0x75, 0xdd, 0x34, 0x72, 0x65, 0xe3, 0xe3, 0x5c, 0xbe, 0xac, 0xab,
 10798  	0x53, 0xe8, 0x36, 0xdc, 0x14, 0xf2, 0x5c, 0xfd, 0x59, 0xb5, 0x20, 0xdd, 0xb6, 0x73, 0x46, 0xf9,
 10799  	0xc0, 0xd4, 0xd5, 0x69, 0x94, 0x85, 0x8c, 0x50, 0x8b, 0xc4, 0xe0, 0xa2, 0x9e, 0x2b, 0x96, 0x8d,
 10800  	0xaa, 0x8e, 0xf5, 0xa7, 0x05, 0x5d, 0x2f, 0xea, 0x45, 0x75, 0x46, 0x04, 0xfd, 0xe0, 0x31, 0xa0,
 10801  	0xd1, 0xe3, 0x86, 0xd2, 0x90, 0xaa, 0xd6, 0xaa, 0xba, 0x9a, 0x40, 0xf3, 0x30, 0xcb, 0x12, 0x59,
 10802  	0xdb, 0xde, 0x56, 0x15, 0xb4, 0x08, 0x73, 0x46, 0xa5, 0xa2, 0x17, 0x8d, 0x5c, 0x43, 0x57, 0x93,
 10803  	0xf9, 0xfb, 0x5f, 0xfd, 0x3b, 0x93, 0xf8, 0xea, 0x65, 0x46, 0xf9, 0xfa, 0x65, 0x46, 0xf9, 0xe6,
 10804  	0x65, 0x46, 0xf9, 0xd7, 0xcb, 0x8c, 0xf2, 0xbb, 0x6f, 0x33, 0x89, 0xaf, 0xbf, 0xcd, 0x24, 0xbe,
 10805  	0xf9, 0x36, 0x93, 0xf8, 0x78, 0x56, 0x6e, 0xe7, 0xff, 0x07, 0x00, 0x00, 0xff, 0xff, 0x7b, 0x53,
 10806  	0xcf, 0x69, 0xfa, 0x1e, 0x00, 0x00,
 10807  }