]> git.sur5r.net Git - bacula/bacula/blobdiff - bacula/src/dird/jobq.c
ebl Add field to command list to restrict Runscript console
[bacula/bacula] / bacula / src / dird / jobq.c
old mode 100755 (executable)
new mode 100644 (file)
index eea66c0..1e7fddc
@@ -1,3 +1,30 @@
+/*
+   Bacula® - The Network Backup Solution
+
+   Copyright (C) 2003-2008 Free Software Foundation Europe e.V.
+
+   The main author of Bacula is Kern Sibbald, with contributions from
+   many others, a complete list can be found in the file AUTHORS.
+   This program is Free Software; you can redistribute it and/or
+   modify it under the terms of version two of the GNU General Public
+   License as published by the Free Software Foundation and included
+   in the file LICENSE.
+
+   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., 51 Franklin Street, Fifth Floor, Boston, MA
+   02110-1301, USA.
+
+   Bacula® is a registered trademark of Kern Sibbald.
+   The licensor of Bacula is the Free Software Foundation Europe
+   (FSFE), Fiduciary Program, Sumatrastrasse 25, 8006 Zürich,
+   Switzerland, email:ftf@fsfeurope.org.
+*/
 /*
  * Bacula job queue routines.
  *
  *    David R. Butenhof
  *
  */
-/*
-   Copyright (C) 2003-2005 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.
-
-   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.
-
- */
 
 #include "bacula.h"
 #include "dird.h"
@@ -46,15 +54,17 @@ extern JCR *jobs;
 extern "C" void *jobq_server(void *arg);
 extern "C" void *sched_wait(void *arg);
 
-static int   start_server(jobq_t *jq);
-
-
+static int  start_server(jobq_t *jq);
+static bool acquire_resources(JCR *jcr);
+static bool reschedule_job(JCR *jcr, jobq_t *jq, jobq_item_t *je);
+static void dec_read_store(JCR *jcr);
+static void dec_write_store(JCR *jcr);
 
 /*
  * Initialize a job queue
  *
  *  Returns: 0 on success
- *          errno on failure
+ *           errno on failure
  */
 int jobq_init(jobq_t *jq, int threads, void *(*engine)(void *arg))
 {
@@ -63,7 +73,7 @@ int jobq_init(jobq_t *jq, int threads, void *(*engine)(void *arg))
 
    if ((stat = pthread_attr_init(&jq->attr)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_attr_init: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_attr_init: ERR=%s\n"), be.bstrerror(stat));
       return stat;
    }
    if ((stat = pthread_attr_setdetachstate(&jq->attr, PTHREAD_CREATE_DETACHED)) != 0) {
@@ -72,22 +82,22 @@ int jobq_init(jobq_t *jq, int threads, void *(*engine)(void *arg))
    }
    if ((stat = pthread_mutex_init(&jq->mutex, NULL)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_init: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_mutex_init: ERR=%s\n"), be.bstrerror(stat));
       pthread_attr_destroy(&jq->attr);
       return stat;
    }
    if ((stat = pthread_cond_init(&jq->work, NULL)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_cond_init: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_cond_init: ERR=%s\n"), be.bstrerror(stat));
       pthread_mutex_destroy(&jq->mutex);
       pthread_attr_destroy(&jq->attr);
       return stat;
    }
    jq->quit = false;
-   jq->max_workers = threads;        /* max threads to create */
-   jq->num_workers = 0;              /* no threads yet */
-   jq->idle_workers = 0;             /* no idle threads */
-   jq->engine = engine;              /* routine to run */
+   jq->max_workers = threads;         /* max threads to create */
+   jq->num_workers = 0;               /* no threads yet */
+   jq->idle_workers = 0;              /* no idle threads */
+   jq->engine = engine;               /* routine to run */
    jq->valid = JOBQ_VALID;
    /* Initialize the job queues */
    jq->waiting_jobs = New(dlist(item, &item->link));
@@ -100,7 +110,7 @@ int jobq_init(jobq_t *jq, int threads, void *(*engine)(void *arg))
  * Destroy the job queue
  *
  * Returns: 0 on success
- *         errno on failure
+ *          errno on failure
  */
 int jobq_destroy(jobq_t *jq)
 {
@@ -111,10 +121,10 @@ int jobq_destroy(jobq_t *jq)
    }
    if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_mutex_lock: ERR=%s\n"), be.bstrerror(stat));
       return stat;
    }
-   jq->valid = 0;                     /* prevent any more operations */
+   jq->valid = 0;                      /* prevent any more operations */
 
    /* 
     * If any threads are active, wake them 
@@ -122,25 +132,25 @@ int jobq_destroy(jobq_t *jq)
    if (jq->num_workers > 0) {
       jq->quit = true;
       if (jq->idle_workers) {
-        if ((stat = pthread_cond_broadcast(&jq->work)) != 0) {
-           berrno be;
-            Jmsg1(NULL, M_ERROR, 0, "pthread_cond_broadcast: ERR=%s\n", be.strerror(stat));
-           pthread_mutex_unlock(&jq->mutex);
-           return stat;
-        }
+         if ((stat = pthread_cond_broadcast(&jq->work)) != 0) {
+            berrno be;
+            Jmsg1(NULL, M_ERROR, 0, _("pthread_cond_broadcast: ERR=%s\n"), be.bstrerror(stat));
+            pthread_mutex_unlock(&jq->mutex);
+            return stat;
+         }
       }
       while (jq->num_workers > 0) {
-        if ((stat = pthread_cond_wait(&jq->work, &jq->mutex)) != 0) {
-           berrno be;
-            Jmsg1(NULL, M_ERROR, 0, "pthread_cond_wait: ERR=%s\n", be.strerror(stat));
-           pthread_mutex_unlock(&jq->mutex);
-           return stat;
-        }
+         if ((stat = pthread_cond_wait(&jq->work, &jq->mutex)) != 0) {
+            berrno be;
+            Jmsg1(NULL, M_ERROR, 0, _("pthread_cond_wait: ERR=%s\n"), be.bstrerror(stat));
+            pthread_mutex_unlock(&jq->mutex);
+            return stat;
+         }
       }
    }
    if ((stat = pthread_mutex_unlock(&jq->mutex)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_mutex_unlock: ERR=%s\n"), be.bstrerror(stat));
       return stat;
    }
    stat  = pthread_mutex_destroy(&jq->mutex);
@@ -177,24 +187,24 @@ void *sched_wait(void *arg)
    /* Wait until scheduled time arrives */
    if (wtime > 0) {
       Jmsg(jcr, M_INFO, 0, _("Job %s waiting %d seconds for scheduled start time.\n"),
-        jcr->Job, wtime);
+         jcr->Job, wtime);
    }
    /* Check every 30 seconds if canceled */
    while (wtime > 0) {
-      Dmsg2(2300, "Waiting on sched time, jobid=%d secs=%d\n", jcr->JobId, wtime);
+      Dmsg3(2300, "Waiting on sched time, jobid=%d secs=%d use=%d\n", 
+         jcr->JobId, wtime, jcr->use_count());
       if (wtime > 30) {
-        wtime = 30;
+         wtime = 30;
       }
       bmicrosleep(wtime, 0);
       if (job_canceled(jcr)) {
-        break;
+         break;
       }
       wtime = jcr->sched_time - time(NULL);
    }
-   P(jcr->mutex);                    /* lock jcr */
+   Dmsg1(200, "resched use=%d\n", jcr->use_count());
    jobq_add(jq, jcr);
-   V(jcr->mutex);
-   free_jcr(jcr);                    /* we are done with jcr */
+   free_jcr(jcr);                     /* we are done with jcr */
    Dmsg0(2300, "Exit sched_wait\n");
    return NULL;
 }
@@ -202,9 +212,6 @@ void *sched_wait(void *arg)
 /*
  *  Add a job to the queue
  *    jq is a queue that was created with jobq_init
- *
- *  On entry jcr->mutex must be locked.
- *
  */
 int jobq_add(jobq_t *jq, JCR *jcr)
 {
@@ -215,37 +222,46 @@ int jobq_add(jobq_t *jq, JCR *jcr)
    pthread_t id;
    wait_pkt *sched_pkt;
 
-   Dmsg3(2300, "jobq_add jobid=%d jcr=0x%x use_count=%d\n", jcr->JobId, jcr, jcr->use_count);
+   if (!jcr->term_wait_inited) { 
+      /* Initialize termination condition variable */
+      if ((stat = pthread_cond_init(&jcr->term_wait, NULL)) != 0) {
+         berrno be;
+         Jmsg1(jcr, M_FATAL, 0, _("Unable to init job cond variable: ERR=%s\n"), be.bstrerror(stat));
+         return stat;
+      }
+      jcr->term_wait_inited = true;
+   }                           
+                             
+   Dmsg3(2300, "jobq_add jobid=%d jcr=0x%x use_count=%d\n", jcr->JobId, jcr, jcr->use_count());
    if (jq->valid != JOBQ_VALID) {
       Jmsg0(jcr, M_ERROR, 0, "Jobq_add queue not initialized.\n");
       return EINVAL;
    }
 
-   jcr->use_count++;                 /* mark jcr in use by us */
-   Dmsg3(2300, "jobq_add jobid=%d jcr=0x%x use_count=%d\n", jcr->JobId, jcr, jcr->use_count);
+   jcr->inc_use_count();                 /* mark jcr in use by us */
+   Dmsg3(2300, "jobq_add jobid=%d jcr=0x%x use_count=%d\n", jcr->JobId, jcr, jcr->use_count());
    if (!job_canceled(jcr) && wtime > 0) {
       set_thread_concurrency(jq->max_workers + 2);
       sched_pkt = (wait_pkt *)malloc(sizeof(wait_pkt));
       sched_pkt->jcr = jcr;
       sched_pkt->jq = jq;
-//    jcr->use_count--;           /* release our use of jcr */
-      stat = pthread_create(&id, &jq->attr, sched_wait, (void *)sched_pkt);       
-      if (stat != 0) {               /* thread not created */
-        berrno be;
-         Jmsg1(jcr, M_ERROR, 0, "pthread_thread_create: ERR=%s\n", be.strerror(stat));
+      stat = pthread_create(&id, &jq->attr, sched_wait, (void *)sched_pkt);        
+      if (stat != 0) {                /* thread not created */
+         berrno be;
+         Jmsg1(jcr, M_ERROR, 0, _("pthread_thread_create: ERR=%s\n"), be.bstrerror(stat));
       }
       return stat;
    }
 
    if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
       berrno be;
-      Jmsg1(jcr, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", be.strerror(stat));
-      jcr->use_count--;              /* release jcr */
+      Jmsg1(jcr, M_ERROR, 0, _("pthread_mutex_lock: ERR=%s\n"), be.bstrerror(stat));
+      free_jcr(jcr);                    /* release jcr */
       return stat;
    }
 
    if ((item = (jobq_item_t *)malloc(sizeof(jobq_item_t))) == NULL) {
-      jcr->use_count--;              /* release jcr */
+      free_jcr(jcr);                    /* release jcr */
       return ENOMEM;
    }
    item->jcr = jcr;
@@ -258,18 +274,18 @@ int jobq_add(jobq_t *jq, JCR *jcr)
       /* Add this job to the wait queue in priority sorted order */
       foreach_dlist(li, jq->waiting_jobs) {
          Dmsg2(2300, "waiting item jobid=%d priority=%d\n",
-           li->jcr->JobId, li->jcr->JobPriority);
-        if (li->jcr->JobPriority > jcr->JobPriority) {
-           jq->waiting_jobs->insert_before(item, li);
+            li->jcr->JobId, li->jcr->JobPriority);
+         if (li->jcr->JobPriority > jcr->JobPriority) {
+            jq->waiting_jobs->insert_before(item, li);
             Dmsg2(2300, "insert_before jobid=%d before waiting job=%d\n",
-              li->jcr->JobId, jcr->JobId);
-           inserted = true;
-           break;
-        }
+               li->jcr->JobId, jcr->JobId);
+            inserted = true;
+            break;
+         }
       }
       /* If not jobs in wait queue, append it */
       if (!inserted) {
-        jq->waiting_jobs->append(item);
+         jq->waiting_jobs->append(item);
          Dmsg1(2300, "Appended item jobid=%d to waiting queue\n", jcr->JobId);
       }
    }
@@ -304,14 +320,14 @@ int jobq_remove(jobq_t *jq, JCR *jcr)
 
    if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_mutex_lock: ERR=%s\n"), be.bstrerror(stat));
       return stat;
    }
 
    foreach_dlist(item, jq->waiting_jobs) {
       if (jcr == item->jcr) {
-        found = true;
-        break;
+         found = true;
+         break;
       }
    }
    if (!found) {
@@ -341,22 +357,26 @@ static int start_server(jobq_t *jq)
    int stat = 0;
    pthread_t id;
 
-   /* if any threads are idle, wake one */
+   /*
+    * if any threads are idle, wake one.
+    *   Actually we do a broadcast because on /lib/tls 
+    *   these signals seem to get lost from time to time.
+    */
    if (jq->idle_workers > 0) {
       Dmsg0(2300, "Signal worker to wake up\n");
-      if ((stat = pthread_cond_signal(&jq->work)) != 0) {
-        berrno be;
-         Jmsg1(NULL, M_ERROR, 0, "pthread_cond_signal: ERR=%s\n", be.strerror(stat));
-        return stat;
+      if ((stat = pthread_cond_broadcast(&jq->work)) != 0) {
+         berrno be;
+         Jmsg1(NULL, M_ERROR, 0, _("pthread_cond_signal: ERR=%s\n"), be.bstrerror(stat));
+         return stat;
       }
    } else if (jq->num_workers < jq->max_workers) {
       Dmsg0(2300, "Create worker thread\n");
       /* No idle threads so create a new one */
       set_thread_concurrency(jq->max_workers + 1);
       if ((stat = pthread_create(&id, &jq->attr, jobq_server, (void *)jq)) != 0) {
-        berrno be;
-         Jmsg1(NULL, M_ERROR, 0, "pthread_create: ERR=%s\n", be.strerror(stat));
-        return stat;
+         berrno be;
+         Jmsg1(NULL, M_ERROR, 0, _("pthread_create: ERR=%s\n"), be.bstrerror(stat));
+         return stat;
       }
    }
    return stat;
@@ -373,7 +393,7 @@ void *jobq_server(void *arg)
 {
    struct timespec timeout;
    jobq_t *jq = (jobq_t *)arg;
-   jobq_item_t *je;                  /* job entry in queue */
+   jobq_item_t *je;                   /* job entry in queue */
    int stat;
    bool timedout = false;
    bool work = true;
@@ -381,7 +401,7 @@ void *jobq_server(void *arg)
    Dmsg0(2300, "Start jobq_server\n");
    if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
       berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", be.strerror(stat));
+      Jmsg1(NULL, M_ERROR, 0, _("pthread_mutex_lock: ERR=%s\n"), be.bstrerror(stat));
       return NULL;
    }
    jq->num_workers++;
@@ -392,323 +412,390 @@ void *jobq_server(void *arg)
 
       Dmsg0(2300, "Top of for loop\n");
       if (!work && !jq->quit) {
-        gettimeofday(&tv, &tz);
-        timeout.tv_nsec = 0;
-        timeout.tv_sec = tv.tv_sec + 4;
-
-        while (!jq->quit) {
-           /*
-            * Wait 4 seconds, then if no more work, exit
-            */
+         gettimeofday(&tv, &tz);
+         timeout.tv_nsec = 0;
+         timeout.tv_sec = tv.tv_sec + 4;
+
+         while (!jq->quit) {
+            /*
+             * Wait 4 seconds, then if no more work, exit
+             */
             Dmsg0(2300, "pthread_cond_timedwait()\n");
-           stat = pthread_cond_timedwait(&jq->work, &jq->mutex, &timeout);
-           if (stat == ETIMEDOUT) {
+            stat = pthread_cond_timedwait(&jq->work, &jq->mutex, &timeout);
+            if (stat == ETIMEDOUT) {
                Dmsg0(2300, "timedwait timedout.\n");
-              timedout = true;
-              break;
-           } else if (stat != 0) {
+               timedout = true;
+               break;
+            } else if (stat != 0) {
                /* This shouldn't happen */
                Dmsg0(2300, "This shouldn't happen\n");
-              jq->num_workers--;
-              pthread_mutex_unlock(&jq->mutex);
-              return NULL;
-           }
-           break;
-        }
+               jq->num_workers--;
+               pthread_mutex_unlock(&jq->mutex);
+               return NULL;
+            }
+            break;
+         }
       }
       /*
        * If anything is in the ready queue, run it
        */
       Dmsg0(2300, "Checking ready queue.\n");
       while (!jq->ready_jobs->empty() && !jq->quit) {
-        JCR *jcr;
-        je = (jobq_item_t *)jq->ready_jobs->first();
-        jcr = je->jcr;
-        jq->ready_jobs->remove(je);
-        if (!jq->ready_jobs->empty()) {
+         JCR *jcr;
+         je = (jobq_item_t *)jq->ready_jobs->first();
+         jcr = je->jcr;
+         jq->ready_jobs->remove(je);
+         if (!jq->ready_jobs->empty()) {
             Dmsg0(2300, "ready queue not empty start server\n");
-           if (start_server(jq) != 0) {
-              jq->num_workers--;
-              pthread_mutex_unlock(&jq->mutex);
-              return NULL;
-           }
-        }
-        jq->running_jobs->append(je);
+            if (start_server(jq) != 0) {
+               jq->num_workers--;
+               pthread_mutex_unlock(&jq->mutex);
+               return NULL;
+            }
+         }
+         jq->running_jobs->append(je);
+         set_jcr_in_tsd(jcr);
          Dmsg1(2300, "Took jobid=%d from ready and appended to run\n", jcr->JobId);
 
-        /* Release job queue lock */
-        if ((stat = pthread_mutex_unlock(&jq->mutex)) != 0) {
-           berrno be;
-            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", be.strerror(stat));
-           jq->num_workers--;
-           return NULL;
-        }
+         /* Release job queue lock */
+         V(jq->mutex);
 
          /* Call user's routine here */
-         Dmsg1(2300, "Calling user engine for jobid=%d\n", jcr->JobId);
-        jq->engine(je->jcr);
-
-         Dmsg1(2300, "Back from user engine jobid=%d.\n", jcr->JobId);
-
-        /* Reacquire job queue lock */
-        if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
-           berrno be;
-            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", be.strerror(stat));
-           jq->num_workers--;
-           free(je);                 /* release job entry */
-           return NULL;
-        }
+         Dmsg2(2300, "Calling user engine for jobid=%d use=%d\n", jcr->JobId,
+            jcr->use_count());
+         jq->engine(je->jcr);
+
+         Dmsg2(2300, "Back from user engine jobid=%d use=%d.\n", jcr->JobId,
+            jcr->use_count());
+
+         /* Reacquire job queue lock */
+         P(jq->mutex);
          Dmsg0(200, "Done lock mutex after running job. Release locks.\n");
-        jq->running_jobs->remove(je);
-        /*
-         * Release locks if acquired. Note, they will not have
-         *  been acquired for jobs canceled before they were
-         *  put into the ready queue.
-         */
-        if (jcr->acquired_resource_locks) {
-           jcr->store->NumConcurrentJobs--;
-           if (jcr->JobType == JT_RESTORE || jcr->JobType == JT_VERIFY) {
-              jcr->store->MaxConcurrentJobs = jcr->saveMaxConcurrentJobs;
-           }
-           jcr->client->NumConcurrentJobs--;
-           jcr->job->NumConcurrentJobs--;
-        }
-
-        /*
-         * Reschedule the job if necessary and requested
-         */
-        if (jcr->job->RescheduleOnError &&
-            jcr->JobStatus != JS_Terminated &&
-            jcr->JobStatus != JS_Canceled &&
-            jcr->job->RescheduleTimes > 0 &&
-            jcr->reschedule_count < jcr->job->RescheduleTimes) {
-            char dt[50];
-
-            /*
-             * Reschedule this job by cleaning it up, but
-             *  reuse the same JobId if possible.
-             */
-           jcr->reschedule_count++;
-           jcr->sched_time = time(NULL) + jcr->job->RescheduleInterval;
-            Dmsg2(2300, "Rescheduled Job %s to re-run in %d seconds.\n", jcr->Job,
-              (int)jcr->job->RescheduleInterval);
-           bstrftime(dt, sizeof(dt), time(NULL));
-            Jmsg(jcr, M_INFO, 0, _("Rescheduled Job %s at %s to re-run in %d seconds.\n"),
-              jcr->Job, dt, (int)jcr->job->RescheduleInterval);
-           dird_free_jcr(jcr);          /* partial cleanup old stuff */
-           jcr->JobStatus = JS_WaitStartTime;
-           jcr->SDJobStatus = 0;
-           if (jcr->JobBytes == 0) {
-               Dmsg1(2300, "Requeue job=%d\n", jcr->JobId);
-              jcr->JobStatus = JS_WaitStartTime;
-              V(jq->mutex);
-              jobq_add(jq, jcr);     /* queue the job to run again */
-              P(jq->mutex);
-              free(je);              /* free the job entry */
-              continue;              /* look for another job to run */
-           }
-           /*
-            * Something was actually backed up, so we cannot reuse
-            *   the old JobId or there will be database record
-            *   conflicts.  We now create a new job, copying the
-            *   appropriate fields.
-            */
-           JCR *njcr = new_jcr(sizeof(JCR), dird_free_jcr);
-           set_jcr_defaults(njcr, jcr->job);
-           njcr->reschedule_count = jcr->reschedule_count;
-           njcr->JobLevel = jcr->JobLevel;
-           njcr->JobStatus = jcr->JobStatus;
-           copy_storage(njcr, jcr);
-           njcr->messages = jcr->messages;
-            Dmsg0(2300, "Call to run new job\n");
-           V(jq->mutex);
-            run_job(njcr);            /* This creates a "new" job */
-            free_jcr(njcr);           /* release "new" jcr */
-           P(jq->mutex);
-            Dmsg0(2300, "Back from running new job.\n");
-        }
-        /* Clean up and release old jcr */
-        if (jcr->db) {
-           db_close_database(jcr, jcr->db);
-           jcr->db = NULL;
-        }
-         Dmsg2(2300, "====== Termination job=%d use_cnt=%d\n", jcr->JobId, jcr->use_count);
-        jcr->SDJobStatus = 0;
-        V(jq->mutex);                /* release internal lock */
-        free_jcr(jcr);
-        free(je);                    /* release job entry */
-        P(jq->mutex);                /* reacquire job queue lock */
+         jq->running_jobs->remove(je);
+         /*
+          * Release locks if acquired. Note, they will not have
+          *  been acquired for jobs canceled before they were
+          *  put into the ready queue.
+          */
+         if (jcr->acquired_resource_locks) {
+            dec_read_store(jcr);
+            dec_write_store(jcr);
+            jcr->client->NumConcurrentJobs--;
+            jcr->job->NumConcurrentJobs--;
+            jcr->acquired_resource_locks = false;
+         }
+
+         if (reschedule_job(jcr, jq, je)) {
+            continue;              /* go look for more work */
+         }
+
+         /* Clean up and release old jcr */
+         Dmsg2(2300, "====== Termination job=%d use_cnt=%d\n", jcr->JobId, jcr->use_count());
+         jcr->SDJobStatus = 0;
+         V(jq->mutex);                /* release internal lock */
+         free_jcr(jcr);
+         free(je);                    /* release job entry */
+         P(jq->mutex);                /* reacquire job queue lock */
       }
       /*
        * If any job in the wait queue can be run,
        *  move it to the ready queue
        */
       Dmsg0(2300, "Done check ready, now check wait queue.\n");
-      while (!jq->waiting_jobs->empty() && !jq->quit) {
-        int Priority;
-        je = (jobq_item_t *)jq->waiting_jobs->first();
-        jobq_item_t *re = (jobq_item_t *)jq->running_jobs->first();
-        if (re) {
-           Priority = re->jcr->JobPriority;
-            Dmsg2(2300, "JobId %d is running. Look for pri=%d\n", re->jcr->JobId, Priority);
-        } else {
-           Priority = je->jcr->JobPriority;
-            Dmsg1(2300, "No job running. Look for Job pri=%d\n", Priority);
-        }
-        /*
-         * Walk down the list of waiting jobs and attempt
-         *   to acquire the resources it needs.
-         */
-        for ( ; je;  ) {
-           /* je is current job item on the queue, jn is the next one */
-           JCR *jcr = je->jcr;
-           bool skip_this_jcr = false;
-           jobq_item_t *jn = (jobq_item_t *)jq->waiting_jobs->next(je);
-            Dmsg3(2300, "Examining Job=%d JobPri=%d want Pri=%d\n",
-              jcr->JobId, jcr->JobPriority, Priority);
-           /* Take only jobs of correct Priority */
-           if (jcr->JobPriority != Priority) {
-              set_jcr_job_status(jcr, JS_WaitPriority);
-              break;
-           }
-           if (jcr->JobType == JT_RESTORE || jcr->JobType == JT_VERIFY) {
-              /* Let only one Restore/verify job run at a time regardless of MaxConcurrentJobs */
-              if (jcr->store->NumConcurrentJobs == 0) {
-                 jcr->store->NumConcurrentJobs++;
-                 jcr->saveMaxConcurrentJobs = jcr->store->MaxConcurrentJobs;
-                 jcr->store->MaxConcurrentJobs = 1;
-              } else {
-                 set_jcr_job_status(jcr, JS_WaitStoreRes);
-                 je = jn;            /* point to next waiting job */
-                 continue;
+      if (!jq->waiting_jobs->empty() && !jq->quit) {
+         int Priority;
+         bool running_allow_mix = false;
+         je = (jobq_item_t *)jq->waiting_jobs->first();
+         jobq_item_t *re = (jobq_item_t *)jq->running_jobs->first();
+         if (re) {
+            Priority = re->jcr->JobPriority;
+            Dmsg2(2300, "JobId %d is running. Look for pri=%d\n",
+                 re->jcr->JobId, Priority);
+           running_allow_mix = true;
+           for ( ; re; ) {
+              Dmsg2(2300, "JobId %d is also running with %s\n",
+                    re->jcr->JobId, 
+                    re->jcr->job->allow_mixed_priority ? "mix" : "no mix");
+              if (!re->jcr->job->allow_mixed_priority) {
+                 running_allow_mix = false;
+                 break;
               }
-           /* We are not doing a Restore or Verify */
-           } else if (jcr->store->NumConcurrentJobs == 0 &&
-                      jcr->store->NumConcurrentJobs < jcr->store->MaxConcurrentJobs) {
-               /* Simple case, first job */
-               jcr->store->NumConcurrentJobs = 1;
-           } else if (jcr->store->NumConcurrentJobs < jcr->store->MaxConcurrentJobs) {
-              /*
-               * At this point, we already have at least one Job running
-               *  for this Storage daemon, so we must ensure that there
-               *  is no Volume conflict. In general, it should be OK, if
-               *  all Jobs pull from the same Pool, so we check the Pools.
-               */
-               JCR *njcr;
-               lock_jcr_chain();
-               for (njcr=jobs; njcr; njcr=njcr->next) {
-                  if (njcr->JobId == 0 || njcr == jcr) {
-                     continue;
-                  }
-                  if (njcr->pool != jcr->pool) {
-                     skip_this_jcr = true;
-                     break;
-                  }
-               }
-               unlock_jcr_chain();
-               if (!skip_this_jcr) {
-                  jcr->store->NumConcurrentJobs++;
-               }
+              re = (jobq_item_t *)jq->running_jobs->next(re);
            }
-           if (skip_this_jcr) {
-              set_jcr_job_status(jcr, JS_WaitStoreRes);
-              je = jn;               /* point to next waiting job */
-              continue;
-           }
-
-           if (jcr->client->NumConcurrentJobs < jcr->client->MaxConcurrentJobs) {
-              jcr->client->NumConcurrentJobs++;
-           } else {
-              /* Back out previous locks */
-              jcr->store->NumConcurrentJobs--;
-              if (jcr->JobType == JT_RESTORE || jcr->JobType == JT_VERIFY) {
-                 jcr->store->MaxConcurrentJobs = jcr->saveMaxConcurrentJobs;
-              }
-              set_jcr_job_status(jcr, JS_WaitClientRes);
-              je = jn;               /* point to next waiting job */
-              continue;
-           }
-           if (jcr->job->NumConcurrentJobs < jcr->job->MaxConcurrentJobs) {
-              jcr->job->NumConcurrentJobs++;
-           } else {
-              /* Back out previous locks */
-              jcr->store->NumConcurrentJobs--;
-              if (jcr->JobType == JT_RESTORE || jcr->JobType == JT_VERIFY) {
-                 jcr->store->MaxConcurrentJobs = jcr->saveMaxConcurrentJobs;
-              }
-              jcr->client->NumConcurrentJobs--;
-              set_jcr_job_status(jcr, JS_WaitJobRes);
-              je = jn;               /* Point to next waiting job */
-              continue;
-           }
-           /* Got all locks, now remove it from wait queue and append it
-            *   to the ready queue
-            */
-           jcr->acquired_resource_locks = true;
-           jq->waiting_jobs->remove(je);
-           jq->ready_jobs->append(je);
+            Dmsg1(2300, "The running job(s) %s mixing priorities.\n",
+                 running_allow_mix ? "allow" : "don't allow");
+         } else {
+            Priority = je->jcr->JobPriority;
+            Dmsg1(2300, "No job running. Look for Job pri=%d\n", Priority);
+         }
+         /*
+          * Walk down the list of waiting jobs and attempt
+          *   to acquire the resources it needs.
+          */
+         for ( ; je;  ) {
+            /* je is current job item on the queue, jn is the next one */
+            JCR *jcr = je->jcr;
+            jobq_item_t *jn = (jobq_item_t *)jq->waiting_jobs->next(je);
+
+            Dmsg4(2300, "Examining Job=%d JobPri=%d want Pri=%d (%s)\n",
+                 jcr->JobId, jcr->JobPriority, Priority,
+                 jcr->job->allow_mixed_priority ? "mix" : "no mix");
+
+            /* Take only jobs of correct Priority */
+            if (!(jcr->JobPriority == Priority
+                 || (jcr->JobPriority < Priority &&
+                     jcr->job->allow_mixed_priority && running_allow_mix))) {
+               set_jcr_job_status(jcr, JS_WaitPriority);
+               break;
+            }
+
+            if (!acquire_resources(jcr)) {
+               /* If resource conflict, job is canceled */
+               if (!job_canceled(jcr)) {
+                  je = jn;            /* point to next waiting job */
+                  continue;
+               }
+            }
+
+            /*
+             * Got all locks, now remove it from wait queue and append it
+             *   to the ready queue.  Note, we may also get here if the
+             *    job was canceled.  Once it is "run", it will quickly
+             *    terminate.
+             */
+            jq->waiting_jobs->remove(je);
+            jq->ready_jobs->append(je);
             Dmsg1(2300, "moved JobId=%d from wait to ready queue\n", je->jcr->JobId);
-           je = jn;                  /* Point to next waiting job */
-        } /* end for loop */
-        break;
-      } /* end while loop */
+            je = jn;                  /* Point to next waiting job */
+         } /* end for loop */
+
+      } /* end if */
+
       Dmsg0(2300, "Done checking wait queue.\n");
       /*
        * If no more ready work and we are asked to quit, then do it
        */
       if (jq->ready_jobs->empty() && jq->quit) {
-        jq->num_workers--;
-        if (jq->num_workers == 0) {
+         jq->num_workers--;
+         if (jq->num_workers == 0) {
             Dmsg0(2300, "Wake up destroy routine\n");
-           /* Wake up destroy routine if he is waiting */
-           pthread_cond_broadcast(&jq->work);
-        }
-        break;
+            /* Wake up destroy routine if he is waiting */
+            pthread_cond_broadcast(&jq->work);
+         }
+         break;
       }
       Dmsg0(2300, "Check for work request\n");
       /*
        * If no more work requests, and we waited long enough, quit
        */
       Dmsg2(2300, "timedout=%d read empty=%d\n", timedout,
-        jq->ready_jobs->empty());
+         jq->ready_jobs->empty());
       if (jq->ready_jobs->empty() && timedout) {
          Dmsg0(2300, "break big loop\n");
-        jq->num_workers--;
-        break;
+         jq->num_workers--;
+         break;
       }
 
       work = !jq->ready_jobs->empty() || !jq->waiting_jobs->empty();
       if (work) {
-        /*
+         /*
           * If a job is waiting on a Resource, don't consume all
-         *   the CPU time looping looking for work, and even more
-         *   important, release the lock so that a job that has
-         *   terminated can give us the resource.
-         */
-        if ((stat = pthread_mutex_unlock(&jq->mutex)) != 0) {
-           berrno be;
-            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", be.strerror(stat));
-           jq->num_workers--;
-           return NULL;
-        }
-        bmicrosleep(2, 0);              /* pause for 2 seconds */
-        if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
-           berrno be;
-            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", be.strerror(stat));
-           jq->num_workers--;
-           return NULL;
-        }
-        /* Recompute work as something may have changed in last 2 secs */
-        work = !jq->ready_jobs->empty() || !jq->waiting_jobs->empty();
+          *   the CPU time looping looking for work, and even more
+          *   important, release the lock so that a job that has
+          *   terminated can give us the resource.
+          */
+         V(jq->mutex);
+         bmicrosleep(2, 0);              /* pause for 2 seconds */
+         P(jq->mutex);
+         /* Recompute work as something may have changed in last 2 secs */
+         work = !jq->ready_jobs->empty() || !jq->waiting_jobs->empty();
       }
       Dmsg1(2300, "Loop again. work=%d\n", work);
    } /* end of big for loop */
 
    Dmsg0(200, "unlock mutex\n");
-   if ((stat = pthread_mutex_unlock(&jq->mutex)) != 0) {
-      berrno be;
-      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", be.strerror(stat));
-   }
+   V(jq->mutex);
    Dmsg0(2300, "End jobq_server\n");
    return NULL;
 }
+
+/*
+ * Returns true if cleanup done and we should look for more work
+ */
+static bool reschedule_job(JCR *jcr, jobq_t *jq, jobq_item_t *je)
+{
+   /*
+    * Reschedule the job if necessary and requested
+    */
+   if (jcr->job->RescheduleOnError &&
+       jcr->JobStatus != JS_Terminated &&
+       jcr->JobStatus != JS_Canceled &&
+       jcr->get_JobType() == JT_BACKUP &&
+       (jcr->job->RescheduleTimes == 0 ||
+        jcr->reschedule_count < jcr->job->RescheduleTimes)) {
+       char dt[50], dt2[50];
+
+       /*
+        * Reschedule this job by cleaning it up, but
+        *  reuse the same JobId if possible.
+        */
+      time_t now = time(NULL);
+      jcr->reschedule_count++;
+      jcr->sched_time = now + jcr->job->RescheduleInterval;
+      bstrftime(dt, sizeof(dt), now);
+      bstrftime(dt2, sizeof(dt2), jcr->sched_time);
+      Dmsg4(2300, "Rescheduled Job %s to re-run in %d seconds.(now=%u,then=%u)\n", jcr->Job,
+            (int)jcr->job->RescheduleInterval, now, jcr->sched_time);
+      Jmsg(jcr, M_INFO, 0, _("Rescheduled Job %s at %s to re-run in %d seconds (%s).\n"),
+           jcr->Job, dt, (int)jcr->job->RescheduleInterval, dt2);
+      dird_free_jcr_pointers(jcr);     /* partial cleanup old stuff */
+      jcr->JobStatus = -1;
+      set_jcr_job_status(jcr, JS_WaitStartTime);
+      jcr->SDJobStatus = 0;
+      if (!allow_duplicate_job(jcr)) {
+         return false;
+      }
+      if (jcr->JobBytes == 0) {
+         Dmsg2(2300, "Requeue job=%d use=%d\n", jcr->JobId, jcr->use_count());
+         V(jq->mutex);
+         jobq_add(jq, jcr);     /* queue the job to run again */
+         P(jq->mutex);
+         free_jcr(jcr);         /* release jcr */
+         free(je);              /* free the job entry */
+         return true;           /* we already cleaned up */
+      }
+      /*
+       * Something was actually backed up, so we cannot reuse
+       *   the old JobId or there will be database record
+       *   conflicts.  We now create a new job, copying the
+       *   appropriate fields.
+       */           
+      JCR *njcr = new_jcr(sizeof(JCR), dird_free_jcr);
+      set_jcr_defaults(njcr, jcr->job);
+      njcr->reschedule_count = jcr->reschedule_count;
+      njcr->sched_time = jcr->sched_time;
+      njcr->set_JobLevel(jcr->get_JobLevel());
+      njcr->pool = jcr->pool;
+      njcr->run_pool_override = jcr->run_pool_override;
+      njcr->full_pool = jcr->full_pool;
+      njcr->run_full_pool_override = jcr->run_full_pool_override;
+      njcr->inc_pool = jcr->inc_pool;
+      njcr->run_inc_pool_override = jcr->run_inc_pool_override;
+      njcr->diff_pool = jcr->diff_pool;
+      njcr->JobStatus = -1;
+      set_jcr_job_status(njcr, jcr->JobStatus);
+      if (jcr->rstore) {
+         copy_rstorage(njcr, jcr->rstorage, _("previous Job"));
+      } else {
+         free_rstorage(njcr);
+      }
+      if (jcr->wstore) {
+         copy_wstorage(njcr, jcr->wstorage, _("previous Job"));
+      } else {
+         free_wstorage(njcr);
+      }
+      njcr->messages = jcr->messages;
+      njcr->spool_data = jcr->spool_data;
+      njcr->write_part_after_job = jcr->write_part_after_job;
+      Dmsg0(2300, "Call to run new job\n");
+      V(jq->mutex);
+      run_job(njcr);            /* This creates a "new" job */
+      free_jcr(njcr);           /* release "new" jcr */
+      P(jq->mutex);
+      Dmsg0(2300, "Back from running new job.\n");
+   }
+   return false;
+}
+
+/*
+ * See if we can acquire all the necessary resources for the job (JCR)
+ *
+ *  Returns: true  if successful
+ *           false if resource failure
+ */
+static bool acquire_resources(JCR *jcr)
+{
+   bool skip_this_jcr = false;
+
+   jcr->acquired_resource_locks = false;
+   if (jcr->rstore && jcr->rstore == jcr->wstore) {    /* possible deadlock */
+      Jmsg(jcr, M_FATAL, 0, _("Job canceled. Attempt to read and write same device.\n"
+         "    Read storage \"%s\" (From %s) -- Write storage \"%s\" (From %s)\n"), 
+         jcr->rstore->name(), jcr->rstore_source, jcr->wstore->name(), jcr->wstore_source);
+      set_jcr_job_status(jcr, JS_Canceled);
+      return false;
+   }
+   if (jcr->rstore) {
+      Dmsg1(200, "Rstore=%s\n", jcr->rstore->name());
+      if (jcr->rstore->NumConcurrentJobs < jcr->rstore->MaxConcurrentJobs) {
+         jcr->rstore->NumConcurrentReadJobs++;
+         jcr->rstore->NumConcurrentJobs++;
+         Dmsg1(200, "Inc rncj=%d\n", jcr->rstore->NumConcurrentJobs);
+      } else {
+         Dmsg1(200, "Fail rncj=%d\n", jcr->rstore->NumConcurrentJobs);
+         set_jcr_job_status(jcr, JS_WaitStoreRes);
+         return false;
+      }
+   }
+   
+   if (jcr->wstore) {
+      Dmsg1(200, "Wstore=%s\n", jcr->wstore->name());
+      if (jcr->wstore->NumConcurrentJobs < jcr->wstore->MaxConcurrentJobs) {
+         jcr->wstore->NumConcurrentJobs++;
+         Dmsg1(200, "Inc wncj=%d\n", jcr->wstore->NumConcurrentJobs);
+      } else if (jcr->rstore) {
+         dec_read_store(jcr);
+         skip_this_jcr = true;
+      } else {
+         Dmsg1(200, "Fail wncj=%d\n", jcr->wstore->NumConcurrentJobs);
+         skip_this_jcr = true;
+      }
+   }
+   if (skip_this_jcr) {
+      set_jcr_job_status(jcr, JS_WaitStoreRes);
+      return false;
+   }
+
+   if (jcr->client->NumConcurrentJobs < jcr->client->MaxConcurrentJobs) {
+      jcr->client->NumConcurrentJobs++;
+   } else {
+      /* Back out previous locks */
+      dec_write_store(jcr);
+      dec_read_store(jcr);
+      set_jcr_job_status(jcr, JS_WaitClientRes);
+      return false;
+   }
+   if (jcr->job->NumConcurrentJobs < jcr->job->MaxConcurrentJobs) {
+      jcr->job->NumConcurrentJobs++;
+   } else {
+      /* Back out previous locks */
+      dec_write_store(jcr);
+      dec_read_store(jcr);
+      jcr->client->NumConcurrentJobs--;
+      set_jcr_job_status(jcr, JS_WaitJobRes);
+      return false;
+   }
+
+   jcr->acquired_resource_locks = true;
+   return true;
+}
+
+static void dec_read_store(JCR *jcr)
+{
+   if (jcr->rstore) {
+      jcr->rstore->NumConcurrentReadJobs--;    /* back out rstore */
+      jcr->rstore->NumConcurrentJobs--;        /* back out rstore */
+      Dmsg1(200, "Dec rncj=%d\n", jcr->rstore->NumConcurrentJobs);
+      ASSERT(jcr->rstore->NumConcurrentReadJobs >= 0);
+      ASSERT(jcr->rstore->NumConcurrentJobs >= 0);
+   }
+}
+
+static void dec_write_store(JCR *jcr)
+{
+   if (jcr->wstore) {
+      jcr->wstore->NumConcurrentJobs--;
+      Dmsg1(200, "Dec wncj=%d\n", jcr->wstore->NumConcurrentJobs);
+      ASSERT(jcr->wstore->NumConcurrentJobs >= 0);
+   }
+}