Class StorageApiWritesShardedRecords<DestinationT extends @NonNull Object,ElementT>

java.lang.Object
org.apache.beam.sdk.transforms.PTransform<PCollection<KV<org.apache.beam.sdk.util.ShardedKey<DestinationT>,Iterable<StorageApiWritePayload>>>,PCollectionTuple>
org.apache.beam.sdk.io.gcp.bigquery.StorageApiWritesShardedRecords<DestinationT,ElementT>
All Implemented Interfaces:
Serializable, HasDisplayData

public class StorageApiWritesShardedRecords<DestinationT extends @NonNull Object,ElementT> extends PTransform<PCollection<KV<org.apache.beam.sdk.util.ShardedKey<DestinationT>,Iterable<StorageApiWritePayload>>>,PCollectionTuple>
A transform to write sharded records to BigQuery using the Storage API (Streaming).
See Also: