Skip to content

Commit

Permalink
Remove test for DataFrame.to_hdf (#7735)
Browse files Browse the repository at this point in the history
  • Loading branch information
hendrikmakait committed Mar 31, 2023
1 parent 5494138 commit d1080d2
Showing 1 changed file with 1 addition and 14 deletions.
15 changes: 1 addition & 14 deletions distributed/shuffle/tests/test_shuffle.py
Expand Up @@ -19,7 +19,7 @@

import dask
from dask.distributed import Event, Nanny, Worker
from dask.utils import stringify, tmpfile
from dask.utils import stringify

from distributed.client import Client
from distributed.scheduler import Scheduler
Expand Down Expand Up @@ -170,19 +170,6 @@ def test_shuffle_before_categorize(loop_in_thread):
c.compute(df)


def test_shuffle_before_to_hdf(loop_in_thread):
with cluster() as (s, [a, b]), Client(s["address"], loop=loop_in_thread) as c:
df = dask.datasets.timeseries(
start="2000-01-01",
end="2000-01-10",
dtypes={"x": float, "y": float},
freq="10 s",
)
x = dd.shuffle.shuffle(df, "x", shuffle="p2p")
with tmpfile("h5") as fn:
x.to_hdf(fn, "/data*")


@gen_cluster(client=True)
async def test_concurrent(c, s, a, b):
df = dask.datasets.timeseries(
Expand Down

0 comments on commit d1080d2

Please sign in to comment.