Skip to content

Commit

Permalink
[core] Remove unused field: stdout and stderr file for core worker (#…
Browse files Browse the repository at this point in the history
…50320)

Remove unused field to avoid confusion.

Signed-off-by: dentiny <[email protected]>
  • Loading branch information
dentiny authored Feb 8, 2025
1 parent 2756c07 commit 9cbff17
Show file tree
Hide file tree
Showing 5 changed files with 1 addition and 22 deletions.
4 changes: 0 additions & 4 deletions python/ray/_private/worker.py
Original file line number Diff line number Diff line change
Expand Up @@ -2370,8 +2370,6 @@ def connect(
)

driver_name = ""
log_stdout_file_path = ""
log_stderr_file_path = ""
interactive_mode = False
if mode == SCRIPT_MODE:
import __main__ as main
Expand Down Expand Up @@ -2476,8 +2474,6 @@ def connect(
node.raylet_ip_address,
(mode == LOCAL_MODE),
driver_name,
log_stdout_file_path,
log_stderr_file_path,
serialized_job_config,
node.metrics_agent_port,
runtime_env_hash,
Expand Down
4 changes: 1 addition & 3 deletions python/ray/_raylet.pyx
Original file line number Diff line number Diff line change
Expand Up @@ -2955,7 +2955,7 @@ cdef class CoreWorker:
def __cinit__(self, worker_type, store_socket, raylet_socket,
JobID job_id, GcsClientOptions gcs_options, log_dir,
node_ip_address, node_manager_port, raylet_ip_address,
local_mode, driver_name, stdout_file, stderr_file,
local_mode, driver_name,
serialized_job_config, metrics_agent_port, runtime_env_hash,
startup_token, session_name, cluster_id, entrypoint,
worker_launch_time_ms, worker_launched_time_ms, debug_source):
Expand Down Expand Up @@ -2990,8 +2990,6 @@ cdef class CoreWorker:
options.node_manager_port = node_manager_port
options.raylet_ip_address = raylet_ip_address.encode("utf-8")
options.driver_name = driver_name
options.stdout_file = stdout_file
options.stderr_file = stderr_file
options.task_execution_callback = task_execution_handler
options.check_signals = check_signals
options.gc_collect = gc_collect
Expand Down
2 changes: 0 additions & 2 deletions python/ray/includes/libcoreworker.pxd
Original file line number Diff line number Diff line change
Expand Up @@ -379,8 +379,6 @@ cdef extern from "ray/core_worker/core_worker.h" nogil:
int node_manager_port
c_string raylet_ip_address
c_string driver_name
c_string stdout_file
c_string stderr_file
(CRayStatus(
const CAddress &caller_address,
CTaskType task_type,
Expand Down
7 changes: 0 additions & 7 deletions src/ray/core_worker/core_worker.cc
Original file line number Diff line number Diff line change
Expand Up @@ -1301,13 +1301,6 @@ void CoreWorker::RegisterToGcs(int64_t worker_launch_time_ms,
}
}

if (!options_.stdout_file.empty()) {
worker_info.emplace("stdout_file", options_.stdout_file);
}
if (!options_.stderr_file.empty()) {
worker_info.emplace("stderr_file", options_.stderr_file);
}

auto worker_data = std::make_shared<rpc::WorkerTableData>();
worker_data->mutable_worker_address()->set_raylet_id(rpc_address_.raylet_id());
worker_data->mutable_worker_address()->set_ip_address(rpc_address_.ip_address());
Expand Down
6 changes: 0 additions & 6 deletions src/ray/core_worker/core_worker_options.h
Original file line number Diff line number Diff line change
Expand Up @@ -80,8 +80,6 @@ struct CoreWorkerOptions {
node_manager_port(0),
raylet_ip_address(""),
driver_name(""),
stdout_file(""),
stderr_file(""),
task_execution_callback(nullptr),
check_signals(nullptr),
gc_collect(nullptr),
Expand Down Expand Up @@ -138,10 +136,6 @@ struct CoreWorkerOptions {
std::string raylet_ip_address;
/// The name of the driver.
std::string driver_name;
/// The stdout file of this process.
std::string stdout_file;
/// The stderr file of this process.
std::string stderr_file;
/// Language worker callback to execute tasks.
TaskExecutionCallback task_execution_callback;
/// The callback to be called when shutting down a `CoreWorker` instance.
Expand Down

0 comments on commit 9cbff17

Please sign in to comment.