Don't NULL self->request until after we're done using it
[freeradius.git] / src / main / threads.c
1 /*
2  * threads.c    request threading support
3  *
4  * Version:     $Id$
5  *
6  *   This program is free software; you can redistribute it and/or modify
7  *   it under the terms of the GNU General Public License as published by
8  *   the Free Software Foundation; either version 2 of the License, or
9  *   (at your option) any later version.
10  *
11  *   This program is distributed in the hope that it will be useful,
12  *   but WITHOUT ANY WARRANTY; without even the implied warranty of
13  *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the
14  *   GNU General Public License for more details.
15  *
16  *   You should have received a copy of the GNU General Public License
17  *   along with this program; if not, write to the Free Software
18  *   Foundation, Inc., 51 Franklin St, Fifth Floor, Boston, MA 02110-1301, USA
19  *
20  * Copyright 2000  The FreeRADIUS server project
21  * Copyright 2000  Alan DeKok <aland@ox.org>
22  */
23
24 #include <freeradius-devel/autoconf.h>
25
26 #include <stdlib.h>
27 #include <string.h>
28
29 /*
30  *      Other OS's have sem_init, OS X doesn't.
31  */
32 #ifndef DARWIN
33 #include <semaphore.h>
34 #else
35 #include <mach/task.h>
36 #include <mach/semaphore.h>
37
38 #undef sem_t
39 #define sem_t semaphore_t
40 #undef sem_init
41 #define sem_init(s,p,c) semaphore_create(mach_task_self(),s,SYNC_POLICY_FIFO,c)
42 #undef sem_wait
43 #define sem_wait(s) semaphore_wait(*s)
44 #undef sem_post
45 #define sem_post(s) semaphore_signal(*s)
46 #endif
47
48 #include <signal.h>
49
50 #ifdef HAVE_SYS_WAIT_H
51 #include <sys/wait.h>
52 #endif
53
54 #include <freeradius-devel/radiusd.h>
55 #include <freeradius-devel/rad_assert.h>
56 #include <freeradius-devel/conffile.h>
57 #include <freeradius-devel/modules.h>
58
59 static const char rcsid[] =
60 "$Id$";
61
62 #ifdef HAVE_PTHREAD_H
63
64 #ifdef HAVE_OPENSSL_CRYPTO_H
65 #include <openssl/crypto.h>
66 #endif
67 #ifdef HAVE_OPENSSL_ERR_H
68 #include <openssl/err.h>
69 #endif
70
71 #define SEMAPHORE_LOCKED        (0)
72 #define SEMAPHORE_UNLOCKED      (1)
73
74 #define THREAD_RUNNING          (1)
75 #define THREAD_CANCELLED        (2)
76 #define THREAD_EXITED           (3)
77
78 #define NUM_FIFOS               (2)
79
80 /*
81  *     Ordered this way because we prefer proxy, then ongoing, then
82  *     start.
83  */
84 #define FIFO_START   (1)
85 #define FIFO_PROXY   (0)
86
87 /*
88  *  A data structure which contains the information about
89  *  the current thread.
90  *
91  *  pthread_id     pthread id
92  *  thread_num     server thread number, 1...number of threads
93  *  semaphore     used to block the thread until a request comes in
94  *  status        is the thread running or exited?
95  *  request_count the number of requests that this thread has handled
96  *  timestamp     when the thread started executing.
97  */
98 typedef struct THREAD_HANDLE {
99         struct THREAD_HANDLE *prev;
100         struct THREAD_HANDLE *next;
101         pthread_t            pthread_id;
102         int                  thread_num;
103         int                  status;
104         unsigned int         request_count;
105         time_t               timestamp;
106         REQUEST              *request;
107 } THREAD_HANDLE;
108
109 /*
110  *      For the request queue.
111  */
112 typedef struct request_queue_t {
113         REQUEST           *request;
114         RAD_REQUEST_FUNP  fun;
115 } request_queue_t;
116
117 typedef struct thread_fork_t {
118         pid_t           pid;
119         int             status;
120         int             exited;
121 } thread_fork_t;
122
123
124 /*
125  *      A data structure to manage the thread pool.  There's no real
126  *      need for a data structure, but it makes things conceptually
127  *      easier.
128  */
129 typedef struct THREAD_POOL {
130         THREAD_HANDLE *head;
131         THREAD_HANDLE *tail;
132
133         int total_threads;
134         int active_threads;     /* protected by queue_mutex */
135         int max_thread_num;
136         int start_threads;
137         int max_threads;
138         int min_spare_threads;
139         int max_spare_threads;
140         unsigned int max_requests_per_thread;
141         unsigned long request_count;
142         time_t time_last_spawned;
143         int cleanup_delay;
144         int spawn_flag;
145
146         pthread_mutex_t wait_mutex;
147         lrad_hash_table_t *waiters;
148
149         /*
150          *      All threads wait on this semaphore, for requests
151          *      to enter the queue.
152          */
153         sem_t           semaphore;
154
155         /*
156          *      To ensure only one thread at a time touches the queue.
157          */
158         pthread_mutex_t queue_mutex;
159
160         int             max_queue_size;
161         int             num_queued;
162         int             fifo_state;
163         lrad_fifo_t     *fifo[NUM_FIFOS];
164 } THREAD_POOL;
165
166 static THREAD_POOL thread_pool;
167 static int pool_initialized = FALSE;
168
169
170 /*
171  *      A mapping of configuration file names to internal integers
172  */
173 static const CONF_PARSER thread_config[] = {
174         { "start_servers",           PW_TYPE_INTEGER, 0, &thread_pool.start_threads,           "5" },
175         { "max_servers",             PW_TYPE_INTEGER, 0, &thread_pool.max_threads,             "32" },
176         { "min_spare_servers",       PW_TYPE_INTEGER, 0, &thread_pool.min_spare_threads,       "3" },
177         { "max_spare_servers",       PW_TYPE_INTEGER, 0, &thread_pool.max_spare_threads,       "10" },
178         { "max_requests_per_server", PW_TYPE_INTEGER, 0, &thread_pool.max_requests_per_thread, "0" },
179         { "cleanup_delay",           PW_TYPE_INTEGER, 0, &thread_pool.cleanup_delay,           "5" },
180         { "max_queue_size",          PW_TYPE_INTEGER, 0, &thread_pool.max_queue_size,           "65536" },
181         { NULL, -1, 0, NULL, NULL }
182 };
183
184
185 #ifdef HAVE_OPENSSL_CRYPTO_H
186
187 /*
188  *      If we're linking against OpenSSL, then it is the
189  *      duty of the application, if it is multithreaded,
190  *      to provide OpenSSL with appropriate thread id
191  *      and mutex locking functions
192  *
193  *      Note: this only implements static callbacks.
194  *      OpenSSL does not use dynamic locking callbacks
195  *      right now, but may in the futiure, so we will have
196  *      to add them at some point.
197  */
198
199 static pthread_mutex_t *ssl_mutexes = NULL;
200
201 static unsigned long ssl_id_function(void)
202 {
203         return (unsigned long) pthread_self();
204 }
205
206 static void ssl_locking_function(int mode, int n, const char *file, int line)
207 {
208         file = file;            /* -Wunused */
209         line = line;            /* -Wunused */
210
211         if (mode & CRYPTO_LOCK) {
212                 pthread_mutex_lock(&(ssl_mutexes[n]));
213         } else {
214                 pthread_mutex_unlock(&(ssl_mutexes[n]));
215         }
216 }
217
218 static int setup_ssl_mutexes(void)
219 {
220         int i;
221
222         ssl_mutexes = rad_malloc(CRYPTO_num_locks() * sizeof(pthread_mutex_t));
223         if (!ssl_mutexes) {
224                 radlog(L_ERR, "Error allocating memory for SSL mutexes!");
225                 return 0;
226         }
227
228         for (i = 0; i < CRYPTO_num_locks(); i++) {
229                 pthread_mutex_init(&(ssl_mutexes[i]), NULL);
230         }
231
232         CRYPTO_set_id_callback(ssl_id_function);
233         CRYPTO_set_locking_callback(ssl_locking_function);
234
235         return 1;
236 }
237 #endif
238
239
240 /*
241  *      We don't want to catch SIGCHLD for a host of reasons.
242  *
243  *      - exec_wait means that someone, somewhere, somewhen, will
244  *      call waitpid(), and catch the child.
245  *
246  *      - SIGCHLD is delivered to a random thread, not the one that
247  *      forked.
248  *
249  *      - if another thread catches the child, we have to coordinate
250  *      with the thread doing the waiting.
251  *
252  *      - if we don't waitpid() for non-wait children, they'll be zombies,
253  *      and will hang around forever.
254  *
255  */
256 static void reap_children(void)
257 {
258         pid_t pid;
259         int status;
260         thread_fork_t mytf, *tf;
261
262         if (lrad_hash_table_num_elements(thread_pool.waiters) == 0) return;
263
264         pthread_mutex_lock(&thread_pool.wait_mutex);
265
266         while (1) {
267                 pid = waitpid(0, &status, WNOHANG);
268                 if (pid <= 0) break;
269
270                 mytf.pid = pid;
271                 tf = lrad_hash_table_finddata(thread_pool.waiters, &mytf);
272                 if (!tf) continue;
273                 
274                 tf->status = status;
275                 tf->exited = 1;
276         }
277
278         pthread_mutex_unlock(&thread_pool.wait_mutex);
279 }
280
281 /*
282  *      Add a request to the list of waiting requests.
283  *      This function gets called ONLY from the main handler thread...
284  *
285  *      This function should never fail.
286  */
287 static int request_enqueue(REQUEST *request, RAD_REQUEST_FUNP fun)
288 {
289         int fifo = FIFO_START;
290         request_queue_t *entry;
291
292         pthread_mutex_lock(&thread_pool.queue_mutex);
293
294         thread_pool.request_count++;
295
296         /*
297          *      FIXME: Handle proxy replies separately?
298          */
299         if (thread_pool.num_queued >= thread_pool.max_queue_size) {
300                 pthread_mutex_unlock(&thread_pool.queue_mutex);
301                 
302                 /*
303                  *      Mark the request as done.
304                  */
305                 radlog(L_ERR|L_CONS, "!!! ERROR !!! The server is blocked: discarding new request %d", request->number);
306                 request->finished = TRUE;
307                 return 0;
308         }
309
310         /*
311          *      Requests get handled in priority.  First, we handle
312          *      replies from a home server, to finish ongoing requests.
313          *
314          *      Then, we handle requests with State, to finish
315          *      multi-packet transactions.
316          *
317          *      Finally, we handle new requests.
318          */
319         if (request->proxy_reply) {
320                 fifo = FIFO_PROXY;
321         } else {
322                 fifo = FIFO_START;
323         }
324
325         entry = rad_malloc(sizeof(*entry));
326         entry->request = request;
327         entry->fun = fun;
328
329         if (!lrad_fifo_push(thread_pool.fifo[fifo], entry)) {
330                 pthread_mutex_unlock(&thread_pool.queue_mutex);
331                 radlog(L_ERR, "!!! ERROR !!! Failed inserting request %d into the queue", request->number);
332                 request->finished = TRUE;
333                 return 0;
334         }
335
336         thread_pool.num_queued++;
337
338         pthread_mutex_unlock(&thread_pool.queue_mutex);
339
340         /*
341          *      There's one more request in the queue.
342          *
343          *      Note that we're not touching the queue any more, so
344          *      the semaphore post is outside of the mutex.  This also
345          *      means that when the thread wakes up and tries to lock
346          *      the mutex, it will be unlocked, and there won't be
347          *      contention.
348          */
349         sem_post(&thread_pool.semaphore);
350
351         return 1;
352 }
353
354 /*
355  *      Remove a request from the queue.
356  */
357 static int request_dequeue(REQUEST **request, RAD_REQUEST_FUNP *fun)
358 {
359         int fifo_state;
360         request_queue_t *entry;
361
362         reap_children();
363
364         pthread_mutex_lock(&thread_pool.queue_mutex);
365
366         fifo_state = thread_pool.fifo_state;
367
368  retry:
369         do {
370                 /*
371                  *      Pop an entry from the current queue, and go to
372                  *      the next queue.
373                  */
374                 entry = lrad_fifo_pop(thread_pool.fifo[fifo_state]);
375                 fifo_state++;
376                 if (fifo_state >= NUM_FIFOS) fifo_state = 0;
377         } while ((fifo_state != thread_pool.fifo_state) && !entry);
378
379         if (!entry) {
380                 pthread_mutex_unlock(&thread_pool.queue_mutex);
381                 *request = NULL;
382                 *fun = NULL;
383                 return 0;
384         }
385
386         rad_assert(thread_pool.num_queued > 0);
387         thread_pool.num_queued--;
388         *request = entry->request;
389         *fun = entry->fun;
390         free(entry);
391
392         rad_assert(*request != NULL);
393         rad_assert((*request)->magic == REQUEST_MAGIC);
394         rad_assert(*fun != NULL);
395
396         /*
397          *      If the request has sat in the queue for too long,
398          *      kill it.
399          *
400          *      The main clean-up code won't delete the request from
401          *      the request list, until it's marked "finished"
402          */
403         if ((*request)->options & RAD_REQUEST_OPTION_STOP_NOW) {
404                 (*request)->finished = 1;
405                 goto retry;
406         }
407
408         /*
409          *      The thread is currently processing a request.
410          */
411         thread_pool.active_threads++;
412         thread_pool.fifo_state = fifo_state;
413
414         pthread_mutex_unlock(&thread_pool.queue_mutex);
415
416         rad_assert((*request)->child_pid == NO_SUCH_CHILD_PID);
417
418         return 1;
419 }
420
421
422 /*
423  *      The main thread handler for requests.
424  *
425  *      Wait on the semaphore until we have it, and process the request.
426  */
427 static void *request_handler_thread(void *arg)
428 {
429         RAD_REQUEST_FUNP  fun;
430         THREAD_HANDLE     *self = (THREAD_HANDLE *) arg;
431 #ifdef HAVE_PTHREAD_SIGMASK
432         sigset_t set;
433
434         /*
435          *      Block SIGHUP handling for the child threads.
436          *
437          *      This ensures that only the main server thread will
438          *      process HUP signals.
439          *
440          *      If we don't have sigprocmask, then it shouldn't be
441          *      a problem, either, as the sig_hup handler should check
442          *      for this condition.
443          */
444         sigemptyset(&set);
445         sigaddset(&set, SIGHUP);
446         sigaddset(&set, SIGINT);
447         sigaddset(&set, SIGQUIT);
448         sigaddset(&set, SIGTERM);
449         pthread_sigmask(SIG_BLOCK, &set, NULL);
450 #endif
451
452         /*
453          *      Loop forever, until told to exit.
454          */
455         do {
456                 int finished;
457
458                 /*
459                  *      Wait to be signalled.
460                  */
461                 DEBUG2("Thread %d waiting to be assigned a request",
462                        self->thread_num);
463         re_wait:
464                 if (sem_wait(&thread_pool.semaphore) != 0) {
465                         /*
466                          *      Interrupted system call.  Go back to
467                          *      waiting, but DON'T print out any more
468                          *      text.
469                          */
470                         if (errno == EINTR) {
471                                 DEBUG2("Re-wait %d", self->thread_num);
472                                 goto re_wait;
473                         }
474                         radlog(L_ERR, "Thread %d failed waiting for semaphore: %s: Exiting\n",
475                                self->thread_num, strerror(errno));
476                         break;
477                 }
478
479                 DEBUG2("Thread %d got semaphore", self->thread_num);
480
481                 /*
482                  *      Try to grab a request from the queue.
483                  *
484                  *      It may be empty, in which case we fail
485                  *      gracefully.
486                  */
487                 if (!request_dequeue(&self->request, &fun)) continue;
488
489                 self->request->child_pid = self->pthread_id;
490                 self->request_count++;
491
492                 DEBUG2("Thread %d handling request %d, (%d handled so far)",
493                        self->thread_num, self->request->number,
494                        self->request_count);
495
496                 /*
497                  *      Respond, and reset request->child_pid
498                  */
499                 finished = rad_respond(self->request, fun);
500
501                 /*
502                  *      Update the active threads.
503                  */
504                 pthread_mutex_lock(&thread_pool.queue_mutex);
505
506                 /*
507                  *      We haven't replied to the client, but we HAVE
508                  *      sent a proxied packet, and we have NOT
509                  *      received a proxy response.  In that case, send
510                  *      the proxied packet now.  Doing this in the mutex
511                  *      avoids race conditions.
512                  *
513                  *      FIXME: this work should really depend on a
514                  *      "state", and "next handler", rather than
515                  *      horrid hacks like thise.
516                  */
517                 if (!self->request->reply->data &&
518                     self->request->proxy && self->request->proxy->data
519                     && !self->request->proxy_reply)
520                         self->request->proxy_listener->send(self->request->proxy_listener,
521                                                             (char *)self->request->proxysecret);
522
523                 self->request->child_pid = NO_SUCH_CHILD_PID;
524                 self->request->finished = finished;
525                 self->request = NULL;
526                 
527                 rad_assert(thread_pool.active_threads > 0);
528                 thread_pool.active_threads--;
529                 pthread_mutex_unlock(&thread_pool.queue_mutex);
530         } while (self->status != THREAD_CANCELLED);
531
532         DEBUG2("Thread %d exiting...", self->thread_num);
533
534 #ifdef HAVE_OPENSSL_ERR_H
535         /*
536          *      If we linked with OpenSSL, the application
537          *      must remove the thread's error queue before
538          *      exiting to prevent memory leaks.
539          */
540         ERR_remove_state(0);
541 #endif
542
543         /*
544          *  Do this as the LAST thing before exiting.
545          */
546         self->status = THREAD_EXITED;
547
548         return NULL;
549 }
550
551 /*
552  *      Take a THREAD_HANDLE, delete it from the thread pool and
553  *      free its resources.
554  *
555  *      This function is called ONLY from the main server thread,
556  *      ONLY after the thread has exited.
557  */
558 static void delete_thread(THREAD_HANDLE *handle)
559 {
560         THREAD_HANDLE *prev;
561         THREAD_HANDLE *next;
562
563         rad_assert(handle->request == NULL);
564
565         DEBUG2("Deleting thread %d", handle->thread_num);
566
567         prev = handle->prev;
568         next = handle->next;
569         rad_assert(thread_pool.total_threads > 0);
570         thread_pool.total_threads--;
571
572         /*
573          *      Remove the handle from the list.
574          */
575         if (prev == NULL) {
576                 rad_assert(thread_pool.head == handle);
577                 thread_pool.head = next;
578         } else {
579                 prev->next = next;
580         }
581
582         if (next == NULL) {
583                 rad_assert(thread_pool.tail == handle);
584                 thread_pool.tail = prev;
585         } else {
586                 next->prev = prev;
587         }
588
589         /*
590          *      Free the handle, now that it's no longer referencable.
591          */
592         free(handle);
593 }
594
595
596 /*
597  *      Spawn a new thread, and place it in the thread pool.
598  *
599  *      The thread is started initially in the blocked state, waiting
600  *      for the semaphore.
601  */
602 static THREAD_HANDLE *spawn_thread(time_t now)
603 {
604         int rcode;
605         THREAD_HANDLE *handle;
606         pthread_attr_t attr;
607
608         /*
609          *      Ensure that we don't spawn too many threads.
610          */
611         if (thread_pool.total_threads >= thread_pool.max_threads) {
612                 DEBUG2("Thread spawn failed.  Maximum number of threads (%d) already running.", thread_pool.max_threads);
613                 return NULL;
614         }
615
616         /*
617          *      Allocate a new thread handle.
618          */
619         handle = (THREAD_HANDLE *) rad_malloc(sizeof(THREAD_HANDLE));
620         memset(handle, 0, sizeof(THREAD_HANDLE));
621         handle->prev = NULL;
622         handle->next = NULL;
623         handle->pthread_id = NO_SUCH_CHILD_PID;
624         handle->thread_num = thread_pool.max_thread_num++;
625         handle->request_count = 0;
626         handle->status = THREAD_RUNNING;
627         handle->timestamp = time(NULL);
628
629         /*
630          *      Initialize the thread's attributes to detached.
631          *
632          *      We could call pthread_detach() later, but if the thread
633          *      exits between the create & detach calls, it will need to
634          *      be joined, which will never happen.
635          */
636         pthread_attr_init(&attr);
637         pthread_attr_setdetachstate(&attr, PTHREAD_CREATE_DETACHED);
638
639         /*
640          *      Create the thread detached, so that it cleans up it's
641          *      own memory when it exits.
642          *
643          *      Note that the function returns non-zero on error, NOT
644          *      -1.  The return code is the error, and errno isn't set.
645          */
646         rcode = pthread_create(&handle->pthread_id, &attr,
647                         request_handler_thread, handle);
648         if (rcode != 0) {
649                 radlog(L_ERR|L_CONS, "FATAL: Thread create failed: %s",
650                        strerror(rcode));
651                 exit(1);
652         }
653         pthread_attr_destroy(&attr);
654
655         /*
656          *      One more thread to go into the list.
657          */
658         thread_pool.total_threads++;
659         DEBUG2("Thread spawned new child %d. Total threads in pool: %d",
660                         handle->thread_num, thread_pool.total_threads);
661
662         /*
663          *      Add the thread handle to the tail of the thread pool list.
664          */
665         if (thread_pool.tail) {
666                 thread_pool.tail->next = handle;
667                 handle->prev = thread_pool.tail;
668                 thread_pool.tail = handle;
669         } else {
670                 rad_assert(thread_pool.head == NULL);
671                 thread_pool.head = thread_pool.tail = handle;
672         }
673
674         /*
675          *      Update the time we last spawned a thread.
676          */
677         thread_pool.time_last_spawned = now;
678
679         /*
680          *      And return the new handle to the caller.
681          */
682         return handle;
683 }
684
685 /*
686  *      Temporary function to prevent server from executing a SIGHUP
687  *      until all threads are finished handling requests.  This returns
688  *      the number of active threads to 'radiusd.c'.
689  */
690 int total_active_threads(void)
691 {
692         /*
693          *      We don't acquire the mutex, so this is just an estimate.
694          *      We can't return with the lock held, so there's no point
695          *      in getting the guaranteed correct value; by the time
696          *      the caller sees it, it can be wrong again.
697          */
698         return thread_pool.active_threads;
699 }
700
701
702 static uint32_t pid_hash(const void *data)
703 {
704         const thread_fork_t *tf = data;
705
706         return lrad_hash(&tf->pid, sizeof(tf->pid));
707 }
708
709 static int pid_cmp(const void *one, const void *two)
710 {
711         const thread_fork_t *a = one;
712         const thread_fork_t *b = two;
713
714         return (a->pid - b->pid);
715 }
716
717 /*
718  *      Allocate the thread pool, and seed it with an initial number
719  *      of threads.
720  *
721  *      FIXME: What to do on a SIGHUP???
722  */
723 int thread_pool_init(int spawn_flag)
724 {
725         int             i, rcode;
726         CONF_SECTION    *pool_cf;
727         time_t          now;
728
729         DEBUG("Initializing the thread pool...");
730         now = time(NULL);
731
732         /*
733          *      After a SIGHUP, we don't over-write the previous values.
734          */
735         if (!pool_initialized) {
736                 /*
737                  *      Initialize the thread pool to some reasonable values.
738                  */
739                 memset(&thread_pool, 0, sizeof(THREAD_POOL));
740                 thread_pool.head = NULL;
741                 thread_pool.tail = NULL;
742                 thread_pool.total_threads = 0;
743                 thread_pool.max_thread_num = 1;
744                 thread_pool.cleanup_delay = 5;
745                 thread_pool.spawn_flag = spawn_flag;
746
747                 if ((pthread_mutex_init(&thread_pool.wait_mutex,NULL) != 0)) {
748                         radlog(L_ERR, "FATAL: Failed to initialize wait mutex: %s",
749                                strerror(errno));
750                         exit(1);
751                 }               
752                 
753                 /*
754                  *      Create the hash table of child PID's
755                  */
756                 thread_pool.waiters = lrad_hash_table_create(pid_hash,
757                                                              pid_cmp,
758                                                              free);
759                 if (!thread_pool.waiters) {
760                         radlog(L_ERR, "FATAL: Failed to set up wait hash");
761                         exit(1);
762                 }
763         }
764
765         /*
766          *      We're not spawning new threads, don't do
767          *      anything.
768          */
769         if (!spawn_flag) return 0;
770
771         pool_cf = cf_section_find("thread");
772         if (pool_cf != NULL) {
773                 /*
774                  *      FIXME: Check for errors?
775                  */
776                 cf_section_parse(pool_cf, NULL, thread_config);
777         }
778
779         /*
780          *      The pool has already been initialized.  Don't spawn
781          *      new threads, and don't forget about forked children,
782          */
783         if (pool_initialized) {
784                 return 0;
785         }
786
787         /*
788          *      Initialize the queue of requests.
789          */
790         memset(&thread_pool.semaphore, 0, sizeof(thread_pool.semaphore));
791         rcode = sem_init(&thread_pool.semaphore, 0, SEMAPHORE_LOCKED);
792         if (rcode != 0) {
793                 radlog(L_ERR|L_CONS, "FATAL: Failed to initialize semaphore: %s",
794                        strerror(errno));
795                 exit(1);
796         }
797
798         rcode = pthread_mutex_init(&thread_pool.queue_mutex,NULL);
799         if (rcode != 0) {
800                 radlog(L_ERR, "FATAL: Failed to initialize queue mutex: %s",
801                        strerror(errno));
802                 exit(1);
803         }
804
805         /*
806          *      Allocate multiple fifos.
807          */
808         for (i = 0; i < NUM_FIFOS; i++) {
809                 thread_pool.fifo[i] = lrad_fifo_create(65536, NULL);
810                 if (!thread_pool.fifo[i]) {
811                         radlog(L_ERR, "FATAL: Failed to set up request fifo");
812                         exit(1);
813                 }
814         }
815
816 #ifdef HAVE_OPENSSL_CRYPTO_H
817         /*
818          *      If we're linking with OpenSSL too, then we need
819          *      to set up the mutexes and enable the thread callbacks.
820          */
821         if (!setup_ssl_mutexes()) {
822                 radlog(L_ERR, "FATAL: Failed to set up SSL mutexes");
823                 exit(1);
824         }
825 #endif
826
827
828         /*
829          *      Create a number of waiting threads.
830          *
831          *      If we fail while creating them, do something intelligent.
832          */
833         for (i = 0; i < thread_pool.start_threads; i++) {
834                 if (spawn_thread(now) == NULL) {
835                         return -1;
836                 }
837         }
838
839         DEBUG2("Thread pool initialized");
840         pool_initialized = TRUE;
841         return 0;
842 }
843
844
845 /*
846  *      Assign a new request to a free thread.
847  *
848  *      If there isn't a free thread, then try to create a new one,
849  *      up to the configured limits.
850  */
851 int thread_pool_addrequest(REQUEST *request, RAD_REQUEST_FUNP fun)
852 {
853         /*
854          *      We've been told not to spawn threads, so don't.
855          */
856         if (!thread_pool.spawn_flag) {
857                 request->finished = rad_respond(request, fun);
858                 return 1;
859         }
860
861         /*
862          *      Add the new request to the queue.
863          */
864         if (!request_enqueue(request, fun)) return 0;
865
866         /*
867          *      If the thread pool is busy handling requests, then
868          *      try to spawn another one.  We don't acquire the mutex
869          *      before reading active_threads, so our thread count is
870          *      just an estimate.  It's fine to go ahead and spawn an
871          *      extra thread in that case.
872          *      NOTE: the log message may be in error since active_threads
873          *      is an estimate, but it's only in error about the thread
874          *      count, not about the fact that we can't create a new one.
875          */
876         if (thread_pool.active_threads == thread_pool.total_threads) {
877                 if (spawn_thread(request->timestamp) == NULL) {
878                         radlog(L_INFO,
879                                "The maximum number of threads (%d) are active, cannot spawn new thread to handle request",
880                                thread_pool.max_threads);
881                         return 1;
882                 }
883         }
884
885         return 1;
886 }
887
888 /*
889  *      Check the min_spare_threads and max_spare_threads.
890  *
891  *      If there are too many or too few threads waiting, then we
892  *      either create some more, or delete some.
893  */
894 int thread_pool_clean(time_t now)
895 {
896         int spare;
897         int i, total;
898         THREAD_HANDLE *handle, *next;
899         int active_threads;
900         static time_t last_cleaned = 0;
901
902         /*
903          *      Loop over the thread pool deleting exited threads.
904          */
905         for (handle = thread_pool.head; handle; handle = next) {
906                 next = handle->next;
907
908                 /*
909                  *      Maybe we've asked the thread to exit, and it
910                  *      has agreed.
911                  */
912                 if (handle->status == THREAD_EXITED) {
913                         delete_thread(handle);
914                 }
915         }
916
917         /*
918          *      We don't need a mutex lock here, as we're reading
919          *      active_threads, and not modifying it.  We want a close
920          *      approximation of the number of active threads, and this
921          *      is good enough.
922          */
923         active_threads = thread_pool.active_threads;
924         spare = thread_pool.total_threads - active_threads;
925         if (debug_flag) {
926                 static int old_total = -1;
927                 static int old_active = -1;
928
929                 if ((old_total != thread_pool.total_threads) ||
930                                 (old_active != active_threads)) {
931                         DEBUG2("Threads: total/active/spare threads = %d/%d/%d",
932                                         thread_pool.total_threads, active_threads, spare);
933                         old_total = thread_pool.total_threads;
934                         old_active = active_threads;
935                 }
936         }
937
938         /*
939          *      If there are too few spare threads, create some more.
940          */
941         if (spare < thread_pool.min_spare_threads) {
942                 total = thread_pool.min_spare_threads - spare;
943
944                 DEBUG2("Threads: Spawning %d spares", total);
945                 /*
946                  *      Create a number of spare threads.
947                  */
948                 for (i = 0; i < total; i++) {
949                         handle = spawn_thread(now);
950                         if (handle == NULL) {
951                                 return -1;
952                         }
953                 }
954
955                 /*
956                  *      And exit, as there can't be too many spare threads.
957                  */
958                 return 0;
959         }
960
961         /*
962          *      Only delete spare threads if we haven't already done
963          *      so this second.
964          */
965         if (now == last_cleaned) {
966                 return 0;
967         }
968         last_cleaned = now;
969
970         /*
971          *      Only delete the spare threads if sufficient time has
972          *      passed since we last created one.  This helps to minimize
973          *      the amount of create/delete cycles.
974          */
975         if ((now - thread_pool.time_last_spawned) < thread_pool.cleanup_delay) {
976                 return 0;
977         }
978
979         /*
980          *      If there are too many spare threads, delete one.
981          *
982          *      Note that we only delete ONE at a time, instead of
983          *      wiping out many.  This allows the excess servers to
984          *      be slowly reaped, just in case the load spike comes again.
985          */
986         if (spare > thread_pool.max_spare_threads) {
987
988                 spare -= thread_pool.max_spare_threads;
989
990                 DEBUG2("Threads: deleting 1 spare out of %d spares", spare);
991
992                 /*
993                  *      Walk through the thread pool, deleting the
994                  *      first idle thread we come across.
995                  */
996                 for (handle = thread_pool.head; (handle != NULL) && (spare > 0) ; handle = next) {
997                         next = handle->next;
998
999                         /*
1000                          *      If the thread is not handling a
1001                          *      request, but still live, then tell it
1002                          *      to exit.
1003                          *
1004                          *      It will eventually wake up, and realize
1005                          *      it's been told to commit suicide.
1006                          */
1007                         if ((handle->request == NULL) &&
1008                             (handle->status == THREAD_RUNNING)) {
1009                                 handle->status = THREAD_CANCELLED;
1010                                 /*
1011                                  *      Post an extra semaphore, as a
1012                                  *      signal to wake up, and exit.
1013                                  */
1014                                 sem_post(&thread_pool.semaphore);
1015                                 spare--;
1016                                 break;
1017                         }
1018                 }
1019         }
1020
1021         /*
1022          *      If the thread has handled too many requests, then make it
1023          *      exit.
1024          */
1025         if (thread_pool.max_requests_per_thread > 0) {
1026                 for (handle = thread_pool.head; handle; handle = next) {
1027                         next = handle->next;
1028
1029                         /*
1030                          *      Not handling a request, but otherwise
1031                          *      live, we can kill it.
1032                          */
1033                         if ((handle->request == NULL) &&
1034                             (handle->status == THREAD_RUNNING) &&
1035                             (handle->request_count > thread_pool.max_requests_per_thread)) {
1036                                 handle->status = THREAD_CANCELLED;
1037                                 sem_post(&thread_pool.semaphore);
1038                         }
1039                 }
1040         }
1041
1042         /*
1043          *      Otherwise everything's kosher.  There are not too few,
1044          *      or too many spare threads.  Exit happily.
1045          */
1046         return 0;
1047 }
1048
1049
1050 /*
1051  *      Thread wrapper for fork().
1052  */
1053 pid_t rad_fork(int exec_wait)
1054 {
1055         pid_t child_pid;
1056
1057         if (exec_wait) return fork();
1058
1059         reap_children();        /* be nice to non-wait thingies */
1060
1061         if (lrad_hash_table_num_elements(thread_pool.waiters) >= 1024) {
1062                 return -1;
1063         }
1064
1065         /*
1066          *      Fork & save the PID for later reaping.
1067          */
1068         child_pid = fork();
1069         if (child_pid > 0) {
1070                 int rcode;
1071                 thread_fork_t *tf;
1072
1073                 tf = rad_malloc(sizeof(*tf));
1074                 memset(tf, 0, sizeof(*tf));
1075                 
1076                 tf->pid = child_pid;
1077
1078                 /*
1079                  *      Lock the mutex.
1080                  */
1081                 pthread_mutex_lock(&thread_pool.wait_mutex);
1082
1083                 rcode = lrad_hash_table_insert(thread_pool.waiters, tf);
1084
1085                 /*
1086                  *      Unlock the mutex.
1087                  */
1088                 pthread_mutex_unlock(&thread_pool.wait_mutex);
1089
1090                 if (!rcode) {
1091                         radlog(L_ERR, "Failed to store PID, creating what will be a zombie process %d",
1092                                (int) child_pid);
1093                 }
1094         }
1095
1096         /*
1097          *      Return whatever we were told.
1098          */
1099         return child_pid;
1100 }
1101
1102 /*
1103  *      We may not need this any more...
1104  */
1105 pid_t rad_waitpid(pid_t pid, int *status, int options)
1106 {
1107         thread_fork_t mytf, *tf;
1108
1109         reap_children();        /* be nice to non-wait thingies */
1110
1111         if (pid <= 0) return -1;
1112
1113         if ((options & WNOHANG) == 0) return -1;
1114
1115         mytf.pid = pid;
1116
1117         pthread_mutex_lock(&thread_pool.wait_mutex);
1118         tf = lrad_hash_table_finddata(thread_pool.waiters, &mytf);
1119
1120         if (!tf) {              /* not found.  It's a problem... */
1121                 pthread_mutex_unlock(&thread_pool.wait_mutex);
1122                 return waitpid(pid, status, options);
1123         }
1124
1125         if (tf->exited) {
1126                 *status = tf->status;
1127                 lrad_hash_table_delete(thread_pool.waiters, &mytf);
1128                 pthread_mutex_unlock(&thread_pool.wait_mutex);
1129                 return pid;
1130         }
1131         
1132         /*
1133          *      Don't wait, and it hasn't exited.  Return.
1134          */
1135         pthread_mutex_unlock(&thread_pool.wait_mutex);
1136         return 0;
1137 }
1138
1139 #else /* HAVE_PTHREAD_H */
1140 /*
1141  *      "thread" code when we don't have threads.
1142  */
1143 int thread_pool_init(int spawn_flag)
1144 {
1145         return 0;
1146 }
1147
1148 /*
1149  *      call "radrespond".
1150  */
1151 int thread_pool_addrequest(REQUEST *request, RAD_REQUEST_FUNP fun)
1152 {
1153         rad_respond(request, fun);
1154         return 1;
1155 }
1156
1157 #endif /* HAVE_PTHREAD_H */