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

     1  // Code generated by protoc-gen-gogo. DO NOT EDIT.
     2  // source: sql/execinfrapb/data.proto
     3  
     4  package execinfrapb
     5  
     6  /*
     7  	Beware! This package name must not be changed, even though it doesn't match
     8  	the Go package name, because it defines the Protobuf message names which
     9  	can't be changed without breaking backward compatibility.
    10  */
    11  
    12  import proto "github.com/gogo/protobuf/proto"
    13  import fmt "fmt"
    14  import math "math"
    15  import errorspb "github.com/cockroachdb/errors/errorspb"
    16  import roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    17  import sqlbase "github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
    18  import types "github.com/cockroachdb/cockroach/pkg/sql/types"
    19  import tracing "github.com/cockroachdb/cockroach/pkg/util/tracing"
    20  
    21  import github_com_cockroachdb_cockroach_pkg_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    22  
    23  import github_com_gogo_protobuf_sortkeys "github.com/gogo/protobuf/sortkeys"
    24  import encoding_binary "encoding/binary"
    25  
    26  import io "io"
    27  
    28  // Reference imports to suppress errors if they are not otherwise used.
    29  var _ = proto.Marshal
    30  var _ = fmt.Errorf
    31  var _ = math.Inf
    32  
    33  // This is a compile-time assertion to ensure that this generated file
    34  // is compatible with the proto package it is being compiled against.
    35  // A compilation error at this line likely means your copy of the
    36  // proto package needs to be updated.
    37  const _ = proto.GoGoProtoPackageIsVersion2 // please upgrade the proto package
    38  
    39  // The direction of the desired ordering for a column.
    40  type Ordering_Column_Direction int32
    41  
    42  const (
    43  	Ordering_Column_ASC  Ordering_Column_Direction = 0
    44  	Ordering_Column_DESC Ordering_Column_Direction = 1
    45  )
    46  
    47  var Ordering_Column_Direction_name = map[int32]string{
    48  	0: "ASC",
    49  	1: "DESC",
    50  }
    51  var Ordering_Column_Direction_value = map[string]int32{
    52  	"ASC":  0,
    53  	"DESC": 1,
    54  }
    55  
    56  func (x Ordering_Column_Direction) Enum() *Ordering_Column_Direction {
    57  	p := new(Ordering_Column_Direction)
    58  	*p = x
    59  	return p
    60  }
    61  func (x Ordering_Column_Direction) String() string {
    62  	return proto.EnumName(Ordering_Column_Direction_name, int32(x))
    63  }
    64  func (x *Ordering_Column_Direction) UnmarshalJSON(data []byte) error {
    65  	value, err := proto.UnmarshalJSONEnum(Ordering_Column_Direction_value, data, "Ordering_Column_Direction")
    66  	if err != nil {
    67  		return err
    68  	}
    69  	*x = Ordering_Column_Direction(value)
    70  	return nil
    71  }
    72  func (Ordering_Column_Direction) EnumDescriptor() ([]byte, []int) {
    73  	return fileDescriptor_data_b1be9c010247b5f4, []int{2, 0, 0}
    74  }
    75  
    76  type StreamEndpointSpec_Type int32
    77  
    78  const (
    79  	// Stream that is part of the local flow.
    80  	StreamEndpointSpec_LOCAL StreamEndpointSpec_Type = 0
    81  	// Stream that has the other endpoint on a different node.
    82  	StreamEndpointSpec_REMOTE StreamEndpointSpec_Type = 1
    83  	// Special stream used when in "sync flow" mode. In this mode, we return
    84  	// results directly as part of the RPC call that set up the flow. This saves
    85  	// overhead (extra RPCs) compared to the normal mode where the RPC just sets
    86  	// up the flow. This type can only be used with outbound endpoints.
    87  	StreamEndpointSpec_SYNC_RESPONSE StreamEndpointSpec_Type = 2
    88  )
    89  
    90  var StreamEndpointSpec_Type_name = map[int32]string{
    91  	0: "LOCAL",
    92  	1: "REMOTE",
    93  	2: "SYNC_RESPONSE",
    94  }
    95  var StreamEndpointSpec_Type_value = map[string]int32{
    96  	"LOCAL":         0,
    97  	"REMOTE":        1,
    98  	"SYNC_RESPONSE": 2,
    99  }
   100  
   101  func (x StreamEndpointSpec_Type) Enum() *StreamEndpointSpec_Type {
   102  	p := new(StreamEndpointSpec_Type)
   103  	*p = x
   104  	return p
   105  }
   106  func (x StreamEndpointSpec_Type) String() string {
   107  	return proto.EnumName(StreamEndpointSpec_Type_name, int32(x))
   108  }
   109  func (x *StreamEndpointSpec_Type) UnmarshalJSON(data []byte) error {
   110  	value, err := proto.UnmarshalJSONEnum(StreamEndpointSpec_Type_value, data, "StreamEndpointSpec_Type")
   111  	if err != nil {
   112  		return err
   113  	}
   114  	*x = StreamEndpointSpec_Type(value)
   115  	return nil
   116  }
   117  func (StreamEndpointSpec_Type) EnumDescriptor() ([]byte, []int) {
   118  	return fileDescriptor_data_b1be9c010247b5f4, []int{3, 0}
   119  }
   120  
   121  type InputSyncSpec_Type int32
   122  
   123  const (
   124  	// Rows from the input streams are interleaved arbitrarily.
   125  	InputSyncSpec_UNORDERED InputSyncSpec_Type = 0
   126  	// The input streams are guaranteed to be ordered according to the column
   127  	// ordering field; rows from the streams are interleaved to preserve that
   128  	// ordering.
   129  	InputSyncSpec_ORDERED InputSyncSpec_Type = 1
   130  )
   131  
   132  var InputSyncSpec_Type_name = map[int32]string{
   133  	0: "UNORDERED",
   134  	1: "ORDERED",
   135  }
   136  var InputSyncSpec_Type_value = map[string]int32{
   137  	"UNORDERED": 0,
   138  	"ORDERED":   1,
   139  }
   140  
   141  func (x InputSyncSpec_Type) Enum() *InputSyncSpec_Type {
   142  	p := new(InputSyncSpec_Type)
   143  	*p = x
   144  	return p
   145  }
   146  func (x InputSyncSpec_Type) String() string {
   147  	return proto.EnumName(InputSyncSpec_Type_name, int32(x))
   148  }
   149  func (x *InputSyncSpec_Type) UnmarshalJSON(data []byte) error {
   150  	value, err := proto.UnmarshalJSONEnum(InputSyncSpec_Type_value, data, "InputSyncSpec_Type")
   151  	if err != nil {
   152  		return err
   153  	}
   154  	*x = InputSyncSpec_Type(value)
   155  	return nil
   156  }
   157  func (InputSyncSpec_Type) EnumDescriptor() ([]byte, []int) {
   158  	return fileDescriptor_data_b1be9c010247b5f4, []int{4, 0}
   159  }
   160  
   161  type OutputRouterSpec_Type int32
   162  
   163  const (
   164  	// Single output stream.
   165  	OutputRouterSpec_PASS_THROUGH OutputRouterSpec_Type = 0
   166  	// Each row is sent to all output streams.
   167  	OutputRouterSpec_MIRROR OutputRouterSpec_Type = 1
   168  	// Each row is sent to one stream, chosen by hashing certain columns of
   169  	// the row (specified by the hash_columns field).
   170  	OutputRouterSpec_BY_HASH OutputRouterSpec_Type = 2
   171  	// Each row is sent to one stream, chosen according to preset boundaries
   172  	// for the values of certain columns of the row.
   173  	OutputRouterSpec_BY_RANGE OutputRouterSpec_Type = 3
   174  )
   175  
   176  var OutputRouterSpec_Type_name = map[int32]string{
   177  	0: "PASS_THROUGH",
   178  	1: "MIRROR",
   179  	2: "BY_HASH",
   180  	3: "BY_RANGE",
   181  }
   182  var OutputRouterSpec_Type_value = map[string]int32{
   183  	"PASS_THROUGH": 0,
   184  	"MIRROR":       1,
   185  	"BY_HASH":      2,
   186  	"BY_RANGE":     3,
   187  }
   188  
   189  func (x OutputRouterSpec_Type) Enum() *OutputRouterSpec_Type {
   190  	p := new(OutputRouterSpec_Type)
   191  	*p = x
   192  	return p
   193  }
   194  func (x OutputRouterSpec_Type) String() string {
   195  	return proto.EnumName(OutputRouterSpec_Type_name, int32(x))
   196  }
   197  func (x *OutputRouterSpec_Type) UnmarshalJSON(data []byte) error {
   198  	value, err := proto.UnmarshalJSONEnum(OutputRouterSpec_Type_value, data, "OutputRouterSpec_Type")
   199  	if err != nil {
   200  		return err
   201  	}
   202  	*x = OutputRouterSpec_Type(value)
   203  	return nil
   204  }
   205  func (OutputRouterSpec_Type) EnumDescriptor() ([]byte, []int) {
   206  	return fileDescriptor_data_b1be9c010247b5f4, []int{5, 0}
   207  }
   208  
   209  // Error is a generic representation including a string message.
   210  type Error struct {
   211  	// full_error contains a structured errors with possibly multiple
   212  	// wrapping layers implementing the errors.Cause() interface.
   213  	FullError *errorspb.EncodedError `protobuf:"bytes,3,opt,name=full_error,json=fullError" json:"full_error,omitempty"`
   214  }
   215  
   216  func (m *Error) Reset()      { *m = Error{} }
   217  func (*Error) ProtoMessage() {}
   218  func (*Error) Descriptor() ([]byte, []int) {
   219  	return fileDescriptor_data_b1be9c010247b5f4, []int{0}
   220  }
   221  func (m *Error) XXX_Unmarshal(b []byte) error {
   222  	return m.Unmarshal(b)
   223  }
   224  func (m *Error) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   225  	b = b[:cap(b)]
   226  	n, err := m.MarshalTo(b)
   227  	if err != nil {
   228  		return nil, err
   229  	}
   230  	return b[:n], nil
   231  }
   232  func (dst *Error) XXX_Merge(src proto.Message) {
   233  	xxx_messageInfo_Error.Merge(dst, src)
   234  }
   235  func (m *Error) XXX_Size() int {
   236  	return m.Size()
   237  }
   238  func (m *Error) XXX_DiscardUnknown() {
   239  	xxx_messageInfo_Error.DiscardUnknown(m)
   240  }
   241  
   242  var xxx_messageInfo_Error proto.InternalMessageInfo
   243  
   244  func (m *Expression) Reset()      { *m = Expression{} }
   245  func (*Expression) ProtoMessage() {}
   246  func (*Expression) Descriptor() ([]byte, []int) {
   247  	return fileDescriptor_data_b1be9c010247b5f4, []int{1}
   248  }
   249  func (m *Expression) XXX_Unmarshal(b []byte) error {
   250  	return m.Unmarshal(b)
   251  }
   252  func (m *Expression) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   253  	b = b[:cap(b)]
   254  	n, err := m.MarshalTo(b)
   255  	if err != nil {
   256  		return nil, err
   257  	}
   258  	return b[:n], nil
   259  }
   260  func (dst *Expression) XXX_Merge(src proto.Message) {
   261  	xxx_messageInfo_Expression.Merge(dst, src)
   262  }
   263  func (m *Expression) XXX_Size() int {
   264  	return m.Size()
   265  }
   266  func (m *Expression) XXX_DiscardUnknown() {
   267  	xxx_messageInfo_Expression.DiscardUnknown(m)
   268  }
   269  
   270  var xxx_messageInfo_Expression proto.InternalMessageInfo
   271  
   272  // Ordering defines an order - specifically a list of column indices and
   273  // directions. See sqlbase.ColumnOrdering.
   274  type Ordering struct {
   275  	Columns []Ordering_Column `protobuf:"bytes,1,rep,name=columns" json:"columns"`
   276  }
   277  
   278  func (m *Ordering) Reset()         { *m = Ordering{} }
   279  func (m *Ordering) String() string { return proto.CompactTextString(m) }
   280  func (*Ordering) ProtoMessage()    {}
   281  func (*Ordering) Descriptor() ([]byte, []int) {
   282  	return fileDescriptor_data_b1be9c010247b5f4, []int{2}
   283  }
   284  func (m *Ordering) XXX_Unmarshal(b []byte) error {
   285  	return m.Unmarshal(b)
   286  }
   287  func (m *Ordering) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   288  	b = b[:cap(b)]
   289  	n, err := m.MarshalTo(b)
   290  	if err != nil {
   291  		return nil, err
   292  	}
   293  	return b[:n], nil
   294  }
   295  func (dst *Ordering) XXX_Merge(src proto.Message) {
   296  	xxx_messageInfo_Ordering.Merge(dst, src)
   297  }
   298  func (m *Ordering) XXX_Size() int {
   299  	return m.Size()
   300  }
   301  func (m *Ordering) XXX_DiscardUnknown() {
   302  	xxx_messageInfo_Ordering.DiscardUnknown(m)
   303  }
   304  
   305  var xxx_messageInfo_Ordering proto.InternalMessageInfo
   306  
   307  type Ordering_Column struct {
   308  	ColIdx    uint32                    `protobuf:"varint,1,opt,name=col_idx,json=colIdx" json:"col_idx"`
   309  	Direction Ordering_Column_Direction `protobuf:"varint,2,opt,name=direction,enum=cockroach.sql.distsqlrun.Ordering_Column_Direction" json:"direction"`
   310  }
   311  
   312  func (m *Ordering_Column) Reset()         { *m = Ordering_Column{} }
   313  func (m *Ordering_Column) String() string { return proto.CompactTextString(m) }
   314  func (*Ordering_Column) ProtoMessage()    {}
   315  func (*Ordering_Column) Descriptor() ([]byte, []int) {
   316  	return fileDescriptor_data_b1be9c010247b5f4, []int{2, 0}
   317  }
   318  func (m *Ordering_Column) XXX_Unmarshal(b []byte) error {
   319  	return m.Unmarshal(b)
   320  }
   321  func (m *Ordering_Column) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   322  	b = b[:cap(b)]
   323  	n, err := m.MarshalTo(b)
   324  	if err != nil {
   325  		return nil, err
   326  	}
   327  	return b[:n], nil
   328  }
   329  func (dst *Ordering_Column) XXX_Merge(src proto.Message) {
   330  	xxx_messageInfo_Ordering_Column.Merge(dst, src)
   331  }
   332  func (m *Ordering_Column) XXX_Size() int {
   333  	return m.Size()
   334  }
   335  func (m *Ordering_Column) XXX_DiscardUnknown() {
   336  	xxx_messageInfo_Ordering_Column.DiscardUnknown(m)
   337  }
   338  
   339  var xxx_messageInfo_Ordering_Column proto.InternalMessageInfo
   340  
   341  // StreamEndpointSpec describes one of the endpoints (input or output) of a physical
   342  // stream.
   343  type StreamEndpointSpec struct {
   344  	Type StreamEndpointSpec_Type `protobuf:"varint,1,opt,name=type,enum=cockroach.sql.distsqlrun.StreamEndpointSpec_Type" json:"type"`
   345  	// The ID of this stream.
   346  	//
   347  	// For LOCAL streams, both ends of the stream are part of the flow on this
   348  	// machine (and there must be a corresponding endpoint with the same ID).
   349  	//
   350  	// For REMOTE streams, this ID is used in the ProducerHeader when connecting to
   351  	// the other host.
   352  	//
   353  	// For SYNC_RESPONSE streams, the ID is unused.
   354  	StreamID StreamID `protobuf:"varint,2,opt,name=stream_id,json=streamId,casttype=StreamID" json:"stream_id"`
   355  	// Node ID of the target host, only used for outgoing REMOTE streams.
   356  	TargetNodeID github_com_cockroachdb_cockroach_pkg_roachpb.NodeID `protobuf:"varint,4,opt,name=target_node_id,json=targetNodeId,casttype=github.com/cockroachdb/cockroach/pkg/roachpb.NodeID" json:"target_node_id"`
   357  }
   358  
   359  func (m *StreamEndpointSpec) Reset()         { *m = StreamEndpointSpec{} }
   360  func (m *StreamEndpointSpec) String() string { return proto.CompactTextString(m) }
   361  func (*StreamEndpointSpec) ProtoMessage()    {}
   362  func (*StreamEndpointSpec) Descriptor() ([]byte, []int) {
   363  	return fileDescriptor_data_b1be9c010247b5f4, []int{3}
   364  }
   365  func (m *StreamEndpointSpec) XXX_Unmarshal(b []byte) error {
   366  	return m.Unmarshal(b)
   367  }
   368  func (m *StreamEndpointSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   369  	b = b[:cap(b)]
   370  	n, err := m.MarshalTo(b)
   371  	if err != nil {
   372  		return nil, err
   373  	}
   374  	return b[:n], nil
   375  }
   376  func (dst *StreamEndpointSpec) XXX_Merge(src proto.Message) {
   377  	xxx_messageInfo_StreamEndpointSpec.Merge(dst, src)
   378  }
   379  func (m *StreamEndpointSpec) XXX_Size() int {
   380  	return m.Size()
   381  }
   382  func (m *StreamEndpointSpec) XXX_DiscardUnknown() {
   383  	xxx_messageInfo_StreamEndpointSpec.DiscardUnknown(m)
   384  }
   385  
   386  var xxx_messageInfo_StreamEndpointSpec proto.InternalMessageInfo
   387  
   388  // InputSyncSpec is the specification for an input synchronizer; it decides how
   389  // to interleave rows from multiple input streams.
   390  type InputSyncSpec struct {
   391  	Type     InputSyncSpec_Type   `protobuf:"varint,1,opt,name=type,enum=cockroach.sql.distsqlrun.InputSyncSpec_Type" json:"type"`
   392  	Ordering Ordering             `protobuf:"bytes,2,opt,name=ordering" json:"ordering"`
   393  	Streams  []StreamEndpointSpec `protobuf:"bytes,3,rep,name=streams" json:"streams"`
   394  	// Schema for the streams entering this synchronizer.
   395  	ColumnTypes []*types.T `protobuf:"bytes,4,rep,name=column_types,json=columnTypes" json:"column_types,omitempty"`
   396  }
   397  
   398  func (m *InputSyncSpec) Reset()         { *m = InputSyncSpec{} }
   399  func (m *InputSyncSpec) String() string { return proto.CompactTextString(m) }
   400  func (*InputSyncSpec) ProtoMessage()    {}
   401  func (*InputSyncSpec) Descriptor() ([]byte, []int) {
   402  	return fileDescriptor_data_b1be9c010247b5f4, []int{4}
   403  }
   404  func (m *InputSyncSpec) XXX_Unmarshal(b []byte) error {
   405  	return m.Unmarshal(b)
   406  }
   407  func (m *InputSyncSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   408  	b = b[:cap(b)]
   409  	n, err := m.MarshalTo(b)
   410  	if err != nil {
   411  		return nil, err
   412  	}
   413  	return b[:n], nil
   414  }
   415  func (dst *InputSyncSpec) XXX_Merge(src proto.Message) {
   416  	xxx_messageInfo_InputSyncSpec.Merge(dst, src)
   417  }
   418  func (m *InputSyncSpec) XXX_Size() int {
   419  	return m.Size()
   420  }
   421  func (m *InputSyncSpec) XXX_DiscardUnknown() {
   422  	xxx_messageInfo_InputSyncSpec.DiscardUnknown(m)
   423  }
   424  
   425  var xxx_messageInfo_InputSyncSpec proto.InternalMessageInfo
   426  
   427  // OutputRouterSpec is the specification for the output router of a processor;
   428  // it decides how to send results to multiple output streams.
   429  type OutputRouterSpec struct {
   430  	Type    OutputRouterSpec_Type `protobuf:"varint,1,opt,name=type,enum=cockroach.sql.distsqlrun.OutputRouterSpec_Type" json:"type"`
   431  	Streams []StreamEndpointSpec  `protobuf:"bytes,2,rep,name=streams" json:"streams"`
   432  	// Only used for the BY_HASH type; these are the indexes of the columns we are
   433  	// hashing.
   434  	HashColumns     []uint32                         `protobuf:"varint,3,rep,name=hash_columns,json=hashColumns" json:"hash_columns,omitempty"`
   435  	RangeRouterSpec OutputRouterSpec_RangeRouterSpec `protobuf:"bytes,4,opt,name=range_router_spec,json=rangeRouterSpec" json:"range_router_spec"`
   436  	// disable_buffering disables output buffering. Generally buffering should be
   437  	// enabled to prevent deadlocks. However some plans are known not to deadlock,
   438  	// and so can set this flag to prevent unbounded buffering causing OOMs.
   439  	DisableBuffering bool `protobuf:"varint,5,opt,name=disable_buffering,json=disableBuffering" json:"disable_buffering"`
   440  }
   441  
   442  func (m *OutputRouterSpec) Reset()         { *m = OutputRouterSpec{} }
   443  func (m *OutputRouterSpec) String() string { return proto.CompactTextString(m) }
   444  func (*OutputRouterSpec) ProtoMessage()    {}
   445  func (*OutputRouterSpec) Descriptor() ([]byte, []int) {
   446  	return fileDescriptor_data_b1be9c010247b5f4, []int{5}
   447  }
   448  func (m *OutputRouterSpec) XXX_Unmarshal(b []byte) error {
   449  	return m.Unmarshal(b)
   450  }
   451  func (m *OutputRouterSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   452  	b = b[:cap(b)]
   453  	n, err := m.MarshalTo(b)
   454  	if err != nil {
   455  		return nil, err
   456  	}
   457  	return b[:n], nil
   458  }
   459  func (dst *OutputRouterSpec) XXX_Merge(src proto.Message) {
   460  	xxx_messageInfo_OutputRouterSpec.Merge(dst, src)
   461  }
   462  func (m *OutputRouterSpec) XXX_Size() int {
   463  	return m.Size()
   464  }
   465  func (m *OutputRouterSpec) XXX_DiscardUnknown() {
   466  	xxx_messageInfo_OutputRouterSpec.DiscardUnknown(m)
   467  }
   468  
   469  var xxx_messageInfo_OutputRouterSpec proto.InternalMessageInfo
   470  
   471  type OutputRouterSpec_RangeRouterSpec struct {
   472  	// spans is a slice of Span. Input matching a span will be routed to its
   473  	// specified stream.
   474  	Spans []OutputRouterSpec_RangeRouterSpec_Span `protobuf:"bytes,1,rep,name=spans" json:"spans"`
   475  	// default_dest, if not nil, is the index of the stream to send rows that do
   476  	// not match any span. If nil, a row that does not match a span will produce
   477  	// an error in the router.
   478  	DefaultDest *int32 `protobuf:"varint,2,opt,name=default_dest,json=defaultDest" json:"default_dest,omitempty"`
   479  	// encodings is a slice of columns and encodings. Each will be appended to a
   480  	// []byte, which is used as input to the spans. Columns from the input rows
   481  	// potentially need to be recoded to match the encoding used for the spans.
   482  	Encodings []OutputRouterSpec_RangeRouterSpec_ColumnEncoding `protobuf:"bytes,3,rep,name=encodings" json:"encodings"`
   483  }
   484  
   485  func (m *OutputRouterSpec_RangeRouterSpec) Reset()         { *m = OutputRouterSpec_RangeRouterSpec{} }
   486  func (m *OutputRouterSpec_RangeRouterSpec) String() string { return proto.CompactTextString(m) }
   487  func (*OutputRouterSpec_RangeRouterSpec) ProtoMessage()    {}
   488  func (*OutputRouterSpec_RangeRouterSpec) Descriptor() ([]byte, []int) {
   489  	return fileDescriptor_data_b1be9c010247b5f4, []int{5, 0}
   490  }
   491  func (m *OutputRouterSpec_RangeRouterSpec) XXX_Unmarshal(b []byte) error {
   492  	return m.Unmarshal(b)
   493  }
   494  func (m *OutputRouterSpec_RangeRouterSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   495  	b = b[:cap(b)]
   496  	n, err := m.MarshalTo(b)
   497  	if err != nil {
   498  		return nil, err
   499  	}
   500  	return b[:n], nil
   501  }
   502  func (dst *OutputRouterSpec_RangeRouterSpec) XXX_Merge(src proto.Message) {
   503  	xxx_messageInfo_OutputRouterSpec_RangeRouterSpec.Merge(dst, src)
   504  }
   505  func (m *OutputRouterSpec_RangeRouterSpec) XXX_Size() int {
   506  	return m.Size()
   507  }
   508  func (m *OutputRouterSpec_RangeRouterSpec) XXX_DiscardUnknown() {
   509  	xxx_messageInfo_OutputRouterSpec_RangeRouterSpec.DiscardUnknown(m)
   510  }
   511  
   512  var xxx_messageInfo_OutputRouterSpec_RangeRouterSpec proto.InternalMessageInfo
   513  
   514  type OutputRouterSpec_RangeRouterSpec_ColumnEncoding struct {
   515  	// column is the index of a column to encode.
   516  	Column uint32 `protobuf:"varint,1,opt,name=column" json:"column"`
   517  	// encoding specifies how a particular column is to be encoded for
   518  	// generating the sort key for a row. This needs to correspond to the way
   519  	// the Span.{start,end} keys have been generated.
   520  	Encoding sqlbase.DatumEncoding `protobuf:"varint,2,opt,name=encoding,enum=cockroach.sql.sqlbase.DatumEncoding" json:"encoding"`
   521  }
   522  
   523  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Reset() {
   524  	*m = OutputRouterSpec_RangeRouterSpec_ColumnEncoding{}
   525  }
   526  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) String() string {
   527  	return proto.CompactTextString(m)
   528  }
   529  func (*OutputRouterSpec_RangeRouterSpec_ColumnEncoding) ProtoMessage() {}
   530  func (*OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Descriptor() ([]byte, []int) {
   531  	return fileDescriptor_data_b1be9c010247b5f4, []int{5, 0, 0}
   532  }
   533  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) XXX_Unmarshal(b []byte) error {
   534  	return m.Unmarshal(b)
   535  }
   536  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   537  	b = b[:cap(b)]
   538  	n, err := m.MarshalTo(b)
   539  	if err != nil {
   540  		return nil, err
   541  	}
   542  	return b[:n], nil
   543  }
   544  func (dst *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) XXX_Merge(src proto.Message) {
   545  	xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_ColumnEncoding.Merge(dst, src)
   546  }
   547  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) XXX_Size() int {
   548  	return m.Size()
   549  }
   550  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) XXX_DiscardUnknown() {
   551  	xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_ColumnEncoding.DiscardUnknown(m)
   552  }
   553  
   554  var xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_ColumnEncoding proto.InternalMessageInfo
   555  
   556  // Span matches bytes in [start, end).
   557  type OutputRouterSpec_RangeRouterSpec_Span struct {
   558  	Start []byte `protobuf:"bytes,1,opt,name=start" json:"start,omitempty"`
   559  	End   []byte `protobuf:"bytes,2,opt,name=end" json:"end,omitempty"`
   560  	// stream is the index of the destination stream.
   561  	Stream int32 `protobuf:"varint,3,opt,name=stream" json:"stream"`
   562  }
   563  
   564  func (m *OutputRouterSpec_RangeRouterSpec_Span) Reset()         { *m = OutputRouterSpec_RangeRouterSpec_Span{} }
   565  func (m *OutputRouterSpec_RangeRouterSpec_Span) String() string { return proto.CompactTextString(m) }
   566  func (*OutputRouterSpec_RangeRouterSpec_Span) ProtoMessage()    {}
   567  func (*OutputRouterSpec_RangeRouterSpec_Span) Descriptor() ([]byte, []int) {
   568  	return fileDescriptor_data_b1be9c010247b5f4, []int{5, 0, 1}
   569  }
   570  func (m *OutputRouterSpec_RangeRouterSpec_Span) XXX_Unmarshal(b []byte) error {
   571  	return m.Unmarshal(b)
   572  }
   573  func (m *OutputRouterSpec_RangeRouterSpec_Span) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   574  	b = b[:cap(b)]
   575  	n, err := m.MarshalTo(b)
   576  	if err != nil {
   577  		return nil, err
   578  	}
   579  	return b[:n], nil
   580  }
   581  func (dst *OutputRouterSpec_RangeRouterSpec_Span) XXX_Merge(src proto.Message) {
   582  	xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_Span.Merge(dst, src)
   583  }
   584  func (m *OutputRouterSpec_RangeRouterSpec_Span) XXX_Size() int {
   585  	return m.Size()
   586  }
   587  func (m *OutputRouterSpec_RangeRouterSpec_Span) XXX_DiscardUnknown() {
   588  	xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_Span.DiscardUnknown(m)
   589  }
   590  
   591  var xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_Span proto.InternalMessageInfo
   592  
   593  type DatumInfo struct {
   594  	Encoding sqlbase.DatumEncoding `protobuf:"varint,1,opt,name=encoding,enum=cockroach.sql.sqlbase.DatumEncoding" json:"encoding"`
   595  	Type     *types.T              `protobuf:"bytes,2,opt,name=type" json:"type,omitempty"`
   596  }
   597  
   598  func (m *DatumInfo) Reset()         { *m = DatumInfo{} }
   599  func (m *DatumInfo) String() string { return proto.CompactTextString(m) }
   600  func (*DatumInfo) ProtoMessage()    {}
   601  func (*DatumInfo) Descriptor() ([]byte, []int) {
   602  	return fileDescriptor_data_b1be9c010247b5f4, []int{6}
   603  }
   604  func (m *DatumInfo) XXX_Unmarshal(b []byte) error {
   605  	return m.Unmarshal(b)
   606  }
   607  func (m *DatumInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   608  	b = b[:cap(b)]
   609  	n, err := m.MarshalTo(b)
   610  	if err != nil {
   611  		return nil, err
   612  	}
   613  	return b[:n], nil
   614  }
   615  func (dst *DatumInfo) XXX_Merge(src proto.Message) {
   616  	xxx_messageInfo_DatumInfo.Merge(dst, src)
   617  }
   618  func (m *DatumInfo) XXX_Size() int {
   619  	return m.Size()
   620  }
   621  func (m *DatumInfo) XXX_DiscardUnknown() {
   622  	xxx_messageInfo_DatumInfo.DiscardUnknown(m)
   623  }
   624  
   625  var xxx_messageInfo_DatumInfo proto.InternalMessageInfo
   626  
   627  // ProducerHeader is a message that is sent once at the beginning of a stream.
   628  type ProducerHeader struct {
   629  	FlowID   FlowID   `protobuf:"bytes,1,opt,name=flow_id,json=flowId,customtype=FlowID" json:"flow_id"`
   630  	StreamID StreamID `protobuf:"varint,2,opt,name=stream_id,json=streamId,casttype=StreamID" json:"stream_id"`
   631  }
   632  
   633  func (m *ProducerHeader) Reset()         { *m = ProducerHeader{} }
   634  func (m *ProducerHeader) String() string { return proto.CompactTextString(m) }
   635  func (*ProducerHeader) ProtoMessage()    {}
   636  func (*ProducerHeader) Descriptor() ([]byte, []int) {
   637  	return fileDescriptor_data_b1be9c010247b5f4, []int{7}
   638  }
   639  func (m *ProducerHeader) XXX_Unmarshal(b []byte) error {
   640  	return m.Unmarshal(b)
   641  }
   642  func (m *ProducerHeader) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   643  	b = b[:cap(b)]
   644  	n, err := m.MarshalTo(b)
   645  	if err != nil {
   646  		return nil, err
   647  	}
   648  	return b[:n], nil
   649  }
   650  func (dst *ProducerHeader) XXX_Merge(src proto.Message) {
   651  	xxx_messageInfo_ProducerHeader.Merge(dst, src)
   652  }
   653  func (m *ProducerHeader) XXX_Size() int {
   654  	return m.Size()
   655  }
   656  func (m *ProducerHeader) XXX_DiscardUnknown() {
   657  	xxx_messageInfo_ProducerHeader.DiscardUnknown(m)
   658  }
   659  
   660  var xxx_messageInfo_ProducerHeader proto.InternalMessageInfo
   661  
   662  // ProducerData is a message that can be sent multiple times as part of a stream
   663  // from a producer to a consumer. It contains 0 or more rows and/or 0 or more
   664  // metadata messages.
   665  type ProducerData struct {
   666  	// A bunch of rows, encoded. Each datum is encoded according to the
   667  	// corresponding DatumInfo.
   668  	RawBytes []byte `protobuf:"bytes,1,opt,name=raw_bytes,json=rawBytes" json:"raw_bytes,omitempty"`
   669  	// In the special case when the stream contains empty rows, the count is
   670  	// passed instead.
   671  	NumEmptyRows int32 `protobuf:"varint,3,opt,name=num_empty_rows,json=numEmptyRows" json:"num_empty_rows"`
   672  	// A bunch of metadata messages.
   673  	Metadata []RemoteProducerMetadata `protobuf:"bytes,2,rep,name=metadata" json:"metadata"`
   674  }
   675  
   676  func (m *ProducerData) Reset()         { *m = ProducerData{} }
   677  func (m *ProducerData) String() string { return proto.CompactTextString(m) }
   678  func (*ProducerData) ProtoMessage()    {}
   679  func (*ProducerData) Descriptor() ([]byte, []int) {
   680  	return fileDescriptor_data_b1be9c010247b5f4, []int{8}
   681  }
   682  func (m *ProducerData) XXX_Unmarshal(b []byte) error {
   683  	return m.Unmarshal(b)
   684  }
   685  func (m *ProducerData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   686  	b = b[:cap(b)]
   687  	n, err := m.MarshalTo(b)
   688  	if err != nil {
   689  		return nil, err
   690  	}
   691  	return b[:n], nil
   692  }
   693  func (dst *ProducerData) XXX_Merge(src proto.Message) {
   694  	xxx_messageInfo_ProducerData.Merge(dst, src)
   695  }
   696  func (m *ProducerData) XXX_Size() int {
   697  	return m.Size()
   698  }
   699  func (m *ProducerData) XXX_DiscardUnknown() {
   700  	xxx_messageInfo_ProducerData.DiscardUnknown(m)
   701  }
   702  
   703  var xxx_messageInfo_ProducerData proto.InternalMessageInfo
   704  
   705  type ProducerMessage struct {
   706  	Header *ProducerHeader `protobuf:"bytes,1,opt,name=header" json:"header,omitempty"`
   707  	// Typing information. There will be one DatumInfo for each element in a row.
   708  	// This field has to be populated on, or before, a ProducerMessage with data
   709  	// in it, and can only be populated once. It can be nil if only zero length
   710  	// rows will be sent.
   711  	// TODO(andrei): It'd be nice if the typing information for streams would be
   712  	// configured statically at plan creation time, instead of being discovered
   713  	// dynamically through the first rows that flow.
   714  	Typing []DatumInfo  `protobuf:"bytes,2,rep,name=typing" json:"typing"`
   715  	Data   ProducerData `protobuf:"bytes,3,opt,name=data" json:"data"`
   716  }
   717  
   718  func (m *ProducerMessage) Reset()         { *m = ProducerMessage{} }
   719  func (m *ProducerMessage) String() string { return proto.CompactTextString(m) }
   720  func (*ProducerMessage) ProtoMessage()    {}
   721  func (*ProducerMessage) Descriptor() ([]byte, []int) {
   722  	return fileDescriptor_data_b1be9c010247b5f4, []int{9}
   723  }
   724  func (m *ProducerMessage) XXX_Unmarshal(b []byte) error {
   725  	return m.Unmarshal(b)
   726  }
   727  func (m *ProducerMessage) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   728  	b = b[:cap(b)]
   729  	n, err := m.MarshalTo(b)
   730  	if err != nil {
   731  		return nil, err
   732  	}
   733  	return b[:n], nil
   734  }
   735  func (dst *ProducerMessage) XXX_Merge(src proto.Message) {
   736  	xxx_messageInfo_ProducerMessage.Merge(dst, src)
   737  }
   738  func (m *ProducerMessage) XXX_Size() int {
   739  	return m.Size()
   740  }
   741  func (m *ProducerMessage) XXX_DiscardUnknown() {
   742  	xxx_messageInfo_ProducerMessage.DiscardUnknown(m)
   743  }
   744  
   745  var xxx_messageInfo_ProducerMessage proto.InternalMessageInfo
   746  
   747  // RemoteProducerMetadata represents records that a producer wants to pass to
   748  // a consumer, other than data rows. It's named RemoteProducerMetadata to not
   749  // clash with ProducerMetadata, which is used internally within a node and has
   750  // a different go error instead of a proto error inside.
   751  type RemoteProducerMetadata struct {
   752  	// Types that are valid to be assigned to Value:
   753  	//	*RemoteProducerMetadata_RangeInfo
   754  	//	*RemoteProducerMetadata_Error
   755  	//	*RemoteProducerMetadata_TraceData_
   756  	//	*RemoteProducerMetadata_LeafTxnFinalState
   757  	//	*RemoteProducerMetadata_RowNum_
   758  	//	*RemoteProducerMetadata_SamplerProgress_
   759  	//	*RemoteProducerMetadata_Metrics_
   760  	//	*RemoteProducerMetadata_BulkProcessorProgress_
   761  	Value isRemoteProducerMetadata_Value `protobuf_oneof:"value"`
   762  }
   763  
   764  func (m *RemoteProducerMetadata) Reset()         { *m = RemoteProducerMetadata{} }
   765  func (m *RemoteProducerMetadata) String() string { return proto.CompactTextString(m) }
   766  func (*RemoteProducerMetadata) ProtoMessage()    {}
   767  func (*RemoteProducerMetadata) Descriptor() ([]byte, []int) {
   768  	return fileDescriptor_data_b1be9c010247b5f4, []int{10}
   769  }
   770  func (m *RemoteProducerMetadata) XXX_Unmarshal(b []byte) error {
   771  	return m.Unmarshal(b)
   772  }
   773  func (m *RemoteProducerMetadata) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   774  	b = b[:cap(b)]
   775  	n, err := m.MarshalTo(b)
   776  	if err != nil {
   777  		return nil, err
   778  	}
   779  	return b[:n], nil
   780  }
   781  func (dst *RemoteProducerMetadata) XXX_Merge(src proto.Message) {
   782  	xxx_messageInfo_RemoteProducerMetadata.Merge(dst, src)
   783  }
   784  func (m *RemoteProducerMetadata) XXX_Size() int {
   785  	return m.Size()
   786  }
   787  func (m *RemoteProducerMetadata) XXX_DiscardUnknown() {
   788  	xxx_messageInfo_RemoteProducerMetadata.DiscardUnknown(m)
   789  }
   790  
   791  var xxx_messageInfo_RemoteProducerMetadata proto.InternalMessageInfo
   792  
   793  type isRemoteProducerMetadata_Value interface {
   794  	isRemoteProducerMetadata_Value()
   795  	MarshalTo([]byte) (int, error)
   796  	Size() int
   797  }
   798  
   799  type RemoteProducerMetadata_RangeInfo struct {
   800  	RangeInfo *RemoteProducerMetadata_RangeInfos `protobuf:"bytes,1,opt,name=range_info,json=rangeInfo,oneof"`
   801  }
   802  type RemoteProducerMetadata_Error struct {
   803  	Error *Error `protobuf:"bytes,2,opt,name=error,oneof"`
   804  }
   805  type RemoteProducerMetadata_TraceData_ struct {
   806  	TraceData *RemoteProducerMetadata_TraceData `protobuf:"bytes,3,opt,name=trace_data,json=traceData,oneof"`
   807  }
   808  type RemoteProducerMetadata_LeafTxnFinalState struct {
   809  	LeafTxnFinalState *roachpb.LeafTxnFinalState `protobuf:"bytes,4,opt,name=leaf_txn_final_state,json=leafTxnFinalState,oneof"`
   810  }
   811  type RemoteProducerMetadata_RowNum_ struct {
   812  	RowNum *RemoteProducerMetadata_RowNum `protobuf:"bytes,5,opt,name=row_num,json=rowNum,oneof"`
   813  }
   814  type RemoteProducerMetadata_SamplerProgress_ struct {
   815  	SamplerProgress *RemoteProducerMetadata_SamplerProgress `protobuf:"bytes,7,opt,name=sampler_progress,json=samplerProgress,oneof"`
   816  }
   817  type RemoteProducerMetadata_Metrics_ struct {
   818  	Metrics *RemoteProducerMetadata_Metrics `protobuf:"bytes,8,opt,name=metrics,oneof"`
   819  }
   820  type RemoteProducerMetadata_BulkProcessorProgress_ struct {
   821  	BulkProcessorProgress *RemoteProducerMetadata_BulkProcessorProgress `protobuf:"bytes,9,opt,name=bulk_processor_progress,json=bulkProcessorProgress,oneof"`
   822  }
   823  
   824  func (*RemoteProducerMetadata_RangeInfo) isRemoteProducerMetadata_Value()              {}
   825  func (*RemoteProducerMetadata_Error) isRemoteProducerMetadata_Value()                  {}
   826  func (*RemoteProducerMetadata_TraceData_) isRemoteProducerMetadata_Value()             {}
   827  func (*RemoteProducerMetadata_LeafTxnFinalState) isRemoteProducerMetadata_Value()      {}
   828  func (*RemoteProducerMetadata_RowNum_) isRemoteProducerMetadata_Value()                {}
   829  func (*RemoteProducerMetadata_SamplerProgress_) isRemoteProducerMetadata_Value()       {}
   830  func (*RemoteProducerMetadata_Metrics_) isRemoteProducerMetadata_Value()               {}
   831  func (*RemoteProducerMetadata_BulkProcessorProgress_) isRemoteProducerMetadata_Value() {}
   832  
   833  func (m *RemoteProducerMetadata) GetValue() isRemoteProducerMetadata_Value {
   834  	if m != nil {
   835  		return m.Value
   836  	}
   837  	return nil
   838  }
   839  
   840  func (m *RemoteProducerMetadata) GetRangeInfo() *RemoteProducerMetadata_RangeInfos {
   841  	if x, ok := m.GetValue().(*RemoteProducerMetadata_RangeInfo); ok {
   842  		return x.RangeInfo
   843  	}
   844  	return nil
   845  }
   846  
   847  func (m *RemoteProducerMetadata) GetError() *Error {
   848  	if x, ok := m.GetValue().(*RemoteProducerMetadata_Error); ok {
   849  		return x.Error
   850  	}
   851  	return nil
   852  }
   853  
   854  func (m *RemoteProducerMetadata) GetTraceData() *RemoteProducerMetadata_TraceData {
   855  	if x, ok := m.GetValue().(*RemoteProducerMetadata_TraceData_); ok {
   856  		return x.TraceData
   857  	}
   858  	return nil
   859  }
   860  
   861  func (m *RemoteProducerMetadata) GetLeafTxnFinalState() *roachpb.LeafTxnFinalState {
   862  	if x, ok := m.GetValue().(*RemoteProducerMetadata_LeafTxnFinalState); ok {
   863  		return x.LeafTxnFinalState
   864  	}
   865  	return nil
   866  }
   867  
   868  func (m *RemoteProducerMetadata) GetRowNum() *RemoteProducerMetadata_RowNum {
   869  	if x, ok := m.GetValue().(*RemoteProducerMetadata_RowNum_); ok {
   870  		return x.RowNum
   871  	}
   872  	return nil
   873  }
   874  
   875  func (m *RemoteProducerMetadata) GetSamplerProgress() *RemoteProducerMetadata_SamplerProgress {
   876  	if x, ok := m.GetValue().(*RemoteProducerMetadata_SamplerProgress_); ok {
   877  		return x.SamplerProgress
   878  	}
   879  	return nil
   880  }
   881  
   882  func (m *RemoteProducerMetadata) GetMetrics() *RemoteProducerMetadata_Metrics {
   883  	if x, ok := m.GetValue().(*RemoteProducerMetadata_Metrics_); ok {
   884  		return x.Metrics
   885  	}
   886  	return nil
   887  }
   888  
   889  func (m *RemoteProducerMetadata) GetBulkProcessorProgress() *RemoteProducerMetadata_BulkProcessorProgress {
   890  	if x, ok := m.GetValue().(*RemoteProducerMetadata_BulkProcessorProgress_); ok {
   891  		return x.BulkProcessorProgress
   892  	}
   893  	return nil
   894  }
   895  
   896  // XXX_OneofFuncs is for the internal use of the proto package.
   897  func (*RemoteProducerMetadata) 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{}) {
   898  	return _RemoteProducerMetadata_OneofMarshaler, _RemoteProducerMetadata_OneofUnmarshaler, _RemoteProducerMetadata_OneofSizer, []interface{}{
   899  		(*RemoteProducerMetadata_RangeInfo)(nil),
   900  		(*RemoteProducerMetadata_Error)(nil),
   901  		(*RemoteProducerMetadata_TraceData_)(nil),
   902  		(*RemoteProducerMetadata_LeafTxnFinalState)(nil),
   903  		(*RemoteProducerMetadata_RowNum_)(nil),
   904  		(*RemoteProducerMetadata_SamplerProgress_)(nil),
   905  		(*RemoteProducerMetadata_Metrics_)(nil),
   906  		(*RemoteProducerMetadata_BulkProcessorProgress_)(nil),
   907  	}
   908  }
   909  
   910  func _RemoteProducerMetadata_OneofMarshaler(msg proto.Message, b *proto.Buffer) error {
   911  	m := msg.(*RemoteProducerMetadata)
   912  	// value
   913  	switch x := m.Value.(type) {
   914  	case *RemoteProducerMetadata_RangeInfo:
   915  		_ = b.EncodeVarint(1<<3 | proto.WireBytes)
   916  		if err := b.EncodeMessage(x.RangeInfo); err != nil {
   917  			return err
   918  		}
   919  	case *RemoteProducerMetadata_Error:
   920  		_ = b.EncodeVarint(2<<3 | proto.WireBytes)
   921  		if err := b.EncodeMessage(x.Error); err != nil {
   922  			return err
   923  		}
   924  	case *RemoteProducerMetadata_TraceData_:
   925  		_ = b.EncodeVarint(3<<3 | proto.WireBytes)
   926  		if err := b.EncodeMessage(x.TraceData); err != nil {
   927  			return err
   928  		}
   929  	case *RemoteProducerMetadata_LeafTxnFinalState:
   930  		_ = b.EncodeVarint(4<<3 | proto.WireBytes)
   931  		if err := b.EncodeMessage(x.LeafTxnFinalState); err != nil {
   932  			return err
   933  		}
   934  	case *RemoteProducerMetadata_RowNum_:
   935  		_ = b.EncodeVarint(5<<3 | proto.WireBytes)
   936  		if err := b.EncodeMessage(x.RowNum); err != nil {
   937  			return err
   938  		}
   939  	case *RemoteProducerMetadata_SamplerProgress_:
   940  		_ = b.EncodeVarint(7<<3 | proto.WireBytes)
   941  		if err := b.EncodeMessage(x.SamplerProgress); err != nil {
   942  			return err
   943  		}
   944  	case *RemoteProducerMetadata_Metrics_:
   945  		_ = b.EncodeVarint(8<<3 | proto.WireBytes)
   946  		if err := b.EncodeMessage(x.Metrics); err != nil {
   947  			return err
   948  		}
   949  	case *RemoteProducerMetadata_BulkProcessorProgress_:
   950  		_ = b.EncodeVarint(9<<3 | proto.WireBytes)
   951  		if err := b.EncodeMessage(x.BulkProcessorProgress); err != nil {
   952  			return err
   953  		}
   954  	case nil:
   955  	default:
   956  		return fmt.Errorf("RemoteProducerMetadata.Value has unexpected type %T", x)
   957  	}
   958  	return nil
   959  }
   960  
   961  func _RemoteProducerMetadata_OneofUnmarshaler(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error) {
   962  	m := msg.(*RemoteProducerMetadata)
   963  	switch tag {
   964  	case 1: // value.range_info
   965  		if wire != proto.WireBytes {
   966  			return true, proto.ErrInternalBadWireType
   967  		}
   968  		msg := new(RemoteProducerMetadata_RangeInfos)
   969  		err := b.DecodeMessage(msg)
   970  		m.Value = &RemoteProducerMetadata_RangeInfo{msg}
   971  		return true, err
   972  	case 2: // value.error
   973  		if wire != proto.WireBytes {
   974  			return true, proto.ErrInternalBadWireType
   975  		}
   976  		msg := new(Error)
   977  		err := b.DecodeMessage(msg)
   978  		m.Value = &RemoteProducerMetadata_Error{msg}
   979  		return true, err
   980  	case 3: // value.trace_data
   981  		if wire != proto.WireBytes {
   982  			return true, proto.ErrInternalBadWireType
   983  		}
   984  		msg := new(RemoteProducerMetadata_TraceData)
   985  		err := b.DecodeMessage(msg)
   986  		m.Value = &RemoteProducerMetadata_TraceData_{msg}
   987  		return true, err
   988  	case 4: // value.leaf_txn_final_state
   989  		if wire != proto.WireBytes {
   990  			return true, proto.ErrInternalBadWireType
   991  		}
   992  		msg := new(roachpb.LeafTxnFinalState)
   993  		err := b.DecodeMessage(msg)
   994  		m.Value = &RemoteProducerMetadata_LeafTxnFinalState{msg}
   995  		return true, err
   996  	case 5: // value.row_num
   997  		if wire != proto.WireBytes {
   998  			return true, proto.ErrInternalBadWireType
   999  		}
  1000  		msg := new(RemoteProducerMetadata_RowNum)
  1001  		err := b.DecodeMessage(msg)
  1002  		m.Value = &RemoteProducerMetadata_RowNum_{msg}
  1003  		return true, err
  1004  	case 7: // value.sampler_progress
  1005  		if wire != proto.WireBytes {
  1006  			return true, proto.ErrInternalBadWireType
  1007  		}
  1008  		msg := new(RemoteProducerMetadata_SamplerProgress)
  1009  		err := b.DecodeMessage(msg)
  1010  		m.Value = &RemoteProducerMetadata_SamplerProgress_{msg}
  1011  		return true, err
  1012  	case 8: // value.metrics
  1013  		if wire != proto.WireBytes {
  1014  			return true, proto.ErrInternalBadWireType
  1015  		}
  1016  		msg := new(RemoteProducerMetadata_Metrics)
  1017  		err := b.DecodeMessage(msg)
  1018  		m.Value = &RemoteProducerMetadata_Metrics_{msg}
  1019  		return true, err
  1020  	case 9: // value.bulk_processor_progress
  1021  		if wire != proto.WireBytes {
  1022  			return true, proto.ErrInternalBadWireType
  1023  		}
  1024  		msg := new(RemoteProducerMetadata_BulkProcessorProgress)
  1025  		err := b.DecodeMessage(msg)
  1026  		m.Value = &RemoteProducerMetadata_BulkProcessorProgress_{msg}
  1027  		return true, err
  1028  	default:
  1029  		return false, nil
  1030  	}
  1031  }
  1032  
  1033  func _RemoteProducerMetadata_OneofSizer(msg proto.Message) (n int) {
  1034  	m := msg.(*RemoteProducerMetadata)
  1035  	// value
  1036  	switch x := m.Value.(type) {
  1037  	case *RemoteProducerMetadata_RangeInfo:
  1038  		s := proto.Size(x.RangeInfo)
  1039  		n += 1 // tag and wire
  1040  		n += proto.SizeVarint(uint64(s))
  1041  		n += s
  1042  	case *RemoteProducerMetadata_Error:
  1043  		s := proto.Size(x.Error)
  1044  		n += 1 // tag and wire
  1045  		n += proto.SizeVarint(uint64(s))
  1046  		n += s
  1047  	case *RemoteProducerMetadata_TraceData_:
  1048  		s := proto.Size(x.TraceData)
  1049  		n += 1 // tag and wire
  1050  		n += proto.SizeVarint(uint64(s))
  1051  		n += s
  1052  	case *RemoteProducerMetadata_LeafTxnFinalState:
  1053  		s := proto.Size(x.LeafTxnFinalState)
  1054  		n += 1 // tag and wire
  1055  		n += proto.SizeVarint(uint64(s))
  1056  		n += s
  1057  	case *RemoteProducerMetadata_RowNum_:
  1058  		s := proto.Size(x.RowNum)
  1059  		n += 1 // tag and wire
  1060  		n += proto.SizeVarint(uint64(s))
  1061  		n += s
  1062  	case *RemoteProducerMetadata_SamplerProgress_:
  1063  		s := proto.Size(x.SamplerProgress)
  1064  		n += 1 // tag and wire
  1065  		n += proto.SizeVarint(uint64(s))
  1066  		n += s
  1067  	case *RemoteProducerMetadata_Metrics_:
  1068  		s := proto.Size(x.Metrics)
  1069  		n += 1 // tag and wire
  1070  		n += proto.SizeVarint(uint64(s))
  1071  		n += s
  1072  	case *RemoteProducerMetadata_BulkProcessorProgress_:
  1073  		s := proto.Size(x.BulkProcessorProgress)
  1074  		n += 1 // tag and wire
  1075  		n += proto.SizeVarint(uint64(s))
  1076  		n += s
  1077  	case nil:
  1078  	default:
  1079  		panic(fmt.Sprintf("proto: unexpected type %T in oneof", x))
  1080  	}
  1081  	return n
  1082  }
  1083  
  1084  type RemoteProducerMetadata_RangeInfos struct {
  1085  	RangeInfo []roachpb.RangeInfo `protobuf:"bytes,1,rep,name=range_info,json=rangeInfo" json:"range_info"`
  1086  }
  1087  
  1088  func (m *RemoteProducerMetadata_RangeInfos) Reset()         { *m = RemoteProducerMetadata_RangeInfos{} }
  1089  func (m *RemoteProducerMetadata_RangeInfos) String() string { return proto.CompactTextString(m) }
  1090  func (*RemoteProducerMetadata_RangeInfos) ProtoMessage()    {}
  1091  func (*RemoteProducerMetadata_RangeInfos) Descriptor() ([]byte, []int) {
  1092  	return fileDescriptor_data_b1be9c010247b5f4, []int{10, 0}
  1093  }
  1094  func (m *RemoteProducerMetadata_RangeInfos) XXX_Unmarshal(b []byte) error {
  1095  	return m.Unmarshal(b)
  1096  }
  1097  func (m *RemoteProducerMetadata_RangeInfos) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1098  	b = b[:cap(b)]
  1099  	n, err := m.MarshalTo(b)
  1100  	if err != nil {
  1101  		return nil, err
  1102  	}
  1103  	return b[:n], nil
  1104  }
  1105  func (dst *RemoteProducerMetadata_RangeInfos) XXX_Merge(src proto.Message) {
  1106  	xxx_messageInfo_RemoteProducerMetadata_RangeInfos.Merge(dst, src)
  1107  }
  1108  func (m *RemoteProducerMetadata_RangeInfos) XXX_Size() int {
  1109  	return m.Size()
  1110  }
  1111  func (m *RemoteProducerMetadata_RangeInfos) XXX_DiscardUnknown() {
  1112  	xxx_messageInfo_RemoteProducerMetadata_RangeInfos.DiscardUnknown(m)
  1113  }
  1114  
  1115  var xxx_messageInfo_RemoteProducerMetadata_RangeInfos proto.InternalMessageInfo
  1116  
  1117  type RemoteProducerMetadata_TraceData struct {
  1118  	CollectedSpans []tracing.RecordedSpan `protobuf:"bytes,1,rep,name=collected_spans,json=collectedSpans" json:"collected_spans"`
  1119  }
  1120  
  1121  func (m *RemoteProducerMetadata_TraceData) Reset()         { *m = RemoteProducerMetadata_TraceData{} }
  1122  func (m *RemoteProducerMetadata_TraceData) String() string { return proto.CompactTextString(m) }
  1123  func (*RemoteProducerMetadata_TraceData) ProtoMessage()    {}
  1124  func (*RemoteProducerMetadata_TraceData) Descriptor() ([]byte, []int) {
  1125  	return fileDescriptor_data_b1be9c010247b5f4, []int{10, 1}
  1126  }
  1127  func (m *RemoteProducerMetadata_TraceData) XXX_Unmarshal(b []byte) error {
  1128  	return m.Unmarshal(b)
  1129  }
  1130  func (m *RemoteProducerMetadata_TraceData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1131  	b = b[:cap(b)]
  1132  	n, err := m.MarshalTo(b)
  1133  	if err != nil {
  1134  		return nil, err
  1135  	}
  1136  	return b[:n], nil
  1137  }
  1138  func (dst *RemoteProducerMetadata_TraceData) XXX_Merge(src proto.Message) {
  1139  	xxx_messageInfo_RemoteProducerMetadata_TraceData.Merge(dst, src)
  1140  }
  1141  func (m *RemoteProducerMetadata_TraceData) XXX_Size() int {
  1142  	return m.Size()
  1143  }
  1144  func (m *RemoteProducerMetadata_TraceData) XXX_DiscardUnknown() {
  1145  	xxx_messageInfo_RemoteProducerMetadata_TraceData.DiscardUnknown(m)
  1146  }
  1147  
  1148  var xxx_messageInfo_RemoteProducerMetadata_TraceData proto.InternalMessageInfo
  1149  
  1150  // RowNum is used to count the rows sent from a processor. It is used in tests
  1151  // to check that metadata is propagated correctly.
  1152  type RemoteProducerMetadata_RowNum struct {
  1153  	// The ID of the processor that is producing rows.
  1154  	SenderID string `protobuf:"bytes,1,opt,name=sender_id,json=senderId" json:"sender_id"`
  1155  	// A running count of the number of rows emitted from the sender so far.
  1156  	RowNum int32 `protobuf:"varint,2,opt,name=row_num,json=rowNum" json:"row_num"`
  1157  	// When set, indicates that the row count contains the expected number of
  1158  	// RowNum messages with this ID.
  1159  	LastMsg bool `protobuf:"varint,3,opt,name=last_msg,json=lastMsg" json:"last_msg"`
  1160  }
  1161  
  1162  func (m *RemoteProducerMetadata_RowNum) Reset()         { *m = RemoteProducerMetadata_RowNum{} }
  1163  func (m *RemoteProducerMetadata_RowNum) String() string { return proto.CompactTextString(m) }
  1164  func (*RemoteProducerMetadata_RowNum) ProtoMessage()    {}
  1165  func (*RemoteProducerMetadata_RowNum) Descriptor() ([]byte, []int) {
  1166  	return fileDescriptor_data_b1be9c010247b5f4, []int{10, 2}
  1167  }
  1168  func (m *RemoteProducerMetadata_RowNum) XXX_Unmarshal(b []byte) error {
  1169  	return m.Unmarshal(b)
  1170  }
  1171  func (m *RemoteProducerMetadata_RowNum) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1172  	b = b[:cap(b)]
  1173  	n, err := m.MarshalTo(b)
  1174  	if err != nil {
  1175  		return nil, err
  1176  	}
  1177  	return b[:n], nil
  1178  }
  1179  func (dst *RemoteProducerMetadata_RowNum) XXX_Merge(src proto.Message) {
  1180  	xxx_messageInfo_RemoteProducerMetadata_RowNum.Merge(dst, src)
  1181  }
  1182  func (m *RemoteProducerMetadata_RowNum) XXX_Size() int {
  1183  	return m.Size()
  1184  }
  1185  func (m *RemoteProducerMetadata_RowNum) XXX_DiscardUnknown() {
  1186  	xxx_messageInfo_RemoteProducerMetadata_RowNum.DiscardUnknown(m)
  1187  }
  1188  
  1189  var xxx_messageInfo_RemoteProducerMetadata_RowNum proto.InternalMessageInfo
  1190  
  1191  type RemoteProducerMetadata_SamplerProgress struct {
  1192  	// The number of rows processed by the sampler processor since the last
  1193  	// update.
  1194  	RowsProcessed uint64 `protobuf:"varint,1,opt,name=rows_processed,json=rowsProcessed" json:"rows_processed"`
  1195  	// Indicates that sample collection for histograms should be disabled,
  1196  	// likely because the sampler processor ran out of memory.
  1197  	HistogramDisabled bool `protobuf:"varint,2,opt,name=histogram_disabled,json=histogramDisabled" json:"histogram_disabled"`
  1198  }
  1199  
  1200  func (m *RemoteProducerMetadata_SamplerProgress) Reset() {
  1201  	*m = RemoteProducerMetadata_SamplerProgress{}
  1202  }
  1203  func (m *RemoteProducerMetadata_SamplerProgress) String() string { return proto.CompactTextString(m) }
  1204  func (*RemoteProducerMetadata_SamplerProgress) ProtoMessage()    {}
  1205  func (*RemoteProducerMetadata_SamplerProgress) Descriptor() ([]byte, []int) {
  1206  	return fileDescriptor_data_b1be9c010247b5f4, []int{10, 3}
  1207  }
  1208  func (m *RemoteProducerMetadata_SamplerProgress) XXX_Unmarshal(b []byte) error {
  1209  	return m.Unmarshal(b)
  1210  }
  1211  func (m *RemoteProducerMetadata_SamplerProgress) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1212  	b = b[:cap(b)]
  1213  	n, err := m.MarshalTo(b)
  1214  	if err != nil {
  1215  		return nil, err
  1216  	}
  1217  	return b[:n], nil
  1218  }
  1219  func (dst *RemoteProducerMetadata_SamplerProgress) XXX_Merge(src proto.Message) {
  1220  	xxx_messageInfo_RemoteProducerMetadata_SamplerProgress.Merge(dst, src)
  1221  }
  1222  func (m *RemoteProducerMetadata_SamplerProgress) XXX_Size() int {
  1223  	return m.Size()
  1224  }
  1225  func (m *RemoteProducerMetadata_SamplerProgress) XXX_DiscardUnknown() {
  1226  	xxx_messageInfo_RemoteProducerMetadata_SamplerProgress.DiscardUnknown(m)
  1227  }
  1228  
  1229  var xxx_messageInfo_RemoteProducerMetadata_SamplerProgress proto.InternalMessageInfo
  1230  
  1231  type RemoteProducerMetadata_BulkProcessorProgress struct {
  1232  	CompletedSpans    []roachpb.Span    `protobuf:"bytes,1,rep,name=completed_spans,json=completedSpans" json:"completed_spans"`
  1233  	CompletedFraction map[int32]float32 `protobuf:"bytes,2,rep,name=completed_fraction,json=completedFraction" json:"completed_fraction,omitempty" protobuf_key:"varint,1,opt,name=key" protobuf_val:"fixed32,2,opt,name=value"`
  1234  	ResumePos         map[int32]int64   `protobuf:"bytes,3,rep,name=resume_pos,json=resumePos" json:"resume_pos,omitempty" protobuf_key:"varint,1,opt,name=key" protobuf_val:"varint,2,opt,name=value"`
  1235  }
  1236  
  1237  func (m *RemoteProducerMetadata_BulkProcessorProgress) Reset() {
  1238  	*m = RemoteProducerMetadata_BulkProcessorProgress{}
  1239  }
  1240  func (m *RemoteProducerMetadata_BulkProcessorProgress) String() string {
  1241  	return proto.CompactTextString(m)
  1242  }
  1243  func (*RemoteProducerMetadata_BulkProcessorProgress) ProtoMessage() {}
  1244  func (*RemoteProducerMetadata_BulkProcessorProgress) Descriptor() ([]byte, []int) {
  1245  	return fileDescriptor_data_b1be9c010247b5f4, []int{10, 4}
  1246  }
  1247  func (m *RemoteProducerMetadata_BulkProcessorProgress) XXX_Unmarshal(b []byte) error {
  1248  	return m.Unmarshal(b)
  1249  }
  1250  func (m *RemoteProducerMetadata_BulkProcessorProgress) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1251  	b = b[:cap(b)]
  1252  	n, err := m.MarshalTo(b)
  1253  	if err != nil {
  1254  		return nil, err
  1255  	}
  1256  	return b[:n], nil
  1257  }
  1258  func (dst *RemoteProducerMetadata_BulkProcessorProgress) XXX_Merge(src proto.Message) {
  1259  	xxx_messageInfo_RemoteProducerMetadata_BulkProcessorProgress.Merge(dst, src)
  1260  }
  1261  func (m *RemoteProducerMetadata_BulkProcessorProgress) XXX_Size() int {
  1262  	return m.Size()
  1263  }
  1264  func (m *RemoteProducerMetadata_BulkProcessorProgress) XXX_DiscardUnknown() {
  1265  	xxx_messageInfo_RemoteProducerMetadata_BulkProcessorProgress.DiscardUnknown(m)
  1266  }
  1267  
  1268  var xxx_messageInfo_RemoteProducerMetadata_BulkProcessorProgress proto.InternalMessageInfo
  1269  
  1270  // Metrics are unconditionally emitted by table readers.
  1271  type RemoteProducerMetadata_Metrics struct {
  1272  	// Total number of bytes read while executing a statement.
  1273  	BytesRead int64 `protobuf:"varint,1,opt,name=bytes_read,json=bytesRead" json:"bytes_read"`
  1274  	// Total number of rows read while executing a statement.
  1275  	RowsRead int64 `protobuf:"varint,2,opt,name=rows_read,json=rowsRead" json:"rows_read"`
  1276  }
  1277  
  1278  func (m *RemoteProducerMetadata_Metrics) Reset()         { *m = RemoteProducerMetadata_Metrics{} }
  1279  func (m *RemoteProducerMetadata_Metrics) String() string { return proto.CompactTextString(m) }
  1280  func (*RemoteProducerMetadata_Metrics) ProtoMessage()    {}
  1281  func (*RemoteProducerMetadata_Metrics) Descriptor() ([]byte, []int) {
  1282  	return fileDescriptor_data_b1be9c010247b5f4, []int{10, 5}
  1283  }
  1284  func (m *RemoteProducerMetadata_Metrics) XXX_Unmarshal(b []byte) error {
  1285  	return m.Unmarshal(b)
  1286  }
  1287  func (m *RemoteProducerMetadata_Metrics) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1288  	b = b[:cap(b)]
  1289  	n, err := m.MarshalTo(b)
  1290  	if err != nil {
  1291  		return nil, err
  1292  	}
  1293  	return b[:n], nil
  1294  }
  1295  func (dst *RemoteProducerMetadata_Metrics) XXX_Merge(src proto.Message) {
  1296  	xxx_messageInfo_RemoteProducerMetadata_Metrics.Merge(dst, src)
  1297  }
  1298  func (m *RemoteProducerMetadata_Metrics) XXX_Size() int {
  1299  	return m.Size()
  1300  }
  1301  func (m *RemoteProducerMetadata_Metrics) XXX_DiscardUnknown() {
  1302  	xxx_messageInfo_RemoteProducerMetadata_Metrics.DiscardUnknown(m)
  1303  }
  1304  
  1305  var xxx_messageInfo_RemoteProducerMetadata_Metrics proto.InternalMessageInfo
  1306  
  1307  // DistSQLVersionGossipInfo represents the DistSQL server version information
  1308  // that gets gossiped for each node. This is used by planners to avoid planning
  1309  // on nodes with incompatible version during rolling cluster updates.
  1310  //
  1311  // For the meaning of the fields, see the corresponding constants in
  1312  // distsqlrun/server.go.
  1313  type DistSQLVersionGossipInfo struct {
  1314  	Version            DistSQLVersion `protobuf:"varint,1,opt,name=version,casttype=DistSQLVersion" json:"version"`
  1315  	MinAcceptedVersion DistSQLVersion `protobuf:"varint,2,opt,name=min_accepted_version,json=minAcceptedVersion,casttype=DistSQLVersion" json:"min_accepted_version"`
  1316  }
  1317  
  1318  func (m *DistSQLVersionGossipInfo) Reset()         { *m = DistSQLVersionGossipInfo{} }
  1319  func (m *DistSQLVersionGossipInfo) String() string { return proto.CompactTextString(m) }
  1320  func (*DistSQLVersionGossipInfo) ProtoMessage()    {}
  1321  func (*DistSQLVersionGossipInfo) Descriptor() ([]byte, []int) {
  1322  	return fileDescriptor_data_b1be9c010247b5f4, []int{11}
  1323  }
  1324  func (m *DistSQLVersionGossipInfo) XXX_Unmarshal(b []byte) error {
  1325  	return m.Unmarshal(b)
  1326  }
  1327  func (m *DistSQLVersionGossipInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1328  	b = b[:cap(b)]
  1329  	n, err := m.MarshalTo(b)
  1330  	if err != nil {
  1331  		return nil, err
  1332  	}
  1333  	return b[:n], nil
  1334  }
  1335  func (dst *DistSQLVersionGossipInfo) XXX_Merge(src proto.Message) {
  1336  	xxx_messageInfo_DistSQLVersionGossipInfo.Merge(dst, src)
  1337  }
  1338  func (m *DistSQLVersionGossipInfo) XXX_Size() int {
  1339  	return m.Size()
  1340  }
  1341  func (m *DistSQLVersionGossipInfo) XXX_DiscardUnknown() {
  1342  	xxx_messageInfo_DistSQLVersionGossipInfo.DiscardUnknown(m)
  1343  }
  1344  
  1345  var xxx_messageInfo_DistSQLVersionGossipInfo proto.InternalMessageInfo
  1346  
  1347  // DistSQLDrainingInfo represents the DistSQL draining state that gets gossiped
  1348  // for each node. This is used by planners to avoid planning on nodes that are
  1349  // known to be draining.
  1350  type DistSQLDrainingInfo struct {
  1351  	Draining bool `protobuf:"varint,1,opt,name=draining" json:"draining"`
  1352  }
  1353  
  1354  func (m *DistSQLDrainingInfo) Reset()         { *m = DistSQLDrainingInfo{} }
  1355  func (m *DistSQLDrainingInfo) String() string { return proto.CompactTextString(m) }
  1356  func (*DistSQLDrainingInfo) ProtoMessage()    {}
  1357  func (*DistSQLDrainingInfo) Descriptor() ([]byte, []int) {
  1358  	return fileDescriptor_data_b1be9c010247b5f4, []int{12}
  1359  }
  1360  func (m *DistSQLDrainingInfo) XXX_Unmarshal(b []byte) error {
  1361  	return m.Unmarshal(b)
  1362  }
  1363  func (m *DistSQLDrainingInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
  1364  	b = b[:cap(b)]
  1365  	n, err := m.MarshalTo(b)
  1366  	if err != nil {
  1367  		return nil, err
  1368  	}
  1369  	return b[:n], nil
  1370  }
  1371  func (dst *DistSQLDrainingInfo) XXX_Merge(src proto.Message) {
  1372  	xxx_messageInfo_DistSQLDrainingInfo.Merge(dst, src)
  1373  }
  1374  func (m *DistSQLDrainingInfo) XXX_Size() int {
  1375  	return m.Size()
  1376  }
  1377  func (m *DistSQLDrainingInfo) XXX_DiscardUnknown() {
  1378  	xxx_messageInfo_DistSQLDrainingInfo.DiscardUnknown(m)
  1379  }
  1380  
  1381  var xxx_messageInfo_DistSQLDrainingInfo proto.InternalMessageInfo
  1382  
  1383  func init() {
  1384  	proto.RegisterType((*Error)(nil), "cockroach.sql.distsqlrun.Error")
  1385  	proto.RegisterType((*Expression)(nil), "cockroach.sql.distsqlrun.Expression")
  1386  	proto.RegisterType((*Ordering)(nil), "cockroach.sql.distsqlrun.Ordering")
  1387  	proto.RegisterType((*Ordering_Column)(nil), "cockroach.sql.distsqlrun.Ordering.Column")
  1388  	proto.RegisterType((*StreamEndpointSpec)(nil), "cockroach.sql.distsqlrun.StreamEndpointSpec")
  1389  	proto.RegisterType((*InputSyncSpec)(nil), "cockroach.sql.distsqlrun.InputSyncSpec")
  1390  	proto.RegisterType((*OutputRouterSpec)(nil), "cockroach.sql.distsqlrun.OutputRouterSpec")
  1391  	proto.RegisterType((*OutputRouterSpec_RangeRouterSpec)(nil), "cockroach.sql.distsqlrun.OutputRouterSpec.RangeRouterSpec")
  1392  	proto.RegisterType((*OutputRouterSpec_RangeRouterSpec_ColumnEncoding)(nil), "cockroach.sql.distsqlrun.OutputRouterSpec.RangeRouterSpec.ColumnEncoding")
  1393  	proto.RegisterType((*OutputRouterSpec_RangeRouterSpec_Span)(nil), "cockroach.sql.distsqlrun.OutputRouterSpec.RangeRouterSpec.Span")
  1394  	proto.RegisterType((*DatumInfo)(nil), "cockroach.sql.distsqlrun.DatumInfo")
  1395  	proto.RegisterType((*ProducerHeader)(nil), "cockroach.sql.distsqlrun.ProducerHeader")
  1396  	proto.RegisterType((*ProducerData)(nil), "cockroach.sql.distsqlrun.ProducerData")
  1397  	proto.RegisterType((*ProducerMessage)(nil), "cockroach.sql.distsqlrun.ProducerMessage")
  1398  	proto.RegisterType((*RemoteProducerMetadata)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata")
  1399  	proto.RegisterType((*RemoteProducerMetadata_RangeInfos)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.RangeInfos")
  1400  	proto.RegisterType((*RemoteProducerMetadata_TraceData)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.TraceData")
  1401  	proto.RegisterType((*RemoteProducerMetadata_RowNum)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.RowNum")
  1402  	proto.RegisterType((*RemoteProducerMetadata_SamplerProgress)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.SamplerProgress")
  1403  	proto.RegisterType((*RemoteProducerMetadata_BulkProcessorProgress)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.BulkProcessorProgress")
  1404  	proto.RegisterMapType((map[int32]float32)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.BulkProcessorProgress.CompletedFractionEntry")
  1405  	proto.RegisterMapType((map[int32]int64)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.BulkProcessorProgress.ResumePosEntry")
  1406  	proto.RegisterType((*RemoteProducerMetadata_Metrics)(nil), "cockroach.sql.distsqlrun.RemoteProducerMetadata.Metrics")
  1407  	proto.RegisterType((*DistSQLVersionGossipInfo)(nil), "cockroach.sql.distsqlrun.DistSQLVersionGossipInfo")
  1408  	proto.RegisterType((*DistSQLDrainingInfo)(nil), "cockroach.sql.distsqlrun.DistSQLDrainingInfo")
  1409  	proto.RegisterEnum("cockroach.sql.distsqlrun.Ordering_Column_Direction", Ordering_Column_Direction_name, Ordering_Column_Direction_value)
  1410  	proto.RegisterEnum("cockroach.sql.distsqlrun.StreamEndpointSpec_Type", StreamEndpointSpec_Type_name, StreamEndpointSpec_Type_value)
  1411  	proto.RegisterEnum("cockroach.sql.distsqlrun.InputSyncSpec_Type", InputSyncSpec_Type_name, InputSyncSpec_Type_value)
  1412  	proto.RegisterEnum("cockroach.sql.distsqlrun.OutputRouterSpec_Type", OutputRouterSpec_Type_name, OutputRouterSpec_Type_value)
  1413  }
  1414  func (this *Ordering) Equal(that interface{}) bool {
  1415  	if that == nil {
  1416  		return this == nil
  1417  	}
  1418  
  1419  	that1, ok := that.(*Ordering)
  1420  	if !ok {
  1421  		that2, ok := that.(Ordering)
  1422  		if ok {
  1423  			that1 = &that2
  1424  		} else {
  1425  			return false
  1426  		}
  1427  	}
  1428  	if that1 == nil {
  1429  		return this == nil
  1430  	} else if this == nil {
  1431  		return false
  1432  	}
  1433  	if len(this.Columns) != len(that1.Columns) {
  1434  		return false
  1435  	}
  1436  	for i := range this.Columns {
  1437  		if !this.Columns[i].Equal(&that1.Columns[i]) {
  1438  			return false
  1439  		}
  1440  	}
  1441  	return true
  1442  }
  1443  func (this *Ordering_Column) Equal(that interface{}) bool {
  1444  	if that == nil {
  1445  		return this == nil
  1446  	}
  1447  
  1448  	that1, ok := that.(*Ordering_Column)
  1449  	if !ok {
  1450  		that2, ok := that.(Ordering_Column)
  1451  		if ok {
  1452  			that1 = &that2
  1453  		} else {
  1454  			return false
  1455  		}
  1456  	}
  1457  	if that1 == nil {
  1458  		return this == nil
  1459  	} else if this == nil {
  1460  		return false
  1461  	}
  1462  	if this.ColIdx != that1.ColIdx {
  1463  		return false
  1464  	}
  1465  	if this.Direction != that1.Direction {
  1466  		return false
  1467  	}
  1468  	return true
  1469  }
  1470  func (m *Error) Marshal() (dAtA []byte, err error) {
  1471  	size := m.Size()
  1472  	dAtA = make([]byte, size)
  1473  	n, err := m.MarshalTo(dAtA)
  1474  	if err != nil {
  1475  		return nil, err
  1476  	}
  1477  	return dAtA[:n], nil
  1478  }
  1479  
  1480  func (m *Error) MarshalTo(dAtA []byte) (int, error) {
  1481  	var i int
  1482  	_ = i
  1483  	var l int
  1484  	_ = l
  1485  	if m.FullError != nil {
  1486  		dAtA[i] = 0x1a
  1487  		i++
  1488  		i = encodeVarintData(dAtA, i, uint64(m.FullError.Size()))
  1489  		n1, err := m.FullError.MarshalTo(dAtA[i:])
  1490  		if err != nil {
  1491  			return 0, err
  1492  		}
  1493  		i += n1
  1494  	}
  1495  	return i, nil
  1496  }
  1497  
  1498  func (m *Expression) Marshal() (dAtA []byte, err error) {
  1499  	size := m.Size()
  1500  	dAtA = make([]byte, size)
  1501  	n, err := m.MarshalTo(dAtA)
  1502  	if err != nil {
  1503  		return nil, err
  1504  	}
  1505  	return dAtA[:n], nil
  1506  }
  1507  
  1508  func (m *Expression) MarshalTo(dAtA []byte) (int, error) {
  1509  	var i int
  1510  	_ = i
  1511  	var l int
  1512  	_ = l
  1513  	dAtA[i] = 0xa
  1514  	i++
  1515  	i = encodeVarintData(dAtA, i, uint64(len(m.Version)))
  1516  	i += copy(dAtA[i:], m.Version)
  1517  	dAtA[i] = 0x12
  1518  	i++
  1519  	i = encodeVarintData(dAtA, i, uint64(len(m.Expr)))
  1520  	i += copy(dAtA[i:], m.Expr)
  1521  	return i, nil
  1522  }
  1523  
  1524  func (m *Ordering) Marshal() (dAtA []byte, err error) {
  1525  	size := m.Size()
  1526  	dAtA = make([]byte, size)
  1527  	n, err := m.MarshalTo(dAtA)
  1528  	if err != nil {
  1529  		return nil, err
  1530  	}
  1531  	return dAtA[:n], nil
  1532  }
  1533  
  1534  func (m *Ordering) MarshalTo(dAtA []byte) (int, error) {
  1535  	var i int
  1536  	_ = i
  1537  	var l int
  1538  	_ = l
  1539  	if len(m.Columns) > 0 {
  1540  		for _, msg := range m.Columns {
  1541  			dAtA[i] = 0xa
  1542  			i++
  1543  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1544  			n, err := msg.MarshalTo(dAtA[i:])
  1545  			if err != nil {
  1546  				return 0, err
  1547  			}
  1548  			i += n
  1549  		}
  1550  	}
  1551  	return i, nil
  1552  }
  1553  
  1554  func (m *Ordering_Column) Marshal() (dAtA []byte, err error) {
  1555  	size := m.Size()
  1556  	dAtA = make([]byte, size)
  1557  	n, err := m.MarshalTo(dAtA)
  1558  	if err != nil {
  1559  		return nil, err
  1560  	}
  1561  	return dAtA[:n], nil
  1562  }
  1563  
  1564  func (m *Ordering_Column) MarshalTo(dAtA []byte) (int, error) {
  1565  	var i int
  1566  	_ = i
  1567  	var l int
  1568  	_ = l
  1569  	dAtA[i] = 0x8
  1570  	i++
  1571  	i = encodeVarintData(dAtA, i, uint64(m.ColIdx))
  1572  	dAtA[i] = 0x10
  1573  	i++
  1574  	i = encodeVarintData(dAtA, i, uint64(m.Direction))
  1575  	return i, nil
  1576  }
  1577  
  1578  func (m *StreamEndpointSpec) Marshal() (dAtA []byte, err error) {
  1579  	size := m.Size()
  1580  	dAtA = make([]byte, size)
  1581  	n, err := m.MarshalTo(dAtA)
  1582  	if err != nil {
  1583  		return nil, err
  1584  	}
  1585  	return dAtA[:n], nil
  1586  }
  1587  
  1588  func (m *StreamEndpointSpec) MarshalTo(dAtA []byte) (int, error) {
  1589  	var i int
  1590  	_ = i
  1591  	var l int
  1592  	_ = l
  1593  	dAtA[i] = 0x8
  1594  	i++
  1595  	i = encodeVarintData(dAtA, i, uint64(m.Type))
  1596  	dAtA[i] = 0x10
  1597  	i++
  1598  	i = encodeVarintData(dAtA, i, uint64(m.StreamID))
  1599  	dAtA[i] = 0x20
  1600  	i++
  1601  	i = encodeVarintData(dAtA, i, uint64(m.TargetNodeID))
  1602  	return i, nil
  1603  }
  1604  
  1605  func (m *InputSyncSpec) Marshal() (dAtA []byte, err error) {
  1606  	size := m.Size()
  1607  	dAtA = make([]byte, size)
  1608  	n, err := m.MarshalTo(dAtA)
  1609  	if err != nil {
  1610  		return nil, err
  1611  	}
  1612  	return dAtA[:n], nil
  1613  }
  1614  
  1615  func (m *InputSyncSpec) MarshalTo(dAtA []byte) (int, error) {
  1616  	var i int
  1617  	_ = i
  1618  	var l int
  1619  	_ = l
  1620  	dAtA[i] = 0x8
  1621  	i++
  1622  	i = encodeVarintData(dAtA, i, uint64(m.Type))
  1623  	dAtA[i] = 0x12
  1624  	i++
  1625  	i = encodeVarintData(dAtA, i, uint64(m.Ordering.Size()))
  1626  	n2, err := m.Ordering.MarshalTo(dAtA[i:])
  1627  	if err != nil {
  1628  		return 0, err
  1629  	}
  1630  	i += n2
  1631  	if len(m.Streams) > 0 {
  1632  		for _, msg := range m.Streams {
  1633  			dAtA[i] = 0x1a
  1634  			i++
  1635  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1636  			n, err := msg.MarshalTo(dAtA[i:])
  1637  			if err != nil {
  1638  				return 0, err
  1639  			}
  1640  			i += n
  1641  		}
  1642  	}
  1643  	if len(m.ColumnTypes) > 0 {
  1644  		for _, msg := range m.ColumnTypes {
  1645  			dAtA[i] = 0x22
  1646  			i++
  1647  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1648  			n, err := msg.MarshalTo(dAtA[i:])
  1649  			if err != nil {
  1650  				return 0, err
  1651  			}
  1652  			i += n
  1653  		}
  1654  	}
  1655  	return i, nil
  1656  }
  1657  
  1658  func (m *OutputRouterSpec) Marshal() (dAtA []byte, err error) {
  1659  	size := m.Size()
  1660  	dAtA = make([]byte, size)
  1661  	n, err := m.MarshalTo(dAtA)
  1662  	if err != nil {
  1663  		return nil, err
  1664  	}
  1665  	return dAtA[:n], nil
  1666  }
  1667  
  1668  func (m *OutputRouterSpec) MarshalTo(dAtA []byte) (int, error) {
  1669  	var i int
  1670  	_ = i
  1671  	var l int
  1672  	_ = l
  1673  	dAtA[i] = 0x8
  1674  	i++
  1675  	i = encodeVarintData(dAtA, i, uint64(m.Type))
  1676  	if len(m.Streams) > 0 {
  1677  		for _, msg := range m.Streams {
  1678  			dAtA[i] = 0x12
  1679  			i++
  1680  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1681  			n, err := msg.MarshalTo(dAtA[i:])
  1682  			if err != nil {
  1683  				return 0, err
  1684  			}
  1685  			i += n
  1686  		}
  1687  	}
  1688  	if len(m.HashColumns) > 0 {
  1689  		for _, num := range m.HashColumns {
  1690  			dAtA[i] = 0x18
  1691  			i++
  1692  			i = encodeVarintData(dAtA, i, uint64(num))
  1693  		}
  1694  	}
  1695  	dAtA[i] = 0x22
  1696  	i++
  1697  	i = encodeVarintData(dAtA, i, uint64(m.RangeRouterSpec.Size()))
  1698  	n3, err := m.RangeRouterSpec.MarshalTo(dAtA[i:])
  1699  	if err != nil {
  1700  		return 0, err
  1701  	}
  1702  	i += n3
  1703  	dAtA[i] = 0x28
  1704  	i++
  1705  	if m.DisableBuffering {
  1706  		dAtA[i] = 1
  1707  	} else {
  1708  		dAtA[i] = 0
  1709  	}
  1710  	i++
  1711  	return i, nil
  1712  }
  1713  
  1714  func (m *OutputRouterSpec_RangeRouterSpec) Marshal() (dAtA []byte, err error) {
  1715  	size := m.Size()
  1716  	dAtA = make([]byte, size)
  1717  	n, err := m.MarshalTo(dAtA)
  1718  	if err != nil {
  1719  		return nil, err
  1720  	}
  1721  	return dAtA[:n], nil
  1722  }
  1723  
  1724  func (m *OutputRouterSpec_RangeRouterSpec) MarshalTo(dAtA []byte) (int, error) {
  1725  	var i int
  1726  	_ = i
  1727  	var l int
  1728  	_ = l
  1729  	if len(m.Spans) > 0 {
  1730  		for _, msg := range m.Spans {
  1731  			dAtA[i] = 0xa
  1732  			i++
  1733  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1734  			n, err := msg.MarshalTo(dAtA[i:])
  1735  			if err != nil {
  1736  				return 0, err
  1737  			}
  1738  			i += n
  1739  		}
  1740  	}
  1741  	if m.DefaultDest != nil {
  1742  		dAtA[i] = 0x10
  1743  		i++
  1744  		i = encodeVarintData(dAtA, i, uint64(*m.DefaultDest))
  1745  	}
  1746  	if len(m.Encodings) > 0 {
  1747  		for _, msg := range m.Encodings {
  1748  			dAtA[i] = 0x1a
  1749  			i++
  1750  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1751  			n, err := msg.MarshalTo(dAtA[i:])
  1752  			if err != nil {
  1753  				return 0, err
  1754  			}
  1755  			i += n
  1756  		}
  1757  	}
  1758  	return i, nil
  1759  }
  1760  
  1761  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Marshal() (dAtA []byte, err error) {
  1762  	size := m.Size()
  1763  	dAtA = make([]byte, size)
  1764  	n, err := m.MarshalTo(dAtA)
  1765  	if err != nil {
  1766  		return nil, err
  1767  	}
  1768  	return dAtA[:n], nil
  1769  }
  1770  
  1771  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) MarshalTo(dAtA []byte) (int, error) {
  1772  	var i int
  1773  	_ = i
  1774  	var l int
  1775  	_ = l
  1776  	dAtA[i] = 0x8
  1777  	i++
  1778  	i = encodeVarintData(dAtA, i, uint64(m.Column))
  1779  	dAtA[i] = 0x10
  1780  	i++
  1781  	i = encodeVarintData(dAtA, i, uint64(m.Encoding))
  1782  	return i, nil
  1783  }
  1784  
  1785  func (m *OutputRouterSpec_RangeRouterSpec_Span) Marshal() (dAtA []byte, err error) {
  1786  	size := m.Size()
  1787  	dAtA = make([]byte, size)
  1788  	n, err := m.MarshalTo(dAtA)
  1789  	if err != nil {
  1790  		return nil, err
  1791  	}
  1792  	return dAtA[:n], nil
  1793  }
  1794  
  1795  func (m *OutputRouterSpec_RangeRouterSpec_Span) MarshalTo(dAtA []byte) (int, error) {
  1796  	var i int
  1797  	_ = i
  1798  	var l int
  1799  	_ = l
  1800  	if m.Start != nil {
  1801  		dAtA[i] = 0xa
  1802  		i++
  1803  		i = encodeVarintData(dAtA, i, uint64(len(m.Start)))
  1804  		i += copy(dAtA[i:], m.Start)
  1805  	}
  1806  	if m.End != nil {
  1807  		dAtA[i] = 0x12
  1808  		i++
  1809  		i = encodeVarintData(dAtA, i, uint64(len(m.End)))
  1810  		i += copy(dAtA[i:], m.End)
  1811  	}
  1812  	dAtA[i] = 0x18
  1813  	i++
  1814  	i = encodeVarintData(dAtA, i, uint64(m.Stream))
  1815  	return i, nil
  1816  }
  1817  
  1818  func (m *DatumInfo) Marshal() (dAtA []byte, err error) {
  1819  	size := m.Size()
  1820  	dAtA = make([]byte, size)
  1821  	n, err := m.MarshalTo(dAtA)
  1822  	if err != nil {
  1823  		return nil, err
  1824  	}
  1825  	return dAtA[:n], nil
  1826  }
  1827  
  1828  func (m *DatumInfo) MarshalTo(dAtA []byte) (int, error) {
  1829  	var i int
  1830  	_ = i
  1831  	var l int
  1832  	_ = l
  1833  	dAtA[i] = 0x8
  1834  	i++
  1835  	i = encodeVarintData(dAtA, i, uint64(m.Encoding))
  1836  	if m.Type != nil {
  1837  		dAtA[i] = 0x12
  1838  		i++
  1839  		i = encodeVarintData(dAtA, i, uint64(m.Type.Size()))
  1840  		n4, err := m.Type.MarshalTo(dAtA[i:])
  1841  		if err != nil {
  1842  			return 0, err
  1843  		}
  1844  		i += n4
  1845  	}
  1846  	return i, nil
  1847  }
  1848  
  1849  func (m *ProducerHeader) Marshal() (dAtA []byte, err error) {
  1850  	size := m.Size()
  1851  	dAtA = make([]byte, size)
  1852  	n, err := m.MarshalTo(dAtA)
  1853  	if err != nil {
  1854  		return nil, err
  1855  	}
  1856  	return dAtA[:n], nil
  1857  }
  1858  
  1859  func (m *ProducerHeader) MarshalTo(dAtA []byte) (int, error) {
  1860  	var i int
  1861  	_ = i
  1862  	var l int
  1863  	_ = l
  1864  	dAtA[i] = 0xa
  1865  	i++
  1866  	i = encodeVarintData(dAtA, i, uint64(m.FlowID.Size()))
  1867  	n5, err := m.FlowID.MarshalTo(dAtA[i:])
  1868  	if err != nil {
  1869  		return 0, err
  1870  	}
  1871  	i += n5
  1872  	dAtA[i] = 0x10
  1873  	i++
  1874  	i = encodeVarintData(dAtA, i, uint64(m.StreamID))
  1875  	return i, nil
  1876  }
  1877  
  1878  func (m *ProducerData) Marshal() (dAtA []byte, err error) {
  1879  	size := m.Size()
  1880  	dAtA = make([]byte, size)
  1881  	n, err := m.MarshalTo(dAtA)
  1882  	if err != nil {
  1883  		return nil, err
  1884  	}
  1885  	return dAtA[:n], nil
  1886  }
  1887  
  1888  func (m *ProducerData) MarshalTo(dAtA []byte) (int, error) {
  1889  	var i int
  1890  	_ = i
  1891  	var l int
  1892  	_ = l
  1893  	if m.RawBytes != nil {
  1894  		dAtA[i] = 0xa
  1895  		i++
  1896  		i = encodeVarintData(dAtA, i, uint64(len(m.RawBytes)))
  1897  		i += copy(dAtA[i:], m.RawBytes)
  1898  	}
  1899  	if len(m.Metadata) > 0 {
  1900  		for _, msg := range m.Metadata {
  1901  			dAtA[i] = 0x12
  1902  			i++
  1903  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1904  			n, err := msg.MarshalTo(dAtA[i:])
  1905  			if err != nil {
  1906  				return 0, err
  1907  			}
  1908  			i += n
  1909  		}
  1910  	}
  1911  	dAtA[i] = 0x18
  1912  	i++
  1913  	i = encodeVarintData(dAtA, i, uint64(m.NumEmptyRows))
  1914  	return i, nil
  1915  }
  1916  
  1917  func (m *ProducerMessage) Marshal() (dAtA []byte, err error) {
  1918  	size := m.Size()
  1919  	dAtA = make([]byte, size)
  1920  	n, err := m.MarshalTo(dAtA)
  1921  	if err != nil {
  1922  		return nil, err
  1923  	}
  1924  	return dAtA[:n], nil
  1925  }
  1926  
  1927  func (m *ProducerMessage) MarshalTo(dAtA []byte) (int, error) {
  1928  	var i int
  1929  	_ = i
  1930  	var l int
  1931  	_ = l
  1932  	if m.Header != nil {
  1933  		dAtA[i] = 0xa
  1934  		i++
  1935  		i = encodeVarintData(dAtA, i, uint64(m.Header.Size()))
  1936  		n6, err := m.Header.MarshalTo(dAtA[i:])
  1937  		if err != nil {
  1938  			return 0, err
  1939  		}
  1940  		i += n6
  1941  	}
  1942  	if len(m.Typing) > 0 {
  1943  		for _, msg := range m.Typing {
  1944  			dAtA[i] = 0x12
  1945  			i++
  1946  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  1947  			n, err := msg.MarshalTo(dAtA[i:])
  1948  			if err != nil {
  1949  				return 0, err
  1950  			}
  1951  			i += n
  1952  		}
  1953  	}
  1954  	dAtA[i] = 0x1a
  1955  	i++
  1956  	i = encodeVarintData(dAtA, i, uint64(m.Data.Size()))
  1957  	n7, err := m.Data.MarshalTo(dAtA[i:])
  1958  	if err != nil {
  1959  		return 0, err
  1960  	}
  1961  	i += n7
  1962  	return i, nil
  1963  }
  1964  
  1965  func (m *RemoteProducerMetadata) Marshal() (dAtA []byte, err error) {
  1966  	size := m.Size()
  1967  	dAtA = make([]byte, size)
  1968  	n, err := m.MarshalTo(dAtA)
  1969  	if err != nil {
  1970  		return nil, err
  1971  	}
  1972  	return dAtA[:n], nil
  1973  }
  1974  
  1975  func (m *RemoteProducerMetadata) MarshalTo(dAtA []byte) (int, error) {
  1976  	var i int
  1977  	_ = i
  1978  	var l int
  1979  	_ = l
  1980  	if m.Value != nil {
  1981  		nn8, err := m.Value.MarshalTo(dAtA[i:])
  1982  		if err != nil {
  1983  			return 0, err
  1984  		}
  1985  		i += nn8
  1986  	}
  1987  	return i, nil
  1988  }
  1989  
  1990  func (m *RemoteProducerMetadata_RangeInfo) MarshalTo(dAtA []byte) (int, error) {
  1991  	i := 0
  1992  	if m.RangeInfo != nil {
  1993  		dAtA[i] = 0xa
  1994  		i++
  1995  		i = encodeVarintData(dAtA, i, uint64(m.RangeInfo.Size()))
  1996  		n9, err := m.RangeInfo.MarshalTo(dAtA[i:])
  1997  		if err != nil {
  1998  			return 0, err
  1999  		}
  2000  		i += n9
  2001  	}
  2002  	return i, nil
  2003  }
  2004  func (m *RemoteProducerMetadata_Error) MarshalTo(dAtA []byte) (int, error) {
  2005  	i := 0
  2006  	if m.Error != nil {
  2007  		dAtA[i] = 0x12
  2008  		i++
  2009  		i = encodeVarintData(dAtA, i, uint64(m.Error.Size()))
  2010  		n10, err := m.Error.MarshalTo(dAtA[i:])
  2011  		if err != nil {
  2012  			return 0, err
  2013  		}
  2014  		i += n10
  2015  	}
  2016  	return i, nil
  2017  }
  2018  func (m *RemoteProducerMetadata_TraceData_) MarshalTo(dAtA []byte) (int, error) {
  2019  	i := 0
  2020  	if m.TraceData != nil {
  2021  		dAtA[i] = 0x1a
  2022  		i++
  2023  		i = encodeVarintData(dAtA, i, uint64(m.TraceData.Size()))
  2024  		n11, err := m.TraceData.MarshalTo(dAtA[i:])
  2025  		if err != nil {
  2026  			return 0, err
  2027  		}
  2028  		i += n11
  2029  	}
  2030  	return i, nil
  2031  }
  2032  func (m *RemoteProducerMetadata_LeafTxnFinalState) MarshalTo(dAtA []byte) (int, error) {
  2033  	i := 0
  2034  	if m.LeafTxnFinalState != nil {
  2035  		dAtA[i] = 0x22
  2036  		i++
  2037  		i = encodeVarintData(dAtA, i, uint64(m.LeafTxnFinalState.Size()))
  2038  		n12, err := m.LeafTxnFinalState.MarshalTo(dAtA[i:])
  2039  		if err != nil {
  2040  			return 0, err
  2041  		}
  2042  		i += n12
  2043  	}
  2044  	return i, nil
  2045  }
  2046  func (m *RemoteProducerMetadata_RowNum_) MarshalTo(dAtA []byte) (int, error) {
  2047  	i := 0
  2048  	if m.RowNum != nil {
  2049  		dAtA[i] = 0x2a
  2050  		i++
  2051  		i = encodeVarintData(dAtA, i, uint64(m.RowNum.Size()))
  2052  		n13, err := m.RowNum.MarshalTo(dAtA[i:])
  2053  		if err != nil {
  2054  			return 0, err
  2055  		}
  2056  		i += n13
  2057  	}
  2058  	return i, nil
  2059  }
  2060  func (m *RemoteProducerMetadata_SamplerProgress_) MarshalTo(dAtA []byte) (int, error) {
  2061  	i := 0
  2062  	if m.SamplerProgress != nil {
  2063  		dAtA[i] = 0x3a
  2064  		i++
  2065  		i = encodeVarintData(dAtA, i, uint64(m.SamplerProgress.Size()))
  2066  		n14, err := m.SamplerProgress.MarshalTo(dAtA[i:])
  2067  		if err != nil {
  2068  			return 0, err
  2069  		}
  2070  		i += n14
  2071  	}
  2072  	return i, nil
  2073  }
  2074  func (m *RemoteProducerMetadata_Metrics_) MarshalTo(dAtA []byte) (int, error) {
  2075  	i := 0
  2076  	if m.Metrics != nil {
  2077  		dAtA[i] = 0x42
  2078  		i++
  2079  		i = encodeVarintData(dAtA, i, uint64(m.Metrics.Size()))
  2080  		n15, err := m.Metrics.MarshalTo(dAtA[i:])
  2081  		if err != nil {
  2082  			return 0, err
  2083  		}
  2084  		i += n15
  2085  	}
  2086  	return i, nil
  2087  }
  2088  func (m *RemoteProducerMetadata_BulkProcessorProgress_) MarshalTo(dAtA []byte) (int, error) {
  2089  	i := 0
  2090  	if m.BulkProcessorProgress != nil {
  2091  		dAtA[i] = 0x4a
  2092  		i++
  2093  		i = encodeVarintData(dAtA, i, uint64(m.BulkProcessorProgress.Size()))
  2094  		n16, err := m.BulkProcessorProgress.MarshalTo(dAtA[i:])
  2095  		if err != nil {
  2096  			return 0, err
  2097  		}
  2098  		i += n16
  2099  	}
  2100  	return i, nil
  2101  }
  2102  func (m *RemoteProducerMetadata_RangeInfos) Marshal() (dAtA []byte, err error) {
  2103  	size := m.Size()
  2104  	dAtA = make([]byte, size)
  2105  	n, err := m.MarshalTo(dAtA)
  2106  	if err != nil {
  2107  		return nil, err
  2108  	}
  2109  	return dAtA[:n], nil
  2110  }
  2111  
  2112  func (m *RemoteProducerMetadata_RangeInfos) MarshalTo(dAtA []byte) (int, error) {
  2113  	var i int
  2114  	_ = i
  2115  	var l int
  2116  	_ = l
  2117  	if len(m.RangeInfo) > 0 {
  2118  		for _, msg := range m.RangeInfo {
  2119  			dAtA[i] = 0xa
  2120  			i++
  2121  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  2122  			n, err := msg.MarshalTo(dAtA[i:])
  2123  			if err != nil {
  2124  				return 0, err
  2125  			}
  2126  			i += n
  2127  		}
  2128  	}
  2129  	return i, nil
  2130  }
  2131  
  2132  func (m *RemoteProducerMetadata_TraceData) Marshal() (dAtA []byte, err error) {
  2133  	size := m.Size()
  2134  	dAtA = make([]byte, size)
  2135  	n, err := m.MarshalTo(dAtA)
  2136  	if err != nil {
  2137  		return nil, err
  2138  	}
  2139  	return dAtA[:n], nil
  2140  }
  2141  
  2142  func (m *RemoteProducerMetadata_TraceData) MarshalTo(dAtA []byte) (int, error) {
  2143  	var i int
  2144  	_ = i
  2145  	var l int
  2146  	_ = l
  2147  	if len(m.CollectedSpans) > 0 {
  2148  		for _, msg := range m.CollectedSpans {
  2149  			dAtA[i] = 0xa
  2150  			i++
  2151  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  2152  			n, err := msg.MarshalTo(dAtA[i:])
  2153  			if err != nil {
  2154  				return 0, err
  2155  			}
  2156  			i += n
  2157  		}
  2158  	}
  2159  	return i, nil
  2160  }
  2161  
  2162  func (m *RemoteProducerMetadata_RowNum) Marshal() (dAtA []byte, err error) {
  2163  	size := m.Size()
  2164  	dAtA = make([]byte, size)
  2165  	n, err := m.MarshalTo(dAtA)
  2166  	if err != nil {
  2167  		return nil, err
  2168  	}
  2169  	return dAtA[:n], nil
  2170  }
  2171  
  2172  func (m *RemoteProducerMetadata_RowNum) MarshalTo(dAtA []byte) (int, error) {
  2173  	var i int
  2174  	_ = i
  2175  	var l int
  2176  	_ = l
  2177  	dAtA[i] = 0xa
  2178  	i++
  2179  	i = encodeVarintData(dAtA, i, uint64(len(m.SenderID)))
  2180  	i += copy(dAtA[i:], m.SenderID)
  2181  	dAtA[i] = 0x10
  2182  	i++
  2183  	i = encodeVarintData(dAtA, i, uint64(m.RowNum))
  2184  	dAtA[i] = 0x18
  2185  	i++
  2186  	if m.LastMsg {
  2187  		dAtA[i] = 1
  2188  	} else {
  2189  		dAtA[i] = 0
  2190  	}
  2191  	i++
  2192  	return i, nil
  2193  }
  2194  
  2195  func (m *RemoteProducerMetadata_SamplerProgress) Marshal() (dAtA []byte, err error) {
  2196  	size := m.Size()
  2197  	dAtA = make([]byte, size)
  2198  	n, err := m.MarshalTo(dAtA)
  2199  	if err != nil {
  2200  		return nil, err
  2201  	}
  2202  	return dAtA[:n], nil
  2203  }
  2204  
  2205  func (m *RemoteProducerMetadata_SamplerProgress) MarshalTo(dAtA []byte) (int, error) {
  2206  	var i int
  2207  	_ = i
  2208  	var l int
  2209  	_ = l
  2210  	dAtA[i] = 0x8
  2211  	i++
  2212  	i = encodeVarintData(dAtA, i, uint64(m.RowsProcessed))
  2213  	dAtA[i] = 0x10
  2214  	i++
  2215  	if m.HistogramDisabled {
  2216  		dAtA[i] = 1
  2217  	} else {
  2218  		dAtA[i] = 0
  2219  	}
  2220  	i++
  2221  	return i, nil
  2222  }
  2223  
  2224  func (m *RemoteProducerMetadata_BulkProcessorProgress) Marshal() (dAtA []byte, err error) {
  2225  	size := m.Size()
  2226  	dAtA = make([]byte, size)
  2227  	n, err := m.MarshalTo(dAtA)
  2228  	if err != nil {
  2229  		return nil, err
  2230  	}
  2231  	return dAtA[:n], nil
  2232  }
  2233  
  2234  func (m *RemoteProducerMetadata_BulkProcessorProgress) MarshalTo(dAtA []byte) (int, error) {
  2235  	var i int
  2236  	_ = i
  2237  	var l int
  2238  	_ = l
  2239  	if len(m.CompletedSpans) > 0 {
  2240  		for _, msg := range m.CompletedSpans {
  2241  			dAtA[i] = 0xa
  2242  			i++
  2243  			i = encodeVarintData(dAtA, i, uint64(msg.Size()))
  2244  			n, err := msg.MarshalTo(dAtA[i:])
  2245  			if err != nil {
  2246  				return 0, err
  2247  			}
  2248  			i += n
  2249  		}
  2250  	}
  2251  	if len(m.CompletedFraction) > 0 {
  2252  		keysForCompletedFraction := make([]int32, 0, len(m.CompletedFraction))
  2253  		for k := range m.CompletedFraction {
  2254  			keysForCompletedFraction = append(keysForCompletedFraction, int32(k))
  2255  		}
  2256  		github_com_gogo_protobuf_sortkeys.Int32s(keysForCompletedFraction)
  2257  		for _, k := range keysForCompletedFraction {
  2258  			dAtA[i] = 0x12
  2259  			i++
  2260  			v := m.CompletedFraction[int32(k)]
  2261  			mapSize := 1 + sovData(uint64(k)) + 1 + 4
  2262  			i = encodeVarintData(dAtA, i, uint64(mapSize))
  2263  			dAtA[i] = 0x8
  2264  			i++
  2265  			i = encodeVarintData(dAtA, i, uint64(k))
  2266  			dAtA[i] = 0x15
  2267  			i++
  2268  			encoding_binary.LittleEndian.PutUint32(dAtA[i:], uint32(math.Float32bits(float32(v))))
  2269  			i += 4
  2270  		}
  2271  	}
  2272  	if len(m.ResumePos) > 0 {
  2273  		keysForResumePos := make([]int32, 0, len(m.ResumePos))
  2274  		for k := range m.ResumePos {
  2275  			keysForResumePos = append(keysForResumePos, int32(k))
  2276  		}
  2277  		github_com_gogo_protobuf_sortkeys.Int32s(keysForResumePos)
  2278  		for _, k := range keysForResumePos {
  2279  			dAtA[i] = 0x1a
  2280  			i++
  2281  			v := m.ResumePos[int32(k)]
  2282  			mapSize := 1 + sovData(uint64(k)) + 1 + sovData(uint64(v))
  2283  			i = encodeVarintData(dAtA, i, uint64(mapSize))
  2284  			dAtA[i] = 0x8
  2285  			i++
  2286  			i = encodeVarintData(dAtA, i, uint64(k))
  2287  			dAtA[i] = 0x10
  2288  			i++
  2289  			i = encodeVarintData(dAtA, i, uint64(v))
  2290  		}
  2291  	}
  2292  	return i, nil
  2293  }
  2294  
  2295  func (m *RemoteProducerMetadata_Metrics) Marshal() (dAtA []byte, err error) {
  2296  	size := m.Size()
  2297  	dAtA = make([]byte, size)
  2298  	n, err := m.MarshalTo(dAtA)
  2299  	if err != nil {
  2300  		return nil, err
  2301  	}
  2302  	return dAtA[:n], nil
  2303  }
  2304  
  2305  func (m *RemoteProducerMetadata_Metrics) MarshalTo(dAtA []byte) (int, error) {
  2306  	var i int
  2307  	_ = i
  2308  	var l int
  2309  	_ = l
  2310  	dAtA[i] = 0x8
  2311  	i++
  2312  	i = encodeVarintData(dAtA, i, uint64(m.BytesRead))
  2313  	dAtA[i] = 0x10
  2314  	i++
  2315  	i = encodeVarintData(dAtA, i, uint64(m.RowsRead))
  2316  	return i, nil
  2317  }
  2318  
  2319  func (m *DistSQLVersionGossipInfo) Marshal() (dAtA []byte, err error) {
  2320  	size := m.Size()
  2321  	dAtA = make([]byte, size)
  2322  	n, err := m.MarshalTo(dAtA)
  2323  	if err != nil {
  2324  		return nil, err
  2325  	}
  2326  	return dAtA[:n], nil
  2327  }
  2328  
  2329  func (m *DistSQLVersionGossipInfo) MarshalTo(dAtA []byte) (int, error) {
  2330  	var i int
  2331  	_ = i
  2332  	var l int
  2333  	_ = l
  2334  	dAtA[i] = 0x8
  2335  	i++
  2336  	i = encodeVarintData(dAtA, i, uint64(m.Version))
  2337  	dAtA[i] = 0x10
  2338  	i++
  2339  	i = encodeVarintData(dAtA, i, uint64(m.MinAcceptedVersion))
  2340  	return i, nil
  2341  }
  2342  
  2343  func (m *DistSQLDrainingInfo) Marshal() (dAtA []byte, err error) {
  2344  	size := m.Size()
  2345  	dAtA = make([]byte, size)
  2346  	n, err := m.MarshalTo(dAtA)
  2347  	if err != nil {
  2348  		return nil, err
  2349  	}
  2350  	return dAtA[:n], nil
  2351  }
  2352  
  2353  func (m *DistSQLDrainingInfo) MarshalTo(dAtA []byte) (int, error) {
  2354  	var i int
  2355  	_ = i
  2356  	var l int
  2357  	_ = l
  2358  	dAtA[i] = 0x8
  2359  	i++
  2360  	if m.Draining {
  2361  		dAtA[i] = 1
  2362  	} else {
  2363  		dAtA[i] = 0
  2364  	}
  2365  	i++
  2366  	return i, nil
  2367  }
  2368  
  2369  func encodeVarintData(dAtA []byte, offset int, v uint64) int {
  2370  	for v >= 1<<7 {
  2371  		dAtA[offset] = uint8(v&0x7f | 0x80)
  2372  		v >>= 7
  2373  		offset++
  2374  	}
  2375  	dAtA[offset] = uint8(v)
  2376  	return offset + 1
  2377  }
  2378  func (m *Error) Size() (n int) {
  2379  	if m == nil {
  2380  		return 0
  2381  	}
  2382  	var l int
  2383  	_ = l
  2384  	if m.FullError != nil {
  2385  		l = m.FullError.Size()
  2386  		n += 1 + l + sovData(uint64(l))
  2387  	}
  2388  	return n
  2389  }
  2390  
  2391  func (m *Expression) Size() (n int) {
  2392  	if m == nil {
  2393  		return 0
  2394  	}
  2395  	var l int
  2396  	_ = l
  2397  	l = len(m.Version)
  2398  	n += 1 + l + sovData(uint64(l))
  2399  	l = len(m.Expr)
  2400  	n += 1 + l + sovData(uint64(l))
  2401  	return n
  2402  }
  2403  
  2404  func (m *Ordering) Size() (n int) {
  2405  	if m == nil {
  2406  		return 0
  2407  	}
  2408  	var l int
  2409  	_ = l
  2410  	if len(m.Columns) > 0 {
  2411  		for _, e := range m.Columns {
  2412  			l = e.Size()
  2413  			n += 1 + l + sovData(uint64(l))
  2414  		}
  2415  	}
  2416  	return n
  2417  }
  2418  
  2419  func (m *Ordering_Column) Size() (n int) {
  2420  	if m == nil {
  2421  		return 0
  2422  	}
  2423  	var l int
  2424  	_ = l
  2425  	n += 1 + sovData(uint64(m.ColIdx))
  2426  	n += 1 + sovData(uint64(m.Direction))
  2427  	return n
  2428  }
  2429  
  2430  func (m *StreamEndpointSpec) Size() (n int) {
  2431  	if m == nil {
  2432  		return 0
  2433  	}
  2434  	var l int
  2435  	_ = l
  2436  	n += 1 + sovData(uint64(m.Type))
  2437  	n += 1 + sovData(uint64(m.StreamID))
  2438  	n += 1 + sovData(uint64(m.TargetNodeID))
  2439  	return n
  2440  }
  2441  
  2442  func (m *InputSyncSpec) Size() (n int) {
  2443  	if m == nil {
  2444  		return 0
  2445  	}
  2446  	var l int
  2447  	_ = l
  2448  	n += 1 + sovData(uint64(m.Type))
  2449  	l = m.Ordering.Size()
  2450  	n += 1 + l + sovData(uint64(l))
  2451  	if len(m.Streams) > 0 {
  2452  		for _, e := range m.Streams {
  2453  			l = e.Size()
  2454  			n += 1 + l + sovData(uint64(l))
  2455  		}
  2456  	}
  2457  	if len(m.ColumnTypes) > 0 {
  2458  		for _, e := range m.ColumnTypes {
  2459  			l = e.Size()
  2460  			n += 1 + l + sovData(uint64(l))
  2461  		}
  2462  	}
  2463  	return n
  2464  }
  2465  
  2466  func (m *OutputRouterSpec) Size() (n int) {
  2467  	if m == nil {
  2468  		return 0
  2469  	}
  2470  	var l int
  2471  	_ = l
  2472  	n += 1 + sovData(uint64(m.Type))
  2473  	if len(m.Streams) > 0 {
  2474  		for _, e := range m.Streams {
  2475  			l = e.Size()
  2476  			n += 1 + l + sovData(uint64(l))
  2477  		}
  2478  	}
  2479  	if len(m.HashColumns) > 0 {
  2480  		for _, e := range m.HashColumns {
  2481  			n += 1 + sovData(uint64(e))
  2482  		}
  2483  	}
  2484  	l = m.RangeRouterSpec.Size()
  2485  	n += 1 + l + sovData(uint64(l))
  2486  	n += 2
  2487  	return n
  2488  }
  2489  
  2490  func (m *OutputRouterSpec_RangeRouterSpec) Size() (n int) {
  2491  	if m == nil {
  2492  		return 0
  2493  	}
  2494  	var l int
  2495  	_ = l
  2496  	if len(m.Spans) > 0 {
  2497  		for _, e := range m.Spans {
  2498  			l = e.Size()
  2499  			n += 1 + l + sovData(uint64(l))
  2500  		}
  2501  	}
  2502  	if m.DefaultDest != nil {
  2503  		n += 1 + sovData(uint64(*m.DefaultDest))
  2504  	}
  2505  	if len(m.Encodings) > 0 {
  2506  		for _, e := range m.Encodings {
  2507  			l = e.Size()
  2508  			n += 1 + l + sovData(uint64(l))
  2509  		}
  2510  	}
  2511  	return n
  2512  }
  2513  
  2514  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Size() (n int) {
  2515  	if m == nil {
  2516  		return 0
  2517  	}
  2518  	var l int
  2519  	_ = l
  2520  	n += 1 + sovData(uint64(m.Column))
  2521  	n += 1 + sovData(uint64(m.Encoding))
  2522  	return n
  2523  }
  2524  
  2525  func (m *OutputRouterSpec_RangeRouterSpec_Span) Size() (n int) {
  2526  	if m == nil {
  2527  		return 0
  2528  	}
  2529  	var l int
  2530  	_ = l
  2531  	if m.Start != nil {
  2532  		l = len(m.Start)
  2533  		n += 1 + l + sovData(uint64(l))
  2534  	}
  2535  	if m.End != nil {
  2536  		l = len(m.End)
  2537  		n += 1 + l + sovData(uint64(l))
  2538  	}
  2539  	n += 1 + sovData(uint64(m.Stream))
  2540  	return n
  2541  }
  2542  
  2543  func (m *DatumInfo) Size() (n int) {
  2544  	if m == nil {
  2545  		return 0
  2546  	}
  2547  	var l int
  2548  	_ = l
  2549  	n += 1 + sovData(uint64(m.Encoding))
  2550  	if m.Type != nil {
  2551  		l = m.Type.Size()
  2552  		n += 1 + l + sovData(uint64(l))
  2553  	}
  2554  	return n
  2555  }
  2556  
  2557  func (m *ProducerHeader) Size() (n int) {
  2558  	if m == nil {
  2559  		return 0
  2560  	}
  2561  	var l int
  2562  	_ = l
  2563  	l = m.FlowID.Size()
  2564  	n += 1 + l + sovData(uint64(l))
  2565  	n += 1 + sovData(uint64(m.StreamID))
  2566  	return n
  2567  }
  2568  
  2569  func (m *ProducerData) Size() (n int) {
  2570  	if m == nil {
  2571  		return 0
  2572  	}
  2573  	var l int
  2574  	_ = l
  2575  	if m.RawBytes != nil {
  2576  		l = len(m.RawBytes)
  2577  		n += 1 + l + sovData(uint64(l))
  2578  	}
  2579  	if len(m.Metadata) > 0 {
  2580  		for _, e := range m.Metadata {
  2581  			l = e.Size()
  2582  			n += 1 + l + sovData(uint64(l))
  2583  		}
  2584  	}
  2585  	n += 1 + sovData(uint64(m.NumEmptyRows))
  2586  	return n
  2587  }
  2588  
  2589  func (m *ProducerMessage) Size() (n int) {
  2590  	if m == nil {
  2591  		return 0
  2592  	}
  2593  	var l int
  2594  	_ = l
  2595  	if m.Header != nil {
  2596  		l = m.Header.Size()
  2597  		n += 1 + l + sovData(uint64(l))
  2598  	}
  2599  	if len(m.Typing) > 0 {
  2600  		for _, e := range m.Typing {
  2601  			l = e.Size()
  2602  			n += 1 + l + sovData(uint64(l))
  2603  		}
  2604  	}
  2605  	l = m.Data.Size()
  2606  	n += 1 + l + sovData(uint64(l))
  2607  	return n
  2608  }
  2609  
  2610  func (m *RemoteProducerMetadata) Size() (n int) {
  2611  	if m == nil {
  2612  		return 0
  2613  	}
  2614  	var l int
  2615  	_ = l
  2616  	if m.Value != nil {
  2617  		n += m.Value.Size()
  2618  	}
  2619  	return n
  2620  }
  2621  
  2622  func (m *RemoteProducerMetadata_RangeInfo) Size() (n int) {
  2623  	if m == nil {
  2624  		return 0
  2625  	}
  2626  	var l int
  2627  	_ = l
  2628  	if m.RangeInfo != nil {
  2629  		l = m.RangeInfo.Size()
  2630  		n += 1 + l + sovData(uint64(l))
  2631  	}
  2632  	return n
  2633  }
  2634  func (m *RemoteProducerMetadata_Error) Size() (n int) {
  2635  	if m == nil {
  2636  		return 0
  2637  	}
  2638  	var l int
  2639  	_ = l
  2640  	if m.Error != nil {
  2641  		l = m.Error.Size()
  2642  		n += 1 + l + sovData(uint64(l))
  2643  	}
  2644  	return n
  2645  }
  2646  func (m *RemoteProducerMetadata_TraceData_) Size() (n int) {
  2647  	if m == nil {
  2648  		return 0
  2649  	}
  2650  	var l int
  2651  	_ = l
  2652  	if m.TraceData != nil {
  2653  		l = m.TraceData.Size()
  2654  		n += 1 + l + sovData(uint64(l))
  2655  	}
  2656  	return n
  2657  }
  2658  func (m *RemoteProducerMetadata_LeafTxnFinalState) Size() (n int) {
  2659  	if m == nil {
  2660  		return 0
  2661  	}
  2662  	var l int
  2663  	_ = l
  2664  	if m.LeafTxnFinalState != nil {
  2665  		l = m.LeafTxnFinalState.Size()
  2666  		n += 1 + l + sovData(uint64(l))
  2667  	}
  2668  	return n
  2669  }
  2670  func (m *RemoteProducerMetadata_RowNum_) Size() (n int) {
  2671  	if m == nil {
  2672  		return 0
  2673  	}
  2674  	var l int
  2675  	_ = l
  2676  	if m.RowNum != nil {
  2677  		l = m.RowNum.Size()
  2678  		n += 1 + l + sovData(uint64(l))
  2679  	}
  2680  	return n
  2681  }
  2682  func (m *RemoteProducerMetadata_SamplerProgress_) Size() (n int) {
  2683  	if m == nil {
  2684  		return 0
  2685  	}
  2686  	var l int
  2687  	_ = l
  2688  	if m.SamplerProgress != nil {
  2689  		l = m.SamplerProgress.Size()
  2690  		n += 1 + l + sovData(uint64(l))
  2691  	}
  2692  	return n
  2693  }
  2694  func (m *RemoteProducerMetadata_Metrics_) Size() (n int) {
  2695  	if m == nil {
  2696  		return 0
  2697  	}
  2698  	var l int
  2699  	_ = l
  2700  	if m.Metrics != nil {
  2701  		l = m.Metrics.Size()
  2702  		n += 1 + l + sovData(uint64(l))
  2703  	}
  2704  	return n
  2705  }
  2706  func (m *RemoteProducerMetadata_BulkProcessorProgress_) Size() (n int) {
  2707  	if m == nil {
  2708  		return 0
  2709  	}
  2710  	var l int
  2711  	_ = l
  2712  	if m.BulkProcessorProgress != nil {
  2713  		l = m.BulkProcessorProgress.Size()
  2714  		n += 1 + l + sovData(uint64(l))
  2715  	}
  2716  	return n
  2717  }
  2718  func (m *RemoteProducerMetadata_RangeInfos) Size() (n int) {
  2719  	if m == nil {
  2720  		return 0
  2721  	}
  2722  	var l int
  2723  	_ = l
  2724  	if len(m.RangeInfo) > 0 {
  2725  		for _, e := range m.RangeInfo {
  2726  			l = e.Size()
  2727  			n += 1 + l + sovData(uint64(l))
  2728  		}
  2729  	}
  2730  	return n
  2731  }
  2732  
  2733  func (m *RemoteProducerMetadata_TraceData) Size() (n int) {
  2734  	if m == nil {
  2735  		return 0
  2736  	}
  2737  	var l int
  2738  	_ = l
  2739  	if len(m.CollectedSpans) > 0 {
  2740  		for _, e := range m.CollectedSpans {
  2741  			l = e.Size()
  2742  			n += 1 + l + sovData(uint64(l))
  2743  		}
  2744  	}
  2745  	return n
  2746  }
  2747  
  2748  func (m *RemoteProducerMetadata_RowNum) Size() (n int) {
  2749  	if m == nil {
  2750  		return 0
  2751  	}
  2752  	var l int
  2753  	_ = l
  2754  	l = len(m.SenderID)
  2755  	n += 1 + l + sovData(uint64(l))
  2756  	n += 1 + sovData(uint64(m.RowNum))
  2757  	n += 2
  2758  	return n
  2759  }
  2760  
  2761  func (m *RemoteProducerMetadata_SamplerProgress) Size() (n int) {
  2762  	if m == nil {
  2763  		return 0
  2764  	}
  2765  	var l int
  2766  	_ = l
  2767  	n += 1 + sovData(uint64(m.RowsProcessed))
  2768  	n += 2
  2769  	return n
  2770  }
  2771  
  2772  func (m *RemoteProducerMetadata_BulkProcessorProgress) Size() (n int) {
  2773  	if m == nil {
  2774  		return 0
  2775  	}
  2776  	var l int
  2777  	_ = l
  2778  	if len(m.CompletedSpans) > 0 {
  2779  		for _, e := range m.CompletedSpans {
  2780  			l = e.Size()
  2781  			n += 1 + l + sovData(uint64(l))
  2782  		}
  2783  	}
  2784  	if len(m.CompletedFraction) > 0 {
  2785  		for k, v := range m.CompletedFraction {
  2786  			_ = k
  2787  			_ = v
  2788  			mapEntrySize := 1 + sovData(uint64(k)) + 1 + 4
  2789  			n += mapEntrySize + 1 + sovData(uint64(mapEntrySize))
  2790  		}
  2791  	}
  2792  	if len(m.ResumePos) > 0 {
  2793  		for k, v := range m.ResumePos {
  2794  			_ = k
  2795  			_ = v
  2796  			mapEntrySize := 1 + sovData(uint64(k)) + 1 + sovData(uint64(v))
  2797  			n += mapEntrySize + 1 + sovData(uint64(mapEntrySize))
  2798  		}
  2799  	}
  2800  	return n
  2801  }
  2802  
  2803  func (m *RemoteProducerMetadata_Metrics) Size() (n int) {
  2804  	if m == nil {
  2805  		return 0
  2806  	}
  2807  	var l int
  2808  	_ = l
  2809  	n += 1 + sovData(uint64(m.BytesRead))
  2810  	n += 1 + sovData(uint64(m.RowsRead))
  2811  	return n
  2812  }
  2813  
  2814  func (m *DistSQLVersionGossipInfo) Size() (n int) {
  2815  	if m == nil {
  2816  		return 0
  2817  	}
  2818  	var l int
  2819  	_ = l
  2820  	n += 1 + sovData(uint64(m.Version))
  2821  	n += 1 + sovData(uint64(m.MinAcceptedVersion))
  2822  	return n
  2823  }
  2824  
  2825  func (m *DistSQLDrainingInfo) Size() (n int) {
  2826  	if m == nil {
  2827  		return 0
  2828  	}
  2829  	var l int
  2830  	_ = l
  2831  	n += 2
  2832  	return n
  2833  }
  2834  
  2835  func sovData(x uint64) (n int) {
  2836  	for {
  2837  		n++
  2838  		x >>= 7
  2839  		if x == 0 {
  2840  			break
  2841  		}
  2842  	}
  2843  	return n
  2844  }
  2845  func sozData(x uint64) (n int) {
  2846  	return sovData(uint64((x << 1) ^ uint64((int64(x) >> 63))))
  2847  }
  2848  func (m *Error) Unmarshal(dAtA []byte) error {
  2849  	l := len(dAtA)
  2850  	iNdEx := 0
  2851  	for iNdEx < l {
  2852  		preIndex := iNdEx
  2853  		var wire uint64
  2854  		for shift := uint(0); ; shift += 7 {
  2855  			if shift >= 64 {
  2856  				return ErrIntOverflowData
  2857  			}
  2858  			if iNdEx >= l {
  2859  				return io.ErrUnexpectedEOF
  2860  			}
  2861  			b := dAtA[iNdEx]
  2862  			iNdEx++
  2863  			wire |= (uint64(b) & 0x7F) << shift
  2864  			if b < 0x80 {
  2865  				break
  2866  			}
  2867  		}
  2868  		fieldNum := int32(wire >> 3)
  2869  		wireType := int(wire & 0x7)
  2870  		if wireType == 4 {
  2871  			return fmt.Errorf("proto: Error: wiretype end group for non-group")
  2872  		}
  2873  		if fieldNum <= 0 {
  2874  			return fmt.Errorf("proto: Error: illegal tag %d (wire type %d)", fieldNum, wire)
  2875  		}
  2876  		switch fieldNum {
  2877  		case 3:
  2878  			if wireType != 2 {
  2879  				return fmt.Errorf("proto: wrong wireType = %d for field FullError", wireType)
  2880  			}
  2881  			var msglen int
  2882  			for shift := uint(0); ; shift += 7 {
  2883  				if shift >= 64 {
  2884  					return ErrIntOverflowData
  2885  				}
  2886  				if iNdEx >= l {
  2887  					return io.ErrUnexpectedEOF
  2888  				}
  2889  				b := dAtA[iNdEx]
  2890  				iNdEx++
  2891  				msglen |= (int(b) & 0x7F) << shift
  2892  				if b < 0x80 {
  2893  					break
  2894  				}
  2895  			}
  2896  			if msglen < 0 {
  2897  				return ErrInvalidLengthData
  2898  			}
  2899  			postIndex := iNdEx + msglen
  2900  			if postIndex > l {
  2901  				return io.ErrUnexpectedEOF
  2902  			}
  2903  			if m.FullError == nil {
  2904  				m.FullError = &errorspb.EncodedError{}
  2905  			}
  2906  			if err := m.FullError.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2907  				return err
  2908  			}
  2909  			iNdEx = postIndex
  2910  		default:
  2911  			iNdEx = preIndex
  2912  			skippy, err := skipData(dAtA[iNdEx:])
  2913  			if err != nil {
  2914  				return err
  2915  			}
  2916  			if skippy < 0 {
  2917  				return ErrInvalidLengthData
  2918  			}
  2919  			if (iNdEx + skippy) > l {
  2920  				return io.ErrUnexpectedEOF
  2921  			}
  2922  			iNdEx += skippy
  2923  		}
  2924  	}
  2925  
  2926  	if iNdEx > l {
  2927  		return io.ErrUnexpectedEOF
  2928  	}
  2929  	return nil
  2930  }
  2931  func (m *Expression) Unmarshal(dAtA []byte) error {
  2932  	l := len(dAtA)
  2933  	iNdEx := 0
  2934  	for iNdEx < l {
  2935  		preIndex := iNdEx
  2936  		var wire uint64
  2937  		for shift := uint(0); ; shift += 7 {
  2938  			if shift >= 64 {
  2939  				return ErrIntOverflowData
  2940  			}
  2941  			if iNdEx >= l {
  2942  				return io.ErrUnexpectedEOF
  2943  			}
  2944  			b := dAtA[iNdEx]
  2945  			iNdEx++
  2946  			wire |= (uint64(b) & 0x7F) << shift
  2947  			if b < 0x80 {
  2948  				break
  2949  			}
  2950  		}
  2951  		fieldNum := int32(wire >> 3)
  2952  		wireType := int(wire & 0x7)
  2953  		if wireType == 4 {
  2954  			return fmt.Errorf("proto: Expression: wiretype end group for non-group")
  2955  		}
  2956  		if fieldNum <= 0 {
  2957  			return fmt.Errorf("proto: Expression: illegal tag %d (wire type %d)", fieldNum, wire)
  2958  		}
  2959  		switch fieldNum {
  2960  		case 1:
  2961  			if wireType != 2 {
  2962  				return fmt.Errorf("proto: wrong wireType = %d for field Version", wireType)
  2963  			}
  2964  			var stringLen uint64
  2965  			for shift := uint(0); ; shift += 7 {
  2966  				if shift >= 64 {
  2967  					return ErrIntOverflowData
  2968  				}
  2969  				if iNdEx >= l {
  2970  					return io.ErrUnexpectedEOF
  2971  				}
  2972  				b := dAtA[iNdEx]
  2973  				iNdEx++
  2974  				stringLen |= (uint64(b) & 0x7F) << shift
  2975  				if b < 0x80 {
  2976  					break
  2977  				}
  2978  			}
  2979  			intStringLen := int(stringLen)
  2980  			if intStringLen < 0 {
  2981  				return ErrInvalidLengthData
  2982  			}
  2983  			postIndex := iNdEx + intStringLen
  2984  			if postIndex > l {
  2985  				return io.ErrUnexpectedEOF
  2986  			}
  2987  			m.Version = string(dAtA[iNdEx:postIndex])
  2988  			iNdEx = postIndex
  2989  		case 2:
  2990  			if wireType != 2 {
  2991  				return fmt.Errorf("proto: wrong wireType = %d for field Expr", wireType)
  2992  			}
  2993  			var stringLen uint64
  2994  			for shift := uint(0); ; shift += 7 {
  2995  				if shift >= 64 {
  2996  					return ErrIntOverflowData
  2997  				}
  2998  				if iNdEx >= l {
  2999  					return io.ErrUnexpectedEOF
  3000  				}
  3001  				b := dAtA[iNdEx]
  3002  				iNdEx++
  3003  				stringLen |= (uint64(b) & 0x7F) << shift
  3004  				if b < 0x80 {
  3005  					break
  3006  				}
  3007  			}
  3008  			intStringLen := int(stringLen)
  3009  			if intStringLen < 0 {
  3010  				return ErrInvalidLengthData
  3011  			}
  3012  			postIndex := iNdEx + intStringLen
  3013  			if postIndex > l {
  3014  				return io.ErrUnexpectedEOF
  3015  			}
  3016  			m.Expr = string(dAtA[iNdEx:postIndex])
  3017  			iNdEx = postIndex
  3018  		default:
  3019  			iNdEx = preIndex
  3020  			skippy, err := skipData(dAtA[iNdEx:])
  3021  			if err != nil {
  3022  				return err
  3023  			}
  3024  			if skippy < 0 {
  3025  				return ErrInvalidLengthData
  3026  			}
  3027  			if (iNdEx + skippy) > l {
  3028  				return io.ErrUnexpectedEOF
  3029  			}
  3030  			iNdEx += skippy
  3031  		}
  3032  	}
  3033  
  3034  	if iNdEx > l {
  3035  		return io.ErrUnexpectedEOF
  3036  	}
  3037  	return nil
  3038  }
  3039  func (m *Ordering) Unmarshal(dAtA []byte) error {
  3040  	l := len(dAtA)
  3041  	iNdEx := 0
  3042  	for iNdEx < l {
  3043  		preIndex := iNdEx
  3044  		var wire uint64
  3045  		for shift := uint(0); ; shift += 7 {
  3046  			if shift >= 64 {
  3047  				return ErrIntOverflowData
  3048  			}
  3049  			if iNdEx >= l {
  3050  				return io.ErrUnexpectedEOF
  3051  			}
  3052  			b := dAtA[iNdEx]
  3053  			iNdEx++
  3054  			wire |= (uint64(b) & 0x7F) << shift
  3055  			if b < 0x80 {
  3056  				break
  3057  			}
  3058  		}
  3059  		fieldNum := int32(wire >> 3)
  3060  		wireType := int(wire & 0x7)
  3061  		if wireType == 4 {
  3062  			return fmt.Errorf("proto: Ordering: wiretype end group for non-group")
  3063  		}
  3064  		if fieldNum <= 0 {
  3065  			return fmt.Errorf("proto: Ordering: illegal tag %d (wire type %d)", fieldNum, wire)
  3066  		}
  3067  		switch fieldNum {
  3068  		case 1:
  3069  			if wireType != 2 {
  3070  				return fmt.Errorf("proto: wrong wireType = %d for field Columns", wireType)
  3071  			}
  3072  			var msglen int
  3073  			for shift := uint(0); ; shift += 7 {
  3074  				if shift >= 64 {
  3075  					return ErrIntOverflowData
  3076  				}
  3077  				if iNdEx >= l {
  3078  					return io.ErrUnexpectedEOF
  3079  				}
  3080  				b := dAtA[iNdEx]
  3081  				iNdEx++
  3082  				msglen |= (int(b) & 0x7F) << shift
  3083  				if b < 0x80 {
  3084  					break
  3085  				}
  3086  			}
  3087  			if msglen < 0 {
  3088  				return ErrInvalidLengthData
  3089  			}
  3090  			postIndex := iNdEx + msglen
  3091  			if postIndex > l {
  3092  				return io.ErrUnexpectedEOF
  3093  			}
  3094  			m.Columns = append(m.Columns, Ordering_Column{})
  3095  			if err := m.Columns[len(m.Columns)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3096  				return err
  3097  			}
  3098  			iNdEx = postIndex
  3099  		default:
  3100  			iNdEx = preIndex
  3101  			skippy, err := skipData(dAtA[iNdEx:])
  3102  			if err != nil {
  3103  				return err
  3104  			}
  3105  			if skippy < 0 {
  3106  				return ErrInvalidLengthData
  3107  			}
  3108  			if (iNdEx + skippy) > l {
  3109  				return io.ErrUnexpectedEOF
  3110  			}
  3111  			iNdEx += skippy
  3112  		}
  3113  	}
  3114  
  3115  	if iNdEx > l {
  3116  		return io.ErrUnexpectedEOF
  3117  	}
  3118  	return nil
  3119  }
  3120  func (m *Ordering_Column) Unmarshal(dAtA []byte) error {
  3121  	l := len(dAtA)
  3122  	iNdEx := 0
  3123  	for iNdEx < l {
  3124  		preIndex := iNdEx
  3125  		var wire uint64
  3126  		for shift := uint(0); ; shift += 7 {
  3127  			if shift >= 64 {
  3128  				return ErrIntOverflowData
  3129  			}
  3130  			if iNdEx >= l {
  3131  				return io.ErrUnexpectedEOF
  3132  			}
  3133  			b := dAtA[iNdEx]
  3134  			iNdEx++
  3135  			wire |= (uint64(b) & 0x7F) << shift
  3136  			if b < 0x80 {
  3137  				break
  3138  			}
  3139  		}
  3140  		fieldNum := int32(wire >> 3)
  3141  		wireType := int(wire & 0x7)
  3142  		if wireType == 4 {
  3143  			return fmt.Errorf("proto: Column: wiretype end group for non-group")
  3144  		}
  3145  		if fieldNum <= 0 {
  3146  			return fmt.Errorf("proto: Column: illegal tag %d (wire type %d)", fieldNum, wire)
  3147  		}
  3148  		switch fieldNum {
  3149  		case 1:
  3150  			if wireType != 0 {
  3151  				return fmt.Errorf("proto: wrong wireType = %d for field ColIdx", wireType)
  3152  			}
  3153  			m.ColIdx = 0
  3154  			for shift := uint(0); ; shift += 7 {
  3155  				if shift >= 64 {
  3156  					return ErrIntOverflowData
  3157  				}
  3158  				if iNdEx >= l {
  3159  					return io.ErrUnexpectedEOF
  3160  				}
  3161  				b := dAtA[iNdEx]
  3162  				iNdEx++
  3163  				m.ColIdx |= (uint32(b) & 0x7F) << shift
  3164  				if b < 0x80 {
  3165  					break
  3166  				}
  3167  			}
  3168  		case 2:
  3169  			if wireType != 0 {
  3170  				return fmt.Errorf("proto: wrong wireType = %d for field Direction", wireType)
  3171  			}
  3172  			m.Direction = 0
  3173  			for shift := uint(0); ; shift += 7 {
  3174  				if shift >= 64 {
  3175  					return ErrIntOverflowData
  3176  				}
  3177  				if iNdEx >= l {
  3178  					return io.ErrUnexpectedEOF
  3179  				}
  3180  				b := dAtA[iNdEx]
  3181  				iNdEx++
  3182  				m.Direction |= (Ordering_Column_Direction(b) & 0x7F) << shift
  3183  				if b < 0x80 {
  3184  					break
  3185  				}
  3186  			}
  3187  		default:
  3188  			iNdEx = preIndex
  3189  			skippy, err := skipData(dAtA[iNdEx:])
  3190  			if err != nil {
  3191  				return err
  3192  			}
  3193  			if skippy < 0 {
  3194  				return ErrInvalidLengthData
  3195  			}
  3196  			if (iNdEx + skippy) > l {
  3197  				return io.ErrUnexpectedEOF
  3198  			}
  3199  			iNdEx += skippy
  3200  		}
  3201  	}
  3202  
  3203  	if iNdEx > l {
  3204  		return io.ErrUnexpectedEOF
  3205  	}
  3206  	return nil
  3207  }
  3208  func (m *StreamEndpointSpec) Unmarshal(dAtA []byte) error {
  3209  	l := len(dAtA)
  3210  	iNdEx := 0
  3211  	for iNdEx < l {
  3212  		preIndex := iNdEx
  3213  		var wire uint64
  3214  		for shift := uint(0); ; shift += 7 {
  3215  			if shift >= 64 {
  3216  				return ErrIntOverflowData
  3217  			}
  3218  			if iNdEx >= l {
  3219  				return io.ErrUnexpectedEOF
  3220  			}
  3221  			b := dAtA[iNdEx]
  3222  			iNdEx++
  3223  			wire |= (uint64(b) & 0x7F) << shift
  3224  			if b < 0x80 {
  3225  				break
  3226  			}
  3227  		}
  3228  		fieldNum := int32(wire >> 3)
  3229  		wireType := int(wire & 0x7)
  3230  		if wireType == 4 {
  3231  			return fmt.Errorf("proto: StreamEndpointSpec: wiretype end group for non-group")
  3232  		}
  3233  		if fieldNum <= 0 {
  3234  			return fmt.Errorf("proto: StreamEndpointSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  3235  		}
  3236  		switch fieldNum {
  3237  		case 1:
  3238  			if wireType != 0 {
  3239  				return fmt.Errorf("proto: wrong wireType = %d for field Type", wireType)
  3240  			}
  3241  			m.Type = 0
  3242  			for shift := uint(0); ; shift += 7 {
  3243  				if shift >= 64 {
  3244  					return ErrIntOverflowData
  3245  				}
  3246  				if iNdEx >= l {
  3247  					return io.ErrUnexpectedEOF
  3248  				}
  3249  				b := dAtA[iNdEx]
  3250  				iNdEx++
  3251  				m.Type |= (StreamEndpointSpec_Type(b) & 0x7F) << shift
  3252  				if b < 0x80 {
  3253  					break
  3254  				}
  3255  			}
  3256  		case 2:
  3257  			if wireType != 0 {
  3258  				return fmt.Errorf("proto: wrong wireType = %d for field StreamID", wireType)
  3259  			}
  3260  			m.StreamID = 0
  3261  			for shift := uint(0); ; shift += 7 {
  3262  				if shift >= 64 {
  3263  					return ErrIntOverflowData
  3264  				}
  3265  				if iNdEx >= l {
  3266  					return io.ErrUnexpectedEOF
  3267  				}
  3268  				b := dAtA[iNdEx]
  3269  				iNdEx++
  3270  				m.StreamID |= (StreamID(b) & 0x7F) << shift
  3271  				if b < 0x80 {
  3272  					break
  3273  				}
  3274  			}
  3275  		case 4:
  3276  			if wireType != 0 {
  3277  				return fmt.Errorf("proto: wrong wireType = %d for field TargetNodeID", wireType)
  3278  			}
  3279  			m.TargetNodeID = 0
  3280  			for shift := uint(0); ; shift += 7 {
  3281  				if shift >= 64 {
  3282  					return ErrIntOverflowData
  3283  				}
  3284  				if iNdEx >= l {
  3285  					return io.ErrUnexpectedEOF
  3286  				}
  3287  				b := dAtA[iNdEx]
  3288  				iNdEx++
  3289  				m.TargetNodeID |= (github_com_cockroachdb_cockroach_pkg_roachpb.NodeID(b) & 0x7F) << shift
  3290  				if b < 0x80 {
  3291  					break
  3292  				}
  3293  			}
  3294  		default:
  3295  			iNdEx = preIndex
  3296  			skippy, err := skipData(dAtA[iNdEx:])
  3297  			if err != nil {
  3298  				return err
  3299  			}
  3300  			if skippy < 0 {
  3301  				return ErrInvalidLengthData
  3302  			}
  3303  			if (iNdEx + skippy) > l {
  3304  				return io.ErrUnexpectedEOF
  3305  			}
  3306  			iNdEx += skippy
  3307  		}
  3308  	}
  3309  
  3310  	if iNdEx > l {
  3311  		return io.ErrUnexpectedEOF
  3312  	}
  3313  	return nil
  3314  }
  3315  func (m *InputSyncSpec) Unmarshal(dAtA []byte) error {
  3316  	l := len(dAtA)
  3317  	iNdEx := 0
  3318  	for iNdEx < l {
  3319  		preIndex := iNdEx
  3320  		var wire uint64
  3321  		for shift := uint(0); ; shift += 7 {
  3322  			if shift >= 64 {
  3323  				return ErrIntOverflowData
  3324  			}
  3325  			if iNdEx >= l {
  3326  				return io.ErrUnexpectedEOF
  3327  			}
  3328  			b := dAtA[iNdEx]
  3329  			iNdEx++
  3330  			wire |= (uint64(b) & 0x7F) << shift
  3331  			if b < 0x80 {
  3332  				break
  3333  			}
  3334  		}
  3335  		fieldNum := int32(wire >> 3)
  3336  		wireType := int(wire & 0x7)
  3337  		if wireType == 4 {
  3338  			return fmt.Errorf("proto: InputSyncSpec: wiretype end group for non-group")
  3339  		}
  3340  		if fieldNum <= 0 {
  3341  			return fmt.Errorf("proto: InputSyncSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  3342  		}
  3343  		switch fieldNum {
  3344  		case 1:
  3345  			if wireType != 0 {
  3346  				return fmt.Errorf("proto: wrong wireType = %d for field Type", wireType)
  3347  			}
  3348  			m.Type = 0
  3349  			for shift := uint(0); ; shift += 7 {
  3350  				if shift >= 64 {
  3351  					return ErrIntOverflowData
  3352  				}
  3353  				if iNdEx >= l {
  3354  					return io.ErrUnexpectedEOF
  3355  				}
  3356  				b := dAtA[iNdEx]
  3357  				iNdEx++
  3358  				m.Type |= (InputSyncSpec_Type(b) & 0x7F) << shift
  3359  				if b < 0x80 {
  3360  					break
  3361  				}
  3362  			}
  3363  		case 2:
  3364  			if wireType != 2 {
  3365  				return fmt.Errorf("proto: wrong wireType = %d for field Ordering", wireType)
  3366  			}
  3367  			var msglen int
  3368  			for shift := uint(0); ; shift += 7 {
  3369  				if shift >= 64 {
  3370  					return ErrIntOverflowData
  3371  				}
  3372  				if iNdEx >= l {
  3373  					return io.ErrUnexpectedEOF
  3374  				}
  3375  				b := dAtA[iNdEx]
  3376  				iNdEx++
  3377  				msglen |= (int(b) & 0x7F) << shift
  3378  				if b < 0x80 {
  3379  					break
  3380  				}
  3381  			}
  3382  			if msglen < 0 {
  3383  				return ErrInvalidLengthData
  3384  			}
  3385  			postIndex := iNdEx + msglen
  3386  			if postIndex > l {
  3387  				return io.ErrUnexpectedEOF
  3388  			}
  3389  			if err := m.Ordering.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3390  				return err
  3391  			}
  3392  			iNdEx = postIndex
  3393  		case 3:
  3394  			if wireType != 2 {
  3395  				return fmt.Errorf("proto: wrong wireType = %d for field Streams", wireType)
  3396  			}
  3397  			var msglen int
  3398  			for shift := uint(0); ; shift += 7 {
  3399  				if shift >= 64 {
  3400  					return ErrIntOverflowData
  3401  				}
  3402  				if iNdEx >= l {
  3403  					return io.ErrUnexpectedEOF
  3404  				}
  3405  				b := dAtA[iNdEx]
  3406  				iNdEx++
  3407  				msglen |= (int(b) & 0x7F) << shift
  3408  				if b < 0x80 {
  3409  					break
  3410  				}
  3411  			}
  3412  			if msglen < 0 {
  3413  				return ErrInvalidLengthData
  3414  			}
  3415  			postIndex := iNdEx + msglen
  3416  			if postIndex > l {
  3417  				return io.ErrUnexpectedEOF
  3418  			}
  3419  			m.Streams = append(m.Streams, StreamEndpointSpec{})
  3420  			if err := m.Streams[len(m.Streams)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3421  				return err
  3422  			}
  3423  			iNdEx = postIndex
  3424  		case 4:
  3425  			if wireType != 2 {
  3426  				return fmt.Errorf("proto: wrong wireType = %d for field ColumnTypes", wireType)
  3427  			}
  3428  			var msglen int
  3429  			for shift := uint(0); ; shift += 7 {
  3430  				if shift >= 64 {
  3431  					return ErrIntOverflowData
  3432  				}
  3433  				if iNdEx >= l {
  3434  					return io.ErrUnexpectedEOF
  3435  				}
  3436  				b := dAtA[iNdEx]
  3437  				iNdEx++
  3438  				msglen |= (int(b) & 0x7F) << shift
  3439  				if b < 0x80 {
  3440  					break
  3441  				}
  3442  			}
  3443  			if msglen < 0 {
  3444  				return ErrInvalidLengthData
  3445  			}
  3446  			postIndex := iNdEx + msglen
  3447  			if postIndex > l {
  3448  				return io.ErrUnexpectedEOF
  3449  			}
  3450  			m.ColumnTypes = append(m.ColumnTypes, &types.T{})
  3451  			if err := m.ColumnTypes[len(m.ColumnTypes)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3452  				return err
  3453  			}
  3454  			iNdEx = postIndex
  3455  		default:
  3456  			iNdEx = preIndex
  3457  			skippy, err := skipData(dAtA[iNdEx:])
  3458  			if err != nil {
  3459  				return err
  3460  			}
  3461  			if skippy < 0 {
  3462  				return ErrInvalidLengthData
  3463  			}
  3464  			if (iNdEx + skippy) > l {
  3465  				return io.ErrUnexpectedEOF
  3466  			}
  3467  			iNdEx += skippy
  3468  		}
  3469  	}
  3470  
  3471  	if iNdEx > l {
  3472  		return io.ErrUnexpectedEOF
  3473  	}
  3474  	return nil
  3475  }
  3476  func (m *OutputRouterSpec) Unmarshal(dAtA []byte) error {
  3477  	l := len(dAtA)
  3478  	iNdEx := 0
  3479  	for iNdEx < l {
  3480  		preIndex := iNdEx
  3481  		var wire uint64
  3482  		for shift := uint(0); ; shift += 7 {
  3483  			if shift >= 64 {
  3484  				return ErrIntOverflowData
  3485  			}
  3486  			if iNdEx >= l {
  3487  				return io.ErrUnexpectedEOF
  3488  			}
  3489  			b := dAtA[iNdEx]
  3490  			iNdEx++
  3491  			wire |= (uint64(b) & 0x7F) << shift
  3492  			if b < 0x80 {
  3493  				break
  3494  			}
  3495  		}
  3496  		fieldNum := int32(wire >> 3)
  3497  		wireType := int(wire & 0x7)
  3498  		if wireType == 4 {
  3499  			return fmt.Errorf("proto: OutputRouterSpec: wiretype end group for non-group")
  3500  		}
  3501  		if fieldNum <= 0 {
  3502  			return fmt.Errorf("proto: OutputRouterSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  3503  		}
  3504  		switch fieldNum {
  3505  		case 1:
  3506  			if wireType != 0 {
  3507  				return fmt.Errorf("proto: wrong wireType = %d for field Type", wireType)
  3508  			}
  3509  			m.Type = 0
  3510  			for shift := uint(0); ; shift += 7 {
  3511  				if shift >= 64 {
  3512  					return ErrIntOverflowData
  3513  				}
  3514  				if iNdEx >= l {
  3515  					return io.ErrUnexpectedEOF
  3516  				}
  3517  				b := dAtA[iNdEx]
  3518  				iNdEx++
  3519  				m.Type |= (OutputRouterSpec_Type(b) & 0x7F) << shift
  3520  				if b < 0x80 {
  3521  					break
  3522  				}
  3523  			}
  3524  		case 2:
  3525  			if wireType != 2 {
  3526  				return fmt.Errorf("proto: wrong wireType = %d for field Streams", wireType)
  3527  			}
  3528  			var msglen int
  3529  			for shift := uint(0); ; shift += 7 {
  3530  				if shift >= 64 {
  3531  					return ErrIntOverflowData
  3532  				}
  3533  				if iNdEx >= l {
  3534  					return io.ErrUnexpectedEOF
  3535  				}
  3536  				b := dAtA[iNdEx]
  3537  				iNdEx++
  3538  				msglen |= (int(b) & 0x7F) << shift
  3539  				if b < 0x80 {
  3540  					break
  3541  				}
  3542  			}
  3543  			if msglen < 0 {
  3544  				return ErrInvalidLengthData
  3545  			}
  3546  			postIndex := iNdEx + msglen
  3547  			if postIndex > l {
  3548  				return io.ErrUnexpectedEOF
  3549  			}
  3550  			m.Streams = append(m.Streams, StreamEndpointSpec{})
  3551  			if err := m.Streams[len(m.Streams)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3552  				return err
  3553  			}
  3554  			iNdEx = postIndex
  3555  		case 3:
  3556  			if wireType == 0 {
  3557  				var v uint32
  3558  				for shift := uint(0); ; shift += 7 {
  3559  					if shift >= 64 {
  3560  						return ErrIntOverflowData
  3561  					}
  3562  					if iNdEx >= l {
  3563  						return io.ErrUnexpectedEOF
  3564  					}
  3565  					b := dAtA[iNdEx]
  3566  					iNdEx++
  3567  					v |= (uint32(b) & 0x7F) << shift
  3568  					if b < 0x80 {
  3569  						break
  3570  					}
  3571  				}
  3572  				m.HashColumns = append(m.HashColumns, v)
  3573  			} else if wireType == 2 {
  3574  				var packedLen int
  3575  				for shift := uint(0); ; shift += 7 {
  3576  					if shift >= 64 {
  3577  						return ErrIntOverflowData
  3578  					}
  3579  					if iNdEx >= l {
  3580  						return io.ErrUnexpectedEOF
  3581  					}
  3582  					b := dAtA[iNdEx]
  3583  					iNdEx++
  3584  					packedLen |= (int(b) & 0x7F) << shift
  3585  					if b < 0x80 {
  3586  						break
  3587  					}
  3588  				}
  3589  				if packedLen < 0 {
  3590  					return ErrInvalidLengthData
  3591  				}
  3592  				postIndex := iNdEx + packedLen
  3593  				if postIndex > l {
  3594  					return io.ErrUnexpectedEOF
  3595  				}
  3596  				var elementCount int
  3597  				var count int
  3598  				for _, integer := range dAtA {
  3599  					if integer < 128 {
  3600  						count++
  3601  					}
  3602  				}
  3603  				elementCount = count
  3604  				if elementCount != 0 && len(m.HashColumns) == 0 {
  3605  					m.HashColumns = make([]uint32, 0, elementCount)
  3606  				}
  3607  				for iNdEx < postIndex {
  3608  					var v uint32
  3609  					for shift := uint(0); ; shift += 7 {
  3610  						if shift >= 64 {
  3611  							return ErrIntOverflowData
  3612  						}
  3613  						if iNdEx >= l {
  3614  							return io.ErrUnexpectedEOF
  3615  						}
  3616  						b := dAtA[iNdEx]
  3617  						iNdEx++
  3618  						v |= (uint32(b) & 0x7F) << shift
  3619  						if b < 0x80 {
  3620  							break
  3621  						}
  3622  					}
  3623  					m.HashColumns = append(m.HashColumns, v)
  3624  				}
  3625  			} else {
  3626  				return fmt.Errorf("proto: wrong wireType = %d for field HashColumns", wireType)
  3627  			}
  3628  		case 4:
  3629  			if wireType != 2 {
  3630  				return fmt.Errorf("proto: wrong wireType = %d for field RangeRouterSpec", wireType)
  3631  			}
  3632  			var msglen int
  3633  			for shift := uint(0); ; shift += 7 {
  3634  				if shift >= 64 {
  3635  					return ErrIntOverflowData
  3636  				}
  3637  				if iNdEx >= l {
  3638  					return io.ErrUnexpectedEOF
  3639  				}
  3640  				b := dAtA[iNdEx]
  3641  				iNdEx++
  3642  				msglen |= (int(b) & 0x7F) << shift
  3643  				if b < 0x80 {
  3644  					break
  3645  				}
  3646  			}
  3647  			if msglen < 0 {
  3648  				return ErrInvalidLengthData
  3649  			}
  3650  			postIndex := iNdEx + msglen
  3651  			if postIndex > l {
  3652  				return io.ErrUnexpectedEOF
  3653  			}
  3654  			if err := m.RangeRouterSpec.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3655  				return err
  3656  			}
  3657  			iNdEx = postIndex
  3658  		case 5:
  3659  			if wireType != 0 {
  3660  				return fmt.Errorf("proto: wrong wireType = %d for field DisableBuffering", wireType)
  3661  			}
  3662  			var v int
  3663  			for shift := uint(0); ; shift += 7 {
  3664  				if shift >= 64 {
  3665  					return ErrIntOverflowData
  3666  				}
  3667  				if iNdEx >= l {
  3668  					return io.ErrUnexpectedEOF
  3669  				}
  3670  				b := dAtA[iNdEx]
  3671  				iNdEx++
  3672  				v |= (int(b) & 0x7F) << shift
  3673  				if b < 0x80 {
  3674  					break
  3675  				}
  3676  			}
  3677  			m.DisableBuffering = bool(v != 0)
  3678  		default:
  3679  			iNdEx = preIndex
  3680  			skippy, err := skipData(dAtA[iNdEx:])
  3681  			if err != nil {
  3682  				return err
  3683  			}
  3684  			if skippy < 0 {
  3685  				return ErrInvalidLengthData
  3686  			}
  3687  			if (iNdEx + skippy) > l {
  3688  				return io.ErrUnexpectedEOF
  3689  			}
  3690  			iNdEx += skippy
  3691  		}
  3692  	}
  3693  
  3694  	if iNdEx > l {
  3695  		return io.ErrUnexpectedEOF
  3696  	}
  3697  	return nil
  3698  }
  3699  func (m *OutputRouterSpec_RangeRouterSpec) Unmarshal(dAtA []byte) error {
  3700  	l := len(dAtA)
  3701  	iNdEx := 0
  3702  	for iNdEx < l {
  3703  		preIndex := iNdEx
  3704  		var wire uint64
  3705  		for shift := uint(0); ; shift += 7 {
  3706  			if shift >= 64 {
  3707  				return ErrIntOverflowData
  3708  			}
  3709  			if iNdEx >= l {
  3710  				return io.ErrUnexpectedEOF
  3711  			}
  3712  			b := dAtA[iNdEx]
  3713  			iNdEx++
  3714  			wire |= (uint64(b) & 0x7F) << shift
  3715  			if b < 0x80 {
  3716  				break
  3717  			}
  3718  		}
  3719  		fieldNum := int32(wire >> 3)
  3720  		wireType := int(wire & 0x7)
  3721  		if wireType == 4 {
  3722  			return fmt.Errorf("proto: RangeRouterSpec: wiretype end group for non-group")
  3723  		}
  3724  		if fieldNum <= 0 {
  3725  			return fmt.Errorf("proto: RangeRouterSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  3726  		}
  3727  		switch fieldNum {
  3728  		case 1:
  3729  			if wireType != 2 {
  3730  				return fmt.Errorf("proto: wrong wireType = %d for field Spans", wireType)
  3731  			}
  3732  			var msglen int
  3733  			for shift := uint(0); ; shift += 7 {
  3734  				if shift >= 64 {
  3735  					return ErrIntOverflowData
  3736  				}
  3737  				if iNdEx >= l {
  3738  					return io.ErrUnexpectedEOF
  3739  				}
  3740  				b := dAtA[iNdEx]
  3741  				iNdEx++
  3742  				msglen |= (int(b) & 0x7F) << shift
  3743  				if b < 0x80 {
  3744  					break
  3745  				}
  3746  			}
  3747  			if msglen < 0 {
  3748  				return ErrInvalidLengthData
  3749  			}
  3750  			postIndex := iNdEx + msglen
  3751  			if postIndex > l {
  3752  				return io.ErrUnexpectedEOF
  3753  			}
  3754  			m.Spans = append(m.Spans, OutputRouterSpec_RangeRouterSpec_Span{})
  3755  			if err := m.Spans[len(m.Spans)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3756  				return err
  3757  			}
  3758  			iNdEx = postIndex
  3759  		case 2:
  3760  			if wireType != 0 {
  3761  				return fmt.Errorf("proto: wrong wireType = %d for field DefaultDest", wireType)
  3762  			}
  3763  			var v int32
  3764  			for shift := uint(0); ; shift += 7 {
  3765  				if shift >= 64 {
  3766  					return ErrIntOverflowData
  3767  				}
  3768  				if iNdEx >= l {
  3769  					return io.ErrUnexpectedEOF
  3770  				}
  3771  				b := dAtA[iNdEx]
  3772  				iNdEx++
  3773  				v |= (int32(b) & 0x7F) << shift
  3774  				if b < 0x80 {
  3775  					break
  3776  				}
  3777  			}
  3778  			m.DefaultDest = &v
  3779  		case 3:
  3780  			if wireType != 2 {
  3781  				return fmt.Errorf("proto: wrong wireType = %d for field Encodings", wireType)
  3782  			}
  3783  			var msglen int
  3784  			for shift := uint(0); ; shift += 7 {
  3785  				if shift >= 64 {
  3786  					return ErrIntOverflowData
  3787  				}
  3788  				if iNdEx >= l {
  3789  					return io.ErrUnexpectedEOF
  3790  				}
  3791  				b := dAtA[iNdEx]
  3792  				iNdEx++
  3793  				msglen |= (int(b) & 0x7F) << shift
  3794  				if b < 0x80 {
  3795  					break
  3796  				}
  3797  			}
  3798  			if msglen < 0 {
  3799  				return ErrInvalidLengthData
  3800  			}
  3801  			postIndex := iNdEx + msglen
  3802  			if postIndex > l {
  3803  				return io.ErrUnexpectedEOF
  3804  			}
  3805  			m.Encodings = append(m.Encodings, OutputRouterSpec_RangeRouterSpec_ColumnEncoding{})
  3806  			if err := m.Encodings[len(m.Encodings)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  3807  				return err
  3808  			}
  3809  			iNdEx = postIndex
  3810  		default:
  3811  			iNdEx = preIndex
  3812  			skippy, err := skipData(dAtA[iNdEx:])
  3813  			if err != nil {
  3814  				return err
  3815  			}
  3816  			if skippy < 0 {
  3817  				return ErrInvalidLengthData
  3818  			}
  3819  			if (iNdEx + skippy) > l {
  3820  				return io.ErrUnexpectedEOF
  3821  			}
  3822  			iNdEx += skippy
  3823  		}
  3824  	}
  3825  
  3826  	if iNdEx > l {
  3827  		return io.ErrUnexpectedEOF
  3828  	}
  3829  	return nil
  3830  }
  3831  func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Unmarshal(dAtA []byte) error {
  3832  	l := len(dAtA)
  3833  	iNdEx := 0
  3834  	for iNdEx < l {
  3835  		preIndex := iNdEx
  3836  		var wire uint64
  3837  		for shift := uint(0); ; shift += 7 {
  3838  			if shift >= 64 {
  3839  				return ErrIntOverflowData
  3840  			}
  3841  			if iNdEx >= l {
  3842  				return io.ErrUnexpectedEOF
  3843  			}
  3844  			b := dAtA[iNdEx]
  3845  			iNdEx++
  3846  			wire |= (uint64(b) & 0x7F) << shift
  3847  			if b < 0x80 {
  3848  				break
  3849  			}
  3850  		}
  3851  		fieldNum := int32(wire >> 3)
  3852  		wireType := int(wire & 0x7)
  3853  		if wireType == 4 {
  3854  			return fmt.Errorf("proto: ColumnEncoding: wiretype end group for non-group")
  3855  		}
  3856  		if fieldNum <= 0 {
  3857  			return fmt.Errorf("proto: ColumnEncoding: illegal tag %d (wire type %d)", fieldNum, wire)
  3858  		}
  3859  		switch fieldNum {
  3860  		case 1:
  3861  			if wireType != 0 {
  3862  				return fmt.Errorf("proto: wrong wireType = %d for field Column", wireType)
  3863  			}
  3864  			m.Column = 0
  3865  			for shift := uint(0); ; shift += 7 {
  3866  				if shift >= 64 {
  3867  					return ErrIntOverflowData
  3868  				}
  3869  				if iNdEx >= l {
  3870  					return io.ErrUnexpectedEOF
  3871  				}
  3872  				b := dAtA[iNdEx]
  3873  				iNdEx++
  3874  				m.Column |= (uint32(b) & 0x7F) << shift
  3875  				if b < 0x80 {
  3876  					break
  3877  				}
  3878  			}
  3879  		case 2:
  3880  			if wireType != 0 {
  3881  				return fmt.Errorf("proto: wrong wireType = %d for field Encoding", wireType)
  3882  			}
  3883  			m.Encoding = 0
  3884  			for shift := uint(0); ; shift += 7 {
  3885  				if shift >= 64 {
  3886  					return ErrIntOverflowData
  3887  				}
  3888  				if iNdEx >= l {
  3889  					return io.ErrUnexpectedEOF
  3890  				}
  3891  				b := dAtA[iNdEx]
  3892  				iNdEx++
  3893  				m.Encoding |= (sqlbase.DatumEncoding(b) & 0x7F) << shift
  3894  				if b < 0x80 {
  3895  					break
  3896  				}
  3897  			}
  3898  		default:
  3899  			iNdEx = preIndex
  3900  			skippy, err := skipData(dAtA[iNdEx:])
  3901  			if err != nil {
  3902  				return err
  3903  			}
  3904  			if skippy < 0 {
  3905  				return ErrInvalidLengthData
  3906  			}
  3907  			if (iNdEx + skippy) > l {
  3908  				return io.ErrUnexpectedEOF
  3909  			}
  3910  			iNdEx += skippy
  3911  		}
  3912  	}
  3913  
  3914  	if iNdEx > l {
  3915  		return io.ErrUnexpectedEOF
  3916  	}
  3917  	return nil
  3918  }
  3919  func (m *OutputRouterSpec_RangeRouterSpec_Span) Unmarshal(dAtA []byte) error {
  3920  	l := len(dAtA)
  3921  	iNdEx := 0
  3922  	for iNdEx < l {
  3923  		preIndex := iNdEx
  3924  		var wire uint64
  3925  		for shift := uint(0); ; shift += 7 {
  3926  			if shift >= 64 {
  3927  				return ErrIntOverflowData
  3928  			}
  3929  			if iNdEx >= l {
  3930  				return io.ErrUnexpectedEOF
  3931  			}
  3932  			b := dAtA[iNdEx]
  3933  			iNdEx++
  3934  			wire |= (uint64(b) & 0x7F) << shift
  3935  			if b < 0x80 {
  3936  				break
  3937  			}
  3938  		}
  3939  		fieldNum := int32(wire >> 3)
  3940  		wireType := int(wire & 0x7)
  3941  		if wireType == 4 {
  3942  			return fmt.Errorf("proto: Span: wiretype end group for non-group")
  3943  		}
  3944  		if fieldNum <= 0 {
  3945  			return fmt.Errorf("proto: Span: illegal tag %d (wire type %d)", fieldNum, wire)
  3946  		}
  3947  		switch fieldNum {
  3948  		case 1:
  3949  			if wireType != 2 {
  3950  				return fmt.Errorf("proto: wrong wireType = %d for field Start", wireType)
  3951  			}
  3952  			var byteLen int
  3953  			for shift := uint(0); ; shift += 7 {
  3954  				if shift >= 64 {
  3955  					return ErrIntOverflowData
  3956  				}
  3957  				if iNdEx >= l {
  3958  					return io.ErrUnexpectedEOF
  3959  				}
  3960  				b := dAtA[iNdEx]
  3961  				iNdEx++
  3962  				byteLen |= (int(b) & 0x7F) << shift
  3963  				if b < 0x80 {
  3964  					break
  3965  				}
  3966  			}
  3967  			if byteLen < 0 {
  3968  				return ErrInvalidLengthData
  3969  			}
  3970  			postIndex := iNdEx + byteLen
  3971  			if postIndex > l {
  3972  				return io.ErrUnexpectedEOF
  3973  			}
  3974  			m.Start = append(m.Start[:0], dAtA[iNdEx:postIndex]...)
  3975  			if m.Start == nil {
  3976  				m.Start = []byte{}
  3977  			}
  3978  			iNdEx = postIndex
  3979  		case 2:
  3980  			if wireType != 2 {
  3981  				return fmt.Errorf("proto: wrong wireType = %d for field End", wireType)
  3982  			}
  3983  			var byteLen int
  3984  			for shift := uint(0); ; shift += 7 {
  3985  				if shift >= 64 {
  3986  					return ErrIntOverflowData
  3987  				}
  3988  				if iNdEx >= l {
  3989  					return io.ErrUnexpectedEOF
  3990  				}
  3991  				b := dAtA[iNdEx]
  3992  				iNdEx++
  3993  				byteLen |= (int(b) & 0x7F) << shift
  3994  				if b < 0x80 {
  3995  					break
  3996  				}
  3997  			}
  3998  			if byteLen < 0 {
  3999  				return ErrInvalidLengthData
  4000  			}
  4001  			postIndex := iNdEx + byteLen
  4002  			if postIndex > l {
  4003  				return io.ErrUnexpectedEOF
  4004  			}
  4005  			m.End = append(m.End[:0], dAtA[iNdEx:postIndex]...)
  4006  			if m.End == nil {
  4007  				m.End = []byte{}
  4008  			}
  4009  			iNdEx = postIndex
  4010  		case 3:
  4011  			if wireType != 0 {
  4012  				return fmt.Errorf("proto: wrong wireType = %d for field Stream", wireType)
  4013  			}
  4014  			m.Stream = 0
  4015  			for shift := uint(0); ; shift += 7 {
  4016  				if shift >= 64 {
  4017  					return ErrIntOverflowData
  4018  				}
  4019  				if iNdEx >= l {
  4020  					return io.ErrUnexpectedEOF
  4021  				}
  4022  				b := dAtA[iNdEx]
  4023  				iNdEx++
  4024  				m.Stream |= (int32(b) & 0x7F) << shift
  4025  				if b < 0x80 {
  4026  					break
  4027  				}
  4028  			}
  4029  		default:
  4030  			iNdEx = preIndex
  4031  			skippy, err := skipData(dAtA[iNdEx:])
  4032  			if err != nil {
  4033  				return err
  4034  			}
  4035  			if skippy < 0 {
  4036  				return ErrInvalidLengthData
  4037  			}
  4038  			if (iNdEx + skippy) > l {
  4039  				return io.ErrUnexpectedEOF
  4040  			}
  4041  			iNdEx += skippy
  4042  		}
  4043  	}
  4044  
  4045  	if iNdEx > l {
  4046  		return io.ErrUnexpectedEOF
  4047  	}
  4048  	return nil
  4049  }
  4050  func (m *DatumInfo) Unmarshal(dAtA []byte) error {
  4051  	l := len(dAtA)
  4052  	iNdEx := 0
  4053  	for iNdEx < l {
  4054  		preIndex := iNdEx
  4055  		var wire uint64
  4056  		for shift := uint(0); ; shift += 7 {
  4057  			if shift >= 64 {
  4058  				return ErrIntOverflowData
  4059  			}
  4060  			if iNdEx >= l {
  4061  				return io.ErrUnexpectedEOF
  4062  			}
  4063  			b := dAtA[iNdEx]
  4064  			iNdEx++
  4065  			wire |= (uint64(b) & 0x7F) << shift
  4066  			if b < 0x80 {
  4067  				break
  4068  			}
  4069  		}
  4070  		fieldNum := int32(wire >> 3)
  4071  		wireType := int(wire & 0x7)
  4072  		if wireType == 4 {
  4073  			return fmt.Errorf("proto: DatumInfo: wiretype end group for non-group")
  4074  		}
  4075  		if fieldNum <= 0 {
  4076  			return fmt.Errorf("proto: DatumInfo: illegal tag %d (wire type %d)", fieldNum, wire)
  4077  		}
  4078  		switch fieldNum {
  4079  		case 1:
  4080  			if wireType != 0 {
  4081  				return fmt.Errorf("proto: wrong wireType = %d for field Encoding", wireType)
  4082  			}
  4083  			m.Encoding = 0
  4084  			for shift := uint(0); ; shift += 7 {
  4085  				if shift >= 64 {
  4086  					return ErrIntOverflowData
  4087  				}
  4088  				if iNdEx >= l {
  4089  					return io.ErrUnexpectedEOF
  4090  				}
  4091  				b := dAtA[iNdEx]
  4092  				iNdEx++
  4093  				m.Encoding |= (sqlbase.DatumEncoding(b) & 0x7F) << shift
  4094  				if b < 0x80 {
  4095  					break
  4096  				}
  4097  			}
  4098  		case 2:
  4099  			if wireType != 2 {
  4100  				return fmt.Errorf("proto: wrong wireType = %d for field Type", wireType)
  4101  			}
  4102  			var msglen int
  4103  			for shift := uint(0); ; shift += 7 {
  4104  				if shift >= 64 {
  4105  					return ErrIntOverflowData
  4106  				}
  4107  				if iNdEx >= l {
  4108  					return io.ErrUnexpectedEOF
  4109  				}
  4110  				b := dAtA[iNdEx]
  4111  				iNdEx++
  4112  				msglen |= (int(b) & 0x7F) << shift
  4113  				if b < 0x80 {
  4114  					break
  4115  				}
  4116  			}
  4117  			if msglen < 0 {
  4118  				return ErrInvalidLengthData
  4119  			}
  4120  			postIndex := iNdEx + msglen
  4121  			if postIndex > l {
  4122  				return io.ErrUnexpectedEOF
  4123  			}
  4124  			if m.Type == nil {
  4125  				m.Type = &types.T{}
  4126  			}
  4127  			if err := m.Type.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4128  				return err
  4129  			}
  4130  			iNdEx = postIndex
  4131  		default:
  4132  			iNdEx = preIndex
  4133  			skippy, err := skipData(dAtA[iNdEx:])
  4134  			if err != nil {
  4135  				return err
  4136  			}
  4137  			if skippy < 0 {
  4138  				return ErrInvalidLengthData
  4139  			}
  4140  			if (iNdEx + skippy) > l {
  4141  				return io.ErrUnexpectedEOF
  4142  			}
  4143  			iNdEx += skippy
  4144  		}
  4145  	}
  4146  
  4147  	if iNdEx > l {
  4148  		return io.ErrUnexpectedEOF
  4149  	}
  4150  	return nil
  4151  }
  4152  func (m *ProducerHeader) Unmarshal(dAtA []byte) error {
  4153  	l := len(dAtA)
  4154  	iNdEx := 0
  4155  	for iNdEx < l {
  4156  		preIndex := iNdEx
  4157  		var wire uint64
  4158  		for shift := uint(0); ; shift += 7 {
  4159  			if shift >= 64 {
  4160  				return ErrIntOverflowData
  4161  			}
  4162  			if iNdEx >= l {
  4163  				return io.ErrUnexpectedEOF
  4164  			}
  4165  			b := dAtA[iNdEx]
  4166  			iNdEx++
  4167  			wire |= (uint64(b) & 0x7F) << shift
  4168  			if b < 0x80 {
  4169  				break
  4170  			}
  4171  		}
  4172  		fieldNum := int32(wire >> 3)
  4173  		wireType := int(wire & 0x7)
  4174  		if wireType == 4 {
  4175  			return fmt.Errorf("proto: ProducerHeader: wiretype end group for non-group")
  4176  		}
  4177  		if fieldNum <= 0 {
  4178  			return fmt.Errorf("proto: ProducerHeader: illegal tag %d (wire type %d)", fieldNum, wire)
  4179  		}
  4180  		switch fieldNum {
  4181  		case 1:
  4182  			if wireType != 2 {
  4183  				return fmt.Errorf("proto: wrong wireType = %d for field FlowID", wireType)
  4184  			}
  4185  			var byteLen int
  4186  			for shift := uint(0); ; shift += 7 {
  4187  				if shift >= 64 {
  4188  					return ErrIntOverflowData
  4189  				}
  4190  				if iNdEx >= l {
  4191  					return io.ErrUnexpectedEOF
  4192  				}
  4193  				b := dAtA[iNdEx]
  4194  				iNdEx++
  4195  				byteLen |= (int(b) & 0x7F) << shift
  4196  				if b < 0x80 {
  4197  					break
  4198  				}
  4199  			}
  4200  			if byteLen < 0 {
  4201  				return ErrInvalidLengthData
  4202  			}
  4203  			postIndex := iNdEx + byteLen
  4204  			if postIndex > l {
  4205  				return io.ErrUnexpectedEOF
  4206  			}
  4207  			if err := m.FlowID.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4208  				return err
  4209  			}
  4210  			iNdEx = postIndex
  4211  		case 2:
  4212  			if wireType != 0 {
  4213  				return fmt.Errorf("proto: wrong wireType = %d for field StreamID", wireType)
  4214  			}
  4215  			m.StreamID = 0
  4216  			for shift := uint(0); ; shift += 7 {
  4217  				if shift >= 64 {
  4218  					return ErrIntOverflowData
  4219  				}
  4220  				if iNdEx >= l {
  4221  					return io.ErrUnexpectedEOF
  4222  				}
  4223  				b := dAtA[iNdEx]
  4224  				iNdEx++
  4225  				m.StreamID |= (StreamID(b) & 0x7F) << shift
  4226  				if b < 0x80 {
  4227  					break
  4228  				}
  4229  			}
  4230  		default:
  4231  			iNdEx = preIndex
  4232  			skippy, err := skipData(dAtA[iNdEx:])
  4233  			if err != nil {
  4234  				return err
  4235  			}
  4236  			if skippy < 0 {
  4237  				return ErrInvalidLengthData
  4238  			}
  4239  			if (iNdEx + skippy) > l {
  4240  				return io.ErrUnexpectedEOF
  4241  			}
  4242  			iNdEx += skippy
  4243  		}
  4244  	}
  4245  
  4246  	if iNdEx > l {
  4247  		return io.ErrUnexpectedEOF
  4248  	}
  4249  	return nil
  4250  }
  4251  func (m *ProducerData) Unmarshal(dAtA []byte) error {
  4252  	l := len(dAtA)
  4253  	iNdEx := 0
  4254  	for iNdEx < l {
  4255  		preIndex := iNdEx
  4256  		var wire uint64
  4257  		for shift := uint(0); ; shift += 7 {
  4258  			if shift >= 64 {
  4259  				return ErrIntOverflowData
  4260  			}
  4261  			if iNdEx >= l {
  4262  				return io.ErrUnexpectedEOF
  4263  			}
  4264  			b := dAtA[iNdEx]
  4265  			iNdEx++
  4266  			wire |= (uint64(b) & 0x7F) << shift
  4267  			if b < 0x80 {
  4268  				break
  4269  			}
  4270  		}
  4271  		fieldNum := int32(wire >> 3)
  4272  		wireType := int(wire & 0x7)
  4273  		if wireType == 4 {
  4274  			return fmt.Errorf("proto: ProducerData: wiretype end group for non-group")
  4275  		}
  4276  		if fieldNum <= 0 {
  4277  			return fmt.Errorf("proto: ProducerData: illegal tag %d (wire type %d)", fieldNum, wire)
  4278  		}
  4279  		switch fieldNum {
  4280  		case 1:
  4281  			if wireType != 2 {
  4282  				return fmt.Errorf("proto: wrong wireType = %d for field RawBytes", wireType)
  4283  			}
  4284  			var byteLen int
  4285  			for shift := uint(0); ; shift += 7 {
  4286  				if shift >= 64 {
  4287  					return ErrIntOverflowData
  4288  				}
  4289  				if iNdEx >= l {
  4290  					return io.ErrUnexpectedEOF
  4291  				}
  4292  				b := dAtA[iNdEx]
  4293  				iNdEx++
  4294  				byteLen |= (int(b) & 0x7F) << shift
  4295  				if b < 0x80 {
  4296  					break
  4297  				}
  4298  			}
  4299  			if byteLen < 0 {
  4300  				return ErrInvalidLengthData
  4301  			}
  4302  			postIndex := iNdEx + byteLen
  4303  			if postIndex > l {
  4304  				return io.ErrUnexpectedEOF
  4305  			}
  4306  			m.RawBytes = append(m.RawBytes[:0], dAtA[iNdEx:postIndex]...)
  4307  			if m.RawBytes == nil {
  4308  				m.RawBytes = []byte{}
  4309  			}
  4310  			iNdEx = postIndex
  4311  		case 2:
  4312  			if wireType != 2 {
  4313  				return fmt.Errorf("proto: wrong wireType = %d for field Metadata", wireType)
  4314  			}
  4315  			var msglen int
  4316  			for shift := uint(0); ; shift += 7 {
  4317  				if shift >= 64 {
  4318  					return ErrIntOverflowData
  4319  				}
  4320  				if iNdEx >= l {
  4321  					return io.ErrUnexpectedEOF
  4322  				}
  4323  				b := dAtA[iNdEx]
  4324  				iNdEx++
  4325  				msglen |= (int(b) & 0x7F) << shift
  4326  				if b < 0x80 {
  4327  					break
  4328  				}
  4329  			}
  4330  			if msglen < 0 {
  4331  				return ErrInvalidLengthData
  4332  			}
  4333  			postIndex := iNdEx + msglen
  4334  			if postIndex > l {
  4335  				return io.ErrUnexpectedEOF
  4336  			}
  4337  			m.Metadata = append(m.Metadata, RemoteProducerMetadata{})
  4338  			if err := m.Metadata[len(m.Metadata)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4339  				return err
  4340  			}
  4341  			iNdEx = postIndex
  4342  		case 3:
  4343  			if wireType != 0 {
  4344  				return fmt.Errorf("proto: wrong wireType = %d for field NumEmptyRows", wireType)
  4345  			}
  4346  			m.NumEmptyRows = 0
  4347  			for shift := uint(0); ; shift += 7 {
  4348  				if shift >= 64 {
  4349  					return ErrIntOverflowData
  4350  				}
  4351  				if iNdEx >= l {
  4352  					return io.ErrUnexpectedEOF
  4353  				}
  4354  				b := dAtA[iNdEx]
  4355  				iNdEx++
  4356  				m.NumEmptyRows |= (int32(b) & 0x7F) << shift
  4357  				if b < 0x80 {
  4358  					break
  4359  				}
  4360  			}
  4361  		default:
  4362  			iNdEx = preIndex
  4363  			skippy, err := skipData(dAtA[iNdEx:])
  4364  			if err != nil {
  4365  				return err
  4366  			}
  4367  			if skippy < 0 {
  4368  				return ErrInvalidLengthData
  4369  			}
  4370  			if (iNdEx + skippy) > l {
  4371  				return io.ErrUnexpectedEOF
  4372  			}
  4373  			iNdEx += skippy
  4374  		}
  4375  	}
  4376  
  4377  	if iNdEx > l {
  4378  		return io.ErrUnexpectedEOF
  4379  	}
  4380  	return nil
  4381  }
  4382  func (m *ProducerMessage) Unmarshal(dAtA []byte) error {
  4383  	l := len(dAtA)
  4384  	iNdEx := 0
  4385  	for iNdEx < l {
  4386  		preIndex := iNdEx
  4387  		var wire uint64
  4388  		for shift := uint(0); ; shift += 7 {
  4389  			if shift >= 64 {
  4390  				return ErrIntOverflowData
  4391  			}
  4392  			if iNdEx >= l {
  4393  				return io.ErrUnexpectedEOF
  4394  			}
  4395  			b := dAtA[iNdEx]
  4396  			iNdEx++
  4397  			wire |= (uint64(b) & 0x7F) << shift
  4398  			if b < 0x80 {
  4399  				break
  4400  			}
  4401  		}
  4402  		fieldNum := int32(wire >> 3)
  4403  		wireType := int(wire & 0x7)
  4404  		if wireType == 4 {
  4405  			return fmt.Errorf("proto: ProducerMessage: wiretype end group for non-group")
  4406  		}
  4407  		if fieldNum <= 0 {
  4408  			return fmt.Errorf("proto: ProducerMessage: illegal tag %d (wire type %d)", fieldNum, wire)
  4409  		}
  4410  		switch fieldNum {
  4411  		case 1:
  4412  			if wireType != 2 {
  4413  				return fmt.Errorf("proto: wrong wireType = %d for field Header", wireType)
  4414  			}
  4415  			var msglen int
  4416  			for shift := uint(0); ; shift += 7 {
  4417  				if shift >= 64 {
  4418  					return ErrIntOverflowData
  4419  				}
  4420  				if iNdEx >= l {
  4421  					return io.ErrUnexpectedEOF
  4422  				}
  4423  				b := dAtA[iNdEx]
  4424  				iNdEx++
  4425  				msglen |= (int(b) & 0x7F) << shift
  4426  				if b < 0x80 {
  4427  					break
  4428  				}
  4429  			}
  4430  			if msglen < 0 {
  4431  				return ErrInvalidLengthData
  4432  			}
  4433  			postIndex := iNdEx + msglen
  4434  			if postIndex > l {
  4435  				return io.ErrUnexpectedEOF
  4436  			}
  4437  			if m.Header == nil {
  4438  				m.Header = &ProducerHeader{}
  4439  			}
  4440  			if err := m.Header.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4441  				return err
  4442  			}
  4443  			iNdEx = postIndex
  4444  		case 2:
  4445  			if wireType != 2 {
  4446  				return fmt.Errorf("proto: wrong wireType = %d for field Typing", wireType)
  4447  			}
  4448  			var msglen int
  4449  			for shift := uint(0); ; shift += 7 {
  4450  				if shift >= 64 {
  4451  					return ErrIntOverflowData
  4452  				}
  4453  				if iNdEx >= l {
  4454  					return io.ErrUnexpectedEOF
  4455  				}
  4456  				b := dAtA[iNdEx]
  4457  				iNdEx++
  4458  				msglen |= (int(b) & 0x7F) << shift
  4459  				if b < 0x80 {
  4460  					break
  4461  				}
  4462  			}
  4463  			if msglen < 0 {
  4464  				return ErrInvalidLengthData
  4465  			}
  4466  			postIndex := iNdEx + msglen
  4467  			if postIndex > l {
  4468  				return io.ErrUnexpectedEOF
  4469  			}
  4470  			m.Typing = append(m.Typing, DatumInfo{})
  4471  			if err := m.Typing[len(m.Typing)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4472  				return err
  4473  			}
  4474  			iNdEx = postIndex
  4475  		case 3:
  4476  			if wireType != 2 {
  4477  				return fmt.Errorf("proto: wrong wireType = %d for field Data", wireType)
  4478  			}
  4479  			var msglen int
  4480  			for shift := uint(0); ; shift += 7 {
  4481  				if shift >= 64 {
  4482  					return ErrIntOverflowData
  4483  				}
  4484  				if iNdEx >= l {
  4485  					return io.ErrUnexpectedEOF
  4486  				}
  4487  				b := dAtA[iNdEx]
  4488  				iNdEx++
  4489  				msglen |= (int(b) & 0x7F) << shift
  4490  				if b < 0x80 {
  4491  					break
  4492  				}
  4493  			}
  4494  			if msglen < 0 {
  4495  				return ErrInvalidLengthData
  4496  			}
  4497  			postIndex := iNdEx + msglen
  4498  			if postIndex > l {
  4499  				return io.ErrUnexpectedEOF
  4500  			}
  4501  			if err := m.Data.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4502  				return err
  4503  			}
  4504  			iNdEx = postIndex
  4505  		default:
  4506  			iNdEx = preIndex
  4507  			skippy, err := skipData(dAtA[iNdEx:])
  4508  			if err != nil {
  4509  				return err
  4510  			}
  4511  			if skippy < 0 {
  4512  				return ErrInvalidLengthData
  4513  			}
  4514  			if (iNdEx + skippy) > l {
  4515  				return io.ErrUnexpectedEOF
  4516  			}
  4517  			iNdEx += skippy
  4518  		}
  4519  	}
  4520  
  4521  	if iNdEx > l {
  4522  		return io.ErrUnexpectedEOF
  4523  	}
  4524  	return nil
  4525  }
  4526  func (m *RemoteProducerMetadata) Unmarshal(dAtA []byte) error {
  4527  	l := len(dAtA)
  4528  	iNdEx := 0
  4529  	for iNdEx < l {
  4530  		preIndex := iNdEx
  4531  		var wire uint64
  4532  		for shift := uint(0); ; shift += 7 {
  4533  			if shift >= 64 {
  4534  				return ErrIntOverflowData
  4535  			}
  4536  			if iNdEx >= l {
  4537  				return io.ErrUnexpectedEOF
  4538  			}
  4539  			b := dAtA[iNdEx]
  4540  			iNdEx++
  4541  			wire |= (uint64(b) & 0x7F) << shift
  4542  			if b < 0x80 {
  4543  				break
  4544  			}
  4545  		}
  4546  		fieldNum := int32(wire >> 3)
  4547  		wireType := int(wire & 0x7)
  4548  		if wireType == 4 {
  4549  			return fmt.Errorf("proto: RemoteProducerMetadata: wiretype end group for non-group")
  4550  		}
  4551  		if fieldNum <= 0 {
  4552  			return fmt.Errorf("proto: RemoteProducerMetadata: illegal tag %d (wire type %d)", fieldNum, wire)
  4553  		}
  4554  		switch fieldNum {
  4555  		case 1:
  4556  			if wireType != 2 {
  4557  				return fmt.Errorf("proto: wrong wireType = %d for field RangeInfo", wireType)
  4558  			}
  4559  			var msglen int
  4560  			for shift := uint(0); ; shift += 7 {
  4561  				if shift >= 64 {
  4562  					return ErrIntOverflowData
  4563  				}
  4564  				if iNdEx >= l {
  4565  					return io.ErrUnexpectedEOF
  4566  				}
  4567  				b := dAtA[iNdEx]
  4568  				iNdEx++
  4569  				msglen |= (int(b) & 0x7F) << shift
  4570  				if b < 0x80 {
  4571  					break
  4572  				}
  4573  			}
  4574  			if msglen < 0 {
  4575  				return ErrInvalidLengthData
  4576  			}
  4577  			postIndex := iNdEx + msglen
  4578  			if postIndex > l {
  4579  				return io.ErrUnexpectedEOF
  4580  			}
  4581  			v := &RemoteProducerMetadata_RangeInfos{}
  4582  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4583  				return err
  4584  			}
  4585  			m.Value = &RemoteProducerMetadata_RangeInfo{v}
  4586  			iNdEx = postIndex
  4587  		case 2:
  4588  			if wireType != 2 {
  4589  				return fmt.Errorf("proto: wrong wireType = %d for field Error", wireType)
  4590  			}
  4591  			var msglen int
  4592  			for shift := uint(0); ; shift += 7 {
  4593  				if shift >= 64 {
  4594  					return ErrIntOverflowData
  4595  				}
  4596  				if iNdEx >= l {
  4597  					return io.ErrUnexpectedEOF
  4598  				}
  4599  				b := dAtA[iNdEx]
  4600  				iNdEx++
  4601  				msglen |= (int(b) & 0x7F) << shift
  4602  				if b < 0x80 {
  4603  					break
  4604  				}
  4605  			}
  4606  			if msglen < 0 {
  4607  				return ErrInvalidLengthData
  4608  			}
  4609  			postIndex := iNdEx + msglen
  4610  			if postIndex > l {
  4611  				return io.ErrUnexpectedEOF
  4612  			}
  4613  			v := &Error{}
  4614  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4615  				return err
  4616  			}
  4617  			m.Value = &RemoteProducerMetadata_Error{v}
  4618  			iNdEx = postIndex
  4619  		case 3:
  4620  			if wireType != 2 {
  4621  				return fmt.Errorf("proto: wrong wireType = %d for field TraceData", wireType)
  4622  			}
  4623  			var msglen int
  4624  			for shift := uint(0); ; shift += 7 {
  4625  				if shift >= 64 {
  4626  					return ErrIntOverflowData
  4627  				}
  4628  				if iNdEx >= l {
  4629  					return io.ErrUnexpectedEOF
  4630  				}
  4631  				b := dAtA[iNdEx]
  4632  				iNdEx++
  4633  				msglen |= (int(b) & 0x7F) << shift
  4634  				if b < 0x80 {
  4635  					break
  4636  				}
  4637  			}
  4638  			if msglen < 0 {
  4639  				return ErrInvalidLengthData
  4640  			}
  4641  			postIndex := iNdEx + msglen
  4642  			if postIndex > l {
  4643  				return io.ErrUnexpectedEOF
  4644  			}
  4645  			v := &RemoteProducerMetadata_TraceData{}
  4646  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4647  				return err
  4648  			}
  4649  			m.Value = &RemoteProducerMetadata_TraceData_{v}
  4650  			iNdEx = postIndex
  4651  		case 4:
  4652  			if wireType != 2 {
  4653  				return fmt.Errorf("proto: wrong wireType = %d for field LeafTxnFinalState", wireType)
  4654  			}
  4655  			var msglen int
  4656  			for shift := uint(0); ; shift += 7 {
  4657  				if shift >= 64 {
  4658  					return ErrIntOverflowData
  4659  				}
  4660  				if iNdEx >= l {
  4661  					return io.ErrUnexpectedEOF
  4662  				}
  4663  				b := dAtA[iNdEx]
  4664  				iNdEx++
  4665  				msglen |= (int(b) & 0x7F) << shift
  4666  				if b < 0x80 {
  4667  					break
  4668  				}
  4669  			}
  4670  			if msglen < 0 {
  4671  				return ErrInvalidLengthData
  4672  			}
  4673  			postIndex := iNdEx + msglen
  4674  			if postIndex > l {
  4675  				return io.ErrUnexpectedEOF
  4676  			}
  4677  			v := &roachpb.LeafTxnFinalState{}
  4678  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4679  				return err
  4680  			}
  4681  			m.Value = &RemoteProducerMetadata_LeafTxnFinalState{v}
  4682  			iNdEx = postIndex
  4683  		case 5:
  4684  			if wireType != 2 {
  4685  				return fmt.Errorf("proto: wrong wireType = %d for field RowNum", wireType)
  4686  			}
  4687  			var msglen int
  4688  			for shift := uint(0); ; shift += 7 {
  4689  				if shift >= 64 {
  4690  					return ErrIntOverflowData
  4691  				}
  4692  				if iNdEx >= l {
  4693  					return io.ErrUnexpectedEOF
  4694  				}
  4695  				b := dAtA[iNdEx]
  4696  				iNdEx++
  4697  				msglen |= (int(b) & 0x7F) << shift
  4698  				if b < 0x80 {
  4699  					break
  4700  				}
  4701  			}
  4702  			if msglen < 0 {
  4703  				return ErrInvalidLengthData
  4704  			}
  4705  			postIndex := iNdEx + msglen
  4706  			if postIndex > l {
  4707  				return io.ErrUnexpectedEOF
  4708  			}
  4709  			v := &RemoteProducerMetadata_RowNum{}
  4710  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4711  				return err
  4712  			}
  4713  			m.Value = &RemoteProducerMetadata_RowNum_{v}
  4714  			iNdEx = postIndex
  4715  		case 7:
  4716  			if wireType != 2 {
  4717  				return fmt.Errorf("proto: wrong wireType = %d for field SamplerProgress", wireType)
  4718  			}
  4719  			var msglen int
  4720  			for shift := uint(0); ; shift += 7 {
  4721  				if shift >= 64 {
  4722  					return ErrIntOverflowData
  4723  				}
  4724  				if iNdEx >= l {
  4725  					return io.ErrUnexpectedEOF
  4726  				}
  4727  				b := dAtA[iNdEx]
  4728  				iNdEx++
  4729  				msglen |= (int(b) & 0x7F) << shift
  4730  				if b < 0x80 {
  4731  					break
  4732  				}
  4733  			}
  4734  			if msglen < 0 {
  4735  				return ErrInvalidLengthData
  4736  			}
  4737  			postIndex := iNdEx + msglen
  4738  			if postIndex > l {
  4739  				return io.ErrUnexpectedEOF
  4740  			}
  4741  			v := &RemoteProducerMetadata_SamplerProgress{}
  4742  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4743  				return err
  4744  			}
  4745  			m.Value = &RemoteProducerMetadata_SamplerProgress_{v}
  4746  			iNdEx = postIndex
  4747  		case 8:
  4748  			if wireType != 2 {
  4749  				return fmt.Errorf("proto: wrong wireType = %d for field Metrics", wireType)
  4750  			}
  4751  			var msglen int
  4752  			for shift := uint(0); ; shift += 7 {
  4753  				if shift >= 64 {
  4754  					return ErrIntOverflowData
  4755  				}
  4756  				if iNdEx >= l {
  4757  					return io.ErrUnexpectedEOF
  4758  				}
  4759  				b := dAtA[iNdEx]
  4760  				iNdEx++
  4761  				msglen |= (int(b) & 0x7F) << shift
  4762  				if b < 0x80 {
  4763  					break
  4764  				}
  4765  			}
  4766  			if msglen < 0 {
  4767  				return ErrInvalidLengthData
  4768  			}
  4769  			postIndex := iNdEx + msglen
  4770  			if postIndex > l {
  4771  				return io.ErrUnexpectedEOF
  4772  			}
  4773  			v := &RemoteProducerMetadata_Metrics{}
  4774  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4775  				return err
  4776  			}
  4777  			m.Value = &RemoteProducerMetadata_Metrics_{v}
  4778  			iNdEx = postIndex
  4779  		case 9:
  4780  			if wireType != 2 {
  4781  				return fmt.Errorf("proto: wrong wireType = %d for field BulkProcessorProgress", wireType)
  4782  			}
  4783  			var msglen int
  4784  			for shift := uint(0); ; shift += 7 {
  4785  				if shift >= 64 {
  4786  					return ErrIntOverflowData
  4787  				}
  4788  				if iNdEx >= l {
  4789  					return io.ErrUnexpectedEOF
  4790  				}
  4791  				b := dAtA[iNdEx]
  4792  				iNdEx++
  4793  				msglen |= (int(b) & 0x7F) << shift
  4794  				if b < 0x80 {
  4795  					break
  4796  				}
  4797  			}
  4798  			if msglen < 0 {
  4799  				return ErrInvalidLengthData
  4800  			}
  4801  			postIndex := iNdEx + msglen
  4802  			if postIndex > l {
  4803  				return io.ErrUnexpectedEOF
  4804  			}
  4805  			v := &RemoteProducerMetadata_BulkProcessorProgress{}
  4806  			if err := v.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4807  				return err
  4808  			}
  4809  			m.Value = &RemoteProducerMetadata_BulkProcessorProgress_{v}
  4810  			iNdEx = postIndex
  4811  		default:
  4812  			iNdEx = preIndex
  4813  			skippy, err := skipData(dAtA[iNdEx:])
  4814  			if err != nil {
  4815  				return err
  4816  			}
  4817  			if skippy < 0 {
  4818  				return ErrInvalidLengthData
  4819  			}
  4820  			if (iNdEx + skippy) > l {
  4821  				return io.ErrUnexpectedEOF
  4822  			}
  4823  			iNdEx += skippy
  4824  		}
  4825  	}
  4826  
  4827  	if iNdEx > l {
  4828  		return io.ErrUnexpectedEOF
  4829  	}
  4830  	return nil
  4831  }
  4832  func (m *RemoteProducerMetadata_RangeInfos) Unmarshal(dAtA []byte) error {
  4833  	l := len(dAtA)
  4834  	iNdEx := 0
  4835  	for iNdEx < l {
  4836  		preIndex := iNdEx
  4837  		var wire uint64
  4838  		for shift := uint(0); ; shift += 7 {
  4839  			if shift >= 64 {
  4840  				return ErrIntOverflowData
  4841  			}
  4842  			if iNdEx >= l {
  4843  				return io.ErrUnexpectedEOF
  4844  			}
  4845  			b := dAtA[iNdEx]
  4846  			iNdEx++
  4847  			wire |= (uint64(b) & 0x7F) << shift
  4848  			if b < 0x80 {
  4849  				break
  4850  			}
  4851  		}
  4852  		fieldNum := int32(wire >> 3)
  4853  		wireType := int(wire & 0x7)
  4854  		if wireType == 4 {
  4855  			return fmt.Errorf("proto: RangeInfos: wiretype end group for non-group")
  4856  		}
  4857  		if fieldNum <= 0 {
  4858  			return fmt.Errorf("proto: RangeInfos: illegal tag %d (wire type %d)", fieldNum, wire)
  4859  		}
  4860  		switch fieldNum {
  4861  		case 1:
  4862  			if wireType != 2 {
  4863  				return fmt.Errorf("proto: wrong wireType = %d for field RangeInfo", wireType)
  4864  			}
  4865  			var msglen int
  4866  			for shift := uint(0); ; shift += 7 {
  4867  				if shift >= 64 {
  4868  					return ErrIntOverflowData
  4869  				}
  4870  				if iNdEx >= l {
  4871  					return io.ErrUnexpectedEOF
  4872  				}
  4873  				b := dAtA[iNdEx]
  4874  				iNdEx++
  4875  				msglen |= (int(b) & 0x7F) << shift
  4876  				if b < 0x80 {
  4877  					break
  4878  				}
  4879  			}
  4880  			if msglen < 0 {
  4881  				return ErrInvalidLengthData
  4882  			}
  4883  			postIndex := iNdEx + msglen
  4884  			if postIndex > l {
  4885  				return io.ErrUnexpectedEOF
  4886  			}
  4887  			m.RangeInfo = append(m.RangeInfo, roachpb.RangeInfo{})
  4888  			if err := m.RangeInfo[len(m.RangeInfo)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4889  				return err
  4890  			}
  4891  			iNdEx = postIndex
  4892  		default:
  4893  			iNdEx = preIndex
  4894  			skippy, err := skipData(dAtA[iNdEx:])
  4895  			if err != nil {
  4896  				return err
  4897  			}
  4898  			if skippy < 0 {
  4899  				return ErrInvalidLengthData
  4900  			}
  4901  			if (iNdEx + skippy) > l {
  4902  				return io.ErrUnexpectedEOF
  4903  			}
  4904  			iNdEx += skippy
  4905  		}
  4906  	}
  4907  
  4908  	if iNdEx > l {
  4909  		return io.ErrUnexpectedEOF
  4910  	}
  4911  	return nil
  4912  }
  4913  func (m *RemoteProducerMetadata_TraceData) Unmarshal(dAtA []byte) error {
  4914  	l := len(dAtA)
  4915  	iNdEx := 0
  4916  	for iNdEx < l {
  4917  		preIndex := iNdEx
  4918  		var wire uint64
  4919  		for shift := uint(0); ; shift += 7 {
  4920  			if shift >= 64 {
  4921  				return ErrIntOverflowData
  4922  			}
  4923  			if iNdEx >= l {
  4924  				return io.ErrUnexpectedEOF
  4925  			}
  4926  			b := dAtA[iNdEx]
  4927  			iNdEx++
  4928  			wire |= (uint64(b) & 0x7F) << shift
  4929  			if b < 0x80 {
  4930  				break
  4931  			}
  4932  		}
  4933  		fieldNum := int32(wire >> 3)
  4934  		wireType := int(wire & 0x7)
  4935  		if wireType == 4 {
  4936  			return fmt.Errorf("proto: TraceData: wiretype end group for non-group")
  4937  		}
  4938  		if fieldNum <= 0 {
  4939  			return fmt.Errorf("proto: TraceData: illegal tag %d (wire type %d)", fieldNum, wire)
  4940  		}
  4941  		switch fieldNum {
  4942  		case 1:
  4943  			if wireType != 2 {
  4944  				return fmt.Errorf("proto: wrong wireType = %d for field CollectedSpans", wireType)
  4945  			}
  4946  			var msglen int
  4947  			for shift := uint(0); ; shift += 7 {
  4948  				if shift >= 64 {
  4949  					return ErrIntOverflowData
  4950  				}
  4951  				if iNdEx >= l {
  4952  					return io.ErrUnexpectedEOF
  4953  				}
  4954  				b := dAtA[iNdEx]
  4955  				iNdEx++
  4956  				msglen |= (int(b) & 0x7F) << shift
  4957  				if b < 0x80 {
  4958  					break
  4959  				}
  4960  			}
  4961  			if msglen < 0 {
  4962  				return ErrInvalidLengthData
  4963  			}
  4964  			postIndex := iNdEx + msglen
  4965  			if postIndex > l {
  4966  				return io.ErrUnexpectedEOF
  4967  			}
  4968  			m.CollectedSpans = append(m.CollectedSpans, tracing.RecordedSpan{})
  4969  			if err := m.CollectedSpans[len(m.CollectedSpans)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  4970  				return err
  4971  			}
  4972  			iNdEx = postIndex
  4973  		default:
  4974  			iNdEx = preIndex
  4975  			skippy, err := skipData(dAtA[iNdEx:])
  4976  			if err != nil {
  4977  				return err
  4978  			}
  4979  			if skippy < 0 {
  4980  				return ErrInvalidLengthData
  4981  			}
  4982  			if (iNdEx + skippy) > l {
  4983  				return io.ErrUnexpectedEOF
  4984  			}
  4985  			iNdEx += skippy
  4986  		}
  4987  	}
  4988  
  4989  	if iNdEx > l {
  4990  		return io.ErrUnexpectedEOF
  4991  	}
  4992  	return nil
  4993  }
  4994  func (m *RemoteProducerMetadata_RowNum) Unmarshal(dAtA []byte) error {
  4995  	l := len(dAtA)
  4996  	iNdEx := 0
  4997  	for iNdEx < l {
  4998  		preIndex := iNdEx
  4999  		var wire uint64
  5000  		for shift := uint(0); ; shift += 7 {
  5001  			if shift >= 64 {
  5002  				return ErrIntOverflowData
  5003  			}
  5004  			if iNdEx >= l {
  5005  				return io.ErrUnexpectedEOF
  5006  			}
  5007  			b := dAtA[iNdEx]
  5008  			iNdEx++
  5009  			wire |= (uint64(b) & 0x7F) << shift
  5010  			if b < 0x80 {
  5011  				break
  5012  			}
  5013  		}
  5014  		fieldNum := int32(wire >> 3)
  5015  		wireType := int(wire & 0x7)
  5016  		if wireType == 4 {
  5017  			return fmt.Errorf("proto: RowNum: wiretype end group for non-group")
  5018  		}
  5019  		if fieldNum <= 0 {
  5020  			return fmt.Errorf("proto: RowNum: illegal tag %d (wire type %d)", fieldNum, wire)
  5021  		}
  5022  		switch fieldNum {
  5023  		case 1:
  5024  			if wireType != 2 {
  5025  				return fmt.Errorf("proto: wrong wireType = %d for field SenderID", wireType)
  5026  			}
  5027  			var stringLen uint64
  5028  			for shift := uint(0); ; shift += 7 {
  5029  				if shift >= 64 {
  5030  					return ErrIntOverflowData
  5031  				}
  5032  				if iNdEx >= l {
  5033  					return io.ErrUnexpectedEOF
  5034  				}
  5035  				b := dAtA[iNdEx]
  5036  				iNdEx++
  5037  				stringLen |= (uint64(b) & 0x7F) << shift
  5038  				if b < 0x80 {
  5039  					break
  5040  				}
  5041  			}
  5042  			intStringLen := int(stringLen)
  5043  			if intStringLen < 0 {
  5044  				return ErrInvalidLengthData
  5045  			}
  5046  			postIndex := iNdEx + intStringLen
  5047  			if postIndex > l {
  5048  				return io.ErrUnexpectedEOF
  5049  			}
  5050  			m.SenderID = string(dAtA[iNdEx:postIndex])
  5051  			iNdEx = postIndex
  5052  		case 2:
  5053  			if wireType != 0 {
  5054  				return fmt.Errorf("proto: wrong wireType = %d for field RowNum", wireType)
  5055  			}
  5056  			m.RowNum = 0
  5057  			for shift := uint(0); ; shift += 7 {
  5058  				if shift >= 64 {
  5059  					return ErrIntOverflowData
  5060  				}
  5061  				if iNdEx >= l {
  5062  					return io.ErrUnexpectedEOF
  5063  				}
  5064  				b := dAtA[iNdEx]
  5065  				iNdEx++
  5066  				m.RowNum |= (int32(b) & 0x7F) << shift
  5067  				if b < 0x80 {
  5068  					break
  5069  				}
  5070  			}
  5071  		case 3:
  5072  			if wireType != 0 {
  5073  				return fmt.Errorf("proto: wrong wireType = %d for field LastMsg", wireType)
  5074  			}
  5075  			var v int
  5076  			for shift := uint(0); ; shift += 7 {
  5077  				if shift >= 64 {
  5078  					return ErrIntOverflowData
  5079  				}
  5080  				if iNdEx >= l {
  5081  					return io.ErrUnexpectedEOF
  5082  				}
  5083  				b := dAtA[iNdEx]
  5084  				iNdEx++
  5085  				v |= (int(b) & 0x7F) << shift
  5086  				if b < 0x80 {
  5087  					break
  5088  				}
  5089  			}
  5090  			m.LastMsg = bool(v != 0)
  5091  		default:
  5092  			iNdEx = preIndex
  5093  			skippy, err := skipData(dAtA[iNdEx:])
  5094  			if err != nil {
  5095  				return err
  5096  			}
  5097  			if skippy < 0 {
  5098  				return ErrInvalidLengthData
  5099  			}
  5100  			if (iNdEx + skippy) > l {
  5101  				return io.ErrUnexpectedEOF
  5102  			}
  5103  			iNdEx += skippy
  5104  		}
  5105  	}
  5106  
  5107  	if iNdEx > l {
  5108  		return io.ErrUnexpectedEOF
  5109  	}
  5110  	return nil
  5111  }
  5112  func (m *RemoteProducerMetadata_SamplerProgress) Unmarshal(dAtA []byte) error {
  5113  	l := len(dAtA)
  5114  	iNdEx := 0
  5115  	for iNdEx < l {
  5116  		preIndex := iNdEx
  5117  		var wire uint64
  5118  		for shift := uint(0); ; shift += 7 {
  5119  			if shift >= 64 {
  5120  				return ErrIntOverflowData
  5121  			}
  5122  			if iNdEx >= l {
  5123  				return io.ErrUnexpectedEOF
  5124  			}
  5125  			b := dAtA[iNdEx]
  5126  			iNdEx++
  5127  			wire |= (uint64(b) & 0x7F) << shift
  5128  			if b < 0x80 {
  5129  				break
  5130  			}
  5131  		}
  5132  		fieldNum := int32(wire >> 3)
  5133  		wireType := int(wire & 0x7)
  5134  		if wireType == 4 {
  5135  			return fmt.Errorf("proto: SamplerProgress: wiretype end group for non-group")
  5136  		}
  5137  		if fieldNum <= 0 {
  5138  			return fmt.Errorf("proto: SamplerProgress: illegal tag %d (wire type %d)", fieldNum, wire)
  5139  		}
  5140  		switch fieldNum {
  5141  		case 1:
  5142  			if wireType != 0 {
  5143  				return fmt.Errorf("proto: wrong wireType = %d for field RowsProcessed", wireType)
  5144  			}
  5145  			m.RowsProcessed = 0
  5146  			for shift := uint(0); ; shift += 7 {
  5147  				if shift >= 64 {
  5148  					return ErrIntOverflowData
  5149  				}
  5150  				if iNdEx >= l {
  5151  					return io.ErrUnexpectedEOF
  5152  				}
  5153  				b := dAtA[iNdEx]
  5154  				iNdEx++
  5155  				m.RowsProcessed |= (uint64(b) & 0x7F) << shift
  5156  				if b < 0x80 {
  5157  					break
  5158  				}
  5159  			}
  5160  		case 2:
  5161  			if wireType != 0 {
  5162  				return fmt.Errorf("proto: wrong wireType = %d for field HistogramDisabled", wireType)
  5163  			}
  5164  			var v int
  5165  			for shift := uint(0); ; shift += 7 {
  5166  				if shift >= 64 {
  5167  					return ErrIntOverflowData
  5168  				}
  5169  				if iNdEx >= l {
  5170  					return io.ErrUnexpectedEOF
  5171  				}
  5172  				b := dAtA[iNdEx]
  5173  				iNdEx++
  5174  				v |= (int(b) & 0x7F) << shift
  5175  				if b < 0x80 {
  5176  					break
  5177  				}
  5178  			}
  5179  			m.HistogramDisabled = bool(v != 0)
  5180  		default:
  5181  			iNdEx = preIndex
  5182  			skippy, err := skipData(dAtA[iNdEx:])
  5183  			if err != nil {
  5184  				return err
  5185  			}
  5186  			if skippy < 0 {
  5187  				return ErrInvalidLengthData
  5188  			}
  5189  			if (iNdEx + skippy) > l {
  5190  				return io.ErrUnexpectedEOF
  5191  			}
  5192  			iNdEx += skippy
  5193  		}
  5194  	}
  5195  
  5196  	if iNdEx > l {
  5197  		return io.ErrUnexpectedEOF
  5198  	}
  5199  	return nil
  5200  }
  5201  func (m *RemoteProducerMetadata_BulkProcessorProgress) Unmarshal(dAtA []byte) error {
  5202  	l := len(dAtA)
  5203  	iNdEx := 0
  5204  	for iNdEx < l {
  5205  		preIndex := iNdEx
  5206  		var wire uint64
  5207  		for shift := uint(0); ; shift += 7 {
  5208  			if shift >= 64 {
  5209  				return ErrIntOverflowData
  5210  			}
  5211  			if iNdEx >= l {
  5212  				return io.ErrUnexpectedEOF
  5213  			}
  5214  			b := dAtA[iNdEx]
  5215  			iNdEx++
  5216  			wire |= (uint64(b) & 0x7F) << shift
  5217  			if b < 0x80 {
  5218  				break
  5219  			}
  5220  		}
  5221  		fieldNum := int32(wire >> 3)
  5222  		wireType := int(wire & 0x7)
  5223  		if wireType == 4 {
  5224  			return fmt.Errorf("proto: BulkProcessorProgress: wiretype end group for non-group")
  5225  		}
  5226  		if fieldNum <= 0 {
  5227  			return fmt.Errorf("proto: BulkProcessorProgress: illegal tag %d (wire type %d)", fieldNum, wire)
  5228  		}
  5229  		switch fieldNum {
  5230  		case 1:
  5231  			if wireType != 2 {
  5232  				return fmt.Errorf("proto: wrong wireType = %d for field CompletedSpans", wireType)
  5233  			}
  5234  			var msglen int
  5235  			for shift := uint(0); ; shift += 7 {
  5236  				if shift >= 64 {
  5237  					return ErrIntOverflowData
  5238  				}
  5239  				if iNdEx >= l {
  5240  					return io.ErrUnexpectedEOF
  5241  				}
  5242  				b := dAtA[iNdEx]
  5243  				iNdEx++
  5244  				msglen |= (int(b) & 0x7F) << shift
  5245  				if b < 0x80 {
  5246  					break
  5247  				}
  5248  			}
  5249  			if msglen < 0 {
  5250  				return ErrInvalidLengthData
  5251  			}
  5252  			postIndex := iNdEx + msglen
  5253  			if postIndex > l {
  5254  				return io.ErrUnexpectedEOF
  5255  			}
  5256  			m.CompletedSpans = append(m.CompletedSpans, roachpb.Span{})
  5257  			if err := m.CompletedSpans[len(m.CompletedSpans)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  5258  				return err
  5259  			}
  5260  			iNdEx = postIndex
  5261  		case 2:
  5262  			if wireType != 2 {
  5263  				return fmt.Errorf("proto: wrong wireType = %d for field CompletedFraction", wireType)
  5264  			}
  5265  			var msglen int
  5266  			for shift := uint(0); ; shift += 7 {
  5267  				if shift >= 64 {
  5268  					return ErrIntOverflowData
  5269  				}
  5270  				if iNdEx >= l {
  5271  					return io.ErrUnexpectedEOF
  5272  				}
  5273  				b := dAtA[iNdEx]
  5274  				iNdEx++
  5275  				msglen |= (int(b) & 0x7F) << shift
  5276  				if b < 0x80 {
  5277  					break
  5278  				}
  5279  			}
  5280  			if msglen < 0 {
  5281  				return ErrInvalidLengthData
  5282  			}
  5283  			postIndex := iNdEx + msglen
  5284  			if postIndex > l {
  5285  				return io.ErrUnexpectedEOF
  5286  			}
  5287  			if m.CompletedFraction == nil {
  5288  				m.CompletedFraction = make(map[int32]float32)
  5289  			}
  5290  			var mapkey int32
  5291  			var mapvalue float32
  5292  			for iNdEx < postIndex {
  5293  				entryPreIndex := iNdEx
  5294  				var wire uint64
  5295  				for shift := uint(0); ; shift += 7 {
  5296  					if shift >= 64 {
  5297  						return ErrIntOverflowData
  5298  					}
  5299  					if iNdEx >= l {
  5300  						return io.ErrUnexpectedEOF
  5301  					}
  5302  					b := dAtA[iNdEx]
  5303  					iNdEx++
  5304  					wire |= (uint64(b) & 0x7F) << shift
  5305  					if b < 0x80 {
  5306  						break
  5307  					}
  5308  				}
  5309  				fieldNum := int32(wire >> 3)
  5310  				if fieldNum == 1 {
  5311  					for shift := uint(0); ; shift += 7 {
  5312  						if shift >= 64 {
  5313  							return ErrIntOverflowData
  5314  						}
  5315  						if iNdEx >= l {
  5316  							return io.ErrUnexpectedEOF
  5317  						}
  5318  						b := dAtA[iNdEx]
  5319  						iNdEx++
  5320  						mapkey |= (int32(b) & 0x7F) << shift
  5321  						if b < 0x80 {
  5322  							break
  5323  						}
  5324  					}
  5325  				} else if fieldNum == 2 {
  5326  					var mapvaluetemp uint32
  5327  					if (iNdEx + 4) > l {
  5328  						return io.ErrUnexpectedEOF
  5329  					}
  5330  					mapvaluetemp = uint32(encoding_binary.LittleEndian.Uint32(dAtA[iNdEx:]))
  5331  					iNdEx += 4
  5332  					mapvalue = math.Float32frombits(mapvaluetemp)
  5333  				} else {
  5334  					iNdEx = entryPreIndex
  5335  					skippy, err := skipData(dAtA[iNdEx:])
  5336  					if err != nil {
  5337  						return err
  5338  					}
  5339  					if skippy < 0 {
  5340  						return ErrInvalidLengthData
  5341  					}
  5342  					if (iNdEx + skippy) > postIndex {
  5343  						return io.ErrUnexpectedEOF
  5344  					}
  5345  					iNdEx += skippy
  5346  				}
  5347  			}
  5348  			m.CompletedFraction[mapkey] = mapvalue
  5349  			iNdEx = postIndex
  5350  		case 3:
  5351  			if wireType != 2 {
  5352  				return fmt.Errorf("proto: wrong wireType = %d for field ResumePos", wireType)
  5353  			}
  5354  			var msglen int
  5355  			for shift := uint(0); ; shift += 7 {
  5356  				if shift >= 64 {
  5357  					return ErrIntOverflowData
  5358  				}
  5359  				if iNdEx >= l {
  5360  					return io.ErrUnexpectedEOF
  5361  				}
  5362  				b := dAtA[iNdEx]
  5363  				iNdEx++
  5364  				msglen |= (int(b) & 0x7F) << shift
  5365  				if b < 0x80 {
  5366  					break
  5367  				}
  5368  			}
  5369  			if msglen < 0 {
  5370  				return ErrInvalidLengthData
  5371  			}
  5372  			postIndex := iNdEx + msglen
  5373  			if postIndex > l {
  5374  				return io.ErrUnexpectedEOF
  5375  			}
  5376  			if m.ResumePos == nil {
  5377  				m.ResumePos = make(map[int32]int64)
  5378  			}
  5379  			var mapkey int32
  5380  			var mapvalue int64
  5381  			for iNdEx < postIndex {
  5382  				entryPreIndex := iNdEx
  5383  				var wire uint64
  5384  				for shift := uint(0); ; shift += 7 {
  5385  					if shift >= 64 {
  5386  						return ErrIntOverflowData
  5387  					}
  5388  					if iNdEx >= l {
  5389  						return io.ErrUnexpectedEOF
  5390  					}
  5391  					b := dAtA[iNdEx]
  5392  					iNdEx++
  5393  					wire |= (uint64(b) & 0x7F) << shift
  5394  					if b < 0x80 {
  5395  						break
  5396  					}
  5397  				}
  5398  				fieldNum := int32(wire >> 3)
  5399  				if fieldNum == 1 {
  5400  					for shift := uint(0); ; shift += 7 {
  5401  						if shift >= 64 {
  5402  							return ErrIntOverflowData
  5403  						}
  5404  						if iNdEx >= l {
  5405  							return io.ErrUnexpectedEOF
  5406  						}
  5407  						b := dAtA[iNdEx]
  5408  						iNdEx++
  5409  						mapkey |= (int32(b) & 0x7F) << shift
  5410  						if b < 0x80 {
  5411  							break
  5412  						}
  5413  					}
  5414  				} else if fieldNum == 2 {
  5415  					for shift := uint(0); ; shift += 7 {
  5416  						if shift >= 64 {
  5417  							return ErrIntOverflowData
  5418  						}
  5419  						if iNdEx >= l {
  5420  							return io.ErrUnexpectedEOF
  5421  						}
  5422  						b := dAtA[iNdEx]
  5423  						iNdEx++
  5424  						mapvalue |= (int64(b) & 0x7F) << shift
  5425  						if b < 0x80 {
  5426  							break
  5427  						}
  5428  					}
  5429  				} else {
  5430  					iNdEx = entryPreIndex
  5431  					skippy, err := skipData(dAtA[iNdEx:])
  5432  					if err != nil {
  5433  						return err
  5434  					}
  5435  					if skippy < 0 {
  5436  						return ErrInvalidLengthData
  5437  					}
  5438  					if (iNdEx + skippy) > postIndex {
  5439  						return io.ErrUnexpectedEOF
  5440  					}
  5441  					iNdEx += skippy
  5442  				}
  5443  			}
  5444  			m.ResumePos[mapkey] = mapvalue
  5445  			iNdEx = postIndex
  5446  		default:
  5447  			iNdEx = preIndex
  5448  			skippy, err := skipData(dAtA[iNdEx:])
  5449  			if err != nil {
  5450  				return err
  5451  			}
  5452  			if skippy < 0 {
  5453  				return ErrInvalidLengthData
  5454  			}
  5455  			if (iNdEx + skippy) > l {
  5456  				return io.ErrUnexpectedEOF
  5457  			}
  5458  			iNdEx += skippy
  5459  		}
  5460  	}
  5461  
  5462  	if iNdEx > l {
  5463  		return io.ErrUnexpectedEOF
  5464  	}
  5465  	return nil
  5466  }
  5467  func (m *RemoteProducerMetadata_Metrics) Unmarshal(dAtA []byte) error {
  5468  	l := len(dAtA)
  5469  	iNdEx := 0
  5470  	for iNdEx < l {
  5471  		preIndex := iNdEx
  5472  		var wire uint64
  5473  		for shift := uint(0); ; shift += 7 {
  5474  			if shift >= 64 {
  5475  				return ErrIntOverflowData
  5476  			}
  5477  			if iNdEx >= l {
  5478  				return io.ErrUnexpectedEOF
  5479  			}
  5480  			b := dAtA[iNdEx]
  5481  			iNdEx++
  5482  			wire |= (uint64(b) & 0x7F) << shift
  5483  			if b < 0x80 {
  5484  				break
  5485  			}
  5486  		}
  5487  		fieldNum := int32(wire >> 3)
  5488  		wireType := int(wire & 0x7)
  5489  		if wireType == 4 {
  5490  			return fmt.Errorf("proto: Metrics: wiretype end group for non-group")
  5491  		}
  5492  		if fieldNum <= 0 {
  5493  			return fmt.Errorf("proto: Metrics: illegal tag %d (wire type %d)", fieldNum, wire)
  5494  		}
  5495  		switch fieldNum {
  5496  		case 1:
  5497  			if wireType != 0 {
  5498  				return fmt.Errorf("proto: wrong wireType = %d for field BytesRead", wireType)
  5499  			}
  5500  			m.BytesRead = 0
  5501  			for shift := uint(0); ; shift += 7 {
  5502  				if shift >= 64 {
  5503  					return ErrIntOverflowData
  5504  				}
  5505  				if iNdEx >= l {
  5506  					return io.ErrUnexpectedEOF
  5507  				}
  5508  				b := dAtA[iNdEx]
  5509  				iNdEx++
  5510  				m.BytesRead |= (int64(b) & 0x7F) << shift
  5511  				if b < 0x80 {
  5512  					break
  5513  				}
  5514  			}
  5515  		case 2:
  5516  			if wireType != 0 {
  5517  				return fmt.Errorf("proto: wrong wireType = %d for field RowsRead", wireType)
  5518  			}
  5519  			m.RowsRead = 0
  5520  			for shift := uint(0); ; shift += 7 {
  5521  				if shift >= 64 {
  5522  					return ErrIntOverflowData
  5523  				}
  5524  				if iNdEx >= l {
  5525  					return io.ErrUnexpectedEOF
  5526  				}
  5527  				b := dAtA[iNdEx]
  5528  				iNdEx++
  5529  				m.RowsRead |= (int64(b) & 0x7F) << shift
  5530  				if b < 0x80 {
  5531  					break
  5532  				}
  5533  			}
  5534  		default:
  5535  			iNdEx = preIndex
  5536  			skippy, err := skipData(dAtA[iNdEx:])
  5537  			if err != nil {
  5538  				return err
  5539  			}
  5540  			if skippy < 0 {
  5541  				return ErrInvalidLengthData
  5542  			}
  5543  			if (iNdEx + skippy) > l {
  5544  				return io.ErrUnexpectedEOF
  5545  			}
  5546  			iNdEx += skippy
  5547  		}
  5548  	}
  5549  
  5550  	if iNdEx > l {
  5551  		return io.ErrUnexpectedEOF
  5552  	}
  5553  	return nil
  5554  }
  5555  func (m *DistSQLVersionGossipInfo) Unmarshal(dAtA []byte) error {
  5556  	l := len(dAtA)
  5557  	iNdEx := 0
  5558  	for iNdEx < l {
  5559  		preIndex := iNdEx
  5560  		var wire uint64
  5561  		for shift := uint(0); ; shift += 7 {
  5562  			if shift >= 64 {
  5563  				return ErrIntOverflowData
  5564  			}
  5565  			if iNdEx >= l {
  5566  				return io.ErrUnexpectedEOF
  5567  			}
  5568  			b := dAtA[iNdEx]
  5569  			iNdEx++
  5570  			wire |= (uint64(b) & 0x7F) << shift
  5571  			if b < 0x80 {
  5572  				break
  5573  			}
  5574  		}
  5575  		fieldNum := int32(wire >> 3)
  5576  		wireType := int(wire & 0x7)
  5577  		if wireType == 4 {
  5578  			return fmt.Errorf("proto: DistSQLVersionGossipInfo: wiretype end group for non-group")
  5579  		}
  5580  		if fieldNum <= 0 {
  5581  			return fmt.Errorf("proto: DistSQLVersionGossipInfo: illegal tag %d (wire type %d)", fieldNum, wire)
  5582  		}
  5583  		switch fieldNum {
  5584  		case 1:
  5585  			if wireType != 0 {
  5586  				return fmt.Errorf("proto: wrong wireType = %d for field Version", wireType)
  5587  			}
  5588  			m.Version = 0
  5589  			for shift := uint(0); ; shift += 7 {
  5590  				if shift >= 64 {
  5591  					return ErrIntOverflowData
  5592  				}
  5593  				if iNdEx >= l {
  5594  					return io.ErrUnexpectedEOF
  5595  				}
  5596  				b := dAtA[iNdEx]
  5597  				iNdEx++
  5598  				m.Version |= (DistSQLVersion(b) & 0x7F) << shift
  5599  				if b < 0x80 {
  5600  					break
  5601  				}
  5602  			}
  5603  		case 2:
  5604  			if wireType != 0 {
  5605  				return fmt.Errorf("proto: wrong wireType = %d for field MinAcceptedVersion", wireType)
  5606  			}
  5607  			m.MinAcceptedVersion = 0
  5608  			for shift := uint(0); ; shift += 7 {
  5609  				if shift >= 64 {
  5610  					return ErrIntOverflowData
  5611  				}
  5612  				if iNdEx >= l {
  5613  					return io.ErrUnexpectedEOF
  5614  				}
  5615  				b := dAtA[iNdEx]
  5616  				iNdEx++
  5617  				m.MinAcceptedVersion |= (DistSQLVersion(b) & 0x7F) << shift
  5618  				if b < 0x80 {
  5619  					break
  5620  				}
  5621  			}
  5622  		default:
  5623  			iNdEx = preIndex
  5624  			skippy, err := skipData(dAtA[iNdEx:])
  5625  			if err != nil {
  5626  				return err
  5627  			}
  5628  			if skippy < 0 {
  5629  				return ErrInvalidLengthData
  5630  			}
  5631  			if (iNdEx + skippy) > l {
  5632  				return io.ErrUnexpectedEOF
  5633  			}
  5634  			iNdEx += skippy
  5635  		}
  5636  	}
  5637  
  5638  	if iNdEx > l {
  5639  		return io.ErrUnexpectedEOF
  5640  	}
  5641  	return nil
  5642  }
  5643  func (m *DistSQLDrainingInfo) Unmarshal(dAtA []byte) error {
  5644  	l := len(dAtA)
  5645  	iNdEx := 0
  5646  	for iNdEx < l {
  5647  		preIndex := iNdEx
  5648  		var wire uint64
  5649  		for shift := uint(0); ; shift += 7 {
  5650  			if shift >= 64 {
  5651  				return ErrIntOverflowData
  5652  			}
  5653  			if iNdEx >= l {
  5654  				return io.ErrUnexpectedEOF
  5655  			}
  5656  			b := dAtA[iNdEx]
  5657  			iNdEx++
  5658  			wire |= (uint64(b) & 0x7F) << shift
  5659  			if b < 0x80 {
  5660  				break
  5661  			}
  5662  		}
  5663  		fieldNum := int32(wire >> 3)
  5664  		wireType := int(wire & 0x7)
  5665  		if wireType == 4 {
  5666  			return fmt.Errorf("proto: DistSQLDrainingInfo: wiretype end group for non-group")
  5667  		}
  5668  		if fieldNum <= 0 {
  5669  			return fmt.Errorf("proto: DistSQLDrainingInfo: illegal tag %d (wire type %d)", fieldNum, wire)
  5670  		}
  5671  		switch fieldNum {
  5672  		case 1:
  5673  			if wireType != 0 {
  5674  				return fmt.Errorf("proto: wrong wireType = %d for field Draining", wireType)
  5675  			}
  5676  			var v int
  5677  			for shift := uint(0); ; shift += 7 {
  5678  				if shift >= 64 {
  5679  					return ErrIntOverflowData
  5680  				}
  5681  				if iNdEx >= l {
  5682  					return io.ErrUnexpectedEOF
  5683  				}
  5684  				b := dAtA[iNdEx]
  5685  				iNdEx++
  5686  				v |= (int(b) & 0x7F) << shift
  5687  				if b < 0x80 {
  5688  					break
  5689  				}
  5690  			}
  5691  			m.Draining = bool(v != 0)
  5692  		default:
  5693  			iNdEx = preIndex
  5694  			skippy, err := skipData(dAtA[iNdEx:])
  5695  			if err != nil {
  5696  				return err
  5697  			}
  5698  			if skippy < 0 {
  5699  				return ErrInvalidLengthData
  5700  			}
  5701  			if (iNdEx + skippy) > l {
  5702  				return io.ErrUnexpectedEOF
  5703  			}
  5704  			iNdEx += skippy
  5705  		}
  5706  	}
  5707  
  5708  	if iNdEx > l {
  5709  		return io.ErrUnexpectedEOF
  5710  	}
  5711  	return nil
  5712  }
  5713  func skipData(dAtA []byte) (n int, err error) {
  5714  	l := len(dAtA)
  5715  	iNdEx := 0
  5716  	for iNdEx < l {
  5717  		var wire uint64
  5718  		for shift := uint(0); ; shift += 7 {
  5719  			if shift >= 64 {
  5720  				return 0, ErrIntOverflowData
  5721  			}
  5722  			if iNdEx >= l {
  5723  				return 0, io.ErrUnexpectedEOF
  5724  			}
  5725  			b := dAtA[iNdEx]
  5726  			iNdEx++
  5727  			wire |= (uint64(b) & 0x7F) << shift
  5728  			if b < 0x80 {
  5729  				break
  5730  			}
  5731  		}
  5732  		wireType := int(wire & 0x7)
  5733  		switch wireType {
  5734  		case 0:
  5735  			for shift := uint(0); ; shift += 7 {
  5736  				if shift >= 64 {
  5737  					return 0, ErrIntOverflowData
  5738  				}
  5739  				if iNdEx >= l {
  5740  					return 0, io.ErrUnexpectedEOF
  5741  				}
  5742  				iNdEx++
  5743  				if dAtA[iNdEx-1] < 0x80 {
  5744  					break
  5745  				}
  5746  			}
  5747  			return iNdEx, nil
  5748  		case 1:
  5749  			iNdEx += 8
  5750  			return iNdEx, nil
  5751  		case 2:
  5752  			var length int
  5753  			for shift := uint(0); ; shift += 7 {
  5754  				if shift >= 64 {
  5755  					return 0, ErrIntOverflowData
  5756  				}
  5757  				if iNdEx >= l {
  5758  					return 0, io.ErrUnexpectedEOF
  5759  				}
  5760  				b := dAtA[iNdEx]
  5761  				iNdEx++
  5762  				length |= (int(b) & 0x7F) << shift
  5763  				if b < 0x80 {
  5764  					break
  5765  				}
  5766  			}
  5767  			iNdEx += length
  5768  			if length < 0 {
  5769  				return 0, ErrInvalidLengthData
  5770  			}
  5771  			return iNdEx, nil
  5772  		case 3:
  5773  			for {
  5774  				var innerWire uint64
  5775  				var start int = iNdEx
  5776  				for shift := uint(0); ; shift += 7 {
  5777  					if shift >= 64 {
  5778  						return 0, ErrIntOverflowData
  5779  					}
  5780  					if iNdEx >= l {
  5781  						return 0, io.ErrUnexpectedEOF
  5782  					}
  5783  					b := dAtA[iNdEx]
  5784  					iNdEx++
  5785  					innerWire |= (uint64(b) & 0x7F) << shift
  5786  					if b < 0x80 {
  5787  						break
  5788  					}
  5789  				}
  5790  				innerWireType := int(innerWire & 0x7)
  5791  				if innerWireType == 4 {
  5792  					break
  5793  				}
  5794  				next, err := skipData(dAtA[start:])
  5795  				if err != nil {
  5796  					return 0, err
  5797  				}
  5798  				iNdEx = start + next
  5799  			}
  5800  			return iNdEx, nil
  5801  		case 4:
  5802  			return iNdEx, nil
  5803  		case 5:
  5804  			iNdEx += 4
  5805  			return iNdEx, nil
  5806  		default:
  5807  			return 0, fmt.Errorf("proto: illegal wireType %d", wireType)
  5808  		}
  5809  	}
  5810  	panic("unreachable")
  5811  }
  5812  
  5813  var (
  5814  	ErrInvalidLengthData = fmt.Errorf("proto: negative length found during unmarshaling")
  5815  	ErrIntOverflowData   = fmt.Errorf("proto: integer overflow")
  5816  )
  5817  
  5818  func init() { proto.RegisterFile("sql/execinfrapb/data.proto", fileDescriptor_data_b1be9c010247b5f4) }
  5819  
  5820  var fileDescriptor_data_b1be9c010247b5f4 = []byte{
  5821  	// 1984 bytes of a gzipped FileDescriptorProto
  5822  	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xac, 0x58, 0xcb, 0x73, 0x5b, 0x49,
  5823  	0xf5, 0xd6, 0x95, 0x64, 0x3d, 0x8e, 0xfc, 0x90, 0xfb, 0x97, 0x64, 0x54, 0xfa, 0x05, 0xdb, 0xa3,
  5824  	0xa1, 0xa8, 0x00, 0x33, 0x52, 0xe2, 0x2c, 0x32, 0x18, 0xa8, 0xc4, 0xb2, 0xe4, 0x48, 0x19, 0xc7,
  5825  	0xf6, 0x5c, 0x39, 0x4c, 0x65, 0x06, 0xea, 0x72, 0x75, 0x6f, 0x4b, 0xbe, 0xe4, 0xbe, 0xdc, 0xdd,
  5826  	0x37, 0xb6, 0x37, 0x14, 0x55, 0xb0, 0x64, 0xc1, 0x8a, 0x62, 0x39, 0x6c, 0xd8, 0xf0, 0x7f, 0x40,
  5827  	0x56, 0xd4, 0x2c, 0x53, 0x2c, 0x52, 0xe0, 0x6c, 0x66, 0x07, 0x5b, 0x66, 0x45, 0xf5, 0x4b, 0xaf,
  5828  	0xd8, 0x09, 0x9e, 0xcc, 0xc6, 0xee, 0x3e, 0x7d, 0xbe, 0xaf, 0x4f, 0x7f, 0x7d, 0xfa, 0x74, 0x5f,
  5829  	0x41, 0x95, 0x1e, 0xf9, 0x0d, 0x7c, 0x82, 0x1d, 0x2f, 0x1c, 0x10, 0x3b, 0xee, 0x37, 0x5c, 0x9b,
  5830  	0xd9, 0xf5, 0x98, 0x44, 0x2c, 0x42, 0x15, 0x27, 0x72, 0x9e, 0x90, 0xc8, 0x76, 0x0e, 0xeb, 0xf4,
  5831  	0xc8, 0xaf, 0xbb, 0x1e, 0x65, 0xf4, 0xc8, 0x27, 0x49, 0x58, 0xbd, 0xf6, 0x8b, 0xa8, 0x4f, 0x1b,
  5832  	0xfc, 0x4f, 0xdc, 0x17, 0xff, 0x24, 0xa2, 0xba, 0x2c, 0xbc, 0xe3, 0x7e, 0xc3, 0x8e, 0x3d, 0x65,
  5833  	0x42, 0xda, 0x34, 0x26, 0xae, 0x5e, 0xd1, 0x36, 0x4c, 0x48, 0x44, 0x34, 0xf8, 0xaa, 0xec, 0xcd,
  5834  	0x9a, 0x57, 0x79, 0x84, 0xf1, 0xf0, 0xd8, 0x23, 0xb8, 0x11, 0x0f, 0xc5, 0xd0, 0xb4, 0xc3, 0x75,
  5835  	0xee, 0x40, 0x8f, 0xfc, 0xbe, 0x4d, 0x71, 0x83, 0x32, 0x92, 0x38, 0x2c, 0x21, 0xd8, 0x9d, 0x84,
  5836  	0xeb, 0x51, 0x1c, 0x3a, 0x91, 0x8b, 0x5d, 0xcb, 0xb5, 0x59, 0x12, 0xe8, 0x69, 0xb9, 0x03, 0x3b,
  5837  	0x8d, 0x31, 0x95, 0x7f, 0x95, 0x79, 0x2d, 0x61, 0x9e, 0xdf, 0x60, 0xc4, 0x76, 0xbc, 0x70, 0xd8,
  5838  	0x20, 0xd8, 0x89, 0x08, 0x47, 0xd2, 0xd8, 0x0e, 0xf5, 0x2a, 0x86, 0xd1, 0x30, 0x12, 0xcd, 0x06,
  5839  	0x6f, 0x49, 0x6b, 0xed, 0x53, 0x98, 0x6b, 0xf3, 0xe8, 0xd0, 0x5d, 0x80, 0x41, 0xe2, 0xfb, 0x96,
  5840  	0x88, 0xb5, 0x92, 0x59, 0x33, 0x6e, 0x94, 0xd6, 0xd7, 0xea, 0x63, 0x49, 0xf5, 0x6a, 0xeb, 0x6d,
  5841  	0x19, 0x94, 0x40, 0x99, 0x45, 0x8e, 0x11, 0xcd, 0x8d, 0xec, 0x1f, 0x3e, 0x5f, 0x4d, 0x3d, 0xc8,
  5842  	0x16, 0x8c, 0x72, 0xfa, 0x41, 0xb6, 0x90, 0x2e, 0x67, 0x6a, 0xfb, 0x00, 0xed, 0x93, 0x98, 0x60,
  5843  	0x4a, 0xbd, 0x28, 0x44, 0x2b, 0x90, 0x7f, 0x8a, 0x09, 0x6f, 0x56, 0x8c, 0x35, 0xe3, 0x46, 0xb1,
  5844  	0x99, 0x7d, 0xf6, 0x62, 0x35, 0x65, 0x6a, 0x23, 0xaa, 0x40, 0x16, 0x9f, 0xc4, 0xa4, 0x92, 0x9e,
  5845  	0x18, 0x14, 0x96, 0x8d, 0x02, 0x67, 0xfe, 0xf7, 0x1f, 0x57, 0x53, 0xb5, 0xdf, 0xa4, 0xa1, 0xb0,
  5846  	0x47, 0x5c, 0x4c, 0xbc, 0x70, 0x88, 0xba, 0x90, 0x77, 0x22, 0x3f, 0x09, 0x42, 0x5a, 0x31, 0xd6,
  5847  	0x32, 0x37, 0x4a, 0xeb, 0xdf, 0xad, 0x5f, 0x94, 0x01, 0x75, 0x0d, 0xaa, 0x6f, 0x09, 0x84, 0x9e,
  5848  	0x5b, 0xe1, 0xab, 0x7f, 0x32, 0x20, 0x27, 0x47, 0xd0, 0xb7, 0x04, 0xab, 0xe5, 0xb9, 0x27, 0x22,
  5849  	0xcc, 0x05, 0xe5, 0x9a, 0x73, 0x22, 0xbf, 0xeb, 0x9e, 0xa0, 0x4f, 0xa0, 0xe8, 0x7a, 0x04, 0x3b,
  5850  	0x8c, 0xaf, 0x83, 0x87, 0xba, 0xb8, 0x7e, 0xfb, 0x7f, 0x9e, 0xb6, 0xde, 0xd2, 0x50, 0xc5, 0x3a,
  5851  	0xe6, 0xaa, 0xad, 0x40, 0x71, 0x34, 0x8a, 0xf2, 0x90, 0xd9, 0xec, 0x6d, 0x95, 0x53, 0xa8, 0x00,
  5852  	0xd9, 0x56, 0xbb, 0xb7, 0x55, 0x36, 0x36, 0xb2, 0x5f, 0x7e, 0xbe, 0xaa, 0xfe, 0xd6, 0xfe, 0x9a,
  5853  	0x06, 0xd4, 0x63, 0x04, 0xdb, 0x41, 0x3b, 0x74, 0xe3, 0xc8, 0x0b, 0x59, 0x2f, 0xc6, 0x0e, 0xfa,
  5854  	0x08, 0xb2, 0x3c, 0x25, 0x44, 0xdc, 0x8b, 0xeb, 0xb7, 0x2e, 0x0e, 0xeb, 0x55, 0x6c, 0xfd, 0xe0,
  5855  	0x34, 0xc6, 0x5a, 0x74, 0x4e, 0x82, 0x7e, 0x00, 0x45, 0x2a, 0xdc, 0x2c, 0xcf, 0x15, 0x0b, 0x9d,
  5856  	0x6b, 0x5e, 0xe7, 0xc3, 0x67, 0x2f, 0x56, 0x0b, 0x12, 0xdf, 0x6d, 0x7d, 0x35, 0xd1, 0x36, 0x0b,
  5857  	0xd2, 0xbd, 0xeb, 0xa2, 0x23, 0x58, 0x64, 0x36, 0x19, 0x62, 0x66, 0x85, 0x91, 0x8b, 0x39, 0x3e,
  5858  	0x2b, 0xf0, 0x1f, 0x29, 0xfc, 0xfc, 0x81, 0x18, 0xdd, 0x8d, 0x5c, 0x2c, 0x38, 0x6e, 0x0f, 0x3d,
  5859  	0x76, 0x98, 0xf4, 0xeb, 0x4e, 0x14, 0x34, 0x46, 0x31, 0xbb, 0xfd, 0x71, 0xbb, 0x11, 0x3f, 0x19,
  5860  	0x36, 0xd4, 0x21, 0xac, 0x4b, 0x98, 0x39, 0xcf, 0xc6, 0x24, 0x6e, 0xed, 0x26, 0x64, 0xf9, 0x0a,
  5861  	0x50, 0x11, 0xe6, 0x76, 0xf6, 0xb6, 0x36, 0x77, 0xca, 0x29, 0x04, 0x90, 0x33, 0xdb, 0x0f, 0xf7,
  5862  	0x0e, 0xda, 0x65, 0x03, 0x2d, 0xc3, 0x42, 0xef, 0xf1, 0xee, 0x96, 0x65, 0xb6, 0x7b, 0xfb, 0x7b,
  5863  	0xbb, 0xbd, 0xb6, 0x48, 0xd1, 0x4c, 0x39, 0x5b, 0xfb, 0x5b, 0x1a, 0x16, 0xba, 0x61, 0x9c, 0xb0,
  5864  	0xde, 0x69, 0xe8, 0x08, 0x11, 0xb7, 0xa7, 0x44, 0x7c, 0xff, 0x62, 0x11, 0xa7, 0x60, 0xaf, 0xea,
  5865  	0xd7, 0x82, 0x42, 0xa4, 0x76, 0x5f, 0xc8, 0x57, 0x5a, 0xaf, 0xbd, 0x39, 0x4f, 0x14, 0xc3, 0x08,
  5866  	0x89, 0x76, 0x20, 0x2f, 0x65, 0xa5, 0x95, 0x8c, 0xc8, 0xf1, 0xf7, 0x2f, 0xb3, 0xab, 0x3a, 0xcd,
  5867  	0x15, 0x05, 0xfa, 0x31, 0xcc, 0xcb, 0x8c, 0xb7, 0x44, 0xe9, 0xa8, 0x64, 0x05, 0x65, 0x75, 0x86,
  5868  	0x92, 0xe2, 0xa0, 0x2e, 0x4b, 0xcb, 0x81, 0x59, 0x92, 0xfe, 0x7c, 0x75, 0xb4, 0x56, 0x53, 0x22,
  5869  	0x2f, 0x40, 0xf1, 0xd1, 0xee, 0x9e, 0xd9, 0x6a, 0x9b, 0xed, 0x56, 0x39, 0x85, 0x4a, 0x90, 0xd7,
  5870  	0x1d, 0xa3, 0xf6, 0x9f, 0x1c, 0x94, 0xf7, 0x12, 0x16, 0x27, 0xcc, 0x8c, 0x12, 0x86, 0x89, 0xd0,
  5871  	0xb4, 0x3b, 0xa5, 0x69, 0xe3, 0x35, 0x3a, 0xcc, 0x20, 0x5f, 0x95, 0x75, 0x42, 0x90, 0xf4, 0xdb,
  5872  	0x0b, 0xf2, 0x2e, 0xcc, 0x1f, 0xda, 0xf4, 0xd0, 0xd2, 0x75, 0x84, 0x6b, 0xbc, 0x60, 0x96, 0xb8,
  5873  	0x4d, 0x9e, 0x58, 0x8a, 0x7c, 0x58, 0x26, 0x76, 0x38, 0xc4, 0x16, 0x11, 0x51, 0x59, 0x34, 0xc6,
  5874  	0x8e, 0xc8, 0xe7, 0xd2, 0xfa, 0xc6, 0x25, 0x16, 0x62, 0x72, 0x8e, 0x71, 0x5f, 0x05, 0xb2, 0x44,
  5875  	0xa6, 0xcd, 0xe8, 0x16, 0x2c, 0xbb, 0x1e, 0xb5, 0xfb, 0x3e, 0xb6, 0xfa, 0xc9, 0x60, 0x20, 0xd3,
  5876  	0x67, 0x6e, 0xcd, 0xb8, 0x51, 0x50, 0x88, 0xb2, 0x1a, 0x6e, 0xea, 0xd1, 0xea, 0x5f, 0x32, 0xb0,
  5877  	0x34, 0xc3, 0x8e, 0x3e, 0x83, 0x39, 0x5e, 0xf9, 0x75, 0x61, 0xbc, 0xfb, 0xf5, 0x03, 0xad, 0xf7,
  5878  	0x62, 0x5b, 0x57, 0x2b, 0xc9, 0xc9, 0x45, 0x73, 0xf1, 0xc0, 0x4e, 0x7c, 0x66, 0xb9, 0x98, 0x32,
  5879  	0x59, 0x1c, 0xcc, 0x92, 0xb2, 0xb5, 0x30, 0x65, 0x28, 0x80, 0xa2, 0xb8, 0xbb, 0xbc, 0x70, 0xa8,
  5880  	0x13, 0xb7, 0xfb, 0x16, 0x31, 0xc8, 0xbd, 0x68, 0x2b, 0x46, 0x5d, 0x3b, 0x47, 0x33, 0x54, 0x9f,
  5881  	0xc2, 0xe2, 0xb4, 0x0b, 0xba, 0x0e, 0x39, 0xb9, 0xa7, 0xaf, 0x14, 0x71, 0x5e, 0xe3, 0xb7, 0xa1,
  5882  	0xa0, 0xc1, 0xaa, 0x86, 0x7f, 0x7b, 0xf6, 0x0c, 0xc8, 0x1b, 0xb8, 0xde, 0xe2, 0x37, 0xef, 0xcc,
  5883  	0xc4, 0x23, 0x6c, 0x75, 0x07, 0xb2, 0x5c, 0x1e, 0x74, 0x05, 0xe6, 0x28, 0xb3, 0x09, 0x13, 0x93,
  5884  	0xcd, 0x9b, 0xb2, 0x83, 0xca, 0x90, 0xc1, 0xa1, 0xac, 0x9d, 0xf3, 0x26, 0x6f, 0xf2, 0xa8, 0x64,
  5885  	0xe6, 0x89, 0xfb, 0x75, 0x4e, 0x47, 0x25, 0x6d, 0xb5, 0xbb, 0xea, 0x78, 0x95, 0x61, 0x7e, 0x7f,
  5886  	0xb3, 0xd7, 0xb3, 0x0e, 0x3a, 0xe6, 0xde, 0xa3, 0xfb, 0x1d, 0x59, 0xca, 0x1e, 0x76, 0x4d, 0x73,
  5887  	0xcf, 0x2c, 0x1b, 0xfc, 0xb4, 0x35, 0x1f, 0x5b, 0x9d, 0xcd, 0x5e, 0xa7, 0x9c, 0x46, 0xf3, 0x50,
  5888  	0x68, 0x3e, 0xb6, 0xcc, 0xcd, 0xdd, 0xfb, 0xed, 0x72, 0xa6, 0xf6, 0x6b, 0x03, 0x8a, 0x22, 0xe0,
  5889  	0x6e, 0x38, 0x88, 0xa6, 0x16, 0x69, 0x7c, 0xfd, 0x45, 0xa2, 0xba, 0x3a, 0xbc, 0xb2, 0x88, 0xbd,
  5890  	0xae, 0x58, 0x08, 0xbf, 0xda, 0x2f, 0x61, 0x71, 0x9f, 0x44, 0x6e, 0xe2, 0x60, 0xd2, 0xc1, 0xb6,
  5891  	0x8b, 0x09, 0xba, 0x05, 0xf9, 0x81, 0x1f, 0x1d, 0xf3, 0x8b, 0x40, 0x08, 0xd4, 0xac, 0xf0, 0x29,
  5892  	0xfe, 0xfe, 0x62, 0x35, 0xb7, 0xed, 0x47, 0xc7, 0xdd, 0xd6, 0xd9, 0xa8, 0x65, 0xe6, 0xb8, 0x63,
  5893  	0xd7, 0x7d, 0x8b, 0xdb, 0xa7, 0xf6, 0x67, 0x03, 0xe6, 0x75, 0x00, 0x2d, 0x9b, 0xd9, 0xe8, 0xff,
  5894  	0xa1, 0x48, 0xec, 0x63, 0xab, 0x7f, 0xca, 0x30, 0x55, 0x3b, 0x54, 0x20, 0xf6, 0x71, 0x93, 0xf7,
  5895  	0x91, 0x09, 0x85, 0x00, 0x33, 0x9b, 0xbf, 0xf6, 0x54, 0x41, 0xb9, 0x79, 0x71, 0xa2, 0x9a, 0x38,
  5896  	0x88, 0x18, 0xd6, 0xe4, 0x0f, 0x15, 0x4e, 0x2b, 0xa6, 0x79, 0xd0, 0xf7, 0x60, 0x31, 0x4c, 0x02,
  5897  	0x0b, 0x07, 0x31, 0x3b, 0xb5, 0x48, 0x74, 0x4c, 0xa7, 0xb6, 0x7b, 0x3e, 0x4c, 0x82, 0x36, 0x1f,
  5898  	0x32, 0xa3, 0x63, 0x5a, 0x7b, 0x6e, 0xc0, 0xd2, 0x98, 0x90, 0x52, 0x7b, 0x88, 0xd1, 0x3d, 0xc8,
  5899  	0x1d, 0x0a, 0xe5, 0x44, 0xb4, 0xa5, 0xf5, 0x1b, 0x17, 0x47, 0x34, 0xad, 0xb4, 0xa9, 0x70, 0x68,
  5900  	0x13, 0x72, 0xec, 0x34, 0x96, 0xe9, 0xcd, 0xd7, 0xf4, 0xde, 0xc5, 0x0c, 0xa3, 0x84, 0xd1, 0xd9,
  5901  	0x28, 0x81, 0xe8, 0x1e, 0x64, 0x85, 0x28, 0xf2, 0x25, 0xf8, 0x9d, 0x37, 0x87, 0xd0, 0x1a, 0x4b,
  5902  	0x21, 0x90, 0xb5, 0x7f, 0x2d, 0xc0, 0xb5, 0xf3, 0x15, 0x43, 0x3f, 0x05, 0x90, 0x45, 0xd5, 0x0b,
  5903  	0x07, 0x91, 0x5a, 0xe5, 0x0f, 0x2f, 0xab, 0xbb, 0x2c, 0x13, 0x3c, 0x74, 0xda, 0x49, 0x99, 0x45,
  5904  	0xa2, 0x7b, 0xe8, 0x0e, 0xcc, 0xc9, 0x57, 0xac, 0x4c, 0xd9, 0xd5, 0x8b, 0x89, 0xc5, 0xcb, 0xb5,
  5905  	0x93, 0x32, 0xa5, 0x3f, 0xfa, 0x0c, 0x80, 0xbf, 0xa0, 0xb1, 0x35, 0xb1, 0xf2, 0x8d, 0x4b, 0x87,
  5906  	0x75, 0xc0, 0x29, 0xb8, 0x1a, 0x3c, 0x2a, 0xa6, 0x3b, 0xe8, 0x13, 0xb8, 0xe2, 0x63, 0x7b, 0x60,
  5907  	0xb1, 0x93, 0xd0, 0x1a, 0x78, 0xa1, 0xed, 0x5b, 0x94, 0xd9, 0x0c, 0xab, 0xbb, 0x64, 0xf2, 0x6c,
  5908  	0xea, 0x97, 0xce, 0x0e, 0xb6, 0x07, 0x07, 0x27, 0xe1, 0x36, 0x77, 0xee, 0x71, 0xdf, 0x4e, 0xca,
  5909  	0x5c, 0xf6, 0x67, 0x8d, 0xc8, 0x84, 0x3c, 0x89, 0x8e, 0xad, 0x30, 0x09, 0xc4, 0x4d, 0x51, 0x5a,
  5910  	0xbf, 0x73, 0x79, 0x25, 0xa3, 0xe3, 0xdd, 0x24, 0xe8, 0xa4, 0xcc, 0x1c, 0x11, 0x2d, 0x14, 0x40,
  5911  	0x99, 0xda, 0x41, 0xec, 0x63, 0x62, 0xc5, 0x24, 0x1a, 0xf2, 0x37, 0x7c, 0x25, 0x2f, 0xc8, 0xef,
  5912  	0x5d, 0x9a, 0xbc, 0x27, 0x89, 0xf6, 0x15, 0x4f, 0x27, 0x65, 0x2e, 0xd1, 0x69, 0x13, 0x3a, 0x80,
  5913  	0x7c, 0x80, 0x19, 0xf1, 0x1c, 0x5a, 0x29, 0x88, 0x59, 0x3e, 0xbc, 0xf4, 0x2c, 0x0f, 0x25, 0xbe,
  5914  	0x93, 0x32, 0x35, 0x15, 0xfa, 0x95, 0x01, 0xef, 0xf4, 0x13, 0xff, 0x09, 0x5f, 0x82, 0x83, 0x29,
  5915  	0x8d, 0x26, 0x16, 0x53, 0x14, 0xd3, 0x6c, 0x5f, 0x7a, 0x9a, 0x66, 0xe2, 0x3f, 0xd9, 0xd7, 0x74,
  5916  	0x13, 0x4b, 0xba, 0xda, 0x3f, 0x6f, 0xa0, 0xba, 0x07, 0x30, 0xce, 0x52, 0xb4, 0x39, 0x93, 0xf6,
  5917  	0xfc, 0x68, 0x5e, 0x3f, 0x67, 0xe3, 0x47, 0x10, 0x7d, 0xd5, 0x8d, 0x72, 0xbb, 0xfa, 0x73, 0x28,
  5918  	0x8e, 0xf2, 0x0b, 0xf5, 0x60, 0xc9, 0x89, 0x7c, 0x1f, 0x3b, 0x4c, 0x7d, 0xea, 0xe9, 0x0b, 0x7f,
  5919  	0x32, 0x9b, 0xf8, 0x87, 0x61, 0x5d, 0x7d, 0x18, 0xd6, 0x4d, 0xf5, 0x61, 0x38, 0x71, 0xab, 0x2f,
  5920  	0x8e, 0x28, 0xb8, 0x91, 0x56, 0x8f, 0x21, 0x27, 0xd3, 0x01, 0x7d, 0x00, 0x45, 0x8a, 0x43, 0x17,
  5921  	0x13, 0x5d, 0xb9, 0x8b, 0xcd, 0xf2, 0xa8, 0x08, 0x8b, 0x01, 0x51, 0x78, 0x65, 0xcb, 0xe5, 0x5f,
  5922  	0x4e, 0x3a, 0x0f, 0xd3, 0x93, 0xd7, 0x9b, 0x4a, 0xa9, 0x55, 0x28, 0xf8, 0x36, 0x65, 0x56, 0x40,
  5923  	0x87, 0xe2, 0x68, 0xe9, 0x17, 0x4d, 0x9e, 0x5b, 0x1f, 0xd2, 0x61, 0x95, 0xc2, 0xd2, 0x4c, 0xaa,
  5924  	0xa0, 0xef, 0xc3, 0x22, 0xaf, 0x9f, 0x7a, 0x03, 0xb1, 0x0c, 0x23, 0xab, 0x90, 0x0b, 0x7c, 0x6c,
  5925  	0x5f, 0x0f, 0xa1, 0xdb, 0x80, 0x0e, 0x3d, 0xca, 0xa2, 0x21, 0xb1, 0x03, 0x4b, 0x3d, 0x93, 0xe4,
  5926  	0xe5, 0xa1, 0xa7, 0x5a, 0x1e, 0x8d, 0xb7, 0xd4, 0x70, 0xf5, 0xcb, 0x0c, 0x5c, 0x3d, 0x77, 0x4f,
  5927  	0xd1, 0x36, 0x17, 0x97, 0x87, 0x33, 0x2b, 0xee, 0x3b, 0xe7, 0xec, 0xd8, 0xb4, 0x9e, 0x0a, 0x25,
  5928  	0xf4, 0x44, 0xbf, 0x35, 0x00, 0x8d, 0x89, 0x06, 0xc4, 0xd6, 0xdf, 0x8e, 0x9c, 0xeb, 0x67, 0xdf,
  5929  	0x4c, 0x02, 0xd6, 0xb7, 0xf4, 0x04, 0xdb, 0x8a, 0xbf, 0x1d, 0x32, 0x72, 0x6a, 0x2e, 0x3b, 0xb3,
  5930  	0x76, 0xc4, 0x00, 0x08, 0xa6, 0x49, 0x80, 0xad, 0x38, 0xd2, 0x6f, 0xb3, 0x47, 0xdf, 0x50, 0x14,
  5931  	0xa6, 0x20, 0xde, 0x8f, 0xa8, 0x9c, 0xbd, 0x48, 0x74, 0xbf, 0xda, 0x82, 0x6b, 0xe7, 0x87, 0xc8,
  5932  	0x5f, 0x49, 0x4f, 0xf0, 0xa9, 0xd8, 0xd7, 0x39, 0x93, 0x37, 0xf9, 0x6b, 0xea, 0xa9, 0xed, 0x27,
  5933  	0xf2, 0xc5, 0x91, 0x36, 0x65, 0x67, 0x23, 0xfd, 0xa1, 0x51, 0xfd, 0x11, 0x2c, 0x4e, 0x4f, 0xf1,
  5934  	0x26, 0x74, 0x66, 0x12, 0xfd, 0x31, 0xe4, 0x55, 0x91, 0x40, 0xef, 0x01, 0x88, 0xe7, 0x80, 0x45,
  5935  	0xb0, 0x2d, 0x73, 0x2a, 0xa3, 0x8f, 0x9a, 0xb0, 0x9b, 0xd8, 0x76, 0xd1, 0xbb, 0x50, 0x14, 0xc9,
  5936  	0x27, 0x7c, 0xd2, 0x13, 0x3e, 0x05, 0x6e, 0xe6, 0x2e, 0xcd, 0xbc, 0x9a, 0xec, 0x41, 0xb6, 0x90,
  5937  	0x2b, 0xe7, 0x6b, 0xbf, 0x37, 0xa0, 0xd2, 0xf2, 0x28, 0xeb, 0x7d, 0xbc, 0xf3, 0x13, 0xf9, 0xab,
  5938  	0xc6, 0xfd, 0x88, 0x52, 0x2f, 0x16, 0xb7, 0xd2, 0xcd, 0xe9, 0xdf, 0x3f, 0x16, 0x9a, 0xd7, 0x38,
  5939  	0xd9, 0x57, 0x2f, 0x56, 0x17, 0xa7, 0x21, 0xe3, 0x5f, 0x44, 0x3a, 0x70, 0x25, 0xf0, 0x42, 0xcb,
  5940  	0x76, 0x1c, 0x1c, 0xf3, 0xdc, 0xd1, 0xf0, 0xf4, 0x6b, 0xe1, 0x28, 0xf0, 0xc2, 0x4d, 0x05, 0x51,
  5941  	0xb6, 0xda, 0x1d, 0xf8, 0x3f, 0xe5, 0xd5, 0x22, 0xb6, 0x17, 0x7a, 0xe1, 0x50, 0x84, 0xb4, 0x06,
  5942  	0x05, 0x57, 0xf5, 0x45, 0x4c, 0xfa, 0x9c, 0x8c, 0xac, 0xcd, 0x0f, 0x9e, 0xfd, 0x73, 0x25, 0xf5,
  5943  	0xec, 0x6c, 0xc5, 0xf8, 0xe2, 0x6c, 0xc5, 0x78, 0x7e, 0xb6, 0x62, 0xfc, 0xe3, 0x6c, 0xc5, 0xf8,
  5944  	0xdd, 0xcb, 0x95, 0xd4, 0x17, 0x2f, 0x57, 0x52, 0xcf, 0x5f, 0xae, 0xa4, 0x3e, 0x2d, 0x4d, 0xfc,
  5945  	0x1a, 0xf7, 0xdf, 0x00, 0x00, 0x00, 0xff, 0xff, 0x73, 0xa5, 0xd1, 0x94, 0x9f, 0x13, 0x00, 0x00,
  5946  }