Package | Description |
---|---|
org.apache.flink.streaming.connectors.gcp.pubsub | |
org.apache.flink.streaming.connectors.gcp.pubsub.emulator |
Modifier and Type | Field and Description |
---|---|
protected PubSubSubscriberFactory |
PubSubSource.pubSubSubscriberFactory |
Modifier and Type | Method and Description |
---|---|
PubSubSource.PubSubSourceBuilder<OUT> |
PubSubSource.PubSubSourceBuilder.withPubSubSubscriberFactory(PubSubSubscriberFactory pubSubSubscriberFactory)
Set a PubSubSubscriberFactory This allows for custom Subscriber options to be set.
|
Modifier and Type | Class and Description |
---|---|
class |
PubSubSubscriberFactoryForEmulator
A convenience PubSubSubscriberFactory that can be used to connect to a PubSub emulator.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.