Revisions of python-distributed

Matej Cepl's avatar Matej Cepl (mcepl) committed (revision 108)
Make cycle
Matej Cepl's avatar Matej Cepl (mcepl) committed (revision 107)
Make cycle
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 960175 from Matej Cepl's avatar Matej Cepl (mcepl) (revision 106)
- Update to 2022.02.1:
    Add the ability for Client to run preload code
    Optionally use NumPy to allocate buffers
    Add git hash to distributed-impl version
    Immediately raise exception when trying to connect to a closed cluster
    Lazily get dask version information
    Remove the requirements to add comm to every handler
    Raise on unclosed comms in check_instances
    Constrained spill
    Remove redundant str() conversions
    Cluster dump now excludes run_spec by default
    Dump more objects with dump_cluster_state
    Do not connect to any sockets on import
    Avoid deadlock when two tasks are concurrently waiting for an unresolved ActorFuture
    Drop Python 3.7
    Remove support for UCX < 1.11.1
    Document and test spill->target hysteresis cycle
    Fix flaky test_remove_replicas_while_computing
    Fix time based test_assert_worker_story_malformed_story parameterize
    Remove xfail from test_no_unnecessary_imports_on_worker
    Start building pre-releases with cythonized scheduler
    Do not mark tests xfail if they don't come up in time
    Use gen_cluster where possible in test_dask_worker.py
    Generate junit report when pytest-timeout kills pytest
    Decrease timeout-minutes for GHA jobs
    Bump pre-release version to be greater than stable releases
    Do not run schedule jobs on forks
    Remove pillow<9 pin in CI
    Show scheduled test runs in report
    Add obvious exclusions with pragma statement
Matej Cepl's avatar Matej Cepl (mcepl) committed (revision 105)
- Add 5709-avoid-deadlock-ActorFuture.patch to avoid deadlock in
  ActorFuture (gh#dask/distributed#5709).
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 950288 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 104)
- Update to version 2022.1.1
  * P2P shuffle skeleton
  * Fix <Task pending name='...' coro=<Client._handle_report()>
  * Add distributed.client.security-loader config
  * Avoid Client._handle_report cancelling itself on Client._close
  * Paused workers shouldn't steal tasks
  * Add option for timestamps from output of Node.get_logs
  * Don't use time.time() or IOLoop.time()
  * Raise plugin exceptions on Worker.start()
  * Fixing docstrings
  * Fix typo in Client.run docstring
  * Update client.py docstrings
  * Skip shuffle tests if pandas / dask.dataframe not installed
  * Improve test coverage
  * Test report improvements
  * P2P shuffle: ignore row order in tests
  * Fix flaky test_no_reconnect[--no-nanny]
  * Pin coverage to 6.2
  * Check for new name of timeouts artifact and be more fault
    tolerant
  * Revisit rebalance unit tests
  * Update comment in rearrange_by_column_p2p
  * Update gpuCI RAPIDS_VER to 22.04
  * Fix groupby test after meta requirements got stricter in Dask
    PR#8563
  * Fix flaky test_close_gracefully and test_lifetime
  * Fix flaky test_workspace_concurrency
  * Fix flaky test_shuffle_extension.py::test_get_partition
  * Fix flaky test_dump_cluster_unresponsive_remote_worker
  * Dump cluster state on all test failures
  * Update license format
  * Fix flaky test_drop_with_paused_workers_with_running_tasks_3_4
  * Do not raise an exception if the GitHub token cannot be found

(Resubmit for the noclean flag)
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 949113 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 103)
Not required to forward to Factory, this is a revert
Dirk Mueller's avatar Dirk Mueller (dirkmueller) committed (revision 102)
- add distributed-fix-python310.patch to fix build with python 3.10
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 948001 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 101)
- Update to version 2022.1.0
  * full changelog at
    https://distributed.readthedocs.io/en/latest/changelog.html
  * New Features:
    - Task group stacked area chart (GH#5320) Ian Rose
    - Support configuring TLS min/max version (GH#5594) Jim
      Crist-Harif
    - Use asyncio for TCP/TLS comms (GH#5450) Jim Crist-Harif
- Enhancement release notes for 2021.12.0
  * Support pytest fixures and parametrize with gen_test (GH#5532)
    Fábio Rosado
  * Allow idempotent scheduler plugins to be registered via the RPC
    (GH#5545) Jacob Tomlinson
  * AMM logging (GH#5530) crusaderky
  * Raise error if asyncssh isn’t installed when using SSHCluster
    (GH#5535) Fábio Rosado
  * Allow None in UCX configuration schema (GH#5534) Fábio Rosado
  * Add distributed.comm.ucx.create-cuda-context config (GH#5526)
    Peter Andreas Entschev
- Security release note for 2021.10.0:
  * This release fixed a potential security vulnerability relating
    to single-machine Dask clusters. Clusters started with
    dask.distributed.LocalCluster or dask.distributed.Client()
    (which defaults to using LocalCluster) would mistakenly
    configure their respective Dask workers to listen on external
    interfaces (typically with a randomly selected high port)
    rather than only on localhost. A Dask cluster created using
    this method AND running on a machine that has these ports
    exposed could be used by a sophisticated attacker to enable
    remote code execution. Users running on machines with standard
    firewalls in place should not be affected. This vulnerability
    is documented in CVE-2021-42343, and is fixed in this release
    (GH#5427). Thanks to Jean-Pierre van Riel for discovering and
    reporting the issue.
- Skip python310: Not supported yet -- gh#dask/distributed#5350
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 921004 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 100)
- Update to version 2021.9.1 
  * Revert AMM ReduceReplicas and parallel AMMs updates
  * Run multiple AMMs in parallel
  * AMM ReduceReplicas to iterate only on replicated tasks
  * Add type annotations to various functions within
    distributed.worker
  * Mark test_ucx_config_w_env_var flaky on UCX < 1.11
  * Warn if CUDA context is created on incorrect device in UCX
  * Remove redundant timeouts from test_client
  * Allow Client to subscribe to events // Remote printing and
    warning
  * Test pickle protocols 4 & 5
  * Fix-up test_pickle_empty
  * Increase timeout for
    test_worker_reconnects_mid_compute_multiple_states_on_scheduler
  * Add synced dict between cluster and scheduler to store cluster
    info
  * Update test_sub_submit_priority
  * Revert "Add test setup fixture
  * Fix flaky test_worker_reconnects_mid_compute
  * Use gen_test in test_adaptive
  * Increase worker.suspicious_counter threshold
  * Active Memory Manager framework + discard excess replicas
  * Add test setup fixture
- Release version 2021.9.0
  * Fix add_plugin warnings 
  * Add list around iterator in handle_missing_dep 
  * Jupyter-client 7 compatiblity 
  * Replace atop with blockwise
  * Add pytest color to CI
  * Fix test_map and others
  * Use name argument with Scheduler.remove_plugin calls
  * Downgrade to jupyter_client 6
  * Migrate Security HTML repr to Jinja2
  * Migrate ProcessInterface HTML repr to Jinja2
  * Add support for diskless machines to system monitor
  * Avoid during-iteration scheduler plugin changes
  * Remove GroupProgress scheduler plugin
  * Properly check for ipv6 availability
  * Improved IPv6 dask-worker support
  * Overwrite worker plugins
  * Refactor scheduler plugins; store in a dictionary
  * Fix "then" -> "than" typo in docs
  * Fix typo (remove extra verb "creates") in docs
  * Fix "fractiom" -> "fraction" typo in docstring
  * Fix "schedulers" -> "scheduler" typo in docs
  * Use non-histogram plots up to 100 workers
- Release 2021.08.1
  * Rename plots to fit in the labextension
  * Log messages for CommClosedError now includes information
    about remote address
  * Add target='_blank' for redirects of dashboard link
  * Update computation code retrieval logic
  * Minor polish on cfexecutor
  * Use development version of dask in gpuCI build
  * Use upstream dask.widgets
  * Fix flaky test_worker_reconnects_mid_compute
  * Update WorkerPlugin docstring about usage of TaskState objects
  * Worker Network Timeseries
  * Add HTML Repr for ProcessInterface class and all its subclasses
  * Fix an issue where a reconnecting worker could cause an
    invalid transition
  * Minor fixes for cfexecutor
  * Add HTML Repr for Security class
  * Fix performance report sizing issue
  * Drop RMM compatibility code from RAPIDS < 0.11
- Release 2021.08.0
  * Include addresses in closed comm repr
  * Test nanny.environ precedence
  * Migrating HTML reprs to jinja2
  * Fix test_process_executor_kills_process flakyness
  * Remove urllib3 as a dependency downloading preloads
  * Download preload urls in the Preload constructor
  * Avoid recursion error in profile.merge
  * Add text exceptions to the Scheduler
  * Use kwarg for Theme filename
  * Add a .git-ignore-revs file
  * Replace not not with bool()
  * Resolve deadlock cause by transition error after fetching
    dependency
  * Set z-index of data-table lower
  * Add no-worker - memory transition to scheduler
  * Deprecate worker plugin overwrite policy
  * Fix flaky tests in CI
  * Instructions for jemalloc with brew on macOS
  * Bump RAPIDS_VER to 21.10
  * Tweak verbiage around async functions
  * Use Python 3 super() calls
  * Support asynchronous tasks
  * Rename total comm bytes and provide doc string
  * Add GPU executor if GPU is present
  * Fix RMM and UCX tests
  * Remove excessive timeout of
    test_steal_during_task_deserialization
  * Add gpuCI build script
  * Demote Worker.ensure_computing to function
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 910741 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 99)
- Update to version 2021.7.2
  * Fix a deadlock connected to task stealing and task
    deserialization
  * Include maximum shard size in second to_frames method
  * Minor dashboard style updates
  * Cap maximum shard size at the size of an integer
  * Document automatic MALLOC_TRIM_THRESHOLD_ environment variable
  * Mark ucx-py tests for GPU
  * Update individual profile plot sizing
  * Handle NVMLError_Unknown in NVML diagnostics
  * Unit tests to use a random port for the dashboard
  * Ensure worker reconnect registers existing tasks properly
  * Halve CI runtime!
  * Add NannyPlugins
  * Add WorkerNetworkBandwidth chart to dashboard
  * Set nanny environment variables in config
  * Read smaller frames to workaround OpenSSL bug
  * Move UCX/RMM config variables to Distributed namespace
  * Allow ws(s) messages greater than 10Mb
  * Short-circuit root-ish check for many deps
-Release 2021.07.1
  * Remove experimental feature warning from actors docs
  * Keep dependents in worker dependency if TS is still known
  * Add Scheduler.set_restrictions
  * Make Actor futures awaitable and work with as_completed
  * Simplify test_secede_balances
  * Computation class
  * Some light dashboard cleanup
  * Don't package tests
  * Add pytest marker for GPU tests
  * Actor: don't hold key references on workers
  * Collapse nav to hamburger sooner
  * Verify that actors survive pickling
  * Reenable UCX-Py tests that used to segfault
  * Better support ProcessPoolExecutors
  * Simplify test_worker_heartbeat_after_cancel
  * Avoid property validation in Bokeh
  * Reduce default websocket frame size and make configurable
  * Disable pytest-timeout SIGALARM on MacOS
  * rebalance() resilience to computations
  * Improve CI stability
  * Ensure heartbeats after cancelation do not raise KeyError s
  * Add more useful exception message on TLS cert mismatch
  * Add bokeh mode parameter to performance reports
- Use the GitHub tarball because the PyPI sdist does to provide the
  tests anymore
  * Remove extra conftest.py source
- Drop distributed-pr5022-improve_ci.patch merged upstream
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 907354 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 98)
- Update to version 2021.7.0
  * Fix Nbytes jitter - less expensive
  * Use native GH actions cancel feature
  * Don't require workers to report to scheduler if scheduler
    shuts down
  * Add pandas to the list of checked packages for client.
    get_versions()
  * Move worker preload before scheduler address is set
  * Fix flaky test_oversubscribing_leases
  * Update scheduling policy docs for #4967
  * Add echo handler to Server class
  * Also include pngs when bundling package
  * Remove duplicated dashboard panes
  * Fix worker memory dashboard flickering
  * Tabs on bottom left corner on dashboard
  * Rename nbytes widgets
  * Co-assign root-ish tasks
  * OSError tweaks
  * Update imports to cudf.testing._utils
  * Ensure shuffle split default durations uses proper prefix
  * Follow up pyupgrade formatting
  * Rename plot dropdown
  * Pyupgrade
  * Misc Sphinx tweaks
  * No longer hold dependencies of erred tasks in memory
  * Add maximum shard size to config
  * Ensure shuffle split operations are blacklisted from work
    stealing
  * Add dropdown menu to access individual plots
  * Edited the path to scheduler.py
  * Task Group Graph Visualization
  * Remove more internal references to deprecated utilities
  * Restructure nbytes hover
  * Except more errors in pynvml.nvmlInit()
  * Add occupancy as individual plot
  * Deprecate utilities which have moved to dask
  * Ensure connectionpool does not leave comms if closed mid
    connect
  * Add support for registering scheduler plugins from Client
  * Stealing dashboard fixes
  * Allow requirements verification to be ignored when loading
    backends from entrypoints
  * Add Log and Logs to API docs
  * Support fixtures and pytest.mark.parametrize with gen_cluster
- Release 2021.06.2
  * Revert refactor to utils.Log[s] and Cluster.get_logs
  * Use deprecation utility from Dask
  * Add transition counter to Scheduler
  * Remove nbytes_in_memory
- Release 2021.06.1
  * Fix deadlock in handle_missing_dep if additional replicas are
    available
  * Add configuration to enable/disable NVML diagnostics
  * Add scheduler log tab to performance reports
  * Add HTML repr to scheduler_info and incorporate into client
    and cluster reprs
  * Fix error state typo
  * Allow actor exceptions to propagate
  * Remove importing apply from dask.compatibility
  * Use more informative default name for WorkerPlugin s
  * Removed unused utility functions
  * Locally rerun successfully completed futures
  * Forget erred tasks and fix deadlocks on worker
  * Handle HTTPClientError in websocket connector
  * Update dask_cuda usage in SSHCluster docstring
  * Remove tests for process_time and thread_time
  * Flake8 config cleanup
  * Don't strip scheduler protocol when determining host
  * Add more documentation on memory management
  * Add range_query tests to NVML test suite
  * No longer cancel result future in async process when using
    timeouts
- Release 2021.06.0
  * Multiple worker executors
  * Ensure PyNVML works correctly when installed with no GPUs
  * Show more in test summary
  * Move SystemMonitor s GPU initialization back to constructor
  * Mark test_server_comms_mark_active_handlers with pytest.mark.asyncio
  * Who has has what html reprs v2
  * O(1) rebalance
  * Ensure repr and eq for cluster always works
- Release 2021.05.1
  * Drop usage of WhoHas & WhatHas from Client
  * Ensure adaptive scaling is properly awaited and closed
  * Fix WhoHas/ HasWhat async usage
  * Add HTML reprs for Client.who_has and Client.has_what
  * Prevent accidentally starting multiple Worker s in the same
    process
  * Add system tab to performance reports
  * Let servers close faster if there are no active handlers
  * Fix UCX scrub config logging
  * Ensure worker clients are closed
  * Fix warning for attribute error when deleting a client
  * Ensure exceptions are raised if workers are incorrectly started
  * Update handling of UCX exceptions on endpoint closing
  * Ensure busy workloads properly look up who_has
  * Check distributed.scheduler.pickle in Scheduler.run_function
  * Add performance_report to API docs
  * Use dict _workers_dv in unordered use cases
  * Bump pre-commit hook versions
  * Do not mindlessly spawn workers when no memory limit is set
  * test_memory to use gen_cluster
  * Increase timeout of gen_test to 30s
- Work on the very flaky testsuite:
  * Add missing conftest.py not packaged on PyPI
  * Add distributed-pr5022-improve_ci.patch in the hope for better
    stability -- gh#dask/distributed#5022
  * Do not use pytest-xdist
- Add Cython as runtime dep because the scheduler checks the
  presence
buildservice-autocommit accepted request 894420 from Matej Cepl's avatar Matej Cepl (mcepl) (revision 97)
baserev update by copy to link target
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 894365 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 96)
- update to version 2021.5.0
  * Merge global annotations on the client (GH#4691) Mads R. B.
    Kristensen
  * Add support for click 8 (GH#4810) James Bourbeau
  * Add HTML reprs to some scheduler classes (GH#4795) James
    Bourbeau
  * Use JupyterLab theme variables (GH#4796) Ian Rose
  * Allow the dashboard to run on multiple ports (GH#4786) Jacob
    Tomlinson
  * Remove release_dep from WorkerPlugin API (GH#4791) James
    Bourbeau
  * Support for UCX 1.10+ (GH#4787) Peter Andreas Entschev
  * Reduce complexity of test_gather_allow_worker_reconnect
    (GH#4739) Florian Jetter
  * Fix doctests in utils.py (GH#4785) Jacob Tomlinson
  * Ensure deps are actually logged in worker (GH#4753) Florian
    Jetter
  * Add stacklevel keyword into performance_report() to allow for
    selecting calling code to be displayed (GH#4777) Nathan
    Danielsen
  * Unregister worker plugin (GH#4748) Naty Clementi
  * Fixes some pickling issues in the Cythonized Scheduler
    (GH#4768) jakirkham
  * Improve graceful shutdown if nanny is involved (GH#4725)
    Florian Jetter
  * Update cythonization in CI (GH#4764) James Bourbeau
  * Use contextlib.nullcontext (GH#4763) James Bourbeau
  * Cython fixes for MemoryState (GH#4761) jakirkham
  * Fix errors in check_thread_leak (GH#4747) James Bourbeau
  * Handle missing key case in report_on_key (GH#4755) jakirkham
  * Drop temporary set variables s (GH#4758) jakirkham
- skip even more flaky tests
- stress that upstream wants to use dask with a matching version
  number
buildservice-autocommit accepted request 883208 from Markéta Machová's avatar Markéta Machová (mcalabkova) (revision 95)
baserev update by copy to link target
Markéta Machová's avatar Markéta Machová (mcalabkova) accepted request 882928 from Arun Persaud's avatar Arun Persaud (apersaud) (revision 94)
update to latest version
Matej Cepl's avatar Matej Cepl (mcepl) accepted request 882710 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 93)
- Disable Cythonization for 32-bit gh#dask/dask#7489
Markéta Machová's avatar Markéta Machová (mcalabkova) accepted request 882449 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 92)
- Update to 2021.3.1
  * Add standalone dashboard page for GPU usage (GH#4556) Jacob 
    Tomlinson
  * Handle stream is None case in TCP comm finalizer (GH#4631) 
    James Bourbeau
  * Include LIST_PICKLE in NumPy array serialization (GH#4632)  
    James Bourbeau
  * Rename annotation plugin in test_highlevelgraph.py (GH#4618) 
    James Bourbeau
  * UCX use nbytes instead of len (GH#4621) Mads R. B. Kristensen
  * Skip NumPy and pandas tests if not importable (GH#4563) Ben 
    Greiner
  * Remove utils.shutting_down in favor of sys.is_finalizing 
    (GH#4624) James Bourbeau
  * Handle async clients when closing (GH#4623) Matthew Rocklin
  * Drop log from remove_key_from_stealable (GH#4609) jakirkham
  * Introduce events log length config option (GH#4615) Fabian 
    Gebhart
  * Upstream config serialization and inheritance (GH#4372) Jacob 
    Tomlinson
  * Add check to scheduler creation in SpecCluster (GH#4605) Jacob 
    Tomlinson
  * Make length of events deque configurable (GH#4604) Fabian 
    Gebhart
  * Add explicit fetch state to worker TaskState (GH#4470) Gil 
    Forsyth
  * Update develop.rst (GH#4603) Florian Jetter
  * pickle_loads(): Handle empty memoryview (GH#4595) Mads R. B. 
    Kristensen
  * Switch documentation builds for PRs to readthedocs (GH#4599) 
    James Bourbeau
  * Track frame sizes along with frames (GH#4593) jakirkham
  * Add support for a list of keys when using batch_size in client.
    map (GH#4592) Sultan Orazbayev
  * If SpecCluster fails to start attempt to gracefully close out 
    again (GH#4590) Jacob Tomlinson
  * Multi-lock extension (GH#4503) Mads R. B. Kristensen
  * Update PipInstall plugin command (GH#4584) James Bourbeau
  * IPython magics: remove deprecated ioloop workarounds (GH#4530) 
    Min RK
  * Add GitHub actions workflow to cancel duplicate builds 
    (GH#4581) James Bourbeau
  * Remove outdated macOS build badge from README (GH#4576) James 
    Bourbeau
  * Dask master -> main (GH#4569) Julia Signell
  * Drop support for Python 3.6 (GH#4390) James Bourbeau
  * Add docstring for dashboard_link property (GH#4572) Doug Davis
  * Change default branch from master to main (GH#4495) Julia 
    Signell
  * Msgpack handles extract serialize (GH#4531) Mads R. B. 
    Kristensen
- Drop importorskip-numpy-tests.patch merged upstream
- Skip python36 build. Upstream dropped support for Python < 3.7
buildservice-autocommit accepted request 877823 from Dirk Mueller's avatar Dirk Mueller (dirkmueller) (revision 91)
baserev update by copy to link target
Dirk Mueller's avatar Dirk Mueller (dirkmueller) accepted request 877788 from Benjamin Greiner's avatar Benjamin Greiner (bnavigator) (revision 90)
- Update to 2021.3.0
  * This is the first release with support for Python 3.9 and the
    last release with support for Python 3.6
  * tcp.write(): cast memoryview to byte itemsize (#4555)
    Mads R. B. Kristensen
  * Refcount the thread_state.asynchronous flag (#4557) Mads
    R. B. Kristensen
  * Python 3.9 (#4460) crusaderky
  * Better bokeh defaults for dashboard (#4554) Benjamin
    Zaitlen
  * Expose system monitor dashboard as individual plot for lab
    extension (#4540) Jacob Tomlinson
  * Pass on original temp dir from nanny to worker (#4549)
    Martin Durant
  * Serialize and split (#4541) Mads R. B. Kristensen
  * Use the new HLG pack/unpack API in Dask (#4489) Mads R.
    B. Kristensen
  * Handle annotations for culled tasks (#4544) Tom
    Augspurger
  * Make sphinx autosummary and autoclass consistent (#4367)
    Casey Clements
  * Move _transition* to SchedulerState (#4545) jakirkham
  * Migrate from travis to GitHub actions (#4504) crusaderky
  * Move new_task to SchedulerState (#4527) jakirkham
  * Batch more Scheduler sends (#4526) jakirkham
  * transition_memory_released and get_nbytes() optimizations
    (#4516) jakirkham
  * Pin black pre-commit (#4533) James Bourbeau
  * Read & write all frames in one pass (#4506) jakirkham
  * Skip stream.write call for empty frames (#4507) jakirkham
  * Prepend frame metadata header (#4505) jakirkham
  * transition_processing_memory optimizations, etc. (#4487)
    jakirkham
  * Attempt to get client from worker in Queue and Variable
    (#4490) James Bourbeau
  * Use main branch for zict (#4499) jakirkham
  * Use a callback to close TCP Comms, rather than check every
    time (#4453) Matthew Rocklin
buildservice-autocommit accepted request 874194 from Matej Cepl's avatar Matej Cepl (mcepl) (revision 89)
baserev update by copy to link target
Displaying revisions 61 - 80 of 168
openSUSE Build Service is sponsored by