Changelog¶
2.27.0 - 2020-09-18¶
Fix registering a worker plugin with
name
arg (GH#4105) Nick EvansSupport different
remote_python
paths on cluster nodes (GH#4085) Abdulelah Bin MahfoodhAllow
RuntimeError
s when closing global clients (GH#4115) Matthew RocklinMatch
pre-commit
in dask (GH#4049) Julia SignellUpdate
super
usage (GH#4110) Poruri Sai Rahul
2.26.0 - 2020-09-11¶
Add logging for adaptive start and stop (GH#4101) Matthew Rocklin
Don’t close a nannied worker if it hasn’t yet started (GH#4093) Matthew Rocklin
Respect timeouts when closing clients synchronously (GH#4096) Matthew Rocklin
Log when downloading a preload script (GH#4094) Matthew Rocklin
dask-worker --nprocs
accepts negative values (GH#4089) Dror SpeiserSupport zero-worker clients (GH#4090) Matthew Rocklin
Exclude
fire-and-forget
client from metrics (GH#4078) Tom AugspurgerAdd
timeout=
keyword toClient.wait_for_workers
method (GH#4087) Matthew Rocklin
2.25.0 - 2020-08-28¶
Update for black (GH#4081) Tom Augspurger
Provide informative error when connecting an older version of Dask (GH#4076) Matthew Rocklin
Graph helper text (GH#4064) Julia Signell
Graph dashboard: Reset container data if task number is too large (GH#4056) Florian Jetter
Ensure semaphore picks correct
IOLoop
for threadpool workers (GH#4060) Florian JetterAdd cluster log method (GH#4051) Jacob Tomlinson
Cleanup more exception tracebacks (GH#4054) Krishan Bhasin
Improve documentation of
scheduler.locks
options (GH#4062) Florian Jetter
2.24.0 - 2020-08-22¶
Move toolbar to above and fix y axis (#4043) Julia Signell
Make behavior clearer for how to get worker dashboard (#4047) Julia Signell
Worker dashboard clean up (#4046) Julia Signell
Add a default argument to the datasets and a possibility to override datasets (#4052) Nils Braun
Discover HTTP endpoints (#3744) Martin Durant
2.23.0 - 2020-08-14¶
Tidy up exception traceback in TCP Comms (GH#4042) Krishan Bhasin
Angle on the x-axis labels (GH#4030) Mathieu Dugré
Fix documentation
upload_file
(GH#4038) Roberto PanaiAdd test for informative errors in serialization cases (GH#4029) Matthew Rocklin
Add compression, pickle protocol to comm contexts (GH#4019) Matthew Rocklin
Make GPU plots robust to not having GPUs (GH#4008) Matthew Rocklin
Update
PendingDeprecationWarning
with correct version number (GH#4025) Matthias BussonnierTry getting cluster
dashboard_link
before asking scheduler (GH#4018) Matthew RocklinIgnore writeable frames with builtin
array
(GH#4016) jakirkhamClear function cache whenever we upload a new file (GH#3993) Jack Xiaosong Xu
Emmit warning when assign/comparing string with
Status
Enum
(GH#3875) Matthias BussonnierImprove
bytes
andbytearray
serialization (GH#4009) jakirkhamFix memory histogram values in dashboard (GH#4006) Willi Rath
2.22.0 - 2020-07-31¶
Only call
frame_split_size
when there are frames (GH#3996) jakirkhamHandle sum of memory percentage when
memory_limit
is 0 (GH#3984) Julia SignellRevert to localhost for local IP if no network available (GH#3991) Matthew Rocklin
Add missing backtick in inline directive. (GH#3988) Matthias Bussonnier
Warn when
threads_per_worker
is set to zero (GH#3986) Julia SignellIterate over list of comms (GH#3959) Matthew Rocklin
Streamline
pack_frames
/unpack_frames
frames (GH#3973) jakirkhamAlways attempt to create
dask-worker-space
folder and continue if it exists (GH#3972) Jendrik JördeningUse continuation prompt for proper example parsing (GH#3966) Matthias Bussonnier
2.21.0 - 2020-07-17¶
Fix data replication error (GH#3963) Andrew Fulton
Treat falsey local directory as
None
(GH#3964) Tom AugspurgerUnpin
numpydoc
now that 1.1 is released (GH#3957) Gil ForsythError hard when Dask has mismatched versions or lz4 installed (GH#3936) Matthew Rocklin
UCX: reuse endpoints in order to fix NVLINK issue (GH#3953) Mads R. B. Kristensen
Update time per task chart with filtering and pie (GH#3933) Benjamin Zaitlen
UCX: explicit shutdown message (GH#3950) Mads R. B. Kristensen
Avoid too aggressive retry of connections (GH#3944) Matthias Bussonnier
Parse timeouts in
Client.sync
(GH#3952) Matthew RocklinSynchronize on non-trivial CUDA frame transmission (GH#3949) jakirkham
Serialize
memoryview
withshape
andformat
(GH#3947) jakirkhamMove
scheduler_comm
intoCluster.__init__
(GH#3945) Matthew Rocklin
2.20.0 - 2020-07-02¶
Link issue on using
async
withexecutor_submit
(GH#3939) jakirkhamMake dashboard server listens on all IPs by default even when interface is set explicitly (GH#3941) Loïc Estève
Update logic for worker removal in check ttl (GH#3927) Benjamin Zaitlen
Close a created cluster quietly (GH#3935) Matthew Rocklin
Ensure
Worker.run*
handleskwargs
correctly (GH#3937) jakirkhamRestore
Scheduler.time_started
for Dask Gateway (GH#3934) Tom AugspurgerFix exception handling in
_wait_until_connected
(GH#3912) Alexander ClausenMake local directory if it does not exist (GH#3928) Matthew Rocklin
Install vanilla status route if bokeh dependency is not satisfied (GH#3844) joshreback
Make
Worker.delete_data
sync (GH#3922) Peter Andreas EntschevFix race condition in repeated calls to
cluster.adapt()
(GH#3915) Jacob Tomlinson
2.19.0 - 2020-06-19¶
Notify worker plugins when a task is released (GH#3817) Nick Evans
Update heartbeat checks in scheduler (GH#3896) Benjamin Zaitlen
Make encryption default if
Security
is given arguments (GH#3887) Matthew RocklinShow
cpu_fraction
on hover for dashboard workers circle plot. (GH#3906) Loïc EstèvePrune virtual client on variable deletion (GH#3910) Marco Neumann
Fix total aggregated metrics in dashboard (GH#3897) Loïc Estève
Support Bokeh 2.1 (GH#3904) Matthew Rocklin
Skip
test_pid_file
in older versions of Python (GH#3888) Matthew RocklinReplace
stream=
withcomm=
in handlers (GH#3860) Julien JerphanionCheck hosts for
None
value in SSH cluster. (GH#3883) Matthias BussonnierAllow dictionaries in
security=
keywords (GH#3874) Matthew RocklinUse pickle protocol 5 with NumPy object arrays (GH#3871) jakirkham
Cast any
frame
touint8
(same type asbytes
) (GH#3870) jakirkhamUse
Enum
for worker, scheduler and nanny status. (GH#3853) Matthias BussonnierDrop old frame splitting in NumPy serialization (GH#3868) jakirkham
Drop no longer needed local
import pickle
(GH#3865) jakirkhamHandle empty times in task stream (GH#3862) Benjamin Zaitlen
Change
asyncssh
objects to sphinx references (GH#3861) Jacob TomlinsonImprove
SSHCluster
docstring forconnect_options
(GH#3859) Jacob TomlinsonValidate address parameter in client constructor (GH#3842) joshreback
Use
SpecCluster
name in worker names (GH#3855) Loïc EstèveAllow async
add_worker
andremove_worker
plugin methods (GH#3847) James Bourbeau
2.18.0 - 2020-06-05¶
Merge frames in
deserialize_bytes
(GH#3639) John KirkhamAllow
SSHCluster
to take a list ofconnect_options
(GH#3854) Jacob TomlinsonAdd favicon to performance report (GH#3852) Jacob Tomlinson
Add dashboard plots for the amount of time spent per key and for transfer/serialization (GH#3792) Benjamin Zaitlen
Fix variable name in journey of a task documentation (GH#3840) Matthias Bussonnier
Fix typo in journey of a task doc (GH#3838) James Bourbeau
Register
dask_cudf
serializers (GH#3832) John KirkhamFix key check in
rebalance
missing keys (GH#3834) Jacob TomlinsonAllow collection of partial profile information in case of exceptions (GH#3773) Florian Jetter
2.17.0 - 2020-05-26¶
Record the time since the last run task on the scheduler (GH#3830) Matthew Rocklin
Set colour of
nbytes
pane based on thresholds (GH#3805) Krishan BhasinInclude total number of tasks in the performance report (GH#3822) Abdulelah Bin Mahfoodh
Allow to pass in task key strings in the worker restrictions (GH#3826) Nils Braun
Control de/ser offload (GH#3793) Martin Durant
Parse timeout parameters in
Variable
/Event
/Lock
to support text timeouts (GH#3825) Nils BraunDon’t send empty dependencies (GH#3423) Jakub Beránek
Add distributed Dask
Event
that mimicsthreading.Event
(GH#3821) Nils BraunEnhance
VersionMismatchWarning
messages (GH#3786) Abdulelah Bin MahfoodhReplace
utils.ignoring
withcontextlib.suppress
(GH#3819) Nils BraunMake re-creating conda environments from the CI output easier (GH#3816) Lucas Rademaker
Add prometheus metrics for semaphore (GH#3757) Lucas Rademaker
Fix worker plugin called with superseded transition (GH#3812) Nick Evans
Add retries to server listen (GH#3801) Jacob Tomlinson
Remove commented out lines from
scheduler.py
(GH#3803) James BourbeauFix
RuntimeWarning
for never awaited coroutine when usingdistributed.Semaphore
(GH#3713) Florian JetterFix profile thread leakage during test teardown on some platforms (GH#3795) Florian Jetter
Await self before handling comms (GH#3788) Matthew Rocklin
Fix typo in
Cluster
docstring (GH#3787) Scott Sanderson
2.16.0 - 2020-05-08¶
Client.get_dataset
to always createFutures
attached to itself (GH#3729) crusaderkyRemove dev-requirements since it is unused (GH#3782) Julia Signell
Use bokeh column for
/system
instead of custom css (GH#3781) Julia SignellAttempt to fix
test_preload_remote_module
on windows (GH#3775) James BourbeauFix broadcast for TLS comms (GH#3766) Florian Jetter
Don’t validate http preloads locally (GH#3768) Rami Chowdhury
Allow range of ports to be specified for
Workers
(GH#3704) James BourbeauAdd UCX support for RDMACM (GH#3759) Peter Andreas Entschev
Support web addresses in preload (GH#3755) Matthew Rocklin
2.15.2 - 2020-05-01¶
Connect to dashboard when address provided (GH#3758) Tom Augspurger
Move
test_gpu_metrics test
(GH#3721) Tom AugspurgerNanny closing worker on
KeyboardInterrupt
(GH#3747) Mads R. B. KristensenReplace
OrderedDict
withdict
in scheduler (GH#3740) Matthew RocklinFix exception handling typo (GH#3751) Jonas Haag
2.15.1 - 2020-04-28¶
Ensure
BokehTornado
uses prefix (GH#3746) James BourbeauWarn if cluster closes before starting (GH#3735) Matthew Rocklin
Memoryview serialisation (GH#3743) Martin Durant
Allows logging config under distributed key (GH#2952) Dillon Niederhut
2.15.0 - 2020-04-24¶
Reinstate support for legacy
@gen_cluster
functions (GH#3738) crusaderkyAdd Configuration Schema (GH#3696) Matthew Rocklin
Reuse CI scripts for local installation process (GH#3698) crusaderky
Use
PeriodicCallback
class from tornado (GH#3725) James BourbeauAdd
remote_python
option in ssh cmd (GH#3709) Abdulelah Bin MahfoodhConfigurable polling interval for cluster widget (GH#3723) Julia Signell
Fix copy-paste in docs (GH#3728) Julia Signell
Replace
gen.coroutine
with async-await in tests (GH#3706) crusaderkyFix flaky
test_oversubscribing_leases
(GH#3726) Florian JetterAdd
batch_size
toClient.map
(GH#3650) Tom AugspurgerAdjust semaphore test timeouts (GH#3720) Florian Jetter
Dask-serialize dicts longer than five elements (GH#3689) Richard J Zamora
Force
threads_per_worker
(GH#3715) crusaderkyIdempotent semaphore acquire with retries (GH#3690) Florian Jetter
Avoid
DeprecationWarning
from pandas (GH#3712) Tom AugspurgerAllow modification of
distributed.comm.retry
at runtime (GH#3705) Florian JetterDo not log an error on unset variable delete (GH#3652) Jonathan J. Helmus
Add
remote_python
keyword to the newSSHCluster
(GH#3701) Abdulelah Bin MahfoodhReplace Example with Examples in docstrings (GH#3697) Matthew Rocklin
Add
Cluster
__enter__
and__exit__
methods (GH#3699) Matthew RocklinFix propagating inherit config in
SSHCluster
for non-bash shells (GH#3688) Abdulelah Bin MahfoodhAdd
Client.wait_to_workers
toClient
autosummary table (GH#3692) James BourbeauReplace Bokeh Server with Tornado HTTPServer (GH#3658) Matthew Rocklin
Fix
dask-ssh
after removinglocal-directory
fromdask_scheduler
cli (GH#3684) Abdulelah Bin MahfoodhSupport preload modules in
Nanny
(GH#3678) Matthew RocklinRefactor semaphore internals: make
_get_lease
synchronous (GH#3679) Lucas RademakerDon’t make task graphs too big (GH#3671) Martin Durant
Pass through
connection
/listen_args
as splatted keywords (GH#3674) Matthew RocklinRun preload at import, start, and teardown (GH#3673) Matthew Rocklin
Use relative URL in scheduler dashboard (GH#3676) Nicholas Smith
Expose
Security
object as public API (GH#3675) Matthew RocklinAdd zoom tools to profile plots (GH#3672) James Bourbeau
Update
Scheduler.rebalance
return value when data is missing (GH#3670) James Bourbeau
2.14.0 - 2020-04-03¶
Remove openssl 1.1.1d pin for Travis (GH#3668) Jonathan J. Helmus
More documentation for
Semaphore
(GH#3664) Florian JetterGet CUDA context to finalize Numba
DeviceNDArray
(GH#3666) jakirkhamAdd Resouces option to
get_task_stream
and calloutput_file
(GH#3653) Prasun AnandAdd
Semaphore
extension (GH#3573) Lucas RademakerReplace
ncores
withnthreads
in work stealing tests (GH#3615) James BourbeauClean up some test warnings (GH#3662) Matthew Rocklin
Write “why killed” docs (GH#3596) Martin Durant
Update Python version checking (GH#3660) James Bourbeau
Add newlines to ensure code formatting for
retire_workers
(GH#3661) Rami ChowdhuryClean up performance report test (GH#3655) Matthew Rocklin
Avoid diagnostics time in performance report (GH#3654) Matthew Rocklin
Introduce config for default task duration (GH#3642) Gabriel Sailer
Bump checkout GitHub action to v2 (GH#3649) James Bourbeau
Handle exception in
faulthandler
(GH#3646) Jacob TomlinsonAdd prometheus metric for suspicious tasks (GH#3550) Gabriel Sailer
Remove
local-directory
keyword (GH#3620) Prasun AnandDon’t create output Futures in Client when there are mixed Client Futures (GH#3643) James Bourbeau
Add link to
contributing.md
(GH#3621) Prasun AnandUpdate bokeh dependency in CI builds (GH#3637) James Bourbeau
2.13.0 - 2020-03-25¶
UCX synchronize default stream only on CUDA frames (GH#3638) Peter Andreas Entschev
Add
as_completed.clear
method (GH#3617) Matthew RocklinDrop unused line from
pack_frames_prelude
(GH#3634) John KirkhamAdd logging message when closing idle dask scheduler (GH#3632) Matthew Rocklin
Include frame lengths of CUDA objects in
header["lengths"]
(GH#3631) John KirkhamEnsure
Client
connection pool semaphore attaches to theClient
event loop (GH#3546) James BourbeauRemove dead stealing code (GH#3619) Florian Jetter
Check
nbytes
andtypes
before readingdata
(GH#3628) John KirkhamEnsure that we don’t steal blacklisted fast tasks (GH#3591) Florian Jetter
Support async
Listener.stop
functions (GH#3613) Matthew RocklinAdd str/repr methods to
as_completed
(GH#3618) Matthew RocklinAdd backoff to comm connect attempts. (GH#3496) Matthias Urlichs
Make
Listeners
awaitable (GH#3611) Matthew RocklinIncrease number of visible mantissas in dashboard plots (GH#3585) Scott Sievert
Pin openssl to 1.1.1d for Travis (GH#3602) Jacob Tomlinson
Replace
tornado.queues
withasyncio.queues
(GH#3607) James BourbeauRemove
dill
from CI environments (GH#3608) Loïc EstèveFix linting errors (GH#3604) James Bourbeau
Synchronize default CUDA stream before UCX send/recv (GH#3598) Peter Andreas Entschev
Add configuration for
Adaptive
arguments (GH#3509) Gabriel SailerChange
Adaptive
docs to referenceadaptive_target
(GH#3597) Julia SignellOptionally compress on a frame-by-frame basis (GH#3586) Matthew Rocklin
Add Python version to version check (GH#3567) James Bourbeau
Import
tlz
(GH#3579) John KirkhamPin
numpydoc
to avoid double escaped*
(GH#3530) Gil ForsythAvoid
performance_report
crashing when a worker dies mid-compute (GH#3575) Krishan BhasinPin
bokeh
in CI builds (GH#3570) James BourbeauDisable fast fail on GitHub Actions Windows CI (GH#3569) James Bourbeau
Fix typo in
Client.shutdown
docstring (GH#3562) John KirkhamAdd
local_directory
option todask-ssh
(GH#3554) Abdulelah Bin Mahfoodh
2.12.0 - 2020-03-06¶
Update
TaskGroup
remove logic (GH#3557) James BourbeauFix-up CuPy sparse serialization (GH#3556) John Kirkham
API docs for
LocalCluster
andSpecCluster
(GH#3548) Tom AugspurgerSerialize sparse arrays (GH#3545) John Kirkham
Allow tasks with restrictions to be stolen (GH#3069) Stan Seibert
Use UCX default configuration instead of raising (GH#3544) Peter Andreas Entschev
Support using other serializers with
register_generic
(GH#3536) John KirkhamDOC: update to async await (GH#3543) Tom Augspurger
Use
pytest.raises
intest_ucx_config.py
(GH#3541) John KirkhamFix/more ucx config options (GH#3539) Benjamin Zaitlen
Update heartbeat
CommClosedError
error handling (GH#3529) James BourbeauUse
makedirs
when constructinglocal_directory
(GH#3538) John KirkhamMark
None
as MessagePack serializable (GH#3537) John KirkhamMark
bool
as MessagePack serializable (GH#3535) John KirkhamUse ‘temporary-directory’ from
dask.config
for Nanny’s directory (GH#3531) John KirkhamAdd try-except around getting source code in performance report (GH#3505) Matthew Rocklin
Fix typo in docstring (GH#3528) Davis Bennett
Make work stealing callback time configurable (GH#3523) Lucas Rademaker
RMM/UCX Config Flags (GH#3515) Benjamin Zaitlen
Revise develop-docs: conda env example (GH#3406) Darren Weber
Remove
import ucp
from the top ofucx.py
(GH#3510) Peter Andreas EntschevRename
logs
toget_logs
(GH#3473) Jacob TomlinsonStop keep alives when worker reconnecting to the scheduler (GH#3493) Jacob Tomlinson
2.11.0 - 2020-02-19¶
Add dask serialization of CUDA objects (GH#3482) John Kirkham
Suppress cuML
ImportError
(GH#3499) John KirkhamMsgpack 1.0 compatibility (GH#3494) James Bourbeau
Register cuML serializers (GH#3485) John Kirkham
Check exact equality for worker state (GH#3483) Brett Naul
Serialize 1-D, contiguous,
uint8
CUDA frames (GH#3475) John KirkhamUpdate NumPy array serialization to handle non-contiguous slices (GH#3474) James Bourbeau
Propose fix for collection based resources docs (GH#3480) Chris Roat
Remove
--verbose
flag from CI runs (GH#3484) Matthew RocklinDo not duplicate messages in scheduler report (GH#3477) Jakub Beránek
Register Dask cuDF serializers (GH#3478) John Kirkham
Add support for Python 3.8 (GH#3249) James Bourbeau
Add last seen column to worker table and highlight errant workers (GH#3468) kaelgreco
Change default value of
local_directory
from empty string toNone
(GH#3441) condoratberlinClear old docs (GH#3458) Matthew Rocklin
Change default multiprocessing behavior to spawn (GH#3461) Matthew Rocklin
Split dashboard host on additional slashes to handle inproc (GH#3466) Jacob Tomlinson
Update
locality.rst
(GH#3470) Dustin TindallMinor
gen.Return
cleanup (GH#3469) James BourbeauUpdate comparison logic for worker state (GH#3321) rockwellw
Update minimum
tblib
version to 1.6.0 (GH#3451) James BourbeauAdd total row to workers plot in dashboard (GH#3464) Julia Signell
Workaround
RecursionError
on profile data (GH#3455) Tom AugspurgerInclude code and summary in performance report (GH#3462) Matthew Rocklin
Skip
test_open_close_many_workers
on Python 3.6 (GH#3459) Matthew RocklinSupport serializing/deserializing
rmm.DeviceBuffer
s (GH#3442) John KirkhamAlways add new
TaskGroup
toTaskPrefix
(GH#3322) James BourbeauRerun
black
on the code base (GH#3444) John KirkhamEnsure
__causes__
s of exceptions raised on workers are serialized (GH#3430) Alex AdamsonAdjust
numba.cuda
import and add check (GH#3446) John KirkhamFix name of Numba serialization test (GH#3447) John Kirkham
Checks for command parameters in
ssh2
(GH#3078) Peter Andreas EntschevUpdate
worker_kwargs
description inLocalCluster
constructor (GH#3438) James BourbeauEnsure scheduler updates task and worker states after successful worker data deletion (GH#3401) James Bourbeau
Avoid
loop=
keyword in asyncio coordination primitives (GH#3437) Matthew RocklinCall pip as a module to avoid warnings (GH#3436) Cyril Shcherbin
Add documentation of parameters in coordination primitives (GH#3434) Søren Fuglede Jørgensen
Replace
tornado.locks
with asyncio for Events/Locks/Conditions/Semaphore (GH#3397) Matthew RocklinRemove object from class hierarchy (GH#3432) Anderson Banihirwe
Add
dashboard_link
property toClient
(GH#3429) Jacob TomlinsonAllow memory monitor to evict data more aggressively (GH#3424) fjetter
Make
_get_ip
return an IP address when defaulting (GH#3418) Pierre GlaserSupport version checking with older versions of Dask (GH#3390) Igor Gotlibovych
Add Mac OS build to CI (GH#3358) James Bourbeau
2.10.0 - 2020-01-28¶
Fixed
ZeroDivisionError
in dashboard when no workers were present (GH#3407) James BourbeauRespect the
dashboard-prefix
when redirecting from the root (GH#3387) Chrysostomos NanakosAllow enabling / disabling work-stealing after the cluster has started (GH#3410) John Kirkham
Support
*args
and**kwargs
in offload (GH#3392) Matthew RocklinAdd lifecycle hooks to SchedulerPlugin (GH#3391) Matthew Rocklin
2.9.3 - 2020-01-17¶
Raise
RuntimeError
if no running loop (GH#3385) James BourbeauFix
get_running_loop
import (GH#3383) James BourbeauGet JavaScript document location instead of window and handle proxied url (GH#3382) Jacob Tomlinson
2.9.2 - 2020-01-16¶
Move Windows CI to GitHub Actions (GH#3373) Jacob Tomlinson
Add client join and leave hooks (GH#3371) Jacob Tomlinson
Add cluster map dashboard (GH#3361) Jacob Tomlinson
Close connection comm on retry (GH#3365) James Bourbeau
Fix scheduler state in case of worker name collision (GH#3366) byjott
Add
--worker-class
option todask-worker
CLI (GH#3364) James BourbeauRemove
locale
check that fails on OS X (GH#3360) Jacob TomlinsonRework version checking (GH#2627) Matthew Rocklin
Add websocket scheduler plugin (GH#3335) Jacob Tomlinson
Return task in
dask-worker
on_signal
function (GH#3354) James BourbeauFix failures on mixed integer/string worker names (GH#3352) Benedikt Reinartz
Avoid calling
nbytes
multiple times when sending data (GH#3349) Markus MohrhardAvoid setting event loop policy if within IPython kernel and no running event loop (GH#3336) Mana Borwornpadungkitti
Relax intermittent failing
test_profile_server
(GH#3346) Matthew Rocklin
2.9.1 - 2019-12-27¶
Add lock around dumps_function cache (GH#3337) Matthew Rocklin
Add setuptools to dependencies (GH#3320) James Bourbeau
Use TaskPrefix.name in Graph layout (GH#3328) Matthew Rocklin
Add missing “ in performance report example (GH#3329) John Kirkham
Add performance report docs and color definitions to docs (GH#3325) Benjamin Zaitlen
Switch startstops to dicts and add worker name to transfer (GH#3319) Jacob Tomlinson
Add plugin entry point for out-of-tree comms library (GH#3305) Patrick Sodré
Use worker name in logs (GH#3309) Stephan Erb
Add TaskGroup and TaskPrefix scheduler state (GH#3262) Matthew Rocklin
Update inlining Futures in task graph in Client._graph_to_futures (GH#3303) James Bourbeau
Use hostname as default IP address rather than localhost (GH#3308) Matthew Rocklin
Clean up flaky test_nanny_throttle (GH#3295) Tom Augspurger
Add lock to scheduler for sensitive operations (GH#3259) Matthew Rocklin
Log address for each of the Scheduler listerners (GH#3306) Matthew Rocklin
Make ConnectionPool.close asynchronous (GH#3304) Matthew Rocklin
2.9.0 - 2019-12-06¶
Add
dask-spec
CLI tool (GH#3090) Matthew RocklinConnectionpool: don’t hand out closed connections (GH#3301) byjott
Skip
Security.temporary()
tests if cryptography not installed (GH#3302) James BourbeauSupport multiple listeners in the scheduler (GH#3288) Matthew Rocklin
Updates RMM comment to the correct release (GH#3299) John Kirkham
Add title to
performance_report
(GH#3298) Matthew RocklinForgot to fix slow test (GH#3297) Benjamin Zaitlen
Update
SSHCluster
docstring parameters (GH#3296) James Bourbeauworker.close()
awaitsbatched_stream.close()
(GH#3291) Mads R. B. KristensenFix asynchronous listener in UCX (GH#3292) Benjamin Zaitlen
Avoid repeatedly adding deps to already in memory stack (GH#3293) James Bourbeau
xfail ucx empty object typed dataframe (GH#3279) Benjamin Zaitlen
Fix
distributed.wait
documentation (GH#3289) Tom RochetteMove Python 3 syntax tests into main tests (GH#3281) Matthew Rocklin
xfail
test_workspace_concurrency
for Python 3.6 (GH#3283) Matthew RocklinAdd
performance_report
context manager for static report generation (GH#3282) Matthew RocklinUpdate function serialization caches with custom LRU class (GH#3260) James Bourbeau
Make
Listener.start
asynchronous (GH#3278) Matthew RocklinRemove
dask-submit
anddask-remote
(GH#3280) Matthew RocklinWorker profile server (GH#3274) Matthew Rocklin
Improve bandwidth workers plot (GH#3273) Matthew Rocklin
Make profile coroutines consistent between
Scheduler
andWorker
(GH#3277) Matthew RocklinEnable saving profile information from server threads (GH#3271) Matthew Rocklin
Remove memory use plot (GH#3269) Matthew Rocklin
Add offload size to configuration (GH#3270) Matthew Rocklin
Fix layout scaling on profile plots (GH#3268) Jacob Tomlinson
Set
x_range
in CPU plot based on the number of threads (GH#3266) Matthew RocklinUse base-2 values for byte-valued axes in dashboard (GH#3267) Matthew Rocklin
Robust gather in case of connection failures (GH#3246) fjetter
Use
DeviceBuffer
from newer RMM releases (GH#3261) John KirkhamFix dev requirements for pytest (GH#3264) Elliott Sales de Andrade
Add validate options to configuration (GH#3258) Matthew Rocklin
2.8.1 - 2019-11-22¶
Fix hanging worker when the scheduler leaves (GH#3250) Tom Augspurger
Fix NumPy writeable serialization bug (GH#3253) James Bourbeau
Skip
numba.cuda
tests if CUDA is not available (GH#3255) Peter Andreas EntschevAdd new dashboard plot for memory use by key (GH#3243) Matthew Rocklin
Fixed cupy array going out of scope (GH#3240) Mads R. B. Kristensen
Remove
gen.coroutine
usage in scheduler (GH#3242) Jim Crist-HarifUse
inspect.isawaitable
where relevant (GH#3241) Jim Crist-Harif
2.8.0 - 2019-11-14¶
Add UCX config values (GH#3135) Matthew Rocklin
Relax test_MultiWorker (GH#3210) Matthew Rocklin
Avoid ucp.init at import time (GH#3211) Matthew Rocklin
Clean up rpc to avoid intermittent test failure (GH#3215) Matthew Rocklin
Respect protocol if given to Scheduler (GH#3212) Matthew Rocklin
Use legend_field= keyword in bokeh plots (GH#3218) Matthew Rocklin
Cache psutil.Process object in Nanny (GH#3207) Matthew Rocklin
Replace gen.sleep with asyncio.sleep (GH#3208) Matthew Rocklin
Avoid offloading serialization for small messages (GH#3224) Matthew Rocklin
Add desired_workers metric (GH#3221) Gabriel Sailer
Fail fast when importing distributed.comm.ucx (GH#3228) Matthew Rocklin
Add module name to Future repr (GH#3231) Matthew Rocklin
Add name to Pub/Sub repr (GH#3235) Matthew Rocklin
Import CPU_COUNT from dask.system (GH#3199) James Bourbeau
Efficiently serialize zero strided NumPy arrays (GH#3180) James Bourbeau
Cache function deserialization in workers (GH#3234) Matthew Rocklin
Respect ordering of futures in futures_of (GH#3236) Matthew Rocklin
Bump dask dependency to 2.7.0 (GH#3237) James Bourbeau
Clear task stream based on recent behavior (GH#3200) Matthew Rocklin
Use the percentage field for profile plots (GH#3238) Matthew Rocklin
2.7.0 - 2019-11-08¶
This release drops support for Python 3.5
Adds badges to README.rst [skip ci] (GH#3152) James Bourbeau
Don’t overwrite self.address if it is present (GH#3153) Gil Forsyth
Remove outdated references to debug scheduler and worker bokeh pages. (GH#3160) darindf
Update CONTRIBUTING.md (GH#3159) Jacob Tomlinson
Add Prometheus metric for a worker’s executing tasks count (GH#3163) darindf
Fix Numba serialization when strides is None (GH#3166) Peter Andreas Entschev
Await cluster in Adaptive.recommendations (GH#3168) Simon Boothroyd
Avoid swamping high-memory workers with data requests (GH#3071) Tom Augspurger
Update UCX variables to use sockcm by default (GH#3177) Peter Andreas Entschev
Get protocol in Nanny/Worker from scheduler address (GH#3175) Peter Andreas Entschev
Add worker and tasks state for Prometheus data collection (GH#3174) darindf
Use async def functions for offload to/from_frames (GH#3171) Mads R. B. Kristensen
Subprocesses inherit the global dask config (GH#3192) Mads R. B. Kristensen
XFail test_open_close_many_workers (GH#3194) Matthew Rocklin
Drop Python 3.5 (GH#3179) James Bourbeau
UCX: avoid double init after fork (GH#3178) Mads R. B. Kristensen
Silence warning when importing while offline (GH#3203) James A. Bednar
Adds docs to Client methods for resources, actors, and traverse (GH#2851) IPetrik
Add test for concurrent scatter operations (GH#2244) Matthew Rocklin
Expand async docs (GH#2293) Dave Hirschfeld
Add PatchedDeviceArray to drop stride attribute for cupy<7.0 (GH#3198) Richard J Zamora
2.6.0 - 2019-10-15¶
Refactor dashboard module (GH#3138) Jacob Tomlinson
Use
setuptools.find_packages
insetup.py
(GH#3150) Matthew RocklinMove death timeout logic up to
Node.start
(GH#3115) Matthew RocklinOnly include metric in
WorkerTable
if it is a scalar (GH#3140) Matthew RocklinAdd
Nanny(config={...})
keyword (GH#3134) Matthew RocklinXfail
test_worksapce_concurrency
on Python 3.6 (GH#3132) Matthew RocklinExtend Worker plugin API with transition method (GH#2994) matthieubulte
Raise exception if the user passes in unused keywords to
Client
(GH#3117) Jonathan De TroyeMove new
SSHCluster
to top level (GH#3128) Matthew Rocklin
2.5.2 - 2019-10-04¶
Make dask-worker close quietly when given sigint signal (GH#3116) Matthew Rocklin
Replace use of tornado.gen with asyncio in dask-worker (GH#3114) Matthew Rocklin
UCX: allocate CUDA arrays using RMM and Numba (GH#3109) Mads R. B. Kristensen
Support calling cluster.scale as async method (GH#3110) Jim Crist
Identify lost workers in SpecCluster based on address not name (GH#3088) James Bourbeau
Add Client.shutdown method (GH#3106) Matthew Rocklin
Collect worker-worker and type bandwidth information (GH#3094) Matthew Rocklin
Send noise over the wire to keep dask-ssh connection alive (GH#3105) Gil Forsyth
Retry scheduler connect multiple times (GH#3104) Jacob Tomlinson
Add favicon of logo to the dashboard (GH#3095) James Bourbeau
Remove utils.py functions for their dask/utils.py equivalents (GH#3042) Matthew Rocklin
Lower default bokeh log level (GH#3087) Philipp Rudiger
Check if self.cluster.scheduler is a local scheduler (GH#3099) Jacob Tomlinson
2.5.1 - 2019-09-27¶
Support clusters that don’t have .security or ._close methods (GH#3100) Matthew Rocklin
2.5.0 - 2019-09-27¶
Use the new UCX Python bindings (GH#3059) Mads R. B. Kristensen
Fix widget with spec that generates multiple workers (GH#3067) Loïc Estève
Make Client.get_versions async friendly (GH#3064) Jacob Tomlinson
Add configuation option for longer error tracebacks (GH#3086) Daniel Farrell
Have Client get Security from passed Cluster (GH#3079) Matthew Rocklin
Respect Cluster.dashboard_link in Client._repr_html_ if it exists (GH#3077) Matthew Rocklin
Add monitoring with dask cluster docs (GH#3072) Arpit Solanki
Protocol of cupy and numba handles serialization exclusively (GH#3047) Mads R. B. Kristensen
Allow specification of worker type in SSHCLuster (GH#3061) Jacob Tomlinson
Use Cluster.scheduler_info for workers= value in repr (GH#3058) Matthew Rocklin
Allow SpecCluster to scale by memory and cores (GH#3057) Matthew Rocklin
Allow full script in preload inputs (GH#3052) Matthew Rocklin
Check multiple cgroups dirs, ceil fractional cpus (GH#3056) Jim Crist
Add blurb about disabling work stealing (GH#3055) Chris White
2.4.0 - 2019-09-13¶
Remove six (GH#3045) Matthew Rocklin
Add missing test data to sdist tarball (GH#3050) Elliott Sales de Andrade
Use mock from unittest standard library (GH#3049) Elliott Sales de Andrade
Use cgroups resource limits to determine default threads and memory (GH#3039) Jim Crist
Move task deserialization to immediately before task execution (GH#3015) James Bourbeau
Drop joblib shim module in distributed (GH#3040) John Kirkham
Redirect configuration doc page (GH#3038) Matthew Rocklin
Support
--name 0
and--nprocs
keywords in dask-worker cli (GH#3037) Matthew RocklinRemove lost workers from
SpecCluster.workers
(GH#2990) Guillaume Eynard-BontempsClean up
test_local.py::test_defaults
(GH#3017) Matthew RocklinReplace print statement in
Queue.__init__
with debug message (GH#3035) Mikhail AkimovSet the
x_range
limit of the Meory utilization plot to memory-limit (GH#3034) Matthew RocklinRely on cudf codebase for cudf serialization (GH#2998) Benjamin Zaitlen
Add support for zstandard compression to comms (GH#2970) Abael He
Avoid collision when using
os.environ
indashboard_link
(GH#3021) Matthew RocklinSupport Spec jobs that generate multiple workers (GH#3013) Matthew Rocklin
Better name for cudf deserialization function name (GH#3008) Benjamin Zaitlen
Make
spec.ProcessInterface
a valid no-op worker (GH#3004) Matthew RocklinReturn dictionaries from
new_worker_spec
rather than name/worker pairs (GH#3000) Matthew RocklinFix minor typo in documentation (GH#3002) Mohammad Noor
Permit more keyword options when scaling with cores and memory (GH#2997) Matthew Rocklin
Add
cuda_ipc
to UCX environment for NVLink (GH#2996) Benjamin ZaitlenAdd
threads=
andmemory=
to Cluster and Client reprs (GH#2995) Matthew RocklinFix PyNVML initialization (GH#2993) Richard J Zamora
2.3.2 - 2019-08-23¶
Skip exceptions in startup information (GH#2991) Jacob Tomlinson
2.3.1 - 2019-08-22¶
Add support for separate external address for SpecCluster scheduler (GH#2963) Jacob Tomlinson
Defer cudf serialization/deserialization to that library (GH#2881) Benjamin Zaitlen
Workaround for hanging test now calls ucp.fin() (GH#2967) Mads R. B. Kristensen
Directly import progress from diagnostics.progressbar (GH#2975) Matthew Rocklin
Handle buffer protocol objects in ensure_bytes (GH#2969) Tom Augspurger
Improve get_ip_interface error message when interface does not exist (GH#2964) Loïc Estève
Add cores= and memory= keywords to scale (GH#2974) Matthew Rocklin
Make workers robust to bad custom metrics (GH#2984) Matthew Rocklin
2.3.0 - 2019-08-16¶
Except all exceptions when checking
pynvml
(GH#2961) Matthew RocklinPass serialization down through small base collections (GH#2948) Peter Andreas Entschev
Use
pytest.warning(Warning)
rather thanException
(GH#2958) Matthew RocklinAllow
server_kwargs
to override defaults in dashboard (GH#2955) Bruce MerryUpdate
utils_perf.py
(GH#2954) Shayan AmaniNormalize names with
str
inretire_workers
(GH#2949) Matthew RocklinUpdate
client.py
(GH#2951) Shayan AmaniAdd
GPUCurrentLoad
dashboard plots (GH#2944) Matthew RocklinPass GPU diagnostics from worker to scheduler (GH#2932) Matthew Rocklin
Fixes Worker docstring formatting (GH#2939) James Bourbeau
Redirect setup docs to docs.dask.org (GH#2936) Matthew Rocklin
Wrap offload in
gen.coroutine
(GH#2934) Matthew RocklinChange
TCP.close
to a coroutine to avoid task pending warning (GH#2930) Matthew RocklinMove core functionality from
SpecCluster
toCluster
(GH#2913) Matthew RocklinAdd aenter/aexit protocols to
ProcessInterface
(GH#2927) Matthew RocklinAdd real-time CPU utilization plot to dashboard (GH#2922) Matthew Rocklin
Always kill processes in clean tests, even if we don’t check (GH#2924) Matthew Rocklin
Add timeouts to processes in SSH tests (GH#2925) Matthew Rocklin
Add documentation around
spec.ProcessInterface
(GH#2923) Matthew RocklinCleanup async warnings in tests (GH#2920) Matthew Rocklin
Give 404 when requesting nonexistent tasks or workers (GH#2921) Martin Durant
Raise informative warning when rescheduling an unknown task (GH#2916) James Bourbeau
Fix docstring (GH#2917) Martin Durant
Add keep-alive message between worker and scheduler (GH#2907) Matthew Rocklin
Rewrite
Adaptive
/SpecCluster
to support slowly arriving workers (GH#2904) Matthew RocklinCall heartbeat rather than reconnect on disconnection (GH#2906) Matthew Rocklin
2.2.0 - 2019-07-31¶
Respect security configuration in LocalCluster (GH#2822) Russ Bubley
Add Nanny to worker docs (GH#2826) Christian Hudon
Don’t make False add-keys report to scheduler (GH#2421) tjb900
Include type name in SpecCluster repr (GH#2834) Jacob Tomlinson
Extend prometheus metrics endpoint (GH#2833) Gabriel Sailer
Add alternative SSHCluster implementation (GH#2827) Matthew Rocklin
Dont reuse closed worker in get_worker (GH#2841) Pierre Glaser
SpecCluster: move init logic into start (GH#2850) Jacob Tomlinson
Document distributed.Reschedule in API docs (GH#2860) James Bourbeau
Add fsspec to installation of test builds (GH#2859) Martin Durant
Make await/start more consistent across Scheduler/Worker/Nanny (GH#2831) Matthew Rocklin
Add cleanup fixture for asyncio tests (GH#2866) Matthew Rocklin
Use only remote connection to scheduler in Adaptive (GH#2865) Matthew Rocklin
Add Server.finished async function (GH#2864) Matthew Rocklin
Align text and remove bullets in Client HTML repr (GH#2867) Matthew Rocklin
Test dask-scheduler –idle-timeout flag (GH#2862) Matthew Rocklin
Replace gen.coroutine with async/await in core (GH#2871) Matthew Rocklin
Forcefully kill all processes before each test (GH#2882) Matthew Rocklin
Cleanup Security class and configuration (GH#2873) Jim Crist
Remove unused variable in SpecCluster scale down (GH#2870) Jacob Tomlinson
Add SpecCluster ProcessInterface (GH#2874) Jacob Tomlinson
Add Log(str) and Logs(dict) classes for nice HTML reprs (GH#2875) Jacob Tomlinson
Pass Client._asynchronous to Cluster._asynchronous (GH#2890) Matthew Rocklin
Add default logs method to Spec Cluster (GH#2889) Matthew Rocklin
Add processes keyword back into clean (GH#2891) Matthew Rocklin
Update black (GH#2901) Matthew Rocklin
Move Worker.local_dir attribute to Worker.local_directory (GH#2900) Matthew Rocklin
Link from TapTools to worker info pages in dashboard (GH#2894) Matthew Rocklin
Avoid exception in Client._ensure_connected if closed (GH#2893) Matthew Rocklin
Convert Pythonic kwargs to CLI Keywords for SSHCluster (GH#2898) Matthew Rocklin
Use kwargs in CLI (GH#2899) Matthew Rocklin
Name SSHClusters by providing name= keyword to SpecCluster (GH#2903) Matthew Rocklin
Request feed of worker information from Scheduler to SpecCluster (GH#2902) Matthew Rocklin
Clear out compatibillity file (GH#2896) Matthew Rocklin
Remove future imports (GH#2897) Matthew Rocklin
Use click’s show_default=True in relevant places (GH#2838) Christian Hudon
Close workers more gracefully (GH#2905) Matthew Rocklin
Close workers gracefully with –lifetime keywords (GH#2892) Matthew Rocklin
Add closing <li> tags to Client._repr_html_ (GH#2911) Matthew Rocklin
Add endline spacing in Logs._repr_html_ (GH#2912) Matthew Rocklin
2.1.0 - 2019-07-08¶
Fix typo that prevented error message (GH#2825) Russ Bubley
Remove
dask-mpi
(GH#2824) Matthew RocklinUpdates to use
update_graph
in task journey docs (GH#2821) James BourbeauFix Client repr with
memory_info=None
(GH#2816) Matthew RocklinFix case where key, rather than
TaskState
, could end up ints.waiting_on
(GH#2819) tjb900Use Keyword-only arguments (GH#2814) Matthew Rocklin
Relax check for worker references in cluster context manager (GH#2813) Matthew Rocklin
Use
dask.utils.format_bytes
(GH#2810) Tom Augspurger
2.0.1 - 2019-06-26¶
We neglected to include python_requires=
in our setup.py file, resulting in
confusion for Python 2 users who erroneously get packages for 2.0.0.
This is fixed in 2.0.1 and we have removed the 2.0.0 files from PyPI.
Add python_requires entry to setup.py (GH#2807) Matthew Rocklin
Correctly manage tasks beyond deque limit in TaskStream plot (GH#2797) Matthew Rocklin
Fix diagnostics page for memory_limit=None (GH#2770) Brett Naul
2.0.0 - 2019-06-25¶
Drop support for Python 2
Relax warnings before release (GH#2796) Matthew Rocklin
Deprecate –bokeh/–no-bokeh CLI (GH#2800) Tom Augspurger
Typo in bokeh service_kwargs for dask-worker (GH#2783) Tom Augspurger
Update command line cli options docs (GH#2794) James Bourbeau
Remove “experimental” from TLS docs (GH#2793) James Bourbeau
Add warnings around ncores= keywords (GH#2791) Matthew Rocklin
Add –version option to scheduler and worker CLI (GH#2782) Tom Augspurger
Raise when workers initialization times out (GH#2784) Tom Augspurger
Replace ncores with nthreads throughout codebase (GH#2758) Matthew Rocklin
Add unknown pytest markers (GH#2764) Tom Augspurger
Delay lookup of allowed failures. (GH#2761) Tom Augspurger
Change address -> worker in ColumnDataSource for nbytes plot (GH#2755) Matthew Rocklin
Remove module state in Prometheus Handlers (GH#2760) Matthew Rocklin
Add stress test for UCX (GH#2759) Matthew Rocklin
Add nanny logs (GH#2744) Tom Augspurger
Move some of the adaptive logic into the scheduler (GH#2735) Matthew Rocklin
Add SpecCluster.new_worker_spec method (GH#2751) Matthew Rocklin
Worker dashboard fixes (GH#2747) Matthew Rocklin
Add async context managers to scheduler/worker classes (GH#2745) Matthew Rocklin
Fix the resource key representation before sending graphs (GH#2733) Michael Spiegel
Allow user to configure whether workers are daemon. (GH#2739) Caleb
Pin pytest >=4 with pip in appveyor and python 3.5 (GH#2737) Matthew Rocklin
Add Experimental UCX Comm (GH#2591) Ben Zaitlen Tom Augspurger Matthew Rocklin
Close nannies gracefully (GH#2731) Matthew Rocklin
add kwargs to progressbars (GH#2638) Manuel Garrido
Add back LocalCluster.__repr__. (GH#2732) Loïc Estève
Move bokeh module to dashboard (GH#2724) Matthew Rocklin
Close clusters at exit (GH#2730) Matthew Rocklin
Add SchedulerPlugin TaskState example (GH#2622) Matt Nicolls
Add SpecificationCluster (GH#2675) Matthew Rocklin
Replace register_worker_callbacks with worker plugins (GH#2453) Matthew Rocklin
Proxy worker dashboards from scheduler dashboard (GH#2715) Ben Zaitlen
Add docstring to Scheduler.check_idle_saturated (GH#2721) Matthew Rocklin
Refer to LocalCluster in Client docstring (GH#2719) Matthew Rocklin
Remove special casing of Scikit-Learn BaseEstimator serialization (GH#2713) Matthew Rocklin
Fix two typos in Pub class docstring (GH#2714) Magnus Nord
Support uploading files with multiple modules (GH#2587) Sam Grayson
Change the main workers bokeh page to /status (GH#2689) Ben Zaitlen
Cleanly stop periodic callbacks in Client (GH#2705) Matthew Rocklin
Disable pan tool for the Progress, Byte Stored and Tasks Processing plot (GH#2703) Mathieu Dugré
Except errors in Nanny’s memory monitor if process no longer exists (GH#2701) Matthew Rocklin
Handle heartbeat when worker has just left (GH#2702) Matthew Rocklin
Modify styling of histograms for many-worker dashboard plots (GH#2695) Mathieu Dugré
Add method to wait for n workers before continuing (GH#2688) Daniel Farrell
Support computation on delayed(None) (GH#2697) Matthew Rocklin
Cleanup localcluster (GH#2693) Matthew Rocklin
Use ‘temporary-directory’ from dask.config for Worker’s directory (GH#2654) Matthew Rocklin
Remove support for Iterators and Queues (GH#2671) Matthew Rocklin
1.28.1 - 2019-05-13¶
This is a small bugfix release due to a config change upstream.
Use config accessor method for “scheduler-address” (GH#2676) James Bourbeau
1.28.0 - 2019-05-08¶
Add Type Attribute to TaskState (GH#2657) Matthew Rocklin
Add waiting task count to progress title bar (GH#2663) James Bourbeau
DOC: Clean up reference to cluster object (GH#2664) K.-Michael Aye
Allow scheduler to politely close workers as part of shutdown (GH#2651) Matthew Rocklin
Check direct_to_workers before using get_worker in Client (GH#2656) Matthew Rocklin
Fixed comment regarding keeping existing level if less verbose (GH#2655) Brett Randall
Add idle timeout to scheduler (GH#2652) Matthew Rocklin
Avoid deprecation warnings (GH#2653) Matthew Rocklin
Use an LRU cache for deserialized functions (GH#2623) Matthew Rocklin
Rename Worker._close to Worker.close (GH#2650) Matthew Rocklin
Add Comm closed bookkeeping (GH#2648) Matthew Rocklin
Explain LocalCluster behavior in Client docstring (GH#2647) Matthew Rocklin
Add last worker into KilledWorker exception to help debug (GH#2610) @plbertrand
Set working worker class for dask-ssh (GH#2646) Martin Durant
Limit test_spill_by_default memory, reenable it (GH#2633) Peter Andreas Entschev
Use proper address in worker -> nanny comms (GH#2640) Jim Crist
Fix deserialization of bytes chunks larger than 64MB (GH#2637) Peter Andreas Entschev
1.27.1 - 2019-04-29¶
Adaptive: recommend close workers when any are idle (GH#2330) Michael Delgado
Increase GC thresholds (GH#2624) Matthew Rocklin
Add interface= keyword to LocalCluster (GH#2629) Matthew Rocklin
Add worker_class argument to LocalCluster (GH#2625) Matthew Rocklin
Remove Python 2.7 from testing matrix (GH#2631) Matthew Rocklin
Add number of trials to diskutils test (GH#2630) Matthew Rocklin
Fix parameter name in LocalCluster docstring (GH#2626) Loïc Estève
Integrate stacktrace for low-level profiling (GH#2575) Peter Andreas Entschev
Apply Black to standardize code styling (GH#2614) Matthew Rocklin
added missing whitespace to start_worker cmd (GH#2613) condoratberlin
Updated logging module doc links from docs.python.org/2 to docs.python.org/3. (GH#2635) Brett Randall
1.27.0 - 2019-04-12¶
Add basic health endpoints to scheduler and worker bokeh. (GH#2607) amerkel2
Improved description accuracy of –memory-limit option. (GH#2601) Brett Randall
Check self.dependencies when looking at dependent tasks in memory (GH#2606) deepthirajagopalan7
Add RabbitMQ SchedulerPlugin example (GH#2604) Matt Nicolls
add resources to scheduler update_graph plugin (GH#2603) Matt Nicolls
Use ensure_bytes in serialize_error (GH#2588) Matthew Rocklin
Specify data storage explicitly from Worker constructor (GH#2600) Matthew Rocklin
Change bokeh port keywords to dashboard_address (GH#2589) Matthew Rocklin
.detach_() pytorch tensor to serialize data as numpy array. (GH#2586) Muammar El Khatib
Add warning if creating scratch directories takes a long time (GH#2561) Matthew Rocklin
Fix typo in pub-sub doc. (GH#2599) Loïc Estève
Allow return_when=’FIRST_COMPLETED’ in wait (GH#2598) Nikos Tsaousis
Use ensure_dict instead of dict (GH#2594) James Bourbeau
Specify protocol in LocalCluster (GH#2489) Matthew Rocklin
1.26.1 - 2019-03-29¶
Fix LocalCluster to not overallocate memory when overcommitting threads per worker (GH#2541) George Sakkis
Make closing resilient to lacking an address (GH#2542) Matthew Rocklin
fix typo in comment (GH#2546) Brett Jurman
Fix double init of prometheus metrics (GH#2544) Marco Neumann
Skip test_duplicate_clients without bokeh. (GH#2553) Elliott Sales de Andrade
Add blocked_handlers to servers (GH#2556) Chris White
Always yield Server.handle_comm coroutine (GH#2559) Tom Augspurger
Use yaml.safe_load (GH#2566) Matthew Rocklin
Fetch executables from build root. (GH#2551) Elliott Sales de Andrade
Fix Torando 6 test failures (GH#2570) Matthew Rocklin
Fix test_sync_closed_loop (GH#2572) Matthew Rocklin
1.26.0 - 2019-02-25¶
Update style to fix recent flake8 update (GH#2500) (GH#2509) Matthew Rocklin
Fix typo in gen_cluster log message (GH#2503) Loïc Estève
Allow KeyError when closing event loop (GH#2498) Matthew Rocklin
Avoid thread testing for TCP ThreadPoolExecutor (GH#2510) Matthew Rocklin
Avoid AttributeError when closing and sending a message (GH#2514) Matthew Rocklin
Add deprecation warning to dask_mpi.py (GH#2522) Julia Kent
Relax statistical profiling test (GH#2527) Matthew Rocklin
Support alternative –remote-dask-worker SSHCluster() and dask-ssh CLI (GH#2526) Adam Beberg
Iterate over full list of plugins in transition (GH#2518) Matthew Rocklin
Create Prometheus Endpoint (GH#2499) Adam Beberg
Use pytest.importorskip for prometheus test (GH#2533) Matthew Rocklin
MAINT skip prometheus test when no installed (GH#2534) Olivier Grisel
Fix intermittent testing failures (GH#2535) Matthew Rocklin
Avoid using nprocs keyword in dask-ssh if set to one (GH#2531) Matthew Rocklin
Bump minimum Tornado version to 5.0
1.25.3 - 2019-01-31¶
Fix excess threading on missing connections (GH#2403) Daniel Farrell
Fix typo in doc (GH#2457) Loïc Estève
Start fewer but larger workers with LocalCluster (GH#2452) Matthew Rocklin
Check for non-zero
length
first inread
loop (GH#2465) John KirkhamDOC: Use of local cluster in script (GH#2462) Peter Killick
DOC/API: Signature for base class write / read (GH#2472) Tom Augspurger
Support Pytest 4 in Tests (GH#2478) Adam Beberg
Ensure async behavior in event loop with LocalCluster (GH#2484) Matthew Rocklin
Fix spurious CancelledError (GH#2485) Loïc Estève
Properly reset dask.config scheduler and shuffle when closing the client (GH#2475) George Sakkis
Make it more explict that resources are per worker. (GH#2470) Loïc Estève
Remove references to center (GH#2488) Matthew Rocklin
Expand client clearing timeout to 10s in testing (GH#2493) Matthew Rocklin
Propagate key keyword in progressbar (GH#2492) Matthew Rocklin
Use provided cluster’s IOLoop if present in Client (GH#2494) Matthew Rocklin
1.25.2 - 2019-01-04¶
Clean up LocalCluster logging better in async mode (GH#2448) Matthew Rocklin
Add short error message if bokeh cannot be imported (GH#2444) Dirk Petersen
Add optional environment variables to Nanny (GH#2431) Matthew Rocklin
Make the direct keyword docstring entries uniform (GH#2441) Matthew Rocklin
Make LocalCluster.close async friendly (GH#2437) Matthew Rocklin
gather_dep: don’t request dependencies we already found out we don’t want (GH#2428) tjb900
Add parameters to Client.run docstring (GH#2429) Matthew Rocklin
Support coroutines and async-def functions in run/run_scheduler (GH#2427) Matthew Rocklin
Name threads in ThreadPoolExecutors (GH#2408) Matthew Rocklin
1.25.1 - 2018-12-15¶
Serialize numpy.ma.masked objects properly (GH#2384) Jim Crist
Turn off bokeh property validation in dashboard (GH#2387) Jim Crist
Fix typo in scheduler docstring (GH#2393) Russ Bubley
DOC: fix typo in distributed.worker.Worker docstring (GH#2395) Loïc Estève
Remove clients and workers from event log after removal (GH#2394) tjb900
Support msgpack 0.6.0 by providing length keywords (GH#2399) tjb900
Use async-await on large messages test (GH#2404) Matthew Rocklin
Fix race condition in normalize_collection (GH#2386) Jim Crist
Fix redict collection after HighLevelGraph fix upstream (GH#2413) Matthew Rocklin
Add a blocking argument to Lock.acquire() (GH#2412) Stephan Hoyer
Fix long traceback test (GH#2417) Matthew Rocklin
Update x509 certificates to current OpenSSL standards. (GH#2418) Diane Trout
1.25.0 - 2018-11-28¶
Fixed the 404 error on the Scheduler Dashboard homepage (GH#2361) Michael Wheeler
Consolidate two Worker classes into one (GH#2363) Matthew Rocklin
Avoid warnings in pyarrow and msgpack (GH#2364) Matthew Rocklin
Avoid race condition in Actor’s Future (GH#2374) Matthew Rocklin
Support missing packages keyword in Client.get_versions (GH#2379) Matthew Rocklin
1.24.2 - 2018-11-15¶
Add support for Bokeh 1.0 (GH#2348) (GH#2356) Matthew Rocklin
Fix regression that dropped support for Tornado 4 (GH#2353) Roy Wedge
Avoid deprecation warnings (GH#2355) (GH#2357) Matthew Rocklin
Fix typo in worker documentation (GH#2349) Tom Rochette
1.24.1 - 2018-11-09¶
Use tornado’s builtin AnyThreadLoopEventPolicy (GH#2326) Matthew Rocklin
Adjust TLS tests for openssl 1.1 (GH#2331) Marius van Niekerk
Avoid setting event loop policy if within Jupyter notebook server (GH#2343) Matthew Rocklin
Add preload script to conf (GH#2325) Guillaume Eynard-Bontemps
Add serializer for Numpy masked arrays (GH#2335) Peter Killick
Use worker SSL context when getting client from worker. (GH#2301) Anonymous
1.24.0 - 2018-10-26¶
Remove Joblib Dask Backend from codebase (GH#2298) Matthew Rocklin
Include worker tls protocol in Scheduler.restart (GH#2295) Matthew Rocklin
Adapt to new Bokeh selection for 1.0 (GH#2292) Matthew Rocklin
Add explicit retry method to Future and Client (GH#2299) Matthew Rocklin
Point to main worker page in bokeh links (GH#2300) Matthew Rocklin
Limit concurrency when gathering many times (GH#2303) Matthew Rocklin
Add tls_cluster pytest fixture (GH#2302) Matthew Rocklin
Convert ConnectionPool.open and active to properties (GH#2304) Matthew Rocklin
Redirect joblib page to dask-ml (GH#2307) Matthew Rocklin
Include unserializable object in error message (GH#2310) Matthew Rocklin
Import Mapping, Iterator, Set from collections.abc in Python 3 (GH#2315) Gaurav Sheni
Update for new flake8 (GH#2321) Matthew Rocklin
1.23.3 - 2018-10-05¶
Err in dask serialization if not a NotImplementedError (GH#2251) Matthew Rocklin
Protect against key missing from priority in GraphLayout (GH#2259) Matthew Rocklin
Do not pull data twice in Client.gather (GH#2263) Adam Klein
Add pytest fixture for cluster tests (GH#2262) Matthew Rocklin
Cleanup bokeh callbacks (GH#2261) (GH#2278) Matthew Rocklin
Fix bokeh error for memory_limit=None (GH#2255) Brett Naul
Place large keywords into task graph in Client.map (GH#2281) Matthew Rocklin
Remove redundant blosc threading code from protocol.numpy (GH#2284) Mike Gevaert
Add ncores to workertable (GH#2289) Matthew Rocklin
Support upload_file on files with no extension (GH#2290) Matthew Rocklin
1.23.2 - 2018-09-17¶
Discard dependent rather than remove (GH#2250) Matthew Rocklin
Use dask_sphinx_theme Matthew Rocklin
Drop the Bokeh index page (GH#2241) John Kirkham
Revert change to keep link relative (GH#2242) Matthew Rocklin
docs: Fix broken AWS link in setup.rst file (GH#2240) Vladyslav Moisieienkov
Return cancelled futures in as_completed (GH#2233) Chris White
1.23.1 - 2018-09-06¶
Raise informative error when mixing futures between clients (GH#2227) Matthew Rocklin
add byte_keys to unpack_remotedata call (GH#2232) Matthew Rocklin
Add documentation for gist/rawgit for get_task_stream (GH#2236) Matthew Rocklin
Quiet Client.close by waiting for scheduler stop signal (GH#2237) Matthew Rocklin
Display system graphs nicely on different screen sizes (GH#2239) Derek Ludwig
Mutate passed in workers dict in TaskStreamPlugin.rectangles (GH#2238) Matthew Rocklin
1.23.0 - 2018-08-30¶
Add direct_to_workers to Client Matthew Rocklin
Add Scheduler.proxy to workers Matthew Rocklin
Implement Actors Matthew Rocklin
Fix tooltip (GH#2168) Loïc Estève
Fix scale / avoid returning coroutines (GH#2171) Joe Hamman
Concatenate all bytes of small messages in TCP comms (GH#2172) Matthew Rocklin
Add dashboard_link property (GH#2176) Jacob Tomlinson
Always offload to_frames (GH#2170) Matthew Rocklin
Warn if desired port is already in use (GH#2191) (GH#2199) Matthew Rocklin
Add profile page for event loop thread (GH#2144) Matthew Rocklin
Use dispatch for dask serialization, also add sklearn, pytorch (GH#2175) Matthew Rocklin
Handle corner cases with busy signal (GH#2182) Matthew Rocklin
Check self.dependencies when looking at tasks in memory (GH#2196) Matthew Rocklin
Add ability to log additional custom metrics from each worker (GH#2169) Loïc Estève
Fix formatting when port is a tuple (GH#2204) Loïc Estève
Describe what ZeroMQ is (GH#2211) Mike DePalatis
Tiny typo fix (GH#2214) Anderson Banihirwe
Add Python 3.7 to travis.yml (GH#2203) Matthew Rocklin
Add plot= keyword to get_task_stream (GH#2198) Matthew Rocklin
Add support for optional versions in Client.get_versions (GH#2216) Matthew Rocklin
Add routes for solo bokeh figures in dashboard (GH#2185) Matthew Rocklin
Be resilient to missing dep after busy signal (GH#2217) Matthew Rocklin
Use CSS Grid to layout status page on the dashboard (GH#2213) Derek Ludwig and Luke Canavan
Fix deserialization of queues on main ioloop thread (GH#2221) Matthew Rocklin
Add a worker initialization function (GH#2201) Guillaume Eynard-Bontemps
Collapse navbar in dashboard (GH#2223) Luke Canavan
1.22.1 - 2018-08-03¶
Add worker_class= keyword to Nanny to support different worker types (GH#2147) Martin Durant
Cleanup intermittent worker failures (GH#2152) (GH#2146) Matthew Rocklin
Fix msgpack PendingDeprecationWarning for encoding=’utf-8’ (GH#2153) Olivier Grisel
Make bokeh coloring deterministic using hash function (GH#2143) Matthew Rocklin
Allow client to query the task stream plot (GH#2122) Matthew Rocklin
Use PID and counter in thread names (GH#2084) (GH#2128) Dror Birkman
Test that worker restrictions are cleared after cancellation (GH#2107) Matthew Rocklin
Expand resources in graph_to_futures (GH#2131) Matthew Rocklin
Add custom serialization support for pyarrow (GH#2115) Dave Hirschfeld
Update dask-scheduler cli help text for preload (GH#2120) Matt Nicolls
Added another nested parallelism test (GH#1710) Tom Augspurger
insert newline by default after TextProgressBar (GH#1976) Phil Tooley
Retire workers from scale (GH#2104) Matthew Rocklin
Allow worker to refuse data requests with busy signal (GH#2092) Matthew Rocklin
Don’t forget released keys (GH#2098) Matthew Rocklin
Update example for stopping a worker (GH#2088) John Kirkham
removed hardcoded value of memory terminate fraction from a log message (GH#2096) Bartosz Marcinkowski
Adjust worker doc after change in config file location and treatment (GH#2094) Aurélien Ponte
Prefer gathering data from same host (GH#2090) Matthew Rocklin
Handle exceptions on deserialized comm with text error (GH#2093) Matthew Rocklin
Fix typo in docstring (GH#2087) Loïc Estève
Provide communication context to serialization functions (GH#2054) Matthew Rocklin
Allow name to be explicitly passed in publish_dataset (GH#1995) Marius van Niekerk
Avoid accessing Worker.scheduler_delay around yield point (GH#2074) Matthew Rocklin
Support TB and PB in format bytes (GH#2072) Matthew Rocklin
Add test for as_completed for loops in Python 2 (GH#2071) Matthew Rocklin
Allow adaptive to exist without a cluster (GH#2064) Matthew Rocklin
Have worker data transfer wait until recipient acknowledges (GH#2052) Matthew Rocklin
Support async def functions in Client.sync (GH#2070) Matthew Rocklin
Add asynchronous parameter to docstring of LocalCluster Matthew Rocklin
Normalize address before comparison (GH#2066) Tom Augspurger
Use ConnectionPool for Worker.scheduler Matthew Rocklin
Avoid reference cycle in str_graph Matthew Rocklin
Pull data outside of while loop in gather (GH#2059) Matthew Rocklin
1.22.0 - 2018-06-14¶
Overhaul configuration (GH#1948) Matthew Rocklin
Replace get= keyword with scheduler= (GH#1959) Matthew Rocklin
Use tuples in msgpack (GH#2000) Matthew Rocklin and Marius van Niekerk
Unify handling of high-volume connections (GH#1970) Matthew Rocklin
Automatically scatter large arguments in joblib connector (GH#2020) (GH#2030) Olivier Grisel
Turn click Python 3 locales failure into a warning (GH#2001) Matthew Rocklin
Rely on dask implementation of sizeof (GH#2042) Matthew Rocklin
Replace deprecated workers.iloc with workers.values() (GH#2013) Grant Jenks
Introduce serialization families (GH#1912) Matthew Rocklin
Add PubSub (GH#1999) Matthew Rocklin
Add Dask stylesheet to documentation Matthew Rocklin
Avoid recomputation on partially-complete results (GH#1840) Matthew Rocklin
Use sys.prefix in popen for testing (GH#1954) Matthew Rocklin
Include yaml files in manifest Matthew Rocklin
Use self.sync so Client.processing works in asynchronous context (GH#1962) Henry Doupe
Fix bug with bad repr on closed client (GH#1965) Matthew Rocklin
Parse –death-timeout keyword in dask-worker (GH#1967) Matthew Rocklin
Support serializers in BatchedSend (GH#1964) Matthew Rocklin
Use normal serialization mechanisms to serialize published datasets (GH#1972) Matthew Rocklin
Add security support to LocalCluster. (GH#1855) Marius van Niekerk
add ConnectionPool.remove method (GH#1977) Tony Lorenzo
Cleanly close workers when scheduler closes (GH#1981) Matthew Rocklin
add comm to packages (GH#1980) Matthew Rocklin
Replace dask.set_options with dask.config.set Matthew Rocklin
Exclude versions of sortedcontainers which do not have .iloc. (GH#1993) Russ Bubley
Exclude gc statistics under PyPy (GH#1997) Marius van Niekerk
Manage recent config and dataframe changes in dask (GH#2009) Matthew Rocklin
Cleanup lingering clients in tests (GH#2012) Matthew Rocklin
Use timeouts during Client._ensure_connected (GH#2011) Martin Durant
Avoid reference cycle in joblib backend (GH#2014) Matthew Rocklin, also Olivier Grisel
DOC: fixed test example (GH#2017) Tom Augspurger
Add worker_key parameter to Adaptive (GH#1992) Matthew Rocklin
Prioritize tasks with their true keys, before stringifying (GH#2006) Matthew Rocklin
Serialize worker exceptions through normal channels (GH#2016) Matthew Rocklin
Include exception in progress bar (GH#2028) Matthew Rocklin
Avoid logging orphaned futures in All (GH#2008) Matthew Rocklin
Don’t use spill-to-disk dictionary if we’re not spilling to disk Matthew Rocklin
Only avoid recomputation if key exists (GH#2036) Matthew Rocklin
Use client connection and serialization arguments in progress (GH#2035) Matthew Rocklin
Rejoin worker client on closing context manager (GH#2041) Matthew Rocklin
Avoid forgetting erred tasks when losing dependencies (GH#2047) Matthew Rocklin
Avoid collisions in graph_layout (GH#2050) Matthew Rocklin
Avoid recursively calling bokeh callback in profile plot (GH#2048) Matthew Rocklin
1.21.8 - 2018-05-03¶
Remove errant print statement (GH#1957) Matthew Rocklin
Only add reevaluate_occupancy callback once (GH#1953) Tony Lorenzo
1.21.7 - 2018-05-02¶
Newline needed for doctest rendering (GH#1917) Loïc Estève
Support Client._repr_html_ when in async mode (GH#1909) Matthew Rocklin
Add parameters to dask-ssh command (GH#1910) Irene Rodriguez
Santize get_dataset trace (GH#1888) John Kirkham
Fix bug where queues would not clean up cleanly (GH#1922) Matthew Rocklin
Delete cached file safely in upload file (GH#1921) Matthew Rocklin
Accept KeyError when closing tornado IOLoop in tests (GH#1937) Matthew Rocklin
Quiet the client and scheduler when gather(…, errors=’skip’) (GH#1936) Matthew Rocklin
Clarify couldn’t gather keys warning (GH#1942) Kenneth Koski
Support submit keywords in joblib (GH#1947) Matthew Rocklin
Avoid use of external resources in bokeh server (GH#1934) Matthew Rocklin
Drop __contains__ from Datasets (GH#1889) John Kirkham
Fix bug with queue timeouts (GH#1950) Matthew Rocklin
Replace msgpack-python by msgpack (GH#1927) Loïc Estève
1.21.6 - 2018-04-06¶
Fix numeric environment variable configuration (GH#1885) Joseph Atkins-Kurkish
support bytearrays in older lz4 library (GH#1886) Matthew Rocklin
Remove started timeout in nanny (GH#1852) Matthew Rocklin
Don’t log errors in sync (GH#1894) Matthew Rocklin
downgrade stale lock warning to info logging level (GH#1890) Matthew Rocklin
Fix
UnboundLocalError
forkey
(GH#1900) John KirkhamResolve deployment issues in Python 2 (GH#1905) Matthew Rocklin
Support retries and priority in Client.get method (GH#1902) Matthew Rocklin
Add additional attributes to task page if applicable (GH#1901) Matthew Rocklin
Add count method to as_completed (GH#1897) Matthew Rocklin
Extend default timeout to 10s (GH#1904) Matthew Rocklin
1.21.5 - 2018-03-31¶
Increase default allowable tick time to 3s (GH#1854) Matthew Rocklin
Handle errant workers when another worker has data (GH#1853) Matthew Rocklin
Close multiprocessing queue in Nanny to reduce open file descriptors (GH#1862) Matthew Rocklin
Extend nanny started timeout to 30s, make configurable (GH#1865) Matthew Rocklin
Comment out the default config file (GH#1871) Matthew Rocklin
Update to fix bokeh 0.12.15 update errors (GH#1872) Matthew Rocklin
Downgrade Event Loop unresponsive warning to INFO level (GH#1870) Matthew Rocklin
Add fifo timeout to control priority generation (GH#1828) Matthew Rocklin
Add retire_workers API to Client (GH#1876) Matthew Rocklin
Catch NoSuchProcess error in Nanny.memory_monitor (GH#1877) Matthew Rocklin
Add uid to nanny queue communitcations (GH#1880) Matthew Rocklin
1.21.4 - 2018-03-21¶
Avoid passing bytearrays to snappy decompression (GH#1831) Matthew Rocklin
Specify IOLoop in Adaptive (GH#1841) Matthew Rocklin
Use connect-timeout config value throughout client (GH#1839) Matthew Rocklin
Support direct= keyword argument in Client.get (GH#1845) Matthew Rocklin
1.21.3 - 2018-03-08¶
Add cluster superclass and improve adaptivity (GH#1813) Matthew Rocklin
Fixup tests and support Python 2 for Tornado 5.0 (GH#1818) Matthew Rocklin
Fix bug in recreate_error when dependencies are dropped (GH#1815) Matthew Rocklin
Add worker time to live in Scheduler (GH#1811) Matthew Rocklin
Scale adaptive based on total_occupancy (GH#1807) Matthew Rocklin
Support calling compute within worker_client (GH#1814) Matthew Rocklin
Add percentage to profile plot (GH#1817) Brett Naul
Overwrite option for remote python in dask-ssh (GH#1812) Sven Kreiss
1.21.2 - 2018-03-05¶
Fix bug where we didn’t check idle/saturated when stealing (GH#1801) Matthew Rocklin
Fix bug where client was noisy when scheduler closed unexpectedly (GH#1806) Matthew Rocklin
Use string-based timedeltas (like
'500 ms'
) everywhere (GH#1804) Matthew RocklinKeep logs in scheduler and worker even if silenced (GH#1803) Matthew Rocklin
Support minimum, maximum, wait_count keywords in Adaptive (GH#1797) Jacob Tomlinson and Matthew Rocklin
Support async protocols for LocalCluster, replace start= with asynchronous= (GH#1798) Matthew Rocklin
Avoid restarting workers when nanny waits on scheduler (GH#1793) Matthew Rocklin
Use
IOStream.read_into()
when available (GH#1477) Antoine PitrouReduce LocalCluster logging threshold from CRITICAL to WARN (GH#1785) Andy Jones
Add futures_of to API docs (GH#1783) John Kirkham
Make diagnostics link in client configurable (GH#1810) Matthew Rocklin
1.21.1 - 2018-02-22¶
Fixed an uncaught exception in
distributed.joblib
with aLocalCluster
using only threads (GH#1775) Tom AugspurgerFormat bytes in info worker page (GH#1752) Matthew Rocklin
Add pass-through arguments for scheduler/worker –preload modules. (GH#1634) Alexander Ford
Use new LZ4 API (GH#1757) Thrasibule
Replace dask.optimize with dask.optimization (GH#1754) Matthew Rocklin
Add graph layout engine and bokeh plot (GH#1756) Matthew Rocklin
Only expand name with –nprocs if name exists (GH#1776) Matthew Rocklin
specify IOLoop for stealing PeriodicCallback (GH#1777) Matthew Rocklin
Fixed distributed.joblib with no processes Tom Augspurger
Use set.discard to avoid KeyErrors in stealing (GH#1766) Matthew Rocklin
Avoid KeyError when task has been released during steal (GH#1765) Matthew Rocklin
Add versions routes to avoid the use of run in Client.get_versions (GH#1773) Matthew Rocklin
Add write_scheduler_file to Client (GH#1778) Joe Hamman
Default host to tls:// if tls information provided (GH#1780) Matthew Rocklin
1.21.0 - 2018-02-09¶
Refactor scheduler to use TaskState objects rather than dictionaries (GH#1594) Antoine Pitrou
Plot CPU fraction of total in workers page (GH#1624) Matthew Rocklin
Use thread CPU time in Throttled GC (GH#1625) Antoine Pitrou
Fix bug with
memory_limit=None
(GH#1639) Matthew RocklinAdd futures_of to top level api (GH#1646) Matthew Rocklin
Warn on serializing large data in Client (GH#1636) Matthew Rocklin
Fix intermittent windows failure when removing lock file (GH#1652) Antoine Pitrou
Add diagnosis and logging of poor GC Behavior (GH#1635) Antoine Pitrou
Add client-scheduler heartbeats (GH#1657) Matthew Rocklin
Return dictionary of worker info in
retire_workers
(GH#1659) Matthew RocklinEnsure dumps_function works with unhashable functions (GH#1662) Matthew Rocklin
Collect client name ids rom client-name config variable (GH#1664) Matthew Rocklin
Allow simultaneous use of –name and –nprocs in dask-worker (GH#1665) Matthew Rocklin
Add support for grouped adaptive scaling and adaptive behavior overrides (GH#1632) Alexander Ford
Share scheduler RPC between worker and client (GH#1673) Matthew Rocklin
Improve documentation for get_client and dask.compute examples (GH#1638) Scott Sievert
Support DASK_SCHEDULER_ADDRESS environment variable in worker (GH#1680) Matthew Rocklin
Support tuple-keys in retries (GH#1681) Matthew Rocklin
Use relative links in bokeh dashboard (GH#1682) Matthew Rocklin
Make message log length configurable, default to zero (GH#1691) Matthew Rocklin
Deprecate
Client.shutdown
(GH#1699) Matthew RocklinAdd warning in configuration docs to install pyyaml (GH#1701) Cornelius Riemenschneider
Handle nested parallelism in distributed.joblib (GH#1705) Tom Augspurger
Don’t wait for Worker.executor to shutdown cleanly when restarting process (GH#1708) Matthew Rocklin
Add support for user defined priorities (GH#1651) Matthew Rocklin
Catch and log OSErrors around worker lock files (GH#1714) Matthew Rocklin
Remove worker prioritization. Coincides with changes to dask.order (GH#1730) Matthew Rocklin
Use process-measured memory rather than nbytes in Bokeh dashboard (GH#1737) Matthew Rocklin
Enable serialization of Locks (GH#1738) Matthew Rocklin
Support Tornado 5 beta (GH#1735) Matthew Rocklin
Cleanup remote_magic client cache after tests (GH#1743) Min RK
Allow service ports to be specified as (host, port) (GH#1744) Bruce Merry
1.20.2 - 2017-12-07¶
Clear deque handlers after each test (GH#1586) Antoine Pitrou
Handle deserialization in FutureState.set_error (GH#1592) Matthew Rocklin
Add process leak checker to tests (GH#1596) Antoine Pitrou
Customize process title for subprocess (GH#1590) Antoine Pitrou
Make linting a separate CI job (GH#1599) Antoine Pitrou
Fix error from get_client() with no global client (GH#1595) Daniel Li
Remove Worker.host_health, correct WorkerTable metrics (GH#1600) Matthew Rocklin
Don’t mark tasks as suspicious when retire_workers called. Addresses (GH#1607) Russ Bubley
Do not include processing workers in workers_to_close (GH#1609) Russ Bubley
Disallow simultaneous scale up and down in Adaptive (GH#1608) Russ Bubley
Parse bytestrings in –memory-limit (GH#1615) Matthew Rocklin
Use environment variable for scheduler address if present (GH#1610) Matthew Rocklin
Fix deprecation warning from logger.warn (GH#1616) Brett Naul
1.20.1 - 2017-11-26¶
Wrap
import ssl
statements with try-except block for ssl-crippled environments, (GH#1570) Xander JohnsonSupport zero memory-limit in Nanny (GH#1571) Matthew Rocklin
Avoid PeriodicCallback double starts (GH#1573) Matthew Rocklin
Add disposable workspace facility (GH#1543) Antoine Pitrou
Use format_time in task_stream plots (GH#1575) Matthew Rocklin
Avoid delayed finalize calls in compute (GH#1577) Matthew Rocklin
Doc fix about secede (GH#1583) Scott Sievert
Add tracemalloc option when tracking test leaks (GH#1585) Antoine Pitrou
Add JSON routes to Bokeh server (GH#1584) Matthew Rocklin
Handle exceptions cleanly in Variables and Queues (GH#1580) Matthew Rocklin
1.20.0 - 2017-11-17¶
Drop use of pandas.msgpack (GH#1473) Matthew Rocklin
Add methods to get/set scheduler metadata Matthew Rocklin
Add distributed lock Matthew Rocklin
Add reschedule exception for worker tasks Matthew Rocklin
Fix
nbytes()
forbytearrays
Matthew RocklinCapture scheduler and worker logs Matthew Rocklin
Garbage collect after data eviction on high worker memory usage (GH#1488) Olivier Grisel
Add scheduler HTML routes to bokeh server (GH#1478) (GH#1514) Matthew Rocklin
Add pytest plugin to test for resource leaks (GH#1499) Antoine Pitrou
Improve documentation for scheduler states (GH#1498) Antoine Pitrou
Correct warn_if_longer timeout in ThrottledGC (GH#1496) Fabian Keller
Catch race condition in as_completed on cancelled futures (GH#1507) Matthew Rocklin
Transactional work stealing (GH#1489) (GH#1528) Matthew Rocklin
Avoid forkserver in PyPy (GH#1509) Matthew Rocklin
Add dict access to get/set datasets (GH#1508) Mike DePalatis
Support Tornado 5 (GH#1509) (GH#1512) (GH#1518) (GH#1534) Antoine Pitrou
Use new Dask collections interface (GH#1513) Matthew Rocklin
Add nanny flag to dask-mpi Matthew Rocklin
Remove JSON-based HTTP servers Matthew Rocklin
Avoid doing I/O in repr/str (GH#1536) Matthew Rocklin
Fix URL for MPI4Py project (GH#1546) Ian Hopkinson
Allow automatic retries of a failed task (GH#1524) Antoine Pitrou
Clean and accelerate tests (GH#1548) (GH#1549) (GH#1552) (GH#1553) (GH#1560) (GH#1564) Antoine Pitrou
Move HDFS functionality to the hdfs3 library (GH#1561) Jim Crist
Fix bug when using events page with no events (GH#1562) @rbubley
Improve diagnostic naming of tasks within tuples (GH#1566) Kelvyn Yang
1.19.3 - 2017-10-16¶
1.19.2 - 2017-10-06¶
as_completed doesn’t block on cancelled futures (GH#1436)
Notify waiting threads/coroutines on cancellation (GH#1438)
Set Future(inform=True) as default (GH#1437)
Rename Scheduler.transition_story to story (GH#1445)
Future uses default client by default (GH#1449)
Add keys= keyword to Client.call_stack (GH#1446)
Add get_current_task to worker (GH#1444)
Ensure that Client remains asynchornous before ioloop starts (GH#1452)
Remove “click for worker page” in bokeh plot (GH#1453)
Add Client.current() (GH#1450)
Clean handling of restart timeouts (GH#1442)
1.19.1 - September 25th, 2017¶
1.19.0 - September 24th, 2017¶
Avoid storing messages in message log (GH#1361)
fileConfig does not disable existing loggers (GH#1380)
Offload upload_file disk I/O to separate thread (GH#1383)
Add missing SSLContext (GH#1385)
Collect worker thread information from sys._curent_frames (GH#1387)
Add nanny timeout (GH#1395)
Restart worker if memory use goes above 95% (GH#1397)
Track workers memory use with psutil (GH#1398)
Track scheduler delay times in workers (GH#1400)
Add time slider to profile plot (GH#1403)
Change memory-limit keyword to refer to maximum number of bytes (GH#1405)
Add
cancel(force=)
keyword (GH#1408)
1.18.2 - September 2nd, 2017¶
1.18.1 - August 25th, 2017¶
Clean up forgotten keys in fire-and-forget workloads (GH#1250)
Handle missing extensions (GH#1263)
Allow recreate_exception on persisted collections (GH#1253)
Add asynchronous= keyword to blocking client methods (GH#1272)
Restrict to horizontal panning in bokeh plots (GH#1274)
Rename client.shutdown to client.close (GH#1275)
Avoid blocking on event loop (GH#1270)
Avoid cloudpickle errors for Client.get_versions (GH#1279)
Yield on Tornado IOStream.write futures (GH#1289)
Assume async behavior if inside a sync statement (GH#1284)
Avoid error messages on closing (GH#1297), (GH#1296) (GH#1318) (GH#1319)
Add timeout= keyword to get_client (GH#1290)
Respect timeouts when restarting (GH#1304)
Clean file descriptor and memory leaks in tests (GH#1317)
Deprecate Executor (GH#1302)
Add timeout to ThreadPoolExecutor.shutdown (GH#1330)
Clean up AsyncProcess handling (GH#1324)
Allow unicode keys in Python 2 scheduler (GH#1328)
Avoid leaking stolen data (GH#1326)
Improve error handling on failed nanny starts (GH#1337), (GH#1331)
Make Adaptive more flexible
Support
--contact-address
and--listen-address
in worker (GH#1278)Remove old dworker, dscheduler executables (GH#1355)
Exit workers if nanny process fails (GH#1345)
Auto pep8 and flake (GH#1353)
1.18.0 - July 8th, 2017¶
Add get_client, secede functions, refactor worker-client relationship (GH#1201)
Allow logging configuraiton using logging.dictConfig() (GH#1206) (GH#1211)
Offload serialization and deserialization to separate thread (GH#1218)
Support fire-and-forget tasks (GH#1221)
Support bytestrings as keys (for Julia) (GH#1234)
Resolve testing corner-cases (GH#1236), (GH#1237), (GH#1240), (GH#1241), (GH#1242), (GH#1244)
Automatic use of scatter/gather(direct=True) in more cases (GH#1239)
1.17.1 - June 14th, 2017¶
1.17.0 - June 9th, 2017¶
Reevaluate worker occupancy periodically during scheduler downtime (GH#1038) (GH#1101)
Add
AioClient
asyncio-compatible client API (GH#1029) (GH#1092) (GH#1099)Update Keras serializer (GH#1067)
Always create new worker directory when passed
--local-directory
(GH#1079)Support pre-scattering data when using joblib frontent (GH#1022)
Make workers more robust to failure of
sizeof
function (GH#1108) and writing to disk (GH#1096)Add
is_empty
andupdate
methods toas_completed
(GH#1113)Remove
_get
coroutine and replace withget(..., sync=False)
(GH#1109)Improve API compatibility with async/await syntax (GH#1115) (GH#1124)
Add distributed Queues (GH#1117) and shared Variables (GH#1128) to enable inter-client coordination
Support direct client-to-worker scattering and gathering (GH#1130) as well as performance enhancements when scattering data
Style improvements for bokeh web dashboards (GH#1126) (GH#1141) as well as a removal of the external bokeh process
HTML reprs for Future and Client objects (GH#1136)
Support nested collections in client.compute (GH#1144)
Use normal client API in asynchronous mode (GH#1152)
Remove old distributed.collections submodule (GH#1153)
1.16.3 - May 5th, 2017¶
1.16.2 - May 3rd, 2017¶
Support
async with Client
syntax (GH#1053)Use internal bokeh server for default diagnostics server (GH#1047)
Improve styling of bokeh plots when empty (GH#1046) (GH#1037)
Support efficient serialization for sparse arrays (GH#1040)
Prioritize newly arrived work in worker (GH#1035)
Prescatter data with joblib backend (GH#1022)
Make client.restart more robust to worker failure (GH#1018)
Support preloading a module or script in dask-worker or dask-scheduler processes (GH#1016)
Specify network interface in command line interface (GH#1007)
Client.scatter supports a single element (GH#1003)
Use blosc compression on all memoryviews passing through comms (GH#998)
Add concurrent.futures-compatible Executor (GH#997)
Add as_completed.batches method and return results (GH#994) (GH#971)
Allow worker_clients to optionally stay within the thread pool (GH#993)
Add bytes-stored and tasks-processing diagnostic histograms (GH#990)
Run supports non-msgpack-serializable results (GH#965)
1.16.1 - March 22nd, 2017¶
Use inproc transport in LocalCluster (GH#919)
Add structured and queryable cluster event logs (GH#922)
Use connection pool for inter-worker communication (GH#935)
Robustly shut down spawned worker processes at shutdown (GH#928)
Worker death timeout (GH#940)
More visual reporting of exceptions in progressbar (GH#941)
Render disk and serialization events to task stream visual (GH#943)
Support async for / await protocol (GH#952)
Ensure random generators are re-seeded in worker processes (GH#953)
Upload sourcecode as zip module (GH#886)
Replay remote exceptions in local process (GH#894)
1.16.0 - February 24th, 2017¶
First come first served priorities on client submissions (GH#840)
Can specify Bokeh internal ports (GH#850)
Allow stolen tasks to return from either worker (GH#853), (GH#875)
Add worker resource constraints during execution (GH#857)
Send small data through Channels (GH#858)
Better estimates for SciPy sparse matrix memory costs (GH#863)
Avoid stealing long running tasks (GH#873)
Maintain fortran ordering of NumPy arrays (GH#876)
Add
--scheduler-file
keyword to dask-scheduler (GH#877)Add serializer for Keras models (GH#878)
Support uploading modules from zip files (GH#886)
Improve titles of Bokeh dashboards (GH#895)
1.15.2 - January 27th, 2017¶
Fix a bug where arrays with large dtypes or shapes were being improperly compressed (GH#830 GH#832 GH#833)
Extend
as_completed
to accept new futures during iteration (GH#829)Add
--nohost
keyword todask-ssh
startup utility (GH#827)Support scheduler shutdown of remote workers, useful for adaptive clusters (:pr: 811 GH#816 GH#821)
Add
Client.run_on_scheduler
method for running debug functions on the scheduler (GH#808)
1.15.1 - January 11th, 2017¶
Make compatibile with Bokeh 0.12.4 (GH#803)
Avoid compressing arrays if not helpful (GH#777)
Add –local-directory keyword to worker (GH#788)
Enable workers to arrive to the cluster with their own data. Useful if a worker leaves and comes back (GH#785)
Resolve thread safety bug when using local_client (GH#802)
Resolve scheduling issues in worker (GH#804)
1.15.0 - January 2nd, 2017¶
Major Worker refactor (GH#704)
Major Scheduler refactor (GH#717) (GH#722) (GH#724) (GH#742) (GH#743
Add
check
(default isFalse
) option toClient.get_versions
to raise if the versions don’t match on client, scheduler & workers (GH#664)Future.add_done_callback
executes in separate thread (GH#656)Clean up numpy serialization (GH#670)
Support serialization of Tornado v4.5 coroutines (GH#673)
Use CPickle instead of Pickle in Python 2 (GH#684)
Use Forkserver rather than Fork on Unix in Python 3 (GH#687)
Support abstract resources for per-task constraints (GH#694) (GH#720) (GH#737)
Add TCP timeouts (GH#697)
Add embedded Bokeh server to workers (GH#709) (GH#713) (GH#738)
Add embedded Bokeh server to scheduler (GH#724) (GH#736) (GH#738)
Add more precise timers for Windows (GH#713)
Add Versioneer (GH#715)
Improve load balancing and work stealing (GH#747) (GH#754) (GH#757)
Run Tornado coroutines on workers
Avoid slow sizeof call on Pandas dataframes (GH#758)
1.14.3 - November 13th, 2016¶
1.14.2 - November 11th, 2016¶
1.14.0 - November 3rd, 2016¶
Add
Client.get_versions()
function to return software and package information from the scheduler, workers, and client (GH#595)Improved windows support (GH#577) (GH#590) (GH#583) (GH#597)
Clean up rpc objects explicitly (GH#584)
Normalize collections against known futures (GH#587)
Add key= keyword to map to specify keynames (GH#589)
Custom data serialization (GH#606)
Allow user-supplied Executor in Worker (GH#609)
Pass Worker kwargs through LocalCluster
1.13.3 - October 15th, 2016¶
Schedulers can retire workers cleanly
Add
Future.add_done_callback
forconcurrent.futures
compatibilityUpdate web interface to be consistent with Bokeh 0.12.3
Close streams explicitly, avoiding race conditions and supporting more robust restarts on Windows.
Improved shuffled performance for dask.dataframe
Add adaptive allocation cluster manager
Reduce administrative overhead when dealing with many workers
dask-ssh --log-directory .
no longer errorsMicroperformance tuning for the scheduler
1.13.2¶
Revert dask_worker to use fork rather than subprocess by default
Scatter retains type information
Bokeh always uses subprocess rather than spawn
1.13.1¶
Fix critical Windows error with dask_worker executable
1.13.0¶
Rename Executor to Client (GH#492)
Add
--memory-limit
option todask-worker
, enabling spill-to-disk behavior when running out of memory (GH#485)Add
--pid-file
option to dask-worker and--dask-scheduler
(GH#496)Add
upload_environment
function to distribute conda environments. This is experimental, undocumented, and may change without notice. (GH#494)Add
workers=
keyword argument toClient.compute
andClient.persist
, supporting location-restricted workloads with Dask collections (GH#484)Add
upload_environment
function to distribute conda environments. This is experimental, undocumented, and may change without notice. (GH#494)Add optional
dask_worker=
keyword toclient.run
functions that gets provided the worker or nanny objectAdd
nanny=False
keyword toClient.run
, allowing for the execution of arbitrary functions on the nannies as well as normal workers
1.12.2¶
This release adds some new features and removes dead code
Publish and share datasets on the scheduler between many clients (GH#453). See Publish Datasets.
Launch tasks from other tasks (experimental) (GH#471). See Launch Tasks from Tasks.
Remove unused code, notably the
Center
object and older client functions (GH#478)Executor()
andLocalCluster()
is now robust to Bokeh’s absence (GH#481)Removed s3fs and boto3 from requirements. These have moved to Dask.
1.12.1¶
This release is largely a bugfix release, recovering from the previous large refactor.
- Fixes from previous refactor
Ensure idempotence across clients
Stress test losing scattered data permanently
- IPython fixes
Add
start_ipython_scheduler
method to ExecutorAdd
%remote
magic for workersClean up code and tests
Pool connects to maintain reuse and reduce number of open file handles
Re-implement work stealing algorithm
Support cancellation of tuple keys, such as occur in dask.arrays
Start synchronizing against worker data that may be superfluous
- Improve bokeh plots styling
Add memory plot tracking number of bytes
Make the progress bars more compact and align colors
Add workers/ page with workers table, stacks/processing plot, and memory
Add this release notes document
1.12.0¶
This release was largely a refactoring release. Internals were changed significantly without many new features.
Major refactor of the scheduler to use transitions system
Tweak protocol to traverse down complex messages in search of large bytestrings
Add dask-submit and dask-remote
Refactor HDFS writing to align with changes in the dask library
Executor reconnects to scheduler on broken connection or failed scheduler
Support sklearn.external.joblib as well as normal joblib