Skip to content

Commit

Permalink
fix
Browse files Browse the repository at this point in the history
Signed-off-by: Ruiyang Wang <rywang014@gmail.com>
  • Loading branch information
rynewang committed Sep 26, 2024
1 parent a617af4 commit cd706f8
Show file tree
Hide file tree
Showing 8 changed files with 2 additions and 24 deletions.
7 changes: 0 additions & 7 deletions src/ray/gcs/gcs_client/accessor.h
Original file line number Diff line number Diff line change
Expand Up @@ -932,13 +932,6 @@ class InternalKVAccessor {
const int64_t timeout_ms,
bool &exists);

/// Get the internal config string from GCS.
///
/// \param callback Processes a map of config options
/// \return Status
virtual Status AsyncGetInternalConfig(
const OptionalItemCallback<std::string> &callback);

private:
GcsClient *client_impl_;
};
Expand Down
2 changes: 0 additions & 2 deletions src/ray/gcs/gcs_server/gcs_kv_manager.cc
Original file line number Diff line number Diff line change
Expand Up @@ -141,8 +141,6 @@ void GcsInternalKVManager::HandleInternalKVKeys(
}
}

std::string GcsInternalKVManager::DebugString() const { return ""; }

Status GcsInternalKVManager::ValidateKey(const std::string &key) const {
constexpr std::string_view kNamespacePrefix = "@namespace_";
if (absl::StartsWith(key, kNamespacePrefix)) {
Expand Down
4 changes: 0 additions & 4 deletions src/ray/gcs/gcs_server/gcs_kv_manager.h
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,6 @@

#pragma once
#include <memory>
#include <string_view>

#include "absl/container/btree_map.h"
#include "absl/synchronization/mutex.h"
Expand Down Expand Up @@ -101,7 +100,6 @@ class InternalKVInterface {
/// This implementation class of `InternalKVHandler`.
class GcsInternalKVManager : public rpc::InternalKVHandler {
public:
// `raylet_config_list` must outlive this class.
explicit GcsInternalKVManager(std::unique_ptr<InternalKVInterface> kv_instance)
: kv_instance_(std::move(kv_instance)) {}

Expand Down Expand Up @@ -131,8 +129,6 @@ class GcsInternalKVManager : public rpc::InternalKVHandler {

InternalKVInterface &GetInstance() { return *kv_instance_; }

std::string DebugString() const;

private:
std::unique_ptr<InternalKVInterface> kv_instance_;
Status ValidateKey(const std::string &key) const;
Expand Down
3 changes: 1 addition & 2 deletions src/ray/gcs/gcs_server/gcs_server.cc
Original file line number Diff line number Diff line change
Expand Up @@ -809,8 +809,7 @@ std::string GcsServer::GetDebugState() const {
<< gcs_placement_group_manager_->DebugString() << "\n\n"
<< gcs_publisher_->DebugString() << "\n\n"
<< runtime_env_manager_->DebugString() << "\n\n"
<< gcs_task_manager_->DebugString() << "\n\n"
<< kv_manager_->DebugString() << "\n\n";
<< gcs_task_manager_->DebugString() << "\n\n";
return stream.str();
}

Expand Down
1 change: 0 additions & 1 deletion src/ray/gcs/gcs_server/gcs_table_storage.cc
Original file line number Diff line number Diff line change
Expand Up @@ -208,7 +208,6 @@ template class GcsTable<JobID, ErrorTableData>;
template class GcsTable<WorkerID, WorkerTableData>;
template class GcsTable<ActorID, ActorTableData>;
template class GcsTable<ActorID, TaskSpec>;
template class GcsTable<UniqueID, StoredConfig>;
template class GcsTableWithJobId<ActorID, ActorTableData>;
template class GcsTableWithJobId<ActorID, TaskSpec>;
template class GcsTable<PlacementGroupID, PlacementGroupTableData>;
Expand Down
1 change: 0 additions & 1 deletion src/ray/gcs/gcs_server/gcs_table_storage.h
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,6 @@ using rpc::GcsNodeInfo;
using rpc::JobTableData;
using rpc::PlacementGroupTableData;
using rpc::ResourceUsageBatchData;
using rpc::StoredConfig;
using rpc::TaskSpec;
using rpc::WorkerTableData;

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -45,7 +45,6 @@ class GcsAutoscalerStateManagerTest : public ::testing::Test {
GcsAutoscalerStateManagerTest() {}

protected:
static constexpr char kRayletConfig[] = R"({"raylet_config":"this is a config"})";
instrumented_io_context io_service_;
std::shared_ptr<GcsServerMocker::MockRayletClient> raylet_client_;
std::shared_ptr<rpc::NodeManagerClientPool> client_pool_;
Expand All @@ -66,8 +65,7 @@ class GcsAutoscalerStateManagerTest : public ::testing::Test {
cluster_resource_manager_ = std::make_unique<ClusterResourceManager>(io_service_);
gcs_node_manager_ = std::make_shared<MockGcsNodeManager>();
kv_manager_ = std::make_unique<GcsInternalKVManager>(
std::make_unique<StoreClientInternalKV>(std::make_unique<MockStoreClient>()),
kRayletConfig);
std::make_unique<StoreClientInternalKV>(std::make_unique<MockStoreClient>()));
function_manager_ = std::make_unique<GcsFunctionManager>(kv_manager_->GetInstance());
runtime_env_manager_ = std::make_unique<RuntimeEnvManager>(
[](const std::string &, std::function<void(bool)>) {});
Expand Down
4 changes: 0 additions & 4 deletions src/ray/protobuf/gcs.proto
Original file line number Diff line number Diff line change
Expand Up @@ -467,10 +467,6 @@ message WorkerDeltaData {
bytes worker_id = 2;
}

message StoredConfig {
string config = 1;
}

message PubSubMessage {
bytes id = 1;
bytes data = 2;
Expand Down

0 comments on commit cd706f8

Please sign in to comment.