Unify SetupDaemon/SetupLogging
[ganeti-local] / daemons / ganeti-masterd
index 885db2f..cdaff4e 100755 (executable)
@@ -29,14 +29,13 @@ inheritance from parent classes requires it.
 
 import sys
 import SocketServer
-import threading
 import time
 import collections
 import Queue
 import random
 import signal
 import simplejson
-
+import logging
 
 from cStringIO import StringIO
 from optparse import OptionParser
@@ -51,12 +50,32 @@ from ganeti import luxi
 from ganeti import utils
 from ganeti import errors
 from ganeti import ssconf
+from ganeti import logger
+from ganeti import workerpool
+from ganeti import rpc
+
 
+CLIENT_REQUEST_WORKERS = 16
 
 EXIT_NOTMASTER = constants.EXIT_NOTMASTER
 EXIT_NODESETUP_ERROR = constants.EXIT_NODESETUP_ERROR
 
 
+class ClientRequestWorker(workerpool.BaseWorker):
+  def RunTask(self, server, request, client_address):
+    """Process the request.
+
+    This is copied from the code in ThreadingMixIn.
+
+    """
+    try:
+      server.finish_request(request, client_address)
+      server.close_request(request)
+    except:
+      server.handle_error(request, client_address)
+      server.close_request(request)
+
+
 class IOServer(SocketServer.UnixStreamServer):
   """IO thread class.
 
@@ -65,8 +84,6 @@ class IOServer(SocketServer.UnixStreamServer):
   cleanup at shutdown.
 
   """
-  QUEUE_PROCESSOR_SIZE = 1
-
   def __init__(self, address, rqhandler, context):
     """IOServer constructor
 
@@ -77,60 +94,31 @@ class IOServer(SocketServer.UnixStreamServer):
 
     """
     SocketServer.UnixStreamServer.__init__(self, address, rqhandler)
-    self.do_quit = False
-    self.queue = jqueue.QueueManager()
     self.context = context
-    self.processors = []
-    signal.signal(signal.SIGINT, self.handle_quit_signals)
-    signal.signal(signal.SIGTERM, self.handle_quit_signals)
 
-  def setup_processors(self):
-    """Spawn the processors threads.
+    # We'll only start threads once we've forked.
+    self.jobqueue = None
+    self.request_workers = None
 
-    This initializes the queue and the thread processors. It is done
-    separately from the constructor because we want the clone()
-    syscalls to happen after the daemonize part.
-
-    """
-    for i in range(self.QUEUE_PROCESSOR_SIZE):
-      self.processors.append(threading.Thread(target=PoolWorker,
-                                              args=(i, self.queue.new_queue,
-                                                    self.context)))
-    for t in self.processors:
-      t.start()
-
-  def process_request_thread(self, request, client_address):
-    """Process the request.
-
-    This is copied from the code in ThreadingMixIn.
-
-    """
-    try:
-      self.finish_request(request, client_address)
-      self.close_request(request)
-    except:
-      self.handle_error(request, client_address)
-      self.close_request(request)
+  def setup_queue(self):
+    self.jobqueue = jqueue.JobQueue(self.context)
+    self.request_workers = workerpool.WorkerPool(CLIENT_REQUEST_WORKERS,
+                                                 ClientRequestWorker)
 
   def process_request(self, request, client_address):
-    """Start a new thread to process the request.
-
-    This is copied from the coode in ThreadingMixIn.
+    """Add task to workerpool to process request.
 
     """
-    t = threading.Thread(target=self.process_request_thread,
-                         args=(request, client_address))
-    t.start()
-
-  def handle_quit_signals(self, signum, frame):
-    print "received %s in %s" % (signum, frame)
-    self.do_quit = True
+    self.request_workers.AddTask(self, request, client_address)
 
   def serve_forever(self):
     """Handle one request at a time until told to quit."""
-    while not self.do_quit:
-      self.handle_request()
-      print "served request, quit=%s" % (self.do_quit)
+    sighandler = utils.SignalHandler([signal.SIGINT, signal.SIGTERM])
+    try:
+      while not sighandler.called:
+        self.handle_request()
+    finally:
+      sighandler.Reset()
 
   def server_cleanup(self):
     """Cleanup the server.
@@ -139,14 +127,14 @@ class IOServer(SocketServer.UnixStreamServer):
     socket.
 
     """
-    self.server_close()
-    utils.RemoveFile(constants.MASTER_SOCKET)
-    for i in range(self.QUEUE_PROCESSOR_SIZE):
-      self.queue.new_queue.put(None)
-    for idx, t in enumerate(self.processors):
-      print "waiting for processor thread %s..." % idx
-      t.join()
-    print "done threads"
+    try:
+      self.server_close()
+      utils.RemoveFile(constants.MASTER_SOCKET)
+    finally:
+      if self.request_workers:
+        self.request_workers.TerminateWorkers()
+      if self.jobqueue:
+        self.jobqueue.Shutdown()
 
 
 class ClientRqHandler(SocketServer.BaseRequestHandler):
@@ -163,21 +151,36 @@ class ClientRqHandler(SocketServer.BaseRequestHandler):
     while True:
       msg = self.read_message()
       if msg is None:
-        print "client closed connection"
+        logging.info("client closed connection")
         break
+
       request = simplejson.loads(msg)
+      logging.debug("request: %s", request)
       if not isinstance(request, dict):
-        print "wrong request received: %s" % msg
+        logging.error("wrong request received: %s", msg)
         break
-      method = request.get('request', None)
-      data = request.get('data', None)
-      if method is None or data is None:
-        print "no method or data in request"
+
+      method = request.get(luxi.KEY_METHOD, None)
+      args = request.get(luxi.KEY_ARGS, None)
+      if method is None or args is None:
+        logging.error("no method or args in request")
         break
-      print "request:", method, data
-      result = self._ops.handle_request(method, data)
-      print "result:", result
-      self.send_message(simplejson.dumps({'success': True, 'result': result}))
+
+      success = False
+      try:
+        result = self._ops.handle_request(method, args)
+        success = True
+      except:
+        logging.error("Unexpected exception", exc_info=True)
+        err = sys.exc_info()
+        result = "Caught exception: %s" % str(err[1])
+
+      response = {
+        luxi.KEY_SUCCESS: success,
+        luxi.KEY_RESULT: result,
+        }
+      logging.debug("response: %s", response)
+      self.send_message(simplejson.dumps(response))
 
   def read_message(self):
     while not self._msgs:
@@ -198,119 +201,34 @@ class ClientOps:
   """Class holding high-level client operations."""
   def __init__(self, server):
     self.server = server
-    self._cpu = None
-
-  def _getcpu(self):
-    if self._cpu is None:
-      self._cpu = mcpu.Processor(lambda x: None)
-    return self._cpu
-
-  def handle_request(self, operation, args):
-    print operation, args
-    if operation == "submit":
-      return self.put(args)
-    elif operation == "query":
-      return self.query(args)
-    else:
-      raise ValueError("Invalid operation")
 
-  def put(self, args):
-    job = luxi.UnserializeJob(args)
-    rid = self.server.queue.put(job)
-    return rid
-
-  def query(self, args):
-    path = args["object"]
-    fields = args["fields"]
-    names = args["names"]
-    if path == "instances":
-      opclass = opcodes.OpQueryInstances
-    elif path == "jobs":
-      # early exit because job query-ing is special (not via opcodes)
-      return self.query_jobs(fields, names)
-    else:
-      raise ValueError("Invalid object %s" % path)
-
-    op = opclass(output_fields = fields, names=names)
-    cpu = self._getcpu()
-    result = cpu.ExecOpCode(op)
-    return result
-
-  def query_jobs(self, fields, names):
-    return self.server.queue.query_jobs(fields, names)
-
-
-def JobRunner(proc, job, context):
-  """Job executor.
+  def handle_request(self, method, args):
+    queue = self.server.jobqueue
 
-  This functions processes a single job in the context of given
-  processor instance.
-
-  Args:
-    proc: Ganeti Processor to run the job on
-    job: The job to run (unserialized format)
-    context: Ganeti shared context
-
-  """
-  job.SetStatus(opcodes.Job.STATUS_RUNNING)
-  fail = False
-  for idx, op in enumerate(job.data.op_list):
-    job.data.op_status[idx] = opcodes.Job.STATUS_RUNNING
-    try:
-      job.data.op_result[idx] = proc.ExecOpCode(op)
-      job.data.op_status[idx] = opcodes.Job.STATUS_SUCCESS
-    except (errors.OpPrereqError, errors.OpExecError), err:
-      fail = True
-      job.data.op_result[idx] = str(err)
-      job.data.op_status[idx] = opcodes.Job.STATUS_FAIL
-  if fail:
-    job.SetStatus(opcodes.Job.STATUS_FAIL)
-  else:
-    job.SetStatus(opcodes.Job.STATUS_SUCCESS)
+    # TODO: Parameter validation
 
+    if method == luxi.REQ_SUBMIT_JOB:
+      ops = [opcodes.OpCode.LoadOpCode(state) for state in args]
+      # we need to compute the node list here, since from now on all
+      # operations require locks on the queue or the storage, and we
+      # shouldn't get another lock
+      node_list = self.server.context.cfg.GetNodeList()
+      return queue.SubmitJob(ops, node_list)
 
-def PoolWorker(worker_id, incoming_queue, context):
-  """A worker thread function.
+    elif method == luxi.REQ_CANCEL_JOB:
+      job_id = args
+      return queue.CancelJob(job_id)
 
-  This is the actual processor of a single thread of Job execution.
+    elif method == luxi.REQ_ARCHIVE_JOB:
+      job_id = args
+      return queue.ArchiveJob(job_id)
 
-  Args:
-    worker_id: the unique id for this worker
-    incoming_queue: a queue to get jobs from
-    context: the common server context, containing all shared data and
-             synchronization structures.
+    elif method == luxi.REQ_QUERY_JOBS:
+      (job_ids, fields) = args
+      return queue.QueryJobs(job_ids, fields)
 
-  """
-  while True:
-    print "worker %s sleeping" % worker_id
-    item = incoming_queue.get(True)
-    if item is None:
-      break
-    print "worker %s processing job %s" % (worker_id, item.data.job_id)
-    #utils.Lock('cmd')
-    try:
-      proc = mcpu.Processor(feedback=lambda x: None)
-      try:
-        JobRunner(proc, item, context)
-      except errors.GenericError, err:
-        msg = "ganeti exception %s" % err
-        item.SetStatus(opcodes.Job.STATUS_FAIL, result=[msg])
-        print msg
-      except Exception, err:
-        msg = "unhandled exception %s" % err
-        item.SetStatus(opcodes.Job.STATUS_FAIL, result=[msg])
-        print msg
-      except:
-        msg = "unhandled unknown exception"
-        item.SetStatus(opcodes.Job.STATUS_FAIL, result=[msg])
-        print msg
-
-    finally:
-      #utils.Unlock('cmd')
-      #utils.LockCleanup()
-      pass
-    print "worker %s finish job %s" % (worker_id, item.data.job_id)
-  print "worker %s exiting" % worker_id
+    else:
+      raise ValueError("Invalid operation")
 
 
 class GanetiContext(object):
@@ -333,7 +251,7 @@ class GanetiContext(object):
     # Create a ConfigWriter...
     self.cfg = config.ConfigWriter()
     # And a GanetiLockingManager...
-    self.GLM = locking.GanetiLockManager(
+    self.glm = locking.GanetiLockManager(
                 self.cfg.GetNodeList(),
                 self.cfg.GetInstanceList())
 
@@ -348,32 +266,6 @@ class GanetiContext(object):
     object.__setattr__(self, name, value)
 
 
-def CheckMaster(debug):
-  """Checks the node setup.
-
-  If this is the master, the function will return. Otherwise it will
-  exit with an exit code based on the node status.
-
-  """
-  try:
-    ss = ssconf.SimpleStore()
-    master_name = ss.GetMasterNode()
-  except errors.ConfigurationError, err:
-    print "Cluster configuration incomplete: '%s'" % str(err)
-    sys.exit(EXIT_NODESETUP_ERROR)
-
-  try:
-    myself = utils.HostInfo()
-  except errors.ResolverError, err:
-    sys.stderr.write("Cannot resolve my own name (%s)\n" % err.args[0])
-    sys.exit(EXIT_NODESETUP_ERROR)
-
-  if myself.name != master_name:
-    if debug:
-      sys.stderr.write("Not master, exiting.\n")
-    sys.exit(EXIT_NOTMASTER)
-
-
 def ParseOptions():
   """Parse the command line options.
 
@@ -403,7 +295,7 @@ def main():
   utils.debug = options.debug
   utils.no_fork = True
 
-  CheckMaster(options.debug)
+  ssconf.CheckMaster(options.debug)
 
   master = IOServer(constants.MASTER_SOCKET, ClientRqHandler, GanetiContext())
 
@@ -412,22 +304,24 @@ def main():
     utils.Daemonize(logfile=constants.LOG_MASTERDAEMON,
                     noclose_fds=[master.fileno()])
 
-  try:
-    utils.Lock('cmd', debug=options.debug)
-  except errors.LockError, err:
-    print >> sys.stderr, str(err)
-    master.server_cleanup()
-    return
+  utils.WritePidFile(constants.MASTERD_PID)
+
+  logger.SetupLogging(constants.LOG_MASTERDAEMON, debug=options.debug,
+                      stderr_logging=not options.fork)
+
+  logging.info("ganeti master daemon startup")
 
+  # activate ip
+  master_node = ssconf.SimpleStore().GetMasterNode()
+  if not rpc.call_node_start_master(master_node, False):
+    logging.error("Can't activate master IP address")
+
+  master.setup_queue()
   try:
-    master.setup_processors()
-    try:
-      master.serve_forever()
-    finally:
-      master.server_cleanup()
+    master.serve_forever()
   finally:
-    utils.Unlock('cmd')
-    utils.LockCleanup()
+    master.server_cleanup()
+    utils.RemovePidFile(constants.MASTERD_PID)
 
 
 if __name__ == "__main__":