Documentation ¶
Overview ¶
Package spannerio provides an API for reading and writing resouces to Google Spanner datastores.
Index ¶
- func Query(s beam.Scope, db string, q string, t reflect.Type, options ...QueryOptionFn) beam.PCollection
- func Read(s beam.Scope, db string, table string, t reflect.Type) beam.PCollection
- func Write(s beam.Scope, db string, table string, col beam.PCollection, ...)
- type QueryOptionFn
- type TestDto
- type WriteOptionsFn
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func Query ¶
func Query(s beam.Scope, db string, q string, t reflect.Type, options ...QueryOptionFn) beam.PCollection
Query executes a spanner query. It returns a PCollection<t> for a given type T. T must be a struct with exported fields that have the "spanner" tag. By default, the transform uses spanners partitioned read ability to split the results into bundles. If the underlying query is not root-partitionable you can disable batching via UseBatching.
func Read ¶
Read reads all rows from the given spanner table. It returns a PCollection<t> for a given type T. T must be a struct with exported fields that have the "spanner" tag. If the table has more rows than t, then Read is implicitly a projection.
func Write ¶
func Write(s beam.Scope, db string, table string, col beam.PCollection, options ...WriteOptionsFn)
Write writes the elements of the given PCollection<T> to spanner. T is required to be the schema type.
Types ¶
type QueryOptionFn ¶ added in v2.49.0
type QueryOptionFn func(*queryOptions) error
QueryOptionFn is a function that can be passed to Read or Query to configure options for reading or querying spanner.
func WithBatching ¶ added in v2.49.0
func WithBatching(batching bool) QueryOptionFn
WithBatching sets whether we will use a batched reader. Batching is set to true by default, disable it when the underlying query is not root-partitionable.
func WithMaxPartitions ¶ added in v2.49.0
func WithMaxPartitions(maxPartitions int64) QueryOptionFn
WithMaxPartitions sets the maximum number of Partitions to split the query into when batched reading.
func WithTimestampBound ¶ added in v2.49.0
func WithTimestampBound(timestampBound spanner.TimestampBound) QueryOptionFn
WithTimestampBound sets the TimestampBound to use when doing batched reads.
type WriteOptionsFn ¶ added in v2.49.0
type WriteOptionsFn func(qo *writeOptions) error
WriteOptionsFn is a function that can be passed to Write to configure options for writing to spanner.
func UseBatchSize ¶
func UseBatchSize(batchSize int) WriteOptionsFn
UseBatchSize explicitly sets the batch size per transaction for writes.