2 * Copyright (C) 2015-2020 "IoT.bzh"
3 * Author José Bollo <jose.bollo@iot.bzh>
5 * Licensed under the Apache License, Version 2.0 (the "License");
6 * you may not use this file except in compliance with the License.
7 * You may obtain a copy of the License at
9 * http://www.apache.org/licenses/LICENSE-2.0
11 * Unless required by applicable law or agreed to in writing, software
12 * distributed under the License is distributed on an "AS IS" BASIS,
13 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
14 * See the License for the specific language governing permissions and
15 * limitations under the License.
26 #include <sys/syscall.h>
30 #include <sys/eventfd.h>
32 #include <systemd/sd-event.h>
36 #include "sig-monitor.h"
40 #define EVENT_TIMEOUT_TOP ((uint64_t)-1)
41 #define EVENT_TIMEOUT_CHILD ((uint64_t)10000)
43 /** Internal shortcut for callback */
44 typedef void (*job_cb_t)(int, void*);
46 /** starting mode for jobs */
49 Start_Default, /**< Start a thread if more than one jobs is pending */
50 Start_Urgent, /**< Always start a thread */
51 Start_Lazy /**< Never start a thread */
54 /** Description of a pending job */
57 struct job *next; /**< link to the next job enqueued */
58 const void *group; /**< group of the request */
59 job_cb_t callback; /**< processing callback */
60 void *arg; /**< argument */
61 int timeout; /**< timeout in second for processing the request */
62 unsigned blocked: 1; /**< is an other request blocking this one ? */
63 unsigned dropped: 1; /**< is removed ? */
66 /** Description of threads */
69 struct thread *next; /**< next thread of the list */
70 struct thread *upper; /**< upper same thread */
71 struct thread *nholder;/**< next holder for evloop */
72 pthread_cond_t *cwhold;/**< condition wait for holding */
73 struct job *job; /**< currently processed job */
74 pthread_t tid; /**< the thread id */
75 volatile unsigned stop: 1; /**< stop requested */
76 volatile unsigned waits: 1; /**< is waiting? */
77 volatile unsigned leaved: 1; /**< was leaved? */
81 * Description of synchronous callback
85 struct thread thread; /**< thread loop data */
87 void (*callback)(int, void*); /**< the synchronous callback */
88 void (*enter)(int signum, void *closure, struct jobloop *jobloop);
89 /**< the entering synchronous routine */
91 void *arg; /**< the argument of the callback */
94 /* synchronisation of threads */
95 static pthread_mutex_t mutex = PTHREAD_MUTEX_INITIALIZER;
96 static pthread_cond_t cond = PTHREAD_COND_INITIALIZER;
98 /* counts for threads */
99 static int allowed_thread_count = 0; /** allowed count of threads */
100 static int started_thread_count = 0; /** started count of threads */
101 static int busy_thread_count = 0; /** count of busy threads */
103 /* list of threads */
104 static struct thread *threads;
105 static _Thread_local struct thread *current_thread;
107 /* counts for jobs */
108 static int remaining_job_count = 0; /** count of job that can be created */
109 static int allowed_job_count = 0; /** allowed count of pending jobs */
111 /* queue of pending jobs */
112 static struct job *first_pending_job;
113 static struct job *first_free_job;
116 static struct evmgr *evmgr;
118 static void (*exit_handler)();
121 * Create a new job with the given parameters
122 * @param group the group of the job
123 * @param timeout the timeout of the job (0 if none)
124 * @param callback the function that achieves the job
125 * @param arg the argument of the callback
126 * @return the created job unblock or NULL when no more memory
128 static struct job *job_create(
136 /* try recyle existing job */
137 job = first_free_job;
139 first_free_job = job->next;
141 /* allocation without blocking */
142 pthread_mutex_unlock(&mutex);
143 job = malloc(sizeof *job);
144 pthread_mutex_lock(&mutex);
146 ERROR("out of memory");
151 /* initialises the job */
153 job->timeout = timeout;
154 job->callback = callback;
163 * Adds 'job' at the end of the list of jobs, marking it
164 * as blocked if an other job with the same group is pending.
165 * @param job the job to add
167 static void job_add(struct job *job)
170 struct job *ijob, **pjob;
176 /* search end and blockers */
177 pjob = &first_pending_job;
178 ijob = first_pending_job;
180 if (group && ijob->group == group)
188 remaining_job_count--;
192 * Get the next job to process or NULL if none.
193 * @return the first job that isn't blocked or NULL
195 static inline struct job *job_get()
197 struct job *job = first_pending_job;
198 while (job && job->blocked)
201 remaining_job_count++;
206 * Releases the processed 'job': removes it
207 * from the list of jobs and unblock the first
208 * pending job of the same group if any.
209 * @param job the job to release
211 static inline void job_release(struct job *job)
213 struct job *ijob, **pjob;
216 /* first unqueue the job */
217 pjob = &first_pending_job;
218 ijob = first_pending_job;
219 while (ijob != job) {
225 /* then unblock jobs of the same group */
229 while (ijob && ijob->group != group)
235 /* recycle the job */
236 job->next = first_free_job;
237 first_free_job = job;
241 * Monitored cancel callback for a job.
242 * This function is called by the monitor
243 * to cancel the job when the safe environment
245 * @param signum 0 on normal flow or the number
246 * of the signal that interrupted the normal
248 * @param arg the job to run
250 __attribute__((unused))
251 static void job_cancel(int signum, void *arg)
253 struct job *job = arg;
254 job->callback(SIGABRT, job->arg);
258 * wakeup the event loop if needed by sending
261 static void evloop_wakeup()
268 * Release the currently held event loop
270 static void evloop_release()
272 struct thread *nh, *ct = current_thread;
274 if (ct && evmgr && evmgr_release_if(evmgr, ct)) {
278 evmgr_try_hold(evmgr, nh);
279 pthread_cond_signal(nh->cwhold);
285 * get the eventloop for the current thread
287 static int evloop_get()
289 return evmgr && evmgr_try_hold(evmgr, current_thread);
293 * acquire the eventloop for the current thread
295 static void evloop_acquire()
297 struct thread *pwait, *ct;
300 /* try to get the evloop */
302 /* failed, init waiting state */
306 pthread_cond_init(&cond, NULL);
308 /* queue current thread in holder list */
309 pwait = evmgr_holder(evmgr);
310 while (pwait->nholder)
311 pwait = pwait->nholder;
314 /* wake up the evloop */
317 /* wait to acquire the evloop */
318 pthread_cond_wait(&cond, &mutex);
319 pthread_cond_destroy(&cond);
325 * @param me the description of the thread to enter
327 static void thread_enter(volatile struct thread *me)
330 /* initialize description of itself and link it in the list */
331 me->tid = pthread_self();
336 me->upper = current_thread;
338 threads = (struct thread*)me;
339 current_thread = (struct thread*)me;
344 * @param me the description of the thread to leave
346 static void thread_leave()
348 struct thread **prv, *me;
350 /* unlink the current thread and cleanup */
357 current_thread = me->upper;
361 * Main processing loop of internal threads with processing jobs.
362 * The loop must be called with the mutex locked
363 * and it returns with the mutex locked.
364 * @param me the description of the thread to use
365 * TODO: how are timeout handled when reentering?
367 static void thread_run_internal(volatile struct thread *me)
374 /* loop until stopped */
376 /* release the current event loop */
382 /* prepare running the job */
383 job->blocked = 1; /* mark job as blocked */
384 me->job = job; /* record the job (only for terminate) */
387 pthread_mutex_unlock(&mutex);
388 sig_monitor(job->timeout, job->callback, job->arg);
389 pthread_mutex_lock(&mutex);
391 /* release the run job */
393 /* no job, check event loop wait */
394 } else if (evloop_get()) {
395 if (!evmgr_can_run(evmgr)) {
397 CRITICAL("Can't enter dispatch while in dispatch!");
401 evmgr_prepare_run(evmgr);
402 pthread_mutex_unlock(&mutex);
403 sig_monitor(0, (void(*)(int,void*))evmgr_job_run, evmgr);
404 pthread_mutex_lock(&mutex);
406 /* no job and no event loop */
408 if (!busy_thread_count)
409 ERROR("Entering job deep sleep! Check your bindings.");
411 pthread_cond_wait(&cond, &mutex);
422 * Main processing loop of external threads.
423 * The loop must be called with the mutex locked
424 * and it returns with the mutex locked.
425 * @param me the description of the thread to use
427 static void thread_run_external(volatile struct thread *me)
432 /* loop until stopped */
435 pthread_cond_wait(&cond, &mutex);
441 * Root for created threads.
443 static void thread_main()
448 started_thread_count++;
449 sig_monitor_init_timeouts();
450 thread_run_internal(&me);
451 sig_monitor_clean_timeouts();
452 started_thread_count--;
457 * Entry point for created threads.
458 * @param data not used
461 static void *thread_starter(void *data)
463 pthread_mutex_lock(&mutex);
465 pthread_mutex_unlock(&mutex);
470 * Starts a new thread
471 * @return 0 in case of success or -1 in case of error
473 static int start_one_thread()
478 rc = pthread_create(&tid, NULL, thread_starter, NULL);
481 WARNING("not able to start thread: %m");
488 * Queues a new asynchronous job represented by 'callback' and 'arg'
489 * for the 'group' and the 'timeout'.
490 * Jobs are queued FIFO and are possibly executed in parallel
491 * concurrently except for job of the same group that are
492 * executed sequentially in FIFO order.
493 * @param group The group of the job or NULL when no group.
494 * @param timeout The maximum execution time in seconds of the job
495 * or 0 for unlimited time.
496 * @param callback The function to execute for achieving the job.
497 * Its first parameter is either 0 on normal flow
498 * or the signal number that broke the normal flow.
499 * The remaining parameter is the parameter 'arg1'
501 * @param arg The second argument for 'callback'
502 * @param start The start mode for threads
503 * @return 0 in case of success or -1 in case of error
505 static int queue_job_internal(
508 void (*callback)(int, void*),
510 enum start_mode start_mode)
515 /* check availability */
516 if (remaining_job_count <= 0) {
517 ERROR("can't process job with threads: too many jobs");
522 /* allocates the job */
523 job = job_create(group, timeout, callback, arg);
527 /* start a thread if needed */
528 busy = busy_thread_count == started_thread_count;
529 if (start_mode != Start_Lazy
531 && (start_mode == Start_Urgent || remaining_job_count + started_thread_count < allowed_job_count)
532 && started_thread_count < allowed_thread_count) {
533 /* all threads are busy and a new can be started */
534 rc = start_one_thread();
535 if (rc < 0 && started_thread_count == 0) {
536 ERROR("can't start initial thread: %m");
545 /* wakeup an evloop if needed */
549 pthread_cond_signal(&cond);
553 job->next = first_free_job;
554 first_free_job = job;
560 * Queues a new asynchronous job represented by 'callback' and 'arg'
561 * for the 'group' and the 'timeout'.
562 * Jobs are queued FIFO and are possibly executed in parallel
563 * concurrently except for job of the same group that are
564 * executed sequentially in FIFO order.
565 * @param group The group of the job or NULL when no group.
566 * @param timeout The maximum execution time in seconds of the job
567 * or 0 for unlimited time.
568 * @param callback The function to execute for achieving the job.
569 * Its first parameter is either 0 on normal flow
570 * or the signal number that broke the normal flow.
571 * The remaining parameter is the parameter 'arg1'
573 * @param arg The second argument for 'callback'
574 * @param start The start mode for threads
575 * @return 0 in case of success or -1 in case of error
577 static int queue_job(
580 void (*callback)(int, void*),
582 enum start_mode start_mode)
586 pthread_mutex_lock(&mutex);
587 rc = queue_job_internal(group, timeout, callback, arg, start_mode);
588 pthread_mutex_unlock(&mutex);
594 * Queues a new asynchronous job represented by 'callback' and 'arg'
595 * for the 'group' and the 'timeout'.
596 * Jobs are queued FIFO and are possibly executed in parallel
597 * concurrently except for job of the same group that are
598 * executed sequentially in FIFO order.
599 * @param group The group of the job or NULL when no group.
600 * @param timeout The maximum execution time in seconds of the job
601 * or 0 for unlimited time.
602 * @param callback The function to execute for achieving the job.
603 * Its first parameter is either 0 on normal flow
604 * or the signal number that broke the normal flow.
605 * The remaining parameter is the parameter 'arg1'
607 * @param arg The second argument for 'callback'
608 * @return 0 in case of success or -1 in case of error
613 void (*callback)(int, void*),
616 return queue_job(group, timeout, callback, arg, Start_Default);
620 * Queues lazyly a new asynchronous job represented by 'callback' and 'arg'
621 * for the 'group' and the 'timeout'.
622 * Jobs are queued FIFO and are possibly executed in parallel
623 * concurrently except for job of the same group that are
624 * executed sequentially in FIFO order.
625 * @param group The group of the job or NULL when no group.
626 * @param timeout The maximum execution time in seconds of the job
627 * or 0 for unlimited time.
628 * @param callback The function to execute for achieving the job.
629 * Its first parameter is either 0 on normal flow
630 * or the signal number that broke the normal flow.
631 * The remaining parameter is the parameter 'arg1'
633 * @param arg The second argument for 'callback'
634 * @return 0 in case of success or -1 in case of error
639 void (*callback)(int, void*),
642 return queue_job(group, timeout, callback, arg, Start_Lazy);
646 * Queues urgently a new asynchronous job represented by 'callback' and 'arg'
647 * for the 'group' and the 'timeout'.
648 * Jobs are queued FIFO and are possibly executed in parallel
649 * concurrently except for job of the same group that are
650 * executed sequentially in FIFO order.
651 * @param group The group of the job or NULL when no group.
652 * @param timeout The maximum execution time in seconds of the job
653 * or 0 for unlimited time.
654 * @param callback The function to execute for achieving the job.
655 * Its first parameter is either 0 on normal flow
656 * or the signal number that broke the normal flow.
657 * The remaining parameter is the parameter 'arg1'
659 * @param arg The second argument for 'callback'
660 * @return 0 in case of success or -1 in case of error
662 int jobs_queue_urgent(
665 void (*callback)(int, void*),
668 return queue_job(group, timeout, callback, arg, Start_Urgent);
672 * Internal helper function for 'jobs_enter'.
673 * @see jobs_enter, jobs_leave
675 static void enter_cb(int signum, void *closure)
677 struct sync *sync = closure;
678 sync->enter(signum, sync->arg, (void*)&sync->thread);
682 * Internal helper function for 'jobs_call'.
685 static void call_cb(int signum, void *closure)
687 struct sync *sync = closure;
688 sync->callback(signum, sync->arg);
689 jobs_leave((void*)&sync->thread);
693 * Internal helper for synchronous jobs. It enters
694 * a new thread loop for evaluating the given job
695 * as recorded by the couple 'sync_cb' and 'sync'.
696 * @see jobs_call, jobs_enter, jobs_leave
701 void (*sync_cb)(int signum, void *closure),
707 pthread_mutex_lock(&mutex);
709 rc = queue_job_internal(group, timeout, sync_cb, sync, Start_Default);
711 /* run until stopped */
713 thread_run_internal(&sync->thread);
715 thread_run_external(&sync->thread);
716 if (!sync->thread.leaved) {
721 pthread_mutex_unlock(&mutex);
726 * Enter a synchronisation point: activates the job given by 'callback'
727 * and 'closure' using 'group' and 'timeout' to control sequencing and
729 * @param group the group for sequencing jobs
730 * @param timeout the time in seconds allocated to the job
731 * @param callback the callback that will handle the job.
732 * it receives 3 parameters: 'signum' that will be 0
733 * on normal flow or the catched signal number in case
734 * of interrupted flow, the context 'closure' as given and
735 * a 'jobloop' reference that must be used when the job is
736 * terminated to unlock the current execution flow.
737 * @param closure the argument to the callback
738 * @return 0 on success or -1 in case of error
743 void (*callback)(int signum, void *closure, struct jobloop *jobloop),
749 sync.enter = callback;
751 return do_sync(group, timeout, enter_cb, &sync);
755 * Unlocks the execution flow designed by 'jobloop'.
756 * @param jobloop indication of the flow to unlock
757 * @return 0 in case of success of -1 on error
759 int jobs_leave(struct jobloop *jobloop)
763 pthread_mutex_lock(&mutex);
765 while (t && t != (struct thread*)jobloop)
773 pthread_cond_broadcast(&cond);
777 pthread_mutex_unlock(&mutex);
782 * Calls synchronously the job represented by 'callback' and 'arg1'
783 * for the 'group' and the 'timeout' and waits for its completion.
784 * @param group The group of the job or NULL when no group.
785 * @param timeout The maximum execution time in seconds of the job
786 * or 0 for unlimited time.
787 * @param callback The function to execute for achieving the job.
788 * Its first parameter is either 0 on normal flow
789 * or the signal number that broke the normal flow.
790 * The remaining parameter is the parameter 'arg1'
792 * @param arg The second argument for 'callback'
793 * @return 0 in case of success or -1 in case of error
798 void (*callback)(int, void*),
803 sync.callback = callback;
806 return do_sync(group, timeout, call_cb, &sync);
810 * Ensure that the current running thread can control the event loop.
812 void jobs_acquire_event_manager()
816 /* ensure an existing thread environment */
817 if (!current_thread) {
818 memset(<, 0, sizeof lt);
819 current_thread = <
823 pthread_mutex_lock(&mutex);
825 /* creates the evloop on need */
827 evmgr_create(&evmgr);
829 /* acquire the event loop under lock */
834 pthread_mutex_unlock(&mutex);
836 /* release the faked thread environment if needed */
837 if (current_thread == <) {
839 * Releasing it is needed because there is no way to guess
840 * when it has to be released really. But here is where it is
841 * hazardous: if the caller modifies the eventloop when it
842 * is waiting, there is no way to make the change effective.
843 * A workaround to achieve that goal is for the caller to
844 * require the event loop a second time after having modified it.
846 NOTICE("Requiring event manager/loop from outside of binder's callback is hazardous!");
847 if (verbose_wants(Log_Level_Info))
848 sig_monitor_dumpstack();
850 current_thread = NULL;
855 * Enter the jobs processing loop.
856 * @param allowed_count Maximum count of thread for jobs including this one
857 * @param start_count Count of thread to start now, must be lower.
858 * @param waiter_count Maximum count of jobs that can be waiting.
859 * @param start The start routine to activate (can't be NULL)
860 * @return 0 in case of success or -1 in case of error.
866 void (*start)(int signum, void* arg),
872 assert(allowed_count >= 1);
873 assert(start_count >= 0);
874 assert(waiter_count > 0);
875 assert(start_count <= allowed_count);
878 pthread_mutex_lock(&mutex);
880 /* check whether already running */
881 if (current_thread || allowed_thread_count) {
882 ERROR("thread already started");
887 /* records the allowed count */
888 allowed_thread_count = allowed_count;
889 started_thread_count = 0;
890 busy_thread_count = 0;
891 remaining_job_count = waiter_count;
892 allowed_job_count = waiter_count;
894 /* start at least one thread: the current one */
896 while (launched < start_count) {
897 if (start_one_thread() != 0) {
898 ERROR("Not all threads can be started");
904 /* queue the start job */
905 job = job_create(NULL, 0, start, arg);
914 pthread_mutex_unlock(&mutex);
921 * Exit jobs threads and call handler if not NULL.
923 void jobs_exit(void (*handler)())
927 /* request all threads to stop */
928 pthread_mutex_lock(&mutex);
930 /* set the handler */
931 exit_handler = handler;
933 /* stops the threads */
940 /* wake up the threads */
942 pthread_cond_broadcast(&cond);
945 pthread_mutex_unlock(&mutex);