Index
Bigtable
(interface)ArrayValue
(message)Cell
(message)CheckAndMutateRowRequest
(message)CheckAndMutateRowResponse
(message)Column
(message)ColumnMetadata
(message)ColumnRange
(message)ExecuteQueryRequest
(message)ExecuteQueryResponse
(message)Family
(message)FullReadStatsView
(message)GenerateInitialChangeStreamPartitionsRequest
(message)GenerateInitialChangeStreamPartitionsResponse
(message)MutateRowRequest
(message)MutateRowResponse
(message)MutateRowsRequest
(message)MutateRowsRequest.Entry
(message)MutateRowsResponse
(message)MutateRowsResponse.Entry
(message)Mutation
(message)Mutation.AddToCell
(message)Mutation.DeleteFromColumn
(message)Mutation.DeleteFromFamily
(message)Mutation.DeleteFromRow
(message)Mutation.MergeToCell
(message)Mutation.SetCell
(message)PartialResultSet
(message)PingAndWarmRequest
(message)PingAndWarmResponse
(message)ProtoFormat
(message)ProtoRows
(message)ProtoRowsBatch
(message)ProtoSchema
(message)RateLimitInfo
(message)ReadChangeStreamRequest
(message)ReadChangeStreamResponse
(message)ReadChangeStreamResponse.CloseStream
(message)ReadChangeStreamResponse.DataChange
(message)ReadChangeStreamResponse.DataChange.Type
(enum)ReadChangeStreamResponse.Heartbeat
(message)ReadChangeStreamResponse.MutationChunk
(message)ReadChangeStreamResponse.MutationChunk.ChunkInfo
(message)ReadIterationStats
(message)ReadModifyWriteRowRequest
(message)ReadModifyWriteRowResponse
(message)ReadModifyWriteRule
(message)ReadRowsRequest
(message)ReadRowsRequest.RequestStatsView
(enum)ReadRowsResponse
(message)ReadRowsResponse.CellChunk
(message)RequestLatencyStats
(message)RequestStats
(message)ResponseParams
(message)ResultSetMetadata
(message)Row
(message)RowFilter
(message)RowFilter.Chain
(message)RowFilter.Condition
(message)RowFilter.Interleave
(message)RowRange
(message)RowSet
(message)SampleRowKeysRequest
(message)SampleRowKeysResponse
(message)StreamContinuationToken
(message)StreamContinuationTokens
(message)StreamPartition
(message)TimestampRange
(message)Type
(message)Type.Aggregate
(message)Type.Aggregate.HyperLogLogPlusPlusUniqueCount
(message)Type.Aggregate.Max
(message)Type.Aggregate.Min
(message)Type.Aggregate.Sum
(message)Type.Array
(message)Type.Bool
(message)Type.Bytes
(message)Type.Bytes.Encoding
(message)Type.Bytes.Encoding.Raw
(message)Type.Date
(message)Type.Float32
(message)Type.Float64
(message)Type.Int64
(message)Type.Int64.Encoding
(message)Type.Int64.Encoding.BigEndianBytes
(message)Type.Map
(message)Type.String
(message)Type.String.Encoding
(message)Type.String.Encoding.Utf8Bytes
(message)Type.String.Encoding.Utf8Raw
(message)Type.Struct
(message)Type.Struct.Field
(message)Type.Timestamp
(message)Value
(message)ValueRange
(message)
Bigtable
Service for reading from and writing to existing Bigtable tables.
CheckAndMutateRow |
---|
Mutates a row atomically based on the output of a predicate Reader filter.
|
ExecuteQuery |
---|
Executes a SQL query against a particular Bigtable instance.
|
GenerateInitialChangeStreamPartitions |
---|
Returns the current list of partitions that make up the table's change stream. The union of partitions will cover the entire keyspace. Partitions can be read with
|
MutateRow |
---|
Mutates a row atomically. Cells already present in the row are left unchanged unless explicitly changed by
|
MutateRows |
---|
Mutates multiple rows in a batch. Each individual row is mutated atomically as in MutateRow, but the entire batch is not executed atomically.
|
PingAndWarm |
---|
Warm up associated instance metadata for this connection. This call is not required but may be useful for connection keep-alive.
|
ReadChangeStream |
---|
Reads changes from a table's change stream. Changes will reflect both user-initiated mutations and mutations that are caused by garbage collection. NOTE: This API is intended to be used by Apache Beam BigtableIO.
|
ReadModifyWriteRow |
---|
Modifies a row atomically on the server. The method reads the latest existing timestamp and value from the specified columns and writes a new entry based on pre-defined read/modify/write rules. The new value for the timestamp is the greater of the existing timestamp or the current server time. The method returns the new contents of all modified cells.
|
ReadRows |
---|
Streams back the contents of all requested rows in key order, optionally applying the same Reader filter to each. Depending on their size, rows and cells may be broken up across multiple responses, but atomicity of each row will still be preserved. See the ReadRowsResponse documentation for details.
|
SampleRowKeys |
---|
Returns a sample of row keys in the table. The returned row keys will delimit contiguous sections of the table of approximately equal size, which can be used to break up the data for distributed tasks like mapreduces.
|
ArrayValue
ArrayValue
is an ordered list of Value
.
Fields | |
---|---|
values[] |
The ordered elements in the array. |
Cell
Specifies (some of) the contents of a single row/column/timestamp of a table.
Fields | |
---|---|
timestamp_micros |
The cell's stored timestamp, which also uniquely identifies it within its column. Values are always expressed in microseconds, but individual tables may set a coarser granularity to further restrict the allowed values. For example, a table which specifies millisecond granularity will only allow values of |
value |
The value stored in the cell. May contain any byte string, including the empty string, up to 100MiB in length. |
labels[] |
Labels applied to the cell by a |
CheckAndMutateRowRequest
Request message for Bigtable.CheckAndMutateRow.
Fields | |
---|---|
table_name |
Optional. The unique name of the table to which the conditional mutation should be applied. Values are of the form Authorization requires one or more of the following IAM permissions on the specified resource
|
authorized_view_name |
Optional. The unique name of the AuthorizedView to which the conditional mutation should be applied. Values are of the form Authorization requires one or more of the following IAM permissions on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
row_key |
Required. The key of the row to which the conditional mutation should be applied. |
predicate_filter |
The filter to be applied to the contents of the specified row. Depending on whether or not any results are yielded, either |
true_mutations[] |
Changes to be atomically applied to the specified row if |
false_mutations[] |
Changes to be atomically applied to the specified row if |
CheckAndMutateRowResponse
Response message for Bigtable.CheckAndMutateRow.
Fields | |
---|---|
predicate_matched |
Whether or not the request's |
Column
Specifies (some of) the contents of a single row/column intersection of a table.
Fields | |
---|---|
qualifier |
The unique key which identifies this column within its family. This is the same key that's used to identify the column in, for example, a RowFilter which sets its |
cells[] |
Must not be empty. Sorted in order of decreasing "timestamp_micros". |
ColumnMetadata
Describes a column in a Bigtable Query Language result set.
Fields | |
---|---|
name |
The name of the column. |
type |
The type of the column. |
ColumnRange
Specifies a contiguous range of columns within a single column family. The range spans from <column_family>:<start_qualifier> to <column_family>:<end_qualifier>, where both bounds can be either inclusive or exclusive.
Fields | |
---|---|
family_name |
The name of the column family within which this range falls. |
Union field start_qualifier . The column qualifier at which to start the range (within column_family ). If neither field is set, interpreted as the empty string, inclusive. start_qualifier can be only one of the following: |
|
start_qualifier_closed |
Used when giving an inclusive lower bound for the range. |
start_qualifier_open |
Used when giving an exclusive lower bound for the range. |
Union field end_qualifier . The column qualifier at which to end the range (within column_family ). If neither field is set, interpreted as the infinite string, exclusive. end_qualifier can be only one of the following: |
|
end_qualifier_closed |
Used when giving an inclusive upper bound for the range. |
end_qualifier_open |
Used when giving an exclusive upper bound for the range. |
ExecuteQueryRequest
Request message for Bigtable.ExecuteQuery
Fields | |
---|---|
instance_name |
Required. The unique name of the instance against which the query should be executed. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
Optional. This value specifies routing for replication. If not specified, the |
query |
Required. The query string. |
resume_token |
Optional. If this request is resuming a previously interrupted query execution, |
params |
Required. params contains string type keys and Bigtable type values that bind to placeholders in the query string. In query string, a parameter placeholder consists of the For example, if In case of Value.kind is not set, it will be set to corresponding null value in googlesql. Value.type should always be set and no inference of type will be made from Value.kind. If Value.type is not set, we will return INVALID_ARGUMENT error. |
Union field data_format . Required. Requested data format for the response. data_format can be only one of the following: |
|
proto_format |
Protocol buffer format as described by ProtoSchema and ProtoRows messages. |
ExecuteQueryResponse
Response message for Bigtable.ExecuteQuery
Fields | |
---|---|
Union field response . The first response streamed from the server is of type ResultSetMetadata and includes information about the columns and types of the result set. From there on, we stream PartialResultSet messages with no additional information. PartialResultSet will contain resume_token to restart the response if query interrupts. In case of resumption with resume_token , the server will not resend the ResultSetMetadata. response can be only one of the following: |
|
metadata |
Structure of rows in this response stream. The first (and only the first) response streamed from the server will be of this type. |
results |
A partial result set with row data potentially including additional instructions on how recent past and future partial responses should be interpreted. |
Family
Specifies (some of) the contents of a single row/column family intersection of a table.
Fields | |
---|---|
name |
The unique key which identifies this family within its row. This is the same key that's used to identify the family in, for example, a RowFilter which sets its "family_name_regex_filter" field. Must match |
columns[] |
Must not be empty. Sorted in order of increasing "qualifier". |
FullReadStatsView
FullReadStatsView captures all known information about a read.
Fields | |
---|---|
read_iteration_stats |
Iteration stats describe how efficient the read is, e.g. comparing rows seen vs. rows returned or cells seen vs cells returned can provide an indication of read efficiency (the higher the ratio of seen to retuned the better). |
request_latency_stats |
Request latency stats describe the time taken to complete a request, from the server side. |
GenerateInitialChangeStreamPartitionsRequest
NOTE: This API is intended to be used by Apache Beam BigtableIO. Request message for Bigtable.GenerateInitialChangeStreamPartitions.
Fields | |
---|---|
table_name |
Required. The unique name of the table from which to get change stream partitions. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. Single cluster routing must be configured on the profile. |
GenerateInitialChangeStreamPartitionsResponse
NOTE: This API is intended to be used by Apache Beam BigtableIO. Response message for Bigtable.GenerateInitialChangeStreamPartitions.
Fields | |
---|---|
partition |
A partition of the change stream. |
MutateRowRequest
Request message for Bigtable.MutateRow.
Fields | |
---|---|
table_name |
Optional. The unique name of the table to which the mutation should be applied. Values are of the form Authorization requires the following IAM permission on the specified resource
|
authorized_view_name |
Optional. The unique name of the AuthorizedView to which the mutation should be applied. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
row_key |
Required. The key of the row to which the mutation should be applied. |
mutations[] |
Required. Changes to be atomically applied to the specified row. Entries are applied in order, meaning that earlier mutations can be masked by later ones. Must contain at least one entry and at most 100000. |
MutateRowResponse
This type has no fields.
Response message for Bigtable.MutateRow.
MutateRowsRequest
Request message for BigtableService.MutateRows.
Fields | |
---|---|
table_name |
Optional. The unique name of the table to which the mutations should be applied. Values are of the form Authorization requires the following IAM permission on the specified resource
|
authorized_view_name |
Optional. The unique name of the AuthorizedView to which the mutations should be applied. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
entries[] |
Required. The row keys and corresponding mutations to be applied in bulk. Each entry is applied as an atomic mutation, but the entries may be applied in arbitrary order (even between entries for the same row). At least one entry must be specified, and in total the entries can contain at most 100000 mutations. |
Entry
A mutation for a given row.
Fields | |
---|---|
row_key |
The key of the row to which the |
mutations[] |
Required. Changes to be atomically applied to the specified row. Mutations are applied in order, meaning that earlier mutations can be masked by later ones. You must specify at least one mutation. |
MutateRowsResponse
Response message for BigtableService.MutateRows.
Fields | |
---|---|
entries[] |
One or more results for Entries from the batch request. |
rate_limit_info |
Information about how client should limit the rate (QPS). Primirily used by supported official Cloud Bigtable clients. If unset, the rate limit info is not provided by the server. |
Entry
The result of applying a passed mutation in the original request.
Fields | |
---|---|
index |
The index into the original request's |
status |
The result of the request Entry identified by |
Mutation
Specifies a particular change to be made to the contents of a row.
Fields | |
---|---|
Union field mutation . Which of the possible Mutation types to apply. mutation can be only one of the following: |
|
set_cell |
Set a cell's value. |
add_to_cell |
Incrementally updates an |
merge_to_cell |
Merges accumulated state to an |
delete_from_column |
Deletes cells from a column. |
delete_from_family |
Deletes cells from a column family. |
delete_from_row |
Deletes cells from the entire row. |
AddToCell
A Mutation which incrementally updates a cell in an Aggregate
family.
Fields | |
---|---|
family_name |
The name of the |
column_qualifier |
The qualifier of the column into which new data should be added. This must be a |
timestamp |
The timestamp of the cell to which new data should be added. This must be a |
input |
The input value to be accumulated into the specified cell. This must be compatible with the family's |
DeleteFromColumn
A Mutation which deletes cells from the specified column, optionally restricting the deletions to a given timestamp range.
Fields | |
---|---|
family_name |
The name of the family from which cells should be deleted. Must match |
column_qualifier |
The qualifier of the column from which cells should be deleted. Can be any byte string, including the empty string. |
time_range |
The range of timestamps within which cells should be deleted. |
DeleteFromFamily
A Mutation which deletes all cells from the specified column family.
Fields | |
---|---|
family_name |
The name of the family from which cells should be deleted. Must match |
DeleteFromRow
This type has no fields.
A Mutation which deletes all cells from the containing row.
MergeToCell
A Mutation which merges accumulated state into a cell in an Aggregate
family.
Fields | |
---|---|
family_name |
The name of the |
column_qualifier |
The qualifier of the column into which new data should be added. This must be a |
timestamp |
The timestamp of the cell to which new data should be added. This must be a |
input |
The input value to be merged into the specified cell. This must be compatible with the family's |
SetCell
A Mutation which sets the value of the specified cell.
Fields | |
---|---|
family_name |
The name of the family into which new data should be written. Must match |
column_qualifier |
The qualifier of the column into which new data should be written. Can be any byte string, including the empty string. |
timestamp_micros |
The timestamp of the cell into which new data should be written. Use -1 for current Bigtable server time. Otherwise, the client should set this value itself, noting that the default value is a timestamp of zero if the field is left unspecified. Values must match the granularity of the table (e.g. micros, millis). |
value |
The value to be written into the specified cell. |
PartialResultSet
A partial result set from the streaming query API. CBT client will buffer partial_rows from result_sets until it gets a resumption_token.
Fields | |
---|---|
resume_token |
An opaque token sent by the server to allow query resumption and signal the client to accumulate If there is a batch in progress, a non-empty The server may set 'resume_token' without a 'partial_rows'. If there is a batch in progress the client should yield it. The server will also send a sentinel |
estimated_batch_size |
Estimated size of a new batch. The server will always set this when returning the first The client can use this estimate to allocate an initial buffer for the batched results. This helps minimize the number of allocations required, though the buffer size may still need to be increased if the estimate is too low. |
Union field partial_rows . Partial Rows in one of the supported formats. It may require many PartialResultSets to stream a batch of rows that can decoded on the client. The client should buffer partial_rows until it gets a resume_token , at which point the batch is complete and can be decoded and yielded to the user. Each sub-message documents the appropriate way to combine results. partial_rows can be only one of the following: |
|
proto_rows_batch |
Partial rows in serialized ProtoRows format. |
PingAndWarmRequest
Request message for client connection keep-alive and warming.
Fields | |
---|---|
name |
Required. The unique name of the instance to check permissions for as well as respond. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
PingAndWarmResponse
This type has no fields.
Response message for Bigtable.PingAndWarm connection keepalive and warming.
ProtoFormat
This type has no fields.
Protocol buffers format descriptor, as described by Messages ProtoSchema and ProtoRows
ProtoRows
Rows represented in proto format.
This should be constructed by concatenating the batch_data
from each of the relevant ProtoRowsBatch
messages and parsing the result as a ProtoRows
message.
Fields | |
---|---|
values[] |
A proto rows message consists of a list of values. Every N complete values defines a row, where N is equal to the number of entries in the |
ProtoRowsBatch
Batch of serialized ProtoRows.
Fields | |
---|---|
batch_data |
Merge partial results by concatenating these bytes, then parsing the overall value as a |
ProtoSchema
ResultSet schema in proto format
Fields | |
---|---|
columns[] |
The columns in the result set. |
RateLimitInfo
Information about how client should adjust the load to Bigtable.
Fields | |
---|---|
period |
Time that clients should wait before adjusting the target rate again. If clients adjust rate too frequently, the impact of the previous adjustment may not have been taken into account and may over-throttle or under-throttle. If clients adjust rate too slowly, they will not be responsive to load changes on server side, and may over-throttle or under-throttle. |
factor |
If it has been at least one The client can measure its load using any unit that's comparable over time. For example, QPS can be used as long as each request involves a similar amount of work. |
ReadChangeStreamRequest
NOTE: This API is intended to be used by Apache Beam BigtableIO. Request message for Bigtable.ReadChangeStream.
Fields | |
---|---|
table_name |
Required. The unique name of the table from which to read a change stream. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. Single cluster routing must be configured on the profile. |
partition |
The partition to read changes from. |
end_time |
If specified, OK will be returned when the stream advances beyond this time. Otherwise, changes will be continuously delivered on the stream. This value is inclusive and will be truncated to microsecond granularity. |
heartbeat_duration |
If specified, the duration between |
Union field start_from . Options for describing where we want to start reading from the stream. start_from can be only one of the following: |
|
start_time |
Start reading the stream at the specified timestamp. This timestamp must be within the change stream retention period, less than or equal to the current time, and after change stream creation, whichever is greater. This value is inclusive and will be truncated to microsecond granularity. |
continuation_tokens |
Tokens that describe how to resume reading a stream where reading previously left off. If specified, changes will be read starting at the the position. Tokens are delivered on the stream as part of If a single token is provided, the token's partition must exactly match the request's partition. If multiple tokens are provided, as in the case of a partition merge, the union of the token partitions must exactly cover the request's partition. Otherwise, INVALID_ARGUMENT will be returned. |
ReadChangeStreamResponse
NOTE: This API is intended to be used by Apache Beam BigtableIO. Response message for Bigtable.ReadChangeStream.
Fields | |
---|---|
Union field stream_record . The data or control message on the stream. stream_record can be only one of the following: |
|
data_change |
A mutation to the partition. |
heartbeat |
A periodic heartbeat message. |
close_stream |
An indication that the stream should be closed. |
CloseStream
A message indicating that the client should stop reading from the stream. If status is OK and continuation_tokens
& new_partitions
are empty, the stream has finished (for example if there was an end_time
specified). If continuation_tokens
& new_partitions
are present, then a change in partitioning requires the client to open a new stream for each token to resume reading. Example:
[B, D) ends
|
v
new_partitions: [A, C) [C, E)
continuation_tokens.partitions: [B,C) [C,D)
^---^ ^---^
^ ^
| |
| StreamContinuationToken 2
|
StreamContinuationToken 1
To read the new partition [A,C), supply the continuation tokens whose ranges cover the new partition, for example ContinuationToken[A,B) & ContinuationToken[B,C).
Fields | |
---|---|
status |
The status of the stream. |
continuation_tokens[] |
If non-empty, contains the information needed to resume reading their associated partitions. |
new_partitions[] |
If non-empty, contains the new partitions to start reading from, which are related to but not necessarily identical to the partitions for the above |
DataChange
A message corresponding to one or more mutations to the partition being streamed. A single logical DataChange
message may also be split across a sequence of multiple individual messages. Messages other than the first in a sequence will only have the type
and chunks
fields populated, with the final message in the sequence also containing done
set to true.
Fields | |
---|---|
type |
The type of the mutation. |
source_cluster_id |
The cluster where the mutation was applied. Not set when |
row_key |
The row key for all mutations that are part of this |
commit_timestamp |
The timestamp at which the mutation was applied on the Bigtable server. |
tiebreaker |
A value that lets stream consumers reconstruct Bigtable's conflict resolution semantics. https://cloud.google.com/bigtable/docs/writes#conflict-resolution In the event that the same row key, column family, column qualifier, timestamp are modified on different clusters at the same |
chunks[] |
The mutations associated with this change to the partition. May contain complete mutations or chunks of a multi-message chunked |
done |
When true, indicates that the entire |
token |
An encoded position for this stream's partition to restart reading from. This token is for the StreamPartition from the request. |
estimated_low_watermark |
An estimate of the commit timestamp that is usually lower than or equal to any timestamp for a record that will be delivered in the future on the stream. It is possible that, under particular circumstances that a future record has a timestamp is is lower than a previously seen timestamp. For an example usage see https://beam.apache.org/documentation/basics/#watermarks |
Type
The type of mutation.
Enums | |
---|---|
TYPE_UNSPECIFIED |
The type is unspecified. |
USER |
A user-initiated mutation. |
GARBAGE_COLLECTION |
A system-initiated mutation as part of garbage collection. https://cloud.google.com/bigtable/docs/garbage-collection |
CONTINUATION |
This is a continuation of a multi-message change. |
Heartbeat
A periodic message with information that can be used to checkpoint the state of a stream.
Fields | |
---|---|
continuation_token |
A token that can be provided to a subsequent |
estimated_low_watermark |
An estimate of the commit timestamp that is usually lower than or equal to any timestamp for a record that will be delivered in the future on the stream. It is possible that, under particular circumstances that a future record has a timestamp that is lower than a previously seen timestamp. For an example usage see https://beam.apache.org/documentation/basics/#watermarks |
MutationChunk
A partial or complete mutation.
Fields | |
---|---|
chunk_info |
If set, then the mutation is a |
mutation |
If this is a continuation of a chunked message ( |
ChunkInfo
Information about the chunking of this mutation. Only SetCell
mutations can be chunked, and all chunks for a SetCell
will be delivered contiguously with no other mutation types interleaved.
Fields | |
---|---|
chunked_value_size |
The total value size of all the chunks that make up the |
chunked_value_offset |
The byte offset of this chunk into the total value size of the mutation. |
last_chunk |
When true, this is the last chunk of a chunked |
ReadIterationStats
ReadIterationStats captures information about the iteration of rows or cells over the course of a read, e.g. how many results were scanned in a read operation versus the results returned.
Fields | |
---|---|
rows_seen_count |
The rows seen (scanned) as part of the request. This includes the count of rows returned, as captured below. |
rows_returned_count |
The rows returned as part of the request. |
cells_seen_count |
The cells seen (scanned) as part of the request. This includes the count of cells returned, as captured below. |
cells_returned_count |
The cells returned as part of the request. |
ReadModifyWriteRowRequest
Request message for Bigtable.ReadModifyWriteRow.
Fields | |
---|---|
table_name |
Optional. The unique name of the table to which the read/modify/write rules should be applied. Values are of the form Authorization requires the following IAM permission on the specified resource
|
authorized_view_name |
Optional. The unique name of the AuthorizedView to which the read/modify/write rules should be applied. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
row_key |
Required. The key of the row to which the read/modify/write rules should be applied. |
rules[] |
Required. Rules specifying how the specified row's contents are to be transformed into writes. Entries are applied in order, meaning that earlier rules will affect the results of later ones. At least one entry must be specified, and there can be at most 100000 rules. |
ReadModifyWriteRowResponse
Response message for Bigtable.ReadModifyWriteRow.
Fields | |
---|---|
row |
A Row containing the new contents of all cells modified by the request. |
ReadModifyWriteRule
Specifies an atomic read/modify/write operation on the latest value of the specified column.
Fields | |
---|---|
family_name |
The name of the family to which the read/modify/write should be applied. Must match |
column_qualifier |
The qualifier of the column to which the read/modify/write should be applied. Can be any byte string, including the empty string. |
Union field rule . The rule used to determine the column's new latest value from its current latest value. rule can be only one of the following: |
|
append_value |
Rule specifying that |
increment_amount |
Rule specifying that |
ReadRowsRequest
Request message for Bigtable.ReadRows.
Fields | |
---|---|
table_name |
Optional. The unique name of the table from which to read. Values are of the form Authorization requires the following IAM permission on the specified resource
|
authorized_view_name |
Optional. The unique name of the AuthorizedView from which to read. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
rows |
The row keys and/or ranges to read sequentially. If not specified, reads from all rows. |
filter |
The filter to apply to the contents of the specified row(s). If unset, reads the entirety of each row. |
rows_limit |
The read will stop after committing to N rows' worth of results. The default (zero) is to return all results. |
request_stats_view |
The view into RequestStats, as described above. |
reversed |
Experimental API - Please note that this API is currently experimental and can change in the future. Return rows in lexiographical descending order of the row keys. The row contents will not be affected by this flag. Example result set:
|
RequestStatsView
The desired view into RequestStats that should be returned in the response.
See also: RequestStats message.
Enums | |
---|---|
REQUEST_STATS_VIEW_UNSPECIFIED |
The default / unset value. The API will default to the NONE option below. |
REQUEST_STATS_NONE |
Do not include any RequestStats in the response. This will leave the RequestStats embedded message unset in the response. |
REQUEST_STATS_FULL |
Include the full set of available RequestStats in the response, applicable to this read. |
ReadRowsResponse
Response message for Bigtable.ReadRows.
Fields | |
---|---|
chunks[] |
A collection of a row's contents as part of the read request. |
last_scanned_row_key |
Optionally the server might return the row key of the last row it has scanned. The client can use this to construct a more efficient retry request if needed: any row keys or portions of ranges less than this row key can be dropped from the request. This is primarily useful for cases where the server has read a lot of data that was filtered out since the last committed row key, allowing the client to skip that work on a retry. |
request_stats |
If requested, return enhanced query performance statistics. The field request_stats is empty in a streamed response unless the ReadRowsResponse message contains request_stats in the last message of the stream. Always returned when requested, even when the read request returns an empty response. |
CellChunk
Specifies a piece of a row's contents returned as part of the read response stream.
Fields | |
---|---|
row_key |
The row key for this chunk of data. If the row key is empty, this CellChunk is a continuation of the same row as the previous CellChunk in the response stream, even if that CellChunk was in a previous ReadRowsResponse message. |
family_name |
The column family name for this chunk of data. If this message is not present this CellChunk is a continuation of the same column family as the previous CellChunk. The empty string can occur as a column family name in a response so clients must check explicitly for the presence of this message, not just for |
qualifier |
The column qualifier for this chunk of data. If this message is not present, this CellChunk is a continuation of the same column as the previous CellChunk. Column qualifiers may be empty so clients must check for the presence of this message, not just for |
timestamp_micros |
The cell's stored timestamp, which also uniquely identifies it within its column. Values are always expressed in microseconds, but individual tables may set a coarser granularity to further restrict the allowed values. For example, a table which specifies millisecond granularity will only allow values of |
labels[] |
Labels applied to the cell by a |
value |
The value stored in the cell. Cell values can be split across multiple CellChunks. In that case only the value field will be set in CellChunks after the first: the timestamp and labels will only be present in the first CellChunk, even if the first CellChunk came in a previous ReadRowsResponse. |
value_size |
If this CellChunk is part of a chunked cell value and this is not the final chunk of that cell, value_size will be set to the total length of the cell value. The client can use this size to pre-allocate memory to hold the full cell value. |
Union field row_status . Signals to the client concerning previous CellChunks received. row_status can be only one of the following: |
|
reset_row |
Indicates that the client should drop all previous chunks for |
commit_row |
Indicates that the client can safely process all previous chunks for |
RequestLatencyStats
RequestLatencyStats provides a measurement of the latency of the request as it interacts with different systems over its lifetime, e.g. how long the request took to execute within a frontend server.
Fields | |
---|---|
frontend_server_latency |
The latency measured by the frontend server handling this request, from when the request was received, to when this value is sent back in the response. For more context on the component that is measuring this latency, see: https://cloud.google.com/bigtable/docs/overview Note: This value may be slightly shorter than the value reported into aggregate latency metrics in Monitoring for this request (https://cloud.google.com/bigtable/docs/monitoring-instance) as this value needs to be sent in the response before the latency measurement including that transmission is finalized. Note: This value includes the end-to-end latency of contacting nodes in the targeted cluster, e.g. measuring from when the first byte arrives at the frontend server, to when this value is sent back as the last value in the response, including any latency incurred by contacting nodes, waiting for results from nodes, and finally sending results from nodes back to the caller. |
RequestStats
RequestStats is the container for additional information pertaining to a single request, helpful for evaluating the performance of the sent request. Currently, the following method is supported: google.bigtable.v2.ReadRows
Fields | |
---|---|
Union field See the messages above for additional context. |
|
full_read_stats_view |
Available with the ReadRowsRequest.RequestStatsView.REQUEST_STATS_FULL view, see package google.bigtable.v2. |
ResponseParams
Response metadata proto
Fields | |
---|---|
zone_id |
The cloud bigtable zone associated with the cluster. |
cluster_id |
Identifier for a cluster that represents set of bigtable resources. |
ResultSetMetadata
Describes the structure of a Bigtable result set.
Fields | |
---|---|
Union field schema . The schema of the ResultSet, contains ordered list of column names with types schema can be only one of the following: |
|
proto_schema |
Schema in proto format |
Row
Specifies the complete (requested) contents of a single row of a table. Rows which exceed 256MiB in size cannot be read in full.
Fields | |
---|---|
key |
The unique key which identifies this row within its table. This is the same key that's used to identify the row in, for example, a MutateRowRequest. May contain any non-empty byte string up to 4KiB in length. |
families[] |
May be empty, but only if the entire row is empty. The mutual ordering of column families is not specified. |
RowFilter
Takes a row as input and produces an alternate view of the row based on specified rules. For example, a RowFilter might trim down a row to include just the cells from columns matching a given regular expression, or might return all the cells of a row but not their values. More complicated filters can be composed out of these components to express requests such as, "within every column of a particular family, give just the two most recent cells which are older than timestamp X."
There are two broad categories of RowFilters (true filters and transformers), as well as two ways to compose simple filters into more complex ones (chains and interleaves). They work as follows:
True filters alter the input row by excluding some of its cells wholesale from the output row. An example of a true filter is the
value_regex_filter
, which excludes cells whose values don't match the specified pattern. All regex true filters use RE2 syntax (https://github.com/google/re2/wiki/Syntax) in raw byte mode (RE2::Latin1), and are evaluated as full matches. An important point to keep in mind is thatRE2(.)
is equivalent by default toRE2([^\n])
, meaning that it does not match newlines. When attempting to match an arbitrary byte, you should therefore use the escape sequence\C
, which may need to be further escaped as\\C
in your client language.Transformers alter the input row by changing the values of some of its cells in the output, without excluding them completely. Currently, the only supported transformer is the
strip_value_transformer
, which replaces every cell's value with the empty string.Chains and interleaves are described in more detail in the RowFilter.Chain and RowFilter.Interleave documentation.
The total serialized size of a RowFilter message must not exceed 20480 bytes, and RowFilters may not be nested within each other (in Chains or Interleaves) to a depth of more than 20.
Fields | |
---|---|
Union field filter . Which of the possible RowFilter types to apply. If none are set, this RowFilter returns all cells in the input row. filter can be only one of the following: |
|
chain |
Applies several RowFilters to the data in sequence, progressively narrowing the results. |
interleave |
Applies several RowFilters to the data in parallel and combines the results. |
condition |
Applies one of two possible RowFilters to the data based on the output of a predicate RowFilter. |
sink |
ADVANCED USE ONLY. Hook for introspection into the RowFilter. Outputs all cells directly to the output of the read rather than to any parent filter. Consider the following example:
Despite being excluded by the qualifier filter, a copy of every cell that reaches the sink is present in the final result. As with an Cannot be used within the |
pass_all_filter |
Matches all cells, regardless of input. Functionally equivalent to leaving |
block_all_filter |
Does not match any cells, regardless of input. Useful for temporarily disabling just part of a filter. |
row_key_regex_filter |
Matches only cells from rows whose keys satisfy the given RE2 regex. In other words, passes through the entire row when the key matches, and otherwise produces an empty row. Note that, since row keys can contain arbitrary bytes, the |
row_sample_filter |
Matches all cells from a row with probability p, and matches no cells from the row with probability 1-p. |
family_name_regex_filter |
Matches only cells from columns whose families satisfy the given RE2 regex. For technical reasons, the regex must not contain the |
column_qualifier_regex_filter |
Matches only cells from columns whose qualifiers satisfy the given RE2 regex. Note that, since column qualifiers can contain arbitrary bytes, the |
column_range_filter |
Matches only cells from columns within the given range. |
timestamp_range_filter |
Matches only cells with timestamps within the given range. |
value_regex_filter |
Matches only cells with values that satisfy the given regular expression. Note that, since cell values can contain arbitrary bytes, the |
value_range_filter |
Matches only cells with values that fall within the given range. |
cells_per_row_offset_filter |
Skips the first N cells of each row, matching all subsequent cells. If duplicate cells are present, as is possible when using an Interleave, each copy of the cell is counted separately. |
cells_per_row_limit_filter |
Matches only the first N cells of each row. If duplicate cells are present, as is possible when using an Interleave, each copy of the cell is counted separately. |
cells_per_column_limit_filter |
Matches only the most recent N cells within each column. For example, if N=2, this filter would match column |
strip_value_transformer |
Replaces each cell's value with the empty string. |
apply_label_transformer |
Applies the given label to all cells in the output row. This allows the client to determine which results were produced from which part of the filter. Values must be at most 15 characters in length, and match the RE2 pattern Due to a technical limitation, it is not currently possible to apply multiple labels to a cell. As a result, a Chain may have no more than one sub-filter which contains a |
Chain
A RowFilter which sends rows through several RowFilters in sequence.
Fields | |
---|---|
filters[] |
The elements of "filters" are chained together to process the input row: in row -> f(0) -> intermediate row -> f(1) -> ... -> f(N) -> out row The full chain is executed atomically. |
Condition
A RowFilter which evaluates one of two possible RowFilters, depending on whether or not a predicate RowFilter outputs any cells from the input row.
IMPORTANT NOTE: The predicate filter does not execute atomically with the true and false filters, which may lead to inconsistent or unexpected results. Additionally, Condition filters have poor performance, especially when filters are set for the false condition.
Fields | |
---|---|
predicate_filter |
If |
true_filter |
The filter to apply to the input row if |
false_filter |
The filter to apply to the input row if |
Interleave
A RowFilter which sends each row to each of several component RowFilters and interleaves the results.
Fields | |
---|---|
filters[] |
The elements of "filters" all process a copy of the input row, and the results are pooled, sorted, and combined into a single output row. If multiple cells are produced with the same column and timestamp, they will all appear in the output row in an unspecified mutual order. Consider the following example, with three filters:
All interleaved filters are executed atomically. |
RowRange
Specifies a contiguous range of rows.
Fields | |
---|---|
Union field start_key . The row key at which to start the range. If neither field is set, interpreted as the empty string, inclusive. start_key can be only one of the following: |
|
start_key_closed |
Used when giving an inclusive lower bound for the range. |
start_key_open |
Used when giving an exclusive lower bound for the range. |
Union field end_key . The row key at which to end the range. If neither field is set, interpreted as the infinite row key, exclusive. end_key can be only one of the following: |
|
end_key_open |
Used when giving an exclusive upper bound for the range. |
end_key_closed |
Used when giving an inclusive upper bound for the range. |
RowSet
Specifies a non-contiguous set of rows.
Fields | |
---|---|
row_keys[] |
Single rows included in the set. |
row_ranges[] |
Contiguous row ranges included in the set. |
SampleRowKeysRequest
Request message for Bigtable.SampleRowKeys.
Fields | |
---|---|
table_name |
Optional. The unique name of the table from which to sample row keys. Values are of the form Authorization requires the following IAM permission on the specified resource
|
authorized_view_name |
Optional. The unique name of the AuthorizedView from which to sample row keys. Values are of the form Authorization requires the following IAM permission on the specified resource
|
app_profile_id |
This value specifies routing for replication. If not specified, the "default" application profile will be used. |
SampleRowKeysResponse
Response message for Bigtable.SampleRowKeys.
Fields | |
---|---|
row_key |
Sorted streamed sequence of sample row keys in the table. The table might have contents before the first row key in the list and after the last one, but a key containing the empty string indicates "end of table" and will be the last response given, if present. Note that row keys in this list may not have ever been written to or read from, and users should therefore not make any assumptions about the row key structure that are specific to their use case. |
offset_bytes |
Approximate total storage space used by all rows in the table which precede |
StreamContinuationToken
NOTE: This API is intended to be used by Apache Beam BigtableIO. The information required to continue reading the data from a StreamPartition
from where a previous read left off.
Fields | |
---|---|
partition |
The partition that this token applies to. |
token |
An encoded position in the stream to restart reading from. |
StreamContinuationTokens
NOTE: This API is intended to be used by Apache Beam BigtableIO. The information required to continue reading the data from multiple StreamPartitions
from where a previous read left off.
Fields | |
---|---|
tokens[] |
List of continuation tokens. |
StreamPartition
NOTE: This API is intended to be used by Apache Beam BigtableIO. A partition of a change stream.
Fields | |
---|---|
row_range |
The row range covered by this partition and is specified by [ |
TimestampRange
Specified a contiguous range of microsecond timestamps.
Fields | |
---|---|
start_timestamp_micros |
Inclusive lower bound. If left empty, interpreted as 0. |
end_timestamp_micros |
Exclusive upper bound. If left empty, interpreted as infinity. |
Type
Type
represents the type of data that is written to, read from, or stored in Bigtable. It is heavily based on the GoogleSQL standard to help maintain familiarity and consistency across products and features.
For compatibility with Bigtable's existing untyped APIs, each Type
includes an Encoding
which describes how to convert to/from the underlying data.
Each encoding also defines the following properties:
- Order-preserving: Does the encoded value sort consistently with the original typed value? Note that Bigtable will always sort data based on the raw encoded value, not the decoded type.
- Example: BYTES values sort in the same order as their raw encodings.
- Counterexample: Encoding INT64 as a fixed-width decimal string does not preserve sort order when dealing with negative numbers.
INT64(1) > INT64(-1)
, butSTRING("-00001") > STRING("00001)
.
- Self-delimiting: If we concatenate two encoded values, can we always tell where the first one ends and the second one begins?
- Example: If we encode INT64s to fixed-width STRINGs, the first value will always contain exactly N digits, possibly preceded by a sign.
- Counterexample: If we concatenate two UTF-8 encoded STRINGs, we have no way to tell where the first one ends.
- Compatibility: Which other systems have matching encoding schemes? For example, does this encoding have a GoogleSQL equivalent? HBase? Java?
Fields | |
---|---|
Union field kind . The kind of type that this represents. kind can be only one of the following: |
|
bytes_type |
Bytes |
string_type |
String |
int64_type |
Int64 |
float32_type |
Float32 |
float64_type |
Float64 |
bool_type |
Bool |
timestamp_type |
Timestamp |
date_type |
Date |
aggregate_type |
Aggregate |
struct_type |
Struct |
array_type |
Array |
map_type |
Map |
Aggregate
A value that combines incremental updates into a summarized value.
Data is never directly written or read using type Aggregate
. Writes will provide either the input_type
or state_type
, and reads will always return the state_type
.
Fields | |
---|---|
input_type |
Type of the inputs that are accumulated by this |
state_type |
Output only. Type that holds the internal accumulator state for the |
Union field aggregator . Which aggregator function to use. The configured types must match. aggregator can be only one of the following: |
|
sum |
Sum aggregator. |
hllpp_unique_count |
HyperLogLogPlusPlusUniqueCount aggregator. |
max |
Max aggregator. |
min |
Min aggregator. |
HyperLogLogPlusPlusUniqueCount
This type has no fields.
Computes an approximate unique count over the input values. When using raw data as input, be careful to use a consistent encoding. Otherwise the same value encoded differently could count more than once, or two distinct values could count as identical. Input: Any, or omit for Raw State: TBD Special state conversions: Int64
(the unique count estimate)
Max
This type has no fields.
Computes the max of the input values. Allowed input: Int64
State: same as input
Min
This type has no fields.
Computes the min of the input values. Allowed input: Int64
State: same as input
Sum
This type has no fields.
Computes the sum of the input values. Allowed input: Int64
State: same as input
Array
An ordered list of elements of a given type. Values of type Array
are stored in Value.array_value
.
Fields | |
---|---|
element_type |
The type of the elements in the array. This must not be |
Bool
This type has no fields.
bool Values of type Bool
are stored in Value.bool_value
.
Bytes
Bytes Values of type Bytes
are stored in Value.bytes_value
.
Fields | |
---|---|
encoding |
The encoding to use when converting to/from lower level types. |
Encoding
Rules used to convert to/from lower level types.
Fields | |
---|---|
Union field encoding . Which encoding to use. encoding can be only one of the following: |
|
raw |
Use |
Raw
This type has no fields.
Leaves the value "as-is" * Order-preserving? Yes * Self-delimiting? No * Compatibility? N/A
Date
This type has no fields.
Date Values of type Date
are stored in Value.date_value
.
Float32
This type has no fields.
Float32 Values of type Float32
are stored in Value.float_value
.
Float64
This type has no fields.
Float64 Values of type Float64
are stored in Value.float_value
.
Int64
Int64 Values of type Int64
are stored in Value.int_value
.
Fields | |
---|---|
encoding |
The encoding to use when converting to/from lower level types. |
Encoding
Rules used to convert to/from lower level types.
Fields | |
---|---|
Union field encoding . Which encoding to use. encoding can be only one of the following: |
|
big_endian_bytes |
Use |
BigEndianBytes
Encodes the value as an 8-byte big endian twos complement Bytes
value. * Order-preserving? No (positive values only) * Self-delimiting? Yes * Compatibility? - BigQuery Federation BINARY
encoding - HBase Bytes.toBytes
- Java ByteBuffer.putLong()
with ByteOrder.BIG_ENDIAN
Fields | |
---|---|
bytes_type |
Deprecated: ignored if set. |
Map
A mapping of keys to values of a given type. Values of type Map
are stored in a Value.array_value
where each entry is another Value.array_value
with two elements (the key and the value, in that order). Normally encoded Map values won't have repeated keys, however, clients are expected to handle the case in which they do. If the same key appears multiple times, the last value takes precedence.
Fields | |
---|---|
key_type |
The type of a map key. Only |
value_type |
The type of the values in a map. |
String
String Values of type String
are stored in Value.string_value
.
Fields | |
---|---|
encoding |
The encoding to use when converting to/from lower level types. |
Encoding
Rules used to convert to/from lower level types.
Fields | |
---|---|
Union field encoding . Which encoding to use. encoding can be only one of the following: |
|
utf8_raw |
Deprecated: if set, converts to an empty |
utf8_bytes |
Use |
Utf8Bytes
This type has no fields.
UTF-8 encoding * Order-preserving? Yes (code point order) * Self-delimiting? No * Compatibility? - BigQuery Federation TEXT
encoding - HBase Bytes.toBytes
- Java String#getBytes(StandardCharsets.UTF_8)
Utf8Raw
This type has no fields.
Deprecated: prefer the equivalent Utf8Bytes
.
Struct
A structured data value, consisting of fields which map to dynamically typed values. Values of type Struct
are stored in Value.array_value
where entries are in the same order and number as field_types
.
Fields | |
---|---|
fields[] |
The names and types of the fields in this struct. |
Field
A struct field and its type.
Fields | |
---|---|
field_name |
The field name (optional). Fields without a |
type |
The type of values in this field. |
Timestamp
This type has no fields.
Timestamp Values of type Timestamp
are stored in Value.timestamp_value
.
Value
Value
represents a dynamically typed value. The typed fields in Value
are used as a transport encoding for the actual value (which may be of a more complex type). See the documentation of the Type
message for more details.
Fields | |
---|---|
type |
The verified Read results will never specify the encoding for When using composite types (Struct, Array, Map) only the outermost |
Union field The value is |
|
raw_value |
Represents a raw byte sequence with no type information. The |
raw_timestamp_micros |
Represents a raw cell timestamp with no type information. The |
bytes_value |
Represents a typed value transported as a byte sequence. |
string_value |
Represents a typed value transported as a string. |
int_value |
Represents a typed value transported as an integer. |
bool_value |
Represents a typed value transported as a boolean. |
float_value |
Represents a typed value transported as a floating point number. |
timestamp_value |
Represents a typed value transported as a timestamp. |
date_value |
Represents a typed value transported as a date. |
array_value |
Represents a typed value transported as a sequence of values. To differentiate between |
ValueRange
Specifies a contiguous range of raw byte values.
Fields | |
---|---|
Union field start_value . The value at which to start the range. If neither field is set, interpreted as the empty string, inclusive. start_value can be only one of the following: |
|
start_value_closed |
Used when giving an inclusive lower bound for the range. |
start_value_open |
Used when giving an exclusive lower bound for the range. |
Union field end_value . The value at which to end the range. If neither field is set, interpreted as the infinite string, exclusive. end_value can be only one of the following: |
|
end_value_closed |
Used when giving an inclusive upper bound for the range. |
end_value_open |
Used when giving an exclusive upper bound for the range. |