Class PubsubClient

java.lang.Object
org.apache.beam.sdk.io.gcp.pubsub.PubsubClient
All Implemented Interfaces:
Closeable, AutoCloseable
Direct Known Subclasses:
PubsubGrpcClient, PubsubJsonClient, PubsubTestClient

public abstract class PubsubClient extends Object implements Closeable
An (abstract) helper class for talking to Pubsub via an underlying transport.