public final class CloudPubsubChecks
extends java.lang.Object
Modifier and Type | Method and Description |
---|---|
static PTransform<PCollection<? extends com.google.cloud.pubsublite.proto.PubSubMessage>,PCollection<com.google.cloud.pubsublite.proto.PubSubMessage>> |
ensureUsableAsCloudPubsub()
Ensure that all messages that pass through can be converted to Cloud Pub/Sub messages using the
standard transformation methods in the client library.
|
public static PTransform<PCollection<? extends com.google.cloud.pubsublite.proto.PubSubMessage>,PCollection<com.google.cloud.pubsublite.proto.PubSubMessage>> ensureUsableAsCloudPubsub()
Will fail the pipeline if a message has multiple attributes per key.