See: Description
Interface | Description |
---|---|
BigQueryOptions |
Properties needed when using Google BigQuery with the Apache Beam SDK.
|
BigQueryServices |
An interface for real, mock, or fake implementations of Cloud BigQuery services.
|
BigQueryServices.BigQueryServerStream<T> |
Container for reading data from streaming endpoints.
|
BigQueryServices.DatasetService |
An interface to get, create and delete Cloud BigQuery datasets and tables.
|
BigQueryServices.JobService |
An interface for the Cloud BigQuery load service.
|
BigQueryServices.StorageClient |
An interface representing a client object for making calls to the BigQuery Storage API.
|
ErrorContainer<T> |
ErrorContainer interface.
|
TestBigQuery.PollingAssertion |
Interface to implement a polling assertion.
|
TestBigQueryOptions |
Class | Description |
---|---|
AvroWriteRequest<T> | |
BigQueryCoderProviderRegistrar |
A
CoderProviderRegistrar for standard types used with BigQueryIO . |
BigQueryHelpers |
A set of helper functions and classes used by
BigQueryIO . |
BigQueryInsertError |
Model definition for BigQueryInsertError.
|
BigQueryInsertErrorCoder |
A
Coder that encodes BigQuery BigQueryInsertError objects. |
BigQueryIO |
PTransform s for reading and writing BigQuery tables. |
BigQueryIO.Read |
Implementation of
BigQueryIO.read() . |
BigQueryIO.TypedRead<T> |
Implementation of
BigQueryIO.read(SerializableFunction) . |
BigQueryIO.Write<T> |
Implementation of
BigQueryIO.write() . |
BigQueryStorageQuerySource<T> |
A
Source representing reading the results of a query. |
BigQueryStorageStreamSource<T> |
A
Source representing a single stream in a read session. |
BigQueryStorageStreamSource.BigQueryStorageStreamReader<T> |
A
Source.Reader which reads records from a stream. |
BigQueryStorageTableSource<T> |
A
Source representing reading from a table. |
BigQueryUtils |
Utility methods for BigQuery related operations.
|
BigQueryUtils.ConversionOptions |
Options for how to convert BigQuery data to Beam data.
|
BigQueryUtils.ConversionOptions.Builder |
Builder for
BigQueryUtils.ConversionOptions . |
CreateTables<DestinationT,ElementT> |
Creates any tables needed before performing streaming writes to the tables.
|
DynamicDestinations<T,DestinationT> |
This class provides the most general way of specifying dynamic BigQuery table destinations.
|
InsertRetryPolicy |
A retry policy for streaming BigQuery inserts.
|
InsertRetryPolicy.Context |
Contains information about a failed insert.
|
PrepareWrite<InputT,DestinationT,OutputT> |
Prepare an input
PCollection for writing to BigQuery. |
ReifyAsIterable<T> |
This transforms turns a side input into a singleton PCollection that can be used as the main
input for another transform.
|
SchemaAndRecord |
A wrapper for a
GenericRecord and the TableSchema representing the schema of the
table (or query) it was generated from. |
StreamingInserts<DestinationT,ElementT> |
PTransform that performs streaming BigQuery write.
|
StreamingWriteTables<ElementT> |
This transform takes in key-value pairs of
TableRow entries and the TableDestination it should be written to. |
TableDestination |
Encapsulates a BigQuery table destination.
|
TableDestinationCoder |
A coder for
TableDestination objects. |
TableDestinationCoderV2 |
A
Coder for TableDestination that includes time partitioning information. |
TableDestinationCoderV3 |
A
Coder for TableDestination that includes time partitioning and clustering
information. |
TableRowJsonCoder | |
TestBigQuery |
Test rule which creates a new table with specified schema, with randomized name and exposes few
APIs to work with it.
|
WriteResult |
The result of a
BigQueryIO.Write transform. |
Enum | Description |
---|---|
BigQueryIO.TypedRead.Method |
Determines the method used to read data from BigQuery.
|
BigQueryIO.TypedRead.QueryPriority |
An enumeration type for the priority of a query.
|
BigQueryIO.Write.CreateDisposition |
An enumeration type for the BigQuery create disposition strings.
|
BigQueryIO.Write.Method |
Determines the method used to insert data in BigQuery.
|
BigQueryIO.Write.SchemaUpdateOption |
An enumeration type for the BigQuery schema update options strings.
|
BigQueryIO.Write.WriteDisposition |
An enumeration type for the BigQuery write disposition strings.
|
BigQueryUtils.ConversionOptions.TruncateTimestamps |
Controls whether to truncate timestamps to millisecond precision lossily, or to crash when
truncation would result.
|
Exception | Description |
---|---|
BigQuerySchemaRetrievalException |
Exception to signal that BigQuery schema retrieval failed.
|
BigQueryIO