Classes
ArrayValue
ArrayValue
is an ordered list of Value
.
AuthorizedViewName
Resource name for the AuthorizedView
resource.
Bigtable
Service for reading from and writing to existing Bigtable tables.
Bigtable.BigtableBase
Base class for server-side implementations of Bigtable
Bigtable.BigtableClient
Client for Bigtable
BigtableClient
BigtableServiceApi client wrapper, for convenient use.
BigtableClientBuilder
Builder class for BigtableClient to provide simple configuration of credentials, endpoint etc.
BigtableClientImpl
BigtableServiceApi client wrapper, for convenient use.
BigtableServiceApiClient
BigtableServiceApi client wrapper, for convenient use.
BigtableServiceApiClient.ExecuteQueryStream
Server streaming methods for ExecuteQuery(ExecuteQueryRequest, CallSettings).
BigtableServiceApiClient.GenerateInitialChangeStreamPartitionsStream
Server streaming methods for GenerateInitialChangeStreamPartitions(GenerateInitialChangeStreamPartitionsRequest, CallSettings) .
BigtableServiceApiClient.MutateRowsStream
Server streaming methods for MutateRows(MutateRowsRequest, CallSettings).
BigtableServiceApiClient.ReadChangeStreamStream
Server streaming methods for ReadChangeStream(ReadChangeStreamRequest, CallSettings).
BigtableServiceApiClient.ReadRowsStream
Server streaming methods for ReadRows(ReadRowsRequest, CallSettings).
BigtableServiceApiClient.SampleRowKeysStream
Server streaming methods for SampleRowKeys(SampleRowKeysRequest, CallSettings).
BigtableServiceApiClientBuilder
Builder class for BigtableServiceApiClient to provide simple configuration of credentials, endpoint etc.
BigtableServiceApiClientImpl
BigtableServiceApi client wrapper implementation, for convenient use.
BigtableServiceApiSettings
Settings for BigtableServiceApiClient instances.
BigtableServiceApiSettingsExtensions
Extensions for use on BigtableServiceApiSettings.
BigtableVersionRange
A contiguous range of versions.
Cell
Specifies (some of) the contents of a single row/column/timestamp of a table.
CheckAndMutateRowRequest
Request message for Bigtable.CheckAndMutateRow.
CheckAndMutateRowResponse
Response message for Bigtable.CheckAndMutateRow.
Column
Specifies (some of) the contents of a single row/column intersection of a table.
ColumnMetadata
Describes a column in a Bigtable Query Language result set.
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.
ExecuteQueryRequest
Request message for Bigtable.ExecuteQuery
ExecuteQueryResponse
Response message for Bigtable.ExecuteQuery
Family
Specifies (some of) the contents of a single row/column family intersection of a table.
FeatureFlags
Feature flags supported or enabled by a client.
This is intended to be sent as part of request metadata to assure the server
that certain behaviors are safe to enable. This proto is meant to be
serialized and websafe-base64 encoded under the bigtable-features
metadata
key. The value will remain constant for the lifetime of a client and due to
HTTP2's HPACK compression, the request overhead will be tiny.
This is an internal implementation detail and should not be used by end users
directly.
FullReadStatsView
FullReadStatsView captures all known information about a read.
GenerateInitialChangeStreamPartitionsRequest
NOTE: This API is intended to be used by Apache Beam BigtableIO. Request message for Bigtable.GenerateInitialChangeStreamPartitions.
GenerateInitialChangeStreamPartitionsResponse
NOTE: This API is intended to be used by Apache Beam BigtableIO. Response message for Bigtable.GenerateInitialChangeStreamPartitions.
MutateRowRequest
Request message for Bigtable.MutateRow.
MutateRowResponse
Response message for Bigtable.MutateRow.
MutateRowsRequest
Request message for BigtableService.MutateRows.
MutateRowsRequest.Types
Container for nested types declared in the MutateRowsRequest message type.
MutateRowsRequest.Types.Entry
A mutation for a given row.
MutateRowsResponse
Response message for BigtableService.MutateRows.
MutateRowsResponse.Types
Container for nested types declared in the MutateRowsResponse message type.
MutateRowsResponse.Types.Entry
The result of applying a passed mutation in the original request.
Mutation
Specifies a particular change to be made to the contents of a row.
Mutation.Types
Container for nested types declared in the Mutation message type.
Mutation.Types.AddToCell
A Mutation which incrementally updates a cell in an Aggregate
family.
Mutation.Types.DeleteFromColumn
A Mutation which deletes cells from the specified column, optionally restricting the deletions to a given timestamp range.
Mutation.Types.DeleteFromFamily
A Mutation which deletes all cells from the specified column family.
Mutation.Types.DeleteFromRow
A Mutation which deletes all cells from the containing row.
Mutation.Types.MergeToCell
A Mutation which merges accumulated state into a cell in an Aggregate
family.
Mutation.Types.SetCell
A Mutation which sets the value of the specified cell.
Mutations
Static class with convenience methods for creating various kinds of Mutation instances.
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.
PingAndWarmRequest
Request message for client connection keep-alive and warming.
PingAndWarmResponse
Response message for Bigtable.PingAndWarm connection keepalive and warming.
ProtoFormat
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.
ProtoRowsBatch
Batch of serialized ProtoRows.
ProtoSchema
ResultSet schema in proto format
RateLimitInfo
Information about how client should adjust the load to Bigtable.
ReadChangeStreamRequest
NOTE: This API is intended to be used by Apache Beam BigtableIO. Request message for Bigtable.ReadChangeStream.
ReadChangeStreamResponse
NOTE: This API is intended to be used by Apache Beam BigtableIO. Response message for Bigtable.ReadChangeStream.
ReadChangeStreamResponse.Types
Container for nested types declared in the ReadChangeStreamResponse message type.
ReadChangeStreamResponse.Types.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).
ReadChangeStreamResponse.Types.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.
ReadChangeStreamResponse.Types.DataChange.Types
Container for nested types declared in the DataChange message type.
ReadChangeStreamResponse.Types.Heartbeat
A periodic message with information that can be used to checkpoint the state of a stream.
ReadChangeStreamResponse.Types.MutationChunk
A partial or complete mutation.
ReadChangeStreamResponse.Types.MutationChunk.Types
Container for nested types declared in the MutationChunk message type.
ReadChangeStreamResponse.Types.MutationChunk.Types.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.
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.
ReadModifyWriteRowRequest
Request message for Bigtable.ReadModifyWriteRow.
ReadModifyWriteRowResponse
Response message for Bigtable.ReadModifyWriteRow.
ReadModifyWriteRule
Specifies an atomic read/modify/write operation on the latest value of the specified column.
ReadModifyWriteRules
Static class with convenience methods for creating various kinds of ReadModifyWriteRule instances.
ReadRowsRequest
Request message for Bigtable.ReadRows.
ReadRowsRequest.Types
Container for nested types declared in the ReadRowsRequest message type.
ReadRowsResponse
Response message for Bigtable.ReadRows.
ReadRowsResponse.Types
Container for nested types declared in the ReadRowsResponse message type.
ReadRowsResponse.Types.CellChunk
Specifies a piece of a row's contents returned as part of the read response stream.
ReadRowsStream
The stream of Row instances returned from the server.
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.
RequestStats
RequestStats is the container for additional information pertaining to a single request, helpful for evaluating the performance of the sent request. Currently, there are the following supported methods:
- google.bigtable.v2.ReadRows
ResponseParams
Response metadata proto This is an experimental feature that will be used to get zone_id and cluster_id from response trailers to tag the metrics. This should not be used by customers directly
ResultSetMetadata
Describes the structure of a Bigtable result set.
Row
Specifies the complete (requested) contents of a single row of a table. Rows which exceed 256MiB in size cannot be read in full.
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.
RowFilter.Types
Container for nested types declared in the RowFilter message type.
RowFilter.Types.Chain
A RowFilter which sends rows through several RowFilters in sequence.
RowFilter.Types.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.
RowFilter.Types.Interleave
A RowFilter which sends each row to each of several component RowFilters and interleaves the results.
RowFilters
Static class with convenience methods for creating various kinds of RowFilter instances.
RowRange
Specifies a contiguous range of rows.
RowSet
Specifies a non-contiguous set of rows.
SampleRowKeysRequest
Request message for Bigtable.SampleRowKeys.
SampleRowKeysResponse
Response message for Bigtable.SampleRowKeys.
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.
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.
StreamPartition
NOTE: This API is intended to be used by Apache Beam BigtableIO. A partition of a change stream.
TimestampRange
Specified a contiguous range of microsecond timestamps.
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?
Type.Types
Container for nested types declared in the Type message type.
Type.Types.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
.
Type.Types.Aggregate.Types
Container for nested types declared in the Aggregate message type.
Type.Types.Aggregate.Types.HyperLogLogPlusPlusUniqueCount
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)
Type.Types.Aggregate.Types.Max
Computes the max of the input values.
Allowed input: Int64
State: same as input
Type.Types.Aggregate.Types.Min
Computes the min of the input values.
Allowed input: Int64
State: same as input
Type.Types.Aggregate.Types.Sum
Computes the sum of the input values.
Allowed input: Int64
State: same as input
Type.Types.Array
An ordered list of elements of a given type.
Values of type Array
are stored in Value.array_value
.
Type.Types.Bool
bool
Values of type Bool
are stored in Value.bool_value
.
Type.Types.Bytes
Bytes
Values of type Bytes
are stored in Value.bytes_value
.
Type.Types.Bytes.Types
Container for nested types declared in the Bytes message type.
Type.Types.Bytes.Types.Encoding
Rules used to convert to/from lower level types.
Type.Types.Bytes.Types.Encoding.Types
Container for nested types declared in the Encoding message type.
Type.Types.Bytes.Types.Encoding.Types.Raw
Leaves the value "as-is"
- Order-preserving? Yes
- Self-delimiting? No
- Compatibility? N/A
Type.Types.Date
Date
Values of type Date
are stored in Value.date_value
.
Type.Types.Float32
Float32
Values of type Float32
are stored in Value.float_value
.
Type.Types.Float64
Float64
Values of type Float64
are stored in Value.float_value
.
Type.Types.Int64
Int64
Values of type Int64
are stored in Value.int_value
.
Type.Types.Int64.Types
Container for nested types declared in the Int64 message type.
Type.Types.Int64.Types.Encoding
Rules used to convert to/from lower level types.
Type.Types.Int64.Types.Encoding.Types
Container for nested types declared in the Encoding message type.
Type.Types.Int64.Types.Encoding.Types.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()
withByteOrder.BIG_ENDIAN
- BigQuery Federation
Type.Types.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.
Type.Types.String
String
Values of type String
are stored in Value.string_value
.
Type.Types.String.Types
Container for nested types declared in the String message type.
Type.Types.String.Types.Encoding
Rules used to convert to/from lower level types.
Type.Types.String.Types.Encoding.Types
Container for nested types declared in the Encoding message type.
Type.Types.String.Types.Encoding.Types.Utf8Bytes
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)
- BigQuery Federation
Type.Types.String.Types.Encoding.Types.Utf8Raw
Deprecated: prefer the equivalent Utf8Bytes
.
Type.Types.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
.
Type.Types.Struct.Types
Container for nested types declared in the Struct message type.
Type.Types.Struct.Types.Field
A struct field and its type.
Type.Types.Timestamp
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.
ValueRange
Specifies a contiguous range of raw byte values.
Structs
BigtableVersion
A version which uniquely identifies a cell within a column.
Enums
AuthorizedViewName.ResourceNameType
The possible contents of AuthorizedViewName.
ColumnRange.EndQualifierOneofCase
Enum of possible cases for the "end_qualifier" oneof.
ColumnRange.StartQualifierOneofCase
Enum of possible cases for the "start_qualifier" oneof.
ExecuteQueryRequest.DataFormatOneofCase
Enum of possible cases for the "data_format" oneof.
ExecuteQueryResponse.ResponseOneofCase
Enum of possible cases for the "response" oneof.
Mutation.MutationOneofCase
Enum of possible cases for the "mutation" oneof.
PartialResultSet.PartialRowsOneofCase
Enum of possible cases for the "partial_rows" oneof.
ReadChangeStreamRequest.StartFromOneofCase
Enum of possible cases for the "start_from" oneof.
ReadChangeStreamResponse.StreamRecordOneofCase
Enum of possible cases for the "stream_record" oneof.
ReadChangeStreamResponse.Types.DataChange.Types.Type
The type of mutation.
ReadModifyWriteRule.RuleOneofCase
Enum of possible cases for the "rule" oneof.
ReadRowsRequest.Types.RequestStatsView
The desired view into RequestStats that should be returned in the response.
See also: RequestStats message.
ReadRowsResponse.Types.CellChunk.RowStatusOneofCase
Enum of possible cases for the "row_status" oneof.
RequestStats.StatsViewOneofCase
Enum of possible cases for the "stats_view" oneof.
ResultSetMetadata.SchemaOneofCase
Enum of possible cases for the "schema" oneof.
RowFilter.FilterOneofCase
Enum of possible cases for the "filter" oneof.
RowRange.EndKeyOneofCase
Enum of possible cases for the "end_key" oneof.
RowRange.StartKeyOneofCase
Enum of possible cases for the "start_key" oneof.
Type.KindOneofCase
Enum of possible cases for the "kind" oneof.
Type.Types.Aggregate.AggregatorOneofCase
Enum of possible cases for the "aggregator" oneof.
Type.Types.Bytes.Types.Encoding.EncodingOneofCase
Enum of possible cases for the "encoding" oneof.
Type.Types.Int64.Types.Encoding.EncodingOneofCase
Enum of possible cases for the "encoding" oneof.
Type.Types.String.Types.Encoding.EncodingOneofCase
Enum of possible cases for the "encoding" oneof.
Value.KindOneofCase
Enum of possible cases for the "kind" oneof.
ValueRange.EndValueOneofCase
Enum of possible cases for the "end_value" oneof.
ValueRange.StartValueOneofCase
Enum of possible cases for the "start_value" oneof.