Skip to content

Commit

Permalink
Merge branch 'main' into fix-memory-erred
Browse files Browse the repository at this point in the history
  • Loading branch information
hendrikmakait authored Mar 8, 2024
2 parents 87c2b38 + e16a7af commit 449f447
Show file tree
Hide file tree
Showing 16 changed files with 247 additions and 318 deletions.
2 changes: 1 addition & 1 deletion .github/workflows/conda.yml
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ jobs:
with:
fetch-depth: 0
- name: Set up Python
uses: conda-incubator/[email protected].2
uses: conda-incubator/[email protected].3
with:
miniforge-variant: Mambaforge
use-mamba: true
Expand Down
2 changes: 1 addition & 1 deletion .github/workflows/test-report.yaml
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ jobs:
- uses: actions/[email protected]

- name: Setup Conda Environment
uses: conda-incubator/[email protected].2
uses: conda-incubator/[email protected].3
with:
miniforge-variant: Mambaforge
miniforge-version: latest
Expand Down
2 changes: 1 addition & 1 deletion .github/workflows/tests.yaml
Original file line number Diff line number Diff line change
Expand Up @@ -115,7 +115,7 @@ jobs:
fetch-depth: 0

- name: Setup Conda Environment
uses: conda-incubator/[email protected].2
uses: conda-incubator/[email protected].3
with:
miniforge-variant: Mambaforge
miniforge-version: latest
Expand Down
2 changes: 1 addition & 1 deletion distributed/dashboard/tests/test_scheduler_bokeh.py
Original file line number Diff line number Diff line change
Expand Up @@ -1346,7 +1346,7 @@ async def test_shuffling(c, s, a, b):
freq="10 s",
)
with dask.config.set({"dataframe.shuffle.method": "p2p"}):
df2 = dd.shuffle.shuffle(df, "x").persist()
df2 = df.shuffle("x").persist()
start = time()
while not ss.source.data["comm_written"]:
ss.update()
Expand Down
15 changes: 12 additions & 3 deletions distributed/protocol/tests/test_highlevelgraph.py
Original file line number Diff line number Diff line change
@@ -1,5 +1,7 @@
from __future__ import annotations

import contextlib

import pytest

np = pytest.importorskip("numpy")
Expand Down Expand Up @@ -173,7 +175,13 @@ async def test_dataframe_annotations(c, s, a, b):
acol = df["a"]
bcol = df["b"]

with dask.annotate(retries=retries):
ctx = contextlib.nullcontext()
if dd._dask_expr_enabled():
ctx = pytest.warns(
UserWarning, match="Annotations will be ignored when using query-planning"
)

with dask.annotate(retries=retries), ctx:
df = acol + bcol

with dask.config.set(optimization__fuse__active=False):
Expand All @@ -182,5 +190,6 @@ async def test_dataframe_annotations(c, s, a, b):
assert rdf.dtypes == np.float64
assert (rdf == 10.0).all()

# There is an annotation match per partition (i.e. task)
assert plugin.retry_matches == df.npartitions
if not dd._dask_expr_enabled():
# There is an annotation match per partition (i.e. task)
assert plugin.retry_matches == df.npartitions
Loading

0 comments on commit 449f447

Please sign in to comment.