Your message dated Sun, 01 May 2022 21:33:23 +0000
with message-id <e1nlhbz-00010x...@fasolo.debian.org>
and subject line Bug#1000271: fixed in jupyter-client 7.3.0-1
has caused the Debian Bug report #1000271,
regarding jupyter-client breaks dask.distributed autopkgtest: ERROR - Workers 
don't have promised key: ['tcp://127.0.0.1:33937']
to be marked as done.

This means that you claim that the problem has been dealt with.
If this is not the case it is now your responsibility to reopen the
Bug report if necessary, and/or fix the problem forthwith.

(NB: If you are a system administrator and have no idea what this
message is talking about, this may indicate a serious mail system
misconfiguration somewhere. Please contact ow...@bugs.debian.org
immediately.)


-- 
1000271: https://bugs.debian.org/cgi-bin/bugreport.cgi?bug=1000271
Debian Bug Tracking System
Contact ow...@bugs.debian.org with problems
--- Begin Message ---
Source: jupyter-client, dask.distributed
Control: found -1 jupyter-client/7.0.6-2
Control: found -1 dask.distributed/2021.09.1+ds.1-2
Severity: serious
Tags: sid bookworm
X-Debbugs-CC: debian...@lists.debian.org
User: debian...@lists.debian.org
Usertags: breaks needs-update

Dear maintainer(s),

With a recent upload of jupyter-client the autopkgtest of dask.distributed fails in testing when that autopkgtest is run with the binary packages of jupyter-client from unstable. It passes on arm64 and ppc64el when run with only packages from testing. In tabular form:

                       pass            fail
jupyter-client         from testing    7.0.6-2
dask.distributed       from testing    2021.09.1+ds.1-2
all others             from testing    from testing

I copied some of the output at the bottom of this report.

Currently this regression is blocking the migration of jupyter-client to testing [1]. Due to the nature of this issue, I filed this bug report against both packages. Can you please investigate the situation and reassign the bug to the right package?

More information about this bug and the reason for filing it can be found on
https://wiki.debian.org/ContinuousIntegration/RegressionEmailInformation

Paul

[1] https://qa.debian.org/excuses.php?package=jupyter-client

https://ci.debian.net/data/autopkgtest/testing/arm64/d/dask.distributed/16840880/log.gz

=================================== FAILURES =================================== ________________________ test_gather_failing_cnn_error _________________________

outer_args = (), kwargs = {}, result = None
coro = <function gen_cluster.<locals>._.<locals>.test_func.<locals>.coro at 0xffff0c67d550>

    @functools.wraps(func)
    def test_func(*outer_args, **kwargs):
        result = None
        workers = []
with clean(timeout=active_rpc_timeout, **clean_kwargs) as loop: async def coro():
                with dask.config.set(config):
                    s = False
for _ in range(60):
                        try:
                            s, ws = await start_cluster(
                                nthreads,
                                scheduler,
                                loop,
                                security=security,
                                Worker=Worker,
                                scheduler_kwargs=scheduler_kwargs,
                                worker_kwargs=worker_kwargs,
                            )
except Exception as e:
                            logger.error(
"Failed to start gen_cluster: "

f"{e.__class__.__name__}: {e}; retrying",
                                exc_info=True,
                            )
await asyncio.sleep(1)
                        else:
                            workers[:] = ws
                            args = [s] + workers
                            break
if s is False: raise Exception("Could not start cluster")
                    if client:
                        c = await Client(
                            s.address,
                            loop=loop,
                            security=security,
                            asynchronous=True,
                            **client_kwargs,
                        )
                        args = [c] + args
                    try:
                        future = func(*args, *outer_args, **kwargs)
                        future = asyncio.wait_for(future, timeout)
                        result = await future
                        if s.validate:
                            s.validate_state()
                    finally:
if client and c.status not in ("closing", "closed"): await c._close(fast=s.status == Status.closed)
                        await end_cluster(s, workers)
await asyncio.wait_for(cleanup_global_workers(), 1)
                        try:
                        c = await default_client()
                    except ValueError:
                        pass
                    else:
await c._close(fast=True)
                        def get_unclosed():
return [c for c in Comm._instances if not c.closed()] + [
                            c
for c in _global_clients.values() if c.status != "closed"
                        ]
                        try:
                        start = time()
while time() < start + 60:
                            gc.collect()
if not get_unclosed():
                                break
await asyncio.sleep(0.05)
                        else:
                            if allow_unclosed:

print(f"Unclosed Comms: {get_unclosed()}")
                            else:
raise RuntimeError("Unclosed Comms", get_unclosed())
                    finally:
                        Comm._instances.clear()
                        _global_clients.clear()
                        return result
    >           result = loop.run_sync(
coro, timeout=timeout * 2 if timeout else timeout
            )

/usr/lib/python3/dist-packages/distributed/utils_test.py:994: _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
self = <tornado.platform.asyncio.AsyncIOLoop object at 0xffff0c5b8ac0>
func = <function gen_cluster.<locals>._.<locals>.test_func.<locals>.coro at 0xffff0c67d550>
timeout = 60

def run_sync(self, func: Callable, timeout: Optional[float] = None) -> Any: """Starts the `IOLoop`, runs the given function, and stops the loop.
    
 The function must return either an awaitable object or  ``None``. If the function returns an awaitable object, the  `IOLoop` will run until the awaitable is resolved (and  `run_sync()` will return the awaitable's result). If it raises  an exception, the `IOLoop` will stop and the exception will be
        re-raised to the caller.
    
 The keyword-only argument ``timeout`` may be used to set  a maximum duration for the function. If the timeout expires,
        a `tornado.util.TimeoutError` is raised.
    
 This method is useful to allow asynchronous calls in a
        ``main()`` function::
    
            async def main():
                # do stuff...
    
            if __name__ == '__main__':
                IOLoop.current().run_sync(main)
    
        .. versionchanged:: 4.3
 Returning a non-``None``, non-awaitable value is now an error.
    
        .. versionchanged:: 5.0
 If a timeout occurs, the ``func`` coroutine will be cancelled.
    
        """
future_cell = [None] # type: List[Optional[Future]] def run() -> None:
            try:
                result = func()
if result is not None: from tornado.gen import convert_yielded
                        result = convert_yielded(result)
            except Exception:
                fut = Future()  # type: Future[Any]
                future_cell[0] = fut
                future_set_exc_info(fut, sys.exc_info())
            else:
                if is_future(result):
                    future_cell[0] = result
                else:
                    fut = Future()
                    future_cell[0] = fut
                    fut.set_result(result)
assert future_cell[0] is not None

self.add_future(future_cell[0], lambda future: self.stop())
            self.add_callback(run)
if timeout is not None: def timeout_callback() -> None: # If we can cancel the future, do so and wait on it. If not, # Just stop the loop and return with the task still pending. # (If we neither cancel nor wait for the task, a warning
                # will be logged).
assert future_cell[0] is not None if not future_cell[0].cancel():
                    self.stop()
timeout_handle = self.add_timeout(self.time() + timeout, timeout_callback)
        self.start()
if timeout is not None:
            self.remove_timeout(timeout_handle)
assert future_cell[0] is not None if future_cell[0].cancelled() or not future_cell[0].done():
          raise 
TimeoutError("Operation timed out after 
%s seconds" % timeout)
E tornado.util.TimeoutError: Operation timed out after 60 seconds

/usr/lib/python3/dist-packages/tornado/ioloop.py:529: TimeoutError ----------------------------- Captured stderr call -----------------------------
distributed.scheduler - INFO - Clear task state
distributed.scheduler - INFO -   Scheduler at:     tcp://127.0.0.1:44789
distributed.scheduler - INFO -   dashboard at:           127.0.0.1:38549
distributed.worker - INFO - Start worker at: tcp://127.0.0.1:33937 distributed.worker - INFO - Listening to: tcp://127.0.0.1:33937 distributed.worker - INFO - dashboard at: 127.0.0.1:44863 distributed.worker - INFO - Waiting to connect to: tcp://127.0.0.1:44789 distributed.worker - INFO - ------------------------------------------------- distributed.worker - INFO - Threads: 1 distributed.worker - INFO - Memory: 7.76 GiB distributed.worker - INFO - Local Directory: /tmp/autopkgtest-lxc.l9pbwc9x/downtmp/autopkgtest_tmp/dask-worker-space/worker-8y9lyj99 distributed.worker - INFO - ------------------------------------------------- distributed.worker - INFO - Start worker at: tcp://127.0.0.1:46645 distributed.worker - INFO - Listening to: tcp://127.0.0.1:46645 distributed.worker - INFO - dashboard at: 127.0.0.1:37565 distributed.worker - INFO - Waiting to connect to: tcp://127.0.0.1:44789 distributed.worker - INFO - ------------------------------------------------- distributed.worker - INFO - Threads: 2 distributed.worker - INFO - Memory: 7.76 GiB distributed.worker - INFO - Local Directory: /tmp/autopkgtest-lxc.l9pbwc9x/downtmp/autopkgtest_tmp/dask-worker-space/worker-9sq6sdkf distributed.worker - INFO - ------------------------------------------------- distributed.scheduler - INFO - Register worker <WorkerState 'tcp://127.0.0.1:33937', name: 0, memory: 0, processing: 0> distributed.scheduler - INFO - Starting worker compute stream, tcp://127.0.0.1:33937
distributed.core - INFO - Starting established connection
distributed.scheduler - INFO - Register worker <WorkerState 'tcp://127.0.0.1:46645', name: 1, memory: 0, processing: 0> distributed.scheduler - INFO - Starting worker compute stream, tcp://127.0.0.1:46645
distributed.core - INFO - Starting established connection
distributed.worker - INFO - Registered to: tcp://127.0.0.1:44789 distributed.worker - INFO - ------------------------------------------------- distributed.worker - INFO - Registered to: tcp://127.0.0.1:44789 distributed.worker - INFO - -------------------------------------------------
distributed.core - INFO - Starting established connection
distributed.core - INFO - Starting established connection
distributed.scheduler - INFO - Receive client connection: Client-4785c8fe-49d3-11ec-91e8-00163ef32aa5
distributed.core - INFO - Starting established connection
distributed.scheduler - ERROR - Couldn't gather keys {'x': ['tcp://127.0.0.1:33937']} state: ['memory'] workers: ['tcp://127.0.0.1:33937']
Traceback (most recent call last):
  File "/usr/lib/python3.9/asyncio/tasks.py", line 328, in __wakeup
    future.result()
  File "/usr/lib/python3.9/asyncio/futures.py", line 201, in result
    raise self._exception
  File "/usr/lib/python3.9/asyncio/tasks.py", line 256, in __step
    result = coro.send(None)
File "/usr/lib/python3/dist-packages/distributed/worker.py", line 3759, in get_data_from_worker return await retry_operation(_get_data, operation="get_data_from_worker") File "/usr/lib/python3/dist-packages/distributed/utils_comm.py", line 385, in retry_operation
    return await retry(
File "/usr/lib/python3/dist-packages/distributed/utils_comm.py", line 370, in retry
    return await coro()
File "/usr/lib/python3/dist-packages/distributed/worker.py", line 3739, in _get_data
    response = await send_recv(
File "/usr/lib/python3/dist-packages/distributed/core.py", line 649, in send_recv
    await comm.write(msg, serializers=serializers, on_error="raise")
File "/usr/lib/python3/dist-packages/distributed/tests/test_scheduler.py", line 2118, in write
    raise OSError()
OSError
distributed.scheduler - INFO - Remove worker <WorkerState 'tcp://127.0.0.1:33937', name: 0, memory: 1, processing: 0>
distributed.core - INFO - Removing comms to tcp://127.0.0.1:33937
distributed.scheduler - ERROR - Workers don't have promised key: ['tcp://127.0.0.1:33937'], x
NoneType: None
distributed.scheduler - INFO - Remove client Client-4785c8fe-49d3-11ec-91e8-00163ef32aa5 distributed.scheduler - INFO - Remove client Client-4785c8fe-49d3-11ec-91e8-00163ef32aa5 distributed.scheduler - INFO - Close client connection: Client-4785c8fe-49d3-11ec-91e8-00163ef32aa5
distributed.worker - INFO - Stopping worker at tcp://127.0.0.1:33937
distributed.worker - INFO - Stopping worker at tcp://127.0.0.1:46645
distributed.scheduler - INFO - Remove worker <WorkerState 'tcp://127.0.0.1:46645', name: 1, memory: 0, processing: 0>
distributed.core - INFO - Removing comms to tcp://127.0.0.1:46645
distributed.scheduler - INFO - Lost all workers
distributed.scheduler - INFO - Scheduler closing...
distributed.scheduler - INFO - Scheduler closing all comms
=============================== warnings summary ===============================
../../../../usr/lib/python3/dist-packages/distributed/tests/test_actor.py:478
/usr/lib/python3/dist-packages/distributed/tests/test_actor.py:478: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(reruns=10, reruns_delay=5)

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:40
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:40: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:67
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:67: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:82
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:82: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:98
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:98: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:120
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:120: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:136
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:136: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:142
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:142: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:154
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:154: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:218
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:218: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:224
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:224: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_batched.py:229
/usr/lib/python3/dist-packages/distributed/tests/test_batched.py:229: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:5328
/usr/lib/python3/dist-packages/distributed/tests/test_client.py:5328: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(condition=WINDOWS, reruns=10, reruns_delay=5)

../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:5973
/usr/lib/python3/dist-packages/distributed/tests/test_client.py:5973: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:6019
/usr/lib/python3/dist-packages/distributed/tests/test_client.py:6019: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_config.py:112
/usr/lib/python3/dist-packages/distributed/tests/test_config.py:112: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_config.py:152
/usr/lib/python3/dist-packages/distributed/tests/test_config.py:152: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_config.py:188
/usr/lib/python3/dist-packages/distributed/tests/test_config.py:188: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_config.py:251
/usr/lib/python3/dist-packages/distributed/tests/test_config.py:251: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_config.py:261
/usr/lib/python3/dist-packages/distributed/tests/test_config.py:261: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:179
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:179: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:325
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:325: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:331
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:331: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:337
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:337: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:348
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:348: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:353
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:353: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:397
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:397: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:402
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:402: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:407
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:407: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:430
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:430: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:435
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:435: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:458
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:458: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:463
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:463: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:481
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:481: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:486
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:486: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:491
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:491: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:525
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:525: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:535
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:535: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:541
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:541: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:565
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:565: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:614
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:614: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:663
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:663: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:686
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:686: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:713
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:713: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:752
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:752: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:836
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:836: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:850
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:850: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:882
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:882: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:930
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:930: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:936
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:936: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:963
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:963: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:981
/usr/lib/python3/dist-packages/distributed/tests/test_core.py:981: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_failed_workers.py:330

/usr/lib/python3/dist-packages/distributed/tests/test_failed_workers.py:330: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(condition=MACOS, reruns=10, reruns_delay=5)

../../../../usr/lib/python3/dist-packages/distributed/tests/test_failed_workers.py:410

/usr/lib/python3/dist-packages/distributed/tests/test_failed_workers.py:410: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(reruns=10, reruns_delay=5)

../../../../usr/lib/python3/dist-packages/distributed/tests/test_nanny.py:560
/usr/lib/python3/dist-packages/distributed/tests/test_nanny.py:560: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_preload.py:143
/usr/lib/python3/dist-packages/distributed/tests/test_preload.py:143: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_preload.py:208
/usr/lib/python3/dist-packages/distributed/tests/test_preload.py:208: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_preload.py:285
/usr/lib/python3/dist-packages/distributed/tests/test_preload.py:285: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_queues.py:280
/usr/lib/python3/dist-packages/distributed/tests/test_queues.py:280: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_scheduler.py:1325

/usr/lib/python3/dist-packages/distributed/tests/test_scheduler.py:1325: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_scheduler.py:2493

/usr/lib/python3/dist-packages/distributed/tests/test_scheduler.py:2493: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html @pytest.mark.flaky(condition=LINUX, reason="see comments", reruns=10, reruns_delay=5)

../../../../usr/lib/python3/dist-packages/distributed/tests/test_security.py:285

/usr/lib/python3/dist-packages/distributed/tests/test_security.py:285: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_security.py:333

/usr/lib/python3/dist-packages/distributed/tests/test_security.py:333: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_security.py:420

/usr/lib/python3/dist-packages/distributed/tests/test_security.py:420: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_steal.py:113
/usr/lib/python3/dist-packages/distributed/tests/test_steal.py:113: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(reruns=10, reruns_delay=5, reason="GH#3574")

../../../../usr/lib/python3/dist-packages/distributed/tests/test_steal.py:647
/usr/lib/python3/dist-packages/distributed/tests/test_steal.py:647: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(

../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils.py:550
/usr/lib/python3/dist-packages/distributed/tests/test_utils.py:550: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:268

/usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:268: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:294

/usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:294: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:322

/usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:322: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:352

/usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:352: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_variable.py:41
/usr/lib/python3/dist-packages/distributed/tests/test_variable.py:41: PytestUnknownMarkWarning: Unknown pytest.mark.isinstalled - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.isinstalled

../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1099
/usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1099: PytestUnknownMarkWarning: Unknown pytest.mark.flaky - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.flaky(reruns=10, reruns_delay=5)

../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1509
/usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1509: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1541
/usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1541: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1555
/usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1555: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1574
/usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1574: PytestUnknownMarkWarning: Unknown pytest.mark.asyncio - is this a typo? You can register custom marks to avoid this warning - for details, see https://docs.pytest.org/en/stable/mark.html
    @pytest.mark.asyncio

tests/test_active_memory_manager.py: 15 warnings
tests/test_client.py: 113 warnings
tests/test_failed_workers.py: 20 warnings
tests/test_scheduler.py: 22 warnings
tests/test_stress.py: 10 warnings
tests/test_worker.py: 5 warnings
/usr/lib/python3/dist-packages/distributed/scheduler.py:6425: DeprecationWarning: Sampling from a set deprecated
  since Python 3.9 and will be removed in a subsequent version.
    for ws in random.sample(workers - ts._who_has, count):

tests/test_actor.py::test_client_actions[True]
tests/test_actor.py::test_client_actions[False]
/usr/lib/python3/dist-packages/distributed/tests/test_actor.py:87: RuntimeWarning: coroutine 'Actor.__getattr__.<locals>.get_actor_attribute_from_worker' was never awaited
    assert hasattr(counter, "n")

tests/test_actor.py: 218 warnings
/usr/lib/python3/dist-packages/distributed/actor.py:171: DeprecationWarning: The loop argument is deprecated since Python 3.8, and scheduled for removal in Python 3.10.
    q = asyncio.Queue(loop=self._io_loop.asyncio_loop)

tests/test_actor.py: 218 warnings
/usr/lib/python3.9/asyncio/queues.py:48: DeprecationWarning: The loop argument is deprecated since Python 3.8, and scheduled for removal in Python 3.10.
    self._finished = locks.Event(loop=loop)

tests/test_actor.py::test_Actor
/usr/lib/python3/dist-packages/distributed/tests/test_actor.py:146: RuntimeWarning: coroutine 'Actor.__getattr__.<locals>.get_actor_attribute_from_worker' was never awaited
    assert hasattr(counter, "n")

tests/test_batched.py: 9 warnings
tests/test_client.py: 3 warnings
tests/test_core.py: 31 warnings
tests/test_nanny.py: 2 warnings
tests/test_preload.py: 3 warnings
tests/test_scheduler.py: 6 warnings
tests/test_security.py: 3 warnings
tests/test_utils.py: 1 warning
tests/test_utils_test.py: 4 warnings
tests/test_worker.py: 7 warnings
/usr/lib/python3/dist-packages/_pytest/python.py:172: PytestUnhandledCoroutineWarning: async def functions are not natively supported and have been skipped. You need to install a suitable plugin for your async framework, for example:
    - anyio
    - pytest-asyncio
    - pytest-tornasync
    - pytest-trio
    - pytest-twisted
    warnings.warn(PytestUnhandledCoroutineWarning(msg.format(nodeid)))

tests/test_client.py::test_long_error
/usr/lib/python3/dist-packages/_pytest/unraisableexception.py:78: PytestUnraisableExceptionWarning: Exception ignored in: <function Client.__del__ at 0xffff90ab8430>
    Traceback (most recent call last):
File "/usr/lib/python3/dist-packages/distributed/client.py", line 1185, in __del__
      self.close()
File "/usr/lib/python3/dist-packages/distributed/client.py", line 1398, in close
      if self.asynchronous:
File "/usr/lib/python3/dist-packages/distributed/client.py", line 808, in asynchronous
      return self._asynchronous and self.loop is IOLoop.current()
  AttributeError: 'Client' object has no attribute '_asynchronous'
      warnings.warn(pytest.PytestUnraisableExceptionWarning(msg))

tests/test_client.py::test_replicate_workers
tests/test_client.py::test_replicate_workers
tests/test_client.py::test_replicate_workers
tests/test_client.py::test_replicate_workers
tests/test_client.py::test_client_replicate
tests/test_client.py::test_client_replicate
/usr/lib/python3/dist-packages/distributed/scheduler.py:6395: DeprecationWarning: Sampling from a set deprecated
  since Python 3.9 and will be removed in a subsequent version.
    for ws in random.sample(

tests/test_client.py::test_client_async_before_loop_starts
/usr/lib/python3/dist-packages/distributed/tests/test_client.py:5408: RuntimeWarning: coroutine 'wait_for' was never awaited
    client.close()

tests/test_client_executor.py::test_as_completed
tests/test_client_executor.py::test_cancellation
tests/test_client_executor.py::test_cancellation_wait
tests/test_client_executor.py::test_cancellation_as_completed
tests/test_client_executor.py::test_pure
/usr/lib/python3/dist-packages/tornado/iostream.py:254: RuntimeWarning: coroutine 'Future._result' was never awaited self.read_chunk_size = min(read_chunk_size or 65536, self.max_buffer_size // 2)

tests/test_client_executor.py::test_shutdown_wait
/usr/lib/python3.9/threading.py:571: RuntimeWarning: coroutine 'Future._result' was never awaited
    with self._cond:

-- Docs: https://docs.pytest.org/en/stable/warnings.html
============================= slowest 20 durations =============================
60.03s call     tests/test_scheduler.py::test_gather_failing_cnn_error
7.33s call     tests/test_stress.py::test_cancel_stress_sync
6.95s call tests/test_worker_client.py::test_compute_within_worker_client
6.81s call     tests/test_stress.py::test_cancel_stress
6.76s call tests/test_failed_workers.py::test_submit_after_failed_worker_sync 6.13s call tests/test_failed_workers.py::test_failed_worker_without_warning
6.13s call     tests/test_utils_test.py::test_bare_cluster
6.10s call     tests/test_nanny.py::test_nanny_terminate
6.08s call     tests/test_scheduler.py::test_bandwidth_clear
5.99s call     tests/test_scheduler.py::test_gather_no_workers
5.95s call     tests/test_steal.py::test_balance_with_longer_task
5.74s call tests/test_failed_workers.py::test_failing_worker_with_additional_replicas_on_cluster
5.72s call     tests/test_failed_workers.py::test_restart_fast_sync
5.28s call     tests/test_nanny.py::test_num_fds
5.22s call     tests/test_failed_workers.py::test_restart_sync
5.20s call     tests/test_failed_workers.py::test_restart_sync_no_center
4.96s call     tests/test_failed_workers.py::test_fast_kill
4.78s call tests/test_failed_workers.py::test_worker_doesnt_await_task_completion
4.75s call     tests/test_failed_workers.py::test_restart_fast
4.70s call tests/test_failed_workers.py::test_forgotten_futures_dont_clean_up_new_futures =========================== short test summary info ============================ SKIPPED [69] ../../../../usr/lib/python3/dist-packages/_pytest/python.py:173: async def function and no async plugin installed (see warnings) SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:827: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:853: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:872: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:1709: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:2562: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:2591: Use fast random selection now SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:3212: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:4508: Now prefer first-in-first-out SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:5877: could not import 'bokeh.plotting': No module named 'bokeh' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:6169: known intermittent failure SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:6252: could not import 'bokeh': No module named 'bokeh' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_client.py:6644: could not import 'bokeh': No module named 'bokeh' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/utils_test.py:782: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_config.py:316: could not import 'jsonschema': No module named 'jsonschema' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:769: could not import 'crick': No module named 'crick' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_core.py:778: could not import 'crick': No module named 'crick' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_counter.py:11: no crick library SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_profile.py:68: could not import 'stacktrace': No module named 'stacktrace' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_queues.py:88: getting same client from main thread SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_resources.py:274: Skipped SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_resources.py:330: Should protect resource keys from optimization SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_resources.py:351: atop fusion seemed to break this SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_scheduler.py:1806: could not import 'bokeh': No module named 'bokeh' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_steal.py:131: Skipped SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_stress.py:201: unconditional skip SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils.py:261: could not import 'pyarrow': No module named 'pyarrow' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_utils_test.py:130: This hangs on travis SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:183: don't yet support uploading pyc files SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:280: could not import 'crick': No module named 'crick' SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:524: Other tests leak memory, so process-level checks trigger immediately SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:922: Our logic here is faulty SKIPPED [1] ../../../../usr/lib/python3/dist-packages/distributed/tests/test_worker.py:1733: skip if we have elevated privileges = 1 failed, 1452 passed, 101 skipped, 68 deselected, 9 xfailed, 6 xpassed, 784 warnings in 1328.62s (0:22:08) =
--- Logging error ---
Traceback (most recent call last):
  File "/usr/lib/python3.9/logging/__init__.py", line 1086, in emit
    stream.write(msg + self.terminator)
ValueError: I/O operation on closed file.
Call stack:
File "/usr/lib/python3/dist-packages/distributed/utils_perf.py", line 199, in _gc_callback
    logger.warning(
Message: 'full garbage collections took %d%% CPU time recently (threshold: %d%%)'
Arguments: (73.93339307635397, 10.0)
Error code 0
Tests failed
autopkgtest [15:36:00]: test command1


Attachment: OpenPGP_signature
Description: OpenPGP digital signature


--- End Message ---
--- Begin Message ---
Source: jupyter-client
Source-Version: 7.3.0-1
Done: Julien Puydt <jpu...@debian.org>

We believe that the bug you reported is fixed in the latest version of
jupyter-client, which is due to be installed in the Debian FTP archive.

A summary of the changes between this version and the previous one is
attached.

Thank you for reporting the bug, which will now be closed.  If you
have further comments please address them to 1000...@bugs.debian.org,
and the maintainer will reopen the bug report if appropriate.

Debian distribution maintenance software
pp.
Julien Puydt <jpu...@debian.org> (supplier of updated jupyter-client package)

(This message was generated automatically at their request; if you
believe that there is a problem with it please contact the archive
administrators by mailing ftpmas...@ftp-master.debian.org)


-----BEGIN PGP SIGNED MESSAGE-----
Hash: SHA512

Format: 1.8
Date: Sun, 01 May 2022 22:39:14 +0200
Source: jupyter-client
Architecture: source
Version: 7.3.0-1
Distribution: unstable
Urgency: medium
Maintainer: Debian Python Team <team+pyt...@tracker.debian.org>
Changed-By: Julien Puydt <jpu...@debian.org>
Closes: 1000271
Changes:
 jupyter-client (7.3.0-1) unstable; urgency=medium
 .
   * New upstream release.
   * Update b-deps.
   * Checked dask.distributed builds with this (Closes: #1000271).
Checksums-Sha1:
 2f778f61a44bae965cfce6fce54ef5c9a6fe26db 2693 jupyter-client_7.3.0-1.dsc
 3003125f43ee29d26c8278ca22f7ab2ce6048e5f 329763 
jupyter-client_7.3.0.orig.tar.gz
 c6303499733bd2390a416d4dd852dda26f1807c7 7572 
jupyter-client_7.3.0-1.debian.tar.xz
 91e042a4b734fb3ff34d2f956d9397cdb1dd75fd 9179 
jupyter-client_7.3.0-1_source.buildinfo
Checksums-Sha256:
 7ff2556b61ad2c814efbcc8376d8f996bdaefe9d3065f9e7fa4ff05b13391e07 2693 
jupyter-client_7.3.0-1.dsc
 f978a376c9442a10f534cca14bdefbb2e379124154c19e5ab68df9ba033a18ca 329763 
jupyter-client_7.3.0.orig.tar.gz
 b884b4e734cbdefa9e6340af5318bf323ac9d4e445a4b5ddfea2bd832e8d89ed 7572 
jupyter-client_7.3.0-1.debian.tar.xz
 3d4576e5d00abb35f9ec76eed52ba50c9a65641e35b29826c41319df98e3769a 9179 
jupyter-client_7.3.0-1_source.buildinfo
Files:
 8d98a9019679fb79ad5606a66e67c6ff 2693 python optional 
jupyter-client_7.3.0-1.dsc
 f0776a28013a50edf8c9393d528c8c81 329763 python optional 
jupyter-client_7.3.0.orig.tar.gz
 539515d65c819eb330be69ba89670be9 7572 python optional 
jupyter-client_7.3.0-1.debian.tar.xz
 bef277af49fc566510ec498e1af9496f 9179 python optional 
jupyter-client_7.3.0-1_source.buildinfo

-----BEGIN PGP SIGNATURE-----

iQJGBAEBCgAwFiEEgS7v2KP7pKzk3xFLBMU71/4DBVEFAmJu8yISHGpwdXlkdEBk
ZWJpYW4ub3JnAAoJEATFO9f+AwVRhj4P/3jgl1zXlLwNMHqmxtc/96ufMv7VeQnu
ZZxDz+AJfWvHP4wGGJGHHT3nn+nFnjAQadwhd8P58ZjGLDfAS6S0TrrvPxt2iJ4M
XZYCY+erplyc21SFOLLjGOTnI23KoRMYscj3tTWJ0iNG1dPlehVTNxPOf3xboBpF
jercQw9p21mogppf29H9lXbGBaH5HJMzS/+tR3t5rOmGB0yHobB+lUa3NyM/s+5V
jdPA0v9LkqdqZuVEDdGztUomOyM91B5tb/P0cGb0yJe2QSPWFf5BIbzjwicPgw2K
lRFZUNLQy+iTbqPXD+eEoJg1CyxOcP142lE0NHIaQlJ7CvD6jNyGbhONG1Sos29o
iSw8d/o0YTkajqQW4yDp3SN6sxRTpCPBlKFwBHdF0zvXxc5ofs8tIaMbV1DipR7y
aUci0zbwem7roGoRWYFJAtaaUCdKgxExgrY9Lx9nwmHC9vuM51bEqeggn9Xf3JuU
kebP9VbSzIAYol28C5eZQ5BtDlwwQ5JiHFzA0bF/6EznZyQgniVAd+064T7S4QOh
Ubu4D6YqL4myZHPzizNnd/1n5N4vxLrygkndF52P0ubpKMPg1Uv8NnHfbhnII/BU
KzLMPK8xVMHrEVqgrn+6D4zyKlBBP2ljt4rc9dczBCySgfV/prJTEEaQo7egRWUH
vBR0S2Zfxqvt
=lElZ
-----END PGP SIGNATURE-----

--- End Message ---

Reply via email to