Summary of entries of Methods for pubsub.
google.cloud.pubsub_v1.publisher.client.Client
Client(
    batch_settings: typing.Union[
        google.cloud.pubsub_v1.types.BatchSettings, typing.Sequence
    ] = (),
    publisher_options: typing.Union[
        google.cloud.pubsub_v1.types.PublisherOptions, typing.Sequence
    ] = (),
    **kwargs: typing.Any
)Instantiates the publisher client.
google.cloud.pubsub_v1.publisher.client.Client.__exit__
__exit__(type, value, traceback)Releases underlying transport's resources.
See more: google.cloud.pubsub_v1.publisher.client.Client.exit
google.cloud.pubsub_v1.publisher.client.Client.common_billing_account_path
common_billing_account_path(billing_account: str) -> strReturns a fully-qualified billing_account string.
See more: google.cloud.pubsub_v1.publisher.client.Client.common_billing_account_path
google.cloud.pubsub_v1.publisher.client.Client.common_folder_path
common_folder_path(folder: str) -> strReturns a fully-qualified folder string.
See more: google.cloud.pubsub_v1.publisher.client.Client.common_folder_path
google.cloud.pubsub_v1.publisher.client.Client.common_location_path
common_location_path(project: str, location: str) -> strReturns a fully-qualified location string.
See more: google.cloud.pubsub_v1.publisher.client.Client.common_location_path
google.cloud.pubsub_v1.publisher.client.Client.common_organization_path
common_organization_path(organization: str) -> strReturns a fully-qualified organization string.
See more: google.cloud.pubsub_v1.publisher.client.Client.common_organization_path
google.cloud.pubsub_v1.publisher.client.Client.common_project_path
common_project_path(project: str) -> strReturns a fully-qualified project string.
See more: google.cloud.pubsub_v1.publisher.client.Client.common_project_path
google.cloud.pubsub_v1.publisher.client.Client.create_topic
create_topic(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.Topic, dict]
    ] = None,
    *,
    name: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.TopicCreates the given topic with the given name.
See more: google.cloud.pubsub_v1.publisher.client.Client.create_topic
google.cloud.pubsub_v1.publisher.client.Client.delete_topic
delete_topic(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.DeleteTopicRequest, dict]
    ] = None,
    *,
    topic: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> NoneDeletes the topic with the given name.
See more: google.cloud.pubsub_v1.publisher.client.Client.delete_topic
google.cloud.pubsub_v1.publisher.client.Client.detach_subscription
detach_subscription(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.DetachSubscriptionRequest, dict]
    ] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.DetachSubscriptionResponseDetaches a subscription from this topic.
See more: google.cloud.pubsub_v1.publisher.client.Client.detach_subscription
google.cloud.pubsub_v1.publisher.client.Client.ensure_cleanup_and_commit_timer_runs
ensure_cleanup_and_commit_timer_runs() -> NoneEnsure a cleanup/commit timer thread is running.
See more: google.cloud.pubsub_v1.publisher.client.Client.ensure_cleanup_and_commit_timer_runs
google.cloud.pubsub_v1.publisher.client.Client.from_service_account_file
from_service_account_file(
    filename: str,
    batch_settings: typing.Union[
        google.cloud.pubsub_v1.types.BatchSettings, typing.Sequence
    ] = (),
    **kwargs: typing.Any
) -> google.cloud.pubsub_v1.publisher.client.ClientCreates an instance of this client using the provided credentials file.
See more: google.cloud.pubsub_v1.publisher.client.Client.from_service_account_file
google.cloud.pubsub_v1.publisher.client.Client.from_service_account_info
from_service_account_info(info: dict, *args, **kwargs)Creates an instance of this client using the provided credentials info.
See more: google.cloud.pubsub_v1.publisher.client.Client.from_service_account_info
google.cloud.pubsub_v1.publisher.client.Client.from_service_account_json
from_service_account_json(
    filename: str,
    batch_settings: typing.Union[
        google.cloud.pubsub_v1.types.BatchSettings, typing.Sequence
    ] = (),
    **kwargs: typing.Any
) -> google.cloud.pubsub_v1.publisher.client.ClientCreates an instance of this client using the provided credentials file.
See more: google.cloud.pubsub_v1.publisher.client.Client.from_service_account_json
google.cloud.pubsub_v1.publisher.client.Client.get_iam_policy
get_iam_policy(
    request: typing.Optional[google.iam.v1.iam_policy_pb2.GetIamPolicyRequest] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.iam.v1.policy_pb2.PolicyGets the IAM access control policy for a function.
See more: google.cloud.pubsub_v1.publisher.client.Client.get_iam_policy
google.cloud.pubsub_v1.publisher.client.Client.get_mtls_endpoint_and_cert_source
get_mtls_endpoint_and_cert_source(
    client_options: typing.Optional[
        google.api_core.client_options.ClientOptions
    ] = None,
)Deprecated.
See more: google.cloud.pubsub_v1.publisher.client.Client.get_mtls_endpoint_and_cert_source
google.cloud.pubsub_v1.publisher.client.Client.get_topic
get_topic(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.GetTopicRequest, dict]
    ] = None,
    *,
    topic: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.TopicGets the configuration of a topic.
See more: google.cloud.pubsub_v1.publisher.client.Client.get_topic
google.cloud.pubsub_v1.publisher.client.Client.list_topic_snapshots
list_topic_snapshots(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ListTopicSnapshotsRequest, dict]
    ] = None,
    *,
    topic: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.pubsub_v1.services.publisher.pagers.ListTopicSnapshotsPagerLists the names of the snapshots on this topic.
See more: google.cloud.pubsub_v1.publisher.client.Client.list_topic_snapshots
google.cloud.pubsub_v1.publisher.client.Client.list_topic_subscriptions
list_topic_subscriptions(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ListTopicSubscriptionsRequest, dict]
    ] = None,
    *,
    topic: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.pubsub_v1.services.publisher.pagers.ListTopicSubscriptionsPagerLists the names of the attached subscriptions on this topic.
See more: google.cloud.pubsub_v1.publisher.client.Client.list_topic_subscriptions
google.cloud.pubsub_v1.publisher.client.Client.list_topics
list_topics(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ListTopicsRequest, dict]
    ] = None,
    *,
    project: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.pubsub_v1.services.publisher.pagers.ListTopicsPagerLists matching topics.
See more: google.cloud.pubsub_v1.publisher.client.Client.list_topics
google.cloud.pubsub_v1.publisher.client.Client.parse_common_billing_account_path
parse_common_billing_account_path(path: str) -> typing.Dict[str, str]Parse a billing_account path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_common_billing_account_path
google.cloud.pubsub_v1.publisher.client.Client.parse_common_folder_path
parse_common_folder_path(path: str) -> typing.Dict[str, str]Parse a folder path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_common_folder_path
google.cloud.pubsub_v1.publisher.client.Client.parse_common_location_path
parse_common_location_path(path: str) -> typing.Dict[str, str]Parse a location path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_common_location_path
google.cloud.pubsub_v1.publisher.client.Client.parse_common_organization_path
parse_common_organization_path(path: str) -> typing.Dict[str, str]Parse a organization path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_common_organization_path
google.cloud.pubsub_v1.publisher.client.Client.parse_common_project_path
parse_common_project_path(path: str) -> typing.Dict[str, str]Parse a project path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_common_project_path
google.cloud.pubsub_v1.publisher.client.Client.parse_schema_path
parse_schema_path(path: str) -> typing.Dict[str, str]Parses a schema path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_schema_path
google.cloud.pubsub_v1.publisher.client.Client.parse_subscription_path
parse_subscription_path(path: str) -> typing.Dict[str, str]Parses a subscription path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_subscription_path
google.cloud.pubsub_v1.publisher.client.Client.parse_topic_path
parse_topic_path(path: str) -> typing.Dict[str, str]Parses a topic path into its component segments.
See more: google.cloud.pubsub_v1.publisher.client.Client.parse_topic_path
google.cloud.pubsub_v1.publisher.client.Client.publish
publish(
    topic: str,
    data: bytes,
    ordering_key: str = "",
    retry: OptionalRetry = _MethodDefault._DEFAULT_VALUE,
    timeout: types.OptionalTimeout = _MethodDefault._DEFAULT_VALUE,
    **attrs: typing.Union[bytes, str]
) -> pubsub_v1.publisher.futures.FuturePublish a single message.
See more: google.cloud.pubsub_v1.publisher.client.Client.publish
google.cloud.pubsub_v1.publisher.client.Client.resume_publish
resume_publish(topic: str, ordering_key: str) -> NoneResume publish on an ordering key that has had unrecoverable errors.
See more: google.cloud.pubsub_v1.publisher.client.Client.resume_publish
google.cloud.pubsub_v1.publisher.client.Client.schema_path
schema_path(project: str, schema: str) -> strReturns a fully-qualified schema string.
See more: google.cloud.pubsub_v1.publisher.client.Client.schema_path
google.cloud.pubsub_v1.publisher.client.Client.set_iam_policy
set_iam_policy(
    request: typing.Optional[google.iam.v1.iam_policy_pb2.SetIamPolicyRequest] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.iam.v1.policy_pb2.PolicySets the IAM access control policy on the specified function.
See more: google.cloud.pubsub_v1.publisher.client.Client.set_iam_policy
google.cloud.pubsub_v1.publisher.client.Client.stop
stop() -> NoneImmediately publish all outstanding messages.
See more: google.cloud.pubsub_v1.publisher.client.Client.stop
google.cloud.pubsub_v1.publisher.client.Client.subscription_path
subscription_path(project: str, subscription: str) -> strReturns a fully-qualified subscription string.
See more: google.cloud.pubsub_v1.publisher.client.Client.subscription_path
google.cloud.pubsub_v1.publisher.client.Client.test_iam_permissions
test_iam_permissions(
    request: typing.Optional[
        google.iam.v1.iam_policy_pb2.TestIamPermissionsRequest
    ] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.iam.v1.iam_policy_pb2.TestIamPermissionsResponseTests the specified IAM permissions against the IAM access control policy for a function.
See more: google.cloud.pubsub_v1.publisher.client.Client.test_iam_permissions
google.cloud.pubsub_v1.publisher.client.Client.topic_path
topic_path(project: str, topic: str) -> strReturns a fully-qualified topic string.
See more: google.cloud.pubsub_v1.publisher.client.Client.topic_path
google.cloud.pubsub_v1.publisher.client.Client.update_topic
update_topic(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.UpdateTopicRequest, dict]
    ] = None,
    *,
    topic: typing.Optional[google.cloud.pubsub_v1.types.Topic] = None,
    update_mask: typing.Optional[google.protobuf.field_mask_pb2.FieldMask] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[
        int,
        float,
        google.api_core.timeout.ConstantTimeout,
        google.api_core.timeout.ExponentialTimeout,
    ] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.TopicUpdates an existing topic by updating the fields specified in the update mask.
See more: google.cloud.pubsub_v1.publisher.client.Client.update_topic
google.cloud.pubsub_v1.publisher.futures.Future
Future()Initializes the future.
google.cloud.pubsub_v1.publisher.futures.Future.add_done_callback
add_done_callback(
    callback: typing.Callable[[pubsub_v1.publisher.futures.Future], typing.Any]
) -> NoneAttach a callable that will be called when the future finishes.
See more: google.cloud.pubsub_v1.publisher.futures.Future.add_done_callback
google.cloud.pubsub_v1.publisher.futures.Future.cancel
cancel() -> boolActions in Pub/Sub generally may not be canceled.
See more: google.cloud.pubsub_v1.publisher.futures.Future.cancel
google.cloud.pubsub_v1.publisher.futures.Future.cancelled
cancelled() -> boolActions in Pub/Sub generally may not be canceled.
See more: google.cloud.pubsub_v1.publisher.futures.Future.cancelled
google.cloud.pubsub_v1.publisher.futures.Future.done
done()Return True if the future was cancelled or finished executing.
See more: google.cloud.pubsub_v1.publisher.futures.Future.done
google.cloud.pubsub_v1.publisher.futures.Future.exception
exception(timeout=None)Return the exception raised by the call that the future represents.
See more: google.cloud.pubsub_v1.publisher.futures.Future.exception
google.cloud.pubsub_v1.publisher.futures.Future.result
result(timeout: typing.Optional[typing.Union[int, float]] = None) -> strReturn the message ID or raise an exception.
See more: google.cloud.pubsub_v1.publisher.futures.Future.result
google.cloud.pubsub_v1.publisher.futures.Future.running
running() -> boolReturn True if the associated Pub/Sub action has not yet completed.
See more: google.cloud.pubsub_v1.publisher.futures.Future.running
google.cloud.pubsub_v1.publisher.futures.Future.set_exception
set_exception(exception: typing.Optional[BaseException])Set the result of the future as being the given exception.
See more: google.cloud.pubsub_v1.publisher.futures.Future.set_exception
google.cloud.pubsub_v1.publisher.futures.Future.set_result
set_result(result: typing.Any)Set the return value of work associated with the future.
See more: google.cloud.pubsub_v1.publisher.futures.Future.set_result
google.cloud.pubsub_v1.publisher.futures.Future.set_running_or_notify_cancel
set_running_or_notify_cancel() -> typing.NoReturnMark the future as running or process any cancel notifications.
See more: google.cloud.pubsub_v1.publisher.futures.Future.set_running_or_notify_cancel
google.cloud.pubsub_v1.subscriber.client.Client
Client(
    subscriber_options: typing.Union[
        google.cloud.pubsub_v1.types.SubscriberOptions, typing.Sequence
    ] = (),
    **kwargs: typing.Any
)Instantiates the subscriber client.
google.cloud.pubsub_v1.subscriber.client.Client.acknowledge
acknowledge(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.AcknowledgeRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[str] = None,
    ack_ids: typing.Optional[typing.MutableSequence[str]] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> NoneAcknowledges the messages associated with the ack_ids in the
AcknowledgeRequest.
See more: google.cloud.pubsub_v1.subscriber.client.Client.acknowledge
google.cloud.pubsub_v1.subscriber.client.Client.close
close() -> NoneClose the underlying channel to release socket resources.
See more: google.cloud.pubsub_v1.subscriber.client.Client.close
google.cloud.pubsub_v1.subscriber.client.Client.common_billing_account_path
common_billing_account_path(billing_account: str) -> strReturns a fully-qualified billing_account string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.common_billing_account_path
google.cloud.pubsub_v1.subscriber.client.Client.common_folder_path
common_folder_path(folder: str) -> strReturns a fully-qualified folder string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.common_folder_path
google.cloud.pubsub_v1.subscriber.client.Client.common_location_path
common_location_path(project: str, location: str) -> strReturns a fully-qualified location string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.common_location_path
google.cloud.pubsub_v1.subscriber.client.Client.common_organization_path
common_organization_path(organization: str) -> strReturns a fully-qualified organization string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.common_organization_path
google.cloud.pubsub_v1.subscriber.client.Client.common_project_path
common_project_path(project: str) -> strReturns a fully-qualified project string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.common_project_path
google.cloud.pubsub_v1.subscriber.client.Client.create_snapshot
create_snapshot(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.CreateSnapshotRequest, dict]
    ] = None,
    *,
    name: typing.Optional[str] = None,
    subscription: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SnapshotCreates a snapshot from the requested subscription.
See more: google.cloud.pubsub_v1.subscriber.client.Client.create_snapshot
google.cloud.pubsub_v1.subscriber.client.Client.create_subscription
create_subscription(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.Subscription, dict]
    ] = None,
    *,
    name: typing.Optional[str] = None,
    topic: typing.Optional[str] = None,
    push_config: typing.Optional[google.cloud.pubsub_v1.types.PushConfig] = None,
    ack_deadline_seconds: typing.Optional[int] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SubscriptionCreates a subscription to a given topic.
See more: google.cloud.pubsub_v1.subscriber.client.Client.create_subscription
google.cloud.pubsub_v1.subscriber.client.Client.delete_snapshot
delete_snapshot(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.DeleteSnapshotRequest, dict]
    ] = None,
    *,
    snapshot: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> NoneRemoves an existing snapshot.
See more: google.cloud.pubsub_v1.subscriber.client.Client.delete_snapshot
google.cloud.pubsub_v1.subscriber.client.Client.delete_subscription
delete_subscription(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.DeleteSubscriptionRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> NoneDeletes an existing subscription.
See more: google.cloud.pubsub_v1.subscriber.client.Client.delete_subscription
google.cloud.pubsub_v1.subscriber.client.Client.from_service_account_file
from_service_account_file(
    filename: str, **kwargs: typing.Any
) -> google.cloud.pubsub_v1.subscriber.client.ClientCreates an instance of this client using the provided credentials file.
See more: google.cloud.pubsub_v1.subscriber.client.Client.from_service_account_file
google.cloud.pubsub_v1.subscriber.client.Client.from_service_account_info
from_service_account_info(info: dict, *args, **kwargs)Creates an instance of this client using the provided credentials info.
See more: google.cloud.pubsub_v1.subscriber.client.Client.from_service_account_info
google.cloud.pubsub_v1.subscriber.client.Client.from_service_account_json
from_service_account_json(
    filename: str, **kwargs: typing.Any
) -> google.cloud.pubsub_v1.subscriber.client.ClientCreates an instance of this client using the provided credentials file.
See more: google.cloud.pubsub_v1.subscriber.client.Client.from_service_account_json
google.cloud.pubsub_v1.subscriber.client.Client.get_iam_policy
get_iam_policy(
    request: typing.Optional[google.iam.v1.iam_policy_pb2.GetIamPolicyRequest] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.iam.v1.policy_pb2.PolicyGets the IAM access control policy for a function.
See more: google.cloud.pubsub_v1.subscriber.client.Client.get_iam_policy
google.cloud.pubsub_v1.subscriber.client.Client.get_mtls_endpoint_and_cert_source
get_mtls_endpoint_and_cert_source(
    client_options: typing.Optional[
        google.api_core.client_options.ClientOptions
    ] = None,
)Deprecated.
See more: google.cloud.pubsub_v1.subscriber.client.Client.get_mtls_endpoint_and_cert_source
google.cloud.pubsub_v1.subscriber.client.Client.get_snapshot
get_snapshot(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.GetSnapshotRequest, dict]
    ] = None,
    *,
    snapshot: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SnapshotGets the configuration details of a snapshot.
See more: google.cloud.pubsub_v1.subscriber.client.Client.get_snapshot
google.cloud.pubsub_v1.subscriber.client.Client.get_subscription
get_subscription(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.GetSubscriptionRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SubscriptionGets the configuration details of a subscription.
See more: google.cloud.pubsub_v1.subscriber.client.Client.get_subscription
google.cloud.pubsub_v1.subscriber.client.Client.list_snapshots
list_snapshots(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ListSnapshotsRequest, dict]
    ] = None,
    *,
    project: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.pubsub_v1.services.subscriber.pagers.ListSnapshotsPagerLists the existing snapshots.
See more: google.cloud.pubsub_v1.subscriber.client.Client.list_snapshots
google.cloud.pubsub_v1.subscriber.client.Client.list_subscriptions
list_subscriptions(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ListSubscriptionsRequest, dict]
    ] = None,
    *,
    project: typing.Optional[str] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.pubsub_v1.services.subscriber.pagers.ListSubscriptionsPagerLists matching subscriptions.
See more: google.cloud.pubsub_v1.subscriber.client.Client.list_subscriptions
google.cloud.pubsub_v1.subscriber.client.Client.modify_ack_deadline
modify_ack_deadline(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ModifyAckDeadlineRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[str] = None,
    ack_ids: typing.Optional[typing.MutableSequence[str]] = None,
    ack_deadline_seconds: typing.Optional[int] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> NoneModifies the ack deadline for a specific message.
See more: google.cloud.pubsub_v1.subscriber.client.Client.modify_ack_deadline
google.cloud.pubsub_v1.subscriber.client.Client.modify_push_config
modify_push_config(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.ModifyPushConfigRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[str] = None,
    push_config: typing.Optional[google.cloud.pubsub_v1.types.PushConfig] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> NoneModifies the PushConfig for a specified subscription.
See more: google.cloud.pubsub_v1.subscriber.client.Client.modify_push_config
google.cloud.pubsub_v1.subscriber.client.Client.parse_common_billing_account_path
parse_common_billing_account_path(path: str) -> typing.Dict[str, str]Parse a billing_account path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_common_billing_account_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_common_folder_path
parse_common_folder_path(path: str) -> typing.Dict[str, str]Parse a folder path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_common_folder_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_common_location_path
parse_common_location_path(path: str) -> typing.Dict[str, str]Parse a location path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_common_location_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_common_organization_path
parse_common_organization_path(path: str) -> typing.Dict[str, str]Parse a organization path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_common_organization_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_common_project_path
parse_common_project_path(path: str) -> typing.Dict[str, str]Parse a project path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_common_project_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_snapshot_path
parse_snapshot_path(path: str) -> typing.Dict[str, str]Parses a snapshot path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_snapshot_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_subscription_path
parse_subscription_path(path: str) -> typing.Dict[str, str]Parses a subscription path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_subscription_path
google.cloud.pubsub_v1.subscriber.client.Client.parse_topic_path
parse_topic_path(path: str) -> typing.Dict[str, str]Parses a topic path into its component segments.
See more: google.cloud.pubsub_v1.subscriber.client.Client.parse_topic_path
google.cloud.pubsub_v1.subscriber.client.Client.pull
pull(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.PullRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[str] = None,
    return_immediately: typing.Optional[bool] = None,
    max_messages: typing.Optional[int] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.PullResponsePulls messages from the server.
See more: google.cloud.pubsub_v1.subscriber.client.Client.pull
google.cloud.pubsub_v1.subscriber.client.Client.seek
seek(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.SeekRequest, dict]
    ] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SeekResponseSeeks an existing subscription to a point in time or to a given snapshot, whichever is provided in the request.
See more: google.cloud.pubsub_v1.subscriber.client.Client.seek
google.cloud.pubsub_v1.subscriber.client.Client.set_iam_policy
set_iam_policy(
    request: typing.Optional[google.iam.v1.iam_policy_pb2.SetIamPolicyRequest] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.iam.v1.policy_pb2.PolicySets the IAM access control policy on the specified function.
See more: google.cloud.pubsub_v1.subscriber.client.Client.set_iam_policy
google.cloud.pubsub_v1.subscriber.client.Client.snapshot_path
snapshot_path(project: str, snapshot: str) -> strReturns a fully-qualified snapshot string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.snapshot_path
google.cloud.pubsub_v1.subscriber.client.Client.streaming_pull
streaming_pull(
    requests: typing.Optional[
        typing.Iterator[google.cloud.pubsub_v1.types.StreamingPullRequest]
    ] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> typing.Iterable[google.cloud.pubsub_v1.types.StreamingPullResponse]Establishes a stream with the server, which sends messages down to the client.
See more: google.cloud.pubsub_v1.subscriber.client.Client.streaming_pull
google.cloud.pubsub_v1.subscriber.client.Client.subscribe
subscribe(
    subscription: str,
    callback: typing.Callable[[subscriber.message.Message], typing.Any],
    flow_control: typing.Union[
        google.cloud.pubsub_v1.types.FlowControl, typing.Sequence
    ] = (),
    scheduler: typing.Optional[subscriber.scheduler.ThreadScheduler] = None,
    use_legacy_flow_control: bool = False,
    await_callbacks_on_shutdown: bool = False,
) -> google.cloud.pubsub_v1.subscriber.futures.StreamingPullFutureAsynchronously start receiving messages on a given subscription.
See more: google.cloud.pubsub_v1.subscriber.client.Client.subscribe
google.cloud.pubsub_v1.subscriber.client.Client.subscription_path
subscription_path(project: str, subscription: str) -> strReturns a fully-qualified subscription string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.subscription_path
google.cloud.pubsub_v1.subscriber.client.Client.test_iam_permissions
test_iam_permissions(
    request: typing.Optional[
        google.iam.v1.iam_policy_pb2.TestIamPermissionsRequest
    ] = None,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.iam.v1.iam_policy_pb2.TestIamPermissionsResponseTests the specified IAM permissions against the IAM access control policy for a function.
See more: google.cloud.pubsub_v1.subscriber.client.Client.test_iam_permissions
google.cloud.pubsub_v1.subscriber.client.Client.topic_path
topic_path(project: str, topic: str) -> strReturns a fully-qualified topic string.
See more: google.cloud.pubsub_v1.subscriber.client.Client.topic_path
google.cloud.pubsub_v1.subscriber.client.Client.update_snapshot
update_snapshot(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.UpdateSnapshotRequest, dict]
    ] = None,
    *,
    snapshot: typing.Optional[google.cloud.pubsub_v1.types.Snapshot] = None,
    update_mask: typing.Optional[google.protobuf.field_mask_pb2.FieldMask] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SnapshotUpdates an existing snapshot by updating the fields specified in the update mask.
See more: google.cloud.pubsub_v1.subscriber.client.Client.update_snapshot
google.cloud.pubsub_v1.subscriber.client.Client.update_subscription
update_subscription(
    request: typing.Optional[
        typing.Union[google.cloud.pubsub_v1.types.UpdateSubscriptionRequest, dict]
    ] = None,
    *,
    subscription: typing.Optional[google.cloud.pubsub_v1.types.Subscription] = None,
    update_mask: typing.Optional[google.protobuf.field_mask_pb2.FieldMask] = None,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
) -> google.cloud.pubsub_v1.types.SubscriptionUpdates an existing subscription by updating the fields specified in the update mask.
See more: google.cloud.pubsub_v1.subscriber.client.Client.update_subscription
google.cloud.pubsub_v1.subscriber.futures.Future
Future()Initializes the future.
google.cloud.pubsub_v1.subscriber.futures.Future.add_done_callback
add_done_callback(fn)Attaches a callable that will be called when the future finishes.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.add_done_callback
google.cloud.pubsub_v1.subscriber.futures.Future.cancel
cancel() -> boolActions in Pub/Sub generally may not be canceled.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.cancel
google.cloud.pubsub_v1.subscriber.futures.Future.cancelled
cancelled() -> boolActions in Pub/Sub generally may not be canceled.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.cancelled
google.cloud.pubsub_v1.subscriber.futures.Future.done
done()Return True if the future was cancelled or finished executing.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.done
google.cloud.pubsub_v1.subscriber.futures.Future.exception
exception(timeout=None)Return the exception raised by the call that the future represents.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.exception
google.cloud.pubsub_v1.subscriber.futures.Future.result
result(
    timeout: typing.Optional[typing.Union[int, float]] = None
) -> google.cloud.pubsub_v1.subscriber.exceptions.AcknowledgeStatusReturn a success code or raise an exception.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.result
google.cloud.pubsub_v1.subscriber.futures.Future.running
running() -> boolReturn True if the associated Pub/Sub action has not yet completed.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.running
google.cloud.pubsub_v1.subscriber.futures.Future.set_exception
set_exception(exception: typing.Optional[BaseException])Set the result of the future as being the given exception.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.set_exception
google.cloud.pubsub_v1.subscriber.futures.Future.set_result
set_result(result: typing.Any)Set the return value of work associated with the future.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.set_result
google.cloud.pubsub_v1.subscriber.futures.Future.set_running_or_notify_cancel
set_running_or_notify_cancel() -> typing.NoReturnMark the future as running or process any cancel notifications.
See more: google.cloud.pubsub_v1.subscriber.futures.Future.set_running_or_notify_cancel
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture
StreamingPullFuture(manager: StreamingPullManager)Initializes the future.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.add_done_callback
add_done_callback(fn)Attaches a callable that will be called when the future finishes.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.add_done_callback
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.cancel
cancel() -> boolStops pulling messages and shutdowns the background thread consuming messages.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.cancel
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.cancelled
cancelled() -> boolgoogle.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.done
done()Return True if the future was cancelled or finished executing.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.done
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.exception
exception(timeout=None)Return the exception raised by the call that the future represents.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.exception
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.result
result(timeout=None)Return the result of the call that the future represents.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.result
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.running
running() -> boolReturn True if the associated Pub/Sub action has not yet completed.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.running
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.set_exception
set_exception(exception: typing.Optional[BaseException])Set the result of the future as being the given exception.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.set_exception
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.set_result
set_result(result: typing.Any)Set the return value of work associated with the future.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.set_result
google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.set_running_or_notify_cancel
set_running_or_notify_cancel() -> typing.NoReturnMark the future as running or process any cancel notifications.
See more: google.cloud.pubsub_v1.subscriber.futures.StreamingPullFuture.set_running_or_notify_cancel
google.cloud.pubsub_v1.subscriber.message.Message
Message(message: types.PubsubMessage._meta._pb, ack_id: str, delivery_attempt: int, request_queue: queue.Queue, exactly_once_delivery_enabled_func: typing.Callable[[], bool] = Construct the Message.
google.cloud.pubsub_v1.subscriber.message.Message.ack
ack() -> NoneAcknowledge the given message.
See more: google.cloud.pubsub_v1.subscriber.message.Message.ack
google.cloud.pubsub_v1.subscriber.message.Message.ack_with_response
ack_with_response() -> google.cloud.pubsub_v1.subscriber.futures.FutureAcknowledge the given message.
See more: google.cloud.pubsub_v1.subscriber.message.Message.ack_with_response
google.cloud.pubsub_v1.subscriber.message.Message.drop
drop() -> NoneRelease the message from lease management.
See more: google.cloud.pubsub_v1.subscriber.message.Message.drop
google.cloud.pubsub_v1.subscriber.message.Message.modify_ack_deadline
modify_ack_deadline(seconds: int) -> NoneResets the deadline for acknowledgement.
See more: google.cloud.pubsub_v1.subscriber.message.Message.modify_ack_deadline
google.cloud.pubsub_v1.subscriber.message.Message.modify_ack_deadline_with_response
modify_ack_deadline_with_response(
    seconds: int,
) -> google.cloud.pubsub_v1.subscriber.futures.FutureResets the deadline for acknowledgement and returns the response status via a future.
See more: google.cloud.pubsub_v1.subscriber.message.Message.modify_ack_deadline_with_response
google.cloud.pubsub_v1.subscriber.message.Message.nack
nack() -> NoneDecline to acknowledge the given message.
See more: google.cloud.pubsub_v1.subscriber.message.Message.nack
google.cloud.pubsub_v1.subscriber.message.Message.nack_with_response
nack_with_response() -> google.cloud.pubsub_v1.subscriber.futures.FutureDecline to acknowledge the given message, returning the response status via a future.
See more: google.cloud.pubsub_v1.subscriber.message.Message.nack_with_response
google.cloud.pubsub_v1.subscriber.scheduler.Scheduler.schedule
schedule(callback: typing.Callable, *args, **kwargs) -> NoneSchedule the callback to be called asynchronously.
See more: google.cloud.pubsub_v1.subscriber.scheduler.Scheduler.schedule
google.cloud.pubsub_v1.subscriber.scheduler.Scheduler.shutdown
shutdown(
    await_msg_callbacks: bool = False,
) -> typing.List[pubsub_v1.subscriber.message.Message]Shuts down the scheduler and immediately end all pending callbacks.
See more: google.cloud.pubsub_v1.subscriber.scheduler.Scheduler.shutdown
google.cloud.pubsub_v1.subscriber.scheduler.ThreadScheduler.schedule
schedule(callback: typing.Callable, *args, **kwargs) -> NoneSchedule the callback to be called asynchronously in a thread pool.
See more: google.cloud.pubsub_v1.subscriber.scheduler.ThreadScheduler.schedule
google.cloud.pubsub_v1.subscriber.scheduler.ThreadScheduler.shutdown
shutdown(
    await_msg_callbacks: bool = False,
) -> typing.List[pubsub_v1.subscriber.message.Message]Shut down the scheduler and immediately end all pending callbacks.
See more: google.cloud.pubsub_v1.subscriber.scheduler.ThreadScheduler.shutdown
google.cloud.pubsub_v1.types.BatchSettings
BatchSettings(
    max_bytes: int = 1000000, max_latency: float = 0.01, max_messages: int = 100
)Create new instance of BatchSettings(max_bytes, max_latency, max_messages).
google.cloud.pubsub_v1.types.FlowControl
FlowControl(
    max_bytes: int = 104857600,
    max_messages: int = 1000,
    max_lease_duration: float = 3600,
    min_duration_per_lease_extension: float = 0,
    max_duration_per_lease_extension: float = 0,
)Create new instance of FlowControl(max_bytes, max_messages, max_lease_duration, min_duration_per_lease_extension, max_duration_per_lease_extension).
See more: google.cloud.pubsub_v1.types.FlowControl
google.cloud.pubsub_v1.types.PublishFlowControl
PublishFlowControl(
    message_limit: int = 1000,
    byte_limit: int = 10000000,
    limit_exceeded_behavior: google.cloud.pubsub_v1.types.LimitExceededBehavior = LimitExceededBehavior.IGNORE,
)Create new instance of PublishFlowControl(message_limit, byte_limit, limit_exceeded_behavior).
google.cloud.pubsub_v1.types.PublisherOptions
PublisherOptions(enable_message_ordering: bool = False, flow_control: google.cloud.pubsub_v1.types.PublishFlowControl = PublishFlowControl(message_limit=1000, byte_limit=10000000, limit_exceeded_behavior=Create new instance of PublisherOptions(enable_message_ordering, flow_control, retry, timeout, enable_open_telemetry_tracing).
google.pubsub_v1.services.publisher.pagers.ListTopicSnapshotsAsyncPager
ListTopicSnapshotsAsyncPager(
    method: typing.Callable[
        [...], typing.Awaitable[google.cloud.pubsub_v1.types.ListTopicSnapshotsResponse]
    ],
    request: google.cloud.pubsub_v1.types.ListTopicSnapshotsRequest,
    response: google.cloud.pubsub_v1.types.ListTopicSnapshotsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary_async.AsyncRetry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiates the pager.
See more: google.pubsub_v1.services.publisher.pagers.ListTopicSnapshotsAsyncPager
google.pubsub_v1.services.publisher.pagers.ListTopicSnapshotsPager
ListTopicSnapshotsPager(
    method: typing.Callable[
        [...], google.cloud.pubsub_v1.types.ListTopicSnapshotsResponse
    ],
    request: google.cloud.pubsub_v1.types.ListTopicSnapshotsRequest,
    response: google.cloud.pubsub_v1.types.ListTopicSnapshotsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiate the pager.
See more: google.pubsub_v1.services.publisher.pagers.ListTopicSnapshotsPager
google.pubsub_v1.services.publisher.pagers.ListTopicSubscriptionsAsyncPager
ListTopicSubscriptionsAsyncPager(
    method: typing.Callable[
        [...],
        typing.Awaitable[google.cloud.pubsub_v1.types.ListTopicSubscriptionsResponse],
    ],
    request: google.cloud.pubsub_v1.types.ListTopicSubscriptionsRequest,
    response: google.cloud.pubsub_v1.types.ListTopicSubscriptionsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary_async.AsyncRetry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiates the pager.
See more: google.pubsub_v1.services.publisher.pagers.ListTopicSubscriptionsAsyncPager
google.pubsub_v1.services.publisher.pagers.ListTopicSubscriptionsPager
ListTopicSubscriptionsPager(
    method: typing.Callable[
        [...], google.cloud.pubsub_v1.types.ListTopicSubscriptionsResponse
    ],
    request: google.cloud.pubsub_v1.types.ListTopicSubscriptionsRequest,
    response: google.cloud.pubsub_v1.types.ListTopicSubscriptionsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiate the pager.
See more: google.pubsub_v1.services.publisher.pagers.ListTopicSubscriptionsPager
google.pubsub_v1.services.publisher.pagers.ListTopicsAsyncPager
ListTopicsAsyncPager(
    method: typing.Callable[
        [...], typing.Awaitable[google.cloud.pubsub_v1.types.ListTopicsResponse]
    ],
    request: google.cloud.pubsub_v1.types.ListTopicsRequest,
    response: google.cloud.pubsub_v1.types.ListTopicsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary_async.AsyncRetry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiates the pager.
See more: google.pubsub_v1.services.publisher.pagers.ListTopicsAsyncPager
google.pubsub_v1.services.publisher.pagers.ListTopicsPager
ListTopicsPager(
    method: typing.Callable[[...], google.cloud.pubsub_v1.types.ListTopicsResponse],
    request: google.cloud.pubsub_v1.types.ListTopicsRequest,
    response: google.cloud.pubsub_v1.types.ListTopicsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiate the pager.
See more: google.pubsub_v1.services.publisher.pagers.ListTopicsPager
google.pubsub_v1.services.subscriber.pagers.ListSnapshotsAsyncPager
ListSnapshotsAsyncPager(
    method: typing.Callable[
        [...], typing.Awaitable[google.cloud.pubsub_v1.types.ListSnapshotsResponse]
    ],
    request: google.cloud.pubsub_v1.types.ListSnapshotsRequest,
    response: google.cloud.pubsub_v1.types.ListSnapshotsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary_async.AsyncRetry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiates the pager.
See more: google.pubsub_v1.services.subscriber.pagers.ListSnapshotsAsyncPager
google.pubsub_v1.services.subscriber.pagers.ListSnapshotsPager
ListSnapshotsPager(
    method: typing.Callable[[...], google.cloud.pubsub_v1.types.ListSnapshotsResponse],
    request: google.cloud.pubsub_v1.types.ListSnapshotsRequest,
    response: google.cloud.pubsub_v1.types.ListSnapshotsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiate the pager.
See more: google.pubsub_v1.services.subscriber.pagers.ListSnapshotsPager
google.pubsub_v1.services.subscriber.pagers.ListSubscriptionsAsyncPager
ListSubscriptionsAsyncPager(
    method: typing.Callable[
        [...], typing.Awaitable[google.cloud.pubsub_v1.types.ListSubscriptionsResponse]
    ],
    request: google.cloud.pubsub_v1.types.ListSubscriptionsRequest,
    response: google.cloud.pubsub_v1.types.ListSubscriptionsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary_async.AsyncRetry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiates the pager.
See more: google.pubsub_v1.services.subscriber.pagers.ListSubscriptionsAsyncPager
google.pubsub_v1.services.subscriber.pagers.ListSubscriptionsPager
ListSubscriptionsPager(
    method: typing.Callable[
        [...], google.cloud.pubsub_v1.types.ListSubscriptionsResponse
    ],
    request: google.cloud.pubsub_v1.types.ListSubscriptionsRequest,
    response: google.cloud.pubsub_v1.types.ListSubscriptionsResponse,
    *,
    retry: typing.Optional[
        typing.Union[
            google.api_core.retry.retry_unary.Retry,
            google.api_core.gapic_v1.method._MethodDefault,
        ]
    ] = _MethodDefault._DEFAULT_VALUE,
    timeout: typing.Union[float, object] = _MethodDefault._DEFAULT_VALUE,
    metadata: typing.Sequence[typing.Tuple[str, str]] = ()
)Instantiate the pager.
See more: google.pubsub_v1.services.subscriber.pagers.ListSubscriptionsPager