Skip to content

Commit e383c61

Browse files
Fix typos found by codespell (#9145)
1 parent 3c651c6 commit e383c61

17 files changed

+21
-21
lines changed

distributed/batched.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -104,7 +104,7 @@ def _background_send(self):
104104
# and we're using `yield` and not `await`, the `write` coroutine object
105105
# will not actually have been awaited, and it will remain sitting around
106106
# for someone to retrieve it. At interpreter exit, this will warn
107-
# sommething like `RuntimeWarning: coroutine 'TCP.write' was never
107+
# something like `RuntimeWarning: coroutine 'TCP.write' was never
108108
# awaited`. By using the `closing` contextmanager, the `write` coroutine
109109
# object is always cleaned up, even if `yield` raises `GeneratorExit`.
110110
with contextlib.closing(

distributed/comm/tests/test_comms.py

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -873,7 +873,7 @@ class CustomBase(BaseException):
873873
async def test_comm_closed_on_write_error(tcp, exc_type):
874874
# Internal errors from comm.stream.write, such as
875875
# BufferError should lead to the stream being closed
876-
# and not re-used. See GitHub #4133
876+
# and not reused. See GitHub #4133
877877

878878
reader, writer = await get_tcp_comm_pair()
879879

@@ -1365,7 +1365,7 @@ def test_register_backend_entrypoint(tmp_path):
13651365

13661366

13671367
class OpaqueList(list):
1368-
"""Don't let the serialization layer travese this object"""
1368+
"""Don't let the serialization layer traverse this object"""
13691369

13701370
pass
13711371

distributed/core.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -1546,7 +1546,7 @@ def reuse(self, addr: str, comm: Comm) -> None:
15461546
"""
15471547
Reuse an open communication to the given address. For internal use.
15481548
"""
1549-
# if the pool is asked to re-use a comm it does not know about, ignore
1549+
# if the pool is asked to reuse a comm it does not know about, ignore
15501550
# this comm: just close it.
15511551
if comm not in self.occupied[addr]:
15521552
IOLoop.current().add_callback(comm.close)

distributed/dashboard/components/scheduler.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -2794,7 +2794,7 @@ def update(self):
27942794
nodes_data["color"].append(color_of(tg.prefix.name))
27952795
nodes_data["tot_tasks"].append(tot_tasks)
27962796

2797-
# memory alpha factor by 0.4 if not get's too dark
2797+
# memory alpha factor by 0.4 if not gets too dark
27982798
nodes_data["mem_alpha"].append(
27992799
(tg.states["memory"] / sum(tg.states.values())) * 0.4
28002800
)

distributed/distributed.yaml

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -102,7 +102,7 @@ distributed:
102102
lifetime:
103103
duration: null # Time after which to gracefully shutdown the worker
104104
stagger: 0 seconds # Random amount by which to stagger lifetimes
105-
restart: False # Do we ressurrect the worker after the lifetime deadline?
105+
restart: False # Do we resurrect the worker after the lifetime deadline?
106106

107107
profile:
108108
enabled: True # Whether or not to enable profiling

distributed/scheduler.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -4286,7 +4286,7 @@ async def start_unsafe(self) -> Self:
42864286
try:
42874287
link = format_dashboard_link(addr, server.port)
42884288
# formatting dashboard link can fail if distributed.dashboard.link
4289-
# refers to non-existant env vars.
4289+
# refers to non-existent env vars.
42904290
except KeyError as e:
42914291
logger.warning(
42924292
f"Failed to format dashboard link, unknown value: {e}"

distributed/semaphore.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -349,7 +349,7 @@ def __init__(
349349
if lease_timeout == "inf":
350350
return
351351

352-
## Below is all code for the lease timout validation
352+
## Below is all code for the lease timeout validation
353353

354354
lease_timeout = parse_timedelta(
355355
dask.config.get("distributed.scheduler.locks.lease-timeout"),

distributed/tests/test_cancelled_state.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -106,7 +106,7 @@ def f(ev):
106106
# another worker with a smaller delay. The key is still the same
107107
fut = c.submit(inc, 1, key="f1", workers=[b.worker_address])
108108
# then, a must switch the execute to fetch. Instead of doing so, it will
109-
# simply re-use the currently computing result.
109+
# simply reuse the currently computing result.
110110
fut = c.submit(inc, fut, workers=[a.worker_address], key="f2")
111111
await wait_for_state("f2", "waiting", a)
112112
await ev.set()

distributed/tests/test_client.py

Lines changed: 4 additions & 4 deletions
Original file line numberDiff line numberDiff line change
@@ -3118,8 +3118,8 @@ async def test_compute_partially_forgotten(c, s, *workers, validate, swap_keys):
31183118
s.validate = False
31193119
# (CPython impl detail)
31203120
# While it is not possible to know what the iteration order of a set will
3121-
# be, it is determinisitic and only depends on the hash of the inserted
3122-
# elements. Therefore, converting the set to a list will alway yield the
3121+
# be, it is deterministic and only depends on the hash of the inserted
3122+
# elements. Therefore, converting the set to a list will always yield the
31233123
# same order. We're initializing the keys in this very specific order to
31243124
# ensure that the scheduler internally arranges the keys in this way
31253125

@@ -4733,7 +4733,7 @@ async def test_retire_workers(c, s, a, b):
47334733
info = await c.retire_workers(workers=[a.address], close_workers=True)
47344734

47354735
# Deployment tooling is sometimes relying on this information to be returned
4736-
# This represents WorkerState.idenity() right now but may be slimmed down in
4736+
# This represents WorkerState.identity() right now but may be slimmed down in
47374737
# the future
47384738
assert info
47394739
assert info[a.address]
@@ -8301,7 +8301,7 @@ def test_worker_clients_do_not_claim_ownership_of_serialize_futures(
83018301
# different process such that we cannot rely on msg ordering
83028302
#
83038303
# 1. The alive futures have to be serialized as part of the submit payload
8304-
# 2. The future arive at the worker but the worker client doesn't claim
8304+
# 2. The future arrive at the worker but the worker client doesn't claim
83058305
# ownership
83068306
# 3. We're deleting them and the cancellation goes through to the scheduler
83078307
# such that it can release the futures

distributed/tests/test_failed_workers.py

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -308,7 +308,7 @@ async def test_broken_worker_during_computation(c, s, a, b):
308308
)
309309

310310
await asyncio.sleep(random.random() / 20)
311-
with suppress(CommClosedError): # comm will be closed abrupty
311+
with suppress(CommClosedError): # comm will be closed abruptly
312312
await c.run(os._exit, 1, workers=[n.worker_address])
313313

314314
await asyncio.sleep(random.random() / 20)

0 commit comments

Comments
 (0)