Ray

Latest version: v2.22.0

Safety actively analyzes 630094 Python packages for vulnerabilities to keep your Python projects secure.

Scan your dependencies

Page 2 of 15

2.9.3

Not secure
This patch release contains fixes for Ray Core, Ray Data, and Ray Serve.

Ray Core

🔨 Fixes:

- Fix protobuf breaking change by adding a compat layer. ([43172](https://github.com/ray-project/ray/pull/43172))
- Bump up task failure logs to warnings to make sure failures could be troubleshooted ([43147](https://github.com/ray-project/ray/pull/43147))
- Fix placement group leaks ([42942](https://github.com/ray-project/ray/pull/42942))

Ray Data

🔨 Fixes:

- Skip `schema` call in `to_tf` if `tf.TypeSpec` is provided ([42917](https://github.com/ray-project/ray/pull/42917))
- Skip recording memory spilled stats when get_memory_info_reply is failed ([42824](https://github.com/ray-project/ray/pull/42824))

Ray Serve

🔨 Fixes:

- Fixing DeploymentStateManager qualifying replicas as running prematurely ([43075](https://github.com/ray-project/ray/pull/43075))

Thanks

Many thanks to all those who contributed to this release!

rynewang, GeneDer, alexeykudinkin, edoakes, c21, rkooo567

2.9.2

Not secure
This patch release contains fixes for Ray Core, Ray Data, and Ray Serve.

Ray Core
🔨 Fixes:
- Fix out of disk test on release branch (https://github.com/ray-project/ray/pull/42724)

Ray Data
🔨 Fixes:
- Fix failing huggingface test (https://github.com/ray-project/ray/pull/42727)
- Fix deadlocks caused by streaming_split (https://github.com/ray-project/ray/pull/42601) (https://github.com/ray-project/ray/pull/42755)
- Fix locality config not being respected in DataConfig (https://github.com/ray-project/ray/pull/42204
https://github.com/ray-project/ray/pull/42204) (https://github.com/ray-project/ray/pull/42722)
- Stability & accuracy improvements for Data+Train benchmark (https://github.com/ray-project/ray/pull/42027)
- Add retry for _sample_fragment during `ParquetDatasource._estimate_files_encoding_ratio()` (https://github.com/ray-project/ray/pull/42759) (https://github.com/ray-project/ray/pull/42774)
- Skip recording memory spilled stats when get_memory_info_reply is failed (https://github.com/ray-project/ray/pull/42824) (https://github.com/ray-project/ray/pull/42834)

Ray Serve
🔨 Fixes:
- Pin the fastapi & starlette version to avoid breaking proxy (https://github.com/ray-project/ray/pull/42740
https://github.com/ray-project/ray/pull/42740)
- Fix IS_PYDANTIC_2 logic for pydantic<1.9.0 (https://github.com/ray-project/ray/pull/42704) (https://github.com/ray-project/ray/pull/42708)
- fix missing message body for json log formats (https://github.com/ray-project/ray/pull/42729) (https://github.com/ray-project/ray/pull/42874)

Thanks

Many thanks to all those who contributed to this release!

c21, raulchen, can-anyscale, edoakes, peytondmurray, scottjlee, aslonnie, architkulkarni, GeneDer, Zandew, sihanwang41

2.9.1

Not secure
This patch release contains fixes for Ray Core, Ray Data, and Ray Serve.

Ray Core
🔨 Fixes:
- Adding debupgy as the ray debugger (42311)
- Fix task events profile events per task leak (42248)
- Make sure redis sync context and async context connect to the same redis instance (42040)

Ray Data
🔨 Fixes:
- [Data] Retry write if error during file clean up (42326)

Ray Serve
🔨 Fixes:
- Improve handling the websocket server disconnect scenario (42130)
- Fix pydantic config documentation (42216)
- Address issues under high network delays:
- Enable setting queue length response deadline via environment variable (42001)
- Add exponential backoff for queue_len_response_deadline_s (42041)

2.9.0

Not secure
Release Highlights<a id="release-highlights"></a>

- This release contains fixes for the Ray Dashboard. Additional context can be found here: <https://www.anyscale.com/blog/update-on-ray-cves-cve-2023-6019-cve-2023-6020-cve-2023-6021-cve-2023-48022-cve-2023-48023> 
- Ray Train has now upgraded support for spot node preemption -- allowing Ray Train to handle preemption node failures differently than application errors.
- Ray is now compatible with Pydantic versions <2.0.0 and >=2.5.0, addressing a piece of user feedback we’ve consistently received.
- The Ray Dashboard now has a page for Ray Data to monitor real-time execution metrics.
- [Streaming generator](https://docs.ray.io/en/latest/ray-core/ray-generator.html) is now officially a public API (#41436, 38784). Streaming generator allows writing streaming applications easily on top of Ray via Python generator API and has been used for Ray Serve and Ray data for several releases. See the [documentation](https://docs.ray.io/en/master/ray-core/ray-generator.html) for details. 
- We’ve added experimental support for new accelerators: Intel GPU (38553), Intel Gaudi Accelerators (40561), and Huawei Ascend NPU (41256).

Ray Libraries<a id="ray-libraries"></a>

Ray Data<a id="ray-data"></a>

🎉 New Features:
* Add the dashboard for Ray Data to monitor real-time execution metrics and log file for debugging (<https://docs.ray.io/en/master/data/monitoring-your-workload.html>).
* Introduce `concurrency` argument to replace `ComputeStrategy` in map-like APIs (41461)
* Allow task failures during execution (41226)
* Support PyArrow 14.0.1 (41036)
* Add new API for reading and writing Datasource (<https://github.com/ray-project/ray/issues/40296>)
* Enable group-by over multiple keys in datasets (37832)
* Add support for multiple group keys in `map_groups` (40778)

💫 Enhancements:
- Optimize `OpState.outqueue_num_blocks` (41748)
- Improve stall detection for `StreamingOutputsBackpressurePolicy` (41637)
- Enable read-only Datasets to be executed on new execution backend (41466, 41597)
- Inherit block size from downstream ops (41019)
- Use runtime object memory for scheduling (41383)
- Add retries to file writes (41263)
- Make range datasource streaming (41302)
- Test core performance metrics (40757)
- Allow `ConcurrencyCapBackpressurePolicy._cap_multiplier` to be set to 1.0 (41222)
- Create `StatsManager` to manage `_StatsActor` remote calls (40913)
- Expose `max_retry_cnt` parameter for `BigQuery` Write (41163)
- Add rows outputted to data metrics (40280)
- Add fault tolerance to remote tasks (41084)
- Add operator-level dropdown to ray data overview (40981)
- Avoid slicing too-small blocks (40840)
- Ray Data jobs detail table (40756)
- Update default shuffle block size to 1GB (40839)
- Log progress bar to data logs (40814)
- Operator level metrics (40805)

🔨 Fixes:
- Partial fix for `Dataset.context` not being sealed after creation (41569)
- Fix the issue that `DataContext` is not propagated when using `streaming_split` (41473)
- Fix Parquet partition filter bug (40947)
- Fix split read output blocks (41070)
- Fix `BigQueryDatasource `fault tolerance bugs (40986)

📖 Documentation:
- Add example of how to read and write custom file types (41785)
- Fix `ray.data.read_databricks_tables` doc (41366)
- Add `read_json` docs example for setting PyArrow block size when reading large files (40533)
- Add `AllToAllAPI` to dataset methods (40842)


Ray Train<a id="ray-train"></a>

🎉 New Features:
- Support reading `Result` from cloud storage (40622)

💫 Enhancements:
- Sort local Train workers by GPU ID (40953)
- Improve logging for Train worker scheduling information (40536)
- Load the latest unflattened metrics with `Result.from_path` (40684)
- Skip incrementing failure counter on preemption node died failures (41285)
- Update TensorFlow `ReportCheckpointCallback` to delete temporary directory (41033)

🔨 Fixes:
- Update config dataclass repr to check against None (40851)
- Add a barrier in Lightning `RayTrainReportCallback` to ensure synchronous reporting. (40875)
- Restore Tuner and `Result`s properly from moved storage path (40647)

📖 Documentation:
- Improve torch, lightning quickstarts and migration guides + fix torch restoration example (41843)
- Clarify error message when trying to use local storage for multi-node distributed training and checkpointing (41844)
- Copy edits and adding links to docstrings (39617)
- Fix the missing ray module import in PyTorch Guide (41300)
- Fix typo in lightning_mnist_example.ipynb (40577)
- Fix typo in deepspeed.rst (40320)

🏗 Architecture refactoring:
- Remove Legacy Trainers (41276)


Ray Tune<a id="ray-tune"></a>

🎉 New Features:
- Support reading `Result` from cloud storage (40622)

💫 Enhancements:
- Skip incrementing failure counter on preemption node died failures (41285)

🔨 Fixes:
- Restore Tuner and `Result`s properly from moved storage path (40647)

📖 Documentation:
- Remove low value Tune examples and references to them  (41348)
- Clarify when to use `MLflowLoggerCallback` and `setup_mlflow` (37854)

🏗 Architecture refactoring:
- Delete legacy `TuneClient`/`TuneServer` APIs (41469)
- Delete legacy `Searcher`s (41414)
- Delete legacy persistence utilities (`air.remote_storage`, etc.) (40207)


Ray Serve<a id="ray-serve"></a>

🎉 New Features:
- Introduce logging config so that users can set different logging parameters for different applications & deployments.
- Added gRPC context object into gRPC deployments for user to set custom code and details back to the client.
- Introduce a runtime environment feature that allows running applications in different containers with different images. This feature is experimental and a new guide can be found in the Serve docs.

💫 Enhancements:
- Explicitly handle gRPC proxy task cancellation when the client dropped a request to not waste compute resources. 
- Enable async `__del__` in the deployment to execute custom clean up steps.
- Make Ray Serve compatible with Pydantic versions <2.0.0 and >=2.5.0.

🔨 Fixes:
- Fixed gRPC proxy streaming request latency metrics to include the entire lifecycle of the request, including the time to consume the generator.
- Fixed gRPC proxy timeout request status from CANCELLED to DEADLINE_EXCEEDED.
- Fixed previously Serve shutdown spamming log files with logs for each event loop to only log once on shutdown.
- Fixed issue during batch requests when a request is dropped, the batch loop will be killed and not processed any future requests.
- Updating replica log filenames to only include POSIX-compliant characters (removed the “” character).
- Replicas will now be gracefully shut down after being marked unhealthy due to health check failures instead of being force killed.
- This behavior can be toggled using the environment variable RAY_SERVE_FORCE_STOP_UNHEALTHY_REPLICAS=1, but this is planned to be removed in the near future. If you rely on this behavior, please file an issue on github.


RLlib<a id="rllib"></a>

🎉 New Features:
- New API stack (in progress):
- New `MultiAgentEpisode` class introduced. Basis for upcoming multi-agent EnvRunner, which will replace RolloutWorker APIs. (40263, 40799)
- PPO runs with new `SingleAgentEnvRunner` (w/o Policy/RolloutWorker APIs). CI learning tests added. (39732, 41074, 41075)
- By default: PPO reverted to use old API stack by default, for now. Pending feature-completion of new API stack (incl. multi-agent, RNN support, new EnvRunners, etc..). (40706)
- Old API stack:
- APPO/IMPALA: Enable using 2 separate optimizers for policy and vs (and 2 learning rates) on the old API stack. (40927)
- Added `on_workers_recreated` callback to Algorithm, which is triggered after workers have failed and been restarted. (40354)

💫 Enhancements:
- Old API stack and `rllib_contrib` cleanups: 40939, 40744, 40789, 40444, 37271

🔨 Fixes:
- Restoring from a checkpoint from an older wheel (where `AlgorithmConfig.rl_module_spec` was NOT a “property” yet) breaks when trying to load from this checkpoint. (41157)
- SampleBatch slicing crashes when using tf + SEQ_LENS + zero-padding. (40905)
- Other fixes: 39978, 40788, 41168, 41204

📖 Documentation:
- Updated codeblocks in RLlib. (37271)


Ray Core and Ray Clusters<a id="ray-core-and-ray-clusters"></a>

Ray Core<a id="ray-core"></a>

🎉 New Features:
- [Streaming generator](https://docs.ray.io/en/master/ray-core/ray-generator.html) is now officially a public API (#41436, 38784). Streaming generator allows writing streaming applications easily on top of Ray via Python generator API and has been used for Ray serve and Ray data for several releases. See the [documentation](https://docs.ray.io/en/master/ray-core/ray-generator.html) for details. 
- As part of the change, num_returns=”dynamic” is planning to be deprecated, and its return type is changed from `ObjectRefGenerator` -> “DynamicObjectRefGenerator”
- Add experimental accelerator support for new hardwares.
- Add experimental support for Intel GPU (38553)
- Add experimental support for Intel Gaudi Accelerators (40561)
- Add experimental support for Huawei Ascend NPU (41256)
- Add the initial support to run MPI based code on top of Ray.(40917, 41349)

💫 Enhancements:
- Optimize next/anext performance for streaming generator (41270)
- Make the number of connections and thread number of the object manager client tunable. (41421)
- Add `__ray_call__` default actor method (41534)

🔨 Fixes:
- Fix NullPointerException cause by raylet id is empty when get actor info in java worker (40560)
- Fix a bug where SIGTERM is ignored to worker processes (40210)
- Fix mmap file leak. (40370)
- Fix the lifetime issue in Plasma server client releasing object. (40809)
- Upgrade grpc from 1.50.2 to 1.57.1 to include security fixes (39090)
- Fix the bug where two head nodes are shown from ray list nodes (40838)
- Fix the crash when the GCS address is not valid. (41253)
- Fix the issue of unexpectedly high socket usage in ray core worker processes. (41121)
- Make worker_process_setup_hook work with strings instead of Python functions (41479)


Ray Clusters<a id="ray-clusters"></a>

💫 Enhancements:
- Stability improvements for the vSphere cluster launcher
- Better CLI output for cluster launcher

🔨 Fixes:
- Fixed `run_init` for TPU command runner

📖Documentation:
- Added missing steps and simplified YAML in top-level clusters quickstart
- Clarify that job entrypoints run on the head node by default and how to override it


Dashboard<a id="dashboard"></a>

💫 Enhancements:
- Improvements to the Ray Data Dashboard
- Added Ray Data-specific overview on jobs page, including a table view with Dataset-level metrics
- Added operator-level metrics granularity to drill down on Dataset operators
- Added additional metrics for monitoring iteration over Datasets

Docs<a id="docs"></a>
🎉 New Features:
- Updated to Sphinx version 7.1.2. Previously, the docs build used Sphinx 4.3.2. Upgrading to a recent version provides a more modern user experience while fixing many long standing issues. Let us know how you like the upgrade or any other docs issues on your mind, on the Ray Slack docs channel.

Thanks

Many thanks to all those who contributed to this release!

justinvyu, zcin, avnishn, jonathan-anyscale, shrekris-anyscale, LeonLuttenberger, c21, JingChen23, liuyang-my, ahmed-mahran, huchen2021, raulchen, scottjlee, jiwq, z4y1b2, jjyao, JoshTanke, marxav, ArturNiederfahrenhorst, SongGuyang, jerome-habana, rickyyx, rynewang, batuhanfaik, can-anyscale, allenwang28, wingkitlee0, angelinalg, peytondmurray, rueian, KamenShah, stephanie-wang, bryanjuho, sihanwang41, ericl, sofianhnaide, RaffaGonzo, xychu, simonsays1980, pcmoritz, aslonnie, WeichenXu123, architkulkarni, matthew29tang, larrylian, iycheng, hongchaodeng, rudeigerc, rkooo567, robertnishihara, alanwguo, emmyscode, kevin85421, alexeykudinkin, michaelhly, ijrsvt, ArkAung, mattip, harborn, sven1977, liuxsh9, woshiyyya, hahahannes, GeneDer, vitsai, Zandew, evalaiyc98, edoakes, matthewdeng, bveeramani

2.8.1

Not secure
Release Highlights
The Ray 2.8.1 patch release contains fixes for the Ray Dashboard.

Additional context can be found here: https://www.anyscale.com/blog/update-on-ray-cves-cve-2023-6019-cve-2023-6020-cve-2023-6021-cve-2023-48022-cve-2023-48023

Ray Dashboard
🔨 Fixes:

[core][state][log] Cherry pick changes to prevent state API from reading files outside the Ray log directory (41520)
[Dashboard] Migrate Logs page to use state api. (41474) (41522)

2.8.0

Not secure
Release Highlights
This release features stability improvements and API clean-ups across the Ray libraries.

- In Ray Serve, we are deprecating the previously experimental DAG API for deployment graphs. Model composition will be supported through [deployment handles](https://docs.ray.io/en/latest/serve/model_composition.html) providing more flexibility and stability. The previously deprecated Ray Serve 1.x APIs have also been removed. We’ve also added a new Java APIs that aligns with the Ray Serve 2.x APIs. More API changes in the release notes below.
- In RLlib, we’ve moved 24 algorithms into `rllib_contrib` (still available within RLlib for Ray 2.8).
- We’ve added support for PyTorch-compatible input files shuffling for Ray Data. This allows users to randomly shuffle input files for better model training accuracy. This release also features new Ray Data datasources for Databricks and BigQuery.
- On the Ray Dashboard, we’ve added new metrics for Ray Data in the Metrics tab. This allows users to monitor Ray Data workload including real time metrics of cluster memory, CPU, GPU, output data size, etc. See [the doc](https://docs.ray.io/en/master/data/performance-tips.html#monitoring-your-application) for more details.
- Ray Core now supports profiling GPU tasks or actors using Nvidia Nsight. See [the documentation](https://docs.ray.io/en/master/ray-observability/user-guides/profiling.html?highlight=nsight#nsight-system-profiler) for instructions.
- We fixed 2 critical bugs raised by many kuberay / ML library users, including a child process leak issue from Ray worker that leaks the GPU memory (40182) and an job page excessive loading time issue when Ray HA cluster restarts a head node (40742)
- Python 3.7 support is officially deprecated from Ray.

Ray Libraries
Ray Data
🎉 New Features:
- Add support for shuffling input files (40154)
- Support streaming read of PyTorch dataset (39554)
- Add BigQuery datasource (37380)
- Add Databricks table / SQL datasource (39852)
- Add inverse transform functionality to LabelEncoder (37785)
- Add function arg params to `Dataset.map` and `Dataset.flat_map` (40010)

💫Enhancements:
- Hard deprecate `DatasetPipeline` (40129)
- Remove `BulkExecutor` code path (40200)
- Deprecate extraneous `Dataset` parameters and methods (40385)
- Remove legacy iteration code path (40013)
- Implement streaming output backpressure (40387)
- Cap op concurrency with exponential ramp-up (40275)
- Store ray dashboard metrics in `_StatsActor` (40118)
- Slice output blocks to respect target block size (40248)
- Drop columns before grouping by in `Dataset.unique()` (40016)
- Standardize physical operator runtime metrics (40173)
- Estimate blocks for limit and union operator (40072)
- Store bytes spilled/restored after plan execution (39361)
- Optimize `sample_boundaries` in `SortTaskSpec` (39581)
- Optimization to reduce ArrowBlock building time for blocks of size 1 (38833)

🔨 Fixes:
- Fix bug where `_StatsActor` errors with `PandasBlock` (40481)
- Remove deprecated `do_write` (40422)
- Improve error message when reading HTTP files (40462)
- Add flag to skip `get_object_locations` for metrics (39884)
- Fall back to fetch files info in parallel for multiple directories (39592)
- Replace deprecated `.pieces` with updated `.fragments` (39523)
- Backwards compatibility for `Preprocessor` that have been fit in older versions (39173)
- Removing unnecessary data copy in `convert_udf_returns_to_numpy` (39188)
- Do not eagerly free root `RefBundles` (39016)

📖Documentation:
- Remove out-of-date Data examples (40127)
- Remove unused and outdated source examples (40271)

Ray Train
🎉 New Features:
- Add initial support for scheduling workers on neuron_cores (39091)

💫Enhancements:
- Update PyTorch Lightning import path to support both `pytorch_lightning` and `lightning` (39841, 40266)
- Propagate driver `DataContext` to `RayTrainWorkers` (40116)

🔨 Fixes:
- Fix error propagation for as_directory if to_directory fails (40025)

📖Documentation:
- Update checkpoint hierarchy documentation for RayTrainReportCallbacks. (40174)
- Update Lightning RayDDPStrategy docstring (40376)

🏗 Architecture refactoring:
- Deprecate `LightningTrainer`, `AccelerateTrainer`, `TransformersTrainer (40163)
- Clean up legacy persistence mode code paths (39921, 40061, 40069, 40168)
- Deprecate legacy `DatasetConfig` (39963)
- Remove references to `DatasetPipeline` (40159)
- Enable isort (40172)

Ray Tune
💫Enhancements:
- Separate storage checkpoint index bookkeeping (39927, 40003)
- Raise an error if `Tuner.restore()` is called on an instance (39676)
🏗 Architecture refactoring:
- Clean up legacy persistence mode code paths (39918, 40061, 40069, 40168, 40175, 40192, 40181, 40193)
- Migrate TuneController tests (39704)
- Remove TuneRichReporter (40169)
- Remove legacy Ray Client tests (40415)

Ray Serve
💫Enhancements:
- The single-app configuration format for the [Serve Config](https://docs.ray.io/en/master/serve/production-guide/config.html#serve-in-production-config-file) (i.e. the Serve Config without the ‘applications’ field) has been deprecated in favor of the new configuration format.
Both single-app configuration and DAG API will be removed in 2.9.
- The Serve REST API is now accessible through the dashboard port, which defaults to `8265`.
- Accessing the Serve REST API through the dashboard agent port (default `52365`) is deprecated. The support will be removed in a future version.
- Ray job error tracebacks are now logged in the job driver log for easier access when jobs fail during start up.
- Deprecated single-application config file
- Deprecated DAG API: `InputNode` and `DAGDriver`
- Removed deprecated Deployment 1.x APIs: `Deployment.deploy()`, `Deployment.delete()`, `Deployment.get_handle()`
- Removed deprecated 1.x API: `serve.get_deployment` and `serve.list_deployments`
- New Java API supported (aligns with Ray Serve 2.x API)

🔨 Fixes:
- The `dedicated_cpu` and `detached` options in `serve.start()` have been fully disallowed.
- Error will be raised when users pass invalid gRPC service functions and fail early.
- The proxy’s readiness check now uses a linear backoff to avoid getting stuck in an infinite loop if it takes longer than usual to start.
- `grpc_options` on `serve.start()` was only allowing a `gRPCOptions` object in Ray 2.7.0. Dictionaries are now allowed to be used as`grpc_options` in the `serve.start()` call.

RLlib
💫Enhancements:
- `rllib_contrib` algorithms (A2C, A3C, AlphaStar 36584, AlphaZero 36736, ApexDDPG 36596, ApexDQN 36591, ARS 36607, Bandits 36612, CRR 36616, DDPG, DDPPO 36620, Dreamer(V1), DT 36623, ES 36625, LeelaChessZero 36627, MA-DDPG 36628, MAML, MB-MPO 36662, PG 36666, QMix 36682, R2D2, SimpleQ 36688, SlateQ 36710, and TD3 36726) all produce warnings now if used. See [here](https://github.com/ray-project/ray/tree/master/rllib_contrib#rllib-contrib) for more information on the `rllib_contrib` efforts. (36620, 36628, 3
- Provide msgpack checkpoint translation utility to convert checkpoint into msgpack format for being able to move in between python versions (38825).

🔨 Fixes:
- Issue 35440 (JSON output writer should include INFOS 39632)
- Issue 39453 (PettingZoo wrappers should use correct multi-agent dict spaces 39459)
- Issue 39421 (Multi-discrete action spaces not supported in new stack 39534)
- Issue 39234 (Multi-categorical distribution bug 39464)
39654, 35975, 39552, 38555
Ray Core and Ray Clusters
Ray Core
🎉 New Features:
- Python 3.7 support is officially deprecated from Ray.
- Supports profiling GPU tasks or actors using Nvidia Nsight. See [the doc](https://docs.ray.io/en/master/ray-observability/user-guides/profiling.html?highlight=nsight#nsight-system-profiler) for instructions.
- Ray on spark autoscaling is officially supported from Ray 2.8. See the [REP](https://github.com/ray-project/enhancements/pull/43) for more details.
💫Enhancements:
- IDLE node information in detail is available from ray status -v (39638)
- Adding a new accelerator to Ray is simplified with a new accelerator interface. See the in-flight [REP](https://github.com/ray-project/enhancements/blob/9936d231b4403cdbceb754a674395ffcf9a586e5/reps/2023-10-13-accelerator-support.md) for more details (#40286).
- Typing_extensions is removed from a dependency requirement because Python 3.7 support is deprecated. (40336)
- Ray state API supports case insensitive match. (34577)
- `ray start --runtime-env-agent-port` is officially supported. (39919)
- Driver exit code is available fromjob info (39675)

🔨 Fixes:
- Fixed a worker leak when Ray is used with placement group because Ray didn’t handle SIGTERM properly (40182)
- Fixed an issue job page loading takes a really long time when Ray HA cluster restarts a head node (40431)
- [core] loosen the check on release object (39570)
- [Core] ray init sigterm (39816)
- [Core] Non Unit Instance fractional value fix (39293)
- [Core]: Enable get_actor_name for actor runtime context (39347)
- [core][streaming][python] Fix asyncio.wait coroutines args deprecated warnings 40292

📖Documentation:
- The Ray streaming generator doc (alpha) is officially available at https://docs.ray.io/en/master/ray-core/ray-generator.html

Ray Clusters
💫Enhancements:
- Enable GPU support for vSphere cluster launcher (40667)

📖Documentation:
- Setup RBAC by KubeRay Helm chart
- KubeRay upgrade documentation
- RayService high availability

🔨 Fixes:
- Assorted fixes for vSphere cluster launcher (40487, 40516, 40655)

Dashboard
🎉 New Features:
- New metrics for ray data can be found in the Metrics tab.
🔨 Fixes:
- Fix bug where download log button did not download all logs for actors.

Thanks
Many thanks to all who contributed to this release!

scottjlee, chappidim, alexeykudinkin, ArturNiederfahrenhorst, stephanie-wang, chaowanggg, peytondmurray, maxpumperla, arvind-chandra, iycheng, JalinWang, matthewdeng, wfangchi, z4y1b2, alanwguo, Zandew, kouroshHakha, justinvyu, yuanchen8911, vitsai, hongchaodeng, allenwang28, caozy623, ijrsvt, omus, larrylian, can-anyscale, joncarter1, ericl, lejara, jjyao, Ox0400, architkulkarni, edoakes, raulchen, bveeramani, sihanwang41, WeichenXu123, zcin, Codle, dimakis, simonsays1980, cadedaniel, angelinalg, luv003, JingChen23, xwjiang2010, rynewang, Yicheng-Lu-llll, scrivy, michaelhly, shrekris-anyscale, xxnwj, avnishn, woshiyyya, aslonnie, amogkam, krfricke, pcmoritz, liuyang-my, jonathan-anyscale, rickyyx, scottsun94, richardliaw, rkooo567, stefanbschneider, kevin85421, c21, sven1977, GeneDer, matthew29tang, RocketRider, LaynePeng, samhallam-reverb, scv119, huchen2021

Page 2 of 15

© 2024 Safety CLI Cybersecurity Inc. All Rights Reserved.