artiq/artiq/master/worker.py

251 lines
8.7 KiB
Python
Raw Normal View History

import sys
import asyncio
2015-05-17 16:11:00 +08:00
import logging
import subprocess
import traceback
import time
2015-07-22 05:13:50 +08:00
from functools import partial
2014-10-25 16:31:34 +08:00
from artiq.protocols import pyon
from artiq.tools import asyncio_wait_or_cancel
2015-05-17 16:11:00 +08:00
logger = logging.getLogger(__name__)
class WorkerTimeout(Exception):
pass
class WorkerWatchdogTimeout(Exception):
pass
class WorkerError(Exception):
2014-12-31 17:41:22 +08:00
pass
class Worker:
def __init__(self, handlers=dict(), send_timeout=0.5):
self.handlers = handlers
self.send_timeout = send_timeout
2015-05-17 16:11:00 +08:00
self.rid = None
self.process = None
self.watchdogs = dict() # wid -> expiration (using time.monotonic)
2015-05-17 16:11:00 +08:00
self.io_lock = asyncio.Lock()
self.closed = asyncio.Event()
def create_watchdog(self, t):
2015-03-12 02:06:46 +08:00
n_user_watchdogs = len(self.watchdogs)
if -1 in self.watchdogs:
n_user_watchdogs -= 1
avail = set(range(n_user_watchdogs + 1)) \
- set(self.watchdogs.keys())
wid = next(iter(avail))
self.watchdogs[wid] = time.monotonic() + t
return wid
def delete_watchdog(self, wid):
del self.watchdogs[wid]
def watchdog_time(self):
if self.watchdogs:
return min(self.watchdogs.values()) - time.monotonic()
else:
return None
2015-10-20 18:11:50 +08:00
async def _create_process(self, log_level):
2015-10-03 19:28:57 +08:00
await self.io_lock.acquire()
2015-05-17 16:11:00 +08:00
try:
if self.closed.is_set():
raise WorkerError("Attempting to create process after close")
2015-10-03 19:28:57 +08:00
self.process = await asyncio.create_subprocess_exec(
2015-05-17 16:11:00 +08:00
sys.executable, "-m", "artiq.master.worker_impl",
2015-10-20 18:11:50 +08:00
str(log_level),
2015-05-17 16:11:00 +08:00
stdout=subprocess.PIPE, stdin=subprocess.PIPE)
finally:
self.io_lock.release()
2015-10-03 19:28:57 +08:00
async def close(self, term_timeout=1.0):
"""Interrupts any I/O with the worker process and terminates the
worker process.
This method should always be called by the user to clean up, even if
build() or examine() raises an exception."""
2015-05-17 16:11:00 +08:00
self.closed.set()
2015-10-03 19:28:57 +08:00
await self.io_lock.acquire()
try:
2015-05-17 16:11:00 +08:00
if self.process is None:
# Note the %s - self.rid can be None
logger.debug("worker was not created (RID %s)", self.rid)
return
if self.process.returncode is not None:
logger.debug("worker already terminated (RID %s)", self.rid)
2015-05-17 16:11:00 +08:00
if self.process.returncode != 0:
logger.warning("worker finished with status code %d"
" (RID %s)", self.process.returncode,
2015-05-17 16:11:00 +08:00
self.rid)
return
obj = {"action": "terminate"}
try:
2015-10-03 19:28:57 +08:00
await self._send(obj, cancellable=False)
2015-05-17 16:11:00 +08:00
except:
logger.warning("failed to send terminate command to worker"
" (RID %s), killing", self.rid, exc_info=True)
2015-05-17 16:11:00 +08:00
self.process.kill()
2015-10-03 19:28:57 +08:00
await self.process.wait()
2015-05-17 16:11:00 +08:00
return
try:
2015-10-03 19:28:57 +08:00
await asyncio.wait_for(self.process.wait(), term_timeout)
2015-05-17 16:11:00 +08:00
except asyncio.TimeoutError:
logger.warning("worker did not exit (RID %s), killing", self.rid)
2015-05-17 16:11:00 +08:00
self.process.kill()
2015-10-03 19:28:57 +08:00
await self.process.wait()
2015-05-17 16:11:00 +08:00
else:
logger.debug("worker exited gracefully (RID %s)", self.rid)
2015-05-17 16:11:00 +08:00
finally:
self.io_lock.release()
2015-10-03 19:28:57 +08:00
async def _send(self, obj, cancellable=True):
2015-05-17 16:11:00 +08:00
assert self.io_lock.locked()
2014-10-25 16:31:34 +08:00
line = pyon.encode(obj)
self.process.stdin.write(line.encode())
self.process.stdin.write("\n".encode())
2015-05-17 16:11:00 +08:00
ifs = [self.process.stdin.drain()]
if cancellable:
ifs.append(self.closed.wait())
2015-10-03 19:28:57 +08:00
fs = await asyncio_wait_or_cancel(
2015-07-15 05:43:08 +08:00
ifs, timeout=self.send_timeout,
2015-05-17 16:11:00 +08:00
return_when=asyncio.FIRST_COMPLETED)
if all(f.cancelled() for f in fs):
raise WorkerTimeout("Timeout sending data to worker")
for f in fs:
if not f.cancelled() and f.done():
f.result() # raise any exceptions
if cancellable and self.closed.is_set():
raise WorkerError("Data transmission to worker cancelled")
2015-10-03 19:28:57 +08:00
async def _recv(self, timeout):
2015-05-17 16:11:00 +08:00
assert self.io_lock.locked()
2015-10-03 19:28:57 +08:00
fs = await asyncio_wait_or_cancel(
2015-05-17 16:11:00 +08:00
[self.process.stdout.readline(), self.closed.wait()],
timeout=timeout, return_when=asyncio.FIRST_COMPLETED)
if all(f.cancelled() for f in fs):
2015-07-09 19:18:12 +08:00
raise WorkerTimeout("Timeout receiving data from worker")
2015-05-17 16:11:00 +08:00
if self.closed.is_set():
raise WorkerError("Data transmission to worker cancelled")
line = fs[0].result()
if not line:
raise WorkerError("Worker ended while attempting to receive data")
try:
2014-10-25 16:31:34 +08:00
obj = pyon.decode(line.decode())
except:
raise WorkerError("Worker sent invalid PYON data")
return obj
2015-10-03 19:28:57 +08:00
async def _handle_worker_requests(self):
while True:
2015-03-12 02:06:46 +08:00
try:
2015-10-03 19:28:57 +08:00
await self.io_lock.acquire()
2015-05-17 16:11:00 +08:00
try:
2015-10-03 19:28:57 +08:00
obj = await self._recv(self.watchdog_time())
2015-05-17 16:11:00 +08:00
finally:
self.io_lock.release()
2015-03-12 02:06:46 +08:00
except WorkerTimeout:
raise WorkerWatchdogTimeout
action = obj["action"]
if action == "completed":
2015-05-17 16:11:00 +08:00
return True
elif action == "pause":
return False
2015-10-28 17:35:57 +08:00
elif action == "create_watchdog":
func = self.create_watchdog
elif action == "delete_watchdog":
func = self.delete_watchdog
elif action == "register_experiment":
func = self.register_experiment
else:
func = self.handlers[action]
2015-07-22 05:13:50 +08:00
if getattr(func, "worker_pass_rid", False):
func = partial(func, self.rid)
try:
2015-10-28 17:35:57 +08:00
data = func(*obj["args"], **obj["kwargs"])
reply = {"status": "ok", "data": data}
except:
reply = {"status": "failed",
"message": traceback.format_exc()}
2015-10-03 19:28:57 +08:00
await self.io_lock.acquire()
2015-05-17 16:11:00 +08:00
try:
2015-10-03 19:28:57 +08:00
await self._send(reply)
2015-05-17 16:11:00 +08:00
finally:
self.io_lock.release()
2015-10-03 19:28:57 +08:00
async def _worker_action(self, obj, timeout=None):
2015-03-12 02:06:46 +08:00
if timeout is not None:
self.watchdogs[-1] = time.monotonic() + timeout
try:
2015-10-03 19:28:57 +08:00
await self.io_lock.acquire()
2015-05-17 16:11:00 +08:00
try:
2015-10-03 19:28:57 +08:00
await self._send(obj)
2015-05-17 16:11:00 +08:00
finally:
self.io_lock.release()
2015-03-12 02:06:46 +08:00
try:
2015-10-03 19:28:57 +08:00
completed = await self._handle_worker_requests()
2015-03-12 02:06:46 +08:00
except WorkerTimeout:
raise WorkerWatchdogTimeout
finally:
if timeout is not None:
del self.watchdogs[-1]
2015-05-17 16:11:00 +08:00
return completed
2015-03-12 02:06:46 +08:00
2015-10-03 19:28:57 +08:00
async def build(self, rid, pipeline_name, wd, expid, priority, timeout=15.0):
2015-05-17 16:11:00 +08:00
self.rid = rid
2015-10-20 18:11:50 +08:00
await self._create_process(expid["log_level"])
2015-10-03 19:28:57 +08:00
await self._worker_action(
2015-07-09 19:18:12 +08:00
{"action": "build",
2015-05-17 16:11:00 +08:00
"rid": rid,
"pipeline_name": pipeline_name,
2015-08-07 15:51:56 +08:00
"wd": wd,
"expid": expid,
"priority": priority},
2015-07-15 05:43:08 +08:00
timeout)
2015-07-09 19:18:12 +08:00
2015-10-03 19:28:57 +08:00
async def prepare(self):
await self._worker_action({"action": "prepare"})
2015-10-03 19:28:57 +08:00
async def run(self):
completed = await self._worker_action({"action": "run"})
2015-05-17 16:11:00 +08:00
if not completed:
self.yield_time = time.monotonic()
return completed
async def resume(self, request_termination):
2015-05-17 16:11:00 +08:00
stop_duration = time.monotonic() - self.yield_time
for wid, expiry in self.watchdogs:
self.watchdogs[wid] += stop_duration
2015-10-03 19:28:57 +08:00
completed = await self._worker_action({"status": "ok",
"data": request_termination})
2015-05-17 16:11:00 +08:00
if not completed:
self.yield_time = time.monotonic()
return completed
2015-10-03 19:28:57 +08:00
async def analyze(self):
await self._worker_action({"action": "analyze"})
2015-03-12 02:06:46 +08:00
2015-10-03 19:28:57 +08:00
async def write_results(self, timeout=15.0):
await self._worker_action({"action": "write_results"},
timeout)
2015-10-03 19:28:57 +08:00
async def examine(self, file, timeout=20.0):
2015-10-20 18:11:50 +08:00
await self._create_process(logging.WARNING)
r = dict()
def register(class_name, name, arguments):
r[class_name] = {"name": name, "arguments": arguments}
self.register_experiment = register
await self._worker_action({"action": "examine", "file": file},
timeout)
del self.register_experiment
return r