]> git.sur5r.net Git - bacula/bacula/blobdiff - bacula/src/dird/job.c
Correct pool source setting
[bacula/bacula] / bacula / src / dird / job.c
index 77fecf011526be4d4d69316cac4324cda8f6cca3..09499daa3e011840862c36110b1d2dd264af1cbb 100644 (file)
@@ -7,22 +7,17 @@
  *    Version $Id$
  */
 /*
-   Copyright (C) 2000-2003 Kern Sibbald and John Walker
+   Copyright (C) 2000-2006 Kern Sibbald
 
    This program is free software; you can redistribute it and/or
-   modify it under the terms of the GNU General Public License as
-   published by the Free Software Foundation; either version 2 of
-   the License, or (at your option) any later version.
+   modify it under the terms of the GNU General Public License
+   version 2 as amended with additional clauses defined in the
+   file LICENSE in the main source directory.
 
    This program is distributed in the hope that it will be useful,
    but WITHOUT ANY WARRANTY; without even the implied warranty of
-   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the GNU
-   General Public License for more details.
-
-   You should have received a copy of the GNU General Public
-   License along with this program; if not, write to the Free
-   Software Foundation, Inc., 59 Temple Place - Suite 330, Boston,
-   MA 02111-1307, USA.
+   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the 
+   the file LICENSE for additional details.
 
  */
 
 
 /* Forward referenced subroutines */
 static void *job_thread(void *arg);
-static char *edit_run_codes(JCR *jcr, char *omsg, char *imsg);
-static void release_resource_locks(JCR *jcr);
-static int acquire_resource_locks(JCR *jcr);
-#ifdef USE_SEMAPHORE
-static void backoff_resource_locks(JCR *jcr, int count);
-#endif
-
-/* Exported subroutines */
-void run_job(JCR *jcr);
-
+static void job_monitor_watchdog(watchdog_t *self);
+static void job_monitor_destructor(watchdog_t *self);
+static bool job_check_maxwaittime(JCR *control_jcr, JCR *jcr);
+static bool job_check_maxruntime(JCR *control_jcr, JCR *jcr);
 
 /* Imported subroutines */
 extern void term_scheduler();
 extern void term_ua_server();
-extern int do_backup(JCR *jcr);
-extern int do_restore(JCR *jcr);
-extern int do_verify(JCR *jcr);
-extern void backup_cleanup(void);
-
-#ifdef USE_SEMAPHORE
-static semlock_t job_lock;
-static pthread_mutex_t mutex;
-static pthread_cond_t  resource_wait;
-static int waiting = 0;              /* count of waiting threads */
-#else
-/* Queue of jobs to be run */
-workq_t job_wq;                  /* our job work queue */
-#endif
+
+/* Imported variables */
+extern time_t watchdog_time;
+
+jobq_t job_queue;
 
 void init_job_server(int max_workers)
 {
    int stat;
-#ifdef USE_SEMAPHORE
-   if ((stat = sem_init(&job_lock, max_workers)) != 0) {
-      Emsg1(M_ABORT, 0, _("Could not init job lock: ERR=%s\n"), strerror(stat));
-   }
-   if ((stat = pthread_mutex_init(&mutex, NULL)) != 0) {
-      Emsg1(M_ABORT, 0, _("Could not init resource mutex: ERR=%s\n"), strerror(stat));
-   }
-   if ((stat = pthread_cond_init(&resource_wait, NULL)) != 0) {
-      Emsg1(M_ABORT, 0, _("Could not init resource wait: ERR=%s\n"), strerror(stat));
-   }
+   watchdog_t *wd;
 
-#else
-   if ((stat = workq_init(&job_wq, max_workers, job_thread)) != 0) {
-      Emsg1(M_ABORT, 0, _("Could not init job work queue: ERR=%s\n"), strerror(stat));
+   if ((stat = jobq_init(&job_queue, max_workers, job_thread)) != 0) {
+      berrno be;
+      Emsg1(M_ABORT, 0, _("Could not init job queue: ERR=%s\n"), be.strerror(stat));
    }
-#endif
-   return;
+   wd = new_watchdog();
+   wd->callback = job_monitor_watchdog;
+   wd->destructor = job_monitor_destructor;
+   wd->one_shot = false;
+   wd->interval = 60;
+   wd->data = new_control_jcr("*JobMonitor*", JT_SYSTEM);
+   register_watchdog(wd);
+}
+
+void term_job_server()
+{
+   jobq_destroy(&job_queue);          /* ignore any errors */
 }
 
 /*
  * Run a job -- typically called by the scheduler, but may also
- *             be called by the UA (Console program).
+ *              be called by the UA (Console program).
+ *
+ *  Returns: 0 on failure
+ *           JobId on success
  *
  */
-void run_job(JCR *jcr)
+JobId_t run_job(JCR *jcr)
+{
+   int stat;
+   if (setup_job(jcr)) {
+      /* Queue the job to be run */
+      if ((stat = jobq_add(&job_queue, jcr)) != 0) {
+         berrno be;
+         Jmsg(jcr, M_FATAL, 0, _("Could not add job queue: ERR=%s\n"), be.strerror(stat));
+         return 0;
+      }
+      return jcr->JobId;
+   }
+   return 0;
+}            
+
+bool setup_job(JCR *jcr) 
 {
-   int stat, errstat;
-#ifdef USE_SEMAPHORE
-   pthread_t tid;
-#else
-   workq_ele_t *work_item;
-#endif
-
-   sm_check(__FILE__, __LINE__, True);
+   int errstat;
+
+   jcr->lock();
+   sm_check(__FILE__, __LINE__, true);
    init_msg(jcr, jcr->messages);
-   create_unique_job_name(jcr, jcr->job->hdr.name);
-   jcr->jr.SchedTime = jcr->sched_time;
-   jcr->jr.StartTime = jcr->start_time;
-   jcr->jr.Type = jcr->JobType;
-   jcr->jr.Level = jcr->JobLevel;
-   jcr->jr.JobStatus = jcr->JobStatus;
-   strcpy(jcr->jr.Name, jcr->job->hdr.name);
-   strcpy(jcr->jr.Job, jcr->Job);
 
    /* Initialize termination condition variable */
    if ((errstat = pthread_cond_init(&jcr->term_wait, NULL)) != 0) {
-      Jmsg1(jcr, M_FATAL, 0, _("Unable to init job cond variable: ERR=%s\n"), strerror(errstat));
-      set_jcr_job_status(jcr, JS_ErrorTerminated);
-      free_jcr(jcr);
-      return;
+      berrno be;
+      Jmsg1(jcr, M_FATAL, 0, _("Unable to init job cond variable: ERR=%s\n"), be.strerror(errstat));
+      goto bail_out;
    }
+   jcr->term_wait_inited = true;
+
+   create_unique_job_name(jcr, jcr->job->hdr.name);
+   set_jcr_job_status(jcr, JS_Created);
+   jcr->unlock();
 
    /*
     * Open database
     */
    Dmsg0(50, "Open database\n");
    jcr->db=db_init_database(jcr, jcr->catalog->db_name, jcr->catalog->db_user,
-                           jcr->catalog->db_password, jcr->catalog->db_address,
-                           jcr->catalog->db_port, jcr->catalog->db_socket);
-   if (!db_open_database(jcr, jcr->db)) {
-      Jmsg(jcr, M_FATAL, 0, "%s", db_strerror(jcr->db));
-      db_close_database(jcr, jcr->db);
-      set_jcr_job_status(jcr, JS_ErrorTerminated);
-      free_jcr(jcr);
-      return;
+                            jcr->catalog->db_password, jcr->catalog->db_address,
+                            jcr->catalog->db_port, jcr->catalog->db_socket,
+                            jcr->catalog->mult_db_connections);
+   if (!jcr->db || !db_open_database(jcr, jcr->db)) {
+      Jmsg(jcr, M_FATAL, 0, _("Could not open database \"%s\".\n"),
+                 jcr->catalog->db_name);
+      if (jcr->db) {
+         Jmsg(jcr, M_FATAL, 0, "%s", db_strerror(jcr->db));
+      }
+      goto bail_out;
    }
    Dmsg0(50, "DB opened\n");
 
+   if (!jcr->fname) {
+      jcr->fname = get_pool_memory(PM_FNAME);
+   }
+   if (!jcr->pool_source) {
+      jcr->pool_source = get_pool_memory(PM_MESSAGE);
+      pm_strcpy(jcr->pool_source, _("unknown source"));
+   }
+   if (!jcr->storage_source) {
+      jcr->storage_source = get_pool_memory(PM_MESSAGE);
+      pm_strcpy(jcr->storage_source, _("unknown source"));
+   }
+
    /*
-    * Create Job record  
+    * Create Job record
     */
-   jcr->jr.JobStatus = jcr->JobStatus;
+   init_jcr_job_record(jcr);
    if (!db_create_job_record(jcr, jcr->db, &jcr->jr)) {
       Jmsg(jcr, M_FATAL, 0, "%s", db_strerror(jcr->db));
-      db_close_database(jcr, jcr->db);
-      set_jcr_job_status(jcr, JS_ErrorTerminated);
-      free_jcr(jcr);
-      return;
+      goto bail_out;
    }
    jcr->JobId = jcr->jr.JobId;
-   ASSERT(jcr->jr.JobId > 0);
+   Dmsg4(100, "Created job record JobId=%d Name=%s Type=%c Level=%c\n",
+       jcr->JobId, jcr->Job, jcr->jr.JobType, jcr->jr.JobLevel);
 
-   Dmsg4(30, "Created job record JobId=%d Name=%s Type=%c Level=%c\n", 
-       jcr->JobId, jcr->Job, jcr->jr.Type, jcr->jr.Level);
-   Dmsg0(200, "Add jrc to work queue\n");
+   generate_daemon_event(jcr, "JobStart");
 
-#ifdef USE_SEMAPHORE
-  if ((stat = pthread_create(&tid, NULL, job_thread, (void *)jcr)) != 0) {
-      Emsg1(M_ABORT, 0, _("Unable to create job thread: ERR=%s\n"), strerror(stat));
+   if (!get_or_create_client_record(jcr)) {
+      goto bail_out;
    }
-#else
-   /* Queue the job to be run */
-   if ((stat = workq_add(&job_wq, (void *)jcr, &work_item, 0)) != 0) {
-      Emsg1(M_ABORT, 0, _("Could not add job to work queue: ERR=%s\n"), strerror(stat));
+
+   if (job_canceled(jcr)) {
+      goto bail_out;
    }
-   jcr->work_item = work_item;
-#endif
-   Dmsg0(200, "Done run_job()\n");
+
+   Dmsg0(200, "Add jrc to work queue\n");
+   return true;
+
+bail_out:
+   return false;
 }
 
-/* 
- * This is the engine called by workq_add() when we were pulled               
+
+/*
+ * This is the engine called by jobq.c:jobq_add() when we were pulled
  *  from the work queue.
- *  At this point, we are running in our own thread 
+ *  At this point, we are running in our own thread and all
+ *    necessary resources are allocated -- see jobq.c
  */
 static void *job_thread(void *arg)
 {
    JCR *jcr = (JCR *)arg;
 
-   pthread_detach(pthread_self());
-   sm_check(__FILE__, __LINE__, True);
-
-   if (!acquire_resource_locks(jcr)) {
-      set_jcr_job_status(jcr, JS_Canceled);
-   }
+   jcr->my_thread_id = pthread_self();
+   pthread_detach(jcr->my_thread_id);
+   sm_check(__FILE__, __LINE__, true);
 
    Dmsg0(200, "=====Start Job=========\n");
    jcr->start_time = time(NULL);      /* set the real start time */
+   jcr->jr.StartTime = jcr->start_time;
 
-   if (job_canceled(jcr)) {
-      update_job_end_record(jcr);
-   } else if (jcr->job->MaxStartDelay != 0 && jcr->job->MaxStartDelay <
+   if (jcr->job->MaxStartDelay != 0 && jcr->job->MaxStartDelay <
        (utime_t)(jcr->start_time - jcr->sched_time)) {
       Jmsg(jcr, M_FATAL, 0, _("Job canceled because max start delay time exceeded.\n"));
       set_jcr_job_status(jcr, JS_Canceled);
+   }
+
+   /* TODO : check if it is used somewhere */
+   if (jcr->job->RunScripts == NULL)
+   {
+      Dmsg0(200, "Warning, job->RunScripts is empty\n");
+      jcr->job->RunScripts = New(alist(10, not_owned_by_alist));
+   }
+
+   /*                                
+    * Note, we continue, even if the job is canceled above. This
+    *  will permit proper setting of the job start record and
+    *  the error (cancel) will be picked up below.
+    */
+
+   generate_job_event(jcr, "JobInit");
+   set_jcr_job_status(jcr, JS_Running);   /* this will be set only if no error */
+
+
+   /*
+    * Now, do pre-run stuff, like setting job level (Inc/diff, ...)
+    *  this allows us to setup a proper job start record for restarting
+    *  in case of later errors.
+    */
+   switch (jcr->JobType) {
+   case JT_BACKUP:
+      if (!do_backup_init(jcr)) {
+         backup_cleanup(jcr, JS_ErrorTerminated);
+      }
+      break;
+   case JT_VERIFY:
+      if (!do_verify_init(jcr)) {
+         verify_cleanup(jcr, JS_ErrorTerminated);
+      }
+      break;
+   case JT_RESTORE:
+      if (!do_restore_init(jcr)) {
+         restore_cleanup(jcr, JS_ErrorTerminated);
+      }
+      break;
+   case JT_ADMIN:
+      if (!do_admin_init(jcr)) {
+         admin_cleanup(jcr, JS_ErrorTerminated);
+      }
+      break;
+   case JT_MIGRATE:
+      if (!do_migration_init(jcr)) { 
+         migration_cleanup(jcr, JS_ErrorTerminated);
+      }
+      break;
+   default:
+      Pmsg1(0, _("Unimplemented job type: %d\n"), jcr->JobType);
+      set_jcr_job_status(jcr, JS_ErrorTerminated);
+      break;
+   }
+
+   if (!db_update_job_start_record(jcr, jcr->db, &jcr->jr)) {
+      Jmsg(jcr, M_FATAL, 0, "%s", db_strerror(jcr->db));
+   }
+
+   if (job_canceled(jcr)) {
       update_job_end_record(jcr);
    } else {
+      /* Run any script BeforeJob on dird */
+      run_scripts(jcr, jcr->job->RunScripts, "BeforeJob");
 
-      /* Run Job */
-      set_jcr_job_status(jcr, JS_Running);
-
-      if (jcr->job->RunBeforeJob) {
-        POOLMEM *before = get_pool_memory(PM_FNAME);
-        int status;
-        
-        before = edit_run_codes(jcr, before, jcr->job->RunBeforeJob);
-        status = run_program(before, 0, NULL);
-        if (status != 0) {
-            Jmsg(jcr, M_FATAL, 0, _("RunBeforeJob returned non-zero status=%d\n"),
-              status);
-           set_jcr_job_status(jcr, JS_FatalError);
-           update_job_end_record(jcr);
-           free_pool_memory(before);
-           goto bail_out;
-        }
-        free_pool_memory(before);
+      /*
+       * We re-update the job start record so that the start
+       *  time is set after the run before job.  This avoids
+       *  that any files created by the run before job will
+       *  be saved twice.  They will be backed up in the current
+       *  job, but not in the next one unless they are changed.
+       *  Without this, they will be backed up in this job and
+       *  in the next job run because in that case, their date
+       *   is after the start of this run.
+       */
+      jcr->start_time = time(NULL);
+      jcr->jr.StartTime = jcr->start_time;
+      if (!db_update_job_start_record(jcr, jcr->db, &jcr->jr)) {
+         Jmsg(jcr, M_FATAL, 0, "%s", db_strerror(jcr->db));
       }
+      generate_job_event(jcr, "JobRun");
+
       switch (jcr->JobType) {
-        case JT_BACKUP:
-           do_backup(jcr);
-           if (jcr->JobStatus == JS_Terminated) {
-              do_autoprune(jcr);
-           }
-           break;
-        case JT_VERIFY:
-           do_verify(jcr);
-           if (jcr->JobStatus == JS_Terminated) {
-              do_autoprune(jcr);
-           }
-           break;
-        case JT_RESTORE:
-           do_restore(jcr);
-           if (jcr->JobStatus == JS_Terminated) {
-              do_autoprune(jcr);
-           }
-           break;
-        case JT_ADMIN:
-           /* No actual job */
-           do_autoprune(jcr);
-           set_jcr_job_status(jcr, JS_Terminated);
-           break;
-        default:
-            Pmsg1(0, "Unimplemented job type: %d\n", jcr->JobType);
-           break;
-        }
-      if (jcr->job->RunAfterJob) {
-        POOLMEM *after = get_pool_memory(PM_FNAME);
-        int status;
-      
-        after = edit_run_codes(jcr, after, jcr->job->RunAfterJob);
-        status = run_program(after, 0, NULL);
-        if (status != 0) {
-            Jmsg(jcr, M_FATAL, 0, _("RunAfterJob returned non-zero status=%d\n"),
-              status);
-           set_jcr_job_status(jcr, JS_FatalError);
-           update_job_end_record(jcr);
-        }
-        free_pool_memory(after);
+      case JT_BACKUP:
+         if (do_backup(jcr)) {
+            do_autoprune(jcr);
+         } else {
+            backup_cleanup(jcr, JS_ErrorTerminated);
+         }
+         break;
+      case JT_VERIFY:
+         if (do_verify(jcr)) {
+            do_autoprune(jcr);
+         } else {
+            verify_cleanup(jcr, JS_ErrorTerminated);
+         }
+         break;
+      case JT_RESTORE:
+         if (do_restore(jcr)) {
+            do_autoprune(jcr);
+         } else {
+            restore_cleanup(jcr, JS_ErrorTerminated);
+         }
+         break;
+      case JT_ADMIN:
+         if (do_admin(jcr)) {
+            do_autoprune(jcr);
+         } else {
+            admin_cleanup(jcr, JS_ErrorTerminated);
+         }
+         break;
+      case JT_MIGRATE:
+      case JT_COPY:
+      case JT_ARCHIVE:
+         if (do_migration(jcr)) {
+            do_autoprune(jcr);
+         } else {
+            migration_cleanup(jcr, JS_ErrorTerminated);
+         }
+         break;
+      default:
+         Pmsg1(0, _("Unimplemented job type: %d\n"), jcr->JobType);
+         break;
+      }
+
+      run_scripts(jcr, jcr->job->RunScripts, "AfterJob");
+
+      /* Send off any queued messages */
+      if (jcr->msg_queue->size() > 0) {
+         dequeue_messages(jcr);
       }
    }
-bail_out:
-   release_resource_locks(jcr);
-   Dmsg0(50, "Before free jcr\n");
-   free_jcr(jcr);
-   Dmsg0(50, "======== End Job ==========\n");
-   sm_check(__FILE__, __LINE__, True);
+
+   generate_daemon_event(jcr, "JobEnd");
+   Dmsg1(50, "======== End Job stat=%c ==========\n", jcr->JobStatus);
+   sm_check(__FILE__, __LINE__, true);
    return NULL;
 }
 
+
 /*
- * Acquire the resources needed. These locks limit the
- *  number of jobs by each resource. We have limits on
- *  Jobs, Clients, Storage, and total jobs.
+ * Cancel a job -- typically called by the UA (Console program), but may also
+ *              be called by the job watchdog.
+ *
+ *  Returns: true  if cancel appears to be successful
+ *           false on failure. Message sent to ua->jcr.
  */
-static int acquire_resource_locks(JCR *jcr)
+bool cancel_job(UAContext *ua, JCR *jcr)
 {
-#ifdef USE_SEMAPHORE
-   int stat;
+   BSOCK *sd, *fd;
 
-   if (jcr->store->sem.valid != SEMLOCK_VALID) {
-      if ((stat = sem_init(&jcr->store->sem, jcr->store->MaxConcurrentJobs)) != 0) {
-         Emsg1(M_ABORT, 0, _("Could not init Storage semaphore: ERR=%s\n"), strerror(stat));
-      }
-   }
-   if (jcr->client->sem.valid != SEMLOCK_VALID) {
-      if ((stat = sem_init(&jcr->client->sem, jcr->client->MaxConcurrentJobs)) != 0) {
-         Emsg1(M_ABORT, 0, _("Could not init Client semaphore: ERR=%s\n"), strerror(stat));
+   set_jcr_job_status(jcr, JS_Canceled);
+
+   switch (jcr->JobStatus) {
+   case JS_Created:
+   case JS_WaitJobRes:
+   case JS_WaitClientRes:
+   case JS_WaitStoreRes:
+   case JS_WaitPriority:
+   case JS_WaitMaxJobs:
+   case JS_WaitStartTime:
+      bsendmsg(ua, _("JobId %d, Job %s marked to be canceled.\n"),
+              jcr->JobId, jcr->Job);
+      jobq_remove(&job_queue, jcr); /* attempt to remove it from queue */
+      return true;
+
+   default:
+      /* Cancel File daemon */
+      if (jcr->file_bsock) {
+         ua->jcr->client = jcr->client;
+         if (!connect_to_file_daemon(ua->jcr, 10, FDConnectTimeout, 1)) {
+            bsendmsg(ua, _("Failed to connect to File daemon.\n"));
+            return 0;
+         }
+         Dmsg0(200, "Connected to file daemon\n");
+         fd = ua->jcr->file_bsock;
+         bnet_fsend(fd, "cancel Job=%s\n", jcr->Job);
+         while (bnet_recv(fd) >= 0) {
+            bsendmsg(ua, "%s", fd->msg);
+         }
+         bnet_sig(fd, BNET_TERMINATE);
+         bnet_close(fd);
+         ua->jcr->file_bsock = NULL;
       }
-   }
-   if (jcr->job->sem.valid != SEMLOCK_VALID) {
-      if ((stat = sem_init(&jcr->job->sem, jcr->job->MaxConcurrentJobs)) != 0) {
-         Emsg1(M_ABORT, 0, _("Could not init Job semaphore: ERR=%s\n"), strerror(stat));
+
+      /* Cancel Storage daemon */
+      if (jcr->store_bsock) {
+         if (!ua->jcr->storage) {
+            copy_storage(ua->jcr, jcr->storage, _("Job resource")); 
+         } else {
+            set_storage(ua->jcr, jcr->store);
+         }
+         if (!connect_to_storage_daemon(ua->jcr, 10, SDConnectTimeout, 1)) {
+            bsendmsg(ua, _("Failed to connect to Storage daemon.\n"));
+            return false;
+         }
+         Dmsg0(200, "Connected to storage daemon\n");
+         sd = ua->jcr->store_bsock;
+         bnet_fsend(sd, "cancel Job=%s\n", jcr->Job);
+         while (bnet_recv(sd) >= 0) {
+            bsendmsg(ua, "%s", sd->msg);
+         }
+         bnet_sig(sd, BNET_TERMINATE);
+         bnet_close(sd);
+         ua->jcr->store_bsock = NULL;
       }
    }
 
-   for ( ;; ) {
-      /* Acquire semaphore */
-      set_jcr_job_status(jcr, JS_WaitJobRes);
-      if ((stat = sem_lock(&jcr->job->sem)) != 0) {
-         Emsg1(M_ABORT, 0, _("Could not acquire Job max jobs lock: ERR=%s\n"), strerror(stat));
-      }
-      set_jcr_job_status(jcr, JS_WaitClientRes);
-      if ((stat = sem_trylock(&jcr->client->sem)) != 0) {
-        if (stat == EBUSY) {
-           backoff_resource_locks(jcr, 1);
-           goto wait;
-        } else {
-            Emsg1(M_ABORT, 0, _("Could not acquire Client max jobs lock: ERR=%s\n"), strerror(stat));
-        }
+   return true;
+}
+
+
+static void job_monitor_destructor(watchdog_t *self)
+{
+   JCR *control_jcr = (JCR *)self->data;
+
+   free_jcr(control_jcr);
+}
+
+static void job_monitor_watchdog(watchdog_t *self)
+{
+   JCR *control_jcr, *jcr;
+
+   control_jcr = (JCR *)self->data;
+
+   Dmsg1(800, "job_monitor_watchdog %p called\n", self);
+
+   foreach_jcr(jcr) {
+      bool cancel;
+
+      if (jcr->JobId == 0) {
+         Dmsg2(800, "Skipping JCR %p (%s) with JobId 0\n",
+               jcr, jcr->Job);
+         continue;
       }
-      set_jcr_job_status(jcr, JS_WaitStoreRes);
-      if ((stat = sem_trylock(&jcr->store->sem)) != 0) {
-        if (stat == EBUSY) {
-           backoff_resource_locks(jcr, 2);
-           goto wait;
-        } else {
-            Emsg1(M_ABORT, 0, _("Could not acquire Storage max jobs lock: ERR=%s\n"), strerror(stat));
-        }
+
+      /* check MaxWaitTime */
+      cancel = job_check_maxwaittime(control_jcr, jcr);
+
+      /* check MaxRunTime */
+      cancel |= job_check_maxruntime(control_jcr, jcr);
+
+      if (cancel) {
+         Dmsg3(800, "Cancelling JCR %p jobid %d (%s)\n",
+               jcr, jcr->JobId, jcr->Job);
+
+         UAContext *ua = new_ua_context(jcr);
+         ua->jcr = control_jcr;
+         cancel_job(ua, jcr);
+         free_ua_context(ua);
+
+         Dmsg2(800, "Have cancelled JCR %p Job=%d\n", jcr, jcr->JobId);
       }
-      set_jcr_job_status(jcr, JS_WaitMaxJobs);
-      if ((stat = sem_trylock(&job_lock)) != 0) {
-        if (stat == EBUSY) {
-           backoff_resource_locks(jcr, 3);
-           goto wait;
-        } else {
-            Emsg1(M_ABORT, 0, _("Could not acquire max jobs lock: ERR=%s\n"), strerror(stat));
-        }
+
+      /* Keep reference counts correct */
+   }
+   endeach_jcr(jcr);
+}
+
+/*
+ * Check if the maxwaittime has expired and it is possible
+ *  to cancel the job.
+ */
+static bool job_check_maxwaittime(JCR *control_jcr, JCR *jcr)
+{
+   bool cancel = false;
+   bool ok_to_cancel = false;
+   JOB *job = jcr->job;
+
+   if (job->MaxWaitTime == 0 && job->FullMaxWaitTime == 0 &&
+       job->IncMaxWaitTime == 0 && job->DiffMaxWaitTime == 0) {
+      return false;
+   } 
+   if (jcr->JobLevel == L_FULL && job->FullMaxWaitTime != 0 &&
+         (watchdog_time - jcr->start_time) >= job->FullMaxWaitTime) {
+      ok_to_cancel = true;
+   } else if (jcr->JobLevel == L_DIFFERENTIAL && job->DiffMaxWaitTime != 0 &&
+         (watchdog_time - jcr->start_time) >= job->DiffMaxWaitTime) {
+      ok_to_cancel = true;
+   } else if (jcr->JobLevel == L_INCREMENTAL && job->IncMaxWaitTime != 0 &&
+         (watchdog_time - jcr->start_time) >= job->IncMaxWaitTime) {
+      ok_to_cancel = true;
+   } else if (job->MaxWaitTime != 0 &&
+         (watchdog_time - jcr->start_time) >= job->MaxWaitTime) {
+      ok_to_cancel = true;
+   }
+   if (!ok_to_cancel) {
+      return false;
+   }
+   Dmsg3(800, "Job %d (%s): MaxWaitTime of %d seconds exceeded, "
+         "checking status\n",
+         jcr->JobId, jcr->Job, job->MaxWaitTime);
+   switch (jcr->JobStatus) {
+   case JS_Created:
+   case JS_Blocked:
+   case JS_WaitFD:
+   case JS_WaitSD:
+   case JS_WaitStoreRes:
+   case JS_WaitClientRes:
+   case JS_WaitJobRes:
+   case JS_WaitPriority:
+   case JS_WaitMaxJobs:
+   case JS_WaitStartTime:
+      cancel = true;
+      Dmsg0(200, "JCR blocked in #1\n");
+      break;
+   case JS_Running:
+      Dmsg0(800, "JCR running, checking SD status\n");
+      switch (jcr->SDJobStatus) {
+      case JS_WaitMount:
+      case JS_WaitMedia:
+      case JS_WaitFD:
+         cancel = true;
+         Dmsg0(800, "JCR blocked in #2\n");
+         break;
+      default:
+         Dmsg0(800, "JCR not blocked in #2\n");
+         break;
       }
       break;
+   case JS_Terminated:
+   case JS_ErrorTerminated:
+   case JS_Canceled:
+   case JS_FatalError:
+      Dmsg0(800, "JCR already dead in #3\n");
+      break;
+   default:
+      Jmsg1(jcr, M_ERROR, 0, _("Unhandled job status code %d\n"),
+            jcr->JobStatus);
+   }
+   Dmsg3(800, "MaxWaitTime result: %scancel JCR %p (%s)\n",
+         cancel ? "" : "do not ", jcr, jcr->job);
 
-wait:
-      P(mutex);
-      /*
-       * Wait for a resource to be released either by backoff or
-       *  by a job terminating.
-       */
-      waiting++;
-      pthread_cond_wait(&resource_wait, &mutex);
-      waiting--;
-      V(mutex);
-      /* Try again */
-   }
-#endif
-   return 1;
+   return cancel;
 }
 
-#ifdef USE_SEMAPHORE
 /*
- * We could not get all the resource locks because 
- *  too many jobs are running, so release any locks
- *  we did acquire, giving others a chance to use them
- *  while we wait.
+ * Check if maxruntime has expired and if the job can be
+ *   canceled.
  */
-static void backoff_resource_locks(JCR *jcr, int count)
+static bool job_check_maxruntime(JCR *control_jcr, JCR *jcr)
 {
-   P(mutex);
-   switch (count) {
-   case 3:
-      sem_unlock(&jcr->store->sem);
-      /* Fall through wanted */
-   case 2:
-      sem_unlock(&jcr->client->sem);
-      /* Fall through wanted */
-   case 1:
-      sem_unlock(&jcr->job->sem);
-      break;
+   bool cancel = false;
+
+   if (jcr->job->MaxRunTime == 0) {
+      return false;
    }
-   /*
-    * Since we released a lock, if there are any threads
-    *  waiting, wake them up so that they can try again.
-    */
-   if (waiting > 0) {
-      pthread_cond_broadcast(&resource_wait);
+   if ((watchdog_time - jcr->start_time) < jcr->job->MaxRunTime) {
+      Dmsg3(200, "Job %p (%s) with MaxRunTime %d not expired\n",
+            jcr, jcr->Job, jcr->job->MaxRunTime);
+      return false;
+   }
+
+   switch (jcr->JobStatus) {
+   case JS_Created:
+   case JS_Running:
+   case JS_Blocked:
+   case JS_WaitFD:
+   case JS_WaitSD:
+   case JS_WaitStoreRes:
+   case JS_WaitClientRes:
+   case JS_WaitJobRes:
+   case JS_WaitPriority:
+   case JS_WaitMaxJobs:
+   case JS_WaitStartTime:
+   case JS_Differences:
+      cancel = true;
+      break;
+   case JS_Terminated:
+   case JS_ErrorTerminated:
+   case JS_Canceled:
+   case JS_FatalError:
+      cancel = false;
+      break;
+   default:
+      Jmsg1(jcr, M_ERROR, 0, _("Unhandled job status code %d\n"),
+            jcr->JobStatus);
    }
-   V(mutex);
+
+   Dmsg3(200, "MaxRunTime result: %scancel JCR %p (%s)\n",
+         cancel ? "" : "do not ", jcr, jcr->job);
+
+   return cancel;
 }
-#endif
 
 /*
- * This is called at the end of the job to release
- *   any resource limits on the number of jobs. If
- *   there are any other jobs waiting, we wake them
- *   up so that they can try again.
+ * Get or create a Pool record with the given name.
+ * Returns: 0 on error
+ *          poolid if OK
  */
-static void release_resource_locks(JCR *jcr)
+DBId_t get_or_create_pool_record(JCR *jcr, char *pool_name)
+{
+   POOL_DBR pr;
+
+   memset(&pr, 0, sizeof(pr));
+   bstrncpy(pr.Name, pool_name, sizeof(pr.Name));
+
+   while (!db_get_pool_record(jcr, jcr->db, &pr)) { /* get by Name */
+      /* Try to create the pool */
+      if (create_pool(jcr, jcr->db, jcr->pool, POOL_OP_CREATE) < 0) {
+         Jmsg(jcr, M_FATAL, 0, _("Pool %s not in database. %s"), pr.Name,
+            db_strerror(jcr->db));
+         return 0;
+      } else {
+         Jmsg(jcr, M_INFO, 0, _("Pool %s created in database.\n"), pr.Name);
+      }
+   }
+   return pr.PoolId;
+}
+
+void apply_pool_overrides(JCR *jcr)
 {
-#ifdef USE_SEMAPHORE
-   P(mutex);
-   sem_unlock(&jcr->store->sem);
-   sem_unlock(&jcr->client->sem);
-   sem_unlock(&jcr->job->sem);
-   sem_unlock(&job_lock);
-   if (waiting > 0) {
-      pthread_cond_broadcast(&resource_wait);
-   }
-   V(mutex);
-#endif
+   if (jcr->run_pool_override) {
+      pm_strcpy(jcr->pool_source, _("Run Pool override"));
+   }
+   /*
+    * Apply any level related Pool selections
+    */
+   switch (jcr->JobLevel) {
+   case L_FULL:
+      if (jcr->full_pool) {
+         jcr->pool = jcr->full_pool;
+         if (jcr->run_full_pool_override) {
+            pm_strcpy(jcr->pool_source, _("Run FullPool override"));
+         } else {
+            pm_strcpy(jcr->pool_source, _("Job FullPool override"));
+         }
+      }
+      break;
+   case L_INCREMENTAL:
+      if (jcr->inc_pool) {
+         jcr->pool = jcr->inc_pool;
+         if (jcr->run_inc_pool_override) {
+            pm_strcpy(jcr->pool_source, _("Run IncPool override"));
+         } else {
+            pm_strcpy(jcr->pool_source, _("Job IncPool override"));
+         }
+      }
+      break;
+   case L_DIFFERENTIAL:
+      if (jcr->diff_pool) {
+         jcr->pool = jcr->diff_pool;
+         if (jcr->run_diff_pool_override) {
+            pm_strcpy(jcr->pool_source, _("Run DiffPool override"));
+         } else {
+            pm_strcpy(jcr->pool_source, _("Job DiffPool override"));
+         }
+      }
+      break;
+   }
 }
 
+
 /*
  * Get or create a Client record for this Job
  */
-int get_or_create_client_record(JCR *jcr)
+bool get_or_create_client_record(JCR *jcr)
 {
    CLIENT_DBR cr;
 
@@ -404,38 +654,79 @@ int get_or_create_client_record(JCR *jcr)
    cr.AutoPrune = jcr->client->AutoPrune;
    cr.FileRetention = jcr->client->FileRetention;
    cr.JobRetention = jcr->client->JobRetention;
-   if (jcr->client_name) {
-      free_pool_memory(jcr->client_name);
+   if (!jcr->client_name) {
+      jcr->client_name = get_pool_memory(PM_NAME);
    }
-   jcr->client_name = get_memory(strlen(jcr->client->hdr.name) + 1);
-   strcpy(jcr->client_name, jcr->client->hdr.name);
+   pm_strcpy(jcr->client_name, jcr->client->hdr.name);
    if (!db_create_client_record(jcr, jcr->db, &cr)) {
-      Jmsg(jcr, M_FATAL, 0, _("Could not create Client record. ERR=%s\n"), 
-        db_strerror(jcr->db));
-      return 0;
+      Jmsg(jcr, M_FATAL, 0, _("Could not create Client record. ERR=%s\n"),
+         db_strerror(jcr->db));
+      return false;
    }
    jcr->jr.ClientId = cr.ClientId;
    if (cr.Uname[0]) {
-      if (jcr->client_uname) {
-        free_pool_memory(jcr->client_uname);
+      if (!jcr->client_uname) {
+         jcr->client_uname = get_pool_memory(PM_NAME);
       }
-      jcr->client_uname = get_memory(strlen(cr.Uname) + 1);
-      strcpy(jcr->client_uname, cr.Uname);
+      pm_strcpy(jcr->client_uname, cr.Uname);
    }
-   Dmsg2(100, "Created Client %s record %d\n", jcr->client->hdr.name, 
+   Dmsg2(100, "Created Client %s record %d\n", jcr->client->hdr.name,
       jcr->jr.ClientId);
-   return 1;
+   return true;
+}
+
+bool get_or_create_fileset_record(JCR *jcr)
+{
+   FILESET_DBR fsr;
+   /*
+    * Get or Create FileSet record
+    */
+   memset(&fsr, 0, sizeof(FILESET_DBR));
+   bstrncpy(fsr.FileSet, jcr->fileset->hdr.name, sizeof(fsr.FileSet));
+   if (jcr->fileset->have_MD5) {
+      struct MD5Context md5c;
+      unsigned char digest[MD5HashSize];
+      memcpy(&md5c, &jcr->fileset->md5c, sizeof(md5c));
+      MD5Final(digest, &md5c);
+      bin_to_base64(fsr.MD5, (char *)digest, MD5HashSize);
+      bstrncpy(jcr->fileset->MD5, fsr.MD5, sizeof(jcr->fileset->MD5));
+   } else {
+      Jmsg(jcr, M_WARNING, 0, _("FileSet MD5 digest not found.\n"));
+   }
+   if (!jcr->fileset->ignore_fs_changes ||
+       !db_get_fileset_record(jcr, jcr->db, &fsr)) {
+      if (!db_create_fileset_record(jcr, jcr->db, &fsr)) {
+         Jmsg(jcr, M_ERROR, 0, _("Could not create FileSet \"%s\" record. ERR=%s\n"),
+            fsr.FileSet, db_strerror(jcr->db));
+         return false;
+      }
+   }
+   jcr->jr.FileSetId = fsr.FileSetId;
+   bstrncpy(jcr->FSCreateTime, fsr.cCreateTime, sizeof(jcr->FSCreateTime));
+   Dmsg2(119, "Created FileSet %s record %u\n", jcr->fileset->hdr.name,
+      jcr->jr.FileSetId);
+   return true;
 }
 
+void init_jcr_job_record(JCR *jcr)
+{
+   jcr->jr.SchedTime = jcr->sched_time;
+   jcr->jr.StartTime = jcr->start_time;
+   jcr->jr.EndTime = 0;               /* perhaps rescheduled, clear it */
+   jcr->jr.JobType = jcr->JobType;
+   jcr->jr.JobLevel = jcr->JobLevel;
+   jcr->jr.JobStatus = jcr->JobStatus;
+   jcr->jr.JobId = jcr->JobId;
+   bstrncpy(jcr->jr.Name, jcr->job->hdr.name, sizeof(jcr->jr.Name));
+   bstrncpy(jcr->jr.Job, jcr->Job, sizeof(jcr->jr.Job));
+}
 
 /*
  * Write status and such in DB
  */
 void update_job_end_record(JCR *jcr)
 {
-   if (jcr->jr.EndTime == 0) {
-      jcr->jr.EndTime = time(NULL);
-   }
+   jcr->jr.EndTime = time(NULL);
    jcr->end_time = jcr->jr.EndTime;
    jcr->jr.JobId = jcr->JobId;
    jcr->jr.JobStatus = jcr->JobStatus;
@@ -444,8 +735,8 @@ void update_job_end_record(JCR *jcr)
    jcr->jr.VolSessionId = jcr->VolSessionId;
    jcr->jr.VolSessionTime = jcr->VolSessionTime;
    if (!db_update_job_end_record(jcr, jcr->db, &jcr->jr)) {
-      Jmsg(jcr, M_WARNING, 0, _("Error updating job record. %s"), 
-        db_strerror(jcr->db));
+      Jmsg(jcr, M_WARNING, 0, _("Error updating job record. %s"),
+         db_strerror(jcr->db));
    }
 }
 
@@ -456,7 +747,7 @@ void update_job_end_record(JCR *jcr)
  *  Returns: unique job name in jcr->Job
  *    date/time in jcr->start_time
  */
-void create_unique_job_name(JCR *jcr, char *base_name)
+void create_unique_job_name(JCR *jcr, const char *base_name)
 {
    /* Job start mutex */
    static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER;
@@ -468,24 +759,24 @@ void create_unique_job_name(JCR *jcr, char *base_name)
    char *p;
 
    /* Guarantee unique start time -- maximum one per second, and
-    * thus unique Job Name 
+    * thus unique Job Name
     */
-   P(mutex);                         /* lock creation of jobs */
+   P(mutex);                          /* lock creation of jobs */
    now = time(NULL);
    while (now == last_start_time) {
-      sleep(1);
+      bmicrosleep(0, 500000);
       now = time(NULL);
    }
    last_start_time = now;
-   V(mutex);                         /* allow creation of jobs */
+   V(mutex);                          /* allow creation of jobs */
    jcr->start_time = now;
    /* Form Unique JobName */
    localtime_r(&now, &tm);
    /* Use only characters that are permitted in Windows filenames */
-   strftime(dt, sizeof(dt), "%Y-%m-%d_%H.%M.%S", &tm); 
+   strftime(dt, sizeof(dt), "%Y-%m-%d_%H.%M.%S", &tm);
    bstrncpy(name, base_name, sizeof(name));
-   name[sizeof(name)-22] = 0;         /* truncate if too long */
-   sprintf(jcr->Job, "%s.%s", name, dt); /* add date & time */
+   name[sizeof(name)-22] = 0;          /* truncate if too long */
+   bsnprintf(jcr->Job, sizeof(jcr->Job), "%s.%s", name, dt); /* add date & time */
    /* Convert spaces into underscores */
    for (p=jcr->Job; *p; p++) {
       if (*p == ' ') {
@@ -494,44 +785,83 @@ void create_unique_job_name(JCR *jcr, char *base_name)
    }
 }
 
-/*
- * Free the Job Control Record if no one is still using it.
- *  Called from main free_jcr() routine in src/lib/jcr.c so
- *  that we can do our Director specific cleanup of the jcr.
- */
-void dird_free_jcr(JCR *jcr)
+/* Called directly from job rescheduling */
+void dird_free_jcr_pointers(JCR *jcr)
 {
-   Dmsg0(200, "Start dird free_jcr\n");
-
+   if (jcr->sd_auth_key) {
+      free(jcr->sd_auth_key);
+      jcr->sd_auth_key = NULL;
+   }
+   if (jcr->where) {
+      free(jcr->where);
+      jcr->where = NULL;
+   }
    if (jcr->file_bsock) {
       Dmsg0(200, "Close File bsock\n");
       bnet_close(jcr->file_bsock);
+      jcr->file_bsock = NULL;
    }
    if (jcr->store_bsock) {
       Dmsg0(200, "Close Store bsock\n");
       bnet_close(jcr->store_bsock);
+      jcr->store_bsock = NULL;
    }
-   if (jcr->fname) {  
+   if (jcr->fname) {
       Dmsg0(200, "Free JCR fname\n");
       free_pool_memory(jcr->fname);
+      jcr->fname = NULL;
+   }
+   if (jcr->pool_source) {
+      free_pool_memory(jcr->pool_source);
+      jcr->pool_source = NULL;
+   }
+   if (jcr->storage_source) {
+      free_pool_memory(jcr->storage_source);
+      jcr->storage_source = NULL;
    }
    if (jcr->stime) {
       Dmsg0(200, "Free JCR stime\n");
       free_pool_memory(jcr->stime);
-   }
-   if (jcr->db) {
-      Dmsg0(200, "Close DB\n");
-      db_close_database(jcr, jcr->db);
-   }
-   if (jcr->RestoreWhere) {
-      free(jcr->RestoreWhere);
+      jcr->stime = NULL;
    }
    if (jcr->RestoreBootstrap) {
       free(jcr->RestoreBootstrap);
+      jcr->RestoreBootstrap = NULL;
    }
    if (jcr->client_uname) {
       free_pool_memory(jcr->client_uname);
+      jcr->client_uname = NULL;
+   }
+   if (jcr->attr) {
+      free_pool_memory(jcr->attr);
+      jcr->attr = NULL;
+   }
+   if (jcr->ar) {
+      free(jcr->ar);
+      jcr->ar = NULL;
+   }
+}
+
+/*
+ * Free the Job Control Record if no one is still using it.
+ *  Called from main free_jcr() routine in src/lib/jcr.c so
+ *  that we can do our Director specific cleanup of the jcr.
+ */
+void dird_free_jcr(JCR *jcr)
+{
+   Dmsg0(200, "Start dird free_jcr\n");
+
+   dird_free_jcr_pointers(jcr);
+   if (jcr->term_wait_inited) {
+      pthread_cond_destroy(&jcr->term_wait);
+      jcr->term_wait_inited = false;
+   }
+
+   /* Delete lists setup to hold storage pointers */
+   if (jcr->storage) {
+      delete jcr->storage;
    }
+   jcr->job_end_push.destroy();
    Dmsg0(200, "End dird free_jcr\n");
 }
 
@@ -546,113 +876,161 @@ void set_jcr_defaults(JCR *jcr, JOB *job)
 {
    jcr->job = job;
    jcr->JobType = job->JobType;
-   jcr->JobLevel = job->level;
-   jcr->store = job->storage;
+   switch (jcr->JobType) {
+   case JT_ADMIN:
+   case JT_RESTORE:
+      jcr->JobLevel = L_NONE;
+      break;
+   default:
+      jcr->JobLevel = job->JobLevel;
+      break;
+   }
+   if (!jcr->fname) {
+      jcr->fname = get_pool_memory(PM_FNAME);
+   }
+   if (!jcr->pool_source) {
+      jcr->pool_source = get_pool_memory(PM_MESSAGE);
+      pm_strcpy(jcr->pool_source, _("unknown source"));
+   }
+   if (!jcr->storage_source) {
+      jcr->storage_source = get_pool_memory(PM_MESSAGE);
+      pm_strcpy(jcr->storage_source, _("unknown source"));
+   }
+   jcr->JobPriority = job->Priority;
+   /* Copy storage definitions -- deleted in dir_free_jcr above */
+   copy_storage(jcr, job->storage, _("Job resource"));
    jcr->client = job->client;
-   if (jcr->client_name) {
-      free_pool_memory(jcr->client_name);
+   if (!jcr->client_name) {
+      jcr->client_name = get_pool_memory(PM_NAME);
    }
-   jcr->client_name = get_memory(strlen(jcr->client->hdr.name) + 1);
-   strcpy(jcr->client_name, jcr->client->hdr.name);
+   pm_strcpy(jcr->client_name, jcr->client->hdr.name);
+   pm_strcpy(jcr->pool_source, _("Job resource"));
    jcr->pool = job->pool;
+   jcr->full_pool = job->full_pool;
+   jcr->inc_pool = job->inc_pool;
+   jcr->diff_pool = job->diff_pool;
    jcr->catalog = job->client->catalog;
    jcr->fileset = job->fileset;
-   jcr->messages = job->messages; 
+   jcr->messages = job->messages;
+   jcr->spool_data = job->spool_data;
+   jcr->write_part_after_job = job->write_part_after_job;
    if (jcr->RestoreBootstrap) {
       free(jcr->RestoreBootstrap);
+      jcr->RestoreBootstrap = NULL;
    }
    /* This can be overridden by Console program */
    if (job->RestoreBootstrap) {
       jcr->RestoreBootstrap = bstrdup(job->RestoreBootstrap);
    }
+   /* This can be overridden by Console program */
+   jcr->verify_job = job->verify_job;
    /* If no default level given, set one */
    if (jcr->JobLevel == 0) {
       switch (jcr->JobType) {
       case JT_VERIFY:
-        jcr->JobLevel = L_VERIFY_CATALOG;
-        break;
+         jcr->JobLevel = L_VERIFY_CATALOG;
+         break;
       case JT_BACKUP:
-        jcr->JobLevel = L_INCREMENTAL;
-        break;
+         jcr->JobLevel = L_INCREMENTAL;
+         break;
+      case JT_RESTORE:
+      case JT_ADMIN:
+         jcr->JobLevel = L_NONE;
+         break;
       default:
-        break;
+         break;
       }
    }
 }
 
-/*
- * Edit codes into Run command
- *  %% = %
- *  %c = Client's name
- *  %d = Director's name
- *  %i = JobId
- *  %e = Job Exit
- *  %j = Job
- *  %l = Job Level
- *  %n = Job name
- *  %t = Job type
- *
- *  omsg = edited output message
- *  imsg = input string containing edit codes (%x)
- *
+
+/* 
+ * Copy the storage definitions from an alist to the JCR
  */
-static char *edit_run_codes(JCR *jcr, char *omsg, char *imsg) 
+void copy_storage(JCR *jcr, alist *storage, const char *where)
 {
-   char *p;
-   const char *str;
-   char add[20];
-
-   *omsg = 0;
-   Dmsg1(200, "edit_run_codes: %s\n", imsg);
-   for (p=imsg; *p; p++) {
-      if (*p == '%') {
-        switch (*++p) {
-         case '%':
-            str = "%";
-           break;
-         case 'c':
-           str = jcr->client_name;
-           if (!str) {
-               str = "";
-           }
-           break;
-         case 'd':
-           str = my_name;
-           break;
-         case 'e':
-           str = job_status_to_str(jcr->JobStatus);
-           break;
-         case 'i':
-            sprintf(add, "%d", jcr->JobId);
-           str = add;
-           break;
-         case 'j':                    /* Job */
-           str = jcr->Job;
-           break;
-         case 'l':
-           str = job_level_to_str(jcr->JobLevel);
-           break;
-         case 'n':
-           str = jcr->job->hdr.name;
-           break;
-         case 't':
-           str = job_type_to_str(jcr->JobType);
-           break;
-        default:
-            add[0] = '%';
-           add[1] = *p;
-           add[2] = 0;
-           str = add;
-           break;
-        }
-      } else {
-        add[0] = *p;
-        add[1] = 0;
-        str = add;
+   if (storage) {
+      STORE *st;
+      if (jcr->storage) {
+         delete jcr->storage;
+      }
+      jcr->storage = New(alist(10, not_owned_by_alist));
+      foreach_alist(st, storage) {
+         jcr->storage->append(st);
+      }
+      pm_strcpy(jcr->storage_source, where);
+   }               
+   if (jcr->storage) {
+      jcr->store = (STORE *)jcr->storage->first();
+   }
+}
+
+
+/* Set storage override */
+void set_storage(JCR *jcr, STORE *store)
+{
+   STORE *storage;
+
+   jcr->store = store;
+   foreach_alist(storage, jcr->storage) {
+      if (store == storage) {
+         return;
       }
-      Dmsg1(200, "add_str %s\n", str);
-      pm_strcat(&omsg, (char *)str);
-      Dmsg1(200, "omsg=%s\n", omsg);
    }
-   return omsg;
+   /* Store not in list, so add it */
+   jcr->storage->prepend(store);
+}
+
+void create_clones(JCR *jcr)
+{
+   /*
+    * Fire off any clone jobs (run directives)
+    */
+   Dmsg2(900, "cloned=%d run_cmds=%p\n", jcr->cloned, jcr->job->run_cmds);
+   if (!jcr->cloned && jcr->job->run_cmds) {
+      char *runcmd;
+      JOB *job = jcr->job;
+      POOLMEM *cmd = get_pool_memory(PM_FNAME);
+      UAContext *ua = new_ua_context(jcr);
+      ua->batch = true;
+      foreach_alist(runcmd, job->run_cmds) {
+         cmd = edit_job_codes(jcr, cmd, runcmd, "");              
+         Mmsg(ua->cmd, "run %s cloned=yes", cmd);
+         Dmsg1(900, "=============== Clone cmd=%s\n", ua->cmd);
+         parse_ua_args(ua);                 /* parse command */
+         int stat = run_cmd(ua, ua->cmd);
+         if (stat == 0) {
+            Jmsg(jcr, M_ERROR, 0, _("Could not start clone job.\n"));
+         } else {
+            Jmsg(jcr, M_INFO, 0, _("Clone JobId %d started.\n"), stat);
+         }
+      }
+      free_ua_context(ua);
+      free_pool_memory(cmd);
+   }
+}
+
+bool create_restore_bootstrap_file(JCR *jcr)
+{
+   RESTORE_CTX rx;
+   UAContext *ua;
+   memset(&rx, 0, sizeof(rx));
+   rx.bsr = new_bsr();
+   rx.JobIds = "";                       
+   rx.bsr->JobId = jcr->previous_jr.JobId;
+   ua = new_ua_context(jcr);
+   complete_bsr(ua, rx.bsr);
+   rx.bsr->fi = new_findex();
+   rx.bsr->fi->findex = 1;
+   rx.bsr->fi->findex2 = jcr->previous_jr.JobFiles;
+   jcr->ExpectedFiles = write_bsr_file(ua, rx);
+   if (jcr->ExpectedFiles == 0) {
+      free_ua_context(ua);
+      free_bsr(rx.bsr);
+      return false;
+   }
+   free_ua_context(ua);
+   free_bsr(rx.bsr);
+   jcr->needs_sd = true;
+   return true;
 }