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

     1  // Code generated by protoc-gen-gogo. DO NOT EDIT.
     2  // source: sql/execinfrapb/processors_bulk_io.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  import sqlbase "github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
    17  import hlc "github.com/cockroachdb/cockroach/pkg/util/hlc"
    18  
    19  import time "time"
    20  
    21  import github_com_gogo_protobuf_sortkeys "github.com/gogo/protobuf/sortkeys"
    22  import encoding_binary "encoding/binary"
    23  
    24  import io "io"
    25  
    26  // Reference imports to suppress errors if they are not otherwise used.
    27  var _ = proto.Marshal
    28  var _ = fmt.Errorf
    29  var _ = math.Inf
    30  var _ = time.Kitchen
    31  
    32  // This is a compile-time assertion to ensure that this generated file
    33  // is compatible with the proto package it is being compiled against.
    34  // A compilation error at this line likely means your copy of the
    35  // proto package needs to be updated.
    36  const _ = proto.GoGoProtoPackageIsVersion2 // please upgrade the proto package
    37  
    38  // FileCompression list of the compression codecs which are currently
    39  // supported for CSVWriter spec
    40  type FileCompression int32
    41  
    42  const (
    43  	FileCompression_None FileCompression = 0
    44  	FileCompression_Gzip FileCompression = 1
    45  )
    46  
    47  var FileCompression_name = map[int32]string{
    48  	0: "None",
    49  	1: "Gzip",
    50  }
    51  var FileCompression_value = map[string]int32{
    52  	"None": 0,
    53  	"Gzip": 1,
    54  }
    55  
    56  func (x FileCompression) Enum() *FileCompression {
    57  	p := new(FileCompression)
    58  	*p = x
    59  	return p
    60  }
    61  func (x FileCompression) String() string {
    62  	return proto.EnumName(FileCompression_name, int32(x))
    63  }
    64  func (x *FileCompression) UnmarshalJSON(data []byte) error {
    65  	value, err := proto.UnmarshalJSONEnum(FileCompression_value, data, "FileCompression")
    66  	if err != nil {
    67  		return err
    68  	}
    69  	*x = FileCompression(value)
    70  	return nil
    71  }
    72  func (FileCompression) EnumDescriptor() ([]byte, []int) {
    73  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{0}
    74  }
    75  
    76  type BackfillerSpec_Type int32
    77  
    78  const (
    79  	BackfillerSpec_Invalid BackfillerSpec_Type = 0
    80  	BackfillerSpec_Column  BackfillerSpec_Type = 1
    81  	BackfillerSpec_Index   BackfillerSpec_Type = 2
    82  )
    83  
    84  var BackfillerSpec_Type_name = map[int32]string{
    85  	0: "Invalid",
    86  	1: "Column",
    87  	2: "Index",
    88  }
    89  var BackfillerSpec_Type_value = map[string]int32{
    90  	"Invalid": 0,
    91  	"Column":  1,
    92  	"Index":   2,
    93  }
    94  
    95  func (x BackfillerSpec_Type) Enum() *BackfillerSpec_Type {
    96  	p := new(BackfillerSpec_Type)
    97  	*p = x
    98  	return p
    99  }
   100  func (x BackfillerSpec_Type) String() string {
   101  	return proto.EnumName(BackfillerSpec_Type_name, int32(x))
   102  }
   103  func (x *BackfillerSpec_Type) UnmarshalJSON(data []byte) error {
   104  	value, err := proto.UnmarshalJSONEnum(BackfillerSpec_Type_value, data, "BackfillerSpec_Type")
   105  	if err != nil {
   106  		return err
   107  	}
   108  	*x = BackfillerSpec_Type(value)
   109  	return nil
   110  }
   111  func (BackfillerSpec_Type) EnumDescriptor() ([]byte, []int) {
   112  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{0, 0}
   113  }
   114  
   115  // BackfillerSpec is the specification for a "schema change backfiller".
   116  // The created backfill processor runs a backfill for the first mutations in
   117  // the table descriptor mutation list with the same mutation id and type.
   118  // A backfiller processor performs KV operations to retrieve rows for a
   119  // table and backfills the new indexes/columns contained in the table
   120  // descriptor. It checkpoints its progress by updating the table
   121  // descriptor in the database, and doesn't emit any rows nor support
   122  // any post-processing.
   123  type BackfillerSpec struct {
   124  	Type  BackfillerSpec_Type     `protobuf:"varint,1,opt,name=type,enum=cockroach.sql.distsqlrun.BackfillerSpec_Type" json:"type"`
   125  	Table sqlbase.TableDescriptor `protobuf:"bytes,2,opt,name=table" json:"table"`
   126  	// Sections of the table to be backfilled.
   127  	Spans []TableReaderSpan `protobuf:"bytes,3,rep,name=spans" json:"spans"`
   128  	// Run the backfill for approximately this duration.
   129  	// The backfill will always process at least one backfill chunk.
   130  	Duration time.Duration `protobuf:"varint,4,opt,name=duration,casttype=time.Duration" json:"duration"`
   131  	// The backfill involves a complete table scan in chunks,
   132  	// where each chunk is a transactional read of a set of rows
   133  	// along with a backfill for the rows. This is the maximum number
   134  	// of entries backfilled per chunk.
   135  	ChunkSize int64 `protobuf:"varint,5,opt,name=chunk_size,json=chunkSize" json:"chunk_size"`
   136  	// Any other (leased) table descriptors necessary for the
   137  	// backfiller to do its job, such as the descriptors for tables with fk
   138  	// relationships to the table being modified.
   139  	OtherTables []sqlbase.TableDescriptor `protobuf:"bytes,6,rep,name=other_tables,json=otherTables" json:"other_tables"`
   140  	// The timestamp to perform index backfill historical scans at.
   141  	ReadAsOf hlc.Timestamp `protobuf:"bytes,7,opt,name=readAsOf" json:"readAsOf"`
   142  }
   143  
   144  func (m *BackfillerSpec) Reset()         { *m = BackfillerSpec{} }
   145  func (m *BackfillerSpec) String() string { return proto.CompactTextString(m) }
   146  func (*BackfillerSpec) ProtoMessage()    {}
   147  func (*BackfillerSpec) Descriptor() ([]byte, []int) {
   148  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{0}
   149  }
   150  func (m *BackfillerSpec) XXX_Unmarshal(b []byte) error {
   151  	return m.Unmarshal(b)
   152  }
   153  func (m *BackfillerSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   154  	b = b[:cap(b)]
   155  	n, err := m.MarshalTo(b)
   156  	if err != nil {
   157  		return nil, err
   158  	}
   159  	return b[:n], nil
   160  }
   161  func (dst *BackfillerSpec) XXX_Merge(src proto.Message) {
   162  	xxx_messageInfo_BackfillerSpec.Merge(dst, src)
   163  }
   164  func (m *BackfillerSpec) XXX_Size() int {
   165  	return m.Size()
   166  }
   167  func (m *BackfillerSpec) XXX_DiscardUnknown() {
   168  	xxx_messageInfo_BackfillerSpec.DiscardUnknown(m)
   169  }
   170  
   171  var xxx_messageInfo_BackfillerSpec proto.InternalMessageInfo
   172  
   173  // JobProgress identifies the job to report progress on. This reporting
   174  // happens outside this package.
   175  type JobProgress struct {
   176  	JobID int64 `protobuf:"varint,1,opt,name=job_id,json=jobId" json:"job_id"`
   177  	// contribution is the percent of work of the total this processor will
   178  	// process.
   179  	Contribution float32 `protobuf:"fixed32,2,opt,name=contribution" json:"contribution"`
   180  	// slot is the index into the job details for this processor's completion.
   181  	Slot int32 `protobuf:"varint,3,opt,name=slot" json:"slot"`
   182  }
   183  
   184  func (m *JobProgress) Reset()         { *m = JobProgress{} }
   185  func (m *JobProgress) String() string { return proto.CompactTextString(m) }
   186  func (*JobProgress) ProtoMessage()    {}
   187  func (*JobProgress) Descriptor() ([]byte, []int) {
   188  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{1}
   189  }
   190  func (m *JobProgress) XXX_Unmarshal(b []byte) error {
   191  	return m.Unmarshal(b)
   192  }
   193  func (m *JobProgress) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   194  	b = b[:cap(b)]
   195  	n, err := m.MarshalTo(b)
   196  	if err != nil {
   197  		return nil, err
   198  	}
   199  	return b[:n], nil
   200  }
   201  func (dst *JobProgress) XXX_Merge(src proto.Message) {
   202  	xxx_messageInfo_JobProgress.Merge(dst, src)
   203  }
   204  func (m *JobProgress) XXX_Size() int {
   205  	return m.Size()
   206  }
   207  func (m *JobProgress) XXX_DiscardUnknown() {
   208  	xxx_messageInfo_JobProgress.DiscardUnknown(m)
   209  }
   210  
   211  var xxx_messageInfo_JobProgress proto.InternalMessageInfo
   212  
   213  type ReadImportDataSpec struct {
   214  	Format roachpb.IOFileFormat `protobuf:"bytes,8,opt,name=format" json:"format"`
   215  	// sample_size is the rate at which to output rows, based on an input row's size.
   216  	SampleSize int32 `protobuf:"varint,2,opt,name=sample_size,json=sampleSize" json:"sample_size"`
   217  	// tables supports input formats that can read multiple tables. If it is
   218  	// non-empty, the keys specify the names of tables for which the processor
   219  	// should read and emit data (ignoring data for any other tables that is
   220  	// present in the input).
   221  	//
   222  	// TODO(dt): If a key has a nil value, the schema for that table should be
   223  	// determined from the input on-the-fly (e.g. by parsing a CREATE TABLE in a
   224  	// dump file) and the processor should emit a key/value for the generated
   225  	// TableDescriptor with the corresponding descriptor ID key. If tables is
   226  	// empty (and table_desc above is not specified), the processor should read
   227  	// all tables in the input, determining their schemas on the fly.
   228  	Tables map[string]*ReadImportDataSpec_ImportTable `protobuf:"bytes,9,rep,name=tables" json:"tables,omitempty" protobuf_key:"bytes,1,opt,name=key" protobuf_val:"bytes,2,opt,name=value"`
   229  	// uri is a cloud.ExternalStorage URI pointing to the CSV files to be
   230  	// read. The map key must be unique across the entire IMPORT job.
   231  	Uri map[int32]string `protobuf:"bytes,7,rep,name=uri" json:"uri,omitempty" protobuf_key:"varint,1,opt,name=key" protobuf_val:"bytes,2,opt,name=value"`
   232  	// resume_pos specifies a map from an input ID to an offset in that
   233  	// input from which the processing should continue.
   234  	// The meaning of offset is specific to each processor.
   235  	ResumePos              map[int32]int64 `protobuf:"bytes,14,rep,name=resume_pos,json=resumePos" json:"resume_pos,omitempty" protobuf_key:"varint,1,opt,name=key" protobuf_val:"varint,2,opt,name=value"`
   236  	Progress               JobProgress     `protobuf:"bytes,6,opt,name=progress" json:"progress"`
   237  	SkipMissingForeignKeys bool            `protobuf:"varint,10,opt,name=skip_missing_foreign_keys,json=skipMissingForeignKeys" json:"skip_missing_foreign_keys"`
   238  	// walltimeNanos is the MVCC time at which the created KVs will be written.
   239  	WalltimeNanos int64 `protobuf:"varint,11,opt,name=walltimeNanos" json:"walltimeNanos"`
   240  	// If set, specifies reader parallelism; 0 implies "use default".
   241  	ReaderParallelism int32 `protobuf:"varint,13,opt,name=readerParallelism" json:"readerParallelism"`
   242  }
   243  
   244  func (m *ReadImportDataSpec) Reset()         { *m = ReadImportDataSpec{} }
   245  func (m *ReadImportDataSpec) String() string { return proto.CompactTextString(m) }
   246  func (*ReadImportDataSpec) ProtoMessage()    {}
   247  func (*ReadImportDataSpec) Descriptor() ([]byte, []int) {
   248  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{2}
   249  }
   250  func (m *ReadImportDataSpec) XXX_Unmarshal(b []byte) error {
   251  	return m.Unmarshal(b)
   252  }
   253  func (m *ReadImportDataSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   254  	b = b[:cap(b)]
   255  	n, err := m.MarshalTo(b)
   256  	if err != nil {
   257  		return nil, err
   258  	}
   259  	return b[:n], nil
   260  }
   261  func (dst *ReadImportDataSpec) XXX_Merge(src proto.Message) {
   262  	xxx_messageInfo_ReadImportDataSpec.Merge(dst, src)
   263  }
   264  func (m *ReadImportDataSpec) XXX_Size() int {
   265  	return m.Size()
   266  }
   267  func (m *ReadImportDataSpec) XXX_DiscardUnknown() {
   268  	xxx_messageInfo_ReadImportDataSpec.DiscardUnknown(m)
   269  }
   270  
   271  var xxx_messageInfo_ReadImportDataSpec proto.InternalMessageInfo
   272  
   273  type ReadImportDataSpec_ImportTable struct {
   274  	Desc *sqlbase.TableDescriptor `protobuf:"bytes,1,opt,name=desc" json:"desc,omitempty"`
   275  	// targetCols is used to store the target columns for each existing table
   276  	// being imported into. These are the columns for which the processor should
   277  	// read and emit data (ignoring data for any other tables or columns outside
   278  	// of the targetCols, that is present in the input).
   279  	TargetCols []string `protobuf:"bytes,2,rep,name=targetCols" json:"targetCols,omitempty"`
   280  }
   281  
   282  func (m *ReadImportDataSpec_ImportTable) Reset()         { *m = ReadImportDataSpec_ImportTable{} }
   283  func (m *ReadImportDataSpec_ImportTable) String() string { return proto.CompactTextString(m) }
   284  func (*ReadImportDataSpec_ImportTable) ProtoMessage()    {}
   285  func (*ReadImportDataSpec_ImportTable) Descriptor() ([]byte, []int) {
   286  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{2, 0}
   287  }
   288  func (m *ReadImportDataSpec_ImportTable) XXX_Unmarshal(b []byte) error {
   289  	return m.Unmarshal(b)
   290  }
   291  func (m *ReadImportDataSpec_ImportTable) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   292  	b = b[:cap(b)]
   293  	n, err := m.MarshalTo(b)
   294  	if err != nil {
   295  		return nil, err
   296  	}
   297  	return b[:n], nil
   298  }
   299  func (dst *ReadImportDataSpec_ImportTable) XXX_Merge(src proto.Message) {
   300  	xxx_messageInfo_ReadImportDataSpec_ImportTable.Merge(dst, src)
   301  }
   302  func (m *ReadImportDataSpec_ImportTable) XXX_Size() int {
   303  	return m.Size()
   304  }
   305  func (m *ReadImportDataSpec_ImportTable) XXX_DiscardUnknown() {
   306  	xxx_messageInfo_ReadImportDataSpec_ImportTable.DiscardUnknown(m)
   307  }
   308  
   309  var xxx_messageInfo_ReadImportDataSpec_ImportTable proto.InternalMessageInfo
   310  
   311  // CSVWriterSpec is the specification for a processor that consumes rows and
   312  // writes them to CSV files at uri. It outputs a row per file written with
   313  // the file name, row count and byte size.
   314  type CSVWriterSpec struct {
   315  	// destination as a cloud.ExternalStorage URI pointing to an export store
   316  	// location (directory).
   317  	Destination string             `protobuf:"bytes,1,opt,name=destination" json:"destination"`
   318  	NamePattern string             `protobuf:"bytes,2,opt,name=name_pattern,json=namePattern" json:"name_pattern"`
   319  	Options     roachpb.CSVOptions `protobuf:"bytes,3,opt,name=options" json:"options"`
   320  	// chunk_rows is num rows to write per file. 0 = no limit.
   321  	ChunkRows int64 `protobuf:"varint,4,opt,name=chunk_rows,json=chunkRows" json:"chunk_rows"`
   322  	// compression_codec specifies compression used for exported file.
   323  	CompressionCodec FileCompression `protobuf:"varint,5,opt,name=compression_codec,json=compressionCodec,enum=cockroach.sql.distsqlrun.FileCompression" json:"compression_codec"`
   324  }
   325  
   326  func (m *CSVWriterSpec) Reset()         { *m = CSVWriterSpec{} }
   327  func (m *CSVWriterSpec) String() string { return proto.CompactTextString(m) }
   328  func (*CSVWriterSpec) ProtoMessage()    {}
   329  func (*CSVWriterSpec) Descriptor() ([]byte, []int) {
   330  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{3}
   331  }
   332  func (m *CSVWriterSpec) XXX_Unmarshal(b []byte) error {
   333  	return m.Unmarshal(b)
   334  }
   335  func (m *CSVWriterSpec) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) {
   336  	b = b[:cap(b)]
   337  	n, err := m.MarshalTo(b)
   338  	if err != nil {
   339  		return nil, err
   340  	}
   341  	return b[:n], nil
   342  }
   343  func (dst *CSVWriterSpec) XXX_Merge(src proto.Message) {
   344  	xxx_messageInfo_CSVWriterSpec.Merge(dst, src)
   345  }
   346  func (m *CSVWriterSpec) XXX_Size() int {
   347  	return m.Size()
   348  }
   349  func (m *CSVWriterSpec) XXX_DiscardUnknown() {
   350  	xxx_messageInfo_CSVWriterSpec.DiscardUnknown(m)
   351  }
   352  
   353  var xxx_messageInfo_CSVWriterSpec proto.InternalMessageInfo
   354  
   355  // BulkRowWriterSpec is the specification for a processor that consumes rows and
   356  // writes them to a target table using AddSSTable. It outputs a BulkOpSummary.
   357  type BulkRowWriterSpec struct {
   358  	Table sqlbase.TableDescriptor `protobuf:"bytes,1,opt,name=table" json:"table"`
   359  }
   360  
   361  func (m *BulkRowWriterSpec) Reset()         { *m = BulkRowWriterSpec{} }
   362  func (m *BulkRowWriterSpec) String() string { return proto.CompactTextString(m) }
   363  func (*BulkRowWriterSpec) ProtoMessage()    {}
   364  func (*BulkRowWriterSpec) Descriptor() ([]byte, []int) {
   365  	return fileDescriptor_processors_bulk_io_8cd4c8af43285ea2, []int{4}
   366  }
   367  func (m *BulkRowWriterSpec) XXX_Unmarshal(b []byte) error {
   368  	return m.Unmarshal(b)
   369  }
   370  func (m *BulkRowWriterSpec) 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 *BulkRowWriterSpec) XXX_Merge(src proto.Message) {
   379  	xxx_messageInfo_BulkRowWriterSpec.Merge(dst, src)
   380  }
   381  func (m *BulkRowWriterSpec) XXX_Size() int {
   382  	return m.Size()
   383  }
   384  func (m *BulkRowWriterSpec) XXX_DiscardUnknown() {
   385  	xxx_messageInfo_BulkRowWriterSpec.DiscardUnknown(m)
   386  }
   387  
   388  var xxx_messageInfo_BulkRowWriterSpec proto.InternalMessageInfo
   389  
   390  func init() {
   391  	proto.RegisterType((*BackfillerSpec)(nil), "cockroach.sql.distsqlrun.BackfillerSpec")
   392  	proto.RegisterType((*JobProgress)(nil), "cockroach.sql.distsqlrun.JobProgress")
   393  	proto.RegisterType((*ReadImportDataSpec)(nil), "cockroach.sql.distsqlrun.ReadImportDataSpec")
   394  	proto.RegisterMapType((map[int32]int64)(nil), "cockroach.sql.distsqlrun.ReadImportDataSpec.ResumePosEntry")
   395  	proto.RegisterMapType((map[string]*ReadImportDataSpec_ImportTable)(nil), "cockroach.sql.distsqlrun.ReadImportDataSpec.TablesEntry")
   396  	proto.RegisterMapType((map[int32]string)(nil), "cockroach.sql.distsqlrun.ReadImportDataSpec.UriEntry")
   397  	proto.RegisterType((*ReadImportDataSpec_ImportTable)(nil), "cockroach.sql.distsqlrun.ReadImportDataSpec.ImportTable")
   398  	proto.RegisterType((*CSVWriterSpec)(nil), "cockroach.sql.distsqlrun.CSVWriterSpec")
   399  	proto.RegisterType((*BulkRowWriterSpec)(nil), "cockroach.sql.distsqlrun.BulkRowWriterSpec")
   400  	proto.RegisterEnum("cockroach.sql.distsqlrun.FileCompression", FileCompression_name, FileCompression_value)
   401  	proto.RegisterEnum("cockroach.sql.distsqlrun.BackfillerSpec_Type", BackfillerSpec_Type_name, BackfillerSpec_Type_value)
   402  }
   403  func (m *BackfillerSpec) Marshal() (dAtA []byte, err error) {
   404  	size := m.Size()
   405  	dAtA = make([]byte, size)
   406  	n, err := m.MarshalTo(dAtA)
   407  	if err != nil {
   408  		return nil, err
   409  	}
   410  	return dAtA[:n], nil
   411  }
   412  
   413  func (m *BackfillerSpec) MarshalTo(dAtA []byte) (int, error) {
   414  	var i int
   415  	_ = i
   416  	var l int
   417  	_ = l
   418  	dAtA[i] = 0x8
   419  	i++
   420  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Type))
   421  	dAtA[i] = 0x12
   422  	i++
   423  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Table.Size()))
   424  	n1, err := m.Table.MarshalTo(dAtA[i:])
   425  	if err != nil {
   426  		return 0, err
   427  	}
   428  	i += n1
   429  	if len(m.Spans) > 0 {
   430  		for _, msg := range m.Spans {
   431  			dAtA[i] = 0x1a
   432  			i++
   433  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(msg.Size()))
   434  			n, err := msg.MarshalTo(dAtA[i:])
   435  			if err != nil {
   436  				return 0, err
   437  			}
   438  			i += n
   439  		}
   440  	}
   441  	dAtA[i] = 0x20
   442  	i++
   443  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Duration))
   444  	dAtA[i] = 0x28
   445  	i++
   446  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.ChunkSize))
   447  	if len(m.OtherTables) > 0 {
   448  		for _, msg := range m.OtherTables {
   449  			dAtA[i] = 0x32
   450  			i++
   451  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(msg.Size()))
   452  			n, err := msg.MarshalTo(dAtA[i:])
   453  			if err != nil {
   454  				return 0, err
   455  			}
   456  			i += n
   457  		}
   458  	}
   459  	dAtA[i] = 0x3a
   460  	i++
   461  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.ReadAsOf.Size()))
   462  	n2, err := m.ReadAsOf.MarshalTo(dAtA[i:])
   463  	if err != nil {
   464  		return 0, err
   465  	}
   466  	i += n2
   467  	return i, nil
   468  }
   469  
   470  func (m *JobProgress) Marshal() (dAtA []byte, err error) {
   471  	size := m.Size()
   472  	dAtA = make([]byte, size)
   473  	n, err := m.MarshalTo(dAtA)
   474  	if err != nil {
   475  		return nil, err
   476  	}
   477  	return dAtA[:n], nil
   478  }
   479  
   480  func (m *JobProgress) MarshalTo(dAtA []byte) (int, error) {
   481  	var i int
   482  	_ = i
   483  	var l int
   484  	_ = l
   485  	dAtA[i] = 0x8
   486  	i++
   487  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.JobID))
   488  	dAtA[i] = 0x15
   489  	i++
   490  	encoding_binary.LittleEndian.PutUint32(dAtA[i:], uint32(math.Float32bits(float32(m.Contribution))))
   491  	i += 4
   492  	dAtA[i] = 0x18
   493  	i++
   494  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Slot))
   495  	return i, nil
   496  }
   497  
   498  func (m *ReadImportDataSpec) Marshal() (dAtA []byte, err error) {
   499  	size := m.Size()
   500  	dAtA = make([]byte, size)
   501  	n, err := m.MarshalTo(dAtA)
   502  	if err != nil {
   503  		return nil, err
   504  	}
   505  	return dAtA[:n], nil
   506  }
   507  
   508  func (m *ReadImportDataSpec) MarshalTo(dAtA []byte) (int, error) {
   509  	var i int
   510  	_ = i
   511  	var l int
   512  	_ = l
   513  	dAtA[i] = 0x10
   514  	i++
   515  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.SampleSize))
   516  	dAtA[i] = 0x32
   517  	i++
   518  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Progress.Size()))
   519  	n3, err := m.Progress.MarshalTo(dAtA[i:])
   520  	if err != nil {
   521  		return 0, err
   522  	}
   523  	i += n3
   524  	if len(m.Uri) > 0 {
   525  		keysForUri := make([]int32, 0, len(m.Uri))
   526  		for k := range m.Uri {
   527  			keysForUri = append(keysForUri, int32(k))
   528  		}
   529  		github_com_gogo_protobuf_sortkeys.Int32s(keysForUri)
   530  		for _, k := range keysForUri {
   531  			dAtA[i] = 0x3a
   532  			i++
   533  			v := m.Uri[int32(k)]
   534  			mapSize := 1 + sovProcessorsBulkIo(uint64(k)) + 1 + len(v) + sovProcessorsBulkIo(uint64(len(v)))
   535  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(mapSize))
   536  			dAtA[i] = 0x8
   537  			i++
   538  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(k))
   539  			dAtA[i] = 0x12
   540  			i++
   541  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(len(v)))
   542  			i += copy(dAtA[i:], v)
   543  		}
   544  	}
   545  	dAtA[i] = 0x42
   546  	i++
   547  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Format.Size()))
   548  	n4, err := m.Format.MarshalTo(dAtA[i:])
   549  	if err != nil {
   550  		return 0, err
   551  	}
   552  	i += n4
   553  	if len(m.Tables) > 0 {
   554  		keysForTables := make([]string, 0, len(m.Tables))
   555  		for k := range m.Tables {
   556  			keysForTables = append(keysForTables, string(k))
   557  		}
   558  		github_com_gogo_protobuf_sortkeys.Strings(keysForTables)
   559  		for _, k := range keysForTables {
   560  			dAtA[i] = 0x4a
   561  			i++
   562  			v := m.Tables[string(k)]
   563  			msgSize := 0
   564  			if v != nil {
   565  				msgSize = v.Size()
   566  				msgSize += 1 + sovProcessorsBulkIo(uint64(msgSize))
   567  			}
   568  			mapSize := 1 + len(k) + sovProcessorsBulkIo(uint64(len(k))) + msgSize
   569  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(mapSize))
   570  			dAtA[i] = 0xa
   571  			i++
   572  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(len(k)))
   573  			i += copy(dAtA[i:], k)
   574  			if v != nil {
   575  				dAtA[i] = 0x12
   576  				i++
   577  				i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(v.Size()))
   578  				n5, err := v.MarshalTo(dAtA[i:])
   579  				if err != nil {
   580  					return 0, err
   581  				}
   582  				i += n5
   583  			}
   584  		}
   585  	}
   586  	dAtA[i] = 0x50
   587  	i++
   588  	if m.SkipMissingForeignKeys {
   589  		dAtA[i] = 1
   590  	} else {
   591  		dAtA[i] = 0
   592  	}
   593  	i++
   594  	dAtA[i] = 0x58
   595  	i++
   596  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.WalltimeNanos))
   597  	dAtA[i] = 0x68
   598  	i++
   599  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.ReaderParallelism))
   600  	if len(m.ResumePos) > 0 {
   601  		keysForResumePos := make([]int32, 0, len(m.ResumePos))
   602  		for k := range m.ResumePos {
   603  			keysForResumePos = append(keysForResumePos, int32(k))
   604  		}
   605  		github_com_gogo_protobuf_sortkeys.Int32s(keysForResumePos)
   606  		for _, k := range keysForResumePos {
   607  			dAtA[i] = 0x72
   608  			i++
   609  			v := m.ResumePos[int32(k)]
   610  			mapSize := 1 + sovProcessorsBulkIo(uint64(k)) + 1 + sovProcessorsBulkIo(uint64(v))
   611  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(mapSize))
   612  			dAtA[i] = 0x8
   613  			i++
   614  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(k))
   615  			dAtA[i] = 0x10
   616  			i++
   617  			i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(v))
   618  		}
   619  	}
   620  	return i, nil
   621  }
   622  
   623  func (m *ReadImportDataSpec_ImportTable) Marshal() (dAtA []byte, err error) {
   624  	size := m.Size()
   625  	dAtA = make([]byte, size)
   626  	n, err := m.MarshalTo(dAtA)
   627  	if err != nil {
   628  		return nil, err
   629  	}
   630  	return dAtA[:n], nil
   631  }
   632  
   633  func (m *ReadImportDataSpec_ImportTable) MarshalTo(dAtA []byte) (int, error) {
   634  	var i int
   635  	_ = i
   636  	var l int
   637  	_ = l
   638  	if m.Desc != nil {
   639  		dAtA[i] = 0xa
   640  		i++
   641  		i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Desc.Size()))
   642  		n6, err := m.Desc.MarshalTo(dAtA[i:])
   643  		if err != nil {
   644  			return 0, err
   645  		}
   646  		i += n6
   647  	}
   648  	if len(m.TargetCols) > 0 {
   649  		for _, s := range m.TargetCols {
   650  			dAtA[i] = 0x12
   651  			i++
   652  			l = len(s)
   653  			for l >= 1<<7 {
   654  				dAtA[i] = uint8(uint64(l)&0x7f | 0x80)
   655  				l >>= 7
   656  				i++
   657  			}
   658  			dAtA[i] = uint8(l)
   659  			i++
   660  			i += copy(dAtA[i:], s)
   661  		}
   662  	}
   663  	return i, nil
   664  }
   665  
   666  func (m *CSVWriterSpec) Marshal() (dAtA []byte, err error) {
   667  	size := m.Size()
   668  	dAtA = make([]byte, size)
   669  	n, err := m.MarshalTo(dAtA)
   670  	if err != nil {
   671  		return nil, err
   672  	}
   673  	return dAtA[:n], nil
   674  }
   675  
   676  func (m *CSVWriterSpec) MarshalTo(dAtA []byte) (int, error) {
   677  	var i int
   678  	_ = i
   679  	var l int
   680  	_ = l
   681  	dAtA[i] = 0xa
   682  	i++
   683  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(len(m.Destination)))
   684  	i += copy(dAtA[i:], m.Destination)
   685  	dAtA[i] = 0x12
   686  	i++
   687  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(len(m.NamePattern)))
   688  	i += copy(dAtA[i:], m.NamePattern)
   689  	dAtA[i] = 0x1a
   690  	i++
   691  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Options.Size()))
   692  	n7, err := m.Options.MarshalTo(dAtA[i:])
   693  	if err != nil {
   694  		return 0, err
   695  	}
   696  	i += n7
   697  	dAtA[i] = 0x20
   698  	i++
   699  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.ChunkRows))
   700  	dAtA[i] = 0x28
   701  	i++
   702  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.CompressionCodec))
   703  	return i, nil
   704  }
   705  
   706  func (m *BulkRowWriterSpec) Marshal() (dAtA []byte, err error) {
   707  	size := m.Size()
   708  	dAtA = make([]byte, size)
   709  	n, err := m.MarshalTo(dAtA)
   710  	if err != nil {
   711  		return nil, err
   712  	}
   713  	return dAtA[:n], nil
   714  }
   715  
   716  func (m *BulkRowWriterSpec) MarshalTo(dAtA []byte) (int, error) {
   717  	var i int
   718  	_ = i
   719  	var l int
   720  	_ = l
   721  	dAtA[i] = 0xa
   722  	i++
   723  	i = encodeVarintProcessorsBulkIo(dAtA, i, uint64(m.Table.Size()))
   724  	n8, err := m.Table.MarshalTo(dAtA[i:])
   725  	if err != nil {
   726  		return 0, err
   727  	}
   728  	i += n8
   729  	return i, nil
   730  }
   731  
   732  func encodeVarintProcessorsBulkIo(dAtA []byte, offset int, v uint64) int {
   733  	for v >= 1<<7 {
   734  		dAtA[offset] = uint8(v&0x7f | 0x80)
   735  		v >>= 7
   736  		offset++
   737  	}
   738  	dAtA[offset] = uint8(v)
   739  	return offset + 1
   740  }
   741  func (m *BackfillerSpec) Size() (n int) {
   742  	if m == nil {
   743  		return 0
   744  	}
   745  	var l int
   746  	_ = l
   747  	n += 1 + sovProcessorsBulkIo(uint64(m.Type))
   748  	l = m.Table.Size()
   749  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   750  	if len(m.Spans) > 0 {
   751  		for _, e := range m.Spans {
   752  			l = e.Size()
   753  			n += 1 + l + sovProcessorsBulkIo(uint64(l))
   754  		}
   755  	}
   756  	n += 1 + sovProcessorsBulkIo(uint64(m.Duration))
   757  	n += 1 + sovProcessorsBulkIo(uint64(m.ChunkSize))
   758  	if len(m.OtherTables) > 0 {
   759  		for _, e := range m.OtherTables {
   760  			l = e.Size()
   761  			n += 1 + l + sovProcessorsBulkIo(uint64(l))
   762  		}
   763  	}
   764  	l = m.ReadAsOf.Size()
   765  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   766  	return n
   767  }
   768  
   769  func (m *JobProgress) Size() (n int) {
   770  	if m == nil {
   771  		return 0
   772  	}
   773  	var l int
   774  	_ = l
   775  	n += 1 + sovProcessorsBulkIo(uint64(m.JobID))
   776  	n += 5
   777  	n += 1 + sovProcessorsBulkIo(uint64(m.Slot))
   778  	return n
   779  }
   780  
   781  func (m *ReadImportDataSpec) Size() (n int) {
   782  	if m == nil {
   783  		return 0
   784  	}
   785  	var l int
   786  	_ = l
   787  	n += 1 + sovProcessorsBulkIo(uint64(m.SampleSize))
   788  	l = m.Progress.Size()
   789  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   790  	if len(m.Uri) > 0 {
   791  		for k, v := range m.Uri {
   792  			_ = k
   793  			_ = v
   794  			mapEntrySize := 1 + sovProcessorsBulkIo(uint64(k)) + 1 + len(v) + sovProcessorsBulkIo(uint64(len(v)))
   795  			n += mapEntrySize + 1 + sovProcessorsBulkIo(uint64(mapEntrySize))
   796  		}
   797  	}
   798  	l = m.Format.Size()
   799  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   800  	if len(m.Tables) > 0 {
   801  		for k, v := range m.Tables {
   802  			_ = k
   803  			_ = v
   804  			l = 0
   805  			if v != nil {
   806  				l = v.Size()
   807  				l += 1 + sovProcessorsBulkIo(uint64(l))
   808  			}
   809  			mapEntrySize := 1 + len(k) + sovProcessorsBulkIo(uint64(len(k))) + l
   810  			n += mapEntrySize + 1 + sovProcessorsBulkIo(uint64(mapEntrySize))
   811  		}
   812  	}
   813  	n += 2
   814  	n += 1 + sovProcessorsBulkIo(uint64(m.WalltimeNanos))
   815  	n += 1 + sovProcessorsBulkIo(uint64(m.ReaderParallelism))
   816  	if len(m.ResumePos) > 0 {
   817  		for k, v := range m.ResumePos {
   818  			_ = k
   819  			_ = v
   820  			mapEntrySize := 1 + sovProcessorsBulkIo(uint64(k)) + 1 + sovProcessorsBulkIo(uint64(v))
   821  			n += mapEntrySize + 1 + sovProcessorsBulkIo(uint64(mapEntrySize))
   822  		}
   823  	}
   824  	return n
   825  }
   826  
   827  func (m *ReadImportDataSpec_ImportTable) Size() (n int) {
   828  	if m == nil {
   829  		return 0
   830  	}
   831  	var l int
   832  	_ = l
   833  	if m.Desc != nil {
   834  		l = m.Desc.Size()
   835  		n += 1 + l + sovProcessorsBulkIo(uint64(l))
   836  	}
   837  	if len(m.TargetCols) > 0 {
   838  		for _, s := range m.TargetCols {
   839  			l = len(s)
   840  			n += 1 + l + sovProcessorsBulkIo(uint64(l))
   841  		}
   842  	}
   843  	return n
   844  }
   845  
   846  func (m *CSVWriterSpec) Size() (n int) {
   847  	if m == nil {
   848  		return 0
   849  	}
   850  	var l int
   851  	_ = l
   852  	l = len(m.Destination)
   853  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   854  	l = len(m.NamePattern)
   855  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   856  	l = m.Options.Size()
   857  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   858  	n += 1 + sovProcessorsBulkIo(uint64(m.ChunkRows))
   859  	n += 1 + sovProcessorsBulkIo(uint64(m.CompressionCodec))
   860  	return n
   861  }
   862  
   863  func (m *BulkRowWriterSpec) Size() (n int) {
   864  	if m == nil {
   865  		return 0
   866  	}
   867  	var l int
   868  	_ = l
   869  	l = m.Table.Size()
   870  	n += 1 + l + sovProcessorsBulkIo(uint64(l))
   871  	return n
   872  }
   873  
   874  func sovProcessorsBulkIo(x uint64) (n int) {
   875  	for {
   876  		n++
   877  		x >>= 7
   878  		if x == 0 {
   879  			break
   880  		}
   881  	}
   882  	return n
   883  }
   884  func sozProcessorsBulkIo(x uint64) (n int) {
   885  	return sovProcessorsBulkIo(uint64((x << 1) ^ uint64((int64(x) >> 63))))
   886  }
   887  func (m *BackfillerSpec) Unmarshal(dAtA []byte) error {
   888  	l := len(dAtA)
   889  	iNdEx := 0
   890  	for iNdEx < l {
   891  		preIndex := iNdEx
   892  		var wire uint64
   893  		for shift := uint(0); ; shift += 7 {
   894  			if shift >= 64 {
   895  				return ErrIntOverflowProcessorsBulkIo
   896  			}
   897  			if iNdEx >= l {
   898  				return io.ErrUnexpectedEOF
   899  			}
   900  			b := dAtA[iNdEx]
   901  			iNdEx++
   902  			wire |= (uint64(b) & 0x7F) << shift
   903  			if b < 0x80 {
   904  				break
   905  			}
   906  		}
   907  		fieldNum := int32(wire >> 3)
   908  		wireType := int(wire & 0x7)
   909  		if wireType == 4 {
   910  			return fmt.Errorf("proto: BackfillerSpec: wiretype end group for non-group")
   911  		}
   912  		if fieldNum <= 0 {
   913  			return fmt.Errorf("proto: BackfillerSpec: illegal tag %d (wire type %d)", fieldNum, wire)
   914  		}
   915  		switch fieldNum {
   916  		case 1:
   917  			if wireType != 0 {
   918  				return fmt.Errorf("proto: wrong wireType = %d for field Type", wireType)
   919  			}
   920  			m.Type = 0
   921  			for shift := uint(0); ; shift += 7 {
   922  				if shift >= 64 {
   923  					return ErrIntOverflowProcessorsBulkIo
   924  				}
   925  				if iNdEx >= l {
   926  					return io.ErrUnexpectedEOF
   927  				}
   928  				b := dAtA[iNdEx]
   929  				iNdEx++
   930  				m.Type |= (BackfillerSpec_Type(b) & 0x7F) << shift
   931  				if b < 0x80 {
   932  					break
   933  				}
   934  			}
   935  		case 2:
   936  			if wireType != 2 {
   937  				return fmt.Errorf("proto: wrong wireType = %d for field Table", wireType)
   938  			}
   939  			var msglen int
   940  			for shift := uint(0); ; shift += 7 {
   941  				if shift >= 64 {
   942  					return ErrIntOverflowProcessorsBulkIo
   943  				}
   944  				if iNdEx >= l {
   945  					return io.ErrUnexpectedEOF
   946  				}
   947  				b := dAtA[iNdEx]
   948  				iNdEx++
   949  				msglen |= (int(b) & 0x7F) << shift
   950  				if b < 0x80 {
   951  					break
   952  				}
   953  			}
   954  			if msglen < 0 {
   955  				return ErrInvalidLengthProcessorsBulkIo
   956  			}
   957  			postIndex := iNdEx + msglen
   958  			if postIndex > l {
   959  				return io.ErrUnexpectedEOF
   960  			}
   961  			if err := m.Table.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
   962  				return err
   963  			}
   964  			iNdEx = postIndex
   965  		case 3:
   966  			if wireType != 2 {
   967  				return fmt.Errorf("proto: wrong wireType = %d for field Spans", wireType)
   968  			}
   969  			var msglen int
   970  			for shift := uint(0); ; shift += 7 {
   971  				if shift >= 64 {
   972  					return ErrIntOverflowProcessorsBulkIo
   973  				}
   974  				if iNdEx >= l {
   975  					return io.ErrUnexpectedEOF
   976  				}
   977  				b := dAtA[iNdEx]
   978  				iNdEx++
   979  				msglen |= (int(b) & 0x7F) << shift
   980  				if b < 0x80 {
   981  					break
   982  				}
   983  			}
   984  			if msglen < 0 {
   985  				return ErrInvalidLengthProcessorsBulkIo
   986  			}
   987  			postIndex := iNdEx + msglen
   988  			if postIndex > l {
   989  				return io.ErrUnexpectedEOF
   990  			}
   991  			m.Spans = append(m.Spans, TableReaderSpan{})
   992  			if err := m.Spans[len(m.Spans)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
   993  				return err
   994  			}
   995  			iNdEx = postIndex
   996  		case 4:
   997  			if wireType != 0 {
   998  				return fmt.Errorf("proto: wrong wireType = %d for field Duration", wireType)
   999  			}
  1000  			m.Duration = 0
  1001  			for shift := uint(0); ; shift += 7 {
  1002  				if shift >= 64 {
  1003  					return ErrIntOverflowProcessorsBulkIo
  1004  				}
  1005  				if iNdEx >= l {
  1006  					return io.ErrUnexpectedEOF
  1007  				}
  1008  				b := dAtA[iNdEx]
  1009  				iNdEx++
  1010  				m.Duration |= (time.Duration(b) & 0x7F) << shift
  1011  				if b < 0x80 {
  1012  					break
  1013  				}
  1014  			}
  1015  		case 5:
  1016  			if wireType != 0 {
  1017  				return fmt.Errorf("proto: wrong wireType = %d for field ChunkSize", wireType)
  1018  			}
  1019  			m.ChunkSize = 0
  1020  			for shift := uint(0); ; shift += 7 {
  1021  				if shift >= 64 {
  1022  					return ErrIntOverflowProcessorsBulkIo
  1023  				}
  1024  				if iNdEx >= l {
  1025  					return io.ErrUnexpectedEOF
  1026  				}
  1027  				b := dAtA[iNdEx]
  1028  				iNdEx++
  1029  				m.ChunkSize |= (int64(b) & 0x7F) << shift
  1030  				if b < 0x80 {
  1031  					break
  1032  				}
  1033  			}
  1034  		case 6:
  1035  			if wireType != 2 {
  1036  				return fmt.Errorf("proto: wrong wireType = %d for field OtherTables", wireType)
  1037  			}
  1038  			var msglen int
  1039  			for shift := uint(0); ; shift += 7 {
  1040  				if shift >= 64 {
  1041  					return ErrIntOverflowProcessorsBulkIo
  1042  				}
  1043  				if iNdEx >= l {
  1044  					return io.ErrUnexpectedEOF
  1045  				}
  1046  				b := dAtA[iNdEx]
  1047  				iNdEx++
  1048  				msglen |= (int(b) & 0x7F) << shift
  1049  				if b < 0x80 {
  1050  					break
  1051  				}
  1052  			}
  1053  			if msglen < 0 {
  1054  				return ErrInvalidLengthProcessorsBulkIo
  1055  			}
  1056  			postIndex := iNdEx + msglen
  1057  			if postIndex > l {
  1058  				return io.ErrUnexpectedEOF
  1059  			}
  1060  			m.OtherTables = append(m.OtherTables, sqlbase.TableDescriptor{})
  1061  			if err := m.OtherTables[len(m.OtherTables)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1062  				return err
  1063  			}
  1064  			iNdEx = postIndex
  1065  		case 7:
  1066  			if wireType != 2 {
  1067  				return fmt.Errorf("proto: wrong wireType = %d for field ReadAsOf", wireType)
  1068  			}
  1069  			var msglen int
  1070  			for shift := uint(0); ; shift += 7 {
  1071  				if shift >= 64 {
  1072  					return ErrIntOverflowProcessorsBulkIo
  1073  				}
  1074  				if iNdEx >= l {
  1075  					return io.ErrUnexpectedEOF
  1076  				}
  1077  				b := dAtA[iNdEx]
  1078  				iNdEx++
  1079  				msglen |= (int(b) & 0x7F) << shift
  1080  				if b < 0x80 {
  1081  					break
  1082  				}
  1083  			}
  1084  			if msglen < 0 {
  1085  				return ErrInvalidLengthProcessorsBulkIo
  1086  			}
  1087  			postIndex := iNdEx + msglen
  1088  			if postIndex > l {
  1089  				return io.ErrUnexpectedEOF
  1090  			}
  1091  			if err := m.ReadAsOf.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1092  				return err
  1093  			}
  1094  			iNdEx = postIndex
  1095  		default:
  1096  			iNdEx = preIndex
  1097  			skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1098  			if err != nil {
  1099  				return err
  1100  			}
  1101  			if skippy < 0 {
  1102  				return ErrInvalidLengthProcessorsBulkIo
  1103  			}
  1104  			if (iNdEx + skippy) > l {
  1105  				return io.ErrUnexpectedEOF
  1106  			}
  1107  			iNdEx += skippy
  1108  		}
  1109  	}
  1110  
  1111  	if iNdEx > l {
  1112  		return io.ErrUnexpectedEOF
  1113  	}
  1114  	return nil
  1115  }
  1116  func (m *JobProgress) Unmarshal(dAtA []byte) error {
  1117  	l := len(dAtA)
  1118  	iNdEx := 0
  1119  	for iNdEx < l {
  1120  		preIndex := iNdEx
  1121  		var wire uint64
  1122  		for shift := uint(0); ; shift += 7 {
  1123  			if shift >= 64 {
  1124  				return ErrIntOverflowProcessorsBulkIo
  1125  			}
  1126  			if iNdEx >= l {
  1127  				return io.ErrUnexpectedEOF
  1128  			}
  1129  			b := dAtA[iNdEx]
  1130  			iNdEx++
  1131  			wire |= (uint64(b) & 0x7F) << shift
  1132  			if b < 0x80 {
  1133  				break
  1134  			}
  1135  		}
  1136  		fieldNum := int32(wire >> 3)
  1137  		wireType := int(wire & 0x7)
  1138  		if wireType == 4 {
  1139  			return fmt.Errorf("proto: JobProgress: wiretype end group for non-group")
  1140  		}
  1141  		if fieldNum <= 0 {
  1142  			return fmt.Errorf("proto: JobProgress: illegal tag %d (wire type %d)", fieldNum, wire)
  1143  		}
  1144  		switch fieldNum {
  1145  		case 1:
  1146  			if wireType != 0 {
  1147  				return fmt.Errorf("proto: wrong wireType = %d for field JobID", wireType)
  1148  			}
  1149  			m.JobID = 0
  1150  			for shift := uint(0); ; shift += 7 {
  1151  				if shift >= 64 {
  1152  					return ErrIntOverflowProcessorsBulkIo
  1153  				}
  1154  				if iNdEx >= l {
  1155  					return io.ErrUnexpectedEOF
  1156  				}
  1157  				b := dAtA[iNdEx]
  1158  				iNdEx++
  1159  				m.JobID |= (int64(b) & 0x7F) << shift
  1160  				if b < 0x80 {
  1161  					break
  1162  				}
  1163  			}
  1164  		case 2:
  1165  			if wireType != 5 {
  1166  				return fmt.Errorf("proto: wrong wireType = %d for field Contribution", wireType)
  1167  			}
  1168  			var v uint32
  1169  			if (iNdEx + 4) > l {
  1170  				return io.ErrUnexpectedEOF
  1171  			}
  1172  			v = uint32(encoding_binary.LittleEndian.Uint32(dAtA[iNdEx:]))
  1173  			iNdEx += 4
  1174  			m.Contribution = float32(math.Float32frombits(v))
  1175  		case 3:
  1176  			if wireType != 0 {
  1177  				return fmt.Errorf("proto: wrong wireType = %d for field Slot", wireType)
  1178  			}
  1179  			m.Slot = 0
  1180  			for shift := uint(0); ; shift += 7 {
  1181  				if shift >= 64 {
  1182  					return ErrIntOverflowProcessorsBulkIo
  1183  				}
  1184  				if iNdEx >= l {
  1185  					return io.ErrUnexpectedEOF
  1186  				}
  1187  				b := dAtA[iNdEx]
  1188  				iNdEx++
  1189  				m.Slot |= (int32(b) & 0x7F) << shift
  1190  				if b < 0x80 {
  1191  					break
  1192  				}
  1193  			}
  1194  		default:
  1195  			iNdEx = preIndex
  1196  			skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1197  			if err != nil {
  1198  				return err
  1199  			}
  1200  			if skippy < 0 {
  1201  				return ErrInvalidLengthProcessorsBulkIo
  1202  			}
  1203  			if (iNdEx + skippy) > l {
  1204  				return io.ErrUnexpectedEOF
  1205  			}
  1206  			iNdEx += skippy
  1207  		}
  1208  	}
  1209  
  1210  	if iNdEx > l {
  1211  		return io.ErrUnexpectedEOF
  1212  	}
  1213  	return nil
  1214  }
  1215  func (m *ReadImportDataSpec) Unmarshal(dAtA []byte) error {
  1216  	l := len(dAtA)
  1217  	iNdEx := 0
  1218  	for iNdEx < l {
  1219  		preIndex := iNdEx
  1220  		var wire uint64
  1221  		for shift := uint(0); ; shift += 7 {
  1222  			if shift >= 64 {
  1223  				return ErrIntOverflowProcessorsBulkIo
  1224  			}
  1225  			if iNdEx >= l {
  1226  				return io.ErrUnexpectedEOF
  1227  			}
  1228  			b := dAtA[iNdEx]
  1229  			iNdEx++
  1230  			wire |= (uint64(b) & 0x7F) << shift
  1231  			if b < 0x80 {
  1232  				break
  1233  			}
  1234  		}
  1235  		fieldNum := int32(wire >> 3)
  1236  		wireType := int(wire & 0x7)
  1237  		if wireType == 4 {
  1238  			return fmt.Errorf("proto: ReadImportDataSpec: wiretype end group for non-group")
  1239  		}
  1240  		if fieldNum <= 0 {
  1241  			return fmt.Errorf("proto: ReadImportDataSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  1242  		}
  1243  		switch fieldNum {
  1244  		case 2:
  1245  			if wireType != 0 {
  1246  				return fmt.Errorf("proto: wrong wireType = %d for field SampleSize", wireType)
  1247  			}
  1248  			m.SampleSize = 0
  1249  			for shift := uint(0); ; shift += 7 {
  1250  				if shift >= 64 {
  1251  					return ErrIntOverflowProcessorsBulkIo
  1252  				}
  1253  				if iNdEx >= l {
  1254  					return io.ErrUnexpectedEOF
  1255  				}
  1256  				b := dAtA[iNdEx]
  1257  				iNdEx++
  1258  				m.SampleSize |= (int32(b) & 0x7F) << shift
  1259  				if b < 0x80 {
  1260  					break
  1261  				}
  1262  			}
  1263  		case 6:
  1264  			if wireType != 2 {
  1265  				return fmt.Errorf("proto: wrong wireType = %d for field Progress", wireType)
  1266  			}
  1267  			var msglen int
  1268  			for shift := uint(0); ; shift += 7 {
  1269  				if shift >= 64 {
  1270  					return ErrIntOverflowProcessorsBulkIo
  1271  				}
  1272  				if iNdEx >= l {
  1273  					return io.ErrUnexpectedEOF
  1274  				}
  1275  				b := dAtA[iNdEx]
  1276  				iNdEx++
  1277  				msglen |= (int(b) & 0x7F) << shift
  1278  				if b < 0x80 {
  1279  					break
  1280  				}
  1281  			}
  1282  			if msglen < 0 {
  1283  				return ErrInvalidLengthProcessorsBulkIo
  1284  			}
  1285  			postIndex := iNdEx + msglen
  1286  			if postIndex > l {
  1287  				return io.ErrUnexpectedEOF
  1288  			}
  1289  			if err := m.Progress.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1290  				return err
  1291  			}
  1292  			iNdEx = postIndex
  1293  		case 7:
  1294  			if wireType != 2 {
  1295  				return fmt.Errorf("proto: wrong wireType = %d for field Uri", wireType)
  1296  			}
  1297  			var msglen int
  1298  			for shift := uint(0); ; shift += 7 {
  1299  				if shift >= 64 {
  1300  					return ErrIntOverflowProcessorsBulkIo
  1301  				}
  1302  				if iNdEx >= l {
  1303  					return io.ErrUnexpectedEOF
  1304  				}
  1305  				b := dAtA[iNdEx]
  1306  				iNdEx++
  1307  				msglen |= (int(b) & 0x7F) << shift
  1308  				if b < 0x80 {
  1309  					break
  1310  				}
  1311  			}
  1312  			if msglen < 0 {
  1313  				return ErrInvalidLengthProcessorsBulkIo
  1314  			}
  1315  			postIndex := iNdEx + msglen
  1316  			if postIndex > l {
  1317  				return io.ErrUnexpectedEOF
  1318  			}
  1319  			if m.Uri == nil {
  1320  				m.Uri = make(map[int32]string)
  1321  			}
  1322  			var mapkey int32
  1323  			var mapvalue string
  1324  			for iNdEx < postIndex {
  1325  				entryPreIndex := iNdEx
  1326  				var wire uint64
  1327  				for shift := uint(0); ; shift += 7 {
  1328  					if shift >= 64 {
  1329  						return ErrIntOverflowProcessorsBulkIo
  1330  					}
  1331  					if iNdEx >= l {
  1332  						return io.ErrUnexpectedEOF
  1333  					}
  1334  					b := dAtA[iNdEx]
  1335  					iNdEx++
  1336  					wire |= (uint64(b) & 0x7F) << shift
  1337  					if b < 0x80 {
  1338  						break
  1339  					}
  1340  				}
  1341  				fieldNum := int32(wire >> 3)
  1342  				if fieldNum == 1 {
  1343  					for shift := uint(0); ; shift += 7 {
  1344  						if shift >= 64 {
  1345  							return ErrIntOverflowProcessorsBulkIo
  1346  						}
  1347  						if iNdEx >= l {
  1348  							return io.ErrUnexpectedEOF
  1349  						}
  1350  						b := dAtA[iNdEx]
  1351  						iNdEx++
  1352  						mapkey |= (int32(b) & 0x7F) << shift
  1353  						if b < 0x80 {
  1354  							break
  1355  						}
  1356  					}
  1357  				} else if fieldNum == 2 {
  1358  					var stringLenmapvalue uint64
  1359  					for shift := uint(0); ; shift += 7 {
  1360  						if shift >= 64 {
  1361  							return ErrIntOverflowProcessorsBulkIo
  1362  						}
  1363  						if iNdEx >= l {
  1364  							return io.ErrUnexpectedEOF
  1365  						}
  1366  						b := dAtA[iNdEx]
  1367  						iNdEx++
  1368  						stringLenmapvalue |= (uint64(b) & 0x7F) << shift
  1369  						if b < 0x80 {
  1370  							break
  1371  						}
  1372  					}
  1373  					intStringLenmapvalue := int(stringLenmapvalue)
  1374  					if intStringLenmapvalue < 0 {
  1375  						return ErrInvalidLengthProcessorsBulkIo
  1376  					}
  1377  					postStringIndexmapvalue := iNdEx + intStringLenmapvalue
  1378  					if postStringIndexmapvalue > l {
  1379  						return io.ErrUnexpectedEOF
  1380  					}
  1381  					mapvalue = string(dAtA[iNdEx:postStringIndexmapvalue])
  1382  					iNdEx = postStringIndexmapvalue
  1383  				} else {
  1384  					iNdEx = entryPreIndex
  1385  					skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1386  					if err != nil {
  1387  						return err
  1388  					}
  1389  					if skippy < 0 {
  1390  						return ErrInvalidLengthProcessorsBulkIo
  1391  					}
  1392  					if (iNdEx + skippy) > postIndex {
  1393  						return io.ErrUnexpectedEOF
  1394  					}
  1395  					iNdEx += skippy
  1396  				}
  1397  			}
  1398  			m.Uri[mapkey] = mapvalue
  1399  			iNdEx = postIndex
  1400  		case 8:
  1401  			if wireType != 2 {
  1402  				return fmt.Errorf("proto: wrong wireType = %d for field Format", wireType)
  1403  			}
  1404  			var msglen int
  1405  			for shift := uint(0); ; shift += 7 {
  1406  				if shift >= 64 {
  1407  					return ErrIntOverflowProcessorsBulkIo
  1408  				}
  1409  				if iNdEx >= l {
  1410  					return io.ErrUnexpectedEOF
  1411  				}
  1412  				b := dAtA[iNdEx]
  1413  				iNdEx++
  1414  				msglen |= (int(b) & 0x7F) << shift
  1415  				if b < 0x80 {
  1416  					break
  1417  				}
  1418  			}
  1419  			if msglen < 0 {
  1420  				return ErrInvalidLengthProcessorsBulkIo
  1421  			}
  1422  			postIndex := iNdEx + msglen
  1423  			if postIndex > l {
  1424  				return io.ErrUnexpectedEOF
  1425  			}
  1426  			if err := m.Format.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1427  				return err
  1428  			}
  1429  			iNdEx = postIndex
  1430  		case 9:
  1431  			if wireType != 2 {
  1432  				return fmt.Errorf("proto: wrong wireType = %d for field Tables", wireType)
  1433  			}
  1434  			var msglen int
  1435  			for shift := uint(0); ; shift += 7 {
  1436  				if shift >= 64 {
  1437  					return ErrIntOverflowProcessorsBulkIo
  1438  				}
  1439  				if iNdEx >= l {
  1440  					return io.ErrUnexpectedEOF
  1441  				}
  1442  				b := dAtA[iNdEx]
  1443  				iNdEx++
  1444  				msglen |= (int(b) & 0x7F) << shift
  1445  				if b < 0x80 {
  1446  					break
  1447  				}
  1448  			}
  1449  			if msglen < 0 {
  1450  				return ErrInvalidLengthProcessorsBulkIo
  1451  			}
  1452  			postIndex := iNdEx + msglen
  1453  			if postIndex > l {
  1454  				return io.ErrUnexpectedEOF
  1455  			}
  1456  			if m.Tables == nil {
  1457  				m.Tables = make(map[string]*ReadImportDataSpec_ImportTable)
  1458  			}
  1459  			var mapkey string
  1460  			var mapvalue *ReadImportDataSpec_ImportTable
  1461  			for iNdEx < postIndex {
  1462  				entryPreIndex := iNdEx
  1463  				var wire uint64
  1464  				for shift := uint(0); ; shift += 7 {
  1465  					if shift >= 64 {
  1466  						return ErrIntOverflowProcessorsBulkIo
  1467  					}
  1468  					if iNdEx >= l {
  1469  						return io.ErrUnexpectedEOF
  1470  					}
  1471  					b := dAtA[iNdEx]
  1472  					iNdEx++
  1473  					wire |= (uint64(b) & 0x7F) << shift
  1474  					if b < 0x80 {
  1475  						break
  1476  					}
  1477  				}
  1478  				fieldNum := int32(wire >> 3)
  1479  				if fieldNum == 1 {
  1480  					var stringLenmapkey uint64
  1481  					for shift := uint(0); ; shift += 7 {
  1482  						if shift >= 64 {
  1483  							return ErrIntOverflowProcessorsBulkIo
  1484  						}
  1485  						if iNdEx >= l {
  1486  							return io.ErrUnexpectedEOF
  1487  						}
  1488  						b := dAtA[iNdEx]
  1489  						iNdEx++
  1490  						stringLenmapkey |= (uint64(b) & 0x7F) << shift
  1491  						if b < 0x80 {
  1492  							break
  1493  						}
  1494  					}
  1495  					intStringLenmapkey := int(stringLenmapkey)
  1496  					if intStringLenmapkey < 0 {
  1497  						return ErrInvalidLengthProcessorsBulkIo
  1498  					}
  1499  					postStringIndexmapkey := iNdEx + intStringLenmapkey
  1500  					if postStringIndexmapkey > l {
  1501  						return io.ErrUnexpectedEOF
  1502  					}
  1503  					mapkey = string(dAtA[iNdEx:postStringIndexmapkey])
  1504  					iNdEx = postStringIndexmapkey
  1505  				} else if fieldNum == 2 {
  1506  					var mapmsglen int
  1507  					for shift := uint(0); ; shift += 7 {
  1508  						if shift >= 64 {
  1509  							return ErrIntOverflowProcessorsBulkIo
  1510  						}
  1511  						if iNdEx >= l {
  1512  							return io.ErrUnexpectedEOF
  1513  						}
  1514  						b := dAtA[iNdEx]
  1515  						iNdEx++
  1516  						mapmsglen |= (int(b) & 0x7F) << shift
  1517  						if b < 0x80 {
  1518  							break
  1519  						}
  1520  					}
  1521  					if mapmsglen < 0 {
  1522  						return ErrInvalidLengthProcessorsBulkIo
  1523  					}
  1524  					postmsgIndex := iNdEx + mapmsglen
  1525  					if mapmsglen < 0 {
  1526  						return ErrInvalidLengthProcessorsBulkIo
  1527  					}
  1528  					if postmsgIndex > l {
  1529  						return io.ErrUnexpectedEOF
  1530  					}
  1531  					mapvalue = &ReadImportDataSpec_ImportTable{}
  1532  					if err := mapvalue.Unmarshal(dAtA[iNdEx:postmsgIndex]); err != nil {
  1533  						return err
  1534  					}
  1535  					iNdEx = postmsgIndex
  1536  				} else {
  1537  					iNdEx = entryPreIndex
  1538  					skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1539  					if err != nil {
  1540  						return err
  1541  					}
  1542  					if skippy < 0 {
  1543  						return ErrInvalidLengthProcessorsBulkIo
  1544  					}
  1545  					if (iNdEx + skippy) > postIndex {
  1546  						return io.ErrUnexpectedEOF
  1547  					}
  1548  					iNdEx += skippy
  1549  				}
  1550  			}
  1551  			m.Tables[mapkey] = mapvalue
  1552  			iNdEx = postIndex
  1553  		case 10:
  1554  			if wireType != 0 {
  1555  				return fmt.Errorf("proto: wrong wireType = %d for field SkipMissingForeignKeys", wireType)
  1556  			}
  1557  			var v int
  1558  			for shift := uint(0); ; shift += 7 {
  1559  				if shift >= 64 {
  1560  					return ErrIntOverflowProcessorsBulkIo
  1561  				}
  1562  				if iNdEx >= l {
  1563  					return io.ErrUnexpectedEOF
  1564  				}
  1565  				b := dAtA[iNdEx]
  1566  				iNdEx++
  1567  				v |= (int(b) & 0x7F) << shift
  1568  				if b < 0x80 {
  1569  					break
  1570  				}
  1571  			}
  1572  			m.SkipMissingForeignKeys = bool(v != 0)
  1573  		case 11:
  1574  			if wireType != 0 {
  1575  				return fmt.Errorf("proto: wrong wireType = %d for field WalltimeNanos", wireType)
  1576  			}
  1577  			m.WalltimeNanos = 0
  1578  			for shift := uint(0); ; shift += 7 {
  1579  				if shift >= 64 {
  1580  					return ErrIntOverflowProcessorsBulkIo
  1581  				}
  1582  				if iNdEx >= l {
  1583  					return io.ErrUnexpectedEOF
  1584  				}
  1585  				b := dAtA[iNdEx]
  1586  				iNdEx++
  1587  				m.WalltimeNanos |= (int64(b) & 0x7F) << shift
  1588  				if b < 0x80 {
  1589  					break
  1590  				}
  1591  			}
  1592  		case 13:
  1593  			if wireType != 0 {
  1594  				return fmt.Errorf("proto: wrong wireType = %d for field ReaderParallelism", wireType)
  1595  			}
  1596  			m.ReaderParallelism = 0
  1597  			for shift := uint(0); ; shift += 7 {
  1598  				if shift >= 64 {
  1599  					return ErrIntOverflowProcessorsBulkIo
  1600  				}
  1601  				if iNdEx >= l {
  1602  					return io.ErrUnexpectedEOF
  1603  				}
  1604  				b := dAtA[iNdEx]
  1605  				iNdEx++
  1606  				m.ReaderParallelism |= (int32(b) & 0x7F) << shift
  1607  				if b < 0x80 {
  1608  					break
  1609  				}
  1610  			}
  1611  		case 14:
  1612  			if wireType != 2 {
  1613  				return fmt.Errorf("proto: wrong wireType = %d for field ResumePos", wireType)
  1614  			}
  1615  			var msglen int
  1616  			for shift := uint(0); ; shift += 7 {
  1617  				if shift >= 64 {
  1618  					return ErrIntOverflowProcessorsBulkIo
  1619  				}
  1620  				if iNdEx >= l {
  1621  					return io.ErrUnexpectedEOF
  1622  				}
  1623  				b := dAtA[iNdEx]
  1624  				iNdEx++
  1625  				msglen |= (int(b) & 0x7F) << shift
  1626  				if b < 0x80 {
  1627  					break
  1628  				}
  1629  			}
  1630  			if msglen < 0 {
  1631  				return ErrInvalidLengthProcessorsBulkIo
  1632  			}
  1633  			postIndex := iNdEx + msglen
  1634  			if postIndex > l {
  1635  				return io.ErrUnexpectedEOF
  1636  			}
  1637  			if m.ResumePos == nil {
  1638  				m.ResumePos = make(map[int32]int64)
  1639  			}
  1640  			var mapkey int32
  1641  			var mapvalue int64
  1642  			for iNdEx < postIndex {
  1643  				entryPreIndex := iNdEx
  1644  				var wire uint64
  1645  				for shift := uint(0); ; shift += 7 {
  1646  					if shift >= 64 {
  1647  						return ErrIntOverflowProcessorsBulkIo
  1648  					}
  1649  					if iNdEx >= l {
  1650  						return io.ErrUnexpectedEOF
  1651  					}
  1652  					b := dAtA[iNdEx]
  1653  					iNdEx++
  1654  					wire |= (uint64(b) & 0x7F) << shift
  1655  					if b < 0x80 {
  1656  						break
  1657  					}
  1658  				}
  1659  				fieldNum := int32(wire >> 3)
  1660  				if fieldNum == 1 {
  1661  					for shift := uint(0); ; shift += 7 {
  1662  						if shift >= 64 {
  1663  							return ErrIntOverflowProcessorsBulkIo
  1664  						}
  1665  						if iNdEx >= l {
  1666  							return io.ErrUnexpectedEOF
  1667  						}
  1668  						b := dAtA[iNdEx]
  1669  						iNdEx++
  1670  						mapkey |= (int32(b) & 0x7F) << shift
  1671  						if b < 0x80 {
  1672  							break
  1673  						}
  1674  					}
  1675  				} else if fieldNum == 2 {
  1676  					for shift := uint(0); ; shift += 7 {
  1677  						if shift >= 64 {
  1678  							return ErrIntOverflowProcessorsBulkIo
  1679  						}
  1680  						if iNdEx >= l {
  1681  							return io.ErrUnexpectedEOF
  1682  						}
  1683  						b := dAtA[iNdEx]
  1684  						iNdEx++
  1685  						mapvalue |= (int64(b) & 0x7F) << shift
  1686  						if b < 0x80 {
  1687  							break
  1688  						}
  1689  					}
  1690  				} else {
  1691  					iNdEx = entryPreIndex
  1692  					skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1693  					if err != nil {
  1694  						return err
  1695  					}
  1696  					if skippy < 0 {
  1697  						return ErrInvalidLengthProcessorsBulkIo
  1698  					}
  1699  					if (iNdEx + skippy) > postIndex {
  1700  						return io.ErrUnexpectedEOF
  1701  					}
  1702  					iNdEx += skippy
  1703  				}
  1704  			}
  1705  			m.ResumePos[mapkey] = mapvalue
  1706  			iNdEx = postIndex
  1707  		default:
  1708  			iNdEx = preIndex
  1709  			skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1710  			if err != nil {
  1711  				return err
  1712  			}
  1713  			if skippy < 0 {
  1714  				return ErrInvalidLengthProcessorsBulkIo
  1715  			}
  1716  			if (iNdEx + skippy) > l {
  1717  				return io.ErrUnexpectedEOF
  1718  			}
  1719  			iNdEx += skippy
  1720  		}
  1721  	}
  1722  
  1723  	if iNdEx > l {
  1724  		return io.ErrUnexpectedEOF
  1725  	}
  1726  	return nil
  1727  }
  1728  func (m *ReadImportDataSpec_ImportTable) Unmarshal(dAtA []byte) error {
  1729  	l := len(dAtA)
  1730  	iNdEx := 0
  1731  	for iNdEx < l {
  1732  		preIndex := iNdEx
  1733  		var wire uint64
  1734  		for shift := uint(0); ; shift += 7 {
  1735  			if shift >= 64 {
  1736  				return ErrIntOverflowProcessorsBulkIo
  1737  			}
  1738  			if iNdEx >= l {
  1739  				return io.ErrUnexpectedEOF
  1740  			}
  1741  			b := dAtA[iNdEx]
  1742  			iNdEx++
  1743  			wire |= (uint64(b) & 0x7F) << shift
  1744  			if b < 0x80 {
  1745  				break
  1746  			}
  1747  		}
  1748  		fieldNum := int32(wire >> 3)
  1749  		wireType := int(wire & 0x7)
  1750  		if wireType == 4 {
  1751  			return fmt.Errorf("proto: ImportTable: wiretype end group for non-group")
  1752  		}
  1753  		if fieldNum <= 0 {
  1754  			return fmt.Errorf("proto: ImportTable: illegal tag %d (wire type %d)", fieldNum, wire)
  1755  		}
  1756  		switch fieldNum {
  1757  		case 1:
  1758  			if wireType != 2 {
  1759  				return fmt.Errorf("proto: wrong wireType = %d for field Desc", wireType)
  1760  			}
  1761  			var msglen int
  1762  			for shift := uint(0); ; shift += 7 {
  1763  				if shift >= 64 {
  1764  					return ErrIntOverflowProcessorsBulkIo
  1765  				}
  1766  				if iNdEx >= l {
  1767  					return io.ErrUnexpectedEOF
  1768  				}
  1769  				b := dAtA[iNdEx]
  1770  				iNdEx++
  1771  				msglen |= (int(b) & 0x7F) << shift
  1772  				if b < 0x80 {
  1773  					break
  1774  				}
  1775  			}
  1776  			if msglen < 0 {
  1777  				return ErrInvalidLengthProcessorsBulkIo
  1778  			}
  1779  			postIndex := iNdEx + msglen
  1780  			if postIndex > l {
  1781  				return io.ErrUnexpectedEOF
  1782  			}
  1783  			if m.Desc == nil {
  1784  				m.Desc = &sqlbase.TableDescriptor{}
  1785  			}
  1786  			if err := m.Desc.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1787  				return err
  1788  			}
  1789  			iNdEx = postIndex
  1790  		case 2:
  1791  			if wireType != 2 {
  1792  				return fmt.Errorf("proto: wrong wireType = %d for field TargetCols", wireType)
  1793  			}
  1794  			var stringLen uint64
  1795  			for shift := uint(0); ; shift += 7 {
  1796  				if shift >= 64 {
  1797  					return ErrIntOverflowProcessorsBulkIo
  1798  				}
  1799  				if iNdEx >= l {
  1800  					return io.ErrUnexpectedEOF
  1801  				}
  1802  				b := dAtA[iNdEx]
  1803  				iNdEx++
  1804  				stringLen |= (uint64(b) & 0x7F) << shift
  1805  				if b < 0x80 {
  1806  					break
  1807  				}
  1808  			}
  1809  			intStringLen := int(stringLen)
  1810  			if intStringLen < 0 {
  1811  				return ErrInvalidLengthProcessorsBulkIo
  1812  			}
  1813  			postIndex := iNdEx + intStringLen
  1814  			if postIndex > l {
  1815  				return io.ErrUnexpectedEOF
  1816  			}
  1817  			m.TargetCols = append(m.TargetCols, string(dAtA[iNdEx:postIndex]))
  1818  			iNdEx = postIndex
  1819  		default:
  1820  			iNdEx = preIndex
  1821  			skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1822  			if err != nil {
  1823  				return err
  1824  			}
  1825  			if skippy < 0 {
  1826  				return ErrInvalidLengthProcessorsBulkIo
  1827  			}
  1828  			if (iNdEx + skippy) > l {
  1829  				return io.ErrUnexpectedEOF
  1830  			}
  1831  			iNdEx += skippy
  1832  		}
  1833  	}
  1834  
  1835  	if iNdEx > l {
  1836  		return io.ErrUnexpectedEOF
  1837  	}
  1838  	return nil
  1839  }
  1840  func (m *CSVWriterSpec) Unmarshal(dAtA []byte) error {
  1841  	l := len(dAtA)
  1842  	iNdEx := 0
  1843  	for iNdEx < l {
  1844  		preIndex := iNdEx
  1845  		var wire uint64
  1846  		for shift := uint(0); ; shift += 7 {
  1847  			if shift >= 64 {
  1848  				return ErrIntOverflowProcessorsBulkIo
  1849  			}
  1850  			if iNdEx >= l {
  1851  				return io.ErrUnexpectedEOF
  1852  			}
  1853  			b := dAtA[iNdEx]
  1854  			iNdEx++
  1855  			wire |= (uint64(b) & 0x7F) << shift
  1856  			if b < 0x80 {
  1857  				break
  1858  			}
  1859  		}
  1860  		fieldNum := int32(wire >> 3)
  1861  		wireType := int(wire & 0x7)
  1862  		if wireType == 4 {
  1863  			return fmt.Errorf("proto: CSVWriterSpec: wiretype end group for non-group")
  1864  		}
  1865  		if fieldNum <= 0 {
  1866  			return fmt.Errorf("proto: CSVWriterSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  1867  		}
  1868  		switch fieldNum {
  1869  		case 1:
  1870  			if wireType != 2 {
  1871  				return fmt.Errorf("proto: wrong wireType = %d for field Destination", wireType)
  1872  			}
  1873  			var stringLen uint64
  1874  			for shift := uint(0); ; shift += 7 {
  1875  				if shift >= 64 {
  1876  					return ErrIntOverflowProcessorsBulkIo
  1877  				}
  1878  				if iNdEx >= l {
  1879  					return io.ErrUnexpectedEOF
  1880  				}
  1881  				b := dAtA[iNdEx]
  1882  				iNdEx++
  1883  				stringLen |= (uint64(b) & 0x7F) << shift
  1884  				if b < 0x80 {
  1885  					break
  1886  				}
  1887  			}
  1888  			intStringLen := int(stringLen)
  1889  			if intStringLen < 0 {
  1890  				return ErrInvalidLengthProcessorsBulkIo
  1891  			}
  1892  			postIndex := iNdEx + intStringLen
  1893  			if postIndex > l {
  1894  				return io.ErrUnexpectedEOF
  1895  			}
  1896  			m.Destination = string(dAtA[iNdEx:postIndex])
  1897  			iNdEx = postIndex
  1898  		case 2:
  1899  			if wireType != 2 {
  1900  				return fmt.Errorf("proto: wrong wireType = %d for field NamePattern", wireType)
  1901  			}
  1902  			var stringLen uint64
  1903  			for shift := uint(0); ; shift += 7 {
  1904  				if shift >= 64 {
  1905  					return ErrIntOverflowProcessorsBulkIo
  1906  				}
  1907  				if iNdEx >= l {
  1908  					return io.ErrUnexpectedEOF
  1909  				}
  1910  				b := dAtA[iNdEx]
  1911  				iNdEx++
  1912  				stringLen |= (uint64(b) & 0x7F) << shift
  1913  				if b < 0x80 {
  1914  					break
  1915  				}
  1916  			}
  1917  			intStringLen := int(stringLen)
  1918  			if intStringLen < 0 {
  1919  				return ErrInvalidLengthProcessorsBulkIo
  1920  			}
  1921  			postIndex := iNdEx + intStringLen
  1922  			if postIndex > l {
  1923  				return io.ErrUnexpectedEOF
  1924  			}
  1925  			m.NamePattern = string(dAtA[iNdEx:postIndex])
  1926  			iNdEx = postIndex
  1927  		case 3:
  1928  			if wireType != 2 {
  1929  				return fmt.Errorf("proto: wrong wireType = %d for field Options", wireType)
  1930  			}
  1931  			var msglen int
  1932  			for shift := uint(0); ; shift += 7 {
  1933  				if shift >= 64 {
  1934  					return ErrIntOverflowProcessorsBulkIo
  1935  				}
  1936  				if iNdEx >= l {
  1937  					return io.ErrUnexpectedEOF
  1938  				}
  1939  				b := dAtA[iNdEx]
  1940  				iNdEx++
  1941  				msglen |= (int(b) & 0x7F) << shift
  1942  				if b < 0x80 {
  1943  					break
  1944  				}
  1945  			}
  1946  			if msglen < 0 {
  1947  				return ErrInvalidLengthProcessorsBulkIo
  1948  			}
  1949  			postIndex := iNdEx + msglen
  1950  			if postIndex > l {
  1951  				return io.ErrUnexpectedEOF
  1952  			}
  1953  			if err := m.Options.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  1954  				return err
  1955  			}
  1956  			iNdEx = postIndex
  1957  		case 4:
  1958  			if wireType != 0 {
  1959  				return fmt.Errorf("proto: wrong wireType = %d for field ChunkRows", wireType)
  1960  			}
  1961  			m.ChunkRows = 0
  1962  			for shift := uint(0); ; shift += 7 {
  1963  				if shift >= 64 {
  1964  					return ErrIntOverflowProcessorsBulkIo
  1965  				}
  1966  				if iNdEx >= l {
  1967  					return io.ErrUnexpectedEOF
  1968  				}
  1969  				b := dAtA[iNdEx]
  1970  				iNdEx++
  1971  				m.ChunkRows |= (int64(b) & 0x7F) << shift
  1972  				if b < 0x80 {
  1973  					break
  1974  				}
  1975  			}
  1976  		case 5:
  1977  			if wireType != 0 {
  1978  				return fmt.Errorf("proto: wrong wireType = %d for field CompressionCodec", wireType)
  1979  			}
  1980  			m.CompressionCodec = 0
  1981  			for shift := uint(0); ; shift += 7 {
  1982  				if shift >= 64 {
  1983  					return ErrIntOverflowProcessorsBulkIo
  1984  				}
  1985  				if iNdEx >= l {
  1986  					return io.ErrUnexpectedEOF
  1987  				}
  1988  				b := dAtA[iNdEx]
  1989  				iNdEx++
  1990  				m.CompressionCodec |= (FileCompression(b) & 0x7F) << shift
  1991  				if b < 0x80 {
  1992  					break
  1993  				}
  1994  			}
  1995  		default:
  1996  			iNdEx = preIndex
  1997  			skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  1998  			if err != nil {
  1999  				return err
  2000  			}
  2001  			if skippy < 0 {
  2002  				return ErrInvalidLengthProcessorsBulkIo
  2003  			}
  2004  			if (iNdEx + skippy) > l {
  2005  				return io.ErrUnexpectedEOF
  2006  			}
  2007  			iNdEx += skippy
  2008  		}
  2009  	}
  2010  
  2011  	if iNdEx > l {
  2012  		return io.ErrUnexpectedEOF
  2013  	}
  2014  	return nil
  2015  }
  2016  func (m *BulkRowWriterSpec) Unmarshal(dAtA []byte) error {
  2017  	l := len(dAtA)
  2018  	iNdEx := 0
  2019  	for iNdEx < l {
  2020  		preIndex := iNdEx
  2021  		var wire uint64
  2022  		for shift := uint(0); ; shift += 7 {
  2023  			if shift >= 64 {
  2024  				return ErrIntOverflowProcessorsBulkIo
  2025  			}
  2026  			if iNdEx >= l {
  2027  				return io.ErrUnexpectedEOF
  2028  			}
  2029  			b := dAtA[iNdEx]
  2030  			iNdEx++
  2031  			wire |= (uint64(b) & 0x7F) << shift
  2032  			if b < 0x80 {
  2033  				break
  2034  			}
  2035  		}
  2036  		fieldNum := int32(wire >> 3)
  2037  		wireType := int(wire & 0x7)
  2038  		if wireType == 4 {
  2039  			return fmt.Errorf("proto: BulkRowWriterSpec: wiretype end group for non-group")
  2040  		}
  2041  		if fieldNum <= 0 {
  2042  			return fmt.Errorf("proto: BulkRowWriterSpec: illegal tag %d (wire type %d)", fieldNum, wire)
  2043  		}
  2044  		switch fieldNum {
  2045  		case 1:
  2046  			if wireType != 2 {
  2047  				return fmt.Errorf("proto: wrong wireType = %d for field Table", wireType)
  2048  			}
  2049  			var msglen int
  2050  			for shift := uint(0); ; shift += 7 {
  2051  				if shift >= 64 {
  2052  					return ErrIntOverflowProcessorsBulkIo
  2053  				}
  2054  				if iNdEx >= l {
  2055  					return io.ErrUnexpectedEOF
  2056  				}
  2057  				b := dAtA[iNdEx]
  2058  				iNdEx++
  2059  				msglen |= (int(b) & 0x7F) << shift
  2060  				if b < 0x80 {
  2061  					break
  2062  				}
  2063  			}
  2064  			if msglen < 0 {
  2065  				return ErrInvalidLengthProcessorsBulkIo
  2066  			}
  2067  			postIndex := iNdEx + msglen
  2068  			if postIndex > l {
  2069  				return io.ErrUnexpectedEOF
  2070  			}
  2071  			if err := m.Table.Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
  2072  				return err
  2073  			}
  2074  			iNdEx = postIndex
  2075  		default:
  2076  			iNdEx = preIndex
  2077  			skippy, err := skipProcessorsBulkIo(dAtA[iNdEx:])
  2078  			if err != nil {
  2079  				return err
  2080  			}
  2081  			if skippy < 0 {
  2082  				return ErrInvalidLengthProcessorsBulkIo
  2083  			}
  2084  			if (iNdEx + skippy) > l {
  2085  				return io.ErrUnexpectedEOF
  2086  			}
  2087  			iNdEx += skippy
  2088  		}
  2089  	}
  2090  
  2091  	if iNdEx > l {
  2092  		return io.ErrUnexpectedEOF
  2093  	}
  2094  	return nil
  2095  }
  2096  func skipProcessorsBulkIo(dAtA []byte) (n int, err error) {
  2097  	l := len(dAtA)
  2098  	iNdEx := 0
  2099  	for iNdEx < l {
  2100  		var wire uint64
  2101  		for shift := uint(0); ; shift += 7 {
  2102  			if shift >= 64 {
  2103  				return 0, ErrIntOverflowProcessorsBulkIo
  2104  			}
  2105  			if iNdEx >= l {
  2106  				return 0, io.ErrUnexpectedEOF
  2107  			}
  2108  			b := dAtA[iNdEx]
  2109  			iNdEx++
  2110  			wire |= (uint64(b) & 0x7F) << shift
  2111  			if b < 0x80 {
  2112  				break
  2113  			}
  2114  		}
  2115  		wireType := int(wire & 0x7)
  2116  		switch wireType {
  2117  		case 0:
  2118  			for shift := uint(0); ; shift += 7 {
  2119  				if shift >= 64 {
  2120  					return 0, ErrIntOverflowProcessorsBulkIo
  2121  				}
  2122  				if iNdEx >= l {
  2123  					return 0, io.ErrUnexpectedEOF
  2124  				}
  2125  				iNdEx++
  2126  				if dAtA[iNdEx-1] < 0x80 {
  2127  					break
  2128  				}
  2129  			}
  2130  			return iNdEx, nil
  2131  		case 1:
  2132  			iNdEx += 8
  2133  			return iNdEx, nil
  2134  		case 2:
  2135  			var length int
  2136  			for shift := uint(0); ; shift += 7 {
  2137  				if shift >= 64 {
  2138  					return 0, ErrIntOverflowProcessorsBulkIo
  2139  				}
  2140  				if iNdEx >= l {
  2141  					return 0, io.ErrUnexpectedEOF
  2142  				}
  2143  				b := dAtA[iNdEx]
  2144  				iNdEx++
  2145  				length |= (int(b) & 0x7F) << shift
  2146  				if b < 0x80 {
  2147  					break
  2148  				}
  2149  			}
  2150  			iNdEx += length
  2151  			if length < 0 {
  2152  				return 0, ErrInvalidLengthProcessorsBulkIo
  2153  			}
  2154  			return iNdEx, nil
  2155  		case 3:
  2156  			for {
  2157  				var innerWire uint64
  2158  				var start int = iNdEx
  2159  				for shift := uint(0); ; shift += 7 {
  2160  					if shift >= 64 {
  2161  						return 0, ErrIntOverflowProcessorsBulkIo
  2162  					}
  2163  					if iNdEx >= l {
  2164  						return 0, io.ErrUnexpectedEOF
  2165  					}
  2166  					b := dAtA[iNdEx]
  2167  					iNdEx++
  2168  					innerWire |= (uint64(b) & 0x7F) << shift
  2169  					if b < 0x80 {
  2170  						break
  2171  					}
  2172  				}
  2173  				innerWireType := int(innerWire & 0x7)
  2174  				if innerWireType == 4 {
  2175  					break
  2176  				}
  2177  				next, err := skipProcessorsBulkIo(dAtA[start:])
  2178  				if err != nil {
  2179  					return 0, err
  2180  				}
  2181  				iNdEx = start + next
  2182  			}
  2183  			return iNdEx, nil
  2184  		case 4:
  2185  			return iNdEx, nil
  2186  		case 5:
  2187  			iNdEx += 4
  2188  			return iNdEx, nil
  2189  		default:
  2190  			return 0, fmt.Errorf("proto: illegal wireType %d", wireType)
  2191  		}
  2192  	}
  2193  	panic("unreachable")
  2194  }
  2195  
  2196  var (
  2197  	ErrInvalidLengthProcessorsBulkIo = fmt.Errorf("proto: negative length found during unmarshaling")
  2198  	ErrIntOverflowProcessorsBulkIo   = fmt.Errorf("proto: integer overflow")
  2199  )
  2200  
  2201  func init() {
  2202  	proto.RegisterFile("sql/execinfrapb/processors_bulk_io.proto", fileDescriptor_processors_bulk_io_8cd4c8af43285ea2)
  2203  }
  2204  
  2205  var fileDescriptor_processors_bulk_io_8cd4c8af43285ea2 = []byte{
  2206  	// 1086 bytes of a gzipped FileDescriptorProto
  2207  	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x9c, 0x56, 0x6f, 0x6f, 0xd3, 0x46,
  2208  	0x18, 0x8f, 0x13, 0x27, 0x75, 0x9e, 0xb4, 0x9d, 0x39, 0x31, 0xe4, 0x55, 0x5b, 0x1a, 0x75, 0x94,
  2209  	0x65, 0x48, 0x38, 0x5a, 0xa5, 0x4d, 0x68, 0x1b, 0x62, 0x4b, 0x0b, 0x55, 0x33, 0x8d, 0x56, 0x2e,
  2210  	0x03, 0x09, 0x4d, 0x8a, 0xce, 0xf6, 0x35, 0x3d, 0x72, 0xf1, 0xb9, 0x77, 0x67, 0x4a, 0xf8, 0x14,
  2211  	0xfb, 0x0c, 0xfb, 0x34, 0xbc, 0xe4, 0x25, 0xaf, 0xd0, 0x68, 0xbf, 0x05, 0xaf, 0xa6, 0x3b, 0xdb,
  2212  	0xc5, 0x05, 0x95, 0xa9, 0x7b, 0xd3, 0xba, 0xf7, 0x3c, 0xbf, 0xdf, 0xfd, 0x9e, 0xbf, 0x57, 0xe8,
  2213  	0xcb, 0x23, 0x36, 0x20, 0xcf, 0x49, 0x44, 0x93, 0x03, 0x81, 0xd3, 0x70, 0x90, 0x0a, 0x1e, 0x11,
  2214  	0x29, 0xb9, 0x90, 0xe3, 0x30, 0x63, 0xd3, 0x31, 0xe5, 0x7e, 0x2a, 0xb8, 0xe2, 0xc8, 0x8b, 0x78,
  2215  	0x34, 0x15, 0x1c, 0x47, 0x87, 0xbe, 0x3c, 0x62, 0x7e, 0x4c, 0xa5, 0x92, 0x47, 0x4c, 0x64, 0xc9,
  2216  	0xca, 0xb5, 0xa7, 0x3c, 0x94, 0x03, 0xfd, 0x23, 0x0d, 0xcd, 0xaf, 0x1c, 0xb1, 0xe2, 0x19, 0xef,
  2217  	0x34, 0x1c, 0x50, 0x7e, 0xeb, 0x80, 0x8b, 0x19, 0x56, 0xa5, 0xe5, 0x4b, 0x7d, 0xab, 0x3c, 0x62,
  2218  	0x21, 0x96, 0x64, 0x20, 0x95, 0xc8, 0x22, 0x95, 0x09, 0x12, 0x17, 0xd6, 0xf5, 0x4f, 0x69, 0xc2,
  2219  	0x92, 0x94, 0xf4, 0x99, 0xa2, 0x6c, 0x70, 0xc8, 0xa2, 0x81, 0xa2, 0x33, 0x22, 0x15, 0x9e, 0xa5,
  2220  	0x85, 0xe5, 0xea, 0x84, 0x4f, 0xb8, 0xf9, 0x1c, 0xe8, 0xaf, 0xfc, 0x74, 0xed, 0x5d, 0x03, 0x96,
  2221  	0x87, 0x38, 0x9a, 0x1e, 0x50, 0xc6, 0x88, 0xd8, 0x4f, 0x49, 0x84, 0xb6, 0xc1, 0x56, 0xf3, 0x94,
  2222  	0x78, 0x56, 0xcf, 0xea, 0x2f, 0x6f, 0xdc, 0xf2, 0x2f, 0x0a, 0xd1, 0x3f, 0x8f, 0xf3, 0x1f, 0xce,
  2223  	0x53, 0x32, 0xb4, 0x5f, 0xbe, 0x59, 0xad, 0x05, 0x86, 0x00, 0x0d, 0xa1, 0xa9, 0x70, 0xc8, 0x88,
  2224  	0x57, 0xef, 0x59, 0xfd, 0xce, 0xc6, 0x8d, 0x0f, 0x98, 0x8a, 0x50, 0xfd, 0x87, 0xda, 0x67, 0x8b,
  2225  	0xc8, 0x48, 0xd0, 0x54, 0x71, 0x51, 0x50, 0xe4, 0x50, 0x74, 0x0f, 0x9a, 0x32, 0xc5, 0x89, 0xf4,
  2226  	0x1a, 0xbd, 0x46, 0xbf, 0xb3, 0xf1, 0xed, 0xc5, 0x6a, 0x0c, 0x4d, 0x40, 0x70, 0xac, 0xe5, 0xe0,
  2227  	0xa4, 0xa4, 0x31, 0x68, 0xf4, 0x1d, 0x38, 0x71, 0x26, 0xb0, 0xa2, 0x3c, 0xf1, 0xec, 0x9e, 0xd5,
  2228  	0x6f, 0x0c, 0x3f, 0xd7, 0xe6, 0x77, 0x6f, 0x56, 0x97, 0x74, 0x9e, 0xfc, 0xad, 0xc2, 0x18, 0x9c,
  2229  	0xb9, 0xa1, 0xaf, 0x01, 0xa2, 0xc3, 0x2c, 0x99, 0x8e, 0x25, 0x7d, 0x41, 0xbc, 0xa6, 0x01, 0xe5,
  2230  	0x9c, 0x6d, 0x73, 0xbe, 0x4f, 0x5f, 0x10, 0xb4, 0x0b, 0x8b, 0x5c, 0x1d, 0x12, 0x31, 0x36, 0x6a,
  2231  	0xa5, 0xd7, 0x32, 0x2a, 0x2f, 0x17, 0x69, 0xc7, 0x30, 0x18, 0x9b, 0x44, 0x77, 0xc1, 0x11, 0x04,
  2232  	0xc7, 0xbf, 0xca, 0xdd, 0x03, 0x6f, 0xc1, 0xa4, 0xed, 0xab, 0x0a, 0x99, 0x2e, 0xae, 0x7f, 0xc8,
  2233  	0x22, 0xff, 0x61, 0x59, 0xdc, 0x82, 0xe3, 0x0c, 0xb4, 0x76, 0x13, 0x6c, 0x5d, 0x08, 0xd4, 0x81,
  2234  	0x85, 0x9d, 0xe4, 0x19, 0x66, 0x34, 0x76, 0x6b, 0x08, 0xa0, 0xb5, 0xc9, 0x59, 0x36, 0x4b, 0x5c,
  2235  	0x0b, 0xb5, 0xa1, 0xb9, 0x93, 0xc4, 0xe4, 0xb9, 0x5b, 0x5f, 0x3b, 0x86, 0xce, 0x88, 0x87, 0x7b,
  2236  	0x82, 0x4f, 0x04, 0x91, 0x12, 0x5d, 0x87, 0xd6, 0x53, 0x1e, 0x8e, 0x69, 0x6c, 0x4a, 0xdf, 0x18,
  2237  	0x2e, 0x69, 0xea, 0x93, 0x37, 0xab, 0xcd, 0x11, 0x0f, 0x77, 0xb6, 0x82, 0xe6, 0x53, 0x1e, 0xee,
  2238  	0xc4, 0xa8, 0x0f, 0x8b, 0x11, 0x4f, 0x94, 0xa0, 0x61, 0x66, 0xd2, 0xa9, 0x8b, 0x5b, 0x2f, 0x64,
  2239  	0x9c, 0xb3, 0x20, 0x0f, 0x6c, 0xc9, 0xb8, 0xf2, 0x1a, 0x3d, 0xab, 0xdf, 0x2c, 0x3b, 0x43, 0x9f,
  2240  	0xac, 0xbd, 0x5d, 0x00, 0xa4, 0x4b, 0xb5, 0x33, 0x4b, 0xb9, 0x50, 0x5b, 0x58, 0x61, 0xd3, 0x79,
  2241  	0xeb, 0xd0, 0x91, 0x78, 0x96, 0x32, 0x92, 0xe7, 0xbc, 0x5e, 0xc1, 0x41, 0x6e, 0x30, 0x49, 0xdf,
  2242  	0x06, 0x27, 0x2d, 0x34, 0x7b, 0x2d, 0x93, 0xa3, 0xf5, 0x8b, 0xdb, 0xa2, 0x12, 0x60, 0x99, 0xab,
  2243  	0x12, 0x8c, 0xb6, 0xa1, 0x91, 0x09, 0xea, 0x2d, 0x98, 0xa2, 0x7d, 0x7f, 0x31, 0xc7, 0xc7, 0x52,
  2244  	0xfd, 0x3f, 0x04, 0xbd, 0x97, 0x28, 0x31, 0x0f, 0x34, 0x03, 0xba, 0x03, 0xad, 0x7c, 0x96, 0x3d,
  2245  	0xc7, 0xe8, 0x59, 0xad, 0x70, 0x15, 0xf3, 0xee, 0xef, 0xec, 0xde, 0xa7, 0x8c, 0xdc, 0x37, 0x6e,
  2246  	0x85, 0x92, 0x02, 0x84, 0x1e, 0x41, 0xab, 0xe8, 0x9f, 0xb6, 0x91, 0x72, 0xfb, 0x52, 0x52, 0xf2,
  2247  	0xce, 0x31, 0x6a, 0x0c, 0xaf, 0x15, 0x14, 0x6c, 0xe8, 0x2e, 0x7c, 0x21, 0xa7, 0x34, 0x1d, 0xcf,
  2248  	0xa8, 0x94, 0x34, 0x99, 0x8c, 0x0f, 0xb8, 0x20, 0x74, 0x92, 0x8c, 0xa7, 0x64, 0x2e, 0x3d, 0xe8,
  2249  	0x59, 0x7d, 0xa7, 0x10, 0x72, 0x4d, 0xbb, 0xfd, 0x9e, 0x7b, 0xdd, 0xcf, 0x9d, 0x7e, 0x23, 0x73,
  2250  	0x89, 0x6e, 0xc2, 0xd2, 0x31, 0x66, 0x4c, 0x8f, 0xc8, 0x03, 0x9c, 0x70, 0xe9, 0x75, 0x2a, 0x63,
  2251  	0x70, 0xde, 0x84, 0x36, 0xe0, 0x8a, 0x30, 0xd3, 0xb7, 0x87, 0x05, 0x66, 0x8c, 0x30, 0x2a, 0x67,
  2252  	0xde, 0x52, 0xa5, 0x84, 0x1f, 0x9b, 0xd1, 0x13, 0x00, 0x41, 0x64, 0x36, 0x23, 0xe3, 0x94, 0x4b,
  2253  	0x6f, 0xd9, 0x04, 0xff, 0xd3, 0xa5, 0x82, 0x0f, 0x0c, 0x7c, 0x8f, 0xe7, 0xf1, 0x07, 0x6d, 0x51,
  2254  	0xfe, 0xbd, 0x92, 0x41, 0x27, 0xf7, 0x35, 0xf9, 0x41, 0xbf, 0x80, 0x1d, 0x13, 0x19, 0x99, 0xd6,
  2255  	0xbe, 0xdc, 0x84, 0x5a, 0x81, 0x41, 0xa2, 0xeb, 0x00, 0x0a, 0x8b, 0x09, 0x51, 0x9b, 0x9c, 0x49,
  2256  	0xaf, 0xde, 0x6b, 0xf4, 0xdb, 0x85, 0xbd, 0x72, 0xbe, 0x22, 0xa1, 0x53, 0x29, 0x08, 0x72, 0xa1,
  2257  	0x31, 0x25, 0x73, 0x73, 0x6b, 0x3b, 0xd0, 0x9f, 0xe8, 0x01, 0x34, 0x9f, 0x61, 0x96, 0x95, 0x5b,
  2258  	0xf1, 0x72, 0xb5, 0xae, 0x44, 0x14, 0xe4, 0x34, 0x3f, 0xd6, 0x6f, 0x5b, 0x2b, 0x3f, 0x80, 0x53,
  2259  	0x36, 0x64, 0xf5, 0xc6, 0x66, 0x7e, 0xe3, 0xd5, 0xea, 0x8d, 0xed, 0x2a, 0xee, 0x67, 0x58, 0x3e,
  2260  	0x9f, 0xc0, 0xff, 0x42, 0x37, 0x2a, 0xe8, 0x91, 0xed, 0x58, 0x6e, 0x7d, 0x64, 0x3b, 0x0d, 0xd7,
  2261  	0x1e, 0xd9, 0x8e, 0xed, 0x36, 0x47, 0xb6, 0xd3, 0x74, 0x5b, 0x23, 0xdb, 0x59, 0x74, 0x97, 0xd6,
  2262  	0xfe, 0xae, 0xc3, 0xd2, 0xe6, 0xfe, 0xa3, 0xc7, 0x82, 0xaa, 0xe2, 0x61, 0xb9, 0x01, 0x9d, 0x98,
  2263  	0x48, 0x45, 0x93, 0x7c, 0x0f, 0x9b, 0x9c, 0x94, 0x3b, 0xb0, 0x62, 0x40, 0xdf, 0xc0, 0x62, 0x82,
  2264  	0x75, 0x4f, 0x60, 0xa5, 0x88, 0xc8, 0x37, 0xcc, 0x99, 0xa3, 0xb6, 0xec, 0xe5, 0x06, 0x74, 0x07,
  2265  	0x16, 0x78, 0xaa, 0x21, 0xd2, 0xec, 0x98, 0xf3, 0xbb, 0xb2, 0x9c, 0xbb, 0xcd, 0xfd, 0x47, 0xbb,
  2266  	0xb9, 0x53, 0x41, 0x51, 0x62, 0xde, 0x6f, 0x78, 0xc1, 0x8f, 0x65, 0xf1, 0x2c, 0x54, 0x37, 0x7c,
  2267  	0xc0, 0x8f, 0x25, 0xfa, 0x13, 0xae, 0x44, 0x7c, 0x96, 0xea, 0x7d, 0x41, 0x79, 0x32, 0x8e, 0x78,
  2268  	0x4c, 0x22, 0xf3, 0x1a, 0x2c, 0x7f, 0xea, 0x31, 0xd2, 0xa3, 0xbe, 0xf9, 0x1e, 0x56, 0xd0, 0xba,
  2269  	0x15, 0xa6, 0x4d, 0x4d, 0xb4, 0xf6, 0x18, 0xae, 0x0c, 0x33, 0xa6, 0x6f, 0xaa, 0xe4, 0xe9, 0xec,
  2270  	0xdd, 0xb4, 0xfe, 0xf7, 0xbb, 0x79, 0x73, 0x1d, 0x3e, 0xfb, 0x40, 0x03, 0x72, 0xc0, 0x7e, 0xc0,
  2271  	0x13, 0xe2, 0xd6, 0xf4, 0xd7, 0xf6, 0x0b, 0x9a, 0xba, 0xd6, 0xf0, 0xd6, 0xcb, 0xb7, 0xdd, 0xda,
  2272  	0xcb, 0x93, 0xae, 0xf5, 0xea, 0xa4, 0x6b, 0xbd, 0x3e, 0xe9, 0x5a, 0xff, 0x9c, 0x74, 0xad, 0xbf,
  2273  	0x4e, 0xbb, 0xb5, 0x57, 0xa7, 0xdd, 0xda, 0xeb, 0xd3, 0x6e, 0xed, 0x49, 0xa7, 0xf2, 0x3f, 0xc7,
  2274  	0xbf, 0x01, 0x00, 0x00, 0xff, 0xff, 0x63, 0xb9, 0x6a, 0x6d, 0x19, 0x09, 0x00, 0x00,
  2275  }