Skip to content

Commit

Permalink
fix compiling failure
Browse files Browse the repository at this point in the history
  • Loading branch information
fishbone committed May 10, 2022
1 parent d18834a commit 3825141
Show file tree
Hide file tree
Showing 2 changed files with 5 additions and 4 deletions.
5 changes: 2 additions & 3 deletions src/ray/gcs/gcs_server/gcs_server.cc
Original file line number Diff line number Diff line change
Expand Up @@ -48,6 +48,7 @@ GcsServer::GcsServer(const ray::gcs::GcsServerConfig &config,
RayConfig::instance().gcs_server_rpc_client_thread_num()),
raylet_client_pool_(
std::make_shared<rpc::NodeManagerClientPool>(client_call_manager_)),
local_node_id_(NodeID::FromRandom()),
pubsub_periodical_runner_(pubsub_io_service_),
periodical_runner_(main_service),
is_started_(false),
Expand Down Expand Up @@ -302,7 +303,6 @@ void GcsServer::InitGcsResourceManager(const GcsInitData &gcs_init_data) {
}

void GcsServer::InitClusterResourceScheduler() {
local_node_id_ = NodeID::FromRandom();
cluster_resource_scheduler_ = std::make_shared<ClusterResourceScheduler>(
scheduling::NodeID(local_node_id_.Binary()),
NodeResources(),
Expand Down Expand Up @@ -473,9 +473,8 @@ void GcsServer::StoreGcsServerAddressInRedis() {

void GcsServer::InitRaySyncer(const GcsInitData &gcs_init_data) {
if (RayConfig::instance().use_ray_syncer()) {
gcs_node_id_ = NodeID::FromRandom();
ray_syncer_ = std::make_unique<syncer::RaySyncer>(ray_syncer_io_context_,
gcs_node_id_.Binary());
local_node_id_.Binary());
ray_syncer_->Register(
syncer::MessageType::RESOURCE_VIEW, nullptr, gcs_resource_manager_.get());
ray_syncer_thread_ = std::make_unique<std::thread>([this]() {
Expand Down
4 changes: 3 additions & 1 deletion src/ray/gcs/gcs_server/test/gcs_actor_scheduler_test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -61,7 +61,9 @@ class GcsActorSchedulerTest : public ::testing::Test {
/*local_task_manager=*/
nullptr);
auto gcs_resource_manager = std::make_shared<gcs::GcsResourceManager>(
gcs_table_storage_, cluster_resource_scheduler->GetClusterResourceManager());
io_service_,
gcs_table_storage_,
cluster_resource_scheduler->GetClusterResourceManager());
gcs_actor_scheduler_ = std::make_shared<GcsServerMocker::MockedGcsActorScheduler>(
io_service_,
*gcs_actor_table_,
Expand Down

0 comments on commit 3825141

Please sign in to comment.