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.pubsub_v1.subscriber.scheduler
# Copyright 2018, 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
#
# https://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.
"""Schedulers provide means to *schedule* callbacks asynchronously.
These are used by the subscriber to call the user-provided callback to process
each message.
"""
import abc
import concurrent.futures
import queue
import warnings
[docs]class Scheduler(metaclass=abc.ABCMeta):
"""Abstract base class for schedulers.
Schedulers are used to schedule callbacks asynchronously.
"""
@property
@abc.abstractmethod
def queue(self): # pragma: NO COVER
"""Queue: A concurrency-safe queue specific to the underlying
concurrency implementation.
This queue is used to send messages *back* to the scheduling actor.
"""
raise NotImplementedError
[docs] @abc.abstractmethod
def schedule(self, callback, *args, **kwargs): # pragma: NO COVER
"""Schedule the callback to be called asynchronously.
Args:
callback (Callable): The function to call.
args: Positional arguments passed to the function.
kwargs: Key-word arguments passed to the function.
Returns:
None
"""
raise NotImplementedError
[docs] @abc.abstractmethod
def shutdown(self, await_msg_callbacks=False): # pragma: NO COVER
"""Shuts down the scheduler and immediately end all pending callbacks.
Args:
await_msg_callbacks (bool):
If ``True``, the method will block until all currently executing
callbacks are done processing. If ``False`` (default), the
method will not wait for the currently running callbacks to complete.
Returns:
List[pubsub_v1.subscriber.message.Message]:
The messages submitted to the scheduler that were not yet dispatched
to their callbacks.
It is assumed that each message was submitted to the scheduler as the
first positional argument to the provided callback.
"""
raise NotImplementedError
def _make_default_thread_pool_executor():
return concurrent.futures.ThreadPoolExecutor(
max_workers=10, thread_name_prefix="ThreadPoolExecutor-ThreadScheduler"
)
[docs]class ThreadScheduler(Scheduler):
"""A thread pool-based scheduler. It must not be shared across
SubscriberClients.
This scheduler is useful in typical I/O-bound message processing.
Args:
executor(concurrent.futures.ThreadPoolExecutor): An optional executor
to use. If not specified, a default one will be created.
"""
def __init__(self, executor=None):
self._queue = queue.Queue()
if executor is None:
self._executor = _make_default_thread_pool_executor()
else:
self._executor = executor
@property
def queue(self):
"""Queue: A thread-safe queue used for communication between callbacks
and the scheduling thread."""
return self._queue
[docs] def schedule(self, callback, *args, **kwargs):
"""Schedule the callback to be called asynchronously in a thread pool.
Args:
callback (Callable): The function to call.
args: Positional arguments passed to the function.
kwargs: Key-word arguments passed to the function.
Returns:
None
"""
try:
self._executor.submit(callback, *args, **kwargs)
except RuntimeError:
warnings.warn(
"Scheduling a callback after executor shutdown.",
category=RuntimeWarning,
stacklevel=2,
)
[docs] def shutdown(self, await_msg_callbacks=False):
"""Shut down the scheduler and immediately end all pending callbacks.
Args:
await_msg_callbacks (bool):
If ``True``, the method will block until all currently executing
executor threads are done processing. If ``False`` (default), the
method will not wait for the currently running threads to complete.
Returns:
List[pubsub_v1.subscriber.message.Message]:
The messages submitted to the scheduler that were not yet dispatched
to their callbacks.
It is assumed that each message was submitted to the scheduler as the
first positional argument to the provided callback.
"""
dropped_messages = []
# Drop all pending item from the executor. Without this, the executor will also
# try to process any pending work items before termination, which is undesirable.
#
# TODO: Replace the logic below by passing `cancel_futures=True` to shutdown()
# once we only need to support Python 3.9+.
try:
while True:
work_item = self._executor._work_queue.get(block=False)
if work_item is None: # Exceutor in shutdown mode.
continue
dropped_messages.append(work_item.args[0])
except queue.Empty:
pass
self._executor.shutdown(wait=await_msg_callbacks)
return dropped_messages