Package Classes (2.33.0)

Summary of entries of Classes for pubsub.

Classes

Client

A publisher client for Google Cloud Pub/Sub.

This creates an object that is capable of publishing messages.Generally, you can instantiate this client with no arguments, and youget sensible defaults.

Future

This future object is returned from asychronous Pub/Sub publishingcalls.

Callingresult will resolve the future by returning the messageID, unless an error occurs.

Client

A subscriber client for Google Cloud Pub/Sub.

This creates an object that is capable of subscribing to messages.Generally, you can instantiate this client with no arguments, and youget sensible defaults.

Future

This future object is for subscribe-side calls.

Callingresult will resolve the future by returning the messageID, unless an error occurs.

StreamingPullFuture

Represents a process that asynchronously performs streaming pull andschedules messages to be processed.

This future is resolved when the process is stopped (viacancel) orif it encounters an unrecoverable error. Calling.result() will causethe calling thread to block indefinitely.

Message

A representation of a single Pub/Sub message.

The common way to interact with.pubsub_v1.subscriber.message.Message objects is to receivethem in callbacks on subscriptions; most users should never have a needto instantiate them by hand. (The exception to this is if you areimplementing a custom subclass to.pubsub_v1.subscriber._consumer.Consumer.)

Scheduler

Abstract base class for schedulers.

Schedulers are used to schedule callbacks asynchronously.

ThreadScheduler

A thread pool-based scheduler. It must not be shared across SubscriberClients.

This scheduler is useful in typical I/O-bound message processing.

AcknowledgeRequest

Request for the Acknowledge method.

AuditConfig

API documentation forpubsub_v1.types.AuditConfig class.

AuditConfigDelta

API documentation forpubsub_v1.types.AuditConfigDelta class.

AuditData

API documentation forpubsub_v1.types.AuditData class.

AuditLogConfig

API documentation forpubsub_v1.types.AuditLogConfig class.

BatchSettings

The settings for batch publishing the messages.

BigQueryConfig

Configuration for a BigQuery subscription.

State

Possible states for a BigQuery subscription.

    - Pub/Sub SA has not been granted the `appropriate BigQuery      IAM      permissions <https://cloud.google.com/pubsub/docs/create-subscription#assign_bigquery_service_account>`__    - bigquery.googleapis.com API is not enabled for the project      (`instructions <https://cloud.google.com/service-usage/docs/enable-disable>`__)NOT_FOUND (3):    Cannot write to the BigQuery table because it    does not exist.SCHEMA_MISMATCH (4):    Cannot write to the BigQuery table due to a    schema mismatch.IN_TRANSIT_LOCATION_RESTRICTION (5):    Cannot write to the destination because enforce_in_transit    is set to true and the destination locations are not in the    allowed regions.

Binding

API documentation forpubsub_v1.types.Binding class.

BindingDelta

API documentation forpubsub_v1.types.BindingDelta class.

CloudStorageConfig

Configuration for a Cloud Storage subscription.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

AvroConfig

Configuration for writing message data in Avro format.Message payloads and metadata will be written to files as anAvro binary.

State

Possible states for a Cloud Storage subscription.

TextConfig

Configuration for writing message data in text format.Message payloads will be written to files as raw text, separatedby a newline.

CreateSnapshotRequest

Request for theCreateSnapshot method.

LabelsEntry

The abstract base class for a message.

TagsEntry

The abstract base class for a message.

CustomHttpPattern

API documentation forpubsub_v1.types.CustomHttpPattern class.

DeadLetterPolicy

Dead lettering is done on a best effort basis. The samemessage might be dead lettered multiple times.

If validation on any of the fields fails at subscriptioncreation/updation, the create/update subscription request willfail.

DeleteSnapshotRequest

Request for theDeleteSnapshot method.

DeleteSubscriptionRequest

Request for the DeleteSubscription method.

DeleteTopicRequest

Request for theDeleteTopic method.

DescriptorProto

API documentation forpubsub_v1.types.DescriptorProto class.

ExtensionRange

API documentation forpubsub_v1.types.DescriptorProto.ExtensionRange class.

ReservedRange

API documentation forpubsub_v1.types.DescriptorProto.ReservedRange class.

DetachSubscriptionRequest

Request for the DetachSubscription method.

DetachSubscriptionResponse

Response for the DetachSubscription method.Reserved for future use.

Duration

API documentation forpubsub_v1.types.Duration class.

Empty

API documentation forpubsub_v1.types.Empty class.

EnumDescriptorProto

API documentation forpubsub_v1.types.EnumDescriptorProto class.

EnumReservedRange

API documentation forpubsub_v1.types.EnumDescriptorProto.EnumReservedRange class.

EnumOptions

API documentation forpubsub_v1.types.EnumOptions class.

EnumValueDescriptorProto

API documentation forpubsub_v1.types.EnumValueDescriptorProto class.

EnumValueOptions

API documentation forpubsub_v1.types.EnumValueOptions class.

ExpirationPolicy

A policy that specifies the conditions for resourceexpiration (i.e., automatic resource deletion).

ExtensionRangeOptions

API documentation forpubsub_v1.types.ExtensionRangeOptions class.

Declaration

API documentation forpubsub_v1.types.ExtensionRangeOptions.Declaration class.

FeatureSet

API documentation forpubsub_v1.types.FeatureSet class.

VisibilityFeature

API documentation forpubsub_v1.types.FeatureSet.VisibilityFeature class.

FeatureSetDefaults

API documentation forpubsub_v1.types.FeatureSetDefaults class.

FeatureSetEditionDefault

API documentation forpubsub_v1.types.FeatureSetDefaults.FeatureSetEditionDefault class.

FieldDescriptorProto

API documentation forpubsub_v1.types.FieldDescriptorProto class.

FieldMask

API documentation forpubsub_v1.types.FieldMask class.

FieldOptions

API documentation forpubsub_v1.types.FieldOptions class.

EditionDefault

API documentation forpubsub_v1.types.FieldOptions.EditionDefault class.

FeatureSupport

API documentation forpubsub_v1.types.FieldOptions.FeatureSupport class.

FileDescriptorProto

API documentation forpubsub_v1.types.FileDescriptorProto class.

FileDescriptorSet

API documentation forpubsub_v1.types.FileDescriptorSet class.

FileOptions

API documentation forpubsub_v1.types.FileOptions class.

FlowControl

The settings for controlling the rate at which messages are pulledwith an asynchronous subscription.

GeneratedCodeInfo

API documentation forpubsub_v1.types.GeneratedCodeInfo class.

Annotation

API documentation forpubsub_v1.types.GeneratedCodeInfo.Annotation class.

GetIamPolicyRequest

API documentation forpubsub_v1.types.GetIamPolicyRequest class.

GetSnapshotRequest

Request for the GetSnapshot method.

GetSubscriptionRequest

Request for the GetSubscription method.

GetTopicRequest

Request for the GetTopic method.

Http

API documentation forpubsub_v1.types.Http class.

HttpRule

API documentation forpubsub_v1.types.HttpRule class.

IngestionDataSourceSettings

Settings for an ingestion data source on a topic.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

AwsKinesis

Ingestion settings for Amazon Kinesis Data Streams.

State

Possible states for ingestion from Amazon Kinesis DataStreams.

    - The provided `aws_role_arn` does not exist or does not      have the appropriate permissions attached.    - The provided `aws_role_arn` is not set up properly for      Identity Federation using `gcp_service_account`.    - The Pub/Sub SA is not granted the      `iam.serviceAccounts.getOpenIdToken` permission on      `gcp_service_account`.PUBLISH_PERMISSION_DENIED (3):    Permission denied encountered while publishing to the topic.    This can happen if the Pub/Sub SA has not been granted the    `appropriate publish    permissions <https://cloud.google.com/pubsub/docs/access-control#pubsub.publisher>`__STREAM_NOT_FOUND (4):    The Kinesis stream does not exist.CONSUMER_NOT_FOUND (5):    The Kinesis consumer does not exist.

AwsMsk

Ingestion settings for Amazon MSK.

State

Possible states for managed ingestion from Amazon MSK.

AzureEventHubs

Ingestion settings for Azure Event Hubs.

State

Possible states for managed ingestion from Event Hubs.

CloudStorage

Ingestion settings for Cloud Storage.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

AvroFormat

Configuration for reading Cloud Storage data in Avro binary format.The bytes of each object will be set to thedata field of aPub/Sub message.

PubSubAvroFormat

Configuration for reading Cloud Storage data written viaCloudStoragesubscriptions <https://cloud.google.com/pubsub/docs/cloudstorage>__.The data and attributes fields of the originally exported Pub/Submessage will be restored when publishing.

State

Possible states for ingestion from Cloud Storage.

    - storage.objects.list: to list the objects in a bucket.    - storage.objects.get: to read the objects in a bucket.    - storage.buckets.get: to verify the bucket exists.PUBLISH_PERMISSION_DENIED (3):    Permission denied encountered while publishing to the topic.    This can happen if the Pub/Sub SA has not been granted the    `appropriate publish    permissions <https://cloud.google.com/pubsub/docs/access-control#pubsub.publisher>`__BUCKET_NOT_FOUND (4):    The provided Cloud Storage bucket doesn't    exist.TOO_MANY_OBJECTS (5):    The Cloud Storage bucket has too many    objects, ingestion will be paused.

TextFormat

Configuration for reading Cloud Storage data in text format. Eachline of text as specified by the delimiter will be set to thedata field of a Pub/Sub message.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

ConfluentCloud

Ingestion settings for Confluent Cloud.

State

Possible states for managed ingestion from Confluent Cloud.

IngestionFailureEvent

Payload of the Platform Log entry sent when a failure isencountered while ingesting.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

ApiViolationReason

Specifies the reason why some data may have been left out of thedesired Pub/Sub message due to the API message limits(https://cloud.google.com/pubsub/quotas#resource_limits). Forexample, when the number of attributes is larger than 100, thenumber of attributes is truncated to 100 to respect the limit on theattribute count. Other attribute limits are treated similarly. Whenthe size of the desired message would've been larger than 10MB, themessage won't be published at all, and ingestion of the subsequentmessages will proceed as normal.

AvroFailureReason

Set when an Avro file is unsupported or its format is notvalid. When this occurs, one or more Avro objects won't beingested.

AwsKinesisFailureReason

Failure when ingesting from an AWS Kinesis source.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

AwsMskFailureReason

Failure when ingesting from an Amazon MSK source.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

AzureEventHubsFailureReason

Failure when ingesting from an Azure Event Hubs source.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

CloudStorageFailure

Failure when ingesting from a Cloud Storage source.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

ConfluentCloudFailureReason

Failure when ingesting from a Confluent Cloud source.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

MessageTransformationFailureReason

Set when a Pub/Sub message fails to get published due to amessage transformation error.

SchemaViolationReason

Set when a Pub/Sub message fails to get published due to aschema validation violation.

JavaScriptUDF

User-defined JavaScript function that can transform or filtera Pub/Sub message.

LimitExceededBehavior

The possible actions when exceeding the publish flow control limits.

ListSnapshotsRequest

Request for theListSnapshots method.

ListSnapshotsResponse

Response for theListSnapshots method.

ListSubscriptionsRequest

Request for theListSubscriptions method.

ListSubscriptionsResponse

Response for theListSubscriptions method.

ListTopicSnapshotsRequest

Request for theListTopicSnapshots method.

ListTopicSnapshotsResponse

Response for theListTopicSnapshots method.

ListTopicSubscriptionsRequest

Request for theListTopicSubscriptions method.

ListTopicSubscriptionsResponse

Response for theListTopicSubscriptions method.

ListTopicsRequest

Request for theListTopics method.

ListTopicsResponse

Response for theListTopics method.

MessageOptions

API documentation forpubsub_v1.types.MessageOptions class.

MessageStoragePolicy

A policy constraining the storage of messages published tothe topic.

MessageTransform

All supported message transforms types.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

MethodDescriptorProto

API documentation forpubsub_v1.types.MethodDescriptorProto class.

MethodOptions

API documentation forpubsub_v1.types.MethodOptions class.

ModifyAckDeadlineRequest

Request for the ModifyAckDeadline method.

ModifyPushConfigRequest

Request for the ModifyPushConfig method.

OneofDescriptorProto

API documentation forpubsub_v1.types.OneofDescriptorProto class.

OneofOptions

API documentation forpubsub_v1.types.OneofOptions class.

PlatformLogsSettings

Settings for Platform Logs produced by Pub/Sub.

Severity

Severity levels of Platform Logs.

Policy

API documentation forpubsub_v1.types.Policy class.

PolicyDelta

API documentation forpubsub_v1.types.PolicyDelta class.

PublishFlowControl

The client flow control settings for message publishing.

PublishRequest

Request for the Publish method.

PublishResponse

Response for thePublish method.

PublisherOptions

The options for the publisher client.

PubsubMessage

A message that is published by publishers and consumed bysubscribers. The message must contain either a non-empty data fieldor at least one attribute. Note that client libraries represent thisobject differently depending on the language. See the correspondingclient librarydocumentation <https://cloud.google.com/pubsub/docs/reference/libraries>__for more information. Seequotas and limits for more information aboutmessage limits.

AttributesEntry

The abstract base class for a message.

PullRequest

Request for thePull method.

PullResponse

Response for thePull method.

PushConfig

Configuration for a push delivery endpoint.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

AttributesEntry

The abstract base class for a message.

NoWrapper

Sets thedata field as the HTTP body for delivery.

OidcToken

Contains information needed for generating anOpenID Connecttoken <https://developers.google.com/identity/protocols/OpenIDConnect>__.

PubsubWrapper

The payload to the push endpoint is in the form of the JSONrepresentation of a PubsubMessage(https://cloud.google.com/pubsub/docs/reference/rpc/google.pubsub.v1#pubsubmessage).

ReceivedMessage

A message and its corresponding acknowledgment ID.

RetryPolicy

A policy that specifies how Pub/Sub retries message delivery.

Retry delay will be exponential based on provided minimum andmaximum backoffs.https://en.wikipedia.org/wiki/Exponential_backoff.

RetryPolicy will be triggered on NACKs or acknowledgment deadlineexceeded events for a given message.

Retry Policy is implemented on a best effort basis. At times, thedelay between consecutive deliveries may not match theconfiguration. That is, delay can be more or less than configuredbackoff.

SchemaSettings

Settings for validating messages published against a schema.

SeekRequest

Request for theSeek method.

This message hasoneof_ fields (mutually exclusive fields).For each oneof, at most one member field can be set at the same time.Setting any member of the oneof automatically clears all othermembers.

.. _oneof:https://proto-plus-python.readthedocs.io/en/stable/fields.html#oneofs-mutually-exclusive-fields

SeekResponse

Response for theSeek method (this response is empty).

ServiceDescriptorProto

API documentation forpubsub_v1.types.ServiceDescriptorProto class.

ServiceOptions

API documentation forpubsub_v1.types.ServiceOptions class.

SetIamPolicyRequest

API documentation forpubsub_v1.types.SetIamPolicyRequest class.

Snapshot

A snapshot resource. Snapshots are used inSeek <https://cloud.google.com/pubsub/docs/replay-overview>__operations, which allow you to manage message acknowledgments inbulk. That is, you can set the acknowledgment state of messages inan existing subscription to the state captured by a snapshot.

LabelsEntry

The abstract base class for a message.

SourceCodeInfo

API documentation forpubsub_v1.types.SourceCodeInfo class.

Location

API documentation forpubsub_v1.types.SourceCodeInfo.Location class.

StreamingPullRequest

Request for theStreamingPull streaming RPC method. This requestis used to establish the initial stream as well as to streamacknowledgments and ack deadline modifications from the client tothe server.

StreamingPullResponse

Response for theStreamingPull method. This response is used tostream messages from the server to the client.

AcknowledgeConfirmation

Acknowledgment IDs sent in one or more previous requests toacknowledge a previously received message.

ModifyAckDeadlineConfirmation

Acknowledgment IDs sent in one or more previous requests tomodify the deadline for a specific message.

SubscriptionProperties

Subscription properties sent as part of the response.

Subscription

A subscription resource. If none ofpush_config,bigquery_config, orcloud_storage_config is set, then thesubscriber will pull and ack messages using API methods. At most oneof these fields may be set.

AnalyticsHubSubscriptionInfo

Information about an associatedAnalytics Hubsubscription <https://cloud.google.com/bigquery/docs/analytics-hub-manage-subscriptions>__.

LabelsEntry

The abstract base class for a message.

State

Possible states for a subscription.

TagsEntry

The abstract base class for a message.

TestIamPermissionsRequest

API documentation forpubsub_v1.types.TestIamPermissionsRequest class.

TestIamPermissionsResponse

API documentation forpubsub_v1.types.TestIamPermissionsResponse class.

Timestamp

API documentation forpubsub_v1.types.Timestamp class.

Topic

A topic resource.

LabelsEntry

The abstract base class for a message.

State

The state of the topic.

TagsEntry

The abstract base class for a message.

UninterpretedOption

API documentation forpubsub_v1.types.UninterpretedOption class.

NamePart

API documentation forpubsub_v1.types.UninterpretedOption.NamePart class.

UpdateSnapshotRequest

Request for the UpdateSnapshot method.

UpdateSubscriptionRequest

Request for the UpdateSubscription method.

UpdateTopicRequest

Request for the UpdateTopic method.

ListTopicSnapshotsAsyncPager

A pager for iterating throughlist_topic_snapshots requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListTopicSnapshotsResponse object, andprovides an__aiter__ method to iterate through itssnapshots field.

If there are more pages, the__aiter__ method will make additionalListTopicSnapshots requests and continue to iteratethrough thesnapshots field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListTopicSnapshotsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListTopicSnapshotsPager

A pager for iterating throughlist_topic_snapshots requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListTopicSnapshotsResponse object, andprovides an__iter__ method to iterate through itssnapshots field.

If there are more pages, the__iter__ method will make additionalListTopicSnapshots requests and continue to iteratethrough thesnapshots field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListTopicSnapshotsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListTopicSubscriptionsAsyncPager

A pager for iterating throughlist_topic_subscriptions requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListTopicSubscriptionsResponse object, andprovides an__aiter__ method to iterate through itssubscriptions field.

If there are more pages, the__aiter__ method will make additionalListTopicSubscriptions requests and continue to iteratethrough thesubscriptions field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListTopicSubscriptionsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListTopicSubscriptionsPager

A pager for iterating throughlist_topic_subscriptions requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListTopicSubscriptionsResponse object, andprovides an__iter__ method to iterate through itssubscriptions field.

If there are more pages, the__iter__ method will make additionalListTopicSubscriptions requests and continue to iteratethrough thesubscriptions field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListTopicSubscriptionsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListTopicsAsyncPager

A pager for iterating throughlist_topics requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListTopicsResponse object, andprovides an__aiter__ method to iterate through itstopics field.

If there are more pages, the__aiter__ method will make additionalListTopics requests and continue to iteratethrough thetopics field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListTopicsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListTopicsPager

A pager for iterating throughlist_topics requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListTopicsResponse object, andprovides an__iter__ method to iterate through itstopics field.

If there are more pages, the__iter__ method will make additionalListTopics requests and continue to iteratethrough thetopics field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListTopicsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListSnapshotsAsyncPager

A pager for iterating throughlist_snapshots requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListSnapshotsResponse object, andprovides an__aiter__ method to iterate through itssnapshots field.

If there are more pages, the__aiter__ method will make additionalListSnapshots requests and continue to iteratethrough thesnapshots field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListSnapshotsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListSnapshotsPager

A pager for iterating throughlist_snapshots requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListSnapshotsResponse object, andprovides an__iter__ method to iterate through itssnapshots field.

If there are more pages, the__iter__ method will make additionalListSnapshots requests and continue to iteratethrough thesnapshots field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListSnapshotsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListSubscriptionsAsyncPager

A pager for iterating throughlist_subscriptions requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListSubscriptionsResponse object, andprovides an__aiter__ method to iterate through itssubscriptions field.

If there are more pages, the__aiter__ method will make additionalListSubscriptions requests and continue to iteratethrough thesubscriptions field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListSubscriptionsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

ListSubscriptionsPager

A pager for iterating throughlist_subscriptions requests.

This class thinly wraps an initialgoogle.pubsub_v1.types.ListSubscriptionsResponse object, andprovides an__iter__ method to iterate through itssubscriptions field.

If there are more pages, the__iter__ method will make additionalListSubscriptions requests and continue to iteratethrough thesubscriptions field on thecorresponding responses.

All the usualgoogle.pubsub_v1.types.ListSubscriptionsResponseattributes are available on the pager. If multiple requests are made, onlythe most recent response is retained, and thus used for attribute lookup.

Modules

publisher.client

API documentation forpubsub_v1.publisher.client module.

publisher.futures

API documentation forpubsub_v1.publisher.futures module.

subscriber.client

API documentation forpubsub_v1.subscriber.client module.

subscriber.futures

API documentation forpubsub_v1.subscriber.futures module.

scheduler

Schedulers provide means toschedule callbacks asynchronously.

These are used by the subscriber to call the user-provided callback to processeach message.

types

API documentation forpubsub_v1.types module.

publisher.pagers

API documentation forpubsub_v1.services.publisher.pagers module.

subscriber.pagers

API documentation forpubsub_v1.services.subscriber.pagers module.

Except as otherwise noted, the content of this page is licensed under theCreative Commons Attribution 4.0 License, and code samples are licensed under theApache 2.0 License. For details, see theGoogle Developers Site Policies. Java is a registered trademark of Oracle and/or its affiliates.

Last updated 2025-10-30 UTC.