--- 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
===================================
[31m[1m________________________ test_gather_failing_cnn_error
_________________________[0m
outer_args = (), kwargs = {}, result = None
coro = <function gen_cluster.<locals>._.<locals>.test_func.<locals>.coro
at 0xffff0c67d550>
[37m@functools[39;49;00m.wraps(func)
[94mdef[39;49;00m [92mtest_func[39;49;00m(*outer_args, **kwargs):
result = [94mNone[39;49;00m
workers = []
[94mwith[39;49;00m clean(timeout=active_rpc_timeout,
**clean_kwargs) [94mas[39;49;00m loop:
[94masync[39;49;00m [94mdef[39;49;00m
[92mcoro[39;49;00m():
[94mwith[39;49;00m dask.config.set(config):
s = [94mFalse[39;49;00m
[94mfor[39;49;00m _ [95min[39;49;00m
[96mrange[39;49;00m([94m60[39;49;00m):
[94mtry[39;49;00m:
s, ws = [94mawait[39;49;00m start_cluster(
nthreads,
scheduler,
loop,
security=security,
Worker=Worker,
scheduler_kwargs=scheduler_kwargs,
worker_kwargs=worker_kwargs,
)
[94mexcept[39;49;00m
[96mException[39;49;00m [94mas[39;49;00m e:
logger.error(
[33m"[39;49;00m[33mFailed to start
gen_cluster: [39;49;00m[33m"[39;49;00m
[33mf[39;49;00m[33m"[39;49;00m[33m{[39;49;00me.[91m__class__[39;49;00m.[91m__name__[39;49;00m[33m}[39;49;00m[33m:
[39;49;00m[33m{[39;49;00me[33m}[39;49;00m[33m;
retrying[39;49;00m[33m"[39;49;00m,
exc_info=[94mTrue[39;49;00m,
)
[94mawait[39;49;00m
asyncio.sleep([94m1[39;49;00m)
[94melse[39;49;00m:
workers[:] = ws
args = [s] + workers
[94mbreak[39;49;00m
[94mif[39;49;00m s [95mis[39;49;00m
[94mFalse[39;49;00m:
[94mraise[39;49;00m
[96mException[39;49;00m([33m"[39;49;00m[33mCould not start
cluster[39;49;00m[33m"[39;49;00m)
[94mif[39;49;00m client:
c = [94mawait[39;49;00m Client(
s.address,
loop=loop,
security=security,
asynchronous=[94mTrue[39;49;00m,
**client_kwargs,
)
args = [c] + args
[94mtry[39;49;00m:
future = func(*args, *outer_args, **kwargs)
future = asyncio.wait_for(future, timeout)
result = [94mawait[39;49;00m future
[94mif[39;49;00m s.validate:
s.validate_state()
[94mfinally[39;49;00m:
[94mif[39;49;00m client [95mand[39;49;00m
c.status [95mnot[39;49;00m [95min[39;49;00m
([33m"[39;49;00m[33mclosing[39;49;00m[33m"[39;49;00m,
[33m"[39;49;00m[33mclosed[39;49;00m[33m"[39;49;00m):
[94mawait[39;49;00m
c._close(fast=s.status == Status.closed)
[94mawait[39;49;00m end_cluster(s, workers)
[94mawait[39;49;00m
asyncio.wait_for(cleanup_global_workers(), [94m1[39;49;00m)
[94mtry[39;49;00m:
c = [94mawait[39;49;00m default_client()
[94mexcept[39;49;00m [96mValueError[39;49;00m:
[94mpass[39;49;00m
[94melse[39;49;00m:
[94mawait[39;49;00m
c._close(fast=[94mTrue[39;49;00m)
[94mdef[39;49;00m [92mget_unclosed[39;49;00m():
[94mreturn[39;49;00m [c
[94mfor[39;49;00m c [95min[39;49;00m Comm._instances
[94mif[39;49;00m [95mnot[39;49;00m c.closed()] + [
c
[94mfor[39;49;00m c [95min[39;49;00m
_global_clients.values()
[94mif[39;49;00m c.status !=
[33m"[39;49;00m[33mclosed[39;49;00m[33m"[39;49;00m
]
[94mtry[39;49;00m:
start = time()
[94mwhile[39;49;00m time() < start +
[94m60[39;49;00m:
gc.collect()
[94mif[39;49;00m [95mnot[39;49;00m
get_unclosed():
[94mbreak[39;49;00m
[94mawait[39;49;00m
asyncio.sleep([94m0.05[39;49;00m)
[94melse[39;49;00m:
[94mif[39;49;00m allow_unclosed:
[96mprint[39;49;00m([33mf[39;49;00m[33m"[39;49;00m[33mUnclosed
Comms:
[39;49;00m[33m{[39;49;00mget_unclosed()[33m}[39;49;00m[33m"[39;49;00m)
[94melse[39;49;00m:
[94mraise[39;49;00m
[96mRuntimeError[39;49;00m([33m"[39;49;00m[33mUnclosed
Comms[39;49;00m[33m"[39;49;00m, get_unclosed())
[94mfinally[39;49;00m:
Comm._instances.clear()
_global_clients.clear()
[94mreturn[39;49;00m result
> result = loop.run_sync(
coro, timeout=timeout * [94m2[39;49;00m
[94mif[39;49;00m timeout [94melse[39;49;00m timeout
)
[1m[31m/usr/lib/python3/dist-packages/distributed/utils_test.py[0m:994:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
_ _ _ _
self = <tornado.platform.asyncio.AsyncIOLoop object at 0xffff0c5b8ac0>
func = <function gen_cluster.<locals>._.<locals>.test_func.<locals>.coro
at 0xffff0c67d550>
timeout = 60
[94mdef[39;49;00m [92mrun_sync[39;49;00m([96mself[39;49;00m,
func: Callable, timeout: Optional[[96mfloat[39;49;00m] =
[94mNone[39;49;00m) -> Any:
[33m"""Starts the `IOLoop`, runs the given function, and stops
the loop.[39;49;00m
[33m[39;49;00m
[33m The function must return either an awaitable object
or[39;49;00m
[33m ``None``. If the function returns an awaitable object,
the[39;49;00m
[33m `IOLoop` will run until the awaitable is resolved
(and[39;49;00m
[33m `run_sync()` will return the awaitable's result). If it
raises[39;49;00m
[33m an exception, the `IOLoop` will stop and the exception
will be[39;49;00m
[33m re-raised to the caller.[39;49;00m
[33m[39;49;00m
[33m The keyword-only argument ``timeout`` may be used to
set[39;49;00m
[33m a maximum duration for the function. If the timeout
expires,[39;49;00m
[33m a `tornado.util.TimeoutError` is raised.[39;49;00m
[33m[39;49;00m
[33m This method is useful to allow asynchronous calls in
a[39;49;00m
[33m ``main()`` function::[39;49;00m
[33m[39;49;00m
[33m async def main():[39;49;00m
[33m # do stuff...[39;49;00m
[33m[39;49;00m
[33m if __name__ == '__main__':[39;49;00m
[33m IOLoop.current().run_sync(main)[39;49;00m
[33m[39;49;00m
[33m .. versionchanged:: 4.3[39;49;00m
[33m Returning a non-``None``, non-awaitable value is now
an error.[39;49;00m
[33m[39;49;00m
[33m .. versionchanged:: 5.0[39;49;00m
[33m If a timeout occurs, the ``func`` coroutine will be
cancelled.[39;49;00m
[33m[39;49;00m
[33m """[39;49;00m
future_cell = [[94mNone[39;49;00m] [90m# type:
List[Optional[Future]][39;49;00m
[94mdef[39;49;00m [92mrun[39;49;00m() ->
[94mNone[39;49;00m:
[94mtry[39;49;00m:
result = func()
[94mif[39;49;00m result [95mis[39;49;00m
[95mnot[39;49;00m [94mNone[39;49;00m:
[94mfrom[39;49;00m
[04m[96mtornado[39;49;00m[04m[96m.[39;49;00m[04m[96mgen[39;49;00m
[94mimport[39;49;00m convert_yielded
result = convert_yielded(result)
[94mexcept[39;49;00m [96mException[39;49;00m:
fut = Future() [90m# type: Future[Any][39;49;00m
future_cell[[94m0[39;49;00m] = fut
future_set_exc_info(fut, sys.exc_info())
[94melse[39;49;00m:
[94mif[39;49;00m is_future(result):
future_cell[[94m0[39;49;00m] = result
[94melse[39;49;00m:
fut = Future()
future_cell[[94m0[39;49;00m] = fut
fut.set_result(result)
[94massert[39;49;00m future_cell[[94m0[39;49;00m]
[95mis[39;49;00m [95mnot[39;49;00m [94mNone[39;49;00m
[96mself[39;49;00m.add_future(future_cell[[94m0[39;49;00m],
[94mlambda[39;49;00m future: [96mself[39;49;00m.stop())
[96mself[39;49;00m.add_callback(run)
[94mif[39;49;00m timeout [95mis[39;49;00m
[95mnot[39;49;00m [94mNone[39;49;00m:
[94mdef[39;49;00m
[92mtimeout_callback[39;49;00m() -> [94mNone[39;49;00m:
[90m# If we can cancel the future, do so and wait on
it. If not,[39;49;00m
[90m# Just stop the loop and return with the task
still pending.[39;49;00m
[90m# (If we neither cancel nor wait for the task, a
warning[39;49;00m
[90m# will be logged).[39;49;00m
[94massert[39;49;00m
future_cell[[94m0[39;49;00m] [95mis[39;49;00m
[95mnot[39;49;00m [94mNone[39;49;00m
[94mif[39;49;00m [95mnot[39;49;00m
future_cell[[94m0[39;49;00m].cancel():
[96mself[39;49;00m.stop()
timeout_handle =
[96mself[39;49;00m.add_timeout([96mself[39;49;00m.time() + timeout,
timeout_callback)
[96mself[39;49;00m.start()
[94mif[39;49;00m timeout [95mis[39;49;00m
[95mnot[39;49;00m [94mNone[39;49;00m:
[96mself[39;49;00m.remove_timeout(timeout_handle)
[94massert[39;49;00m future_cell[[94m0[39;49;00m]
[95mis[39;49;00m [95mnot[39;49;00m [94mNone[39;49;00m
[94mif[39;49;00m
future_cell[[94m0[39;49;00m].cancelled() [95mor[39;49;00m
[95mnot[39;49;00m future_cell[[94m0[39;49;00m].done():
[94mraise[39;49;00m
[96mTimeoutError[39;49;00m([33m"[39;49;00m[33mOperation timed out after
[39;49;00m[33m%s[39;49;00m[33m seconds[39;49;00m[33m"[39;49;00m % timeout)
[1m[31mE tornado.util.TimeoutError: Operation timed out
after 60 seconds[0m
[1m[31m/usr/lib/python3/dist-packages/tornado/ioloop.py[0m: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
[33m=============================== warnings summary
===============================[0m
../../../../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
[31m= [31m[1m1 failed[0m, [32m1452 passed[0m, [33m101
skipped[0m, [33m68 deselected[0m, [33m9 xfailed[0m, [33m6
xpassed[0m, [33m784 warnings[0m[31m in 1328.62s (0:22:08)[0m[31m =[0m
--- 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
OpenPGP_signature
Description: OpenPGP digital signature
--- End Message ---