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

     1  // Code generated by protoc-gen-gogo. DO NOT EDIT.
     2  // source: sql/execinfrapb/api.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 roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    16  
    17  import github_com_cockroachdb_cockroach_pkg_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
    18  import time "time"
    19  
    20  import (
    21  	context "context"
    22  	grpc "google.golang.org/grpc"
    23  )
    24  
    25  import github_com_gogo_protobuf_types "github.com/gogo/protobuf/types"
    26  
    27  import io "io"
    28  
    29  // Reference imports to suppress errors if they are not otherwise used.
    30  var _ = proto.Marshal
    31  var _ = fmt.Errorf
    32  var _ = math.Inf
    33  var _ = time.Kitchen
    34  
    35  // This is a compile-time assertion to ensure that this generated file
    36  // is compatible with the proto package it is being compiled against.
    37  // A compilation error at this line likely means your copy of the
    38  // proto package needs to be updated.
    39  const _ = proto.GoGoProtoPackageIsVersion2 // please upgrade the proto package
    40  
    41  // BytesEncodeFormat is the configuration for bytes to string conversions.
    42  type BytesEncodeFormat int32
    43  
    44  const (
    45  	BytesEncodeFormat_HEX    BytesEncodeFormat = 0
    46  	BytesEncodeFormat_ESCAPE BytesEncodeFormat = 1
    47  	BytesEncodeFormat_BASE64 BytesEncodeFormat = 2
    48  )
    49  
    50  var BytesEncodeFormat_name = map[int32]string{
    51  	0: "HEX",
    52  	1: "ESCAPE",
    53  	2: "BASE64",
    54  }
    55  var BytesEncodeFormat_value = map[string]int32{
    56  	"HEX":    0,
    57  	"ESCAPE": 1,
    58  	"BASE64": 2,
    59  }
    60  
    61  func (x BytesEncodeFormat) Enum() *BytesEncodeFormat {
    62  	p := new(BytesEncodeFormat)
    63  	*p = x
    64  	return p
    65  }
    66  func (x BytesEncodeFormat) String() string {
    67  	return proto.EnumName(BytesEncodeFormat_name, int32(x))
    68  }
    69  func (x *BytesEncodeFormat) UnmarshalJSON(data []byte) error {
    70  	value, err := proto.UnmarshalJSONEnum(BytesEncodeFormat_value, data, "BytesEncodeFormat")
    71  	if err != nil {
    72  		return err
    73  	}
    74  	*x = BytesEncodeFormat(value)
    75  	return nil
    76  }
    77  func (BytesEncodeFormat) EnumDescriptor() ([]byte, []int) {
    78  	return fileDescriptor_api_45d3d17cbc679dc1, []int{0}
    79  }
    80  
    81  type SetupFlowRequest struct {
    82  	// LeafTxnInputState is the input parameter for the *client.Txn needed for
    83  	// executing the flow.
    84  	// If nil, the flow will not run in a higher-level transaction
    85  	// (i.e. it is responsible for managing its own transactions, if any). Most
    86  	// flows expect to run in a txn, but some, like backfills, don't.
    87  	LeafTxnInputState *roachpb.LeafTxnInputState `protobuf:"bytes,7,opt,name=leaf_txn_input_state,json=leafTxnInputState" json:"leaf_txn_input_state,omitempty"`
    88  	// Version of distsqlrun protocol; a server accepts a certain range of
    89  	// versions, up to its own version. See server.go for more details.
    90  	Version     DistSQLVersion `protobuf:"varint,5,opt,name=version,casttype=DistSQLVersion" json:"version"`
    91  	Flow        FlowSpec       `protobuf:"bytes,3,opt,name=flow" json:"flow"`
    92  	EvalContext EvalContext    `protobuf:"bytes,6,opt,name=evalContext" json:"evalContext"`
    93  	TraceKV     bool           `protobuf:"varint,8,opt,name=TraceKV" json:"TraceKV"`
    94  }
    95  
    96  func (m *SetupFlowRequest) Reset()         { *m = SetupFlowRequest{} }
    97  func (m *SetupFlowRequest) String() string { return proto.CompactTextString(m) }
    98  func (*SetupFlowRequest) ProtoMessage()    {}
    99  func (*SetupFlowRequest) Descriptor() ([]byte, []int) {
   100  	return fileDescriptor_api_45d3d17cbc679dc1, []int{0}
   101  }
   102  func (m *SetupFlowRequest) XXX_Unmarshal(b []byte) error {
   103  	return m.Unmarshal(b)
   104  }
   105  func (m *SetupFlowRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   106  	b = b[:cap(b)]
   107  	n, err := m.MarshalTo(b)
   108  	if err != nil {
   109  		return nil, err
   110  	}
   111  	return b[:n], nil
   112  }
   113  func (dst *SetupFlowRequest) XXX_Merge(src proto.Message) {
   114  	xxx_messageInfo_SetupFlowRequest.Merge(dst, src)
   115  }
   116  func (m *SetupFlowRequest) XXX_Size() int {
   117  	return m.Size()
   118  }
   119  func (m *SetupFlowRequest) XXX_DiscardUnknown() {
   120  	xxx_messageInfo_SetupFlowRequest.DiscardUnknown(m)
   121  }
   122  
   123  var xxx_messageInfo_SetupFlowRequest proto.InternalMessageInfo
   124  
   125  // FlowSpec describes a "flow" which is a subgraph of a distributed SQL
   126  // computation consisting of processors and streams.
   127  type FlowSpec struct {
   128  	FlowID FlowID `protobuf:"bytes,1,opt,name=flow_id,json=flowId,customtype=FlowID" json:"flow_id"`
   129  	// The NodeID of the gateway that planned this Flow. Used for debugging.
   130  	Gateway    github_com_cockroachdb_cockroach_pkg_roachpb.NodeID `protobuf:"varint,3,opt,name=gateway,casttype=github.com/cockroachdb/cockroach/pkg/roachpb.NodeID" json:"gateway"`
   131  	Processors []ProcessorSpec                                     `protobuf:"bytes,2,rep,name=processors" json:"processors"`
   132  }
   133  
   134  func (m *FlowSpec) Reset()         { *m = FlowSpec{} }
   135  func (m *FlowSpec) String() string { return proto.CompactTextString(m) }
   136  func (*FlowSpec) ProtoMessage()    {}
   137  func (*FlowSpec) Descriptor() ([]byte, []int) {
   138  	return fileDescriptor_api_45d3d17cbc679dc1, []int{1}
   139  }
   140  func (m *FlowSpec) XXX_Unmarshal(b []byte) error {
   141  	return m.Unmarshal(b)
   142  }
   143  func (m *FlowSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   144  	b = b[:cap(b)]
   145  	n, err := m.MarshalTo(b)
   146  	if err != nil {
   147  		return nil, err
   148  	}
   149  	return b[:n], nil
   150  }
   151  func (dst *FlowSpec) XXX_Merge(src proto.Message) {
   152  	xxx_messageInfo_FlowSpec.Merge(dst, src)
   153  }
   154  func (m *FlowSpec) XXX_Size() int {
   155  	return m.Size()
   156  }
   157  func (m *FlowSpec) XXX_DiscardUnknown() {
   158  	xxx_messageInfo_FlowSpec.DiscardUnknown(m)
   159  }
   160  
   161  var xxx_messageInfo_FlowSpec proto.InternalMessageInfo
   162  
   163  // EvalContext is used to marshall some planner.EvalContext members.
   164  type EvalContext struct {
   165  	StmtTimestampNanos int64 `protobuf:"varint,1,opt,name=stmtTimestampNanos" json:"stmtTimestampNanos"`
   166  	TxnTimestampNanos  int64 `protobuf:"varint,2,opt,name=txnTimestampNanos" json:"txnTimestampNanos"`
   167  	// The name of the location according to whose current timezone we're going to
   168  	// parse timestamps. Used to init EvalContext.Location.
   169  	Location            string            `protobuf:"bytes,4,opt,name=location" json:"location"`
   170  	Database            string            `protobuf:"bytes,5,opt,name=database" json:"database"`
   171  	SearchPath          []string          `protobuf:"bytes,6,rep,name=search_path,json=searchPath" json:"search_path,omitempty"`
   172  	TemporarySchemaName string            `protobuf:"bytes,13,opt,name=temporary_schema_name,json=temporarySchemaName" json:"temporary_schema_name"`
   173  	User                string            `protobuf:"bytes,7,opt,name=user" json:"user"`
   174  	SeqState            SequenceState     `protobuf:"bytes,8,opt,name=seq_state,json=seqState" json:"seq_state"`
   175  	ApplicationName     string            `protobuf:"bytes,9,opt,name=application_name,json=applicationName" json:"application_name"`
   176  	BytesEncodeFormat   BytesEncodeFormat `protobuf:"varint,10,opt,name=bytes_encode_format,json=bytesEncodeFormat,enum=cockroach.sql.distsqlrun.BytesEncodeFormat" json:"bytes_encode_format"`
   177  	ExtraFloatDigits    int32             `protobuf:"varint,11,opt,name=extra_float_digits,json=extraFloatDigits" json:"extra_float_digits"`
   178  	Vectorize           int32             `protobuf:"varint,12,opt,name=vectorize" json:"vectorize"`
   179  }
   180  
   181  func (m *EvalContext) Reset()         { *m = EvalContext{} }
   182  func (m *EvalContext) String() string { return proto.CompactTextString(m) }
   183  func (*EvalContext) ProtoMessage()    {}
   184  func (*EvalContext) Descriptor() ([]byte, []int) {
   185  	return fileDescriptor_api_45d3d17cbc679dc1, []int{2}
   186  }
   187  func (m *EvalContext) XXX_Unmarshal(b []byte) error {
   188  	return m.Unmarshal(b)
   189  }
   190  func (m *EvalContext) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   191  	b = b[:cap(b)]
   192  	n, err := m.MarshalTo(b)
   193  	if err != nil {
   194  		return nil, err
   195  	}
   196  	return b[:n], nil
   197  }
   198  func (dst *EvalContext) XXX_Merge(src proto.Message) {
   199  	xxx_messageInfo_EvalContext.Merge(dst, src)
   200  }
   201  func (m *EvalContext) XXX_Size() int {
   202  	return m.Size()
   203  }
   204  func (m *EvalContext) XXX_DiscardUnknown() {
   205  	xxx_messageInfo_EvalContext.DiscardUnknown(m)
   206  }
   207  
   208  var xxx_messageInfo_EvalContext proto.InternalMessageInfo
   209  
   210  // SequenceState is used to marshall the sessiondata.SequenceState struct.
   211  type SequenceState struct {
   212  	Seqs []*SequenceState_Seq `protobuf:"bytes,1,rep,name=seqs" json:"seqs,omitempty"`
   213  	// last_seq_incremented is the id of the last sequence incremented by the
   214  	// session. This field is filled in iff seqs is not empty.
   215  	LastSeqIncremented *uint32 `protobuf:"varint,2,opt,name=last_seq_incremented,json=lastSeqIncremented" json:"last_seq_incremented,omitempty"`
   216  }
   217  
   218  func (m *SequenceState) Reset()         { *m = SequenceState{} }
   219  func (m *SequenceState) String() string { return proto.CompactTextString(m) }
   220  func (*SequenceState) ProtoMessage()    {}
   221  func (*SequenceState) Descriptor() ([]byte, []int) {
   222  	return fileDescriptor_api_45d3d17cbc679dc1, []int{3}
   223  }
   224  func (m *SequenceState) XXX_Unmarshal(b []byte) error {
   225  	return m.Unmarshal(b)
   226  }
   227  func (m *SequenceState) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   228  	b = b[:cap(b)]
   229  	n, err := m.MarshalTo(b)
   230  	if err != nil {
   231  		return nil, err
   232  	}
   233  	return b[:n], nil
   234  }
   235  func (dst *SequenceState) XXX_Merge(src proto.Message) {
   236  	xxx_messageInfo_SequenceState.Merge(dst, src)
   237  }
   238  func (m *SequenceState) XXX_Size() int {
   239  	return m.Size()
   240  }
   241  func (m *SequenceState) XXX_DiscardUnknown() {
   242  	xxx_messageInfo_SequenceState.DiscardUnknown(m)
   243  }
   244  
   245  var xxx_messageInfo_SequenceState proto.InternalMessageInfo
   246  
   247  // Seq represents the last value of one sequence modified by the session.
   248  type SequenceState_Seq struct {
   249  	SeqID     uint32 `protobuf:"varint,1,opt,name=seq_id,json=seqId" json:"seq_id"`
   250  	LatestVal int64  `protobuf:"varint,2,opt,name=latest_val,json=latestVal" json:"latest_val"`
   251  }
   252  
   253  func (m *SequenceState_Seq) Reset()         { *m = SequenceState_Seq{} }
   254  func (m *SequenceState_Seq) String() string { return proto.CompactTextString(m) }
   255  func (*SequenceState_Seq) ProtoMessage()    {}
   256  func (*SequenceState_Seq) Descriptor() ([]byte, []int) {
   257  	return fileDescriptor_api_45d3d17cbc679dc1, []int{3, 0}
   258  }
   259  func (m *SequenceState_Seq) XXX_Unmarshal(b []byte) error {
   260  	return m.Unmarshal(b)
   261  }
   262  func (m *SequenceState_Seq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   263  	b = b[:cap(b)]
   264  	n, err := m.MarshalTo(b)
   265  	if err != nil {
   266  		return nil, err
   267  	}
   268  	return b[:n], nil
   269  }
   270  func (dst *SequenceState_Seq) XXX_Merge(src proto.Message) {
   271  	xxx_messageInfo_SequenceState_Seq.Merge(dst, src)
   272  }
   273  func (m *SequenceState_Seq) XXX_Size() int {
   274  	return m.Size()
   275  }
   276  func (m *SequenceState_Seq) XXX_DiscardUnknown() {
   277  	xxx_messageInfo_SequenceState_Seq.DiscardUnknown(m)
   278  }
   279  
   280  var xxx_messageInfo_SequenceState_Seq proto.InternalMessageInfo
   281  
   282  type SimpleResponse struct {
   283  	Error *Error `protobuf:"bytes,1,opt,name=error" json:"error,omitempty"`
   284  }
   285  
   286  func (m *SimpleResponse) Reset()         { *m = SimpleResponse{} }
   287  func (m *SimpleResponse) String() string { return proto.CompactTextString(m) }
   288  func (*SimpleResponse) ProtoMessage()    {}
   289  func (*SimpleResponse) Descriptor() ([]byte, []int) {
   290  	return fileDescriptor_api_45d3d17cbc679dc1, []int{4}
   291  }
   292  func (m *SimpleResponse) XXX_Unmarshal(b []byte) error {
   293  	return m.Unmarshal(b)
   294  }
   295  func (m *SimpleResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   296  	b = b[:cap(b)]
   297  	n, err := m.MarshalTo(b)
   298  	if err != nil {
   299  		return nil, err
   300  	}
   301  	return b[:n], nil
   302  }
   303  func (dst *SimpleResponse) XXX_Merge(src proto.Message) {
   304  	xxx_messageInfo_SimpleResponse.Merge(dst, src)
   305  }
   306  func (m *SimpleResponse) XXX_Size() int {
   307  	return m.Size()
   308  }
   309  func (m *SimpleResponse) XXX_DiscardUnknown() {
   310  	xxx_messageInfo_SimpleResponse.DiscardUnknown(m)
   311  }
   312  
   313  var xxx_messageInfo_SimpleResponse proto.InternalMessageInfo
   314  
   315  // ConsumerSignal are messages flowing from consumer to producer (so, from RPC
   316  // server to client) for the FlowStream RPC.
   317  type ConsumerSignal struct {
   318  	// The consumer is done (doesn't need to consume any more rows) and is asking
   319  	// the producer to push whatever trailing metadata it has and close its
   320  	// stream.
   321  	DrainRequest *DrainRequest `protobuf:"bytes,1,opt,name=drain_request,json=drainRequest" json:"drain_request,omitempty"`
   322  	// Used in the RunSyncFlow case; the first message on the client stream must
   323  	// contain this message.
   324  	SetupFlowRequest *SetupFlowRequest `protobuf:"bytes,2,opt,name=setup_flow_request,json=setupFlowRequest" json:"setup_flow_request,omitempty"`
   325  	// Consumer->Producer handshake messages. See message definition.
   326  	Handshake *ConsumerHandshake `protobuf:"bytes,3,opt,name=handshake" json:"handshake,omitempty"`
   327  }
   328  
   329  func (m *ConsumerSignal) Reset()         { *m = ConsumerSignal{} }
   330  func (m *ConsumerSignal) String() string { return proto.CompactTextString(m) }
   331  func (*ConsumerSignal) ProtoMessage()    {}
   332  func (*ConsumerSignal) Descriptor() ([]byte, []int) {
   333  	return fileDescriptor_api_45d3d17cbc679dc1, []int{5}
   334  }
   335  func (m *ConsumerSignal) XXX_Unmarshal(b []byte) error {
   336  	return m.Unmarshal(b)
   337  }
   338  func (m *ConsumerSignal) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   339  	b = b[:cap(b)]
   340  	n, err := m.MarshalTo(b)
   341  	if err != nil {
   342  		return nil, err
   343  	}
   344  	return b[:n], nil
   345  }
   346  func (dst *ConsumerSignal) XXX_Merge(src proto.Message) {
   347  	xxx_messageInfo_ConsumerSignal.Merge(dst, src)
   348  }
   349  func (m *ConsumerSignal) XXX_Size() int {
   350  	return m.Size()
   351  }
   352  func (m *ConsumerSignal) XXX_DiscardUnknown() {
   353  	xxx_messageInfo_ConsumerSignal.DiscardUnknown(m)
   354  }
   355  
   356  var xxx_messageInfo_ConsumerSignal proto.InternalMessageInfo
   357  
   358  type DrainRequest struct {
   359  }
   360  
   361  func (m *DrainRequest) Reset()         { *m = DrainRequest{} }
   362  func (m *DrainRequest) String() string { return proto.CompactTextString(m) }
   363  func (*DrainRequest) ProtoMessage()    {}
   364  func (*DrainRequest) Descriptor() ([]byte, []int) {
   365  	return fileDescriptor_api_45d3d17cbc679dc1, []int{6}
   366  }
   367  func (m *DrainRequest) XXX_Unmarshal(b []byte) error {
   368  	return m.Unmarshal(b)
   369  }
   370  func (m *DrainRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   371  	b = b[:cap(b)]
   372  	n, err := m.MarshalTo(b)
   373  	if err != nil {
   374  		return nil, err
   375  	}
   376  	return b[:n], nil
   377  }
   378  func (dst *DrainRequest) XXX_Merge(src proto.Message) {
   379  	xxx_messageInfo_DrainRequest.Merge(dst, src)
   380  }
   381  func (m *DrainRequest) XXX_Size() int {
   382  	return m.Size()
   383  }
   384  func (m *DrainRequest) XXX_DiscardUnknown() {
   385  	xxx_messageInfo_DrainRequest.DiscardUnknown(m)
   386  }
   387  
   388  var xxx_messageInfo_DrainRequest proto.InternalMessageInfo
   389  
   390  // ConsumerHandshake is the first one or two message sent in the
   391  // consumer->producer direction on a stream. It informs the producer about the
   392  // status of the consumer flow.
   393  // Introduced in version 1.1 for future use by producers.
   394  type ConsumerHandshake struct {
   395  	// consumer_scheduled is true if the flow that's consuming this stream has
   396  	// already been scheduled and so it is ready to consume data. If this is
   397  	// false, then the consumer has not yet been scheduled. In this case, the
   398  	// server (i.e. the consumer node) will send another ConsumerHandshake with
   399  	// consumer_scheduled = true when the consumer is finally scheduled (unless
   400  	// the scheduling timeout fires first, in which case the stream will be
   401  	// closed server-side).
   402  	ConsumerScheduled bool `protobuf:"varint,1,opt,name=consumer_scheduled,json=consumerScheduled" json:"consumer_scheduled"`
   403  	// If consumer_scheduled is false, then this indicates the deadline for the
   404  	// scheduling of the consumer flow. If the flow is not scheduled within that
   405  	// dealine, this stream will be disconnected by the server-side.
   406  	ConsumerScheduleDeadline *time.Time `protobuf:"bytes,2,opt,name=consumer_schedule_deadline,json=consumerScheduleDeadline,stdtime" json:"consumer_schedule_deadline,omitempty"`
   407  	// The server's DistSQL version range.
   408  	Version            DistSQLVersion `protobuf:"varint,3,opt,name=version,casttype=DistSQLVersion" json:"version"`
   409  	MinAcceptedVersion DistSQLVersion `protobuf:"varint,4,opt,name=min_accepted_version,json=minAcceptedVersion,casttype=DistSQLVersion" json:"min_accepted_version"`
   410  }
   411  
   412  func (m *ConsumerHandshake) Reset()         { *m = ConsumerHandshake{} }
   413  func (m *ConsumerHandshake) String() string { return proto.CompactTextString(m) }
   414  func (*ConsumerHandshake) ProtoMessage()    {}
   415  func (*ConsumerHandshake) Descriptor() ([]byte, []int) {
   416  	return fileDescriptor_api_45d3d17cbc679dc1, []int{7}
   417  }
   418  func (m *ConsumerHandshake) XXX_Unmarshal(b []byte) error {
   419  	return m.Unmarshal(b)
   420  }
   421  func (m *ConsumerHandshake) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   422  	b = b[:cap(b)]
   423  	n, err := m.MarshalTo(b)
   424  	if err != nil {
   425  		return nil, err
   426  	}
   427  	return b[:n], nil
   428  }
   429  func (dst *ConsumerHandshake) XXX_Merge(src proto.Message) {
   430  	xxx_messageInfo_ConsumerHandshake.Merge(dst, src)
   431  }
   432  func (m *ConsumerHandshake) XXX_Size() int {
   433  	return m.Size()
   434  }
   435  func (m *ConsumerHandshake) XXX_DiscardUnknown() {
   436  	xxx_messageInfo_ConsumerHandshake.DiscardUnknown(m)
   437  }
   438  
   439  var xxx_messageInfo_ConsumerHandshake proto.InternalMessageInfo
   440  
   441  func init() {
   442  	proto.RegisterType((*SetupFlowRequest)(nil), "cockroach.sql.distsqlrun.SetupFlowRequest")
   443  	proto.RegisterType((*FlowSpec)(nil), "cockroach.sql.distsqlrun.FlowSpec")
   444  	proto.RegisterType((*EvalContext)(nil), "cockroach.sql.distsqlrun.EvalContext")
   445  	proto.RegisterType((*SequenceState)(nil), "cockroach.sql.distsqlrun.SequenceState")
   446  	proto.RegisterType((*SequenceState_Seq)(nil), "cockroach.sql.distsqlrun.SequenceState.Seq")
   447  	proto.RegisterType((*SimpleResponse)(nil), "cockroach.sql.distsqlrun.SimpleResponse")
   448  	proto.RegisterType((*ConsumerSignal)(nil), "cockroach.sql.distsqlrun.ConsumerSignal")
   449  	proto.RegisterType((*DrainRequest)(nil), "cockroach.sql.distsqlrun.DrainRequest")
   450  	proto.RegisterType((*ConsumerHandshake)(nil), "cockroach.sql.distsqlrun.ConsumerHandshake")
   451  	proto.RegisterEnum("cockroach.sql.distsqlrun.BytesEncodeFormat", BytesEncodeFormat_name, BytesEncodeFormat_value)
   452  }
   453  
   454  // Reference imports to suppress errors if they are not otherwise used.
   455  var _ context.Context
   456  var _ grpc.ClientConn
   457  
   458  // This is a compile-time assertion to ensure that this generated file
   459  // is compatible with the grpc package it is being compiled against.
   460  const _ = grpc.SupportPackageIsVersion4
   461  
   462  // DistSQLClient is the client API for DistSQL service.
   463  //
   464  // For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.
   465  type DistSQLClient interface {
   466  	// RunSyncFlow instantiates a flow and streams back results of that flow.
   467  	// The request must contain one flow, and that flow must have a single mailbox
   468  	// of the special sync response type.
   469  	RunSyncFlow(ctx context.Context, opts ...grpc.CallOption) (DistSQL_RunSyncFlowClient, error)
   470  	// SetupFlow instantiates a flow (subgraphs of a distributed SQL
   471  	// computation) on the receiving node.
   472  	SetupFlow(ctx context.Context, in *SetupFlowRequest, opts ...grpc.CallOption) (*SimpleResponse, error)
   473  	// FlowStream is used to push a stream of messages that is part of a flow. The
   474  	// first message will have a StreamHeader which identifies the flow and the
   475  	// stream (mailbox).
   476  	//
   477  	// The response is a stream that the consumer uses to perform a handshake and
   478  	// to signal the producer when it wants it to start draining. The client (i.e.
   479  	// the producer) will read from this consumer->producer stream until it has
   480  	// sent everything it needs to send and it performs CloseSend() on the
   481  	// producer->consumer stream; after that point the producer isn't listening
   482  	// for consumer signals any more.
   483  	FlowStream(ctx context.Context, opts ...grpc.CallOption) (DistSQL_FlowStreamClient, error)
   484  }
   485  
   486  type distSQLClient struct {
   487  	cc *grpc.ClientConn
   488  }
   489  
   490  func NewDistSQLClient(cc *grpc.ClientConn) DistSQLClient {
   491  	return &distSQLClient{cc}
   492  }
   493  
   494  func (c *distSQLClient) RunSyncFlow(ctx context.Context, opts ...grpc.CallOption) (DistSQL_RunSyncFlowClient, error) {
   495  	stream, err := c.cc.NewStream(ctx, &_DistSQL_serviceDesc.Streams[0], "/cockroach.sql.distsqlrun.DistSQL/RunSyncFlow", opts...)
   496  	if err != nil {
   497  		return nil, err
   498  	}
   499  	x := &distSQLRunSyncFlowClient{stream}
   500  	return x, nil
   501  }
   502  
   503  type DistSQL_RunSyncFlowClient interface {
   504  	Send(*ConsumerSignal) error
   505  	Recv() (*ProducerMessage, error)
   506  	grpc.ClientStream
   507  }
   508  
   509  type distSQLRunSyncFlowClient struct {
   510  	grpc.ClientStream
   511  }
   512  
   513  func (x *distSQLRunSyncFlowClient) Send(m *ConsumerSignal) error {
   514  	return x.ClientStream.SendMsg(m)
   515  }
   516  
   517  func (x *distSQLRunSyncFlowClient) Recv() (*ProducerMessage, error) {
   518  	m := new(ProducerMessage)
   519  	if err := x.ClientStream.RecvMsg(m); err != nil {
   520  		return nil, err
   521  	}
   522  	return m, nil
   523  }
   524  
   525  func (c *distSQLClient) SetupFlow(ctx context.Context, in *SetupFlowRequest, opts ...grpc.CallOption) (*SimpleResponse, error) {
   526  	out := new(SimpleResponse)
   527  	err := c.cc.Invoke(ctx, "/cockroach.sql.distsqlrun.DistSQL/SetupFlow", in, out, opts...)
   528  	if err != nil {
   529  		return nil, err
   530  	}
   531  	return out, nil
   532  }
   533  
   534  func (c *distSQLClient) FlowStream(ctx context.Context, opts ...grpc.CallOption) (DistSQL_FlowStreamClient, error) {
   535  	stream, err := c.cc.NewStream(ctx, &_DistSQL_serviceDesc.Streams[1], "/cockroach.sql.distsqlrun.DistSQL/FlowStream", opts...)
   536  	if err != nil {
   537  		return nil, err
   538  	}
   539  	x := &distSQLFlowStreamClient{stream}
   540  	return x, nil
   541  }
   542  
   543  type DistSQL_FlowStreamClient interface {
   544  	Send(*ProducerMessage) error
   545  	Recv() (*ConsumerSignal, error)
   546  	grpc.ClientStream
   547  }
   548  
   549  type distSQLFlowStreamClient struct {
   550  	grpc.ClientStream
   551  }
   552  
   553  func (x *distSQLFlowStreamClient) Send(m *ProducerMessage) error {
   554  	return x.ClientStream.SendMsg(m)
   555  }
   556  
   557  func (x *distSQLFlowStreamClient) Recv() (*ConsumerSignal, error) {
   558  	m := new(ConsumerSignal)
   559  	if err := x.ClientStream.RecvMsg(m); err != nil {
   560  		return nil, err
   561  	}
   562  	return m, nil
   563  }
   564  
   565  // DistSQLServer is the server API for DistSQL service.
   566  type DistSQLServer interface {
   567  	// RunSyncFlow instantiates a flow and streams back results of that flow.
   568  	// The request must contain one flow, and that flow must have a single mailbox
   569  	// of the special sync response type.
   570  	RunSyncFlow(DistSQL_RunSyncFlowServer) error
   571  	// SetupFlow instantiates a flow (subgraphs of a distributed SQL
   572  	// computation) on the receiving node.
   573  	SetupFlow(context.Context, *SetupFlowRequest) (*SimpleResponse, error)
   574  	// FlowStream is used to push a stream of messages that is part of a flow. The
   575  	// first message will have a StreamHeader which identifies the flow and the
   576  	// stream (mailbox).
   577  	//
   578  	// The response is a stream that the consumer uses to perform a handshake and
   579  	// to signal the producer when it wants it to start draining. The client (i.e.
   580  	// the producer) will read from this consumer->producer stream until it has
   581  	// sent everything it needs to send and it performs CloseSend() on the
   582  	// producer->consumer stream; after that point the producer isn't listening
   583  	// for consumer signals any more.
   584  	FlowStream(DistSQL_FlowStreamServer) error
   585  }
   586  
   587  func RegisterDistSQLServer(s *grpc.Server, srv DistSQLServer) {
   588  	s.RegisterService(&_DistSQL_serviceDesc, srv)
   589  }
   590  
   591  func _DistSQL_RunSyncFlow_Handler(srv interface{}, stream grpc.ServerStream) error {
   592  	return srv.(DistSQLServer).RunSyncFlow(&distSQLRunSyncFlowServer{stream})
   593  }
   594  
   595  type DistSQL_RunSyncFlowServer interface {
   596  	Send(*ProducerMessage) error
   597  	Recv() (*ConsumerSignal, error)
   598  	grpc.ServerStream
   599  }
   600  
   601  type distSQLRunSyncFlowServer struct {
   602  	grpc.ServerStream
   603  }
   604  
   605  func (x *distSQLRunSyncFlowServer) Send(m *ProducerMessage) error {
   606  	return x.ServerStream.SendMsg(m)
   607  }
   608  
   609  func (x *distSQLRunSyncFlowServer) Recv() (*ConsumerSignal, error) {
   610  	m := new(ConsumerSignal)
   611  	if err := x.ServerStream.RecvMsg(m); err != nil {
   612  		return nil, err
   613  	}
   614  	return m, nil
   615  }
   616  
   617  func _DistSQL_SetupFlow_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
   618  	in := new(SetupFlowRequest)
   619  	if err := dec(in); err != nil {
   620  		return nil, err
   621  	}
   622  	if interceptor == nil {
   623  		return srv.(DistSQLServer).SetupFlow(ctx, in)
   624  	}
   625  	info := &grpc.UnaryServerInfo{
   626  		Server:     srv,
   627  		FullMethod: "/cockroach.sql.distsqlrun.DistSQL/SetupFlow",
   628  	}
   629  	handler := func(ctx context.Context, req interface{}) (interface{}, error) {
   630  		return srv.(DistSQLServer).SetupFlow(ctx, req.(*SetupFlowRequest))
   631  	}
   632  	return interceptor(ctx, in, info, handler)
   633  }
   634  
   635  func _DistSQL_FlowStream_Handler(srv interface{}, stream grpc.ServerStream) error {
   636  	return srv.(DistSQLServer).FlowStream(&distSQLFlowStreamServer{stream})
   637  }
   638  
   639  type DistSQL_FlowStreamServer interface {
   640  	Send(*ConsumerSignal) error
   641  	Recv() (*ProducerMessage, error)
   642  	grpc.ServerStream
   643  }
   644  
   645  type distSQLFlowStreamServer struct {
   646  	grpc.ServerStream
   647  }
   648  
   649  func (x *distSQLFlowStreamServer) Send(m *ConsumerSignal) error {
   650  	return x.ServerStream.SendMsg(m)
   651  }
   652  
   653  func (x *distSQLFlowStreamServer) Recv() (*ProducerMessage, error) {
   654  	m := new(ProducerMessage)
   655  	if err := x.ServerStream.RecvMsg(m); err != nil {
   656  		return nil, err
   657  	}
   658  	return m, nil
   659  }
   660  
   661  var _DistSQL_serviceDesc = grpc.ServiceDesc{
   662  	ServiceName: "cockroach.sql.distsqlrun.DistSQL",
   663  	HandlerType: (*DistSQLServer)(nil),
   664  	Methods: []grpc.MethodDesc{
   665  		{
   666  			MethodName: "SetupFlow",
   667  			Handler:    _DistSQL_SetupFlow_Handler,
   668  		},
   669  	},
   670  	Streams: []grpc.StreamDesc{
   671  		{
   672  			StreamName:    "RunSyncFlow",
   673  			Handler:       _DistSQL_RunSyncFlow_Handler,
   674  			ServerStreams: true,
   675  			ClientStreams: true,
   676  		},
   677  		{
   678  			StreamName:    "FlowStream",
   679  			Handler:       _DistSQL_FlowStream_Handler,
   680  			ServerStreams: true,
   681  			ClientStreams: true,
   682  		},
   683  	},
   684  	Metadata: "sql/execinfrapb/api.proto",
   685  }
   686  
   687  func (m *SetupFlowRequest) Marshal() (dAtA []byte, err error) {
   688  	size := m.Size()
   689  	dAtA = make([]byte, size)
   690  	n, err := m.MarshalTo(dAtA)
   691  	if err != nil {
   692  		return nil, err
   693  	}
   694  	return dAtA[:n], nil
   695  }
   696  
   697  func (m *SetupFlowRequest) MarshalTo(dAtA []byte) (int, error) {
   698  	var i int
   699  	_ = i
   700  	var l int
   701  	_ = l
   702  	dAtA[i] = 0x1a
   703  	i++
   704  	i = encodeVarintApi(dAtA, i, uint64(m.Flow.Size()))
   705  	n1, err := m.Flow.MarshalTo(dAtA[i:])
   706  	if err != nil {
   707  		return 0, err
   708  	}
   709  	i += n1
   710  	dAtA[i] = 0x28
   711  	i++
   712  	i = encodeVarintApi(dAtA, i, uint64(m.Version))
   713  	dAtA[i] = 0x32
   714  	i++
   715  	i = encodeVarintApi(dAtA, i, uint64(m.EvalContext.Size()))
   716  	n2, err := m.EvalContext.MarshalTo(dAtA[i:])
   717  	if err != nil {
   718  		return 0, err
   719  	}
   720  	i += n2
   721  	if m.LeafTxnInputState != nil {
   722  		dAtA[i] = 0x3a
   723  		i++
   724  		i = encodeVarintApi(dAtA, i, uint64(m.LeafTxnInputState.Size()))
   725  		n3, err := m.LeafTxnInputState.MarshalTo(dAtA[i:])
   726  		if err != nil {
   727  			return 0, err
   728  		}
   729  		i += n3
   730  	}
   731  	dAtA[i] = 0x40
   732  	i++
   733  	if m.TraceKV {
   734  		dAtA[i] = 1
   735  	} else {
   736  		dAtA[i] = 0
   737  	}
   738  	i++
   739  	return i, nil
   740  }
   741  
   742  func (m *FlowSpec) Marshal() (dAtA []byte, err error) {
   743  	size := m.Size()
   744  	dAtA = make([]byte, size)
   745  	n, err := m.MarshalTo(dAtA)
   746  	if err != nil {
   747  		return nil, err
   748  	}
   749  	return dAtA[:n], nil
   750  }
   751  
   752  func (m *FlowSpec) MarshalTo(dAtA []byte) (int, error) {
   753  	var i int
   754  	_ = i
   755  	var l int
   756  	_ = l
   757  	dAtA[i] = 0xa
   758  	i++
   759  	i = encodeVarintApi(dAtA, i, uint64(m.FlowID.Size()))
   760  	n4, err := m.FlowID.MarshalTo(dAtA[i:])
   761  	if err != nil {
   762  		return 0, err
   763  	}
   764  	i += n4
   765  	if len(m.Processors) > 0 {
   766  		for _, msg := range m.Processors {
   767  			dAtA[i] = 0x12
   768  			i++
   769  			i = encodeVarintApi(dAtA, i, uint64(msg.Size()))
   770  			n, err := msg.MarshalTo(dAtA[i:])
   771  			if err != nil {
   772  				return 0, err
   773  			}
   774  			i += n
   775  		}
   776  	}
   777  	dAtA[i] = 0x18
   778  	i++
   779  	i = encodeVarintApi(dAtA, i, uint64(m.Gateway))
   780  	return i, nil
   781  }
   782  
   783  func (m *EvalContext) Marshal() (dAtA []byte, err error) {
   784  	size := m.Size()
   785  	dAtA = make([]byte, size)
   786  	n, err := m.MarshalTo(dAtA)
   787  	if err != nil {
   788  		return nil, err
   789  	}
   790  	return dAtA[:n], nil
   791  }
   792  
   793  func (m *EvalContext) MarshalTo(dAtA []byte) (int, error) {
   794  	var i int
   795  	_ = i
   796  	var l int
   797  	_ = l
   798  	dAtA[i] = 0x8
   799  	i++
   800  	i = encodeVarintApi(dAtA, i, uint64(m.StmtTimestampNanos))
   801  	dAtA[i] = 0x10
   802  	i++
   803  	i = encodeVarintApi(dAtA, i, uint64(m.TxnTimestampNanos))
   804  	dAtA[i] = 0x22
   805  	i++
   806  	i = encodeVarintApi(dAtA, i, uint64(len(m.Location)))
   807  	i += copy(dAtA[i:], m.Location)
   808  	dAtA[i] = 0x2a
   809  	i++
   810  	i = encodeVarintApi(dAtA, i, uint64(len(m.Database)))
   811  	i += copy(dAtA[i:], m.Database)
   812  	if len(m.SearchPath) > 0 {
   813  		for _, s := range m.SearchPath {
   814  			dAtA[i] = 0x32
   815  			i++
   816  			l = len(s)
   817  			for l >= 1<<7 {
   818  				dAtA[i] = uint8(uint64(l)&0x7f | 0x80)
   819  				l >>= 7
   820  				i++
   821  			}
   822  			dAtA[i] = uint8(l)
   823  			i++
   824  			i += copy(dAtA[i:], s)
   825  		}
   826  	}
   827  	dAtA[i] = 0x3a
   828  	i++
   829  	i = encodeVarintApi(dAtA, i, uint64(len(m.User)))
   830  	i += copy(dAtA[i:], m.User)
   831  	dAtA[i] = 0x42
   832  	i++
   833  	i = encodeVarintApi(dAtA, i, uint64(m.SeqState.Size()))
   834  	n5, err := m.SeqState.MarshalTo(dAtA[i:])
   835  	if err != nil {
   836  		return 0, err
   837  	}
   838  	i += n5
   839  	dAtA[i] = 0x4a
   840  	i++
   841  	i = encodeVarintApi(dAtA, i, uint64(len(m.ApplicationName)))
   842  	i += copy(dAtA[i:], m.ApplicationName)
   843  	dAtA[i] = 0x50
   844  	i++
   845  	i = encodeVarintApi(dAtA, i, uint64(m.BytesEncodeFormat))
   846  	dAtA[i] = 0x58
   847  	i++
   848  	i = encodeVarintApi(dAtA, i, uint64(m.ExtraFloatDigits))
   849  	dAtA[i] = 0x60
   850  	i++
   851  	i = encodeVarintApi(dAtA, i, uint64(m.Vectorize))
   852  	dAtA[i] = 0x6a
   853  	i++
   854  	i = encodeVarintApi(dAtA, i, uint64(len(m.TemporarySchemaName)))
   855  	i += copy(dAtA[i:], m.TemporarySchemaName)
   856  	return i, nil
   857  }
   858  
   859  func (m *SequenceState) Marshal() (dAtA []byte, err error) {
   860  	size := m.Size()
   861  	dAtA = make([]byte, size)
   862  	n, err := m.MarshalTo(dAtA)
   863  	if err != nil {
   864  		return nil, err
   865  	}
   866  	return dAtA[:n], nil
   867  }
   868  
   869  func (m *SequenceState) MarshalTo(dAtA []byte) (int, error) {
   870  	var i int
   871  	_ = i
   872  	var l int
   873  	_ = l
   874  	if len(m.Seqs) > 0 {
   875  		for _, msg := range m.Seqs {
   876  			dAtA[i] = 0xa
   877  			i++
   878  			i = encodeVarintApi(dAtA, i, uint64(msg.Size()))
   879  			n, err := msg.MarshalTo(dAtA[i:])
   880  			if err != nil {
   881  				return 0, err
   882  			}
   883  			i += n
   884  		}
   885  	}
   886  	if m.LastSeqIncremented != nil {
   887  		dAtA[i] = 0x10
   888  		i++
   889  		i = encodeVarintApi(dAtA, i, uint64(*m.LastSeqIncremented))
   890  	}
   891  	return i, nil
   892  }
   893  
   894  func (m *SequenceState_Seq) Marshal() (dAtA []byte, err error) {
   895  	size := m.Size()
   896  	dAtA = make([]byte, size)
   897  	n, err := m.MarshalTo(dAtA)
   898  	if err != nil {
   899  		return nil, err
   900  	}
   901  	return dAtA[:n], nil
   902  }
   903  
   904  func (m *SequenceState_Seq) MarshalTo(dAtA []byte) (int, error) {
   905  	var i int
   906  	_ = i
   907  	var l int
   908  	_ = l
   909  	dAtA[i] = 0x8
   910  	i++
   911  	i = encodeVarintApi(dAtA, i, uint64(m.SeqID))
   912  	dAtA[i] = 0x10
   913  	i++
   914  	i = encodeVarintApi(dAtA, i, uint64(m.LatestVal))
   915  	return i, nil
   916  }
   917  
   918  func (m *SimpleResponse) Marshal() (dAtA []byte, err error) {
   919  	size := m.Size()
   920  	dAtA = make([]byte, size)
   921  	n, err := m.MarshalTo(dAtA)
   922  	if err != nil {
   923  		return nil, err
   924  	}
   925  	return dAtA[:n], nil
   926  }
   927  
   928  func (m *SimpleResponse) MarshalTo(dAtA []byte) (int, error) {
   929  	var i int
   930  	_ = i
   931  	var l int
   932  	_ = l
   933  	if m.Error != nil {
   934  		dAtA[i] = 0xa
   935  		i++
   936  		i = encodeVarintApi(dAtA, i, uint64(m.Error.Size()))
   937  		n6, err := m.Error.MarshalTo(dAtA[i:])
   938  		if err != nil {
   939  			return 0, err
   940  		}
   941  		i += n6
   942  	}
   943  	return i, nil
   944  }
   945  
   946  func (m *ConsumerSignal) Marshal() (dAtA []byte, err error) {
   947  	size := m.Size()
   948  	dAtA = make([]byte, size)
   949  	n, err := m.MarshalTo(dAtA)
   950  	if err != nil {
   951  		return nil, err
   952  	}
   953  	return dAtA[:n], nil
   954  }
   955  
   956  func (m *ConsumerSignal) MarshalTo(dAtA []byte) (int, error) {
   957  	var i int
   958  	_ = i
   959  	var l int
   960  	_ = l
   961  	if m.DrainRequest != nil {
   962  		dAtA[i] = 0xa
   963  		i++
   964  		i = encodeVarintApi(dAtA, i, uint64(m.DrainRequest.Size()))
   965  		n7, err := m.DrainRequest.MarshalTo(dAtA[i:])
   966  		if err != nil {
   967  			return 0, err
   968  		}
   969  		i += n7
   970  	}
   971  	if m.SetupFlowRequest != nil {
   972  		dAtA[i] = 0x12
   973  		i++
   974  		i = encodeVarintApi(dAtA, i, uint64(m.SetupFlowRequest.Size()))
   975  		n8, err := m.SetupFlowRequest.MarshalTo(dAtA[i:])
   976  		if err != nil {
   977  			return 0, err
   978  		}
   979  		i += n8
   980  	}
   981  	if m.Handshake != nil {
   982  		dAtA[i] = 0x1a
   983  		i++
   984  		i = encodeVarintApi(dAtA, i, uint64(m.Handshake.Size()))
   985  		n9, err := m.Handshake.MarshalTo(dAtA[i:])
   986  		if err != nil {
   987  			return 0, err
   988  		}
   989  		i += n9
   990  	}
   991  	return i, nil
   992  }
   993  
   994  func (m *DrainRequest) Marshal() (dAtA []byte, err error) {
   995  	size := m.Size()
   996  	dAtA = make([]byte, size)
   997  	n, err := m.MarshalTo(dAtA)
   998  	if err != nil {
   999  		return nil, err
  1000  	}
  1001  	return dAtA[:n], nil
  1002  }
  1003  
  1004  func (m *DrainRequest) MarshalTo(dAtA []byte) (int, error) {
  1005  	var i int
  1006  	_ = i
  1007  	var l int
  1008  	_ = l
  1009  	return i, nil
  1010  }
  1011  
  1012  func (m *ConsumerHandshake) Marshal() (dAtA []byte, err error) {
  1013  	size := m.Size()
  1014  	dAtA = make([]byte, size)
  1015  	n, err := m.MarshalTo(dAtA)
  1016  	if err != nil {
  1017  		return nil, err
  1018  	}
  1019  	return dAtA[:n], nil
  1020  }
  1021  
  1022  func (m *ConsumerHandshake) MarshalTo(dAtA []byte) (int, error) {
  1023  	var i int
  1024  	_ = i
  1025  	var l int
  1026  	_ = l
  1027  	dAtA[i] = 0x8
  1028  	i++
  1029  	if m.ConsumerScheduled {
  1030  		dAtA[i] = 1
  1031  	} else {
  1032  		dAtA[i] = 0
  1033  	}
  1034  	i++
  1035  	if m.ConsumerScheduleDeadline != nil {
  1036  		dAtA[i] = 0x12
  1037  		i++
  1038  		i = encodeVarintApi(dAtA, i, uint64(github_com_gogo_protobuf_types.SizeOfStdTime(*m.ConsumerScheduleDeadline)))
  1039  		n10, err := github_com_gogo_protobuf_types.StdTimeMarshalTo(*m.ConsumerScheduleDeadline, dAtA[i:])
  1040  		if err != nil {
  1041  			return 0, err
  1042  		}
  1043  		i += n10
  1044  	}
  1045  	dAtA[i] = 0x18
  1046  	i++
  1047  	i = encodeVarintApi(dAtA, i, uint64(m.Version))
  1048  	dAtA[i] = 0x20
  1049  	i++
  1050  	i = encodeVarintApi(dAtA, i, uint64(m.MinAcceptedVersion))
  1051  	return i, nil
  1052  }
  1053  
  1054  func encodeVarintApi(dAtA []byte, offset int, v uint64) int {
  1055  	for v >= 1<<7 {
  1056  		dAtA[offset] = uint8(v&0x7f | 0x80)
  1057  		v >>= 7
  1058  		offset++
  1059  	}
  1060  	dAtA[offset] = uint8(v)
  1061  	return offset + 1
  1062  }
  1063  func (m *SetupFlowRequest) Size() (n int) {
  1064  	if m == nil {
  1065  		return 0
  1066  	}
  1067  	var l int
  1068  	_ = l
  1069  	l = m.Flow.Size()
  1070  	n += 1 + l + sovApi(uint64(l))
  1071  	n += 1 + sovApi(uint64(m.Version))
  1072  	l = m.EvalContext.Size()
  1073  	n += 1 + l + sovApi(uint64(l))
  1074  	if m.LeafTxnInputState != nil {
  1075  		l = m.LeafTxnInputState.Size()
  1076  		n += 1 + l + sovApi(uint64(l))
  1077  	}
  1078  	n += 2
  1079  	return n
  1080  }
  1081  
  1082  func (m *FlowSpec) Size() (n int) {
  1083  	if m == nil {
  1084  		return 0
  1085  	}
  1086  	var l int
  1087  	_ = l
  1088  	l = m.FlowID.Size()
  1089  	n += 1 + l + sovApi(uint64(l))
  1090  	if len(m.Processors) > 0 {
  1091  		for _, e := range m.Processors {
  1092  			l = e.Size()
  1093  			n += 1 + l + sovApi(uint64(l))
  1094  		}
  1095  	}
  1096  	n += 1 + sovApi(uint64(m.Gateway))
  1097  	return n
  1098  }
  1099  
  1100  func (m *EvalContext) Size() (n int) {
  1101  	if m == nil {
  1102  		return 0
  1103  	}
  1104  	var l int
  1105  	_ = l
  1106  	n += 1 + sovApi(uint64(m.StmtTimestampNanos))
  1107  	n += 1 + sovApi(uint64(m.TxnTimestampNanos))
  1108  	l = len(m.Location)
  1109  	n += 1 + l + sovApi(uint64(l))
  1110  	l = len(m.Database)
  1111  	n += 1 + l + sovApi(uint64(l))
  1112  	if len(m.SearchPath) > 0 {
  1113  		for _, s := range m.SearchPath {
  1114  			l = len(s)
  1115  			n += 1 + l + sovApi(uint64(l))
  1116  		}
  1117  	}
  1118  	l = len(m.User)
  1119  	n += 1 + l + sovApi(uint64(l))
  1120  	l = m.SeqState.Size()
  1121  	n += 1 + l + sovApi(uint64(l))
  1122  	l = len(m.ApplicationName)
  1123  	n += 1 + l + sovApi(uint64(l))
  1124  	n += 1 + sovApi(uint64(m.BytesEncodeFormat))
  1125  	n += 1 + sovApi(uint64(m.ExtraFloatDigits))
  1126  	n += 1 + sovApi(uint64(m.Vectorize))
  1127  	l = len(m.TemporarySchemaName)
  1128  	n += 1 + l + sovApi(uint64(l))
  1129  	return n
  1130  }
  1131  
  1132  func (m *SequenceState) Size() (n int) {
  1133  	if m == nil {
  1134  		return 0
  1135  	}
  1136  	var l int
  1137  	_ = l
  1138  	if len(m.Seqs) > 0 {
  1139  		for _, e := range m.Seqs {
  1140  			l = e.Size()
  1141  			n += 1 + l + sovApi(uint64(l))
  1142  		}
  1143  	}
  1144  	if m.LastSeqIncremented != nil {
  1145  		n += 1 + sovApi(uint64(*m.LastSeqIncremented))
  1146  	}
  1147  	return n
  1148  }
  1149  
  1150  func (m *SequenceState_Seq) Size() (n int) {
  1151  	if m == nil {
  1152  		return 0
  1153  	}
  1154  	var l int
  1155  	_ = l
  1156  	n += 1 + sovApi(uint64(m.SeqID))
  1157  	n += 1 + sovApi(uint64(m.LatestVal))
  1158  	return n
  1159  }
  1160  
  1161  func (m *SimpleResponse) Size() (n int) {
  1162  	if m == nil {
  1163  		return 0
  1164  	}
  1165  	var l int
  1166  	_ = l
  1167  	if m.Error != nil {
  1168  		l = m.Error.Size()
  1169  		n += 1 + l + sovApi(uint64(l))
  1170  	}
  1171  	return n
  1172  }
  1173  
  1174  func (m *ConsumerSignal) Size() (n int) {
  1175  	if m == nil {
  1176  		return 0
  1177  	}
  1178  	var l int
  1179  	_ = l
  1180  	if m.DrainRequest != nil {
  1181  		l = m.DrainRequest.Size()
  1182  		n += 1 + l + sovApi(uint64(l))
  1183  	}
  1184  	if m.SetupFlowRequest != nil {
  1185  		l = m.SetupFlowRequest.Size()
  1186  		n += 1 + l + sovApi(uint64(l))
  1187  	}
  1188  	if m.Handshake != nil {
  1189  		l = m.Handshake.Size()
  1190  		n += 1 + l + sovApi(uint64(l))
  1191  	}
  1192  	return n
  1193  }
  1194  
  1195  func (m *DrainRequest) Size() (n int) {
  1196  	if m == nil {
  1197  		return 0
  1198  	}
  1199  	var l int
  1200  	_ = l
  1201  	return n
  1202  }
  1203  
  1204  func (m *ConsumerHandshake) Size() (n int) {
  1205  	if m == nil {
  1206  		return 0
  1207  	}
  1208  	var l int
  1209  	_ = l
  1210  	n += 2
  1211  	if m.ConsumerScheduleDeadline != nil {
  1212  		l = github_com_gogo_protobuf_types.SizeOfStdTime(*m.ConsumerScheduleDeadline)
  1213  		n += 1 + l + sovApi(uint64(l))
  1214  	}
  1215  	n += 1 + sovApi(uint64(m.Version))
  1216  	n += 1 + sovApi(uint64(m.MinAcceptedVersion))
  1217  	return n
  1218  }
  1219  
  1220  func sovApi(x uint64) (n int) {
  1221  	for {
  1222  		n++
  1223  		x >>= 7
  1224  		if x == 0 {
  1225  			break
  1226  		}
  1227  	}
  1228  	return n
  1229  }
  1230  func sozApi(x uint64) (n int) {
  1231  	return sovApi(uint64((x << 1) ^ uint64((int64(x) >> 63))))
  1232  }
  1233  func (this *ConsumerSignal) GetValue() interface{} {
  1234  	if this.DrainRequest != nil {
  1235  		return this.DrainRequest
  1236  	}
  1237  	if this.SetupFlowRequest != nil {
  1238  		return this.SetupFlowRequest
  1239  	}
  1240  	if this.Handshake != nil {
  1241  		return this.Handshake
  1242  	}
  1243  	return nil
  1244  }
  1245  
  1246  func (this *ConsumerSignal) SetValue(value interface{}) bool {
  1247  	switch vt := value.(type) {
  1248  	case *DrainRequest:
  1249  		this.DrainRequest = vt
  1250  	case *SetupFlowRequest:
  1251  		this.SetupFlowRequest = vt
  1252  	case *ConsumerHandshake:
  1253  		this.Handshake = vt
  1254  	default:
  1255  		return false
  1256  	}
  1257  	return true
  1258  }
  1259  func (m *SetupFlowRequest) Unmarshal(dAtA []byte) error {
  1260  	l := len(dAtA)
  1261  	iNdEx := 0
  1262  	for iNdEx < l {
  1263  		preIndex := iNdEx
  1264  		var wire uint64
  1265  		for shift := uint(0); ; shift += 7 {
  1266  			if shift >= 64 {
  1267  				return ErrIntOverflowApi
  1268  			}
  1269  			if iNdEx >= l {
  1270  				return io.ErrUnexpectedEOF
  1271  			}
  1272  			b := dAtA[iNdEx]
  1273  			iNdEx++
  1274  			wire |= (uint64(b) & 0x7F) << shift
  1275  			if b < 0x80 {
  1276  				break
  1277  			}
  1278  		}
  1279  		fieldNum := int32(wire >> 3)
  1280  		wireType := int(wire & 0x7)
  1281  		if wireType == 4 {
  1282  			return fmt.Errorf("proto: SetupFlowRequest: wiretype end group for non-group")
  1283  		}
  1284  		if fieldNum <= 0 {
  1285  			return fmt.Errorf("proto: SetupFlowRequest: illegal tag %d (wire type %d)", fieldNum, wire)
  1286  		}
  1287  		switch fieldNum {
  1288  		case 3:
  1289  			if wireType != 2 {
  1290  				return fmt.Errorf("proto: wrong wireType = %d for field Flow", wireType)
  1291  			}
  1292  			var msglen int
  1293  			for shift := uint(0); ; shift += 7 {
  1294  				if shift >= 64 {
  1295  					return ErrIntOverflowApi
  1296  				}
  1297  				if iNdEx >= l {
  1298  					return io.ErrUnexpectedEOF
  1299  				}
  1300  				b := dAtA[iNdEx]
  1301  				iNdEx++
  1302  				msglen |= (int(b) & 0x7F) << shift
  1303  				if b < 0x80 {
  1304  					break
  1305  				}
  1306  			}
  1307  			if msglen < 0 {
  1308  				return ErrInvalidLengthApi
  1309  			}
  1310  			postIndex := iNdEx + msglen
  1311  			if postIndex > l {
  1312  				return io.ErrUnexpectedEOF
  1313  			}
  1314  			if err := m.Flow.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1315  				return err
  1316  			}
  1317  			iNdEx = postIndex
  1318  		case 5:
  1319  			if wireType != 0 {
  1320  				return fmt.Errorf("proto: wrong wireType = %d for field Version", wireType)
  1321  			}
  1322  			m.Version = 0
  1323  			for shift := uint(0); ; shift += 7 {
  1324  				if shift >= 64 {
  1325  					return ErrIntOverflowApi
  1326  				}
  1327  				if iNdEx >= l {
  1328  					return io.ErrUnexpectedEOF
  1329  				}
  1330  				b := dAtA[iNdEx]
  1331  				iNdEx++
  1332  				m.Version |= (DistSQLVersion(b) & 0x7F) << shift
  1333  				if b < 0x80 {
  1334  					break
  1335  				}
  1336  			}
  1337  		case 6:
  1338  			if wireType != 2 {
  1339  				return fmt.Errorf("proto: wrong wireType = %d for field EvalContext", wireType)
  1340  			}
  1341  			var msglen int
  1342  			for shift := uint(0); ; shift += 7 {
  1343  				if shift >= 64 {
  1344  					return ErrIntOverflowApi
  1345  				}
  1346  				if iNdEx >= l {
  1347  					return io.ErrUnexpectedEOF
  1348  				}
  1349  				b := dAtA[iNdEx]
  1350  				iNdEx++
  1351  				msglen |= (int(b) & 0x7F) << shift
  1352  				if b < 0x80 {
  1353  					break
  1354  				}
  1355  			}
  1356  			if msglen < 0 {
  1357  				return ErrInvalidLengthApi
  1358  			}
  1359  			postIndex := iNdEx + msglen
  1360  			if postIndex > l {
  1361  				return io.ErrUnexpectedEOF
  1362  			}
  1363  			if err := m.EvalContext.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1364  				return err
  1365  			}
  1366  			iNdEx = postIndex
  1367  		case 7:
  1368  			if wireType != 2 {
  1369  				return fmt.Errorf("proto: wrong wireType = %d for field LeafTxnInputState", wireType)
  1370  			}
  1371  			var msglen int
  1372  			for shift := uint(0); ; shift += 7 {
  1373  				if shift >= 64 {
  1374  					return ErrIntOverflowApi
  1375  				}
  1376  				if iNdEx >= l {
  1377  					return io.ErrUnexpectedEOF
  1378  				}
  1379  				b := dAtA[iNdEx]
  1380  				iNdEx++
  1381  				msglen |= (int(b) & 0x7F) << shift
  1382  				if b < 0x80 {
  1383  					break
  1384  				}
  1385  			}
  1386  			if msglen < 0 {
  1387  				return ErrInvalidLengthApi
  1388  			}
  1389  			postIndex := iNdEx + msglen
  1390  			if postIndex > l {
  1391  				return io.ErrUnexpectedEOF
  1392  			}
  1393  			if m.LeafTxnInputState == nil {
  1394  				m.LeafTxnInputState = &roachpb.LeafTxnInputState{}
  1395  			}
  1396  			if err := m.LeafTxnInputState.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1397  				return err
  1398  			}
  1399  			iNdEx = postIndex
  1400  		case 8:
  1401  			if wireType != 0 {
  1402  				return fmt.Errorf("proto: wrong wireType = %d for field TraceKV", wireType)
  1403  			}
  1404  			var v int
  1405  			for shift := uint(0); ; shift += 7 {
  1406  				if shift >= 64 {
  1407  					return ErrIntOverflowApi
  1408  				}
  1409  				if iNdEx >= l {
  1410  					return io.ErrUnexpectedEOF
  1411  				}
  1412  				b := dAtA[iNdEx]
  1413  				iNdEx++
  1414  				v |= (int(b) & 0x7F) << shift
  1415  				if b < 0x80 {
  1416  					break
  1417  				}
  1418  			}
  1419  			m.TraceKV = bool(v != 0)
  1420  		default:
  1421  			iNdEx = preIndex
  1422  			skippy, err := skipApi(dAtA[iNdEx:])
  1423  			if err != nil {
  1424  				return err
  1425  			}
  1426  			if skippy < 0 {
  1427  				return ErrInvalidLengthApi
  1428  			}
  1429  			if (iNdEx + skippy) > l {
  1430  				return io.ErrUnexpectedEOF
  1431  			}
  1432  			iNdEx += skippy
  1433  		}
  1434  	}
  1435  
  1436  	if iNdEx > l {
  1437  		return io.ErrUnexpectedEOF
  1438  	}
  1439  	return nil
  1440  }
  1441  func (m *FlowSpec) Unmarshal(dAtA []byte) error {
  1442  	l := len(dAtA)
  1443  	iNdEx := 0
  1444  	for iNdEx < l {
  1445  		preIndex := iNdEx
  1446  		var wire uint64
  1447  		for shift := uint(0); ; shift += 7 {
  1448  			if shift >= 64 {
  1449  				return ErrIntOverflowApi
  1450  			}
  1451  			if iNdEx >= l {
  1452  				return io.ErrUnexpectedEOF
  1453  			}
  1454  			b := dAtA[iNdEx]
  1455  			iNdEx++
  1456  			wire |= (uint64(b) & 0x7F) << shift
  1457  			if b < 0x80 {
  1458  				break
  1459  			}
  1460  		}
  1461  		fieldNum := int32(wire >> 3)
  1462  		wireType := int(wire & 0x7)
  1463  		if wireType == 4 {
  1464  			return fmt.Errorf("proto: FlowSpec: wiretype end group for non-group")
  1465  		}
  1466  		if fieldNum <= 0 {
  1467  			return fmt.Errorf("proto: FlowSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  1468  		}
  1469  		switch fieldNum {
  1470  		case 1:
  1471  			if wireType != 2 {
  1472  				return fmt.Errorf("proto: wrong wireType = %d for field FlowID", wireType)
  1473  			}
  1474  			var byteLen int
  1475  			for shift := uint(0); ; shift += 7 {
  1476  				if shift >= 64 {
  1477  					return ErrIntOverflowApi
  1478  				}
  1479  				if iNdEx >= l {
  1480  					return io.ErrUnexpectedEOF
  1481  				}
  1482  				b := dAtA[iNdEx]
  1483  				iNdEx++
  1484  				byteLen |= (int(b) & 0x7F) << shift
  1485  				if b < 0x80 {
  1486  					break
  1487  				}
  1488  			}
  1489  			if byteLen < 0 {
  1490  				return ErrInvalidLengthApi
  1491  			}
  1492  			postIndex := iNdEx + byteLen
  1493  			if postIndex > l {
  1494  				return io.ErrUnexpectedEOF
  1495  			}
  1496  			if err := m.FlowID.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1497  				return err
  1498  			}
  1499  			iNdEx = postIndex
  1500  		case 2:
  1501  			if wireType != 2 {
  1502  				return fmt.Errorf("proto: wrong wireType = %d for field Processors", wireType)
  1503  			}
  1504  			var msglen int
  1505  			for shift := uint(0); ; shift += 7 {
  1506  				if shift >= 64 {
  1507  					return ErrIntOverflowApi
  1508  				}
  1509  				if iNdEx >= l {
  1510  					return io.ErrUnexpectedEOF
  1511  				}
  1512  				b := dAtA[iNdEx]
  1513  				iNdEx++
  1514  				msglen |= (int(b) & 0x7F) << shift
  1515  				if b < 0x80 {
  1516  					break
  1517  				}
  1518  			}
  1519  			if msglen < 0 {
  1520  				return ErrInvalidLengthApi
  1521  			}
  1522  			postIndex := iNdEx + msglen
  1523  			if postIndex > l {
  1524  				return io.ErrUnexpectedEOF
  1525  			}
  1526  			m.Processors = append(m.Processors, ProcessorSpec{})
  1527  			if err := m.Processors[len(m.Processors)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1528  				return err
  1529  			}
  1530  			iNdEx = postIndex
  1531  		case 3:
  1532  			if wireType != 0 {
  1533  				return fmt.Errorf("proto: wrong wireType = %d for field Gateway", wireType)
  1534  			}
  1535  			m.Gateway = 0
  1536  			for shift := uint(0); ; shift += 7 {
  1537  				if shift >= 64 {
  1538  					return ErrIntOverflowApi
  1539  				}
  1540  				if iNdEx >= l {
  1541  					return io.ErrUnexpectedEOF
  1542  				}
  1543  				b := dAtA[iNdEx]
  1544  				iNdEx++
  1545  				m.Gateway |= (github_com_cockroachdb_cockroach_pkg_roachpb.NodeID(b) & 0x7F) << shift
  1546  				if b < 0x80 {
  1547  					break
  1548  				}
  1549  			}
  1550  		default:
  1551  			iNdEx = preIndex
  1552  			skippy, err := skipApi(dAtA[iNdEx:])
  1553  			if err != nil {
  1554  				return err
  1555  			}
  1556  			if skippy < 0 {
  1557  				return ErrInvalidLengthApi
  1558  			}
  1559  			if (iNdEx + skippy) > l {
  1560  				return io.ErrUnexpectedEOF
  1561  			}
  1562  			iNdEx += skippy
  1563  		}
  1564  	}
  1565  
  1566  	if iNdEx > l {
  1567  		return io.ErrUnexpectedEOF
  1568  	}
  1569  	return nil
  1570  }
  1571  func (m *EvalContext) Unmarshal(dAtA []byte) error {
  1572  	l := len(dAtA)
  1573  	iNdEx := 0
  1574  	for iNdEx < l {
  1575  		preIndex := iNdEx
  1576  		var wire uint64
  1577  		for shift := uint(0); ; shift += 7 {
  1578  			if shift >= 64 {
  1579  				return ErrIntOverflowApi
  1580  			}
  1581  			if iNdEx >= l {
  1582  				return io.ErrUnexpectedEOF
  1583  			}
  1584  			b := dAtA[iNdEx]
  1585  			iNdEx++
  1586  			wire |= (uint64(b) & 0x7F) << shift
  1587  			if b < 0x80 {
  1588  				break
  1589  			}
  1590  		}
  1591  		fieldNum := int32(wire >> 3)
  1592  		wireType := int(wire & 0x7)
  1593  		if wireType == 4 {
  1594  			return fmt.Errorf("proto: EvalContext: wiretype end group for non-group")
  1595  		}
  1596  		if fieldNum <= 0 {
  1597  			return fmt.Errorf("proto: EvalContext: illegal tag %d (wire type %d)", fieldNum, wire)
  1598  		}
  1599  		switch fieldNum {
  1600  		case 1:
  1601  			if wireType != 0 {
  1602  				return fmt.Errorf("proto: wrong wireType = %d for field StmtTimestampNanos", wireType)
  1603  			}
  1604  			m.StmtTimestampNanos = 0
  1605  			for shift := uint(0); ; shift += 7 {
  1606  				if shift >= 64 {
  1607  					return ErrIntOverflowApi
  1608  				}
  1609  				if iNdEx >= l {
  1610  					return io.ErrUnexpectedEOF
  1611  				}
  1612  				b := dAtA[iNdEx]
  1613  				iNdEx++
  1614  				m.StmtTimestampNanos |= (int64(b) & 0x7F) << shift
  1615  				if b < 0x80 {
  1616  					break
  1617  				}
  1618  			}
  1619  		case 2:
  1620  			if wireType != 0 {
  1621  				return fmt.Errorf("proto: wrong wireType = %d for field TxnTimestampNanos", wireType)
  1622  			}
  1623  			m.TxnTimestampNanos = 0
  1624  			for shift := uint(0); ; shift += 7 {
  1625  				if shift >= 64 {
  1626  					return ErrIntOverflowApi
  1627  				}
  1628  				if iNdEx >= l {
  1629  					return io.ErrUnexpectedEOF
  1630  				}
  1631  				b := dAtA[iNdEx]
  1632  				iNdEx++
  1633  				m.TxnTimestampNanos |= (int64(b) & 0x7F) << shift
  1634  				if b < 0x80 {
  1635  					break
  1636  				}
  1637  			}
  1638  		case 4:
  1639  			if wireType != 2 {
  1640  				return fmt.Errorf("proto: wrong wireType = %d for field Location", wireType)
  1641  			}
  1642  			var stringLen uint64
  1643  			for shift := uint(0); ; shift += 7 {
  1644  				if shift >= 64 {
  1645  					return ErrIntOverflowApi
  1646  				}
  1647  				if iNdEx >= l {
  1648  					return io.ErrUnexpectedEOF
  1649  				}
  1650  				b := dAtA[iNdEx]
  1651  				iNdEx++
  1652  				stringLen |= (uint64(b) & 0x7F) << shift
  1653  				if b < 0x80 {
  1654  					break
  1655  				}
  1656  			}
  1657  			intStringLen := int(stringLen)
  1658  			if intStringLen < 0 {
  1659  				return ErrInvalidLengthApi
  1660  			}
  1661  			postIndex := iNdEx + intStringLen
  1662  			if postIndex > l {
  1663  				return io.ErrUnexpectedEOF
  1664  			}
  1665  			m.Location = string(dAtA[iNdEx:postIndex])
  1666  			iNdEx = postIndex
  1667  		case 5:
  1668  			if wireType != 2 {
  1669  				return fmt.Errorf("proto: wrong wireType = %d for field Database", wireType)
  1670  			}
  1671  			var stringLen uint64
  1672  			for shift := uint(0); ; shift += 7 {
  1673  				if shift >= 64 {
  1674  					return ErrIntOverflowApi
  1675  				}
  1676  				if iNdEx >= l {
  1677  					return io.ErrUnexpectedEOF
  1678  				}
  1679  				b := dAtA[iNdEx]
  1680  				iNdEx++
  1681  				stringLen |= (uint64(b) & 0x7F) << shift
  1682  				if b < 0x80 {
  1683  					break
  1684  				}
  1685  			}
  1686  			intStringLen := int(stringLen)
  1687  			if intStringLen < 0 {
  1688  				return ErrInvalidLengthApi
  1689  			}
  1690  			postIndex := iNdEx + intStringLen
  1691  			if postIndex > l {
  1692  				return io.ErrUnexpectedEOF
  1693  			}
  1694  			m.Database = string(dAtA[iNdEx:postIndex])
  1695  			iNdEx = postIndex
  1696  		case 6:
  1697  			if wireType != 2 {
  1698  				return fmt.Errorf("proto: wrong wireType = %d for field SearchPath", wireType)
  1699  			}
  1700  			var stringLen uint64
  1701  			for shift := uint(0); ; shift += 7 {
  1702  				if shift >= 64 {
  1703  					return ErrIntOverflowApi
  1704  				}
  1705  				if iNdEx >= l {
  1706  					return io.ErrUnexpectedEOF
  1707  				}
  1708  				b := dAtA[iNdEx]
  1709  				iNdEx++
  1710  				stringLen |= (uint64(b) & 0x7F) << shift
  1711  				if b < 0x80 {
  1712  					break
  1713  				}
  1714  			}
  1715  			intStringLen := int(stringLen)
  1716  			if intStringLen < 0 {
  1717  				return ErrInvalidLengthApi
  1718  			}
  1719  			postIndex := iNdEx + intStringLen
  1720  			if postIndex > l {
  1721  				return io.ErrUnexpectedEOF
  1722  			}
  1723  			m.SearchPath = append(m.SearchPath, string(dAtA[iNdEx:postIndex]))
  1724  			iNdEx = postIndex
  1725  		case 7:
  1726  			if wireType != 2 {
  1727  				return fmt.Errorf("proto: wrong wireType = %d for field User", wireType)
  1728  			}
  1729  			var stringLen uint64
  1730  			for shift := uint(0); ; shift += 7 {
  1731  				if shift >= 64 {
  1732  					return ErrIntOverflowApi
  1733  				}
  1734  				if iNdEx >= l {
  1735  					return io.ErrUnexpectedEOF
  1736  				}
  1737  				b := dAtA[iNdEx]
  1738  				iNdEx++
  1739  				stringLen |= (uint64(b) & 0x7F) << shift
  1740  				if b < 0x80 {
  1741  					break
  1742  				}
  1743  			}
  1744  			intStringLen := int(stringLen)
  1745  			if intStringLen < 0 {
  1746  				return ErrInvalidLengthApi
  1747  			}
  1748  			postIndex := iNdEx + intStringLen
  1749  			if postIndex > l {
  1750  				return io.ErrUnexpectedEOF
  1751  			}
  1752  			m.User = string(dAtA[iNdEx:postIndex])
  1753  			iNdEx = postIndex
  1754  		case 8:
  1755  			if wireType != 2 {
  1756  				return fmt.Errorf("proto: wrong wireType = %d for field SeqState", wireType)
  1757  			}
  1758  			var msglen int
  1759  			for shift := uint(0); ; shift += 7 {
  1760  				if shift >= 64 {
  1761  					return ErrIntOverflowApi
  1762  				}
  1763  				if iNdEx >= l {
  1764  					return io.ErrUnexpectedEOF
  1765  				}
  1766  				b := dAtA[iNdEx]
  1767  				iNdEx++
  1768  				msglen |= (int(b) & 0x7F) << shift
  1769  				if b < 0x80 {
  1770  					break
  1771  				}
  1772  			}
  1773  			if msglen < 0 {
  1774  				return ErrInvalidLengthApi
  1775  			}
  1776  			postIndex := iNdEx + msglen
  1777  			if postIndex > l {
  1778  				return io.ErrUnexpectedEOF
  1779  			}
  1780  			if err := m.SeqState.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1781  				return err
  1782  			}
  1783  			iNdEx = postIndex
  1784  		case 9:
  1785  			if wireType != 2 {
  1786  				return fmt.Errorf("proto: wrong wireType = %d for field ApplicationName", wireType)
  1787  			}
  1788  			var stringLen uint64
  1789  			for shift := uint(0); ; shift += 7 {
  1790  				if shift >= 64 {
  1791  					return ErrIntOverflowApi
  1792  				}
  1793  				if iNdEx >= l {
  1794  					return io.ErrUnexpectedEOF
  1795  				}
  1796  				b := dAtA[iNdEx]
  1797  				iNdEx++
  1798  				stringLen |= (uint64(b) & 0x7F) << shift
  1799  				if b < 0x80 {
  1800  					break
  1801  				}
  1802  			}
  1803  			intStringLen := int(stringLen)
  1804  			if intStringLen < 0 {
  1805  				return ErrInvalidLengthApi
  1806  			}
  1807  			postIndex := iNdEx + intStringLen
  1808  			if postIndex > l {
  1809  				return io.ErrUnexpectedEOF
  1810  			}
  1811  			m.ApplicationName = string(dAtA[iNdEx:postIndex])
  1812  			iNdEx = postIndex
  1813  		case 10:
  1814  			if wireType != 0 {
  1815  				return fmt.Errorf("proto: wrong wireType = %d for field BytesEncodeFormat", wireType)
  1816  			}
  1817  			m.BytesEncodeFormat = 0
  1818  			for shift := uint(0); ; shift += 7 {
  1819  				if shift >= 64 {
  1820  					return ErrIntOverflowApi
  1821  				}
  1822  				if iNdEx >= l {
  1823  					return io.ErrUnexpectedEOF
  1824  				}
  1825  				b := dAtA[iNdEx]
  1826  				iNdEx++
  1827  				m.BytesEncodeFormat |= (BytesEncodeFormat(b) & 0x7F) << shift
  1828  				if b < 0x80 {
  1829  					break
  1830  				}
  1831  			}
  1832  		case 11:
  1833  			if wireType != 0 {
  1834  				return fmt.Errorf("proto: wrong wireType = %d for field ExtraFloatDigits", wireType)
  1835  			}
  1836  			m.ExtraFloatDigits = 0
  1837  			for shift := uint(0); ; shift += 7 {
  1838  				if shift >= 64 {
  1839  					return ErrIntOverflowApi
  1840  				}
  1841  				if iNdEx >= l {
  1842  					return io.ErrUnexpectedEOF
  1843  				}
  1844  				b := dAtA[iNdEx]
  1845  				iNdEx++
  1846  				m.ExtraFloatDigits |= (int32(b) & 0x7F) << shift
  1847  				if b < 0x80 {
  1848  					break
  1849  				}
  1850  			}
  1851  		case 12:
  1852  			if wireType != 0 {
  1853  				return fmt.Errorf("proto: wrong wireType = %d for field Vectorize", wireType)
  1854  			}
  1855  			m.Vectorize = 0
  1856  			for shift := uint(0); ; shift += 7 {
  1857  				if shift >= 64 {
  1858  					return ErrIntOverflowApi
  1859  				}
  1860  				if iNdEx >= l {
  1861  					return io.ErrUnexpectedEOF
  1862  				}
  1863  				b := dAtA[iNdEx]
  1864  				iNdEx++
  1865  				m.Vectorize |= (int32(b) & 0x7F) << shift
  1866  				if b < 0x80 {
  1867  					break
  1868  				}
  1869  			}
  1870  		case 13:
  1871  			if wireType != 2 {
  1872  				return fmt.Errorf("proto: wrong wireType = %d for field TemporarySchemaName", wireType)
  1873  			}
  1874  			var stringLen uint64
  1875  			for shift := uint(0); ; shift += 7 {
  1876  				if shift >= 64 {
  1877  					return ErrIntOverflowApi
  1878  				}
  1879  				if iNdEx >= l {
  1880  					return io.ErrUnexpectedEOF
  1881  				}
  1882  				b := dAtA[iNdEx]
  1883  				iNdEx++
  1884  				stringLen |= (uint64(b) & 0x7F) << shift
  1885  				if b < 0x80 {
  1886  					break
  1887  				}
  1888  			}
  1889  			intStringLen := int(stringLen)
  1890  			if intStringLen < 0 {
  1891  				return ErrInvalidLengthApi
  1892  			}
  1893  			postIndex := iNdEx + intStringLen
  1894  			if postIndex > l {
  1895  				return io.ErrUnexpectedEOF
  1896  			}
  1897  			m.TemporarySchemaName = string(dAtA[iNdEx:postIndex])
  1898  			iNdEx = postIndex
  1899  		default:
  1900  			iNdEx = preIndex
  1901  			skippy, err := skipApi(dAtA[iNdEx:])
  1902  			if err != nil {
  1903  				return err
  1904  			}
  1905  			if skippy < 0 {
  1906  				return ErrInvalidLengthApi
  1907  			}
  1908  			if (iNdEx + skippy) > l {
  1909  				return io.ErrUnexpectedEOF
  1910  			}
  1911  			iNdEx += skippy
  1912  		}
  1913  	}
  1914  
  1915  	if iNdEx > l {
  1916  		return io.ErrUnexpectedEOF
  1917  	}
  1918  	return nil
  1919  }
  1920  func (m *SequenceState) Unmarshal(dAtA []byte) error {
  1921  	l := len(dAtA)
  1922  	iNdEx := 0
  1923  	for iNdEx < l {
  1924  		preIndex := iNdEx
  1925  		var wire uint64
  1926  		for shift := uint(0); ; shift += 7 {
  1927  			if shift >= 64 {
  1928  				return ErrIntOverflowApi
  1929  			}
  1930  			if iNdEx >= l {
  1931  				return io.ErrUnexpectedEOF
  1932  			}
  1933  			b := dAtA[iNdEx]
  1934  			iNdEx++
  1935  			wire |= (uint64(b) & 0x7F) << shift
  1936  			if b < 0x80 {
  1937  				break
  1938  			}
  1939  		}
  1940  		fieldNum := int32(wire >> 3)
  1941  		wireType := int(wire & 0x7)
  1942  		if wireType == 4 {
  1943  			return fmt.Errorf("proto: SequenceState: wiretype end group for non-group")
  1944  		}
  1945  		if fieldNum <= 0 {
  1946  			return fmt.Errorf("proto: SequenceState: illegal tag %d (wire type %d)", fieldNum, wire)
  1947  		}
  1948  		switch fieldNum {
  1949  		case 1:
  1950  			if wireType != 2 {
  1951  				return fmt.Errorf("proto: wrong wireType = %d for field Seqs", wireType)
  1952  			}
  1953  			var msglen int
  1954  			for shift := uint(0); ; shift += 7 {
  1955  				if shift >= 64 {
  1956  					return ErrIntOverflowApi
  1957  				}
  1958  				if iNdEx >= l {
  1959  					return io.ErrUnexpectedEOF
  1960  				}
  1961  				b := dAtA[iNdEx]
  1962  				iNdEx++
  1963  				msglen |= (int(b) & 0x7F) << shift
  1964  				if b < 0x80 {
  1965  					break
  1966  				}
  1967  			}
  1968  			if msglen < 0 {
  1969  				return ErrInvalidLengthApi
  1970  			}
  1971  			postIndex := iNdEx + msglen
  1972  			if postIndex > l {
  1973  				return io.ErrUnexpectedEOF
  1974  			}
  1975  			m.Seqs = append(m.Seqs, &SequenceState_Seq{})
  1976  			if err := m.Seqs[len(m.Seqs)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1977  				return err
  1978  			}
  1979  			iNdEx = postIndex
  1980  		case 2:
  1981  			if wireType != 0 {
  1982  				return fmt.Errorf("proto: wrong wireType = %d for field LastSeqIncremented", wireType)
  1983  			}
  1984  			var v uint32
  1985  			for shift := uint(0); ; shift += 7 {
  1986  				if shift >= 64 {
  1987  					return ErrIntOverflowApi
  1988  				}
  1989  				if iNdEx >= l {
  1990  					return io.ErrUnexpectedEOF
  1991  				}
  1992  				b := dAtA[iNdEx]
  1993  				iNdEx++
  1994  				v |= (uint32(b) & 0x7F) << shift
  1995  				if b < 0x80 {
  1996  					break
  1997  				}
  1998  			}
  1999  			m.LastSeqIncremented = &v
  2000  		default:
  2001  			iNdEx = preIndex
  2002  			skippy, err := skipApi(dAtA[iNdEx:])
  2003  			if err != nil {
  2004  				return err
  2005  			}
  2006  			if skippy < 0 {
  2007  				return ErrInvalidLengthApi
  2008  			}
  2009  			if (iNdEx + skippy) > l {
  2010  				return io.ErrUnexpectedEOF
  2011  			}
  2012  			iNdEx += skippy
  2013  		}
  2014  	}
  2015  
  2016  	if iNdEx > l {
  2017  		return io.ErrUnexpectedEOF
  2018  	}
  2019  	return nil
  2020  }
  2021  func (m *SequenceState_Seq) Unmarshal(dAtA []byte) error {
  2022  	l := len(dAtA)
  2023  	iNdEx := 0
  2024  	for iNdEx < l {
  2025  		preIndex := iNdEx
  2026  		var wire uint64
  2027  		for shift := uint(0); ; shift += 7 {
  2028  			if shift >= 64 {
  2029  				return ErrIntOverflowApi
  2030  			}
  2031  			if iNdEx >= l {
  2032  				return io.ErrUnexpectedEOF
  2033  			}
  2034  			b := dAtA[iNdEx]
  2035  			iNdEx++
  2036  			wire |= (uint64(b) & 0x7F) << shift
  2037  			if b < 0x80 {
  2038  				break
  2039  			}
  2040  		}
  2041  		fieldNum := int32(wire >> 3)
  2042  		wireType := int(wire & 0x7)
  2043  		if wireType == 4 {
  2044  			return fmt.Errorf("proto: Seq: wiretype end group for non-group")
  2045  		}
  2046  		if fieldNum <= 0 {
  2047  			return fmt.Errorf("proto: Seq: illegal tag %d (wire type %d)", fieldNum, wire)
  2048  		}
  2049  		switch fieldNum {
  2050  		case 1:
  2051  			if wireType != 0 {
  2052  				return fmt.Errorf("proto: wrong wireType = %d for field SeqID", wireType)
  2053  			}
  2054  			m.SeqID = 0
  2055  			for shift := uint(0); ; shift += 7 {
  2056  				if shift >= 64 {
  2057  					return ErrIntOverflowApi
  2058  				}
  2059  				if iNdEx >= l {
  2060  					return io.ErrUnexpectedEOF
  2061  				}
  2062  				b := dAtA[iNdEx]
  2063  				iNdEx++
  2064  				m.SeqID |= (uint32(b) & 0x7F) << shift
  2065  				if b < 0x80 {
  2066  					break
  2067  				}
  2068  			}
  2069  		case 2:
  2070  			if wireType != 0 {
  2071  				return fmt.Errorf("proto: wrong wireType = %d for field LatestVal", wireType)
  2072  			}
  2073  			m.LatestVal = 0
  2074  			for shift := uint(0); ; shift += 7 {
  2075  				if shift >= 64 {
  2076  					return ErrIntOverflowApi
  2077  				}
  2078  				if iNdEx >= l {
  2079  					return io.ErrUnexpectedEOF
  2080  				}
  2081  				b := dAtA[iNdEx]
  2082  				iNdEx++
  2083  				m.LatestVal |= (int64(b) & 0x7F) << shift
  2084  				if b < 0x80 {
  2085  					break
  2086  				}
  2087  			}
  2088  		default:
  2089  			iNdEx = preIndex
  2090  			skippy, err := skipApi(dAtA[iNdEx:])
  2091  			if err != nil {
  2092  				return err
  2093  			}
  2094  			if skippy < 0 {
  2095  				return ErrInvalidLengthApi
  2096  			}
  2097  			if (iNdEx + skippy) > l {
  2098  				return io.ErrUnexpectedEOF
  2099  			}
  2100  			iNdEx += skippy
  2101  		}
  2102  	}
  2103  
  2104  	if iNdEx > l {
  2105  		return io.ErrUnexpectedEOF
  2106  	}
  2107  	return nil
  2108  }
  2109  func (m *SimpleResponse) Unmarshal(dAtA []byte) error {
  2110  	l := len(dAtA)
  2111  	iNdEx := 0
  2112  	for iNdEx < l {
  2113  		preIndex := iNdEx
  2114  		var wire uint64
  2115  		for shift := uint(0); ; shift += 7 {
  2116  			if shift >= 64 {
  2117  				return ErrIntOverflowApi
  2118  			}
  2119  			if iNdEx >= l {
  2120  				return io.ErrUnexpectedEOF
  2121  			}
  2122  			b := dAtA[iNdEx]
  2123  			iNdEx++
  2124  			wire |= (uint64(b) & 0x7F) << shift
  2125  			if b < 0x80 {
  2126  				break
  2127  			}
  2128  		}
  2129  		fieldNum := int32(wire >> 3)
  2130  		wireType := int(wire & 0x7)
  2131  		if wireType == 4 {
  2132  			return fmt.Errorf("proto: SimpleResponse: wiretype end group for non-group")
  2133  		}
  2134  		if fieldNum <= 0 {
  2135  			return fmt.Errorf("proto: SimpleResponse: illegal tag %d (wire type %d)", fieldNum, wire)
  2136  		}
  2137  		switch fieldNum {
  2138  		case 1:
  2139  			if wireType != 2 {
  2140  				return fmt.Errorf("proto: wrong wireType = %d for field Error", wireType)
  2141  			}
  2142  			var msglen int
  2143  			for shift := uint(0); ; shift += 7 {
  2144  				if shift >= 64 {
  2145  					return ErrIntOverflowApi
  2146  				}
  2147  				if iNdEx >= l {
  2148  					return io.ErrUnexpectedEOF
  2149  				}
  2150  				b := dAtA[iNdEx]
  2151  				iNdEx++
  2152  				msglen |= (int(b) & 0x7F) << shift
  2153  				if b < 0x80 {
  2154  					break
  2155  				}
  2156  			}
  2157  			if msglen < 0 {
  2158  				return ErrInvalidLengthApi
  2159  			}
  2160  			postIndex := iNdEx + msglen
  2161  			if postIndex > l {
  2162  				return io.ErrUnexpectedEOF
  2163  			}
  2164  			if m.Error == nil {
  2165  				m.Error = &Error{}
  2166  			}
  2167  			if err := m.Error.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2168  				return err
  2169  			}
  2170  			iNdEx = postIndex
  2171  		default:
  2172  			iNdEx = preIndex
  2173  			skippy, err := skipApi(dAtA[iNdEx:])
  2174  			if err != nil {
  2175  				return err
  2176  			}
  2177  			if skippy < 0 {
  2178  				return ErrInvalidLengthApi
  2179  			}
  2180  			if (iNdEx + skippy) > l {
  2181  				return io.ErrUnexpectedEOF
  2182  			}
  2183  			iNdEx += skippy
  2184  		}
  2185  	}
  2186  
  2187  	if iNdEx > l {
  2188  		return io.ErrUnexpectedEOF
  2189  	}
  2190  	return nil
  2191  }
  2192  func (m *ConsumerSignal) Unmarshal(dAtA []byte) error {
  2193  	l := len(dAtA)
  2194  	iNdEx := 0
  2195  	for iNdEx < l {
  2196  		preIndex := iNdEx
  2197  		var wire uint64
  2198  		for shift := uint(0); ; shift += 7 {
  2199  			if shift >= 64 {
  2200  				return ErrIntOverflowApi
  2201  			}
  2202  			if iNdEx >= l {
  2203  				return io.ErrUnexpectedEOF
  2204  			}
  2205  			b := dAtA[iNdEx]
  2206  			iNdEx++
  2207  			wire |= (uint64(b) & 0x7F) << shift
  2208  			if b < 0x80 {
  2209  				break
  2210  			}
  2211  		}
  2212  		fieldNum := int32(wire >> 3)
  2213  		wireType := int(wire & 0x7)
  2214  		if wireType == 4 {
  2215  			return fmt.Errorf("proto: ConsumerSignal: wiretype end group for non-group")
  2216  		}
  2217  		if fieldNum <= 0 {
  2218  			return fmt.Errorf("proto: ConsumerSignal: illegal tag %d (wire type %d)", fieldNum, wire)
  2219  		}
  2220  		switch fieldNum {
  2221  		case 1:
  2222  			if wireType != 2 {
  2223  				return fmt.Errorf("proto: wrong wireType = %d for field DrainRequest", wireType)
  2224  			}
  2225  			var msglen int
  2226  			for shift := uint(0); ; shift += 7 {
  2227  				if shift >= 64 {
  2228  					return ErrIntOverflowApi
  2229  				}
  2230  				if iNdEx >= l {
  2231  					return io.ErrUnexpectedEOF
  2232  				}
  2233  				b := dAtA[iNdEx]
  2234  				iNdEx++
  2235  				msglen |= (int(b) & 0x7F) << shift
  2236  				if b < 0x80 {
  2237  					break
  2238  				}
  2239  			}
  2240  			if msglen < 0 {
  2241  				return ErrInvalidLengthApi
  2242  			}
  2243  			postIndex := iNdEx + msglen
  2244  			if postIndex > l {
  2245  				return io.ErrUnexpectedEOF
  2246  			}
  2247  			if m.DrainRequest == nil {
  2248  				m.DrainRequest = &DrainRequest{}
  2249  			}
  2250  			if err := m.DrainRequest.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2251  				return err
  2252  			}
  2253  			iNdEx = postIndex
  2254  		case 2:
  2255  			if wireType != 2 {
  2256  				return fmt.Errorf("proto: wrong wireType = %d for field SetupFlowRequest", wireType)
  2257  			}
  2258  			var msglen int
  2259  			for shift := uint(0); ; shift += 7 {
  2260  				if shift >= 64 {
  2261  					return ErrIntOverflowApi
  2262  				}
  2263  				if iNdEx >= l {
  2264  					return io.ErrUnexpectedEOF
  2265  				}
  2266  				b := dAtA[iNdEx]
  2267  				iNdEx++
  2268  				msglen |= (int(b) & 0x7F) << shift
  2269  				if b < 0x80 {
  2270  					break
  2271  				}
  2272  			}
  2273  			if msglen < 0 {
  2274  				return ErrInvalidLengthApi
  2275  			}
  2276  			postIndex := iNdEx + msglen
  2277  			if postIndex > l {
  2278  				return io.ErrUnexpectedEOF
  2279  			}
  2280  			if m.SetupFlowRequest == nil {
  2281  				m.SetupFlowRequest = &SetupFlowRequest{}
  2282  			}
  2283  			if err := m.SetupFlowRequest.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2284  				return err
  2285  			}
  2286  			iNdEx = postIndex
  2287  		case 3:
  2288  			if wireType != 2 {
  2289  				return fmt.Errorf("proto: wrong wireType = %d for field Handshake", wireType)
  2290  			}
  2291  			var msglen int
  2292  			for shift := uint(0); ; shift += 7 {
  2293  				if shift >= 64 {
  2294  					return ErrIntOverflowApi
  2295  				}
  2296  				if iNdEx >= l {
  2297  					return io.ErrUnexpectedEOF
  2298  				}
  2299  				b := dAtA[iNdEx]
  2300  				iNdEx++
  2301  				msglen |= (int(b) & 0x7F) << shift
  2302  				if b < 0x80 {
  2303  					break
  2304  				}
  2305  			}
  2306  			if msglen < 0 {
  2307  				return ErrInvalidLengthApi
  2308  			}
  2309  			postIndex := iNdEx + msglen
  2310  			if postIndex > l {
  2311  				return io.ErrUnexpectedEOF
  2312  			}
  2313  			if m.Handshake == nil {
  2314  				m.Handshake = &ConsumerHandshake{}
  2315  			}
  2316  			if err := m.Handshake.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2317  				return err
  2318  			}
  2319  			iNdEx = postIndex
  2320  		default:
  2321  			iNdEx = preIndex
  2322  			skippy, err := skipApi(dAtA[iNdEx:])
  2323  			if err != nil {
  2324  				return err
  2325  			}
  2326  			if skippy < 0 {
  2327  				return ErrInvalidLengthApi
  2328  			}
  2329  			if (iNdEx + skippy) > l {
  2330  				return io.ErrUnexpectedEOF
  2331  			}
  2332  			iNdEx += skippy
  2333  		}
  2334  	}
  2335  
  2336  	if iNdEx > l {
  2337  		return io.ErrUnexpectedEOF
  2338  	}
  2339  	return nil
  2340  }
  2341  func (m *DrainRequest) Unmarshal(dAtA []byte) error {
  2342  	l := len(dAtA)
  2343  	iNdEx := 0
  2344  	for iNdEx < l {
  2345  		preIndex := iNdEx
  2346  		var wire uint64
  2347  		for shift := uint(0); ; shift += 7 {
  2348  			if shift >= 64 {
  2349  				return ErrIntOverflowApi
  2350  			}
  2351  			if iNdEx >= l {
  2352  				return io.ErrUnexpectedEOF
  2353  			}
  2354  			b := dAtA[iNdEx]
  2355  			iNdEx++
  2356  			wire |= (uint64(b) & 0x7F) << shift
  2357  			if b < 0x80 {
  2358  				break
  2359  			}
  2360  		}
  2361  		fieldNum := int32(wire >> 3)
  2362  		wireType := int(wire & 0x7)
  2363  		if wireType == 4 {
  2364  			return fmt.Errorf("proto: DrainRequest: wiretype end group for non-group")
  2365  		}
  2366  		if fieldNum <= 0 {
  2367  			return fmt.Errorf("proto: DrainRequest: illegal tag %d (wire type %d)", fieldNum, wire)
  2368  		}
  2369  		switch fieldNum {
  2370  		default:
  2371  			iNdEx = preIndex
  2372  			skippy, err := skipApi(dAtA[iNdEx:])
  2373  			if err != nil {
  2374  				return err
  2375  			}
  2376  			if skippy < 0 {
  2377  				return ErrInvalidLengthApi
  2378  			}
  2379  			if (iNdEx + skippy) > l {
  2380  				return io.ErrUnexpectedEOF
  2381  			}
  2382  			iNdEx += skippy
  2383  		}
  2384  	}
  2385  
  2386  	if iNdEx > l {
  2387  		return io.ErrUnexpectedEOF
  2388  	}
  2389  	return nil
  2390  }
  2391  func (m *ConsumerHandshake) Unmarshal(dAtA []byte) error {
  2392  	l := len(dAtA)
  2393  	iNdEx := 0
  2394  	for iNdEx < l {
  2395  		preIndex := iNdEx
  2396  		var wire uint64
  2397  		for shift := uint(0); ; shift += 7 {
  2398  			if shift >= 64 {
  2399  				return ErrIntOverflowApi
  2400  			}
  2401  			if iNdEx >= l {
  2402  				return io.ErrUnexpectedEOF
  2403  			}
  2404  			b := dAtA[iNdEx]
  2405  			iNdEx++
  2406  			wire |= (uint64(b) & 0x7F) << shift
  2407  			if b < 0x80 {
  2408  				break
  2409  			}
  2410  		}
  2411  		fieldNum := int32(wire >> 3)
  2412  		wireType := int(wire & 0x7)
  2413  		if wireType == 4 {
  2414  			return fmt.Errorf("proto: ConsumerHandshake: wiretype end group for non-group")
  2415  		}
  2416  		if fieldNum <= 0 {
  2417  			return fmt.Errorf("proto: ConsumerHandshake: illegal tag %d (wire type %d)", fieldNum, wire)
  2418  		}
  2419  		switch fieldNum {
  2420  		case 1:
  2421  			if wireType != 0 {
  2422  				return fmt.Errorf("proto: wrong wireType = %d for field ConsumerScheduled", wireType)
  2423  			}
  2424  			var v int
  2425  			for shift := uint(0); ; shift += 7 {
  2426  				if shift >= 64 {
  2427  					return ErrIntOverflowApi
  2428  				}
  2429  				if iNdEx >= l {
  2430  					return io.ErrUnexpectedEOF
  2431  				}
  2432  				b := dAtA[iNdEx]
  2433  				iNdEx++
  2434  				v |= (int(b) & 0x7F) << shift
  2435  				if b < 0x80 {
  2436  					break
  2437  				}
  2438  			}
  2439  			m.ConsumerScheduled = bool(v != 0)
  2440  		case 2:
  2441  			if wireType != 2 {
  2442  				return fmt.Errorf("proto: wrong wireType = %d for field ConsumerScheduleDeadline", wireType)
  2443  			}
  2444  			var msglen int
  2445  			for shift := uint(0); ; shift += 7 {
  2446  				if shift >= 64 {
  2447  					return ErrIntOverflowApi
  2448  				}
  2449  				if iNdEx >= l {
  2450  					return io.ErrUnexpectedEOF
  2451  				}
  2452  				b := dAtA[iNdEx]
  2453  				iNdEx++
  2454  				msglen |= (int(b) & 0x7F) << shift
  2455  				if b < 0x80 {
  2456  					break
  2457  				}
  2458  			}
  2459  			if msglen < 0 {
  2460  				return ErrInvalidLengthApi
  2461  			}
  2462  			postIndex := iNdEx + msglen
  2463  			if postIndex > l {
  2464  				return io.ErrUnexpectedEOF
  2465  			}
  2466  			if m.ConsumerScheduleDeadline == nil {
  2467  				m.ConsumerScheduleDeadline = new(time.Time)
  2468  			}
  2469  			if err := github_com_gogo_protobuf_types.StdTimeUnmarshal(m.ConsumerScheduleDeadline, dAtA[iNdEx:postIndex]); err != nil {
  2470  				return err
  2471  			}
  2472  			iNdEx = postIndex
  2473  		case 3:
  2474  			if wireType != 0 {
  2475  				return fmt.Errorf("proto: wrong wireType = %d for field Version", wireType)
  2476  			}
  2477  			m.Version = 0
  2478  			for shift := uint(0); ; shift += 7 {
  2479  				if shift >= 64 {
  2480  					return ErrIntOverflowApi
  2481  				}
  2482  				if iNdEx >= l {
  2483  					return io.ErrUnexpectedEOF
  2484  				}
  2485  				b := dAtA[iNdEx]
  2486  				iNdEx++
  2487  				m.Version |= (DistSQLVersion(b) & 0x7F) << shift
  2488  				if b < 0x80 {
  2489  					break
  2490  				}
  2491  			}
  2492  		case 4:
  2493  			if wireType != 0 {
  2494  				return fmt.Errorf("proto: wrong wireType = %d for field MinAcceptedVersion", wireType)
  2495  			}
  2496  			m.MinAcceptedVersion = 0
  2497  			for shift := uint(0); ; shift += 7 {
  2498  				if shift >= 64 {
  2499  					return ErrIntOverflowApi
  2500  				}
  2501  				if iNdEx >= l {
  2502  					return io.ErrUnexpectedEOF
  2503  				}
  2504  				b := dAtA[iNdEx]
  2505  				iNdEx++
  2506  				m.MinAcceptedVersion |= (DistSQLVersion(b) & 0x7F) << shift
  2507  				if b < 0x80 {
  2508  					break
  2509  				}
  2510  			}
  2511  		default:
  2512  			iNdEx = preIndex
  2513  			skippy, err := skipApi(dAtA[iNdEx:])
  2514  			if err != nil {
  2515  				return err
  2516  			}
  2517  			if skippy < 0 {
  2518  				return ErrInvalidLengthApi
  2519  			}
  2520  			if (iNdEx + skippy) > l {
  2521  				return io.ErrUnexpectedEOF
  2522  			}
  2523  			iNdEx += skippy
  2524  		}
  2525  	}
  2526  
  2527  	if iNdEx > l {
  2528  		return io.ErrUnexpectedEOF
  2529  	}
  2530  	return nil
  2531  }
  2532  func skipApi(dAtA []byte) (n int, err error) {
  2533  	l := len(dAtA)
  2534  	iNdEx := 0
  2535  	for iNdEx < l {
  2536  		var wire uint64
  2537  		for shift := uint(0); ; shift += 7 {
  2538  			if shift >= 64 {
  2539  				return 0, ErrIntOverflowApi
  2540  			}
  2541  			if iNdEx >= l {
  2542  				return 0, io.ErrUnexpectedEOF
  2543  			}
  2544  			b := dAtA[iNdEx]
  2545  			iNdEx++
  2546  			wire |= (uint64(b) & 0x7F) << shift
  2547  			if b < 0x80 {
  2548  				break
  2549  			}
  2550  		}
  2551  		wireType := int(wire & 0x7)
  2552  		switch wireType {
  2553  		case 0:
  2554  			for shift := uint(0); ; shift += 7 {
  2555  				if shift >= 64 {
  2556  					return 0, ErrIntOverflowApi
  2557  				}
  2558  				if iNdEx >= l {
  2559  					return 0, io.ErrUnexpectedEOF
  2560  				}
  2561  				iNdEx++
  2562  				if dAtA[iNdEx-1] < 0x80 {
  2563  					break
  2564  				}
  2565  			}
  2566  			return iNdEx, nil
  2567  		case 1:
  2568  			iNdEx += 8
  2569  			return iNdEx, nil
  2570  		case 2:
  2571  			var length int
  2572  			for shift := uint(0); ; shift += 7 {
  2573  				if shift >= 64 {
  2574  					return 0, ErrIntOverflowApi
  2575  				}
  2576  				if iNdEx >= l {
  2577  					return 0, io.ErrUnexpectedEOF
  2578  				}
  2579  				b := dAtA[iNdEx]
  2580  				iNdEx++
  2581  				length |= (int(b) & 0x7F) << shift
  2582  				if b < 0x80 {
  2583  					break
  2584  				}
  2585  			}
  2586  			iNdEx += length
  2587  			if length < 0 {
  2588  				return 0, ErrInvalidLengthApi
  2589  			}
  2590  			return iNdEx, nil
  2591  		case 3:
  2592  			for {
  2593  				var innerWire uint64
  2594  				var start int = iNdEx
  2595  				for shift := uint(0); ; shift += 7 {
  2596  					if shift >= 64 {
  2597  						return 0, ErrIntOverflowApi
  2598  					}
  2599  					if iNdEx >= l {
  2600  						return 0, io.ErrUnexpectedEOF
  2601  					}
  2602  					b := dAtA[iNdEx]
  2603  					iNdEx++
  2604  					innerWire |= (uint64(b) & 0x7F) << shift
  2605  					if b < 0x80 {
  2606  						break
  2607  					}
  2608  				}
  2609  				innerWireType := int(innerWire & 0x7)
  2610  				if innerWireType == 4 {
  2611  					break
  2612  				}
  2613  				next, err := skipApi(dAtA[start:])
  2614  				if err != nil {
  2615  					return 0, err
  2616  				}
  2617  				iNdEx = start + next
  2618  			}
  2619  			return iNdEx, nil
  2620  		case 4:
  2621  			return iNdEx, nil
  2622  		case 5:
  2623  			iNdEx += 4
  2624  			return iNdEx, nil
  2625  		default:
  2626  			return 0, fmt.Errorf("proto: illegal wireType %d", wireType)
  2627  		}
  2628  	}
  2629  	panic("unreachable")
  2630  }
  2631  
  2632  var (
  2633  	ErrInvalidLengthApi = fmt.Errorf("proto: negative length found during unmarshaling")
  2634  	ErrIntOverflowApi   = fmt.Errorf("proto: integer overflow")
  2635  )
  2636  
  2637  func init() { proto.RegisterFile("sql/execinfrapb/api.proto", fileDescriptor_api_45d3d17cbc679dc1) }
  2638  
  2639  var fileDescriptor_api_45d3d17cbc679dc1 = []byte{
  2640  	// 1217 bytes of a gzipped FileDescriptorProto
  2641  	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x94, 0x56, 0x4f, 0x73, 0x1b, 0xc5,
  2642  	0x12, 0xd7, 0x4a, 0xb2, 0x25, 0xb5, 0x2c, 0x3f, 0x79, 0xe2, 0xf7, 0x6a, 0x9f, 0x0e, 0x92, 0x4a,
  2643  	0x2f, 0x0f, 0x44, 0x52, 0x48, 0x41, 0x09, 0x14, 0x05, 0x54, 0x51, 0x51, 0xe4, 0x10, 0x39, 0x7f,
  2644  	0xca, 0xec, 0x26, 0xa9, 0x14, 0x07, 0xb6, 0x46, 0xbb, 0x2d, 0x69, 0x2b, 0xfb, 0x4f, 0x3b, 0x23,
  2645  	0xc7, 0xe6, 0x13, 0x70, 0xcc, 0x47, 0xe0, 0xc0, 0x17, 0xe1, 0xe6, 0x63, 0x0e, 0x39, 0xa4, 0x38,
  2646  	0x18, 0xb0, 0xef, 0x7c, 0x00, 0x4e, 0xd4, 0xcc, 0xee, 0xca, 0x6b, 0x19, 0x0b, 0x73, 0x9b, 0xed,
  2647  	0xfe, 0xfd, 0x7a, 0xa6, 0xbb, 0x7f, 0x33, 0xbd, 0xf0, 0x5f, 0x36, 0x73, 0xba, 0x78, 0x80, 0xa6,
  2648  	0xed, 0x8d, 0x43, 0x1a, 0x8c, 0xba, 0x34, 0xb0, 0x3b, 0x41, 0xe8, 0x73, 0x9f, 0xa8, 0xa6, 0x6f,
  2649  	0xbe, 0x0c, 0x7d, 0x6a, 0x4e, 0x3b, 0x6c, 0xe6, 0x74, 0x2c, 0x9b, 0x71, 0x36, 0x73, 0xc2, 0xb9,
  2650  	0x57, 0xdb, 0x9e, 0xf8, 0x13, 0x5f, 0x82, 0xba, 0x62, 0x15, 0xe1, 0x6b, 0x8d, 0x89, 0xef, 0x4f,
  2651  	0x1c, 0xec, 0xca, 0xaf, 0xd1, 0x7c, 0xdc, 0xe5, 0xb6, 0x8b, 0x8c, 0x53, 0x37, 0x88, 0x01, 0x44,
  2652  	0x06, 0x0b, 0x46, 0x5d, 0x8b, 0x72, 0x1a, 0xdb, 0x6a, 0xcb, 0xfb, 0xa7, 0x7c, 0xcd, 0x65, 0x5f,
  2653  	0x10, 0xfa, 0x26, 0x32, 0xe6, 0x87, 0x2c, 0x42, 0xb4, 0xde, 0x66, 0xa1, 0xaa, 0x23, 0x9f, 0x07,
  2654  	0xf7, 0x1d, 0xff, 0x95, 0x86, 0xb3, 0x39, 0x32, 0x4e, 0xbe, 0x80, 0xfc, 0xd8, 0xf1, 0x5f, 0xa9,
  2655  	0xb9, 0xa6, 0xd2, 0x2e, 0xf7, 0x5a, 0x9d, 0xcb, 0xd2, 0xe8, 0x08, 0x92, 0x1e, 0xa0, 0xd9, 0xcf,
  2656  	0x1f, 0x1d, 0x37, 0x32, 0x9a, 0x64, 0x91, 0x5b, 0x50, 0xd8, 0xc7, 0x90, 0xd9, 0xbe, 0xa7, 0xae,
  2657  	0x35, 0x95, 0x76, 0xa5, 0xff, 0x1f, 0xe1, 0xfc, 0xe3, 0xb8, 0xb1, 0x39, 0xb0, 0x19, 0xd7, 0xbf,
  2658  	0x7e, 0xf4, 0x3c, 0xf2, 0x6a, 0x09, 0x8c, 0x3c, 0x86, 0x32, 0xee, 0x53, 0xe7, 0x9e, 0xef, 0x71,
  2659  	0x3c, 0xe0, 0xea, 0xba, 0xdc, 0xf6, 0xff, 0x97, 0x6f, 0xbb, 0x73, 0x06, 0x8e, 0x77, 0x4e, 0xf3,
  2660  	0xc9, 0x33, 0xd8, 0x76, 0x90, 0x8e, 0x0d, 0x7e, 0xe0, 0x19, 0xb6, 0x17, 0xcc, 0xb9, 0xc1, 0x38,
  2661  	0xe5, 0xa8, 0x16, 0x64, 0xdc, 0xeb, 0xa9, 0xb8, 0x71, 0x39, 0x3b, 0x8f, 0x90, 0x8e, 0x9f, 0x1e,
  2662  	0x78, 0x43, 0x01, 0xd6, 0x05, 0x56, 0xdb, 0x72, 0x96, 0x4d, 0xa4, 0x0e, 0x85, 0xa7, 0x21, 0x35,
  2663  	0xf1, 0xe1, 0x73, 0xb5, 0xd8, 0x54, 0xda, 0xc5, 0x78, 0xeb, 0xc4, 0xb8, 0x9b, 0x2f, 0x2a, 0xd5,
  2664  	0xec, 0x6e, 0xbe, 0x98, 0xad, 0xe6, 0x5a, 0xa7, 0x0a, 0x14, 0x93, 0xe2, 0x90, 0x8f, 0xa0, 0x20,
  2665  	0x0a, 0x63, 0xd8, 0x96, 0xaa, 0x34, 0x95, 0xf6, 0x46, 0x5f, 0x15, 0xc4, 0x9f, 0x8f, 0x1b, 0xeb,
  2666  	0x02, 0x32, 0x1c, 0x9c, 0x2c, 0x56, 0xda, 0xba, 0x00, 0x0e, 0x2d, 0xf2, 0x18, 0xe0, 0xac, 0x55,
  2667  	0x6a, 0xb6, 0x99, 0x6b, 0x97, 0x7b, 0xef, 0x5f, 0x5e, 0x90, 0xbd, 0x04, 0x9b, 0x6a, 0x46, 0x2a,
  2668  	0x00, 0x79, 0x06, 0x85, 0x09, 0xe5, 0xf8, 0x8a, 0x1e, 0xca, 0x9e, 0xae, 0xf5, 0x3f, 0x8f, 0x5b,
  2669  	0x72, 0x7b, 0x62, 0xf3, 0xe9, 0x7c, 0xd4, 0x31, 0x7d, 0xb7, 0xbb, 0x88, 0x6e, 0x8d, 0xce, 0xd6,
  2670  	0xdd, 0xe0, 0xe5, 0xa4, 0x9b, 0x94, 0xe9, 0x89, 0x6f, 0xe1, 0x70, 0xa0, 0x25, 0xb1, 0x5a, 0xbf,
  2671  	0xe7, 0xa1, 0x9c, 0xea, 0x05, 0xb9, 0x03, 0x84, 0x71, 0x97, 0x3f, 0x4d, 0x54, 0xfb, 0x84, 0x7a,
  2672  	0x3e, 0x93, 0x39, 0xe7, 0xe2, 0x43, 0xfd, 0x85, 0x9f, 0xf4, 0x60, 0x8b, 0x1f, 0x78, 0x4b, 0xa4,
  2673  	0x6c, 0x8a, 0x74, 0xd1, 0x4d, 0x9a, 0x50, 0x74, 0x7c, 0x93, 0x72, 0x21, 0xb2, 0x7c, 0x53, 0x69,
  2674  	0x97, 0x62, 0xe8, 0xc2, 0x2a, 0x10, 0xe2, 0x22, 0x8c, 0x28, 0x43, 0x29, 0xc3, 0x05, 0x22, 0xb1,
  2675  	0x92, 0x06, 0x94, 0x19, 0xd2, 0xd0, 0x9c, 0x1a, 0x01, 0xe5, 0x53, 0x75, 0xbd, 0x99, 0x6b, 0x97,
  2676  	0x34, 0x88, 0x4c, 0x7b, 0x94, 0x4f, 0x89, 0x0a, 0xf9, 0x39, 0xc3, 0x50, 0xea, 0x26, 0xa1, 0x4b,
  2677  	0x0b, 0xd9, 0x85, 0x12, 0xc3, 0x59, 0x2c, 0xab, 0xa2, 0x94, 0xd5, 0x8a, 0xee, 0xe8, 0xe2, 0x5a,
  2678  	0x79, 0x26, 0x4a, 0x19, 0x25, 0xc7, 0x60, 0x38, 0x8b, 0x64, 0xd5, 0x85, 0x2a, 0x0d, 0x02, 0xc7,
  2679  	0x8e, 0xce, 0x6d, 0x78, 0xd4, 0x45, 0xb5, 0x94, 0xda, 0xf1, 0x5f, 0x29, 0xef, 0x13, 0xea, 0x22,
  2680  	0xa1, 0x70, 0x6d, 0x74, 0xc8, 0x91, 0x19, 0xe8, 0x99, 0xbe, 0x85, 0xc6, 0xd8, 0x0f, 0x5d, 0xca,
  2681  	0x55, 0x68, 0x2a, 0xed, 0xcd, 0xde, 0xcd, 0xcb, 0x8f, 0xd1, 0x17, 0xa4, 0x1d, 0xc9, 0xb9, 0x2f,
  2682  	0x29, 0x49, 0x79, 0x47, 0xcb, 0x0e, 0xd2, 0x03, 0x82, 0x07, 0x3c, 0xa4, 0xc6, 0xd8, 0xf1, 0x29,
  2683  	0x37, 0x2c, 0x7b, 0x62, 0x73, 0xa6, 0x96, 0xa5, 0x74, 0x22, 0x52, 0x55, 0xfa, 0xef, 0x0b, 0xf7,
  2684  	0x40, 0x7a, 0x49, 0x0b, 0x4a, 0xfb, 0x68, 0x72, 0x3f, 0xb4, 0xbf, 0x43, 0x75, 0x23, 0x05, 0x3d,
  2685  	0x33, 0x93, 0x4f, 0xe1, 0xdf, 0x1c, 0xdd, 0xc0, 0x0f, 0x69, 0x78, 0x68, 0x30, 0x73, 0x8a, 0x2e,
  2686  	0x8d, 0x12, 0xae, 0xa4, 0x12, 0xbe, 0xb6, 0x80, 0xe8, 0x12, 0x21, 0x92, 0xde, 0xcd, 0x17, 0x73,
  2687  	0xd5, 0x7c, 0xeb, 0xad, 0x02, 0x95, 0x73, 0xd5, 0x24, 0x5f, 0x42, 0x9e, 0xe1, 0x4c, 0x88, 0x4c,
  2688  	0x5c, 0x91, 0x9b, 0x57, 0x6c, 0x82, 0xf8, 0xd2, 0x24, 0x91, 0xdc, 0x82, 0x6d, 0x87, 0x32, 0x6e,
  2689  	0x88, 0x7e, 0xda, 0x9e, 0x19, 0xa2, 0x8b, 0x1e, 0x47, 0x4b, 0x0a, 0xb0, 0xa2, 0x11, 0xe1, 0xd3,
  2690  	0x71, 0x36, 0x3c, 0xf3, 0xd4, 0xf6, 0x20, 0xa7, 0xe3, 0x8c, 0x5c, 0x87, 0x75, 0xc9, 0x89, 0x2e,
  2691  	0x75, 0xa5, 0x5f, 0x11, 0x87, 0x3f, 0x39, 0x6e, 0xac, 0x09, 0xf8, 0x40, 0x5b, 0x63, 0x38, 0x1b,
  2692  	0x5a, 0xe4, 0x7f, 0x00, 0x0e, 0xe5, 0xc8, 0xb8, 0xb1, 0x4f, 0x9d, 0x73, 0xaa, 0x2e, 0x45, 0xf6,
  2693  	0xe7, 0xd4, 0x69, 0x7d, 0x05, 0x9b, 0xba, 0xed, 0x06, 0x0e, 0x6a, 0xc8, 0x02, 0xdf, 0x63, 0x48,
  2694  	0x3e, 0x86, 0x35, 0x0c, 0x43, 0x3f, 0x94, 0xb1, 0xcb, 0xbd, 0xc6, 0x8a, 0xb7, 0x50, 0xc0, 0xb4,
  2695  	0x08, 0xdd, 0xfa, 0x3e, 0x0b, 0x9b, 0xf7, 0x7c, 0x8f, 0xcd, 0x5d, 0x0c, 0x75, 0x7b, 0xe2, 0x51,
  2696  	0x87, 0x3c, 0x84, 0x8a, 0x15, 0x52, 0xdb, 0x33, 0xc2, 0xe8, 0x71, 0x8f, 0x23, 0xbe, 0x77, 0x79,
  2697  	0xc4, 0x81, 0x80, 0xc7, 0xa3, 0x40, 0xdb, 0xb0, 0x52, 0x5f, 0xe4, 0x05, 0x10, 0x26, 0x86, 0x85,
  2698  	0x21, 0xdf, 0xb3, 0x24, 0x62, 0x56, 0x46, 0xbc, 0xb1, 0xaa, 0xf6, 0xe7, 0x07, 0x8c, 0x56, 0x65,
  2699  	0xcb, 0x23, 0x67, 0x08, 0xa5, 0x29, 0xf5, 0x2c, 0x36, 0xa5, 0x2f, 0x31, 0x9e, 0x3b, 0x2b, 0x9a,
  2700  	0x99, 0xe4, 0xf8, 0x20, 0xa1, 0x68, 0x67, 0xec, 0xcf, 0xf2, 0x47, 0x3f, 0x34, 0x94, 0xd6, 0x26,
  2701  	0x6c, 0xa4, 0x13, 0x69, 0xfd, 0x98, 0x85, 0xad, 0x0b, 0x34, 0x72, 0x1b, 0x88, 0x19, 0x1b, 0xa5,
  2702  	0x1e, 0xad, 0xb9, 0x83, 0x51, 0x43, 0x93, 0xe7, 0x7d, 0x2b, 0xf1, 0xeb, 0x89, 0x9b, 0x7c, 0x0b,
  2703  	0xb5, 0x0b, 0x24, 0xc3, 0x42, 0x6a, 0x39, 0xb6, 0x87, 0x71, 0x35, 0x6a, 0x9d, 0x68, 0x96, 0x77,
  2704  	0x92, 0x59, 0xde, 0x59, 0xbc, 0x60, 0xfd, 0xfc, 0xeb, 0x5f, 0x1a, 0x8a, 0xa6, 0x2e, 0x07, 0x1e,
  2705  	0xc4, 0x11, 0xd2, 0x03, 0x34, 0x77, 0xb5, 0x01, 0xfa, 0x00, 0xb6, 0x5d, 0xdb, 0x33, 0xa8, 0x69,
  2706  	0x62, 0xc0, 0xd1, 0x32, 0x12, 0x7a, 0x7e, 0x25, 0x9d, 0xb8, 0xb6, 0x77, 0x37, 0xa6, 0xc4, 0xb6,
  2707  	0x1b, 0x77, 0x60, 0xeb, 0xc2, 0x3b, 0x41, 0x0a, 0x90, 0x7b, 0xb0, 0xf3, 0xa2, 0x9a, 0x21, 0x00,
  2708  	0xeb, 0x3b, 0xfa, 0xbd, 0xbb, 0x7b, 0x3b, 0x55, 0x45, 0xac, 0xfb, 0x77, 0xf5, 0x9d, 0x4f, 0xee,
  2709  	0x54, 0xb3, 0xbd, 0x9f, 0xb2, 0x50, 0x88, 0x83, 0x93, 0x29, 0x94, 0xb5, 0xb9, 0xa7, 0x1f, 0x7a,
  2710  	0xa6, 0xe8, 0x2f, 0x69, 0xff, 0x7d, 0x17, 0x23, 0xa5, 0xd6, 0x3e, 0x58, 0x39, 0xdf, 0xac, 0xb9,
  2711  	0x89, 0xe1, 0x63, 0x64, 0x8c, 0x4e, 0xb0, 0x95, 0x69, 0x2b, 0xb7, 0x14, 0x62, 0x42, 0x69, 0xa1,
  2712  	0x2c, 0xf2, 0x0f, 0xe4, 0x57, 0x5b, 0x71, 0xa6, 0xf3, 0xf7, 0xb0, 0x95, 0x21, 0x13, 0x00, 0x39,
  2713  	0xc8, 0x79, 0x88, 0xd4, 0x25, 0x57, 0x3f, 0x63, 0xed, 0xca, 0x89, 0x47, 0xd9, 0xf4, 0x3f, 0x3c,
  2714  	0xfa, 0xad, 0x9e, 0x39, 0x3a, 0xa9, 0x2b, 0x6f, 0x4e, 0xea, 0xca, 0xbb, 0x93, 0xba, 0xf2, 0xeb,
  2715  	0x49, 0x5d, 0x79, 0x7d, 0x5a, 0xcf, 0xbc, 0x39, 0xad, 0x67, 0xde, 0x9d, 0xd6, 0x33, 0xdf, 0x94,
  2716  	0x53, 0x7f, 0x72, 0x7f, 0x06, 0x00, 0x00, 0xff, 0xff, 0xfc, 0xd4, 0x8a, 0x63, 0x77, 0x0a, 0x00,
  2717  	0x00,
  2718  }