]> git.sur5r.net Git - bacula/bacula/blobdiff - bacula/src/dird/jobq.c
- Add index file to JobId field of File records for PostgreSQL.
[bacula/bacula] / bacula / src / dird / jobq.c
index c552aa781acdcb28c7986375757bc9aa3365e270..35438cfcf7b3d940954ba5f400c9ba5dee20d47a 100755 (executable)
@@ -18,7 +18,7 @@
  *
  */
 /*
-   Copyright (C) 2000-2003 Kern Sibbald and John Walker
+   Copyright (C) 2003-2004 Kern Sibbald and John Walker
 
    This program is free software; you can redistribute it and/or
    modify it under the terms of the GNU General Public License as
@@ -42,7 +42,9 @@
 
 
 /* Forward referenced functions */
-static void *jobq_server(void *arg);
+extern "C" void *jobq_server(void *arg);
+extern "C" void *sched_wait(void *arg);
+
 static int   start_server(jobq_t *jq);
 
 /*   
@@ -82,9 +84,9 @@ int jobq_init(jobq_t *jq, int threads, void *(*engine)(void *arg))
    jq->engine = engine;              /* routine to run */
    jq->valid = JOBQ_VALID; 
    /* Initialize the job queues */
-   jq->waiting_jobs = new dlist(item, &item->link);
-   jq->running_jobs = new dlist(item, &item->link);
-   jq->ready_jobs = new dlist(item, &item->link);
+   jq->waiting_jobs = New(dlist(item, &item->link));
+   jq->running_jobs = New(dlist(item, &item->link));
+   jq->ready_jobs = New(dlist(item, &item->link));
    return 0;
 }
 
@@ -152,23 +154,24 @@ struct wait_pkt {
  *  most jobs are put into the job queue only when their
  *  scheduled time arives.
  */
-static void *sched_wait(void *arg)
+extern "C"  
+void *sched_wait(void *arg)
 {
    JCR *jcr = ((wait_pkt *)arg)->jcr;
    jobq_t *jq = ((wait_pkt *)arg)->jq;
 
-   Dmsg0(010, "Enter sched_wait.\n");
+   Dmsg0(300, "Enter sched_wait.\n");
    free(arg);
    time_t wtime = jcr->sched_time - time(NULL);
+   set_jcr_job_status(jcr, JS_WaitStartTime);
    /* Wait until scheduled time arrives */
-   if (wtime > 0 && verbose) {
+   if (wtime > 0) {
       Jmsg(jcr, M_INFO, 0, _("Job %s waiting %d seconds for scheduled start time.\n"), 
         jcr->Job, wtime);
-      set_jcr_job_status(jcr, JS_WaitStartTime);
    }
    /* Check every 30 seconds if canceled */ 
    while (wtime > 0) {
-      Dmsg2(010, "Waiting on sched time, jobid=%d secs=%d\n", jcr->JobId, wtime);
+      Dmsg2(300, "Waiting on sched time, jobid=%d secs=%d\n", jcr->JobId, wtime);
       if (wtime > 30) {
         wtime = 30;
       }
@@ -182,11 +185,10 @@ static void *sched_wait(void *arg)
    jobq_add(jq, jcr);
    V(jcr->mutex);
    free_jcr(jcr);                    /* we are done with jcr */
-   Dmsg0(010, "Exit sched_wait\n");
+   Dmsg0(300, "Exit sched_wait\n");
    return NULL;
 }
 
-
 /*
  *  Add a job to the queue
  *    jq is a queue that was created with jobq_init
@@ -203,24 +205,23 @@ int jobq_add(jobq_t *jq, JCR *jcr)
    pthread_t id;
    wait_pkt *sched_pkt;
     
-   Dmsg3(010, "jobq_add jobid=%d jcr=0x%x use_count=%d\n", jcr->JobId, jcr, jcr->use_count);
+   Dmsg3(300, "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(010, "jobq_add jobid=%d jcr=0x%x use_count=%d\n", jcr->JobId, jcr, jcr->use_count);
+   Dmsg3(300, "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 */
          Jmsg1(jcr, M_ERROR, 0, "pthread_thread_create: ERR=%s\n", strerror(stat));
-        jcr->use_count--;            /* release jcr */
       }
       return stat;
    }
@@ -240,15 +241,15 @@ int jobq_add(jobq_t *jq, JCR *jcr)
    if (job_canceled(jcr)) {
       /* Add job to ready queue so that it is canceled quickly */
       jq->ready_jobs->prepend(item);
-      Dmsg1(010, "Prepended job=%d to ready queue\n", jcr->JobId);
+      Dmsg1(300, "Prepended job=%d to ready queue\n", jcr->JobId);
    } else {
       /* Add this job to the wait queue in priority sorted order */
       foreach_dlist(li, jq->waiting_jobs) {
-         Dmsg2(010, "waiting item jobid=%d priority=%d\n",
+         Dmsg2(300, "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);
-            Dmsg2(010, "insert_before jobid=%d before waiting job=%d\n", 
+            Dmsg2(300, "insert_before jobid=%d before waiting job=%d\n", 
               li->jcr->JobId, jcr->JobId);
            inserted = true;
            break;
@@ -257,7 +258,7 @@ int jobq_add(jobq_t *jq, JCR *jcr)
       /* If not jobs in wait queue, append it */
       if (!inserted) {
         jq->waiting_jobs->append(item);
-         Dmsg1(010, "Appended item jobid=%d to waiting queue\n", jcr->JobId);
+         Dmsg1(300, "Appended item jobid=%d to waiting queue\n", jcr->JobId);
       }
    }
 
@@ -265,7 +266,7 @@ int jobq_add(jobq_t *jq, JCR *jcr)
    stat = start_server(jq);
 
    pthread_mutex_unlock(&jq->mutex);
-   Dmsg0(010, "Return jobq_add\n");
+   Dmsg0(300, "Return jobq_add\n");
    return stat;
 }
 
@@ -284,7 +285,7 @@ int jobq_remove(jobq_t *jq, JCR *jcr)
    bool found = false;
    jobq_item_t *item;
     
-   Dmsg2(010, "jobq_remove jobid=%d jcr=0x%x\n", jcr->JobId, jcr);
+   Dmsg2(300, "jobq_remove jobid=%d jcr=0x%x\n", jcr->JobId, jcr);
    if (jq->valid != JOBQ_VALID) {
       return EINVAL;
    }
@@ -302,19 +303,19 @@ int jobq_remove(jobq_t *jq, JCR *jcr)
    }
    if (!found) {
       pthread_mutex_unlock(&jq->mutex);
-      Dmsg2(010, "jobq_remove jobid=%d jcr=0x%x not in wait queue\n", jcr->JobId, jcr);
+      Dmsg2(300, "jobq_remove jobid=%d jcr=0x%x not in wait queue\n", jcr->JobId, jcr);
       return EINVAL;
    }
 
    /* Move item to be the first on the list */
    jq->waiting_jobs->remove(item);
    jq->ready_jobs->prepend(item);
-   Dmsg2(010, "jobq_remove jobid=%d jcr=0x%x moved to ready queue\n", jcr->JobId, jcr);
+   Dmsg2(300, "jobq_remove jobid=%d jcr=0x%x moved to ready queue\n", jcr->JobId, jcr);
    
    stat = start_server(jq);
 
    pthread_mutex_unlock(&jq->mutex);
-   Dmsg0(010, "Return jobq_remove\n");
+   Dmsg0(300, "Return jobq_remove\n");
    return stat;
 }
 
@@ -329,13 +330,13 @@ static int start_server(jobq_t *jq)
 
    /* if any threads are idle, wake one */
    if (jq->idle_workers > 0) {
-      Dmsg0(010, "Signal worker to wake up\n");
+      Dmsg0(300, "Signal worker to wake up\n");
       if ((stat = pthread_cond_signal(&jq->work)) != 0) {
          Jmsg1(NULL, M_ERROR, 0, "pthread_cond_signal: ERR=%s\n", strerror(stat));
         return stat;
       }
    } else if (jq->num_workers < jq->max_workers) {
-      Dmsg0(010, "Create worker thread\n");
+      Dmsg0(300, "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) {
@@ -352,16 +353,17 @@ static int start_server(jobq_t *jq)
  * When all the resources are acquired for the job, 
  *  it will call the user's engine.
  */
-static void *jobq_server(void *arg)
+extern "C"  
+void *jobq_server(void *arg)
 {
    struct timespec timeout;
    jobq_t *jq = (jobq_t *)arg;
    jobq_item_t *je;                  /* job entry in queue */
    int stat;
-   bool timedout;
+   bool timedout = false;
    bool work = true;
 
-   Dmsg0(010, "Start jobq_server\n");
+   Dmsg0(300, "Start jobq_server\n");
    if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
       Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", strerror(stat));
       return NULL;
@@ -372,42 +374,43 @@ static void *jobq_server(void *arg)
       struct timeval tv;
       struct timezone tz;
 
-      Dmsg0(010, "Top of for loop\n");
-      timedout = false;
-      gettimeofday(&tv, &tz);
-      timeout.tv_nsec = 0;
-      timeout.tv_sec = tv.tv_sec + 4;
+      Dmsg0(300, "Top of for loop\n");
+      if (!work && !jq->quit) {
+        gettimeofday(&tv, &tz);
+        timeout.tv_nsec = 0;
+        timeout.tv_sec = tv.tv_sec + 4;
 
-      while (!work && !jq->quit) {
-        /*
-         * Wait 4 seconds, then if no more work, exit
-         */
-         Dmsg0(010, "pthread_cond_timedwait()\n");
-        stat = pthread_cond_timedwait(&jq->work, &jq->mutex, &timeout);
-        if (stat == ETIMEDOUT) {
-            Dmsg0(010, "timedwait timedout.\n");
-           timedout = true;
+        while (!jq->quit) {
+           /*
+            * Wait 4 seconds, then if no more work, exit
+            */
+            Dmsg0(300, "pthread_cond_timedwait()\n");
+           stat = pthread_cond_timedwait(&jq->work, &jq->mutex, &timeout);
+           if (stat == ETIMEDOUT) {
+               Dmsg0(300, "timedwait timedout.\n");
+              timedout = true;
+              break;
+           } else if (stat != 0) {
+               /* This shouldn't happen */
+               Dmsg0(300, "This shouldn't happen\n");
+              jq->num_workers--;
+              pthread_mutex_unlock(&jq->mutex);
+              return NULL;
+           }
            break;
-        } else if (stat != 0) {
-            /* This shouldn't happen */
-            Dmsg0(010, "This shouldn't happen\n");
-           jq->num_workers--;
-           pthread_mutex_unlock(&jq->mutex);
-           return NULL;
-        }
-        break;
-      } 
+        } 
+      }
       /* 
        * If anything is in the ready queue, run it
        */
-      Dmsg0(010, "Checking ready queue.\n");
+      Dmsg0(300, "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()) {
-            Dmsg0(010, "ready queue not empty start server\n");
+            Dmsg0(300, "ready queue not empty start server\n");
            if (start_server(jq) != 0) {
               jq->num_workers--;
               pthread_mutex_unlock(&jq->mutex);
@@ -415,18 +418,24 @@ static void *jobq_server(void *arg)
            }
         }
         jq->running_jobs->append(je);
-         Dmsg1(010, "Took jobid=%d from ready and appended to run\n", jcr->JobId);
+         Dmsg1(300, "Took jobid=%d from ready and appended to run\n", jcr->JobId);
+
+        /* Release job queue lock */
         if ((stat = pthread_mutex_unlock(&jq->mutex)) != 0) {
             Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", strerror(stat));
            jq->num_workers--;
            return NULL;
         }
+
          /* Call user's routine here */
-         Dmsg1(010, "Calling user engine for jobid=%d\n", jcr->JobId);
+         Dmsg1(300, "Calling user engine for jobid=%d\n", jcr->JobId);
         jq->engine(je->jcr);
-         Dmsg1(010, "Back from user engine jobid=%d.\n", jcr->JobId);
+
+         Dmsg1(300, "Back from user engine jobid=%d.\n", jcr->JobId);
+
+        /* Reacquire job queue lock */
         if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
-            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", strerror(stat));
+            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", strerror(stat));
            jq->num_workers--;
            free(je);                 /* release job entry */
            return NULL;
@@ -440,15 +449,22 @@ static void *jobq_server(void *arg)
          */
         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
@@ -456,12 +472,17 @@ static void *jobq_server(void *arg)
              */
            jcr->reschedule_count++;
            jcr->sched_time = time(NULL) + jcr->job->RescheduleInterval;
-            Dmsg2(010, "Rescheduled Job %s to re-run in %d seconds.\n", jcr->Job,
+            Dmsg2(300, "Rescheduled Job %s to re-run in %d seconds.\n", jcr->Job,
               (int)jcr->job->RescheduleInterval);
-           jcr->JobStatus = JS_Created; /* force new status */
+           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(010, "Requeue job=%d\n", jcr->JobId);
+               Dmsg1(300, "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);
@@ -482,37 +503,40 @@ static void *jobq_server(void *arg)
            njcr->pool = jcr->pool;
            njcr->store = jcr->store;
            njcr->messages = jcr->messages;
-            Dmsg0(010, "Call to run new job\n");
+            Dmsg0(300, "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(010, "Back from running new job.\n");
+            Dmsg0(300, "Back from running new job.\n");
         }
         /* Clean up and release old jcr */
         if (jcr->db) {
            db_close_database(jcr, jcr->db);
            jcr->db = NULL;
         }
-         Dmsg1(010, "====== Termination job=%d\n", jcr->JobId);
+         Dmsg2(300, "====== 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(010, "Done check ready, now check wait queue.\n");
+      Dmsg0(300, "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(010, "JobId %d is running. Set pri=%d\n", re->jcr->JobId, Priority);
+            Dmsg2(300, "JobId %d is running. Look for pri=%d\n", re->jcr->JobId, Priority);
         } else {
            Priority = je->jcr->JobPriority;
-            Dmsg1(010, "No job running. Set Job pri=%d\n", Priority);
+            Dmsg1(300, "No job running. Look for Job pri=%d\n", Priority);
         }
         /*
          * Walk down the list of waiting jobs and attempt
@@ -522,24 +546,40 @@ static void *jobq_server(void *arg)
            /* 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);
-            Dmsg3(010, "Examining Job=%d JobPri=%d want Pri=%d\n",
+            Dmsg3(300, "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->store->NumConcurrentJobs < jcr->store->MaxConcurrentJobs) {
+           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;
+                 continue;
+              }
+           } else if (jcr->store->NumConcurrentJobs < jcr->store->MaxConcurrentJobs) {
               jcr->store->NumConcurrentJobs++;
            } else {
               set_jcr_job_status(jcr, JS_WaitStoreRes);
               je = jn;
               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;
               continue;
@@ -547,7 +587,11 @@ static void *jobq_server(void *arg)
            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;
@@ -559,41 +603,65 @@ static void *jobq_server(void *arg)
            jcr->acquired_resource_locks = true;
            jq->waiting_jobs->remove(je);
            jq->ready_jobs->append(je);
-            Dmsg1(010, "moved JobId=%d from wait to ready queue\n", je->jcr->JobId);
+            Dmsg1(300, "moved JobId=%d from wait to ready queue\n", je->jcr->JobId);
            je = jn;
         } /* end for loop */
         break;
       } /* end while loop */
-      Dmsg0(010, "Done checking wait queue.\n");
+      Dmsg0(300, "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) {
-            Dmsg0(010, "Wake up destroy routine\n");
+            Dmsg0(300, "Wake up destroy routine\n");
            /* Wake up destroy routine if he is waiting */
            pthread_cond_broadcast(&jq->work);
         }
         break;
       }
-      Dmsg0(010, "Check for work request\n");
+      Dmsg0(300, "Check for work request\n");
       /* 
        * If no more work requests, and we waited long enough, quit
        */
-      Dmsg2(010, "timedout=%d read empty=%d\n", timedout,
+      Dmsg2(300, "timedout=%d read empty=%d\n", timedout,
         jq->ready_jobs->empty());
       if (jq->ready_jobs->empty() && timedout) {
-         Dmsg0(010, "break big loop\n");
+         Dmsg0(300, "break big loop\n");
         jq->num_workers--;
         break;
       }
-      work = !jq->ready_jobs->empty() || !jq->waiting_jobs->empty();              
-      Dmsg1(010, "Loop again. work=%d\n", work);
+
+      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) {
+            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", strerror(stat));
+           jq->num_workers--;
+           return NULL;
+        }
+        bmicrosleep(2, 0);              /* pause for 2 seconds */
+        if ((stat = pthread_mutex_lock(&jq->mutex)) != 0) {
+            Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_lock: ERR=%s\n", 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();
+      }
+      Dmsg1(300, "Loop again. work=%d\n", work);
    } /* end of big for loop */
 
    Dmsg0(200, "unlock mutex\n");
-   pthread_mutex_unlock(&jq->mutex);
-   Dmsg0(010, "End jobq_server\n");
+   if ((stat = pthread_mutex_unlock(&jq->mutex)) != 0) {
+      Jmsg1(NULL, M_ERROR, 0, "pthread_mutex_unlock: ERR=%s\n", strerror(stat));
+   }
+   Dmsg0(300, "End jobq_server\n");
    return NULL;
 }