Interface PubsubTestClient.PubsubTestClientFactory
- All Superinterfaces:
AutoCloseable
,Closeable
,PubsubClient.PubsubClientFactory
,Serializable
- Enclosing class:
PubsubTestClient
public static interface PubsubTestClient.PubsubTestClientFactory
extends PubsubClient.PubsubClientFactory, Closeable, Serializable
Closing the factory will validate all expected messages were processed.
-
Method Summary
Modifier and TypeMethodDescriptiondefault <T> PubsubIO.Read
<T> setClock
(PubsubIO.Read<T> readTransform, com.google.api.client.util.Clock clock) Methods inherited from interface org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.PubsubClientFactory
getKind, newClient, newClient
-
Method Details
-
setClock
default <T> PubsubIO.Read<T> setClock(PubsubIO.Read<T> readTransform, com.google.api.client.util.Clock clock)
-