dask / distributed

A distributed task scheduler for Dask
https://distributed.dask.org
BSD 3-Clause "New" or "Revised" License
1.56k stars 715 forks source link

Dask RuntimeError: Cluster failed to start: 'str' object has no attribute 'decode' #7690

Closed robomike closed 1 year ago

robomike commented 1 year ago

add support for multiple GPUs

from cuml.dask.common import utils as dask_utils from dask_cuda import LocalCUDACluster from dask.distributed import Client

import the dask linear regression model

from cuml.dask.linear_model import LinearRegression as dask_LinearRegression

cluster = LocalCUDACluster() client = Client(cluster)


2023-03-21 10:48:45,893 - distributed.deploy.spec - WARNING - Cluster closed without starting up Output exceeds the size limit. Open the full output data in a text editor

AttributeError Traceback (most recent call last) File ~/miniconda3/envs/rapids-23.02/lib/python3.10/site-packages/distributed/deploy/spec.py:319, in SpecCluster._start(self) 318 cls = import_term(cls) --> 319 self.scheduler = cls(**self.scheduler_spec.get("options", {})) 320 self.scheduler = await self.scheduler

File ~/miniconda3/envs/rapids-23.02/lib/python3.10/site-packages/distributed/scheduler.py:3662, in Scheduler.init(self, loop, delete_interval, synchronize_worker_interval, services, service_kwargs, allowed_failures, extensions, validate, scheduler_file, security, worker_ttl, idle_timeout, interface, host, port, protocol, dashboard_address, dashboard, http_prefix, preload, preload_argv, plugins, contact_address, transition_counter_max, jupyter, kwargs) 3648 SchedulerState.init( 3649 self, 3650 aliases=aliases, (...) 3660 transition_counter_max=transition_counter_max, 3661 ) -> 3662 ServerNode.init( 3663 self, 3664 handlers=self.handlers, 3665 stream_handlers=merge(worker_handlers, client_handlers), 3666 connection_limit=connection_limit, 3667 deserialize=False, 3668 connection_args=self.connection_args, 3669 kwargs, 3670 ) 3672 if self.worker_ttl: ... 328 self.status = Status.failed 329 await self._close() --> 330 raise RuntimeError(f"Cluster failed to start: {e}") from e

RuntimeError: Cluster failed to start: 'str' object has no attribute 'decode'


pynvml.nvmlInit() pynvml.nvmlSystemGetDriverVersion() '525.78.01' pynvml.nvmlSystemGetNVMLVersion() '12.525.78.01'


(rapids-23.02) futuregen@futuregen-System-Product-Name:~/code/predictiveAnalytics$ pip freeze aiofiles @ file:///home/conda/feedstock_root/build_artifacts/aiofiles_1664378549280/work aiohttp @ file:///home/conda/feedstock_root/build_artifacts/aiohttp_1676292661248/work aiosignal @ file:///home/conda/feedstock_root/build_artifacts/aiosignal_1667935791922/work aiosqlite @ file:///home/conda/feedstock_root/build_artifacts/aiosqlite_1671461885930/work anyio @ file:///home/conda/feedstock_root/build_artifacts/anyio_1666191106763/work/dist appdirs @ file:///home/conda/feedstock_root/build_artifacts/appdirs_1603108395799/work apriltag==0.0.16 argon2-cffi @ file:///home/conda/feedstock_root/build_artifacts/argon2-cffi_1640817743617/work argon2-cffi-bindings @ file:///home/conda/feedstock_root/build_artifacts/argon2-cffi-bindings_1666850768662/work asttokens==2.2.1 async-timeout @ file:///home/conda/feedstock_root/build_artifacts/async-timeout_1640026696943/work attrs @ file:///home/conda/feedstock_root/build_artifacts/attrs_1671632566681/work Babel @ file:///home/conda/feedstock_root/build_artifacts/babel_1677767029043/work backcall==0.2.0 backports.functools-lru-cache @ file:///home/conda/feedstock_root/build_artifacts/backports.functools_lru_cache_1618230623929/work beautifulsoup4 @ file:///home/conda/feedstock_root/build_artifacts/beautifulsoup4_1679322162244/work bleach @ file:///home/conda/feedstock_root/build_artifacts/bleach_1674535352125/work bokeh @ file:///home/conda/feedstock_root/build_artifacts/bokeh_1660586590972/work branca @ file:///home/conda/feedstock_root/build_artifacts/branca_1667848736831/work Brotli @ file:///home/conda/feedstock_root/build_artifacts/brotli-split_1666788425425/work brotlipy @ file:///home/conda/feedstock_root/build_artifacts/brotlipy_1666764671472/work cachetools @ file:///home/conda/feedstock_root/build_artifacts/cachetools_1674482203741/work certifi==2022.12.7 cffi @ file:///home/conda/feedstock_root/build_artifacts/cffi_1671179353105/work charset-normalizer @ file:///home/conda/feedstock_root/build_artifacts/charset-normalizer_1661170624537/work click @ file:///home/conda/feedstock_root/build_artifacts/click_1666798198223/work click-plugins==1.1.1 cligj @ file:///home/conda/feedstock_root/build_artifacts/cligj_1633637764473/work cloudpickle @ file:///home/conda/feedstock_root/build_artifacts/cloudpickle_1674202310934/work colorama @ file:///home/conda/feedstock_root/build_artifacts/colorama_1666700638685/work colorcet @ file:///home/conda/feedstock_root/build_artifacts/colorcet_1664843244467/work comm==0.1.2 contourpy @ file:///home/conda/feedstock_root/build_artifacts/contourpy_1673633665736/work cryptography @ file:///home/conda/feedstock_root/build_artifacts/cryptography-split_1677821274828/work cubinlinker @ file:///home/conda/feedstock_root/build_artifacts/cubinlinker_1669932549674/work cucim==23.2.0 cuda-python @ file:///home/conda/feedstock_root/build_artifacts/cuda-python_1670580728957/work cudf==23.2.0 cugraph @ file:///opt/conda/conda-bld/work/python/cugraph cuml==23.2.0 cupy @ file:///home/conda/feedstock_root/build_artifacts/cupy_1677786697638/work cusignal==23.2.0 cuspatial==23.2.0 cuxfilter==23.2.0 cycler @ file:///home/conda/feedstock_root/build_artifacts/cycler_1635519461629/work cytoolz @ file:///home/conda/feedstock_root/build_artifacts/cytoolz_1666829662037/work dash @ file:///home/conda/feedstock_root/build_artifacts/dash_1679123358017/work dask @ file:///home/conda/feedstock_root/build_artifacts/dask-core_1674873905639/work dask-cuda @ file:///opt/conda/conda-bld/work dask-cudf==23.2.0 datashader==0.13.1a0 datashape==0.5.4 debugpy==1.6.6 decorator @ file:///home/conda/feedstock_root/build_artifacts/decorator_1641555617451/work defusedxml @ file:///home/conda/feedstock_root/build_artifacts/defusedxml_1615232257335/work distributed @ file:///home/conda/feedstock_root/build_artifacts/distributed_1674878344345/work entrypoints @ file:///home/conda/feedstock_root/build_artifacts/entrypoints_1643888246732/work executing==1.2.0 fastavro @ file:///home/conda/feedstock_root/build_artifacts/fastavro_1678386936540/work fastjsonschema @ file:///home/conda/feedstock_root/build_artifacts/python-fastjsonschema_1677336799617/work/dist fastrlock==0.8 Fiona @ file:///home/conda/feedstock_root/build_artifacts/fiona_1667566189417/work Flask @ file:///home/conda/feedstock_root/build_artifacts/flask_1676592993069/work Flask-Compress @ file:///home/conda/feedstock_root/build_artifacts/flask-compress_1663772969809/work flit_core @ file:///home/conda/feedstock_root/build_artifacts/flit-core_1667734568827/work/source/flit_core folium @ file:///home/conda/feedstock_root/build_artifacts/folium_1670956290671/work fonttools @ file:///home/conda/feedstock_root/build_artifacts/fonttools_1678999666001/work frozenlist @ file:///home/conda/feedstock_root/build_artifacts/frozenlist_1667935435842/work fsspec @ file:///home/conda/feedstock_root/build_artifacts/fsspec_1678112553830/work GDAL==3.5.3 geopandas @ file:///home/conda/feedstock_root/build_artifacts/geopandas_1670698600430/work HeapDict==1.0.1 holoviews @ file:///home/conda/feedstock_root/build_artifacts/holoviews_1670920091880/work idna @ file:///home/conda/feedstock_root/build_artifacts/idna_1663625384323/work imagecodecs @ file:///home/conda/feedstock_root/build_artifacts/imagecodecs_1671885549045/work imageio @ file:///home/conda/feedstock_root/build_artifacts/imageio_1677507485990/work importlib-metadata @ file:///home/conda/feedstock_root/build_artifacts/importlib-metadata_1679167925176/work importlib-resources @ file:///home/conda/feedstock_root/build_artifacts/importlib_resources_1676919000169/work ipykernel==6.21.2 ipython==8.10.0 ipython-genutils==0.2.0 ipywidgets @ file:///home/conda/feedstock_root/build_artifacts/ipywidgets_1671720089366/work itsdangerous @ file:///home/conda/feedstock_root/build_artifacts/itsdangerous_1648147185463/work jedi==0.18.2 Jinja2 @ file:///home/conda/feedstock_root/build_artifacts/jinja2_1654302431367/work joblib @ file:///home/conda/feedstock_root/build_artifacts/joblib_1663332044897/work json5 @ file:///home/conda/feedstock_root/build_artifacts/json5_1600692310011/work jsonschema @ file:///home/conda/feedstock_root/build_artifacts/jsonschema-meta_1669810440410/work jupyter-events @ file:///home/conda/feedstock_root/build_artifacts/jupyter_events_1673559782596/work jupyter-server-proxy @ file:///home/conda/feedstock_root/build_artifacts/jupyter-server-proxy_1662628585242/work jupyter-ydoc @ file:///home/conda/feedstock_root/build_artifacts/jupyter_ydoc_1679325289144/work/dist jupyter_client @ file:///home/conda/feedstock_root/build_artifacts/jupyter_client_1676579893731/work jupyter_core==5.2.0 jupyter_server @ file:///home/conda/feedstock_root/build_artifacts/jupyter_server_1679073341944/work jupyter_server_fileid @ file:///home/conda/feedstock_root/build_artifacts/jupyter_server_fileid_1677220209229/work jupyter_server_terminals @ file:///home/conda/feedstock_root/build_artifacts/jupyter_server_terminals_1673491454549/work jupyter_server_ydoc @ file:///home/conda/feedstock_root/build_artifacts/jupyter_server_ydoc_1678043727957/work jupyterlab @ file:///home/conda/feedstock_root/build_artifacts/jupyterlab_1679327603632/work jupyterlab-pygments @ file:///home/conda/feedstock_root/build_artifacts/jupyterlab_pygments_1649936611996/work jupyterlab-widgets @ file:///home/conda/feedstock_root/build_artifacts/jupyterlab_widgets_1671722028097/work jupyterlab_server @ file:///home/conda/feedstock_root/build_artifacts/jupyterlab_server_1678139120126/work kiwisolver @ file:///home/conda/feedstock_root/build_artifacts/kiwisolver_1666805701884/work llvmlite==0.39.1 locket @ file:///home/conda/feedstock_root/build_artifacts/locket_1650660393415/work lz4 @ file:///home/conda/feedstock_root/build_artifacts/lz4_1675806673645/work mapclassify @ file:///home/conda/feedstock_root/build_artifacts/mapclassify_1673861555770/work Markdown @ file:///home/conda/feedstock_root/build_artifacts/markdown_1657921053229/work MarkupSafe @ file:///home/conda/feedstock_root/build_artifacts/markupsafe_1674135787083/work matplotlib @ file:///home/conda/feedstock_root/build_artifacts/matplotlib-suite_1678135565516/work matplotlib-inline==0.1.6 mistune @ file:///home/conda/feedstock_root/build_artifacts/mistune_1675771498296/work msgpack @ file:///home/conda/feedstock_root/build_artifacts/msgpack-python_1678312712169/work multidict @ file:///home/conda/feedstock_root/build_artifacts/multidict_1672339403932/work multipledispatch==0.6.0 munch==2.5.0 munkres==1.1.4 nbclassic @ file:///home/conda/feedstock_root/build_artifacts/nbclassic_1678277563913/work nbclient @ file:///home/conda/feedstock_root/build_artifacts/nbclient_1669795076334/work nbconvert @ file:///home/conda/feedstock_root/build_artifacts/nbconvert-meta_1674590374792/work nbformat @ file:///home/conda/feedstock_root/build_artifacts/nbformat_1673560067442/work nest-asyncio==1.5.6 networkx @ file:///home/conda/feedstock_root/build_artifacts/networkx_1673151334029/work notebook @ file:///home/conda/feedstock_root/build_artifacts/notebook_1678109761260/work notebook_shim @ file:///home/conda/feedstock_root/build_artifacts/notebook-shim_1667478401171/work numba @ file:///home/conda/feedstock_root/build_artifacts/numba_1669103970038/work numpy @ file:///home/conda/feedstock_root/build_artifacts/numpy_1668919096861/work nvtx @ file:///home/conda/feedstock_root/build_artifacts/nvtx_1667383032221/work packaging @ file:///home/conda/feedstock_root/build_artifacts/packaging_1673482170163/work pandas==1.5.3 pandocfilters @ file:///home/conda/feedstock_root/build_artifacts/pandocfilters_1631603243851/work panel @ file:///home/conda/feedstock_root/build_artifacts/panel_1667466777996/work param @ file:///home/conda/feedstock_root/build_artifacts/param_1678790747312/work parso==0.8.3 partd @ file:///home/conda/feedstock_root/build_artifacts/partd_1660316728562/work pexpect @ file:///home/conda/feedstock_root/build_artifacts/pexpect_1667297516076/work pickleshare==0.7.5 Pillow @ file:///home/conda/feedstock_root/build_artifacts/pillow_1675487172403/work pkgutil_resolve_name @ file:///home/conda/feedstock_root/build_artifacts/pkgutil-resolve-name_1633981968097/work platformdirs==3.0.0 plotly @ file:///home/conda/feedstock_root/build_artifacts/plotly_1677271849976/work pooch @ file:///home/conda/feedstock_root/build_artifacts/pooch_1677600624926/work prometheus-client @ file:///home/conda/feedstock_root/build_artifacts/prometheus_client_1674535637125/work prompt-toolkit==3.0.37 protobuf==4.21.12 psutil @ file:///home/conda/feedstock_root/build_artifacts/psutil_1667885877572/work ptxcompiler @ file:///home/conda/feedstock_root/build_artifacts/ptxcompiler_1669972017279/work ptyprocess @ file:///home/conda/feedstock_root/build_artifacts/ptyprocess_1609419310487/work/dist/ptyprocess-0.7.0-py2.py3-none-any.whl pure-eval==0.2.2 pyarrow==10.0.1 pycparser @ file:///home/conda/feedstock_root/build_artifacts/pycparser_1636257122734/work pyct==0.4.6 pydeck @ file:///home/conda/feedstock_root/build_artifacts/pydeck_1603714958102/work pyee @ file:///home/conda/feedstock_root/build_artifacts/pyee_1644152123334/work Pygments @ file:///home/conda/feedstock_root/build_artifacts/pygments_1672682006896/work pylibcugraph @ file:///opt/conda/conda-bld/work/python/pylibcugraph pylibraft==23.2.0 pynvml @ file:///home/conda/feedstock_root/build_artifacts/pynvml_1676513396402/work pyOpenSSL @ file:///home/conda/feedstock_root/build_artifacts/pyopenssl_1672659226110/work pyparsing @ file:///home/conda/feedstock_root/build_artifacts/pyparsing_1652235407899/work pyppeteer @ file:///home/conda/feedstock_root/build_artifacts/pyppeteer_1643233645996/work pyproj @ file:///home/conda/feedstock_root/build_artifacts/pyproj_1666938623924/work pyrsistent @ file:///home/conda/feedstock_root/build_artifacts/pyrsistent_1672681463845/work PySocks @ file:///home/conda/feedstock_root/build_artifacts/pysocks_1661604839144/work python-dateutil==2.8.2 python-json-logger @ file:///home/conda/feedstock_root/build_artifacts/python-json-logger_1677079630776/work pytz @ file:///home/conda/feedstock_root/build_artifacts/pytz_1673864280276/work pyviz-comms @ file:///home/conda/feedstock_root/build_artifacts/pyviz_comms_1661341338467/work PyWavelets @ file:///home/conda/feedstock_root/build_artifacts/pywavelets_1673082339639/work PyYAML @ file:///home/conda/feedstock_root/build_artifacts/pyyaml_1666772395347/work pyzmq==25.0.0 raft-dask==23.2.0 requests @ file:///home/conda/feedstock_root/build_artifacts/requests_1673863902341/work rfc3339-validator @ file:///home/conda/feedstock_root/build_artifacts/rfc3339-validator_1638811747357/work rfc3986-validator @ file:///home/conda/feedstock_root/build_artifacts/rfc3986-validator_1598024191506/work rmm==23.2.0 Rtree @ file:///home/conda/feedstock_root/build_artifacts/rtree_1666813265145/work scikit-image @ file:///home/conda/feedstock_root/build_artifacts/scikit-image_1667117143644/work scikit-learn @ file:///home/conda/feedstock_root/build_artifacts/scikit-learn_1678356544388/work scipy==1.10.1 Send2Trash @ file:///home/conda/feedstock_root/build_artifacts/send2trash_1628511208346/work shapely @ file:///home/conda/feedstock_root/build_artifacts/shapely_1675079591791/work simpervisor @ file:///home/conda/feedstock_root/build_artifacts/simpervisor_1609865618711/work six @ file:///home/conda/feedstock_root/build_artifacts/six_1620240208055/work sniffio @ file:///home/conda/feedstock_root/build_artifacts/sniffio_1662051266223/work sortedcontainers @ file:///home/conda/feedstock_root/build_artifacts/sortedcontainers_1621217038088/work soupsieve @ file:///home/conda/feedstock_root/build_artifacts/soupsieve_1658207591808/work stack-data==0.6.2 tblib @ file:///home/conda/feedstock_root/build_artifacts/tblib_1616261298899/work tenacity @ file:///home/conda/feedstock_root/build_artifacts/tenacity_1677600641219/work terminado @ file:///home/conda/feedstock_root/build_artifacts/terminado_1670253674810/work threadpoolctl @ file:///home/conda/feedstock_root/build_artifacts/threadpoolctl_1643647933166/work tifffile @ file:///home/conda/feedstock_root/build_artifacts/tifffile_1665588749940/work tinycss2 @ file:///home/conda/feedstock_root/build_artifacts/tinycss2_1666100256010/work tomli @ file:///home/conda/feedstock_root/build_artifacts/tomli_1644342247877/work toolz @ file:///home/conda/feedstock_root/build_artifacts/toolz_1657485559105/work tornado==6.2 tqdm @ file:///home/conda/feedstock_root/build_artifacts/tqdm_1677948868469/work traitlets==5.9.0 treelite==3.1.0 treelite-runtime==3.1.0 typing_extensions @ file:///home/conda/feedstock_root/build_artifacts/typing_extensions_1678559861143/work ucx-py @ file:///opt/conda/conda-bld/work unicodedata2 @ file:///home/conda/feedstock_root/build_artifacts/unicodedata2_1667239886688/work urllib3 @ file:///home/conda/feedstock_root/build_artifacts/urllib3_1678635778344/work wcwidth==0.2.6 webencodings==0.5.1 websocket-client @ file:///home/conda/feedstock_root/build_artifacts/websocket-client_1675567828044/work websockets @ file:///home/conda/feedstock_root/build_artifacts/websockets_1666806213473/work Werkzeug @ file:///home/conda/feedstock_root/build_artifacts/werkzeug_1676411946679/work widgetsnbextension @ file:///home/conda/feedstock_root/build_artifacts/widgetsnbextension_1672066693230/work xarray @ file:///home/conda/feedstock_root/build_artifacts/xarray_1675801625528/work xyzservices @ file:///home/conda/feedstock_root/build_artifacts/xyzservices_1676835466992/work y-py @ file:///home/conda/feedstock_root/build_artifacts/y-py_1677231008299/work yarl @ file:///home/conda/feedstock_root/build_artifacts/yarl_1672340954791/work ypy-websocket @ file:///home/conda/feedstock_root/build_artifacts/ypy-websocket_1670333059911/work zict @ file:///home/conda/feedstock_root/build_artifacts/zict_1651156074437/work zipp @ file:///home/conda/feedstock_root/build_artifacts/zipp_1677313463193/work

jrbourbeau commented 1 year ago

Thanks for the issue @robomike. It looks like this might be a duplicate of https://github.com/dask/distributed/issues/5768. I can't tell from what you've posted what version of distributed you're using. The fix for https://github.com/dask/distributed/issues/5768 was included in the distributed=2023.2.1 release

robomike commented 1 year ago

I've installed it with Rapids:

conda create -n rapids-23.02 -c rapidsai -c conda-forge -c nvidia \ cudf=23.02 cuml=23.02 cugraph=23.02 cuspatial=23.02 cuxfilter=23.02 cusignal=23.02 cucim=23.02 python=3.10 cudatoolkit=11.8 \ jupyterlab dash

jrbourbeau commented 1 year ago

What version of distributed does that end up installing? Does using distributed>=2023.2.1 fix the problem? Also cc @pentschev for visibility

robomike commented 1 year ago

distributed 2023.1.1 pyhd8ed1ab_0 conda-forge

robomike commented 1 year ago

i tried to perform conda upgrade distributed but the version did not change. Is the latest fix on the conda environment?

jrbourbeau commented 1 year ago

The latest distributed release on conda-forge is 2023.3.1 but I know RAPIDS pins tightly to dask and distributed. @charlesbluca @quasiben @jakirkham any insight into what versions @robomike should be using to get distributed>=2023.2.1?

pentschev commented 1 year ago

RAPIDS 23.02 pins to distributed==2023.1.1, see https://github.com/rapidsai/dask-cuda/blob/d281b83d5a5420e55b6679c0b96d8ac87b678e71/dependencies.yaml#L98-L99 . If you need a fix that is included in distributed>=2023.2.1 you will need to using RAPIDS nightly builds (23.04).

pentschev commented 1 year ago

Also, I believe you may be already aware of it, but you can get a list of package versions/channels for nightly builds from the RAPIDS release selector.

robomike commented 1 year ago

yes, and that solves this issue :)

rjavierch commented 4 months ago

Hello! I am facing the same error when I want to run the dask tutorial's commands:

from dask.distributed import Client, progress

client = Client(processes=False, threads_per_worker=4, n_workers=1, memory_limit="2GB")
client
{
    "name": "RuntimeError",
    "message": "Cluster failed to start: 'str' object has no attribute 'decode'",
    "stack": "---------------------------------------------------------------------------
AttributeError                            Traceback (most recent call last)
File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/deploy/spec.py:324, in SpecCluster._start(self)
    323     cls = import_term(cls)
--> 324 self.scheduler = cls(**self.scheduler_spec.get(\"options\", {}))
    325 self.scheduler = await self.scheduler

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/scheduler.py:3649, in Scheduler.__init__(self, loop, delete_interval, synchronize_worker_interval, services, service_kwargs, allowed_failures, extensions, validate, scheduler_file, security, worker_ttl, idle_timeout, interface, host, port, protocol, dashboard_address, dashboard, http_prefix, preload, preload_argv, plugins, contact_address, transition_counter_max, jupyter, **kwargs)
   3648 if show_dashboard:
-> 3649     distributed.dashboard.scheduler.connect(
   3650         self.http_application, self.http_server, self, prefix=http_prefix
   3651     )
   3652 scheduler = self

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/dashboard/scheduler.py:170, in connect(application, http_server, scheduler, prefix)
    165 def connect(application, http_server, scheduler, prefix=\"\"):
    166     bokeh_app = BokehApplication(
    167         applications,
    168         scheduler,
    169         prefix=prefix,
--> 170         template_variables=template_variables(scheduler),
    171     )
    172     application.add_application(bokeh_app)

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/cytoolz/functoolz.pyx:489, in cytoolz.functoolz._memoize.__call__()

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/dashboard/scheduler.py:135, in template_variables(scheduler)
    127 from distributed.diagnostics.nvml import device_get_count
    129 template_variables = {
    130     \"pages\": [
    131         \"status\",
    132         \"workers\",
    133         \"tasks\",
    134         \"system\",
--> 135         *([\"gpu\"] if device_get_count() > 0 else []),
    136         \"profile\",
    137         \"graph\",
    138         \"groups\",
    139         \"info\",
    140     ],
    141     \"plots\": [
    142         {
    143             \"url\": x.strip(\"/\"),
    144             \"name\": \" \".join(x.strip(\"/\").split(\"-\")[1:])
    145             .title()
    146             .replace(\"Cpu\", \"CPU\")
    147             .replace(\"Gpu\", \"GPU\")
    148             .replace(\"Rmm\", \"RMM\"),
    149         }
    150         for x in applications
    151         if \"individual\" in x
    152     ]
    153     + [
    154         {\"url\": \"hardware\", \"name\": \"Hardware\"},
    155         {\"url\": \"shuffle\", \"name\": \"Shuffle\"},
    156     ],
    157     \"jupyter\": scheduler.jupyter,
    158 }
    159 template_variables[\"plots\"] = sorted(
    160     template_variables[\"plots\"], key=lambda d: d[\"name\"]
    161 )

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/diagnostics/nvml.py:126, in device_get_count()
    125 def device_get_count():
--> 126     init_once()
    127     if not is_initialized():

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/diagnostics/nvml.py:108, in init_once()
    105     return
    107 if _in_wsl() and parse_version(
--> 108     pynvml.nvmlSystemGetDriverVersion().decode()
    109 ) < parse_version(MINIMUM_WSL_VERSION):
    110     NVML_STATE = NVMLState.DISABLED_WSL_INSUFFICIENT_DRIVER

AttributeError: 'str' object has no attribute 'decode'

The above exception was the direct cause of the following exception:

RuntimeError                              Traceback (most recent call last)
Cell In[1], line 2
      1 from dask.distributed import Client, progress
----> 2 client = Client(processes=False, threads_per_worker=4,
      3                 n_workers=1, memory_limit='2GB')
      4 client

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/client.py:1015, in Client.__init__(self, address, loop, timeout, set_as_default, scheduler_file, security, asynchronous, name, heartbeat_interval, serializers, deserializers, extensions, direct_to_workers, connection_limit, **kwargs)
   1012 preload_argv = dask.config.get(\"distributed.client.preload-argv\")
   1013 self.preloads = preloading.process_preloads(self, preload, preload_argv)
-> 1015 self.start(timeout=timeout)
   1016 Client._instances.add(self)
   1018 from distributed.recreate_tasks import ReplayTaskClient

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/client.py:1217, in Client.start(self, **kwargs)
   1215     self._started = asyncio.ensure_future(self._start(**kwargs))
   1216 else:
-> 1217     sync(self.loop, self._start, **kwargs)

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/utils.py:434, in sync(loop, func, callback_timeout, *args, **kwargs)
    431         wait(10)
    433 if error is not None:
--> 434     raise error
    435 else:
    436     return result

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/utils.py:408, in sync.<locals>.f()
    406         awaitable = wait_for(awaitable, timeout)
    407     future = asyncio.ensure_future(awaitable)
--> 408     result = yield future
    409 except Exception as exception:
    410     error = exception

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/tornado/gen.py:767, in Runner.run(self)
    765 try:
    766     try:
--> 767         value = future.result()
    768     except Exception as e:
    769         # Save the exception for later. It's important that
    770         # gen.throw() not be called inside this try/except block
    771         # because that makes sys.exc_info behave unexpectedly.
    772         exc: Optional[Exception] = e

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/client.py:1283, in Client._start(self, timeout, **kwargs)
   1280 elif self._start_arg is None:
   1281     from distributed.deploy import LocalCluster
-> 1283     self.cluster = await LocalCluster(
   1284         loop=self.loop,
   1285         asynchronous=self._asynchronous,
   1286         **self._startup_kwargs,
   1287     )
   1288     address = self.cluster.scheduler_address
   1290 self._gather_semaphore = asyncio.Semaphore(5)

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/deploy/spec.py:418, in SpecCluster.__await__.<locals>._()
    416 async def _() -> Self:
    417     if self.status == Status.created:
--> 418         await self._start()
    419     await self.scheduler
    420     await self._correct_state()

File ~/miniconda3/envs/gs1/lib/python3.11/site-packages/distributed/deploy/spec.py:335, in SpecCluster._start(self)
    333 self.status = Status.failed
    334 await self._close()
--> 335 raise RuntimeError(f\"Cluster failed to start: {e}\") from e

RuntimeError: Cluster failed to start: 'str' object has no attribute 'decode'"
}

Currently, I am trying to run this in Ubuntu 22.04 (WSL2). The versions of dask and distributed are 2024.2.1 and 2024.2.1, respectively.

The full conda environment is as follows:

# Name                    Version                   Build  Channel
_libgcc_mutex             0.1                 conda_forge    conda-forge
_openmp_mutex             4.5                  2_kmp_llvm    conda-forge
abseil-cpp                20220623.0           h8cdb687_6    conda-forge
absl-py                   2.1.0              pyhd8ed1ab_0    conda-forge
adal                      1.2.7              pyhd8ed1ab_0    conda-forge
adlfs                     2024.2.0           pyhd8ed1ab_0    conda-forge
affine                    2.4.0              pyhd8ed1ab_0    conda-forge
aiohttp                   3.9.3           py311h459d7ec_0    conda-forge
aiohttp-cors              0.7.0                      py_0    conda-forge
aiosignal                 1.3.1              pyhd8ed1ab_0    conda-forge
alsa-lib                  1.2.8                h166bdaf_0    conda-forge
anyio                     4.3.0              pyhd8ed1ab_0    conda-forge
argon2-cffi               23.1.0             pyhd8ed1ab_0    conda-forge
argon2-cffi-bindings      21.2.0          py311h459d7ec_4    conda-forge
arrow                     1.3.0              pyhd8ed1ab_0    conda-forge
arrow-cpp                 11.0.0           ha770c72_5_cpu    conda-forge
asciitree                 0.3.3                      py_2  
asttokens                 2.4.1              pyhd8ed1ab_0    conda-forge
async-lru                 2.0.4              pyhd8ed1ab_0    conda-forge
attr                      2.5.1                h166bdaf_1    conda-forge
attrs                     23.2.0             pyh71513ae_0    conda-forge
aws-c-auth                0.6.24               h84a1944_5    conda-forge
aws-c-cal                 0.5.20               hc60faf5_6    conda-forge
aws-c-common              0.8.11               h0b41bf4_0    conda-forge
aws-c-compression         0.2.16               h034cb4b_3    conda-forge
aws-c-event-stream        0.2.18               h75388cd_6    conda-forge
aws-c-http                0.7.4                hf084cc8_2    conda-forge
aws-c-io                  0.13.17              h10df833_2    conda-forge
aws-c-mqtt                0.8.6                hc41645a_6    conda-forge
aws-c-s3                  0.2.4                h1b8f470_3    conda-forge
aws-c-sdkutils            0.1.7                h034cb4b_3    conda-forge
aws-checksums             0.1.14               h034cb4b_3    conda-forge
aws-crt-cpp               0.19.7               h0073717_7    conda-forge
aws-sdk-cpp               1.10.57              h4707e7a_4    conda-forge
azure-core                1.30.1             pyhd8ed1ab_0    conda-forge
azure-datalake-store      0.0.51             pyh9f0ad1d_0    conda-forge
azure-identity            1.15.0             pyhd8ed1ab_0    conda-forge
azure-storage-blob        12.19.0            pyhd8ed1ab_0    conda-forge
babel                     2.14.0             pyhd8ed1ab_0    conda-forge
beautifulsoup4            4.12.3             pyha770c72_0    conda-forge
blas                      1.0                         mkl    conda-forge
blas-devel                3.9.0            12_linux64_mkl    conda-forge
bleach                    6.1.0              pyhd8ed1ab_0    conda-forge
blessed                   1.20.0          py311h06a4308_0  
blinker                   1.7.0              pyhd8ed1ab_0    conda-forge
blosc                     1.21.5               h0f2a231_0    conda-forge
bokeh                     3.3.4              pyhd8ed1ab_0    conda-forge
boost-cpp                 1.78.0               h5adbc97_2    conda-forge
bottleneck                1.3.8           py311h1f0f07a_0    conda-forge
brotli                    1.0.9                h166bdaf_9    conda-forge
brotli-bin                1.0.9                h166bdaf_9    conda-forge
brotli-python             1.0.9           py311ha362b79_9    conda-forge
bzip2                     1.0.8                hd590300_5    conda-forge
c-ares                    1.27.0               hd590300_0    conda-forge
ca-certificates           2024.2.2             hbcca054_0    conda-forge
cached-property           1.5.2                hd8ed1ab_1    conda-forge
cachetools                5.3.3              pyhd8ed1ab_0    conda-forge
cairo                     1.16.0            ha61ee94_1014    conda-forge
cartopy                   0.22.0          py311h320fe9a_1    conda-forge
certifi                   2024.2.2           pyhd8ed1ab_0    conda-forge
cffi                      1.16.0          py311hb3a22ac_0    conda-forge
cfgrib                    0.9.10.4           pyhd8ed1ab_0    conda-forge
cfitsio                   4.2.0                hd9d235c_0    conda-forge
cftime                    1.6.3           py311h1f0f07a_0    conda-forge
charset-normalizer        3.3.2              pyhd8ed1ab_0    conda-forge
click                     8.1.7           unix_pyh707e725_0    conda-forge
click-plugins             1.1.1                      py_0    conda-forge
cligj                     0.7.2              pyhd8ed1ab_1    conda-forge
cloudpickle               3.0.0              pyhd8ed1ab_0    conda-forge
colorama                  0.4.6              pyhd8ed1ab_0    conda-forge
colorful                  0.5.4              pyhd8ed1ab_0    conda-forge
comm                      0.2.1              pyhd8ed1ab_0    conda-forge
contourpy                 1.2.0           py311h9547e67_0    conda-forge
cryptography              42.0.2          py311hcb13ee4_0    conda-forge
cuda-cudart               12.1.105                      0    nvidia
cuda-cupti                12.1.105                      0    nvidia
cuda-libraries            12.1.0                        0    nvidia
cuda-nvrtc                12.1.105                      0    nvidia
cuda-nvtx                 12.1.105                      0    nvidia
cuda-opencl               12.3.101                      0    nvidia
cuda-runtime              12.1.0                        0    nvidia
cudatoolkit               11.8.0              h4ba93d1_13    conda-forge
cudnn                     8.9.2.26               cuda11_0  
curl                      8.5.0                hdbd6064_0  
cycler                    0.12.1             pyhd8ed1ab_0    conda-forge
cytoolz                   0.12.3          py311h459d7ec_0    conda-forge
dask                      2024.2.1           pyhd8ed1ab_0    conda-forge
dask-core                 2024.2.1           pyhd8ed1ab_0    conda-forge
dbus                      1.13.18              hb2f20db_0  
debugpy                   1.8.1           py311hb755f60_0    conda-forge
decorator                 5.1.1              pyhd8ed1ab_0    conda-forge
defusedxml                0.7.1              pyhd8ed1ab_0    conda-forge
distlib                   0.3.8              pyhd8ed1ab_0    conda-forge
distributed               2024.2.1           pyhd8ed1ab_0    conda-forge
eccodes                   2.29.0               h54fcba4_0    conda-forge
entrypoints               0.4                pyhd8ed1ab_0    conda-forge
esmf                      8.4.1           mpi_mpich_h7b33e6e_100    conda-forge
exceptiongroup            1.2.0              pyhd8ed1ab_2    conda-forge
executing                 2.0.1              pyhd8ed1ab_0    conda-forge
expat                     2.5.0                hcb278e6_1    conda-forge
fasteners                 0.17.3             pyhd8ed1ab_0    conda-forge
ffmpeg                    3.2.4                         1    conda-forge
fftw                      3.3.10          nompi_hc118613_108    conda-forge
filelock                  3.13.1             pyhd8ed1ab_0    conda-forge
findlibs                  0.0.5              pyhd8ed1ab_0    conda-forge
font-ttf-dejavu-sans-mono 2.37                 hab24e00_0    conda-forge
font-ttf-inconsolata      3.000                h77eed37_0    conda-forge
font-ttf-source-code-pro  2.038                h77eed37_0    conda-forge
font-ttf-ubuntu           0.83                 h77eed37_1    conda-forge
fontconfig                2.14.2               h14ed4e7_0    conda-forge
fonts-anaconda            1                    h8fa9717_0  
fonts-conda-ecosystem     1                             0    conda-forge
fonts-conda-forge         1                             0    conda-forge
fonttools                 4.49.0          py311h459d7ec_0    conda-forge
fqdn                      1.5.1              pyhd8ed1ab_0    conda-forge
freeglut                  3.2.2                h9c3ff4c_1    conda-forge
freetype                  2.12.1               h267a509_2    conda-forge
freexl                    1.0.6                h166bdaf_1    conda-forge
frozenlist                1.4.1           py311h459d7ec_0    conda-forge
fsspec                    2024.2.0           pyhca7485f_0    conda-forge
g2clib                    1.6.0                         3    conda-forge
geos                      3.11.1               h27087fc_0    conda-forge
geotiff                   1.7.1                h7a142b4_6    conda-forge
gettext                   0.21.1               h27087fc_0    conda-forge
gflags                    2.2.2             he1b5a44_1004    conda-forge
giflib                    5.2.1                h0b41bf4_3    conda-forge
glib                      2.78.1               hfc55251_0    conda-forge
glib-tools                2.78.1               hfc55251_0    conda-forge
glog                      0.6.0                h6f12383_0    conda-forge
gmp                       6.3.0                h59595ed_0    conda-forge
gmpy2                     2.1.2           py311h6a5fa03_1    conda-forge
gnutls                    3.7.9                hb077bed_0    conda-forge
google-api-core           2.17.1             pyhd8ed1ab_0    conda-forge
google-auth               2.28.1             pyhca7485f_0    conda-forge
google-auth-oauthlib      1.2.0              pyhd8ed1ab_0    conda-forge
googleapis-common-protos  1.62.0             pyhd8ed1ab_0    conda-forge
gpustat                   1.1.1              pyhd8ed1ab_0    conda-forge
graphite2                 1.3.14               h295c915_1  
grpc-cpp                  1.51.1               h27aab58_1    conda-forge
grpcio                    1.51.1          py311hbaf6091_1    conda-forge
gsl                       2.7.1                h6e86dc7_1  
gst-plugins-base          1.22.0               h4243ec0_2    conda-forge
gstreamer                 1.22.0               h25f0c4b_2    conda-forge
gstreamer-orc             0.4.37               hd590300_0    conda-forge
gtest                     1.14.0               h00ab1b0_1    conda-forge
h11                       0.14.0             pyhd8ed1ab_0    conda-forge
h2                        4.1.0              pyhd8ed1ab_0    conda-forge
h5netcdf                  1.3.0              pyhd8ed1ab_0    conda-forge
h5py                      3.8.0           nompi_py311h1db17ec_100    conda-forge
harfbuzz                  6.0.0                h8e241bc_0    conda-forge
hdf4                      4.2.15               h9772cbc_5    conda-forge
hdf5                      1.12.2          mpi_mpich_h5d83325_1    conda-forge
hdfeos2                   2.20              hb955811_1002    conda-forge
hdfeos5                   5.1.16              hc55c121_12    conda-forge
heapdict                  1.0.1                      py_0    conda-forge
hpack                     4.0.0              pyh9f0ad1d_0    conda-forge
httpcore                  1.0.4              pyhd8ed1ab_0    conda-forge
httpx                     0.27.0             pyhd8ed1ab_0    conda-forge
hyperframe                6.0.1              pyhd8ed1ab_0    conda-forge
icu                       70.1                 h27087fc_0    conda-forge
idna                      3.6                pyhd8ed1ab_0    conda-forge
importlib-metadata        7.0.1              pyha770c72_0    conda-forge
importlib_metadata        7.0.1                hd8ed1ab_0    conda-forge
importlib_resources       6.1.2              pyhd8ed1ab_0    conda-forge
intel-openmp              2023.1.0         hdb19cb5_46306  
ipykernel                 6.29.3             pyhd33586a_0    conda-forge
ipython                   8.22.1             pyh707e725_0    conda-forge
ipywidgets                8.1.2              pyhd8ed1ab_0    conda-forge
isodate                   0.6.1              pyhd8ed1ab_0    conda-forge
isoduration               20.11.0            pyhd8ed1ab_0    conda-forge
jack                      1.9.22               h11f4161_0    conda-forge
jasper                    2.0.33               h0ff4b12_1    conda-forge
jedi                      0.19.1             pyhd8ed1ab_0    conda-forge
jinja2                    3.1.3              pyhd8ed1ab_0    conda-forge
joblib                    1.3.2              pyhd8ed1ab_0    conda-forge
jpeg                      9e                   h166bdaf_2    conda-forge
json-c                    0.16                 hc379101_0    conda-forge
json5                     0.9.17             pyhd8ed1ab_0    conda-forge
jsonpointer               2.4             py311h38be061_3    conda-forge
jsonschema                4.21.1             pyhd8ed1ab_0    conda-forge
jsonschema-specifications 2023.12.1          pyhd8ed1ab_0    conda-forge
jsonschema-with-format-nongpl 4.21.1             pyhd8ed1ab_0    conda-forge
jupyter                   1.0.0             pyhd8ed1ab_10    conda-forge
jupyter-lsp               2.2.3              pyhd8ed1ab_0    conda-forge
jupyter_client            8.6.0              pyhd8ed1ab_0    conda-forge
jupyter_console           6.6.3              pyhd8ed1ab_0    conda-forge
jupyter_core              5.7.1           py311h38be061_0    conda-forge
jupyter_events            0.9.0              pyhd8ed1ab_0    conda-forge
jupyter_server            2.12.5             pyhd8ed1ab_0    conda-forge
jupyter_server_terminals  0.5.2              pyhd8ed1ab_0    conda-forge
jupyterlab                4.1.2              pyhd8ed1ab_0    conda-forge
jupyterlab_pygments       0.3.0              pyhd8ed1ab_1    conda-forge
jupyterlab_server         2.25.3             pyhd8ed1ab_0    conda-forge
jupyterlab_widgets        3.0.10             pyhd8ed1ab_0    conda-forge
kealib                    1.5.0                ha7026e8_0    conda-forge
keyutils                  1.6.1                h166bdaf_0    conda-forge
kiwisolver                1.4.5           py311h9547e67_1    conda-forge
krb5                      1.20.1               h81ceb04_0    conda-forge
lame                      3.100             h166bdaf_1003    conda-forge
lcms2                     2.15                 hfd0df8a_0    conda-forge
ld_impl_linux-64          2.40                 h41732ed_0    conda-forge
lerc                      4.0.0                h27087fc_0    conda-forge
libabseil                 20220623.0      cxx17_h05df665_6    conda-forge
libaec                    1.1.2                h59595ed_1    conda-forge
libarrow                  11.0.0           h2ebd325_5_cpu    conda-forge
libblas                   3.9.0            12_linux64_mkl    conda-forge
libbrotlicommon           1.0.9                h166bdaf_9    conda-forge
libbrotlidec              1.0.9                h166bdaf_9    conda-forge
libbrotlienc              1.0.9                h166bdaf_9    conda-forge
libcap                    2.67                 he9d0100_0    conda-forge
libcblas                  3.9.0            12_linux64_mkl    conda-forge
libclang                  15.0.7          default_hb11cfb5_4    conda-forge
libclang13                15.0.7          default_ha2b6cf4_4    conda-forge
libcrc32c                 1.1.2                h9c3ff4c_0    conda-forge
libcublas                 12.1.0.26                     0    nvidia
libcufft                  11.0.2.4                      0    nvidia
libcufile                 1.8.1.2                       0    nvidia
libcups                   2.3.3                h36d4200_3    conda-forge
libcurand                 10.3.4.107                    0    nvidia
libcurl                   8.5.0                h251f7ec_0  
libcusolver               11.4.4.55                     0    nvidia
libcusparse               12.0.2.55                     0    nvidia
libdb                     6.2.32               h9c3ff4c_0    conda-forge
libdeflate                1.17                 h0b41bf4_0    conda-forge
libedit                   3.1.20230828         h5eee18b_0  
libev                     4.33                 hd590300_2    conda-forge
libevent                  2.1.10               h28343ad_4    conda-forge
libexpat                  2.5.0                hcb278e6_1    conda-forge
libffi                    3.4.4                h6a678d5_0  
libflac                   1.4.3                h59595ed_0    conda-forge
libgcc-ng                 13.2.0               h807b86a_5    conda-forge
libgcrypt                 1.10.3               hd590300_0    conda-forge
libgdal                   3.6.2                h6c674c2_9    conda-forge
libgfortran-ng            13.2.0               h69a702a_5    conda-forge
libgfortran5              13.2.0               ha4646dd_5    conda-forge
libgirepository           1.78.1               h003a4f0_1    conda-forge
libglib                   2.78.1               hebfc3b9_0    conda-forge
libglu                    9.0.0             he1b5a44_1001    conda-forge
libgomp                   13.2.0               h807b86a_5    conda-forge
libgoogle-cloud           2.7.0                h21dfe5b_1    conda-forge
libgpg-error              1.48                 h71f35ed_0    conda-forge
libgrpc                   1.51.1               h4fad500_1    conda-forge
libhwloc                  2.9.1                hd6dc26d_0    conda-forge
libiconv                  1.17                 hd590300_2    conda-forge
libidn2                   2.3.7                hd590300_0    conda-forge
libjpeg-turbo             2.1.4                h166bdaf_0    conda-forge
libkml                    1.3.0             h01aab08_1016    conda-forge
liblapack                 3.9.0            12_linux64_mkl    conda-forge
liblapacke                3.9.0            12_linux64_mkl    conda-forge
libllvm15                 15.0.7               hadd5161_1    conda-forge
libnetcdf                 4.9.1           mpi_mpich_hf10a581_1    conda-forge
libnghttp2                1.58.0               h47da74e_0    conda-forge
libnpp                    12.0.2.50                     0    nvidia
libnsl                    2.0.1                hd590300_0    conda-forge
libnvjitlink              12.1.105                      0    nvidia
libnvjpeg                 12.1.1.14                     0    nvidia
libogg                    1.3.5                h27cfd23_1  
libopenblas               0.3.26          pthreads_h413a1c8_0    conda-forge
libopus                   1.3.1                h7f98852_1    conda-forge
libpng                    1.6.43               h2797004_0    conda-forge
libpq                     15.2                 hb675445_0    conda-forge
libprotobuf               3.21.12              hfc55251_2    conda-forge
librttopo                 1.1.0               ha49c73b_12    conda-forge
libsecret                 0.18.8               h329b89f_2    conda-forge
libsndfile                1.2.2                hc60ed4a_1    conda-forge
libsodium                 1.0.18               h36c2ea0_1    conda-forge
libspatialite             5.0.1               h221c8f1_23    conda-forge
libsqlite                 3.45.1               h2797004_0    conda-forge
libssh2                   1.11.0               h0841786_0    conda-forge
libstdcxx-ng              13.2.0               h7e041cc_5    conda-forge
libsystemd0               253                  h8c4010b_1    conda-forge
libtasn1                  4.19.0               h166bdaf_0    conda-forge
libthrift                 0.18.0               h5e4af38_0    conda-forge
libtiff                   4.5.0                h6adf6a1_2    conda-forge
libtool                   2.4.7                h27087fc_0    conda-forge
libudev1                  253                  h0b41bf4_1    conda-forge
libudunits2               2.2.28               h40f5838_3    conda-forge
libunistring              0.9.10               h7f98852_0    conda-forge
libunwind                 1.6.2                h9c3ff4c_0    conda-forge
libutf8proc               2.8.0                h166bdaf_0    conda-forge
libuuid                   2.38.1               h0b41bf4_0    conda-forge
libvorbis                 1.3.7                h9c3ff4c_0    conda-forge
libwebp-base              1.3.2                hd590300_0    conda-forge
libxcb                    1.13              h7f98852_1004    conda-forge
libxkbcommon              1.5.0                h79f4944_1    conda-forge
libxml2                   2.10.3               hca2bb57_4    conda-forge
libzip                    1.10.1               h2629f0a_3    conda-forge
libzlib                   1.2.13               hd590300_5    conda-forge
llvm-openmp               15.0.7               h0cdce71_0    conda-forge
locket                    1.0.0              pyhd8ed1ab_0    conda-forge
lz4                       4.3.3           py311h38e4bf4_0    conda-forge
lz4-c                     1.9.4                hcb278e6_0    conda-forge
markdown                  3.5.2              pyhd8ed1ab_0    conda-forge
markupsafe                2.1.5           py311h459d7ec_0    conda-forge
matplotlib                3.8.3           py311h38be061_0    conda-forge
matplotlib-base           3.8.3           py311h54ef318_0    conda-forge
matplotlib-inline         0.1.6              pyhd8ed1ab_0    conda-forge
mistune                   3.0.2              pyhd8ed1ab_0    conda-forge
mkl                       2021.4.0           h8d4b97c_729    conda-forge
mkl-devel                 2021.4.0           ha770c72_730    conda-forge
mkl-include               2021.4.0           h8d4b97c_729    conda-forge
mkl-service               2.4.0           py311h5eee18b_0  
mpc                       1.3.1                hfe3b2da_0    conda-forge
mpfr                      4.2.1                h9458935_0    conda-forge
mpg123                    1.32.4               h59595ed_0    conda-forge
mpi                       1.0                       mpich    conda-forge
mpich                     4.0.3              h846660c_100    conda-forge
mpmath                    1.3.0              pyhd8ed1ab_0    conda-forge
msal                      1.27.0             pyhd8ed1ab_0    conda-forge
msal_extensions           1.1.0           py311h38be061_1    conda-forge
msgpack-python            1.0.7           py311h9547e67_0    conda-forge
multidict                 6.0.5           py311h459d7ec_0    conda-forge
munkres                   1.1.4              pyh9f0ad1d_0    conda-forge
mysql-common              8.0.33               hf1915f5_6    conda-forge
mysql-libs                8.0.33               hca2cd23_6    conda-forge
nbclient                  0.8.0              pyhd8ed1ab_0    conda-forge
nbconvert                 7.16.1             pyhd8ed1ab_0    conda-forge
nbconvert-core            7.16.1             pyhd8ed1ab_0    conda-forge
nbconvert-pandoc          7.16.1             pyhd8ed1ab_0    conda-forge
nbformat                  5.9.2              pyhd8ed1ab_0    conda-forge
ncl                       6.6.2               ha851dbf_44    conda-forge
ncurses                   6.4                  h59595ed_2    conda-forge
nest-asyncio              1.6.0              pyhd8ed1ab_0    conda-forge
netcdf-fortran            4.6.0           mpi_mpich_ha3603da_3    conda-forge
netcdf4                   1.6.3           nompi_py311ha396515_100    conda-forge
nettle                    3.9.1                h7ab15ed_0    conda-forge
networkx                  3.2.1              pyhd8ed1ab_0    conda-forge
notebook                  7.1.1              pyhd8ed1ab_0    conda-forge
notebook-shim             0.2.4              pyhd8ed1ab_0    conda-forge
nspr                      4.35                 h27087fc_0    conda-forge
nss                       3.98                 h1d7d5a4_0    conda-forge
numcodecs                 0.12.1          py311hb755f60_0    conda-forge
numexpr                   2.8.4           py311h802d673_0  
numpy                     1.26.4          py311h64a7726_0    conda-forge
nvidia-ml-py              12.535.133         pyhd8ed1ab_0    conda-forge
oauthlib                  3.2.2              pyhd8ed1ab_0    conda-forge
opencensus                0.11.3             pyhd8ed1ab_0    conda-forge
opencensus-context        0.1.3           py311h38be061_2    conda-forge
openh264                  2.4.1                h59595ed_0    conda-forge
openjpeg                  2.5.0                hfec8fc6_2    conda-forge
openssl                   3.1.5                hd590300_0    conda-forge
orc                       1.8.2                hfdbbad2_2    conda-forge
overrides                 7.7.0              pyhd8ed1ab_0    conda-forge
p11-kit                   0.24.1               hc5aa10d_0    conda-forge
packaging                 23.2               pyhd8ed1ab_0    conda-forge
pandas                    2.2.1           py311h320fe9a_0    conda-forge
pandoc                    3.1.12.1             ha770c72_0    conda-forge
pandocfilters             1.5.0              pyhd8ed1ab_0    conda-forge
parallelio                2.5.10          mpi_mpich_h773ea27_101    conda-forge
parquet-cpp               1.5.1                         2    conda-forge
parso                     0.8.3              pyhd8ed1ab_0    conda-forge
partd                     1.4.1              pyhd8ed1ab_0    conda-forge
patsy                     0.5.6              pyhd8ed1ab_0    conda-forge
pcre2                     10.40                hc3806b6_0    conda-forge
pexpect                   4.9.0              pyhd8ed1ab_0    conda-forge
pickleshare               0.7.5                   py_1003    conda-forge
pillow                    10.2.0          py311h5eee18b_0  
pip                       24.0               pyhd8ed1ab_0    conda-forge
pixman                    0.43.2               h59595ed_0    conda-forge
pkgutil-resolve-name      1.3.10             pyhd8ed1ab_1    conda-forge
platformdirs              3.11.0             pyhd8ed1ab_0    conda-forge
ply                       3.11                       py_1    conda-forge
poppler                   23.03.0              h091648b_0    conda-forge
poppler-data              0.4.12               hd8ed1ab_0    conda-forge
portalocker               2.8.2           py311h38be061_1    conda-forge
postgresql                15.2                 h3248436_0    conda-forge
proj                      9.1.1                h8ffa02c_2    conda-forge
prometheus_client         0.20.0             pyhd8ed1ab_0    conda-forge
prompt-toolkit            3.0.43          py311h06a4308_0  
prompt_toolkit            3.0.43               hd3eb1b0_0  
protobuf                  4.21.12         py311hcafe171_0    conda-forge
psutil                    5.9.8           py311h459d7ec_0    conda-forge
pthread-stubs             0.4               h36c2ea0_1001    conda-forge
ptyprocess                0.7.0              pyhd3deb0d_0    conda-forge
pulseaudio                16.1                 hcb278e6_3    conda-forge
pulseaudio-client         16.1                 h5195f5e_3    conda-forge
pulseaudio-daemon         16.1                 ha8d29e2_3    conda-forge
pure_eval                 0.2.2              pyhd8ed1ab_0    conda-forge
py-spy                    0.3.14               h87a5ac0_0    conda-forge
pyarrow                   11.0.0          py311hbdf6286_5_cpu    conda-forge
pyarrow-hotfix            0.6                pyhd8ed1ab_0    conda-forge
pyasn1                    0.5.1              pyhd8ed1ab_0    conda-forge
pyasn1-modules            0.3.0              pyhd8ed1ab_0    conda-forge
pycairo                   1.25.0          py311h8feb60e_1    conda-forge
pycparser                 2.21               pyhd8ed1ab_0    conda-forge
pydantic                  1.10.13         py311h459d7ec_1    conda-forge
pygments                  2.17.2             pyhd8ed1ab_0    conda-forge
pygobject                 3.46.0          py311h86ed371_1    conda-forge
pygrib                    2.1.4           py311h0acc61a_6    conda-forge
pyjwt                     2.8.0              pyhd8ed1ab_1    conda-forge
pyngl                     1.6.1           py311hd9db0c4_6    conda-forge
pynio                     1.5.5           py311h5956141_22    conda-forge
pyopenssl                 24.0.0             pyhd8ed1ab_0    conda-forge
pyparsing                 3.1.1              pyhd8ed1ab_0    conda-forge
pyproj                    3.5.0           py311h945b3ca_0    conda-forge
pyqt                      5.15.10         py311h6a678d5_0  
pyqt5-sip                 12.13.0         py311h5eee18b_0  
pyshp                     2.3.1              pyhd8ed1ab_0    conda-forge
pysocks                   1.7.1              pyha2e5f31_6    conda-forge
python                    3.11.6          hab00c5b_0_cpython    conda-forge
python-dateutil           2.8.2              pyhd8ed1ab_0    conda-forge
python-eccodes            1.5.1           py311hcb2cf0a_0    conda-forge
python-fastjsonschema     2.19.1             pyhd8ed1ab_0    conda-forge
python-json-logger        2.0.7              pyhd8ed1ab_0    conda-forge
python-lmdb               1.4.1           py311h8731a88_1    conda-forge
python-tzdata             2024.1             pyhd8ed1ab_0    conda-forge
python_abi                3.11                    4_cp311    conda-forge
pytorch                   2.1.2           py3.11_cuda12.1_cudnn8.9.2_0    pytorch
pytorch-cuda              12.1                 ha16c6d3_5    pytorch
pytorch-mutex             1.0                        cuda    pytorch
pytz                      2024.1             pyhd8ed1ab_0    conda-forge
pyu2f                     0.1.5              pyhd8ed1ab_0    conda-forge
pyyaml                    6.0.1           py311h459d7ec_1    conda-forge
pyzmq                     25.1.2          py311h34ded2d_0    conda-forge
qt-main                   5.15.8               h5d23da1_6    conda-forge
qtconsole                 5.5.1              pyhd8ed1ab_0    conda-forge
qtconsole-base            5.5.1              pyha770c72_0    conda-forge
qtpy                      2.4.1              pyhd8ed1ab_0    conda-forge
rasterio                  1.3.6           py311h567e639_0    conda-forge
ray-core                  2.8.1           py311hb59c3c9_0    conda-forge
ray-default               2.8.1           py311h38be061_0    conda-forge
re2                       2023.02.01           hcb278e6_0    conda-forge
readline                  8.2                  h8228510_1    conda-forge
referencing               0.33.0             pyhd8ed1ab_0    conda-forge
requests                  2.31.0             pyhd8ed1ab_0    conda-forge
requests-oauthlib         1.3.1              pyhd8ed1ab_0    conda-forge
rfc3339-validator         0.1.4              pyhd8ed1ab_0    conda-forge
rfc3986-validator         0.1.1              pyh9f0ad1d_0    conda-forge
rpds-py                   0.18.0          py311h46250e7_0    conda-forge
rsa                       4.9                pyhd8ed1ab_0    conda-forge
s2n                       1.3.37               h3358134_0    conda-forge
scikit-learn              1.4.1.post1     py311hc009520_0    conda-forge
scipy                     1.12.0          py311h64a7726_2    conda-forge
send2trash                1.8.2              pyh41d4057_0    conda-forge
setproctitle              1.3.3           py311h459d7ec_0    conda-forge
setuptools                69.1.1             pyhd8ed1ab_0    conda-forge
shapely                   2.0.1           py311h0f577a2_0    conda-forge
sip                       6.7.12          py311hb755f60_0    conda-forge
six                       1.16.0             pyh6c4a22f_0    conda-forge
smart_open                7.0.1              pyhd8ed1ab_0    conda-forge
snappy                    1.1.10               h9fff704_0    conda-forge
sniffio                   1.3.1              pyhd8ed1ab_0    conda-forge
snuggs                    1.4.7                      py_0    conda-forge
sortedcontainers          2.4.0              pyhd8ed1ab_0    conda-forge
soupsieve                 2.5                pyhd8ed1ab_1    conda-forge
sqlite                    3.45.1               h2c6b66d_0    conda-forge
stack_data                0.6.2              pyhd8ed1ab_0    conda-forge
statsmodels               0.14.1          py311h1f0f07a_0    conda-forge
sympy                     1.12            pypyh9d50eac_103    conda-forge
tbb                       2021.9.0             hf52228f_0    conda-forge
tblib                     3.0.0              pyhd8ed1ab_0    conda-forge
tensorboard               2.16.2             pyhd8ed1ab_0    conda-forge
tensorboard-data-server   0.7.0           py311h63ff55d_1    conda-forge
tensorboard-plugin-wit    1.8.1              pyhd8ed1ab_0    conda-forge
terminado                 0.18.0             pyh0d859eb_0    conda-forge
threadpoolctl             3.3.0              pyhc1e730c_0    conda-forge
tiledb                    2.13.2               hd532e3d_0    conda-forge
tinycss2                  1.2.1              pyhd8ed1ab_0    conda-forge
tk                        8.6.13          noxft_h4845f30_101    conda-forge
toml                      0.10.2             pyhd8ed1ab_0    conda-forge
tomli                     2.0.1              pyhd8ed1ab_0    conda-forge
toolz                     0.12.1             pyhd8ed1ab_0    conda-forge
torchaudio                2.1.2               py311_cu121    pytorch
torchtriton               2.1.0                     py311    pytorch
torchvision               0.15.2          cuda118py311h4cc2eb7_0  
tornado                   6.4             py311h459d7ec_0    conda-forge
tqdm                      4.66.2             pyhd8ed1ab_0    conda-forge
traitlets                 5.14.1             pyhd8ed1ab_0    conda-forge
types-python-dateutil     2.8.19.20240106    pyhd8ed1ab_0    conda-forge
typing-extensions         4.10.0               hd8ed1ab_0    conda-forge
typing_extensions         4.10.0             pyha770c72_0    conda-forge
typing_utils              0.1.0              pyhd8ed1ab_0    conda-forge
tzcode                    2024a                h3f72095_0    conda-forge
tzdata                    2024a                h0c530f3_0    conda-forge
udunits2                  2.2.28               h40f5838_3    conda-forge
uri-template              1.3.0              pyhd8ed1ab_0    conda-forge
uriparser                 0.9.7                h59595ed_1    conda-forge
urllib3                   2.2.1              pyhd8ed1ab_0    conda-forge
virtualenv                20.21.0            pyhd8ed1ab_0    conda-forge
wcwidth                   0.2.13             pyhd8ed1ab_0    conda-forge
webcolors                 1.13               pyhd8ed1ab_0    conda-forge
webencodings              0.5.1              pyhd8ed1ab_2    conda-forge
websocket-client          1.7.0              pyhd8ed1ab_0    conda-forge
werkzeug                  3.0.1              pyhd8ed1ab_0    conda-forge
wheel                     0.42.0             pyhd8ed1ab_0    conda-forge
widgetsnbextension        4.0.10             pyhd8ed1ab_0    conda-forge
wrapt                     1.16.0          py311h459d7ec_0    conda-forge
x264                      1!164.3095           h166bdaf_2    conda-forge
xarray                    2024.2.0           pyhd8ed1ab_0    conda-forge
xbatcher                  0.3.0              pyhd8ed1ab_0    conda-forge
xcb-util                  0.4.0                h516909a_0    conda-forge
xcb-util-image            0.4.0                h166bdaf_0    conda-forge
xcb-util-keysyms          0.4.0                h516909a_0    conda-forge
xcb-util-renderutil       0.3.9                h166bdaf_0    conda-forge
xcb-util-wm               0.4.1                h516909a_0    conda-forge
xerces-c                  3.2.4                h55805fa_1    conda-forge
xkeyboard-config          2.38                 h0b41bf4_0    conda-forge
xorg-fixesproto           5.0               h7f98852_1002    conda-forge
xorg-imake                1.0.7                         0    conda-forge
xorg-inputproto           2.3.2             h7f98852_1002    conda-forge
xorg-kbproto              1.0.7             h7f98852_1002    conda-forge
xorg-libice               1.0.10               h7f98852_0    conda-forge
xorg-libsm                1.2.3             hd9c2040_1000    conda-forge
xorg-libx11               1.8.4                h0b41bf4_0    conda-forge
xorg-libxau               1.0.11               hd590300_0    conda-forge
xorg-libxaw               1.0.14               h7f98852_1    conda-forge
xorg-libxdmcp             1.1.3                h7f98852_0    conda-forge
xorg-libxext              1.3.4                h0b41bf4_2    conda-forge
xorg-libxfixes            5.0.3             h7f98852_1004    conda-forge
xorg-libxi                1.7.10               h7f98852_0    conda-forge
xorg-libxmu               1.1.3                h7f98852_0    conda-forge
xorg-libxpm               3.5.16               hd590300_0    conda-forge
xorg-libxrender           0.9.10            h7f98852_1003    conda-forge
xorg-libxt                1.3.0                hd590300_0    conda-forge
xorg-makedepend           1.0.9                h59595ed_0    conda-forge
xorg-renderproto          0.11.1            h7f98852_1002    conda-forge
xorg-xextproto            7.3.0             h0b41bf4_1003    conda-forge
xorg-xproto               7.0.31            h7f98852_1007    conda-forge
xyzservices               2023.10.1          pyhd8ed1ab_0    conda-forge
xz                        5.4.6                h5eee18b_0  
yaml                      0.2.5                h7f98852_2    conda-forge
yarl                      1.9.4           py311h459d7ec_0    conda-forge
zarr                      2.17.0             pyhd8ed1ab_0    conda-forge
zeromq                    4.3.5                h59595ed_1    conda-forge
zict                      3.0.0              pyhd8ed1ab_0    conda-forge
zipp                      3.17.0             pyhd8ed1ab_0    conda-forge
zlib                      1.2.13               hd590300_5    conda-forge
zstd                      1.5.5                hfc55251_0    conda-forge

Do I have any conflict with the versions I am currently running?