As of January 1, 2020 this library no longer supports Python 2 on the latest released version. Library versions released prior to that date will continue to be available. For more information please visit Python 2 support on Google Cloud.

Source code for google.cloud.pubsublite.cloudpubsub.subscriber_client

# Copyright 2020 Google LLC
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
#     http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.

from concurrent.futures.thread import ThreadPoolExecutor
from typing import Optional, Union, Set, AsyncIterator

from google.api_core.client_options import ClientOptions
from google.auth.credentials import Credentials
from google.cloud.pubsub_v1.subscriber.futures import StreamingPullFuture
from google.cloud.pubsub_v1.subscriber.message import Message

from google.cloud.pubsublite.cloudpubsub.reassignment_handler import ReassignmentHandler
from google.cloud.pubsublite.cloudpubsub.internal.make_subscriber import (
    make_async_subscriber,
)
from google.cloud.pubsublite.cloudpubsub.internal.multiplexed_async_subscriber_client import (
    MultiplexedAsyncSubscriberClient,
)
from google.cloud.pubsublite.cloudpubsub.internal.multiplexed_subscriber_client import (
    MultiplexedSubscriberClient,
)
from google.cloud.pubsublite.cloudpubsub.message_transformer import MessageTransformer
from google.cloud.pubsublite.cloudpubsub.nack_handler import NackHandler
from google.cloud.pubsublite.cloudpubsub.subscriber_client_interface import (
    SubscriberClientInterface,
    AsyncSubscriberClientInterface,
    MessageCallback,
)
from google.cloud.pubsublite.internal.constructable_from_service_account import (
    ConstructableFromServiceAccount,
)
from google.cloud.pubsublite.internal.require_started import RequireStarted
from google.cloud.pubsublite.types import (
    FlowControlSettings,
    Partition,
    SubscriptionPath,
)
from overrides import overrides


[docs]class SubscriberClient(SubscriberClientInterface, ConstructableFromServiceAccount): """ A SubscriberClient reads messages similar to Google Pub/Sub. Any subscribe failures are unlikely to succeed if retried. Must be used in a `with` block or have __enter__() called before use. """ _impl: SubscriberClientInterface _require_started: RequireStarted def __init__( self, *, executor: Optional[ThreadPoolExecutor] = None, nack_handler: Optional[NackHandler] = None, reassignment_handler: Optional[ReassignmentHandler] = None, message_transformer: Optional[MessageTransformer] = None, credentials: Optional[Credentials] = None, transport: str = "grpc_asyncio", client_options: Optional[ClientOptions] = None, ): """ Create a new SubscriberClient. Args: executor: A ThreadPoolExecutor to use. The client will shut it down on __exit__. If provided a single threaded executor, messages will be ordered per-partition, but take care that the callback does not block for too long as it will impede forward progress on all subscriptions. nack_handler: A handler for when `nack()` is called. The default NackHandler raises an exception and fails the subscribe stream. message_transformer: A transformer from Pub/Sub Lite messages to Cloud Pub/Sub messages. This may not return a message with "message_id" set. credentials: If provided, the credentials to use when connecting. transport: The transport to use. Must correspond to an asyncio transport. client_options: The client options to use when connecting. If used, must explicitly set `api_endpoint`. """ if executor is None: executor = ThreadPoolExecutor() self._impl = MultiplexedSubscriberClient( executor, lambda subscription, partitions, settings: make_async_subscriber( subscription=subscription, transport=transport, per_partition_flow_control_settings=settings, nack_handler=nack_handler, reassignment_handler=reassignment_handler, message_transformer=message_transformer, fixed_partitions=partitions, credentials=credentials, client_options=client_options, ), ) self._require_started = RequireStarted()
[docs] @overrides def subscribe( self, subscription: Union[SubscriptionPath, str], callback: MessageCallback, per_partition_flow_control_settings: FlowControlSettings, fixed_partitions: Optional[Set[Partition]] = None, ) -> StreamingPullFuture: self._require_started.require_started() return self._impl.subscribe( subscription, callback, per_partition_flow_control_settings, fixed_partitions, )
[docs] @overrides def __enter__(self): self._require_started.__enter__() self._impl.__enter__() return self
[docs] @overrides def __exit__(self, exc_type, exc_value, traceback): self._impl.__exit__(exc_type, exc_value, traceback) self._require_started.__exit__(exc_type, exc_value, traceback)
[docs]class AsyncSubscriberClient( AsyncSubscriberClientInterface, ConstructableFromServiceAccount ): """ An AsyncSubscriberClient reads messages similar to Google Pub/Sub, but must be used in an async context. Any subscribe failures are unlikely to succeed if retried. Must be used in an `async with` block or have __aenter__() awaited before use. """ _impl: AsyncSubscriberClientInterface _require_started: RequireStarted def __init__( self, *, nack_handler: Optional[NackHandler] = None, reassignment_handler: Optional[ReassignmentHandler] = None, message_transformer: Optional[MessageTransformer] = None, credentials: Optional[Credentials] = None, transport: str = "grpc_asyncio", client_options: Optional[ClientOptions] = None, ): """ Create a new AsyncSubscriberClient. Args: nack_handler: A handler for when `nack()` is called. The default NackHandler raises an exception and fails the subscribe stream. message_transformer: A transformer from Pub/Sub Lite messages to Cloud Pub/Sub messages. This may not return a message with "message_id" set. credentials: If provided, the credentials to use when connecting. transport: The transport to use. Must correspond to an asyncio transport. client_options: The client options to use when connecting. If used, must explicitly set `api_endpoint`. """ self._impl = MultiplexedAsyncSubscriberClient( lambda subscription, partitions, settings: make_async_subscriber( subscription=subscription, transport=transport, per_partition_flow_control_settings=settings, nack_handler=nack_handler, reassignment_handler=reassignment_handler, message_transformer=message_transformer, fixed_partitions=partitions, credentials=credentials, client_options=client_options, ) ) self._require_started = RequireStarted()
[docs] @overrides async def subscribe( self, subscription: Union[SubscriptionPath, str], per_partition_flow_control_settings: FlowControlSettings, fixed_partitions: Optional[Set[Partition]] = None, ) -> AsyncIterator[Message]: self._require_started.require_started() return await self._impl.subscribe( subscription, per_partition_flow_control_settings, fixed_partitions )
[docs] @overrides async def __aenter__(self): self._require_started.__enter__() await self._impl.__aenter__() return self
[docs] @overrides async def __aexit__(self, exc_type, exc_value, traceback): await self._impl.__aexit__(exc_type, exc_value, traceback) self._require_started.__exit__(exc_type, exc_value, traceback)