storage

package
v0.0.0-...-8c6c420 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Apr 15, 2024 License: Apache-2.0 Imports: 15 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	WriteStream_Type_name = map[int32]string{
		0: "TYPE_UNSPECIFIED",
		1: "COMMITTED",
		2: "PENDING",
		3: "BUFFERED",
	}
	WriteStream_Type_value = map[string]int32{
		"TYPE_UNSPECIFIED": 0,
		"COMMITTED":        1,
		"PENDING":          2,
		"BUFFERED":         3,
	}
)

Enum value maps for WriteStream_Type.

View Source
var (
	TableFieldSchema_Type_name = map[int32]string{
		0:  "TYPE_UNSPECIFIED",
		1:  "STRING",
		2:  "INT64",
		3:  "DOUBLE",
		4:  "STRUCT",
		5:  "BYTES",
		6:  "BOOL",
		7:  "TIMESTAMP",
		8:  "DATE",
		9:  "TIME",
		10: "DATETIME",
		11: "GEOGRAPHY",
		12: "NUMERIC",
	}
	TableFieldSchema_Type_value = map[string]int32{
		"TYPE_UNSPECIFIED": 0,
		"STRING":           1,
		"INT64":            2,
		"DOUBLE":           3,
		"STRUCT":           4,
		"BYTES":            5,
		"BOOL":             6,
		"TIMESTAMP":        7,
		"DATE":             8,
		"TIME":             9,
		"DATETIME":         10,
		"GEOGRAPHY":        11,
		"NUMERIC":          12,
	}
)

Enum value maps for TableFieldSchema_Type.

View Source
var (
	TableFieldSchema_Mode_name = map[int32]string{
		0: "MODE_UNSPECIFIED",
		1: "NULLABLE",
		2: "REQUIRED",
		3: "REPEATED",
	}
	TableFieldSchema_Mode_value = map[string]int32{
		"MODE_UNSPECIFIED": 0,
		"NULLABLE":         1,
		"REQUIRED":         2,
		"REPEATED":         3,
	}
)

Enum value maps for TableFieldSchema_Mode.

View Source
var File_google_cloud_bigquery_storage_v1alpha2_protobuf_proto protoreflect.FileDescriptor
View Source
var File_google_cloud_bigquery_storage_v1alpha2_storage_proto protoreflect.FileDescriptor
View Source
var File_google_cloud_bigquery_storage_v1alpha2_stream_proto protoreflect.FileDescriptor
View Source
var File_google_cloud_bigquery_storage_v1alpha2_table_proto protoreflect.FileDescriptor

Functions

func RegisterBigQueryWriteServer deprecated

func RegisterBigQueryWriteServer(s *grpc.Server, srv BigQueryWriteServer)

Deprecated: Do not use.

Types

type AppendRowsRequest

type AppendRowsRequest struct {

	// Required. The stream that is the target of the append operation. This value must be
	// specified for the initial request. If subsequent requests specify the
	// stream name, it must equal to the value provided in the first request.
	// To write to the _default stream, populate this field with a string in the
	// format `projects/{project}/datasets/{dataset}/tables/{table}/_default`.
	WriteStream string `protobuf:"bytes,1,opt,name=write_stream,json=writeStream,proto3" json:"write_stream,omitempty"`
	// Optional. If present, the write is only performed if the next append offset is same
	// as the provided value. If not present, the write is performed at the
	// current end of stream. Specifying a value for this field is not allowed
	// when calling AppendRows for the '_default' stream.
	Offset *wrapperspb.Int64Value `protobuf:"bytes,2,opt,name=offset,proto3" json:"offset,omitempty"`
	// Input rows. The `writer_schema` field must be specified at the initial
	// request and currently, it will be ignored if specified in following
	// requests. Following requests must have data in the same format as the
	// initial request.
	//
	// Types that are assignable to Rows:
	//	*AppendRowsRequest_ProtoRows
	Rows isAppendRowsRequest_Rows `protobuf_oneof:"rows"`
	// Only initial request setting is respected. If true, drop unknown input
	// fields. Otherwise, the extra fields will cause append to fail. Default
	// value is false.
	IgnoreUnknownFields bool `protobuf:"varint,5,opt,name=ignore_unknown_fields,json=ignoreUnknownFields,proto3" json:"ignore_unknown_fields,omitempty"`
	// contains filtered or unexported fields
}

Request message for `AppendRows`.

func (*AppendRowsRequest) Descriptor deprecated

func (*AppendRowsRequest) Descriptor() ([]byte, []int)

Deprecated: Use AppendRowsRequest.ProtoReflect.Descriptor instead.

func (*AppendRowsRequest) GetIgnoreUnknownFields

func (x *AppendRowsRequest) GetIgnoreUnknownFields() bool

func (*AppendRowsRequest) GetOffset

func (x *AppendRowsRequest) GetOffset() *wrapperspb.Int64Value

func (*AppendRowsRequest) GetProtoRows

func (*AppendRowsRequest) GetRows

func (m *AppendRowsRequest) GetRows() isAppendRowsRequest_Rows

func (*AppendRowsRequest) GetWriteStream

func (x *AppendRowsRequest) GetWriteStream() string

func (*AppendRowsRequest) ProtoMessage

func (*AppendRowsRequest) ProtoMessage()

func (*AppendRowsRequest) ProtoReflect

func (x *AppendRowsRequest) ProtoReflect() protoreflect.Message

func (*AppendRowsRequest) Reset

func (x *AppendRowsRequest) Reset()

func (*AppendRowsRequest) String

func (x *AppendRowsRequest) String() string

type AppendRowsRequest_ProtoData

type AppendRowsRequest_ProtoData struct {

	// Proto schema used to serialize the data.
	WriterSchema *ProtoSchema `protobuf:"bytes,1,opt,name=writer_schema,json=writerSchema,proto3" json:"writer_schema,omitempty"`
	// Serialized row data in protobuf message format.
	Rows *ProtoRows `protobuf:"bytes,2,opt,name=rows,proto3" json:"rows,omitempty"`
	// contains filtered or unexported fields
}

func (*AppendRowsRequest_ProtoData) Descriptor deprecated

func (*AppendRowsRequest_ProtoData) Descriptor() ([]byte, []int)

Deprecated: Use AppendRowsRequest_ProtoData.ProtoReflect.Descriptor instead.

func (*AppendRowsRequest_ProtoData) GetRows

func (x *AppendRowsRequest_ProtoData) GetRows() *ProtoRows

func (*AppendRowsRequest_ProtoData) GetWriterSchema

func (x *AppendRowsRequest_ProtoData) GetWriterSchema() *ProtoSchema

func (*AppendRowsRequest_ProtoData) ProtoMessage

func (*AppendRowsRequest_ProtoData) ProtoMessage()

func (*AppendRowsRequest_ProtoData) ProtoReflect

func (*AppendRowsRequest_ProtoData) Reset

func (x *AppendRowsRequest_ProtoData) Reset()

func (*AppendRowsRequest_ProtoData) String

func (x *AppendRowsRequest_ProtoData) String() string

type AppendRowsRequest_ProtoRows

type AppendRowsRequest_ProtoRows struct {
	ProtoRows *AppendRowsRequest_ProtoData `protobuf:"bytes,4,opt,name=proto_rows,json=protoRows,proto3,oneof"`
}

type AppendRowsResponse

type AppendRowsResponse struct {

	// Types that are assignable to Response:
	//	*AppendRowsResponse_Offset
	//	*AppendRowsResponse_Error
	Response isAppendRowsResponse_Response `protobuf_oneof:"response"`
	// If backend detects a schema update, pass it to user so that user can
	// use it to input new type of message. It will be empty when there is no
	// schema updates.
	UpdatedSchema *TableSchema `protobuf:"bytes,3,opt,name=updated_schema,json=updatedSchema,proto3" json:"updated_schema,omitempty"`
	// contains filtered or unexported fields
}

Response message for `AppendRows`.

func (*AppendRowsResponse) Descriptor deprecated

func (*AppendRowsResponse) Descriptor() ([]byte, []int)

Deprecated: Use AppendRowsResponse.ProtoReflect.Descriptor instead.

func (*AppendRowsResponse) GetError

func (x *AppendRowsResponse) GetError() *status.Status

func (*AppendRowsResponse) GetOffset

func (x *AppendRowsResponse) GetOffset() int64

func (*AppendRowsResponse) GetResponse

func (m *AppendRowsResponse) GetResponse() isAppendRowsResponse_Response

func (*AppendRowsResponse) GetUpdatedSchema

func (x *AppendRowsResponse) GetUpdatedSchema() *TableSchema

func (*AppendRowsResponse) ProtoMessage

func (*AppendRowsResponse) ProtoMessage()

func (*AppendRowsResponse) ProtoReflect

func (x *AppendRowsResponse) ProtoReflect() protoreflect.Message

func (*AppendRowsResponse) Reset

func (x *AppendRowsResponse) Reset()

func (*AppendRowsResponse) String

func (x *AppendRowsResponse) String() string

type AppendRowsResponse_Error

type AppendRowsResponse_Error struct {
	// Error in case of append failure. If set, it means rows are not accepted
	// into the system. Users can retry or continue with other requests within
	// the same connection.
	// ALREADY_EXISTS: happens when offset is specified, it means the row is
	//   already appended, it is safe to ignore this error.
	// OUT_OF_RANGE: happens when offset is specified, it means the specified
	//   offset is beyond the end of the stream.
	// INVALID_ARGUMENT: error caused by malformed request or data.
	// RESOURCE_EXHAUSTED: request rejected due to throttling. Only happens when
	//   append without offset.
	// ABORTED: request processing is aborted because of prior failures, request
	//   can be retried if previous failure is fixed.
	// INTERNAL: server side errors that can be retried.
	Error *status.Status `protobuf:"bytes,2,opt,name=error,proto3,oneof"`
}

type AppendRowsResponse_Offset

type AppendRowsResponse_Offset struct {
	// The row offset at which the last append occurred.
	Offset int64 `protobuf:"varint,1,opt,name=offset,proto3,oneof"`
}

type BatchCommitWriteStreamsRequest

type BatchCommitWriteStreamsRequest struct {

	// Required. Parent table that all the streams should belong to, in the form of
	// `projects/{project}/datasets/{dataset}/tables/{table}`.
	Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"`
	// Required. The group of streams that will be committed atomically.
	WriteStreams []string `protobuf:"bytes,2,rep,name=write_streams,json=writeStreams,proto3" json:"write_streams,omitempty"`
	// contains filtered or unexported fields
}

Request message for `BatchCommitWriteStreams`.

func (*BatchCommitWriteStreamsRequest) Descriptor deprecated

func (*BatchCommitWriteStreamsRequest) Descriptor() ([]byte, []int)

Deprecated: Use BatchCommitWriteStreamsRequest.ProtoReflect.Descriptor instead.

func (*BatchCommitWriteStreamsRequest) GetParent

func (x *BatchCommitWriteStreamsRequest) GetParent() string

func (*BatchCommitWriteStreamsRequest) GetWriteStreams

func (x *BatchCommitWriteStreamsRequest) GetWriteStreams() []string

func (*BatchCommitWriteStreamsRequest) ProtoMessage

func (*BatchCommitWriteStreamsRequest) ProtoMessage()

func (*BatchCommitWriteStreamsRequest) ProtoReflect

func (*BatchCommitWriteStreamsRequest) Reset

func (x *BatchCommitWriteStreamsRequest) Reset()

func (*BatchCommitWriteStreamsRequest) String

type BatchCommitWriteStreamsResponse

type BatchCommitWriteStreamsResponse struct {

	// The time at which streams were committed in microseconds granularity.
	CommitTime *timestamppb.Timestamp `protobuf:"bytes,1,opt,name=commit_time,json=commitTime,proto3" json:"commit_time,omitempty"`
	// contains filtered or unexported fields
}

Response message for `BatchCommitWriteStreams`.

func (*BatchCommitWriteStreamsResponse) Descriptor deprecated

func (*BatchCommitWriteStreamsResponse) Descriptor() ([]byte, []int)

Deprecated: Use BatchCommitWriteStreamsResponse.ProtoReflect.Descriptor instead.

func (*BatchCommitWriteStreamsResponse) GetCommitTime

func (*BatchCommitWriteStreamsResponse) ProtoMessage

func (*BatchCommitWriteStreamsResponse) ProtoMessage()

func (*BatchCommitWriteStreamsResponse) ProtoReflect

func (*BatchCommitWriteStreamsResponse) Reset

func (*BatchCommitWriteStreamsResponse) String

type BigQueryWriteClient deprecated

type BigQueryWriteClient interface {
	// Creates a write stream to the given table.
	// Additionally, every table has a special COMMITTED stream named '_default'
	// to which data can be written. This stream doesn't need to be created using
	// CreateWriteStream. It is a stream that can be used simultaneously by any
	// number of clients. Data written to this stream is considered committed as
	// soon as an acknowledgement is received.
	CreateWriteStream(ctx context.Context, in *CreateWriteStreamRequest, opts ...grpc.CallOption) (*WriteStream, error)
	// Appends data to the given stream.
	//
	// If `offset` is specified, the `offset` is checked against the end of
	// stream. The server returns `OUT_OF_RANGE` in `AppendRowsResponse` if an
	// attempt is made to append to an offset beyond the current end of the stream
	// or `ALREADY_EXISTS` if user provids an `offset` that has already been
	// written to. User can retry with adjusted offset within the same RPC
	// stream. If `offset` is not specified, append happens at the end of the
	// stream.
	//
	// The response contains the offset at which the append happened. Responses
	// are received in the same order in which requests are sent. There will be
	// one response for each successful request. If the `offset` is not set in
	// response, it means append didn't happen due to some errors. If one request
	// fails, all the subsequent requests will also fail until a success request
	// is made again.
	//
	// If the stream is of `PENDING` type, data will only be available for read
	// operations after the stream is committed.
	AppendRows(ctx context.Context, opts ...grpc.CallOption) (BigQueryWrite_AppendRowsClient, error)
	// Gets a write stream.
	GetWriteStream(ctx context.Context, in *GetWriteStreamRequest, opts ...grpc.CallOption) (*WriteStream, error)
	// Finalize a write stream so that no new data can be appended to the
	// stream. Finalize is not supported on the '_default' stream.
	FinalizeWriteStream(ctx context.Context, in *FinalizeWriteStreamRequest, opts ...grpc.CallOption) (*FinalizeWriteStreamResponse, error)
	// Atomically commits a group of `PENDING` streams that belong to the same
	// `parent` table.
	// Streams must be finalized before commit and cannot be committed multiple
	// times. Once a stream is committed, data in the stream becomes available
	// for read operations.
	BatchCommitWriteStreams(ctx context.Context, in *BatchCommitWriteStreamsRequest, opts ...grpc.CallOption) (*BatchCommitWriteStreamsResponse, error)
	// Flushes rows to a BUFFERED stream.
	// If users are appending rows to BUFFERED stream, flush operation is
	// required in order for the rows to become available for reading. A
	// Flush operation flushes up to any previously flushed offset in a BUFFERED
	// stream, to the offset specified in the request.
	// Flush is not supported on the _default stream, since it is not BUFFERED.
	FlushRows(ctx context.Context, in *FlushRowsRequest, opts ...grpc.CallOption) (*FlushRowsResponse, error)
}

BigQueryWriteClient is the client API for BigQueryWrite service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Do not use.

func NewBigQueryWriteClient deprecated

func NewBigQueryWriteClient(cc grpc.ClientConnInterface) BigQueryWriteClient

Deprecated: Do not use.

type BigQueryWriteServer deprecated

type BigQueryWriteServer interface {
	// Creates a write stream to the given table.
	// Additionally, every table has a special COMMITTED stream named '_default'
	// to which data can be written. This stream doesn't need to be created using
	// CreateWriteStream. It is a stream that can be used simultaneously by any
	// number of clients. Data written to this stream is considered committed as
	// soon as an acknowledgement is received.
	CreateWriteStream(context.Context, *CreateWriteStreamRequest) (*WriteStream, error)
	// Appends data to the given stream.
	//
	// If `offset` is specified, the `offset` is checked against the end of
	// stream. The server returns `OUT_OF_RANGE` in `AppendRowsResponse` if an
	// attempt is made to append to an offset beyond the current end of the stream
	// or `ALREADY_EXISTS` if user provids an `offset` that has already been
	// written to. User can retry with adjusted offset within the same RPC
	// stream. If `offset` is not specified, append happens at the end of the
	// stream.
	//
	// The response contains the offset at which the append happened. Responses
	// are received in the same order in which requests are sent. There will be
	// one response for each successful request. If the `offset` is not set in
	// response, it means append didn't happen due to some errors. If one request
	// fails, all the subsequent requests will also fail until a success request
	// is made again.
	//
	// If the stream is of `PENDING` type, data will only be available for read
	// operations after the stream is committed.
	AppendRows(BigQueryWrite_AppendRowsServer) error
	// Gets a write stream.
	GetWriteStream(context.Context, *GetWriteStreamRequest) (*WriteStream, error)
	// Finalize a write stream so that no new data can be appended to the
	// stream. Finalize is not supported on the '_default' stream.
	FinalizeWriteStream(context.Context, *FinalizeWriteStreamRequest) (*FinalizeWriteStreamResponse, error)
	// Atomically commits a group of `PENDING` streams that belong to the same
	// `parent` table.
	// Streams must be finalized before commit and cannot be committed multiple
	// times. Once a stream is committed, data in the stream becomes available
	// for read operations.
	BatchCommitWriteStreams(context.Context, *BatchCommitWriteStreamsRequest) (*BatchCommitWriteStreamsResponse, error)
	// Flushes rows to a BUFFERED stream.
	// If users are appending rows to BUFFERED stream, flush operation is
	// required in order for the rows to become available for reading. A
	// Flush operation flushes up to any previously flushed offset in a BUFFERED
	// stream, to the offset specified in the request.
	// Flush is not supported on the _default stream, since it is not BUFFERED.
	FlushRows(context.Context, *FlushRowsRequest) (*FlushRowsResponse, error)
}

BigQueryWriteServer is the server API for BigQueryWrite service.

Deprecated: Do not use.

type BigQueryWrite_AppendRowsClient

type BigQueryWrite_AppendRowsClient interface {
	Send(*AppendRowsRequest) error
	Recv() (*AppendRowsResponse, error)
	grpc.ClientStream
}

type BigQueryWrite_AppendRowsServer

type BigQueryWrite_AppendRowsServer interface {
	Send(*AppendRowsResponse) error
	Recv() (*AppendRowsRequest, error)
	grpc.ServerStream
}

type CreateWriteStreamRequest

type CreateWriteStreamRequest struct {

	// Required. Reference to the table to which the stream belongs, in the format
	// of `projects/{project}/datasets/{dataset}/tables/{table}`.
	Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"`
	// Required. Stream to be created.
	WriteStream *WriteStream `protobuf:"bytes,2,opt,name=write_stream,json=writeStream,proto3" json:"write_stream,omitempty"`
	// contains filtered or unexported fields
}

Request message for `CreateWriteStream`.

func (*CreateWriteStreamRequest) Descriptor deprecated

func (*CreateWriteStreamRequest) Descriptor() ([]byte, []int)

Deprecated: Use CreateWriteStreamRequest.ProtoReflect.Descriptor instead.

func (*CreateWriteStreamRequest) GetParent

func (x *CreateWriteStreamRequest) GetParent() string

func (*CreateWriteStreamRequest) GetWriteStream

func (x *CreateWriteStreamRequest) GetWriteStream() *WriteStream

func (*CreateWriteStreamRequest) ProtoMessage

func (*CreateWriteStreamRequest) ProtoMessage()

func (*CreateWriteStreamRequest) ProtoReflect

func (x *CreateWriteStreamRequest) ProtoReflect() protoreflect.Message

func (*CreateWriteStreamRequest) Reset

func (x *CreateWriteStreamRequest) Reset()

func (*CreateWriteStreamRequest) String

func (x *CreateWriteStreamRequest) String() string

type FinalizeWriteStreamRequest

type FinalizeWriteStreamRequest struct {

	// Required. Name of the stream to finalize, in the form of
	// `projects/{project}/datasets/{dataset}/tables/{table}/streams/{stream}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// contains filtered or unexported fields
}

Request message for invoking `FinalizeWriteStream`.

func (*FinalizeWriteStreamRequest) Descriptor deprecated

func (*FinalizeWriteStreamRequest) Descriptor() ([]byte, []int)

Deprecated: Use FinalizeWriteStreamRequest.ProtoReflect.Descriptor instead.

func (*FinalizeWriteStreamRequest) GetName

func (x *FinalizeWriteStreamRequest) GetName() string

func (*FinalizeWriteStreamRequest) ProtoMessage

func (*FinalizeWriteStreamRequest) ProtoMessage()

func (*FinalizeWriteStreamRequest) ProtoReflect

func (*FinalizeWriteStreamRequest) Reset

func (x *FinalizeWriteStreamRequest) Reset()

func (*FinalizeWriteStreamRequest) String

func (x *FinalizeWriteStreamRequest) String() string

type FinalizeWriteStreamResponse

type FinalizeWriteStreamResponse struct {

	// Number of rows in the finalized stream.
	RowCount int64 `protobuf:"varint,1,opt,name=row_count,json=rowCount,proto3" json:"row_count,omitempty"`
	// contains filtered or unexported fields
}

Response message for `FinalizeWriteStream`.

func (*FinalizeWriteStreamResponse) Descriptor deprecated

func (*FinalizeWriteStreamResponse) Descriptor() ([]byte, []int)

Deprecated: Use FinalizeWriteStreamResponse.ProtoReflect.Descriptor instead.

func (*FinalizeWriteStreamResponse) GetRowCount

func (x *FinalizeWriteStreamResponse) GetRowCount() int64

func (*FinalizeWriteStreamResponse) ProtoMessage

func (*FinalizeWriteStreamResponse) ProtoMessage()

func (*FinalizeWriteStreamResponse) ProtoReflect

func (*FinalizeWriteStreamResponse) Reset

func (x *FinalizeWriteStreamResponse) Reset()

func (*FinalizeWriteStreamResponse) String

func (x *FinalizeWriteStreamResponse) String() string

type FlushRowsRequest

type FlushRowsRequest struct {

	// Required. The stream that is the target of the flush operation.
	WriteStream string `protobuf:"bytes,1,opt,name=write_stream,json=writeStream,proto3" json:"write_stream,omitempty"`
	// Ending offset of the flush operation. Rows before this offset(including
	// this offset) will be flushed.
	Offset int64 `protobuf:"varint,2,opt,name=offset,proto3" json:"offset,omitempty"`
	// contains filtered or unexported fields
}

Request message for `FlushRows`.

func (*FlushRowsRequest) Descriptor deprecated

func (*FlushRowsRequest) Descriptor() ([]byte, []int)

Deprecated: Use FlushRowsRequest.ProtoReflect.Descriptor instead.

func (*FlushRowsRequest) GetOffset

func (x *FlushRowsRequest) GetOffset() int64

func (*FlushRowsRequest) GetWriteStream

func (x *FlushRowsRequest) GetWriteStream() string

func (*FlushRowsRequest) ProtoMessage

func (*FlushRowsRequest) ProtoMessage()

func (*FlushRowsRequest) ProtoReflect

func (x *FlushRowsRequest) ProtoReflect() protoreflect.Message

func (*FlushRowsRequest) Reset

func (x *FlushRowsRequest) Reset()

func (*FlushRowsRequest) String

func (x *FlushRowsRequest) String() string

type FlushRowsResponse

type FlushRowsResponse struct {

	// The rows before this offset (including this offset) are flushed.
	Offset int64 `protobuf:"varint,1,opt,name=offset,proto3" json:"offset,omitempty"`
	// contains filtered or unexported fields
}

Respond message for `FlushRows`.

func (*FlushRowsResponse) Descriptor deprecated

func (*FlushRowsResponse) Descriptor() ([]byte, []int)

Deprecated: Use FlushRowsResponse.ProtoReflect.Descriptor instead.

func (*FlushRowsResponse) GetOffset

func (x *FlushRowsResponse) GetOffset() int64

func (*FlushRowsResponse) ProtoMessage

func (*FlushRowsResponse) ProtoMessage()

func (*FlushRowsResponse) ProtoReflect

func (x *FlushRowsResponse) ProtoReflect() protoreflect.Message

func (*FlushRowsResponse) Reset

func (x *FlushRowsResponse) Reset()

func (*FlushRowsResponse) String

func (x *FlushRowsResponse) String() string

type GetWriteStreamRequest

type GetWriteStreamRequest struct {

	// Required. Name of the stream to get, in the form of
	// `projects/{project}/datasets/{dataset}/tables/{table}/streams/{stream}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// contains filtered or unexported fields
}

Request message for `GetWriteStreamRequest`.

func (*GetWriteStreamRequest) Descriptor deprecated

func (*GetWriteStreamRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetWriteStreamRequest.ProtoReflect.Descriptor instead.

func (*GetWriteStreamRequest) GetName

func (x *GetWriteStreamRequest) GetName() string

func (*GetWriteStreamRequest) ProtoMessage

func (*GetWriteStreamRequest) ProtoMessage()

func (*GetWriteStreamRequest) ProtoReflect

func (x *GetWriteStreamRequest) ProtoReflect() protoreflect.Message

func (*GetWriteStreamRequest) Reset

func (x *GetWriteStreamRequest) Reset()

func (*GetWriteStreamRequest) String

func (x *GetWriteStreamRequest) String() string

type ProtoRows

type ProtoRows struct {

	// A sequence of rows serialized as a Protocol Buffer.
	//
	// See https://developers.google.com/protocol-buffers/docs/overview for more
	// information on deserializing this field.
	SerializedRows [][]byte `protobuf:"bytes,1,rep,name=serialized_rows,json=serializedRows,proto3" json:"serialized_rows,omitempty"`
	// contains filtered or unexported fields
}

Protobuf rows.

func (*ProtoRows) Descriptor deprecated

func (*ProtoRows) Descriptor() ([]byte, []int)

Deprecated: Use ProtoRows.ProtoReflect.Descriptor instead.

func (*ProtoRows) GetSerializedRows

func (x *ProtoRows) GetSerializedRows() [][]byte

func (*ProtoRows) ProtoMessage

func (*ProtoRows) ProtoMessage()

func (*ProtoRows) ProtoReflect

func (x *ProtoRows) ProtoReflect() protoreflect.Message

func (*ProtoRows) Reset

func (x *ProtoRows) Reset()

func (*ProtoRows) String

func (x *ProtoRows) String() string

type ProtoSchema

type ProtoSchema struct {

	// Descriptor for input message. The descriptor has to be self contained,
	// including all the nested types, excepted for proto buffer well known types
	// (https://developers.google.com/protocol-buffers/docs/reference/google.protobuf)
	// and zetasql public protos
	// (https://github.com/google/zetasql/tree/master/zetasql/public/proto).
	ProtoDescriptor *descriptorpb.DescriptorProto `protobuf:"bytes,1,opt,name=proto_descriptor,json=protoDescriptor,proto3" json:"proto_descriptor,omitempty"`
	// contains filtered or unexported fields
}

Protobuf schema is an API presentation the proto buffer schema.

func (*ProtoSchema) Descriptor deprecated

func (*ProtoSchema) Descriptor() ([]byte, []int)

Deprecated: Use ProtoSchema.ProtoReflect.Descriptor instead.

func (*ProtoSchema) GetProtoDescriptor

func (x *ProtoSchema) GetProtoDescriptor() *descriptorpb.DescriptorProto

func (*ProtoSchema) ProtoMessage

func (*ProtoSchema) ProtoMessage()

func (*ProtoSchema) ProtoReflect

func (x *ProtoSchema) ProtoReflect() protoreflect.Message

func (*ProtoSchema) Reset

func (x *ProtoSchema) Reset()

func (*ProtoSchema) String

func (x *ProtoSchema) String() string

type TableFieldSchema

type TableFieldSchema struct {

	// Required. The field name. The name must contain only letters (a-z, A-Z),
	// numbers (0-9), or underscores (_), and must start with a letter or
	// underscore. The maximum length is 128 characters.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Required. The field data type.
	Type TableFieldSchema_Type `` /* 128-byte string literal not displayed */
	// Optional. The field mode. The default value is NULLABLE.
	Mode TableFieldSchema_Mode `` /* 128-byte string literal not displayed */
	// Optional. Describes the nested schema fields if the type property is set to STRUCT.
	Fields []*TableFieldSchema `protobuf:"bytes,4,rep,name=fields,proto3" json:"fields,omitempty"`
	// Optional. The field description. The maximum length is 1,024 characters.
	Description string `protobuf:"bytes,6,opt,name=description,proto3" json:"description,omitempty"`
	// contains filtered or unexported fields
}

A field in TableSchema

func (*TableFieldSchema) Descriptor deprecated

func (*TableFieldSchema) Descriptor() ([]byte, []int)

Deprecated: Use TableFieldSchema.ProtoReflect.Descriptor instead.

func (*TableFieldSchema) GetDescription

func (x *TableFieldSchema) GetDescription() string

func (*TableFieldSchema) GetFields

func (x *TableFieldSchema) GetFields() []*TableFieldSchema

func (*TableFieldSchema) GetMode

func (*TableFieldSchema) GetName

func (x *TableFieldSchema) GetName() string

func (*TableFieldSchema) GetType

func (*TableFieldSchema) ProtoMessage

func (*TableFieldSchema) ProtoMessage()

func (*TableFieldSchema) ProtoReflect

func (x *TableFieldSchema) ProtoReflect() protoreflect.Message

func (*TableFieldSchema) Reset

func (x *TableFieldSchema) Reset()

func (*TableFieldSchema) String

func (x *TableFieldSchema) String() string

type TableFieldSchema_Mode

type TableFieldSchema_Mode int32
const (
	// Illegal value
	TableFieldSchema_MODE_UNSPECIFIED TableFieldSchema_Mode = 0
	TableFieldSchema_NULLABLE         TableFieldSchema_Mode = 1
	TableFieldSchema_REQUIRED         TableFieldSchema_Mode = 2
	TableFieldSchema_REPEATED         TableFieldSchema_Mode = 3
)

func (TableFieldSchema_Mode) Descriptor

func (TableFieldSchema_Mode) Enum

func (TableFieldSchema_Mode) EnumDescriptor deprecated

func (TableFieldSchema_Mode) EnumDescriptor() ([]byte, []int)

Deprecated: Use TableFieldSchema_Mode.Descriptor instead.

func (TableFieldSchema_Mode) Number

func (TableFieldSchema_Mode) String

func (x TableFieldSchema_Mode) String() string

func (TableFieldSchema_Mode) Type

type TableFieldSchema_Type

type TableFieldSchema_Type int32
const (
	// Illegal value
	TableFieldSchema_TYPE_UNSPECIFIED TableFieldSchema_Type = 0
	// 64K, UTF8
	TableFieldSchema_STRING TableFieldSchema_Type = 1
	// 64-bit signed
	TableFieldSchema_INT64 TableFieldSchema_Type = 2
	// 64-bit IEEE floating point
	TableFieldSchema_DOUBLE TableFieldSchema_Type = 3
	// Aggregate type
	TableFieldSchema_STRUCT TableFieldSchema_Type = 4
	// 64K, Binary
	TableFieldSchema_BYTES TableFieldSchema_Type = 5
	// 2-valued
	TableFieldSchema_BOOL TableFieldSchema_Type = 6
	// 64-bit signed usec since UTC epoch
	TableFieldSchema_TIMESTAMP TableFieldSchema_Type = 7
	// Civil date - Year, Month, Day
	TableFieldSchema_DATE TableFieldSchema_Type = 8
	// Civil time - Hour, Minute, Second, Microseconds
	TableFieldSchema_TIME TableFieldSchema_Type = 9
	// Combination of civil date and civil time
	TableFieldSchema_DATETIME TableFieldSchema_Type = 10
	// Geography object
	TableFieldSchema_GEOGRAPHY TableFieldSchema_Type = 11
	// Numeric value
	TableFieldSchema_NUMERIC TableFieldSchema_Type = 12
)

func (TableFieldSchema_Type) Descriptor

func (TableFieldSchema_Type) Enum

func (TableFieldSchema_Type) EnumDescriptor deprecated

func (TableFieldSchema_Type) EnumDescriptor() ([]byte, []int)

Deprecated: Use TableFieldSchema_Type.Descriptor instead.

func (TableFieldSchema_Type) Number

func (TableFieldSchema_Type) String

func (x TableFieldSchema_Type) String() string

func (TableFieldSchema_Type) Type

type TableSchema

type TableSchema struct {

	// Describes the fields in a table.
	Fields []*TableFieldSchema `protobuf:"bytes,1,rep,name=fields,proto3" json:"fields,omitempty"`
	// contains filtered or unexported fields
}

Schema of a table

func (*TableSchema) Descriptor deprecated

func (*TableSchema) Descriptor() ([]byte, []int)

Deprecated: Use TableSchema.ProtoReflect.Descriptor instead.

func (*TableSchema) GetFields

func (x *TableSchema) GetFields() []*TableFieldSchema

func (*TableSchema) ProtoMessage

func (*TableSchema) ProtoMessage()

func (*TableSchema) ProtoReflect

func (x *TableSchema) ProtoReflect() protoreflect.Message

func (*TableSchema) Reset

func (x *TableSchema) Reset()

func (*TableSchema) String

func (x *TableSchema) String() string

type UnimplementedBigQueryWriteServer

type UnimplementedBigQueryWriteServer struct {
}

UnimplementedBigQueryWriteServer can be embedded to have forward compatible implementations.

func (*UnimplementedBigQueryWriteServer) AppendRows

func (*UnimplementedBigQueryWriteServer) CreateWriteStream

func (*UnimplementedBigQueryWriteServer) FinalizeWriteStream

func (*UnimplementedBigQueryWriteServer) FlushRows

func (*UnimplementedBigQueryWriteServer) GetWriteStream

type WriteStream

type WriteStream struct {

	// Output only. Name of the stream, in the form
	// `projects/{project}/datasets/{dataset}/tables/{table}/streams/{stream}`.
	Name string           `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	Type WriteStream_Type `protobuf:"varint,2,opt,name=type,proto3,enum=google.cloud.bigquery.storage.v1alpha2.WriteStream_Type" json:"type,omitempty"`
	// Output only. Create time of the stream. For the _default stream, this is the
	// creation_time of the table.
	CreateTime *timestamppb.Timestamp `protobuf:"bytes,3,opt,name=create_time,json=createTime,proto3" json:"create_time,omitempty"`
	// Output only. Commit time of the stream.
	// If a stream is of `COMMITTED` type, then it will have a commit_time same as
	// `create_time`. If the stream is of `PENDING` type, commit_time being empty
	// means it is not committed.
	CommitTime *timestamppb.Timestamp `protobuf:"bytes,4,opt,name=commit_time,json=commitTime,proto3" json:"commit_time,omitempty"`
	// Output only. The schema of the destination table. It is only returned in
	// `CreateWriteStream` response. Caller should generate data that's
	// compatible with this schema to send in initial `AppendRowsRequest`.
	// The table schema could go out of date during the life time of the stream.
	TableSchema *TableSchema `protobuf:"bytes,5,opt,name=table_schema,json=tableSchema,proto3" json:"table_schema,omitempty"`
	// Id set by client to annotate its identity.
	ExternalId string `protobuf:"bytes,6,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"`
	// contains filtered or unexported fields
}

Information about a single stream that gets data inside the storage system.

func (*WriteStream) Descriptor deprecated

func (*WriteStream) Descriptor() ([]byte, []int)

Deprecated: Use WriteStream.ProtoReflect.Descriptor instead.

func (*WriteStream) GetCommitTime

func (x *WriteStream) GetCommitTime() *timestamppb.Timestamp

func (*WriteStream) GetCreateTime

func (x *WriteStream) GetCreateTime() *timestamppb.Timestamp

func (*WriteStream) GetExternalId

func (x *WriteStream) GetExternalId() string

func (*WriteStream) GetName

func (x *WriteStream) GetName() string

func (*WriteStream) GetTableSchema

func (x *WriteStream) GetTableSchema() *TableSchema

func (*WriteStream) GetType

func (x *WriteStream) GetType() WriteStream_Type

func (*WriteStream) ProtoMessage

func (*WriteStream) ProtoMessage()

func (*WriteStream) ProtoReflect

func (x *WriteStream) ProtoReflect() protoreflect.Message

func (*WriteStream) Reset

func (x *WriteStream) Reset()

func (*WriteStream) String

func (x *WriteStream) String() string

type WriteStream_Type

type WriteStream_Type int32
const (
	// Unknown type.
	WriteStream_TYPE_UNSPECIFIED WriteStream_Type = 0
	// Data will commit automatically and appear as soon as the write is
	// acknowledged.
	WriteStream_COMMITTED WriteStream_Type = 1
	// Data is invisible until the stream is committed.
	WriteStream_PENDING WriteStream_Type = 2
	// Data is only visible up to the offset to which it was flushed.
	WriteStream_BUFFERED WriteStream_Type = 3
)

func (WriteStream_Type) Descriptor

func (WriteStream_Type) Enum

func (WriteStream_Type) EnumDescriptor deprecated

func (WriteStream_Type) EnumDescriptor() ([]byte, []int)

Deprecated: Use WriteStream_Type.Descriptor instead.

func (WriteStream_Type) Number

func (WriteStream_Type) String

func (x WriteStream_Type) String() string

func (WriteStream_Type) Type

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL