Skip to content

Commit

Permalink
flake8
Browse files Browse the repository at this point in the history
  • Loading branch information
mrocklin committed Mar 20, 2017
1 parent 2b681f9 commit 76c0f39
Show file tree
Hide file tree
Showing 4 changed files with 8 additions and 6 deletions.
2 changes: 1 addition & 1 deletion dask/dataframe/core.py
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@
from ..utils import (random_state_data,
pseudorandom, derived_from, funcname, memory_repr,
put_lines, M, key_split)
from ..base import Base, compute, tokenize, normalize_token
from ..base import Base, tokenize, normalize_token
from . import methods
from .accessor import DatetimeAccessor, StringAccessor
from .categorical import CategoricalAccessor, categorize
Expand Down
2 changes: 1 addition & 1 deletion dask/dataframe/shuffle.py
Original file line number Diff line number Diff line change
Expand Up @@ -54,7 +54,7 @@ def set_index(df, index, npartitions=None, shuffle=None, compute=False,
iparts = index2.to_delayed()
mins = [ipart.min() for ipart in iparts]
maxes = [ipart.max() for ipart in iparts]
divisions, sizes, mins, maxes = base.compute(divisions, sizes, mins, maxes)
divisions, sizes, mins, maxes = base.compute(divisions, sizes, mins, maxes)
divisions = divisions.tolist()

if repartition:
Expand Down
6 changes: 4 additions & 2 deletions dask/dataframe/tests/test_dataframe.py
Original file line number Diff line number Diff line change
Expand Up @@ -239,8 +239,10 @@ def test_set_index_timezone():
d2.divisions[0] == s2badtype[0]


@pytest.mark.parametrize('npartitions', [1,
pytest.mark.xfail(2, reason='pandas join removes freq')])
@pytest.mark.parametrize(
'npartitions',
[1, pytest.mark.xfail(2, reason='pandas join removes freq')]
)
def test_timezone_freq(npartitions):
s_naive = pd.Series(pd.date_range('20130101', periods=10))
s_aware = pd.Series(pd.date_range('20130101', periods=10, tz='US/Eastern'))
Expand Down
4 changes: 2 additions & 2 deletions dask/dataframe/tests/test_groupby.py
Original file line number Diff line number Diff line change
Expand Up @@ -144,8 +144,8 @@ def test_groupby_dir():
@pytest.mark.parametrize('get', [dask.async.get_sync, dask.threaded.get])
def test_groupby_on_index(get):
pdf = pd.DataFrame({'a': [1, 2, 3, 4, 5, 6, 7, 8, 9],
'b': [4, 5, 6, 3, 2, 1, 0, 0, 0]},
index=[0, 1, 3, 5, 6, 8, 9, 9, 9])
'b': [4, 5, 6, 3, 2, 1, 0, 0, 0]},
index=[0, 1, 3, 5, 6, 8, 9, 9, 9])
ddf = dd.from_pandas(pdf, npartitions=3)

ddf2 = ddf.set_index('a')
Expand Down

0 comments on commit 76c0f39

Please sign in to comment.