Skip to content

Commit

Permalink
Fixes.
Browse files Browse the repository at this point in the history
  • Loading branch information
Robert Nishihara committed Nov 24, 2018
1 parent 047b349 commit 1985863
Show file tree
Hide file tree
Showing 5 changed files with 2 additions and 13 deletions.
2 changes: 0 additions & 2 deletions python/ray/experimental/state.py
Original file line number Diff line number Diff line change
Expand Up @@ -1151,8 +1151,6 @@ def workers(self):
worker_id = binary_to_hex(worker_key[len("Workers:"):])

workers_data[worker_id] = {
"local_scheduler_socket": (decode(
worker_info[b"local_scheduler_socket"])),
"node_ip_address": decode(worker_info[b"node_ip_address"]),
"plasma_store_socket": decode(
worker_info[b"plasma_store_socket"])
Expand Down
1 change: 0 additions & 1 deletion python/ray/services.py
Original file line number Diff line number Diff line change
Expand Up @@ -1162,7 +1162,6 @@ def start_worker(node_ip_address,
sys.executable, "-u", worker_path,
"--node-ip-address=" + node_ip_address,
"--object-store-name=" + object_store_name,
"--local-scheduler-name=" + local_scheduler_name,
"--redis-address=" + str(redis_address),
"--temp-dir=" + get_temp_root()
]
Expand Down
5 changes: 2 additions & 3 deletions python/ray/worker.py
Original file line number Diff line number Diff line change
Expand Up @@ -2036,7 +2036,7 @@ def connect(info,
worker.plasma_client = thread_safe_client(
plasma.connect(info["store_socket_name"], "", 64))

local_scheduler_socket = info["raylet_socket_name"]
raylet_socket = info["raylet_socket_name"]

# If this is a driver, set the current task ID, the task driver ID, and set
# the task index to 0.
Expand Down Expand Up @@ -2095,8 +2095,7 @@ def connect(info,
worker.multithreading_warned = False

worker.local_scheduler_client = ray.raylet.LocalSchedulerClient(
local_scheduler_socket, worker.worker_id, is_worker,
worker.current_task_id)
raylet_socket, worker.worker_id, is_worker, worker.current_task_id)

# Start the import thread
import_thread.ImportThread(worker, mode).start()
Expand Down
6 changes: 0 additions & 6 deletions python/ray/workers/default_worker.py
Original file line number Diff line number Diff line change
Expand Up @@ -40,11 +40,6 @@
required=False,
type=str,
help="the object store manager's name")
parser.add_argument(
"--local-scheduler-name",
required=False,
type=str,
help="the local scheduler's name")
parser.add_argument(
"--raylet-name", required=False, type=str, help="the raylet's name")
parser.add_argument(
Expand Down Expand Up @@ -76,7 +71,6 @@
"redis_password": args.redis_password,
"store_socket_name": args.object_store_name,
"manager_socket_name": args.object_store_manager_name,
"local_scheduler_socket_name": args.local_scheduler_name,
"raylet_socket_name": args.raylet_name
}

Expand Down
1 change: 0 additions & 1 deletion test/runtest.py
Original file line number Diff line number Diff line change
Expand Up @@ -2326,7 +2326,6 @@ def f():
assert len(worker_info) >= num_workers
for worker_id, info in worker_info.items():
assert "node_ip_address" in info
assert "local_scheduler_socket" in info
assert "plasma_store_socket" in info
assert "stderr_file" in info
assert "stdout_file" in info
Expand Down

0 comments on commit 1985863

Please sign in to comment.