Skip to content

Commit

Permalink
Revert "Revert Split Tokenize"
Browse files Browse the repository at this point in the history
This reverts commit 6eebcfc.
  • Loading branch information
maldag committed Sep 10, 2024
1 parent 24cc26d commit 226b860
Show file tree
Hide file tree
Showing 8 changed files with 9 additions and 9 deletions.
2 changes: 1 addition & 1 deletion distributed/client.py
Original file line number Diff line number Diff line change
Expand Up @@ -49,7 +49,7 @@
from dask.highlevelgraph import HighLevelGraph
from dask.layers import Layer
from dask.optimization import SubgraphCallable
from dask.base import tokenize
from dask.tokenize import tokenize
from dask.typing import Key, NoDefault, no_default
from dask.utils import (
apply,
Expand Down
2 changes: 1 addition & 1 deletion distributed/diagnostics/progress.py
Original file line number Diff line number Diff line change
Expand Up @@ -9,7 +9,7 @@

from tlz import groupby, valmap

from dask.base import tokenize
from dask.tokenize import tokenize
from dask.utils import key_split

from distributed.diagnostics.plugin import SchedulerPlugin
Expand Down
2 changes: 1 addition & 1 deletion distributed/protocol/serialize.py
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@

import dask
from dask.sizeof import sizeof
from dask.base import normalize_token
from dask.tokenize import normalize_token
from dask.utils import typename

from distributed.metrics import context_meter
Expand Down
2 changes: 1 addition & 1 deletion distributed/scheduler.py
Original file line number Diff line number Diff line change
Expand Up @@ -55,7 +55,7 @@
import dask
import dask.utils
from dask.core import get_deps, iskey, validate_key
from dask.base import TokenizationError, normalize_token, tokenize
from dask.tokenize import TokenizationError, normalize_token, tokenize
from dask.typing import Key, no_default
from dask.utils import (
_deprecated,
Expand Down
2 changes: 1 addition & 1 deletion distributed/shuffle/_merge.py
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@
from dask.base import is_dask_collection
from dask.highlevelgraph import HighLevelGraph
from dask.layers import Layer
from dask.base import tokenize
from dask.tokenize import tokenize

from distributed.shuffle._arrow import check_minimal_arrow_version
from distributed.shuffle._core import ShuffleId, barrier_key, get_worker_plugin
Expand Down
2 changes: 1 addition & 1 deletion distributed/shuffle/_rechunk.py
Original file line number Diff line number Diff line change
Expand Up @@ -123,7 +123,7 @@
import dask.config
from dask.highlevelgraph import HighLevelGraph
from dask.layers import Layer
from dask.base import tokenize
from dask.tokenize import tokenize
from dask.typing import Key
from dask.utils import parse_bytes

Expand Down
2 changes: 1 addition & 1 deletion distributed/shuffle/_shuffle.py
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@
import dask
from dask.highlevelgraph import HighLevelGraph
from dask.layers import Layer
from dask.base import tokenize
from dask.tokenize import tokenize
from dask.typing import Key

from distributed.core import PooledRPCCall
Expand Down
4 changes: 2 additions & 2 deletions distributed/tests/test_client.py
Original file line number Diff line number Diff line change
Expand Up @@ -43,7 +43,7 @@
import dask.bag as db
from dask import delayed
from dask.optimization import SubgraphCallable
from dask.base import tokenize
from dask.tokenize import tokenize
from dask.utils import get_default_shuffle_method, parse_timedelta, tmpfile

from distributed import (
Expand Down Expand Up @@ -1127,7 +1127,7 @@ async def test_scatter_non_list(c, s, a, b):

@gen_cluster(client=True)
async def test_scatter_tokenize_local(c, s, a, b):
from dask.base import normalize_token
from dask.tokenize import normalize_token

class MyObj:
pass
Expand Down

0 comments on commit 226b860

Please sign in to comment.