├── .git-blame-ignore-revs ├── .github ├── PULL_REQUEST_TEMPLATE.md ├── dependabot.yml ├── release-drafter.yml └── workflows │ ├── ci-pre-commit.yml │ ├── conda.yml │ ├── label-all.yml │ ├── publish-test-results.yaml │ ├── release-drafter.yml │ ├── release-publish.yml │ ├── ssh_debug.yaml.donotrun │ ├── test-report.yaml │ └── tests.yaml ├── .gitignore ├── .pre-commit-config.yaml ├── .readthedocs.yaml ├── AUTHORS.md ├── CODEOWNERS ├── CONTRIBUTING.md ├── LICENSE.txt ├── MANIFEST.in ├── README.rst ├── codecov.yml ├── conftest.py ├── continuous_integration ├── condarc ├── environment-3.10.yaml ├── environment-3.11.yaml ├── environment-3.12.yaml ├── environment-3.13.yaml ├── environment-mindeps.yaml ├── recipes │ ├── dask │ │ └── meta.yaml │ └── distributed │ │ └── meta.yaml └── scripts │ ├── host_info.py │ ├── parse_stdout.py │ ├── set_ulimit.sh │ ├── setup_ssh.sh │ ├── test-report-environment.yml │ └── test_report.py ├── distributed ├── __init__.py ├── _async_taskgroup.py ├── _asyncio.py ├── _concurrent_futures_thread.py ├── _signals.py ├── _stories.py ├── active_memory_manager.py ├── actor.py ├── batched.py ├── bokeh.py ├── broker.py ├── cfexecutor.py ├── chaos.py ├── cli │ ├── __init__.py │ ├── dask_scheduler.py │ ├── dask_spec.py │ ├── dask_ssh.py │ ├── dask_worker.py │ ├── tests │ │ ├── __init__.py │ │ ├── test_dask_scheduler.py │ │ ├── test_dask_spec.py │ │ ├── test_dask_ssh.py │ │ ├── test_dask_worker.py │ │ └── test_tls_cli.py │ └── utils.py ├── client.py ├── cluster_dump.py ├── collections.py ├── comm │ ├── __init__.py │ ├── addressing.py │ ├── core.py │ ├── inproc.py │ ├── registry.py │ ├── tcp.py │ ├── tests │ │ ├── __init__.py │ │ ├── test_comms.py │ │ ├── test_tcp.py │ │ └── test_ws.py │ ├── ucx.py │ ├── utils.py │ └── ws.py ├── compatibility.py ├── config.py ├── core.py ├── counter.py ├── dashboard │ ├── __init__.py │ ├── components │ │ ├── __init__.py │ │ ├── nvml.py │ │ ├── rmm.py │ │ ├── scheduler.py │ │ ├── shared.py │ │ └── worker.py │ ├── core.py │ ├── export_tool.js │ ├── export_tool.py │ ├── scheduler.py │ ├── templates │ │ ├── __init__.py │ │ └── performance_report.html │ ├── tests │ │ ├── test_bokeh.py │ │ ├── test_components.py │ │ ├── test_scheduler_bokeh.py │ │ └── test_worker_bokeh.py │ ├── theme.yaml │ ├── utils.py │ └── worker.py ├── deploy │ ├── __init__.py │ ├── adaptive.py │ ├── adaptive_core.py │ ├── cluster.py │ ├── local.py │ ├── old_ssh.py │ ├── spec.py │ ├── ssh.py │ ├── subprocess.py │ ├── tests │ │ ├── test_adaptive.py │ │ ├── test_adaptive_core.py │ │ ├── test_cluster.py │ │ ├── test_deploy_utils.py │ │ ├── test_local.py │ │ ├── test_old_ssh.py │ │ ├── test_slow_adaptive.py │ │ ├── test_spec_cluster.py │ │ ├── test_ssh.py │ │ └── test_subprocess.py │ └── utils.py ├── diagnostics │ ├── __init__.py │ ├── cluster_dump.py │ ├── cudf.py │ ├── eventstream.py │ ├── graph_layout.py │ ├── memory_sampler.py │ ├── memray.py │ ├── nvml.py │ ├── plugin.py │ ├── progress.py │ ├── progress_stream.py │ ├── progressbar.py │ ├── rmm.py │ ├── task_stream.py │ ├── tests │ │ ├── test_cluster_dump_plugin.py │ │ ├── test_cudf_diagnostics.py │ │ ├── test_eventstream.py │ │ ├── test_graph_layout.py │ │ ├── test_install_plugin.py │ │ ├── test_memory_sampler.py │ │ ├── test_memray.py │ │ ├── test_nanny_plugin.py │ │ ├── test_nvml.py │ │ ├── test_progress.py │ │ ├── test_progress_stream.py │ │ ├── test_progress_widgets.py │ │ ├── test_progressbar.py │ │ ├── test_rmm_diagnostics.py │ │ ├── test_scheduler_plugin.py │ │ ├── test_task_stream.py │ │ └── test_worker_plugin.py │ └── websocket.py ├── diskutils.py ├── distributed-schema.yaml ├── distributed.yaml ├── event.py ├── exceptions.py ├── gc.py ├── http │ ├── __init__.py │ ├── health.py │ ├── prometheus.py │ ├── proxy.py │ ├── routing.py │ ├── scheduler │ │ ├── __init__.py │ │ ├── api.py │ │ ├── info.py │ │ ├── json.py │ │ ├── missing_bokeh.py │ │ ├── prometheus │ │ │ ├── __init__.py │ │ │ ├── core.py │ │ │ ├── semaphore.py │ │ │ └── stealing.py │ │ └── tests │ │ │ ├── test_missing_bokeh.py │ │ │ ├── test_scheduler_http.py │ │ │ ├── test_semaphore_http.py │ │ │ └── test_stealing_http.py │ ├── static │ │ ├── __init__.py │ │ ├── css │ │ │ ├── __init__.py │ │ │ ├── base.css │ │ │ ├── gpu.css │ │ │ ├── individual-cluster-map.css │ │ │ ├── sortable.min.css │ │ │ ├── sortable.min.css.map │ │ │ └── status.css │ │ ├── images │ │ │ ├── __init__.py │ │ │ ├── dask-logo.svg │ │ │ ├── fa-bars.svg │ │ │ ├── favicon.ico │ │ │ ├── jupyter.svg │ │ │ ├── numpy.png │ │ │ ├── pandas.png │ │ │ └── python.png │ │ ├── individual-cluster-map.html │ │ └── js │ │ │ ├── __init__.py │ │ │ ├── anime.min.js │ │ │ ├── individual-cluster-map.js │ │ │ ├── reconnecting-websocket.min.js │ │ │ └── sortable.min.js │ ├── statics.py │ ├── templates │ │ ├── __init__.py │ │ ├── base.html │ │ ├── call-stack.html │ │ ├── exceptions.html │ │ ├── gpu.html │ │ ├── json-index.html │ │ ├── logs.html │ │ ├── main.html │ │ ├── simple.html │ │ ├── status.html │ │ ├── task.html │ │ ├── worker-table.html │ │ ├── worker.html │ │ └── workers.html │ ├── tests │ │ ├── __init__.py │ │ ├── test_core.py │ │ └── test_routing.py │ ├── utils.py │ └── worker │ │ ├── __init__.py │ │ ├── prometheus │ │ ├── __init__.py │ │ └── core.py │ │ └── tests │ │ └── test_worker_http.py ├── itertools.py ├── lock.py ├── metrics.py ├── multi_lock.py ├── nanny.py ├── node.py ├── objects.py ├── preloading.py ├── process.py ├── proctitle.py ├── profile.py ├── protocol │ ├── __init__.py │ ├── arrow.py │ ├── compression.py │ ├── core.py │ ├── cuda.py │ ├── cupy.py │ ├── h5py.py │ ├── keras.py │ ├── netcdf4.py │ ├── numba.py │ ├── numpy.py │ ├── pickle.py │ ├── rmm.py │ ├── scipy.py │ ├── serialize.py │ ├── sparse.py │ ├── tests │ │ ├── __init__.py │ │ ├── test_arrow.py │ │ ├── test_collection.py │ │ ├── test_collection_cuda.py │ │ ├── test_compression.py │ │ ├── test_cupy.py │ │ ├── test_h5py.py │ │ ├── test_highlevelgraph.py │ │ ├── test_keras.py │ │ ├── test_netcdf4.py │ │ ├── test_numba.py │ │ ├── test_numpy.py │ │ ├── test_pandas.py │ │ ├── test_pickle.py │ │ ├── test_protocol.py │ │ ├── test_protocol_utils.py │ │ ├── test_rmm.py │ │ ├── test_scipy.py │ │ ├── test_serialize.py │ │ ├── test_sparse.py │ │ ├── test_to_pickle.py │ │ ├── test_torch.py │ │ ├── test_utils.py │ │ └── test_utils_test.py │ ├── torch.py │ ├── utils.py │ └── utils_test.py ├── publish.py ├── py.typed ├── pytest_resourceleaks.py ├── queues.py ├── recreate_tasks.py ├── scheduler.py ├── security.py ├── semaphore.py ├── shuffle │ ├── __init__.py │ ├── _arrow.py │ ├── _buffer.py │ ├── _comms.py │ ├── _core.py │ ├── _disk.py │ ├── _exceptions.py │ ├── _limiter.py │ ├── _memory.py │ ├── _merge.py │ ├── _pickle.py │ ├── _rechunk.py │ ├── _scheduler_plugin.py │ ├── _shuffle.py │ ├── _worker_plugin.py │ └── tests │ │ ├── __init__.py │ │ ├── test_buffer.py │ │ ├── test_comm_buffer.py │ │ ├── test_core.py │ │ ├── test_disk_buffer.py │ │ ├── test_graph.py │ │ ├── test_limiter.py │ │ ├── test_memory_buffer.py │ │ ├── test_merge.py │ │ ├── test_merge_column_and_index.py │ │ ├── test_metrics.py │ │ ├── test_pickle.py │ │ ├── test_read_write_lock.py │ │ ├── test_rechunk.py │ │ ├── test_shuffle.py │ │ ├── test_shuffle_plugins.py │ │ └── utils.py ├── sizeof.py ├── spans.py ├── spill.py ├── stealing.py ├── system.py ├── system_monitor.py ├── tests │ ├── make_tls_certs.py │ ├── mytest.pyz │ ├── test_active_memory_manager.py │ ├── test_actor.py │ ├── test_as_completed.py │ ├── test_async_task_group.py │ ├── test_asyncio.py │ ├── test_asyncprocess.py │ ├── test_batched.py │ ├── test_cancelled_state.py │ ├── test_chaos.py │ ├── test_client.py │ ├── test_client_executor.py │ ├── test_client_loop.py │ ├── test_cluster_dump.py │ ├── test_collections.py │ ├── test_compatibility.py │ ├── test_computations.py │ ├── test_config.py │ ├── test_core.py │ ├── test_counter.py │ ├── test_dask_collections.py │ ├── test_deadline.py │ ├── test_diskutils.py │ ├── test_event_logging.py │ ├── test_events.py │ ├── test_failed_workers.py │ ├── test_gc.py │ ├── test_imports.py │ ├── test_init.py │ ├── test_itertools.py │ ├── test_jupyter.py │ ├── test_locks.py │ ├── test_metrics.py │ ├── test_multi_locks.py │ ├── test_nanny.py │ ├── test_parse_stdout.py │ ├── test_preload.py │ ├── test_priorities.py │ ├── test_profile.py │ ├── test_publish.py │ ├── test_queues.py │ ├── test_reschedule.py │ ├── test_resources.py │ ├── test_scheduler.py │ ├── test_security.py │ ├── test_semaphore.py │ ├── test_sizeof.py │ ├── test_spans.py │ ├── test_spec.py │ ├── test_spill.py │ ├── test_steal.py │ ├── test_stories.py │ ├── test_stress.py │ ├── test_system.py │ ├── test_system_monitor.py │ ├── test_threadpoolexecutor.py │ ├── test_tls_functional.py │ ├── test_utils.py │ ├── test_utils_comm.py │ ├── test_utils_test.py │ ├── test_variable.py │ ├── test_versions.py │ ├── test_worker.py │ ├── test_worker_client.py │ ├── test_worker_memory.py │ ├── test_worker_metrics.py │ ├── test_worker_state_machine.py │ ├── testegg-1.0.0-py3.4.egg │ ├── tls-ca-cert.pem │ ├── tls-ca-key.pem │ ├── tls-cert-chain.pem │ ├── tls-cert.pem │ ├── tls-key-cert.pem │ ├── tls-key.pem │ ├── tls-self-signed-cert.pem │ └── tls-self-signed-key.pem ├── threadpoolexecutor.py ├── utils.py ├── utils_comm.py ├── utils_test.py ├── variable.py ├── versions.py ├── widgets │ ├── __init__.py │ └── templates │ │ ├── __init__.py │ │ ├── client.html.j2 │ │ ├── cluster.html.j2 │ │ ├── computation.html.j2 │ │ ├── future.html.j2 │ │ ├── has_what.html.j2 │ │ ├── local_cluster.html.j2 │ │ ├── log.html.j2 │ │ ├── logs.html.j2 │ │ ├── process_interface.html.j2 │ │ ├── scheduler.html.j2 │ │ ├── scheduler_info.html.j2 │ │ ├── security.html.j2 │ │ ├── task_state.html.j2 │ │ ├── who_has.html.j2 │ │ └── worker_state.html.j2 ├── worker.py ├── worker_client.py ├── worker_memory.py └── worker_state_machine.py ├── docs ├── Makefile ├── make.bat ├── release-procedure.md ├── requirements.txt └── source │ ├── active_memory_manager.rst │ ├── actors.rst │ ├── api.rst │ ├── asynchronous.rst │ ├── changelog.rst │ ├── client.rst │ ├── communications.rst │ ├── conf.py │ ├── develop.rst │ ├── diagnosing-performance.rst │ ├── efficiency.rst │ ├── examples-overview.rst │ ├── examples │ └── word-count.rst │ ├── faq.rst │ ├── fine-performance-metrics.rst │ ├── foundations.rst │ ├── http_services.rst │ ├── images │ ├── fine-performance-metrics │ │ ├── bytes.png │ │ ├── seconds-IO.png │ │ ├── seconds-full.png │ │ ├── seconds-not-IO.png │ │ └── spans.png │ ├── memory-sampler.svg │ ├── network.png │ ├── network.svg │ ├── run_dot.sh │ ├── scheduler-detailed.png │ ├── scheduler-detailed.svg │ ├── task-state.dot │ ├── task-state.svg │ ├── worker-cancel-state1.dot │ ├── worker-cancel-state1.svg │ ├── worker-cancel-state2.dot │ ├── worker-cancel-state2.svg │ ├── worker-dep-state.dot │ ├── worker-dep-state.svg │ ├── worker-execute-state.dot │ ├── worker-execute-state.svg │ ├── worker-forget-state.dot │ ├── worker-forget-state.svg │ ├── worker-scatter-state.dot │ ├── worker-scatter-state.svg │ ├── worker-state-machine.dot │ └── worker-state-machine.svg │ ├── index.rst │ ├── install.rst │ ├── journey.rst │ ├── killed.rst │ ├── limitations.rst │ ├── locality.rst │ ├── logging.rst │ ├── manage-computation.rst │ ├── memory.rst │ ├── plugins.rst │ ├── priority.rst │ ├── prometheus.rst │ ├── protocol.rst │ ├── publish.rst │ ├── queues.rst │ ├── quickstart.rst │ ├── related-work.rst │ ├── resilience.rst │ ├── resources.rst │ ├── scheduling-policies.rst │ ├── scheduling-state.rst │ ├── serialization.rst │ ├── spans.rst │ ├── task-launch.rst │ ├── tls.rst │ ├── work-stealing.rst │ ├── worker-memory.rst │ ├── worker-state.rst │ └── worker.rst └── pyproject.toml /.git-blame-ignore-revs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.git-blame-ignore-revs -------------------------------------------------------------------------------- /.github/PULL_REQUEST_TEMPLATE.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/PULL_REQUEST_TEMPLATE.md -------------------------------------------------------------------------------- /.github/dependabot.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/dependabot.yml -------------------------------------------------------------------------------- /.github/release-drafter.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/release-drafter.yml -------------------------------------------------------------------------------- /.github/workflows/ci-pre-commit.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/ci-pre-commit.yml -------------------------------------------------------------------------------- /.github/workflows/conda.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/conda.yml -------------------------------------------------------------------------------- /.github/workflows/label-all.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/label-all.yml -------------------------------------------------------------------------------- /.github/workflows/publish-test-results.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/publish-test-results.yaml -------------------------------------------------------------------------------- /.github/workflows/release-drafter.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/release-drafter.yml -------------------------------------------------------------------------------- /.github/workflows/release-publish.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/release-publish.yml -------------------------------------------------------------------------------- /.github/workflows/ssh_debug.yaml.donotrun: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/ssh_debug.yaml.donotrun -------------------------------------------------------------------------------- /.github/workflows/test-report.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/test-report.yaml -------------------------------------------------------------------------------- /.github/workflows/tests.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.github/workflows/tests.yaml -------------------------------------------------------------------------------- /.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.gitignore -------------------------------------------------------------------------------- /.pre-commit-config.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.pre-commit-config.yaml -------------------------------------------------------------------------------- /.readthedocs.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/.readthedocs.yaml -------------------------------------------------------------------------------- /AUTHORS.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/AUTHORS.md -------------------------------------------------------------------------------- /CODEOWNERS: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/CODEOWNERS -------------------------------------------------------------------------------- /CONTRIBUTING.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/CONTRIBUTING.md -------------------------------------------------------------------------------- /LICENSE.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/LICENSE.txt -------------------------------------------------------------------------------- /MANIFEST.in: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/MANIFEST.in -------------------------------------------------------------------------------- /README.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/README.rst -------------------------------------------------------------------------------- /codecov.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/codecov.yml -------------------------------------------------------------------------------- /conftest.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/conftest.py -------------------------------------------------------------------------------- /continuous_integration/condarc: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/condarc -------------------------------------------------------------------------------- /continuous_integration/environment-3.10.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/environment-3.10.yaml -------------------------------------------------------------------------------- /continuous_integration/environment-3.11.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/environment-3.11.yaml -------------------------------------------------------------------------------- /continuous_integration/environment-3.12.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/environment-3.12.yaml -------------------------------------------------------------------------------- /continuous_integration/environment-3.13.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/environment-3.13.yaml -------------------------------------------------------------------------------- /continuous_integration/environment-mindeps.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/environment-mindeps.yaml -------------------------------------------------------------------------------- /continuous_integration/recipes/dask/meta.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/recipes/dask/meta.yaml -------------------------------------------------------------------------------- /continuous_integration/recipes/distributed/meta.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/recipes/distributed/meta.yaml -------------------------------------------------------------------------------- /continuous_integration/scripts/host_info.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/scripts/host_info.py -------------------------------------------------------------------------------- /continuous_integration/scripts/parse_stdout.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/scripts/parse_stdout.py -------------------------------------------------------------------------------- /continuous_integration/scripts/set_ulimit.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/scripts/set_ulimit.sh -------------------------------------------------------------------------------- /continuous_integration/scripts/setup_ssh.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/scripts/setup_ssh.sh -------------------------------------------------------------------------------- /continuous_integration/scripts/test-report-environment.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/scripts/test-report-environment.yml -------------------------------------------------------------------------------- /continuous_integration/scripts/test_report.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/continuous_integration/scripts/test_report.py -------------------------------------------------------------------------------- /distributed/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/__init__.py -------------------------------------------------------------------------------- /distributed/_async_taskgroup.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/_async_taskgroup.py -------------------------------------------------------------------------------- /distributed/_asyncio.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/_asyncio.py -------------------------------------------------------------------------------- /distributed/_concurrent_futures_thread.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/_concurrent_futures_thread.py -------------------------------------------------------------------------------- /distributed/_signals.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/_signals.py -------------------------------------------------------------------------------- /distributed/_stories.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/_stories.py -------------------------------------------------------------------------------- /distributed/active_memory_manager.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/active_memory_manager.py -------------------------------------------------------------------------------- /distributed/actor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/actor.py -------------------------------------------------------------------------------- /distributed/batched.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/batched.py -------------------------------------------------------------------------------- /distributed/bokeh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/bokeh.py -------------------------------------------------------------------------------- /distributed/broker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/broker.py -------------------------------------------------------------------------------- /distributed/cfexecutor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cfexecutor.py -------------------------------------------------------------------------------- /distributed/chaos.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/chaos.py -------------------------------------------------------------------------------- /distributed/cli/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/cli/dask_scheduler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/dask_scheduler.py -------------------------------------------------------------------------------- /distributed/cli/dask_spec.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/dask_spec.py -------------------------------------------------------------------------------- /distributed/cli/dask_ssh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/dask_ssh.py -------------------------------------------------------------------------------- /distributed/cli/dask_worker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/dask_worker.py -------------------------------------------------------------------------------- /distributed/cli/tests/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/cli/tests/test_dask_scheduler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/tests/test_dask_scheduler.py -------------------------------------------------------------------------------- /distributed/cli/tests/test_dask_spec.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/tests/test_dask_spec.py -------------------------------------------------------------------------------- /distributed/cli/tests/test_dask_ssh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/tests/test_dask_ssh.py -------------------------------------------------------------------------------- /distributed/cli/tests/test_dask_worker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/tests/test_dask_worker.py -------------------------------------------------------------------------------- /distributed/cli/tests/test_tls_cli.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/tests/test_tls_cli.py -------------------------------------------------------------------------------- /distributed/cli/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cli/utils.py -------------------------------------------------------------------------------- /distributed/client.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/client.py -------------------------------------------------------------------------------- /distributed/cluster_dump.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/cluster_dump.py -------------------------------------------------------------------------------- /distributed/collections.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/collections.py -------------------------------------------------------------------------------- /distributed/comm/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/__init__.py -------------------------------------------------------------------------------- /distributed/comm/addressing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/addressing.py -------------------------------------------------------------------------------- /distributed/comm/core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/core.py -------------------------------------------------------------------------------- /distributed/comm/inproc.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/inproc.py -------------------------------------------------------------------------------- /distributed/comm/registry.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/registry.py -------------------------------------------------------------------------------- /distributed/comm/tcp.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/tcp.py -------------------------------------------------------------------------------- /distributed/comm/tests/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/comm/tests/test_comms.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/tests/test_comms.py -------------------------------------------------------------------------------- /distributed/comm/tests/test_tcp.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/tests/test_tcp.py -------------------------------------------------------------------------------- /distributed/comm/tests/test_ws.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/tests/test_ws.py -------------------------------------------------------------------------------- /distributed/comm/ucx.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/ucx.py -------------------------------------------------------------------------------- /distributed/comm/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/utils.py -------------------------------------------------------------------------------- /distributed/comm/ws.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/comm/ws.py -------------------------------------------------------------------------------- /distributed/compatibility.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/compatibility.py -------------------------------------------------------------------------------- /distributed/config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/config.py -------------------------------------------------------------------------------- /distributed/core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/core.py -------------------------------------------------------------------------------- /distributed/counter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/counter.py -------------------------------------------------------------------------------- /distributed/dashboard/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/dashboard/components/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/components/__init__.py -------------------------------------------------------------------------------- /distributed/dashboard/components/nvml.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/components/nvml.py -------------------------------------------------------------------------------- /distributed/dashboard/components/rmm.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/components/rmm.py -------------------------------------------------------------------------------- /distributed/dashboard/components/scheduler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/components/scheduler.py -------------------------------------------------------------------------------- /distributed/dashboard/components/shared.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/components/shared.py -------------------------------------------------------------------------------- /distributed/dashboard/components/worker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/components/worker.py -------------------------------------------------------------------------------- /distributed/dashboard/core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/core.py -------------------------------------------------------------------------------- /distributed/dashboard/export_tool.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/export_tool.js -------------------------------------------------------------------------------- /distributed/dashboard/export_tool.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/export_tool.py -------------------------------------------------------------------------------- /distributed/dashboard/scheduler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/scheduler.py -------------------------------------------------------------------------------- /distributed/dashboard/templates/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/dashboard/templates/performance_report.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/templates/performance_report.html -------------------------------------------------------------------------------- /distributed/dashboard/tests/test_bokeh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/tests/test_bokeh.py -------------------------------------------------------------------------------- /distributed/dashboard/tests/test_components.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/tests/test_components.py -------------------------------------------------------------------------------- /distributed/dashboard/tests/test_scheduler_bokeh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/tests/test_scheduler_bokeh.py -------------------------------------------------------------------------------- /distributed/dashboard/tests/test_worker_bokeh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/tests/test_worker_bokeh.py -------------------------------------------------------------------------------- /distributed/dashboard/theme.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/theme.yaml -------------------------------------------------------------------------------- /distributed/dashboard/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/utils.py -------------------------------------------------------------------------------- /distributed/dashboard/worker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/dashboard/worker.py -------------------------------------------------------------------------------- /distributed/deploy/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/__init__.py -------------------------------------------------------------------------------- /distributed/deploy/adaptive.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/adaptive.py -------------------------------------------------------------------------------- /distributed/deploy/adaptive_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/adaptive_core.py -------------------------------------------------------------------------------- /distributed/deploy/cluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/cluster.py -------------------------------------------------------------------------------- /distributed/deploy/local.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/local.py -------------------------------------------------------------------------------- /distributed/deploy/old_ssh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/old_ssh.py -------------------------------------------------------------------------------- /distributed/deploy/spec.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/spec.py -------------------------------------------------------------------------------- /distributed/deploy/ssh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/ssh.py -------------------------------------------------------------------------------- /distributed/deploy/subprocess.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/subprocess.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_adaptive.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_adaptive.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_adaptive_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_adaptive_core.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_cluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_cluster.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_deploy_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_deploy_utils.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_local.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_local.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_old_ssh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_old_ssh.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_slow_adaptive.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_slow_adaptive.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_spec_cluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_spec_cluster.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_ssh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_ssh.py -------------------------------------------------------------------------------- /distributed/deploy/tests/test_subprocess.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/tests/test_subprocess.py -------------------------------------------------------------------------------- /distributed/deploy/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/deploy/utils.py -------------------------------------------------------------------------------- /distributed/diagnostics/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/__init__.py -------------------------------------------------------------------------------- /distributed/diagnostics/cluster_dump.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/cluster_dump.py -------------------------------------------------------------------------------- /distributed/diagnostics/cudf.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/cudf.py -------------------------------------------------------------------------------- /distributed/diagnostics/eventstream.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/eventstream.py -------------------------------------------------------------------------------- /distributed/diagnostics/graph_layout.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/graph_layout.py -------------------------------------------------------------------------------- /distributed/diagnostics/memory_sampler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/memory_sampler.py -------------------------------------------------------------------------------- /distributed/diagnostics/memray.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/memray.py -------------------------------------------------------------------------------- /distributed/diagnostics/nvml.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/nvml.py -------------------------------------------------------------------------------- /distributed/diagnostics/plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/plugin.py -------------------------------------------------------------------------------- /distributed/diagnostics/progress.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/progress.py -------------------------------------------------------------------------------- /distributed/diagnostics/progress_stream.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/progress_stream.py -------------------------------------------------------------------------------- /distributed/diagnostics/progressbar.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/progressbar.py -------------------------------------------------------------------------------- /distributed/diagnostics/rmm.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/rmm.py -------------------------------------------------------------------------------- /distributed/diagnostics/task_stream.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/task_stream.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_cluster_dump_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_cluster_dump_plugin.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_cudf_diagnostics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_cudf_diagnostics.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_eventstream.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_eventstream.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_graph_layout.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_graph_layout.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_install_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_install_plugin.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_memory_sampler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_memory_sampler.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_memray.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_memray.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_nanny_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_nanny_plugin.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_nvml.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_nvml.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_progress.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_progress.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_progress_stream.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_progress_stream.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_progress_widgets.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_progress_widgets.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_progressbar.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_progressbar.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_rmm_diagnostics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_rmm_diagnostics.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_scheduler_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_scheduler_plugin.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_task_stream.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_task_stream.py -------------------------------------------------------------------------------- /distributed/diagnostics/tests/test_worker_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/tests/test_worker_plugin.py -------------------------------------------------------------------------------- /distributed/diagnostics/websocket.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diagnostics/websocket.py -------------------------------------------------------------------------------- /distributed/diskutils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/diskutils.py -------------------------------------------------------------------------------- /distributed/distributed-schema.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/distributed-schema.yaml -------------------------------------------------------------------------------- /distributed/distributed.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/distributed.yaml -------------------------------------------------------------------------------- /distributed/event.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/event.py -------------------------------------------------------------------------------- /distributed/exceptions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/exceptions.py -------------------------------------------------------------------------------- /distributed/gc.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/gc.py -------------------------------------------------------------------------------- /distributed/http/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/__init__.py -------------------------------------------------------------------------------- /distributed/http/health.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/health.py -------------------------------------------------------------------------------- /distributed/http/prometheus.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/prometheus.py -------------------------------------------------------------------------------- /distributed/http/proxy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/proxy.py -------------------------------------------------------------------------------- /distributed/http/routing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/routing.py -------------------------------------------------------------------------------- /distributed/http/scheduler/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/scheduler/api.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/api.py -------------------------------------------------------------------------------- /distributed/http/scheduler/info.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/info.py -------------------------------------------------------------------------------- /distributed/http/scheduler/json.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/json.py -------------------------------------------------------------------------------- /distributed/http/scheduler/missing_bokeh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/missing_bokeh.py -------------------------------------------------------------------------------- /distributed/http/scheduler/prometheus/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/prometheus/__init__.py -------------------------------------------------------------------------------- /distributed/http/scheduler/prometheus/core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/prometheus/core.py -------------------------------------------------------------------------------- /distributed/http/scheduler/prometheus/semaphore.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/prometheus/semaphore.py -------------------------------------------------------------------------------- /distributed/http/scheduler/prometheus/stealing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/prometheus/stealing.py -------------------------------------------------------------------------------- /distributed/http/scheduler/tests/test_missing_bokeh.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/tests/test_missing_bokeh.py -------------------------------------------------------------------------------- /distributed/http/scheduler/tests/test_scheduler_http.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/tests/test_scheduler_http.py -------------------------------------------------------------------------------- /distributed/http/scheduler/tests/test_semaphore_http.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/tests/test_semaphore_http.py -------------------------------------------------------------------------------- /distributed/http/scheduler/tests/test_stealing_http.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/scheduler/tests/test_stealing_http.py -------------------------------------------------------------------------------- /distributed/http/static/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/static/css/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/static/css/base.css: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/css/base.css -------------------------------------------------------------------------------- /distributed/http/static/css/gpu.css: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/css/gpu.css -------------------------------------------------------------------------------- /distributed/http/static/css/individual-cluster-map.css: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/css/individual-cluster-map.css -------------------------------------------------------------------------------- /distributed/http/static/css/sortable.min.css: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/css/sortable.min.css -------------------------------------------------------------------------------- /distributed/http/static/css/sortable.min.css.map: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/css/sortable.min.css.map -------------------------------------------------------------------------------- /distributed/http/static/css/status.css: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/css/status.css -------------------------------------------------------------------------------- /distributed/http/static/images/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/static/images/dask-logo.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/dask-logo.svg -------------------------------------------------------------------------------- /distributed/http/static/images/fa-bars.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/fa-bars.svg -------------------------------------------------------------------------------- /distributed/http/static/images/favicon.ico: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/favicon.ico -------------------------------------------------------------------------------- /distributed/http/static/images/jupyter.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/jupyter.svg -------------------------------------------------------------------------------- /distributed/http/static/images/numpy.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/numpy.png -------------------------------------------------------------------------------- /distributed/http/static/images/pandas.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/pandas.png -------------------------------------------------------------------------------- /distributed/http/static/images/python.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/images/python.png -------------------------------------------------------------------------------- /distributed/http/static/individual-cluster-map.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/individual-cluster-map.html -------------------------------------------------------------------------------- /distributed/http/static/js/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/static/js/anime.min.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/js/anime.min.js -------------------------------------------------------------------------------- /distributed/http/static/js/individual-cluster-map.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/js/individual-cluster-map.js -------------------------------------------------------------------------------- /distributed/http/static/js/reconnecting-websocket.min.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/js/reconnecting-websocket.min.js -------------------------------------------------------------------------------- /distributed/http/static/js/sortable.min.js: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/static/js/sortable.min.js -------------------------------------------------------------------------------- /distributed/http/statics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/statics.py -------------------------------------------------------------------------------- /distributed/http/templates/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/templates/base.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/base.html -------------------------------------------------------------------------------- /distributed/http/templates/call-stack.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/call-stack.html -------------------------------------------------------------------------------- /distributed/http/templates/exceptions.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/exceptions.html -------------------------------------------------------------------------------- /distributed/http/templates/gpu.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/gpu.html -------------------------------------------------------------------------------- /distributed/http/templates/json-index.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/json-index.html -------------------------------------------------------------------------------- /distributed/http/templates/logs.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/logs.html -------------------------------------------------------------------------------- /distributed/http/templates/main.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/main.html -------------------------------------------------------------------------------- /distributed/http/templates/simple.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/simple.html -------------------------------------------------------------------------------- /distributed/http/templates/status.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/status.html -------------------------------------------------------------------------------- /distributed/http/templates/task.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/task.html -------------------------------------------------------------------------------- /distributed/http/templates/worker-table.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/worker-table.html -------------------------------------------------------------------------------- /distributed/http/templates/worker.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/worker.html -------------------------------------------------------------------------------- /distributed/http/templates/workers.html: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/templates/workers.html -------------------------------------------------------------------------------- /distributed/http/tests/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/tests/test_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/tests/test_core.py -------------------------------------------------------------------------------- /distributed/http/tests/test_routing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/tests/test_routing.py -------------------------------------------------------------------------------- /distributed/http/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/utils.py -------------------------------------------------------------------------------- /distributed/http/worker/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/http/worker/prometheus/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/worker/prometheus/__init__.py -------------------------------------------------------------------------------- /distributed/http/worker/prometheus/core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/worker/prometheus/core.py -------------------------------------------------------------------------------- /distributed/http/worker/tests/test_worker_http.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/http/worker/tests/test_worker_http.py -------------------------------------------------------------------------------- /distributed/itertools.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/itertools.py -------------------------------------------------------------------------------- /distributed/lock.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/lock.py -------------------------------------------------------------------------------- /distributed/metrics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/metrics.py -------------------------------------------------------------------------------- /distributed/multi_lock.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/multi_lock.py -------------------------------------------------------------------------------- /distributed/nanny.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/nanny.py -------------------------------------------------------------------------------- /distributed/node.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/node.py -------------------------------------------------------------------------------- /distributed/objects.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/objects.py -------------------------------------------------------------------------------- /distributed/preloading.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/preloading.py -------------------------------------------------------------------------------- /distributed/process.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/process.py -------------------------------------------------------------------------------- /distributed/proctitle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/proctitle.py -------------------------------------------------------------------------------- /distributed/profile.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/profile.py -------------------------------------------------------------------------------- /distributed/protocol/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/__init__.py -------------------------------------------------------------------------------- /distributed/protocol/arrow.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/arrow.py -------------------------------------------------------------------------------- /distributed/protocol/compression.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/compression.py -------------------------------------------------------------------------------- /distributed/protocol/core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/core.py -------------------------------------------------------------------------------- /distributed/protocol/cuda.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/cuda.py -------------------------------------------------------------------------------- /distributed/protocol/cupy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/cupy.py -------------------------------------------------------------------------------- /distributed/protocol/h5py.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/h5py.py -------------------------------------------------------------------------------- /distributed/protocol/keras.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/keras.py -------------------------------------------------------------------------------- /distributed/protocol/netcdf4.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/netcdf4.py -------------------------------------------------------------------------------- /distributed/protocol/numba.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/numba.py -------------------------------------------------------------------------------- /distributed/protocol/numpy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/numpy.py -------------------------------------------------------------------------------- /distributed/protocol/pickle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/pickle.py -------------------------------------------------------------------------------- /distributed/protocol/rmm.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/rmm.py -------------------------------------------------------------------------------- /distributed/protocol/scipy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/scipy.py -------------------------------------------------------------------------------- /distributed/protocol/serialize.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/serialize.py -------------------------------------------------------------------------------- /distributed/protocol/sparse.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/sparse.py -------------------------------------------------------------------------------- /distributed/protocol/tests/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/protocol/tests/test_arrow.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_arrow.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_collection.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_collection.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_collection_cuda.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_collection_cuda.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_compression.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_compression.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_cupy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_cupy.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_h5py.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_h5py.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_highlevelgraph.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_highlevelgraph.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_keras.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_keras.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_netcdf4.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_netcdf4.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_numba.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_numba.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_numpy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_numpy.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_pandas.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_pandas.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_pickle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_pickle.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_protocol.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_protocol.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_protocol_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_protocol_utils.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_rmm.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_rmm.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_scipy.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_scipy.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_serialize.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_serialize.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_sparse.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_sparse.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_to_pickle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_to_pickle.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_torch.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_torch.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_utils.py -------------------------------------------------------------------------------- /distributed/protocol/tests/test_utils_test.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/tests/test_utils_test.py -------------------------------------------------------------------------------- /distributed/protocol/torch.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/torch.py -------------------------------------------------------------------------------- /distributed/protocol/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/utils.py -------------------------------------------------------------------------------- /distributed/protocol/utils_test.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/protocol/utils_test.py -------------------------------------------------------------------------------- /distributed/publish.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/publish.py -------------------------------------------------------------------------------- /distributed/py.typed: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/pytest_resourceleaks.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/pytest_resourceleaks.py -------------------------------------------------------------------------------- /distributed/queues.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/queues.py -------------------------------------------------------------------------------- /distributed/recreate_tasks.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/recreate_tasks.py -------------------------------------------------------------------------------- /distributed/scheduler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/scheduler.py -------------------------------------------------------------------------------- /distributed/security.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/security.py -------------------------------------------------------------------------------- /distributed/semaphore.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/semaphore.py -------------------------------------------------------------------------------- /distributed/shuffle/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/__init__.py -------------------------------------------------------------------------------- /distributed/shuffle/_arrow.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_arrow.py -------------------------------------------------------------------------------- /distributed/shuffle/_buffer.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_buffer.py -------------------------------------------------------------------------------- /distributed/shuffle/_comms.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_comms.py -------------------------------------------------------------------------------- /distributed/shuffle/_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_core.py -------------------------------------------------------------------------------- /distributed/shuffle/_disk.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_disk.py -------------------------------------------------------------------------------- /distributed/shuffle/_exceptions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_exceptions.py -------------------------------------------------------------------------------- /distributed/shuffle/_limiter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_limiter.py -------------------------------------------------------------------------------- /distributed/shuffle/_memory.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_memory.py -------------------------------------------------------------------------------- /distributed/shuffle/_merge.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_merge.py -------------------------------------------------------------------------------- /distributed/shuffle/_pickle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_pickle.py -------------------------------------------------------------------------------- /distributed/shuffle/_rechunk.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_rechunk.py -------------------------------------------------------------------------------- /distributed/shuffle/_scheduler_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_scheduler_plugin.py -------------------------------------------------------------------------------- /distributed/shuffle/_shuffle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_shuffle.py -------------------------------------------------------------------------------- /distributed/shuffle/_worker_plugin.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/_worker_plugin.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_buffer.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_buffer.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_comm_buffer.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_comm_buffer.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_core.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_disk_buffer.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_disk_buffer.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_graph.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_graph.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_limiter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_limiter.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_memory_buffer.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_memory_buffer.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_merge.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_merge.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_merge_column_and_index.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_merge_column_and_index.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_metrics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_metrics.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_pickle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_pickle.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_read_write_lock.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_read_write_lock.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_rechunk.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_rechunk.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_shuffle.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_shuffle.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/test_shuffle_plugins.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/test_shuffle_plugins.py -------------------------------------------------------------------------------- /distributed/shuffle/tests/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/shuffle/tests/utils.py -------------------------------------------------------------------------------- /distributed/sizeof.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/sizeof.py -------------------------------------------------------------------------------- /distributed/spans.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/spans.py -------------------------------------------------------------------------------- /distributed/spill.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/spill.py -------------------------------------------------------------------------------- /distributed/stealing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/stealing.py -------------------------------------------------------------------------------- /distributed/system.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/system.py -------------------------------------------------------------------------------- /distributed/system_monitor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/system_monitor.py -------------------------------------------------------------------------------- /distributed/tests/make_tls_certs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/make_tls_certs.py -------------------------------------------------------------------------------- /distributed/tests/mytest.pyz: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/mytest.pyz -------------------------------------------------------------------------------- /distributed/tests/test_active_memory_manager.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_active_memory_manager.py -------------------------------------------------------------------------------- /distributed/tests/test_actor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_actor.py -------------------------------------------------------------------------------- /distributed/tests/test_as_completed.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_as_completed.py -------------------------------------------------------------------------------- /distributed/tests/test_async_task_group.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_async_task_group.py -------------------------------------------------------------------------------- /distributed/tests/test_asyncio.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_asyncio.py -------------------------------------------------------------------------------- /distributed/tests/test_asyncprocess.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_asyncprocess.py -------------------------------------------------------------------------------- /distributed/tests/test_batched.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_batched.py -------------------------------------------------------------------------------- /distributed/tests/test_cancelled_state.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_cancelled_state.py -------------------------------------------------------------------------------- /distributed/tests/test_chaos.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_chaos.py -------------------------------------------------------------------------------- /distributed/tests/test_client.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_client.py -------------------------------------------------------------------------------- /distributed/tests/test_client_executor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_client_executor.py -------------------------------------------------------------------------------- /distributed/tests/test_client_loop.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_client_loop.py -------------------------------------------------------------------------------- /distributed/tests/test_cluster_dump.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_cluster_dump.py -------------------------------------------------------------------------------- /distributed/tests/test_collections.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_collections.py -------------------------------------------------------------------------------- /distributed/tests/test_compatibility.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_compatibility.py -------------------------------------------------------------------------------- /distributed/tests/test_computations.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_computations.py -------------------------------------------------------------------------------- /distributed/tests/test_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_config.py -------------------------------------------------------------------------------- /distributed/tests/test_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_core.py -------------------------------------------------------------------------------- /distributed/tests/test_counter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_counter.py -------------------------------------------------------------------------------- /distributed/tests/test_dask_collections.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_dask_collections.py -------------------------------------------------------------------------------- /distributed/tests/test_deadline.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_deadline.py -------------------------------------------------------------------------------- /distributed/tests/test_diskutils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_diskutils.py -------------------------------------------------------------------------------- /distributed/tests/test_event_logging.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_event_logging.py -------------------------------------------------------------------------------- /distributed/tests/test_events.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_events.py -------------------------------------------------------------------------------- /distributed/tests/test_failed_workers.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_failed_workers.py -------------------------------------------------------------------------------- /distributed/tests/test_gc.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_gc.py -------------------------------------------------------------------------------- /distributed/tests/test_imports.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_imports.py -------------------------------------------------------------------------------- /distributed/tests/test_init.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_init.py -------------------------------------------------------------------------------- /distributed/tests/test_itertools.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_itertools.py -------------------------------------------------------------------------------- /distributed/tests/test_jupyter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_jupyter.py -------------------------------------------------------------------------------- /distributed/tests/test_locks.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_locks.py -------------------------------------------------------------------------------- /distributed/tests/test_metrics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_metrics.py -------------------------------------------------------------------------------- /distributed/tests/test_multi_locks.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_multi_locks.py -------------------------------------------------------------------------------- /distributed/tests/test_nanny.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_nanny.py -------------------------------------------------------------------------------- /distributed/tests/test_parse_stdout.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_parse_stdout.py -------------------------------------------------------------------------------- /distributed/tests/test_preload.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_preload.py -------------------------------------------------------------------------------- /distributed/tests/test_priorities.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_priorities.py -------------------------------------------------------------------------------- /distributed/tests/test_profile.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_profile.py -------------------------------------------------------------------------------- /distributed/tests/test_publish.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_publish.py -------------------------------------------------------------------------------- /distributed/tests/test_queues.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_queues.py -------------------------------------------------------------------------------- /distributed/tests/test_reschedule.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_reschedule.py -------------------------------------------------------------------------------- /distributed/tests/test_resources.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_resources.py -------------------------------------------------------------------------------- /distributed/tests/test_scheduler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_scheduler.py -------------------------------------------------------------------------------- /distributed/tests/test_security.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_security.py -------------------------------------------------------------------------------- /distributed/tests/test_semaphore.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_semaphore.py -------------------------------------------------------------------------------- /distributed/tests/test_sizeof.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_sizeof.py -------------------------------------------------------------------------------- /distributed/tests/test_spans.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_spans.py -------------------------------------------------------------------------------- /distributed/tests/test_spec.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_spec.py -------------------------------------------------------------------------------- /distributed/tests/test_spill.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_spill.py -------------------------------------------------------------------------------- /distributed/tests/test_steal.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_steal.py -------------------------------------------------------------------------------- /distributed/tests/test_stories.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_stories.py -------------------------------------------------------------------------------- /distributed/tests/test_stress.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_stress.py -------------------------------------------------------------------------------- /distributed/tests/test_system.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_system.py -------------------------------------------------------------------------------- /distributed/tests/test_system_monitor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_system_monitor.py -------------------------------------------------------------------------------- /distributed/tests/test_threadpoolexecutor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_threadpoolexecutor.py -------------------------------------------------------------------------------- /distributed/tests/test_tls_functional.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_tls_functional.py -------------------------------------------------------------------------------- /distributed/tests/test_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_utils.py -------------------------------------------------------------------------------- /distributed/tests/test_utils_comm.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_utils_comm.py -------------------------------------------------------------------------------- /distributed/tests/test_utils_test.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_utils_test.py -------------------------------------------------------------------------------- /distributed/tests/test_variable.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_variable.py -------------------------------------------------------------------------------- /distributed/tests/test_versions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_versions.py -------------------------------------------------------------------------------- /distributed/tests/test_worker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_worker.py -------------------------------------------------------------------------------- /distributed/tests/test_worker_client.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_worker_client.py -------------------------------------------------------------------------------- /distributed/tests/test_worker_memory.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_worker_memory.py -------------------------------------------------------------------------------- /distributed/tests/test_worker_metrics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_worker_metrics.py -------------------------------------------------------------------------------- /distributed/tests/test_worker_state_machine.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/test_worker_state_machine.py -------------------------------------------------------------------------------- /distributed/tests/testegg-1.0.0-py3.4.egg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/testegg-1.0.0-py3.4.egg -------------------------------------------------------------------------------- /distributed/tests/tls-ca-cert.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-ca-cert.pem -------------------------------------------------------------------------------- /distributed/tests/tls-ca-key.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-ca-key.pem -------------------------------------------------------------------------------- /distributed/tests/tls-cert-chain.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-cert-chain.pem -------------------------------------------------------------------------------- /distributed/tests/tls-cert.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-cert.pem -------------------------------------------------------------------------------- /distributed/tests/tls-key-cert.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-key-cert.pem -------------------------------------------------------------------------------- /distributed/tests/tls-key.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-key.pem -------------------------------------------------------------------------------- /distributed/tests/tls-self-signed-cert.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-self-signed-cert.pem -------------------------------------------------------------------------------- /distributed/tests/tls-self-signed-key.pem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/tests/tls-self-signed-key.pem -------------------------------------------------------------------------------- /distributed/threadpoolexecutor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/threadpoolexecutor.py -------------------------------------------------------------------------------- /distributed/utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/utils.py -------------------------------------------------------------------------------- /distributed/utils_comm.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/utils_comm.py -------------------------------------------------------------------------------- /distributed/utils_test.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/utils_test.py -------------------------------------------------------------------------------- /distributed/variable.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/variable.py -------------------------------------------------------------------------------- /distributed/versions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/versions.py -------------------------------------------------------------------------------- /distributed/widgets/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/__init__.py -------------------------------------------------------------------------------- /distributed/widgets/templates/__init__.py: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /distributed/widgets/templates/client.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/client.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/cluster.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/cluster.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/computation.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/computation.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/future.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/future.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/has_what.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/has_what.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/local_cluster.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/local_cluster.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/log.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/log.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/logs.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/logs.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/process_interface.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/process_interface.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/scheduler.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/scheduler.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/scheduler_info.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/scheduler_info.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/security.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/security.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/task_state.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/task_state.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/who_has.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/who_has.html.j2 -------------------------------------------------------------------------------- /distributed/widgets/templates/worker_state.html.j2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/widgets/templates/worker_state.html.j2 -------------------------------------------------------------------------------- /distributed/worker.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/worker.py -------------------------------------------------------------------------------- /distributed/worker_client.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/worker_client.py -------------------------------------------------------------------------------- /distributed/worker_memory.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/worker_memory.py -------------------------------------------------------------------------------- /distributed/worker_state_machine.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/distributed/worker_state_machine.py -------------------------------------------------------------------------------- /docs/Makefile: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/Makefile -------------------------------------------------------------------------------- /docs/make.bat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/make.bat -------------------------------------------------------------------------------- /docs/release-procedure.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/release-procedure.md -------------------------------------------------------------------------------- /docs/requirements.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/requirements.txt -------------------------------------------------------------------------------- /docs/source/active_memory_manager.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/active_memory_manager.rst -------------------------------------------------------------------------------- /docs/source/actors.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/actors.rst -------------------------------------------------------------------------------- /docs/source/api.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/api.rst -------------------------------------------------------------------------------- /docs/source/asynchronous.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/asynchronous.rst -------------------------------------------------------------------------------- /docs/source/changelog.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/changelog.rst -------------------------------------------------------------------------------- /docs/source/client.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/client.rst -------------------------------------------------------------------------------- /docs/source/communications.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/communications.rst -------------------------------------------------------------------------------- /docs/source/conf.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/conf.py -------------------------------------------------------------------------------- /docs/source/develop.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/develop.rst -------------------------------------------------------------------------------- /docs/source/diagnosing-performance.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/diagnosing-performance.rst -------------------------------------------------------------------------------- /docs/source/efficiency.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/efficiency.rst -------------------------------------------------------------------------------- /docs/source/examples-overview.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/examples-overview.rst -------------------------------------------------------------------------------- /docs/source/examples/word-count.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/examples/word-count.rst -------------------------------------------------------------------------------- /docs/source/faq.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/faq.rst -------------------------------------------------------------------------------- /docs/source/fine-performance-metrics.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/fine-performance-metrics.rst -------------------------------------------------------------------------------- /docs/source/foundations.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/foundations.rst -------------------------------------------------------------------------------- /docs/source/http_services.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/http_services.rst -------------------------------------------------------------------------------- /docs/source/images/fine-performance-metrics/bytes.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/fine-performance-metrics/bytes.png -------------------------------------------------------------------------------- /docs/source/images/fine-performance-metrics/seconds-IO.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/fine-performance-metrics/seconds-IO.png -------------------------------------------------------------------------------- /docs/source/images/fine-performance-metrics/seconds-full.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/fine-performance-metrics/seconds-full.png -------------------------------------------------------------------------------- /docs/source/images/fine-performance-metrics/seconds-not-IO.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/fine-performance-metrics/seconds-not-IO.png -------------------------------------------------------------------------------- /docs/source/images/fine-performance-metrics/spans.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/fine-performance-metrics/spans.png -------------------------------------------------------------------------------- /docs/source/images/memory-sampler.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/memory-sampler.svg -------------------------------------------------------------------------------- /docs/source/images/network.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/network.png -------------------------------------------------------------------------------- /docs/source/images/network.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/network.svg -------------------------------------------------------------------------------- /docs/source/images/run_dot.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/run_dot.sh -------------------------------------------------------------------------------- /docs/source/images/scheduler-detailed.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/scheduler-detailed.png -------------------------------------------------------------------------------- /docs/source/images/scheduler-detailed.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/scheduler-detailed.svg -------------------------------------------------------------------------------- /docs/source/images/task-state.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/task-state.dot -------------------------------------------------------------------------------- /docs/source/images/task-state.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/task-state.svg -------------------------------------------------------------------------------- /docs/source/images/worker-cancel-state1.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-cancel-state1.dot -------------------------------------------------------------------------------- /docs/source/images/worker-cancel-state1.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-cancel-state1.svg -------------------------------------------------------------------------------- /docs/source/images/worker-cancel-state2.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-cancel-state2.dot -------------------------------------------------------------------------------- /docs/source/images/worker-cancel-state2.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-cancel-state2.svg -------------------------------------------------------------------------------- /docs/source/images/worker-dep-state.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-dep-state.dot -------------------------------------------------------------------------------- /docs/source/images/worker-dep-state.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-dep-state.svg -------------------------------------------------------------------------------- /docs/source/images/worker-execute-state.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-execute-state.dot -------------------------------------------------------------------------------- /docs/source/images/worker-execute-state.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-execute-state.svg -------------------------------------------------------------------------------- /docs/source/images/worker-forget-state.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-forget-state.dot -------------------------------------------------------------------------------- /docs/source/images/worker-forget-state.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-forget-state.svg -------------------------------------------------------------------------------- /docs/source/images/worker-scatter-state.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-scatter-state.dot -------------------------------------------------------------------------------- /docs/source/images/worker-scatter-state.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-scatter-state.svg -------------------------------------------------------------------------------- /docs/source/images/worker-state-machine.dot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-state-machine.dot -------------------------------------------------------------------------------- /docs/source/images/worker-state-machine.svg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/images/worker-state-machine.svg -------------------------------------------------------------------------------- /docs/source/index.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/index.rst -------------------------------------------------------------------------------- /docs/source/install.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/install.rst -------------------------------------------------------------------------------- /docs/source/journey.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/journey.rst -------------------------------------------------------------------------------- /docs/source/killed.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/killed.rst -------------------------------------------------------------------------------- /docs/source/limitations.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/limitations.rst -------------------------------------------------------------------------------- /docs/source/locality.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/locality.rst -------------------------------------------------------------------------------- /docs/source/logging.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/logging.rst -------------------------------------------------------------------------------- /docs/source/manage-computation.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/manage-computation.rst -------------------------------------------------------------------------------- /docs/source/memory.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/memory.rst -------------------------------------------------------------------------------- /docs/source/plugins.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/plugins.rst -------------------------------------------------------------------------------- /docs/source/priority.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/priority.rst -------------------------------------------------------------------------------- /docs/source/prometheus.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/prometheus.rst -------------------------------------------------------------------------------- /docs/source/protocol.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/protocol.rst -------------------------------------------------------------------------------- /docs/source/publish.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/publish.rst -------------------------------------------------------------------------------- /docs/source/queues.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/queues.rst -------------------------------------------------------------------------------- /docs/source/quickstart.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/quickstart.rst -------------------------------------------------------------------------------- /docs/source/related-work.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/related-work.rst -------------------------------------------------------------------------------- /docs/source/resilience.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/resilience.rst -------------------------------------------------------------------------------- /docs/source/resources.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/resources.rst -------------------------------------------------------------------------------- /docs/source/scheduling-policies.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/scheduling-policies.rst -------------------------------------------------------------------------------- /docs/source/scheduling-state.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/scheduling-state.rst -------------------------------------------------------------------------------- /docs/source/serialization.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/serialization.rst -------------------------------------------------------------------------------- /docs/source/spans.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/spans.rst -------------------------------------------------------------------------------- /docs/source/task-launch.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/task-launch.rst -------------------------------------------------------------------------------- /docs/source/tls.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/tls.rst -------------------------------------------------------------------------------- /docs/source/work-stealing.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/work-stealing.rst -------------------------------------------------------------------------------- /docs/source/worker-memory.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/worker-memory.rst -------------------------------------------------------------------------------- /docs/source/worker-state.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/worker-state.rst -------------------------------------------------------------------------------- /docs/source/worker.rst: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/docs/source/worker.rst -------------------------------------------------------------------------------- /pyproject.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/dask/distributed/HEAD/pyproject.toml --------------------------------------------------------------------------------