Skip to content
Merged
Show file tree
Hide file tree
Changes from 2 commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
2 changes: 1 addition & 1 deletion src/ray/core_worker/core_worker.h
Original file line number Diff line number Diff line change
Expand Up @@ -1850,7 +1850,7 @@ class CoreWorker {
absl::flat_hash_set<TaskID> canceled_tasks_ ABSL_GUARDED_BY(mutex_);

/// Key value pairs to be displayed on Web UI.
std::unordered_map<std::string, std::string> webui_display_ ABSL_GUARDED_BY(mutex_);
absl::flat_hash_map<std::string, std::string> webui_display_ ABSL_GUARDED_BY(mutex_);

/// Actor repr name if overrides by the user, empty string if not.
std::string actor_repr_name_ ABSL_GUARDED_BY(mutex_);
Expand Down
5 changes: 3 additions & 2 deletions src/ray/core_worker/experimental_mutable_object_provider.h
Original file line number Diff line number Diff line change
Expand Up @@ -17,6 +17,7 @@
#include <unordered_map>
#include <vector>

#include "absl/container/flat_hash_map.h"
#include "ray/common/asio/instrumented_io_context.h"
#include "ray/core_worker/experimental_mutable_object_manager.h"
#include "ray/raylet_rpc_client/raylet_client_interface.h"
Expand Down Expand Up @@ -215,7 +216,7 @@ class MutableObjectProvider : public MutableObjectProviderInterface {
// Maps the remote node object ID (i.e., the object ID that the remote node writes to)
// to the corresponding local object ID (i.e., the object ID that the local node reads
// from) and the number of readers.
std::unordered_map<ObjectID, LocalReaderInfo> remote_writer_object_to_local_reader_
absl::flat_hash_map<ObjectID, LocalReaderInfo> remote_writer_object_to_local_reader_
ABSL_GUARDED_BY(remote_writer_object_to_local_reader_lock_);

// Creates a Raylet client for each mutable object. When the polling thread detects a
Expand Down Expand Up @@ -244,7 +245,7 @@ class MutableObjectProvider : public MutableObjectProviderInterface {
// For objects larger than the gRPC max payload size *that this node receives from a
// writer node*, this map tracks how many bytes have been received so far for a single
// object write.
std::unordered_map<ObjectID, uint64_t> written_so_far_
absl::flat_hash_map<ObjectID, uint64_t> written_so_far_
ABSL_GUARDED_BY(written_so_far_lock_);

friend class MutableObjectProvider_MutableObjectBufferReadRelease_Test;
Expand Down