2 * linux/kernel/signal.c
4 * Copyright (C) 1991, 1992 Linus Torvalds
6 * 1997-11-02 Modified for POSIX.1b signals by Richard Henderson
8 * 2003-06-02 Jim Houston - Concurrent Computer Corp.
9 * Changes to use preallocated sigqueue structures
10 * to allow signals to be sent reliably.
13 #include <linux/slab.h>
14 #include <linux/module.h>
15 #include <linux/init.h>
16 #include <linux/sched.h>
18 #include <linux/tty.h>
19 #include <linux/binfmts.h>
20 #include <linux/security.h>
21 #include <linux/syscalls.h>
22 #include <linux/ptrace.h>
23 #include <linux/signal.h>
24 #include <linux/capability.h>
25 #include <linux/freezer.h>
26 #include <linux/pid_namespace.h>
27 #include <linux/nsproxy.h>
29 #include <asm/param.h>
30 #include <asm/uaccess.h>
31 #include <asm/unistd.h>
32 #include <asm/siginfo.h>
33 #include "audit.h" /* audit_signal_info() */
36 * SLAB caches for signal bits.
39 static struct kmem_cache *sigqueue_cachep;
42 static int sig_ignored(struct task_struct *t, int sig)
44 void __user * handler;
47 * Tracers always want to know about signals..
49 if (t->ptrace & PT_PTRACED)
53 * Blocked signals are never ignored, since the
54 * signal handler may change by the time it is
57 if (sigismember(&t->blocked, sig))
60 /* Is it explicitly or implicitly ignored? */
61 handler = t->sighand->action[sig-1].sa.sa_handler;
62 return handler == SIG_IGN ||
63 (handler == SIG_DFL && sig_kernel_ignore(sig));
67 * Re-calculate pending state from the set of locally pending
68 * signals, globally pending signals, and blocked signals.
70 static inline int has_pending_signals(sigset_t *signal, sigset_t *blocked)
75 switch (_NSIG_WORDS) {
77 for (i = _NSIG_WORDS, ready = 0; --i >= 0 ;)
78 ready |= signal->sig[i] &~ blocked->sig[i];
81 case 4: ready = signal->sig[3] &~ blocked->sig[3];
82 ready |= signal->sig[2] &~ blocked->sig[2];
83 ready |= signal->sig[1] &~ blocked->sig[1];
84 ready |= signal->sig[0] &~ blocked->sig[0];
87 case 2: ready = signal->sig[1] &~ blocked->sig[1];
88 ready |= signal->sig[0] &~ blocked->sig[0];
91 case 1: ready = signal->sig[0] &~ blocked->sig[0];
96 #define PENDING(p,b) has_pending_signals(&(p)->signal, (b))
98 fastcall void recalc_sigpending_tsk(struct task_struct *t)
100 if (t->signal->group_stop_count > 0 ||
102 PENDING(&t->pending, &t->blocked) ||
103 PENDING(&t->signal->shared_pending, &t->blocked))
104 set_tsk_thread_flag(t, TIF_SIGPENDING);
106 clear_tsk_thread_flag(t, TIF_SIGPENDING);
109 void recalc_sigpending(void)
111 recalc_sigpending_tsk(current);
114 /* Given the mask, find the first available signal that should be serviced. */
117 next_signal(struct sigpending *pending, sigset_t *mask)
119 unsigned long i, *s, *m, x;
122 s = pending->signal.sig;
124 switch (_NSIG_WORDS) {
126 for (i = 0; i < _NSIG_WORDS; ++i, ++s, ++m)
127 if ((x = *s &~ *m) != 0) {
128 sig = ffz(~x) + i*_NSIG_BPW + 1;
133 case 2: if ((x = s[0] &~ m[0]) != 0)
135 else if ((x = s[1] &~ m[1]) != 0)
142 case 1: if ((x = *s &~ *m) != 0)
150 static struct sigqueue *__sigqueue_alloc(struct task_struct *t, gfp_t flags,
153 struct sigqueue *q = NULL;
154 struct user_struct *user;
157 * In order to avoid problems with "switch_user()", we want to make
158 * sure that the compiler doesn't re-load "t->user"
162 atomic_inc(&user->sigpending);
163 if (override_rlimit ||
164 atomic_read(&user->sigpending) <=
165 t->signal->rlim[RLIMIT_SIGPENDING].rlim_cur)
166 q = kmem_cache_alloc(sigqueue_cachep, flags);
167 if (unlikely(q == NULL)) {
168 atomic_dec(&user->sigpending);
170 INIT_LIST_HEAD(&q->list);
172 q->user = get_uid(user);
177 static void __sigqueue_free(struct sigqueue *q)
179 if (q->flags & SIGQUEUE_PREALLOC)
181 atomic_dec(&q->user->sigpending);
183 kmem_cache_free(sigqueue_cachep, q);
186 void flush_sigqueue(struct sigpending *queue)
190 sigemptyset(&queue->signal);
191 while (!list_empty(&queue->list)) {
192 q = list_entry(queue->list.next, struct sigqueue , list);
193 list_del_init(&q->list);
199 * Flush all pending signals for a task.
201 void flush_signals(struct task_struct *t)
205 spin_lock_irqsave(&t->sighand->siglock, flags);
206 clear_tsk_thread_flag(t,TIF_SIGPENDING);
207 flush_sigqueue(&t->pending);
208 flush_sigqueue(&t->signal->shared_pending);
209 spin_unlock_irqrestore(&t->sighand->siglock, flags);
213 * Flush all handlers for a task.
217 flush_signal_handlers(struct task_struct *t, int force_default)
220 struct k_sigaction *ka = &t->sighand->action[0];
221 for (i = _NSIG ; i != 0 ; i--) {
222 if (force_default || ka->sa.sa_handler != SIG_IGN)
223 ka->sa.sa_handler = SIG_DFL;
225 sigemptyset(&ka->sa.sa_mask);
231 /* Notify the system that a driver wants to block all signals for this
232 * process, and wants to be notified if any signals at all were to be
233 * sent/acted upon. If the notifier routine returns non-zero, then the
234 * signal will be acted upon after all. If the notifier routine returns 0,
235 * then then signal will be blocked. Only one block per process is
236 * allowed. priv is a pointer to private data that the notifier routine
237 * can use to determine if the signal should be blocked or not. */
240 block_all_signals(int (*notifier)(void *priv), void *priv, sigset_t *mask)
244 spin_lock_irqsave(¤t->sighand->siglock, flags);
245 current->notifier_mask = mask;
246 current->notifier_data = priv;
247 current->notifier = notifier;
248 spin_unlock_irqrestore(¤t->sighand->siglock, flags);
251 /* Notify the system that blocking has ended. */
254 unblock_all_signals(void)
258 spin_lock_irqsave(¤t->sighand->siglock, flags);
259 current->notifier = NULL;
260 current->notifier_data = NULL;
262 spin_unlock_irqrestore(¤t->sighand->siglock, flags);
265 static int collect_signal(int sig, struct sigpending *list, siginfo_t *info)
267 struct sigqueue *q, *first = NULL;
268 int still_pending = 0;
270 if (unlikely(!sigismember(&list->signal, sig)))
274 * Collect the siginfo appropriate to this signal. Check if
275 * there is another siginfo for the same signal.
277 list_for_each_entry(q, &list->list, list) {
278 if (q->info.si_signo == sig) {
287 list_del_init(&first->list);
288 copy_siginfo(info, &first->info);
289 __sigqueue_free(first);
291 sigdelset(&list->signal, sig);
294 /* Ok, it wasn't in the queue. This must be
295 a fast-pathed signal or we must have been
296 out of queue space. So zero out the info.
298 sigdelset(&list->signal, sig);
299 info->si_signo = sig;
308 static int __dequeue_signal(struct sigpending *pending, sigset_t *mask,
311 int sig = next_signal(pending, mask);
314 if (current->notifier) {
315 if (sigismember(current->notifier_mask, sig)) {
316 if (!(current->notifier)(current->notifier_data)) {
317 clear_thread_flag(TIF_SIGPENDING);
323 if (!collect_signal(sig, pending, info))
331 * Dequeue a signal and return the element to the caller, which is
332 * expected to free it.
334 * All callers have to hold the siglock.
336 int dequeue_signal(struct task_struct *tsk, sigset_t *mask, siginfo_t *info)
338 int signr = __dequeue_signal(&tsk->pending, mask, info);
340 signr = __dequeue_signal(&tsk->signal->shared_pending,
345 * itimers are process shared and we restart periodic
346 * itimers in the signal delivery path to prevent DoS
347 * attacks in the high resolution timer case. This is
348 * compliant with the old way of self restarting
349 * itimers, as the SIGALRM is a legacy signal and only
350 * queued once. Changing the restart behaviour to
351 * restart the timer in the signal dequeue path is
352 * reducing the timer noise on heavy loaded !highres
355 if (unlikely(signr == SIGALRM)) {
356 struct hrtimer *tmr = &tsk->signal->real_timer;
358 if (!hrtimer_is_queued(tmr) &&
359 tsk->signal->it_real_incr.tv64 != 0) {
360 hrtimer_forward(tmr, tmr->base->get_time(),
361 tsk->signal->it_real_incr);
362 hrtimer_restart(tmr);
366 recalc_sigpending_tsk(tsk);
367 if (signr && unlikely(sig_kernel_stop(signr))) {
369 * Set a marker that we have dequeued a stop signal. Our
370 * caller might release the siglock and then the pending
371 * stop signal it is about to process is no longer in the
372 * pending bitmasks, but must still be cleared by a SIGCONT
373 * (and overruled by a SIGKILL). So those cases clear this
374 * shared flag after we've set it. Note that this flag may
375 * remain set after the signal we return is ignored or
376 * handled. That doesn't matter because its only purpose
377 * is to alert stop-signal processing code when another
378 * processor has come along and cleared the flag.
380 if (!(tsk->signal->flags & SIGNAL_GROUP_EXIT))
381 tsk->signal->flags |= SIGNAL_STOP_DEQUEUED;
384 ((info->si_code & __SI_MASK) == __SI_TIMER) &&
385 info->si_sys_private){
387 * Release the siglock to ensure proper locking order
388 * of timer locks outside of siglocks. Note, we leave
389 * irqs disabled here, since the posix-timers code is
390 * about to disable them again anyway.
392 spin_unlock(&tsk->sighand->siglock);
393 do_schedule_next_timer(info);
394 spin_lock(&tsk->sighand->siglock);
400 * Tell a process that it has a new active signal..
402 * NOTE! we rely on the previous spin_lock to
403 * lock interrupts for us! We can only be called with
404 * "siglock" held, and the local interrupt must
405 * have been disabled when that got acquired!
407 * No need to set need_resched since signal event passing
408 * goes through ->blocked
410 void signal_wake_up(struct task_struct *t, int resume)
414 set_tsk_thread_flag(t, TIF_SIGPENDING);
417 * For SIGKILL, we want to wake it up in the stopped/traced case.
418 * We don't check t->state here because there is a race with it
419 * executing another processor and just now entering stopped state.
420 * By using wake_up_state, we ensure the process will wake up and
421 * handle its death signal.
423 mask = TASK_INTERRUPTIBLE;
425 mask |= TASK_STOPPED | TASK_TRACED;
426 if (!wake_up_state(t, mask))
431 * Remove signals in mask from the pending set and queue.
432 * Returns 1 if any signals were found.
434 * All callers must be holding the siglock.
436 * This version takes a sigset mask and looks at all signals,
437 * not just those in the first mask word.
439 static int rm_from_queue_full(sigset_t *mask, struct sigpending *s)
441 struct sigqueue *q, *n;
444 sigandsets(&m, mask, &s->signal);
445 if (sigisemptyset(&m))
448 signandsets(&s->signal, &s->signal, mask);
449 list_for_each_entry_safe(q, n, &s->list, list) {
450 if (sigismember(mask, q->info.si_signo)) {
451 list_del_init(&q->list);
458 * Remove signals in mask from the pending set and queue.
459 * Returns 1 if any signals were found.
461 * All callers must be holding the siglock.
463 static int rm_from_queue(unsigned long mask, struct sigpending *s)
465 struct sigqueue *q, *n;
467 if (!sigtestsetmask(&s->signal, mask))
470 sigdelsetmask(&s->signal, mask);
471 list_for_each_entry_safe(q, n, &s->list, list) {
472 if (q->info.si_signo < SIGRTMIN &&
473 (mask & sigmask(q->info.si_signo))) {
474 list_del_init(&q->list);
482 * Bad permissions for sending the signal
484 static int check_kill_permission(int sig, struct siginfo *info,
485 struct task_struct *t)
488 if (!valid_signal(sig))
491 if ((info == SEND_SIG_NOINFO || (!is_si_special(info) && SI_FROMUSER(info)))
492 && ((sig != SIGCONT) ||
493 (process_session(current) != process_session(t)))
494 && (current->euid ^ t->suid) && (current->euid ^ t->uid)
495 && (current->uid ^ t->suid) && (current->uid ^ t->uid)
496 && !capable(CAP_KILL))
499 error = security_task_kill(t, info, sig, 0);
501 audit_signal_info(sig, t); /* Let audit system see the signal */
506 static void do_notify_parent_cldstop(struct task_struct *tsk, int why);
509 * Handle magic process-wide effects of stop/continue signals.
510 * Unlike the signal actions, these happen immediately at signal-generation
511 * time regardless of blocking, ignoring, or handling. This does the
512 * actual continuing for SIGCONT, but not the actual stopping for stop
513 * signals. The process stop is done as a signal action for SIG_DFL.
515 static void handle_stop_signal(int sig, struct task_struct *p)
517 struct task_struct *t;
519 if (p->signal->flags & SIGNAL_GROUP_EXIT)
521 * The process is in the middle of dying already.
525 if (sig_kernel_stop(sig)) {
527 * This is a stop signal. Remove SIGCONT from all queues.
529 rm_from_queue(sigmask(SIGCONT), &p->signal->shared_pending);
532 rm_from_queue(sigmask(SIGCONT), &t->pending);
535 } else if (sig == SIGCONT) {
537 * Remove all stop signals from all queues,
538 * and wake all threads.
540 if (unlikely(p->signal->group_stop_count > 0)) {
542 * There was a group stop in progress. We'll
543 * pretend it finished before we got here. We are
544 * obliged to report it to the parent: if the
545 * SIGSTOP happened "after" this SIGCONT, then it
546 * would have cleared this pending SIGCONT. If it
547 * happened "before" this SIGCONT, then the parent
548 * got the SIGCHLD about the stop finishing before
549 * the continue happened. We do the notification
550 * now, and it's as if the stop had finished and
551 * the SIGCHLD was pending on entry to this kill.
553 p->signal->group_stop_count = 0;
554 p->signal->flags = SIGNAL_STOP_CONTINUED;
555 spin_unlock(&p->sighand->siglock);
556 do_notify_parent_cldstop(p, CLD_STOPPED);
557 spin_lock(&p->sighand->siglock);
559 rm_from_queue(SIG_KERNEL_STOP_MASK, &p->signal->shared_pending);
563 rm_from_queue(SIG_KERNEL_STOP_MASK, &t->pending);
566 * If there is a handler for SIGCONT, we must make
567 * sure that no thread returns to user mode before
568 * we post the signal, in case it was the only
569 * thread eligible to run the signal handler--then
570 * it must not do anything between resuming and
571 * running the handler. With the TIF_SIGPENDING
572 * flag set, the thread will pause and acquire the
573 * siglock that we hold now and until we've queued
574 * the pending signal.
576 * Wake up the stopped thread _after_ setting
579 state = TASK_STOPPED;
580 if (sig_user_defined(t, SIGCONT) && !sigismember(&t->blocked, SIGCONT)) {
581 set_tsk_thread_flag(t, TIF_SIGPENDING);
582 state |= TASK_INTERRUPTIBLE;
584 wake_up_state(t, state);
589 if (p->signal->flags & SIGNAL_STOP_STOPPED) {
591 * We were in fact stopped, and are now continued.
592 * Notify the parent with CLD_CONTINUED.
594 p->signal->flags = SIGNAL_STOP_CONTINUED;
595 p->signal->group_exit_code = 0;
596 spin_unlock(&p->sighand->siglock);
597 do_notify_parent_cldstop(p, CLD_CONTINUED);
598 spin_lock(&p->sighand->siglock);
601 * We are not stopped, but there could be a stop
602 * signal in the middle of being processed after
603 * being removed from the queue. Clear that too.
605 p->signal->flags = 0;
607 } else if (sig == SIGKILL) {
609 * Make sure that any pending stop signal already dequeued
610 * is undone by the wakeup for SIGKILL.
612 p->signal->flags = 0;
616 static int send_signal(int sig, struct siginfo *info, struct task_struct *t,
617 struct sigpending *signals)
619 struct sigqueue * q = NULL;
623 * fast-pathed signals for kernel-internal things like SIGSTOP
626 if (info == SEND_SIG_FORCED)
629 /* Real-time signals must be queued if sent by sigqueue, or
630 some other real-time mechanism. It is implementation
631 defined whether kill() does so. We attempt to do so, on
632 the principle of least surprise, but since kill is not
633 allowed to fail with EAGAIN when low on memory we just
634 make sure at least one signal gets delivered and don't
635 pass on the info struct. */
637 q = __sigqueue_alloc(t, GFP_ATOMIC, (sig < SIGRTMIN &&
638 (is_si_special(info) ||
639 info->si_code >= 0)));
641 list_add_tail(&q->list, &signals->list);
642 switch ((unsigned long) info) {
643 case (unsigned long) SEND_SIG_NOINFO:
644 q->info.si_signo = sig;
645 q->info.si_errno = 0;
646 q->info.si_code = SI_USER;
647 q->info.si_pid = current->pid;
648 q->info.si_uid = current->uid;
650 case (unsigned long) SEND_SIG_PRIV:
651 q->info.si_signo = sig;
652 q->info.si_errno = 0;
653 q->info.si_code = SI_KERNEL;
658 copy_siginfo(&q->info, info);
661 } else if (!is_si_special(info)) {
662 if (sig >= SIGRTMIN && info->si_code != SI_USER)
664 * Queue overflow, abort. We may abort if the signal was rt
665 * and sent by user using something other than kill().
671 sigaddset(&signals->signal, sig);
675 #define LEGACY_QUEUE(sigptr, sig) \
676 (((sig) < SIGRTMIN) && sigismember(&(sigptr)->signal, (sig)))
680 specific_send_sig_info(int sig, struct siginfo *info, struct task_struct *t)
684 BUG_ON(!irqs_disabled());
685 assert_spin_locked(&t->sighand->siglock);
687 /* Short-circuit ignored signals. */
688 if (sig_ignored(t, sig))
691 /* Support queueing exactly one non-rt signal, so that we
692 can get more detailed information about the cause of
694 if (LEGACY_QUEUE(&t->pending, sig))
697 ret = send_signal(sig, info, t, &t->pending);
698 if (!ret && !sigismember(&t->blocked, sig))
699 signal_wake_up(t, sig == SIGKILL);
705 * Force a signal that the process can't ignore: if necessary
706 * we unblock the signal and change any SIG_IGN to SIG_DFL.
708 * Note: If we unblock the signal, we always reset it to SIG_DFL,
709 * since we do not want to have a signal handler that was blocked
710 * be invoked when user space had explicitly blocked it.
712 * We don't want to have recursive SIGSEGV's etc, for example.
715 force_sig_info(int sig, struct siginfo *info, struct task_struct *t)
717 unsigned long int flags;
718 int ret, blocked, ignored;
719 struct k_sigaction *action;
721 spin_lock_irqsave(&t->sighand->siglock, flags);
722 action = &t->sighand->action[sig-1];
723 ignored = action->sa.sa_handler == SIG_IGN;
724 blocked = sigismember(&t->blocked, sig);
725 if (blocked || ignored) {
726 action->sa.sa_handler = SIG_DFL;
728 sigdelset(&t->blocked, sig);
729 recalc_sigpending_tsk(t);
732 ret = specific_send_sig_info(sig, info, t);
733 spin_unlock_irqrestore(&t->sighand->siglock, flags);
739 force_sig_specific(int sig, struct task_struct *t)
741 force_sig_info(sig, SEND_SIG_FORCED, t);
745 * Test if P wants to take SIG. After we've checked all threads with this,
746 * it's equivalent to finding no threads not blocking SIG. Any threads not
747 * blocking SIG were ruled out because they are not running and already
748 * have pending signals. Such threads will dequeue from the shared queue
749 * as soon as they're available, so putting the signal on the shared queue
750 * will be equivalent to sending it to one such thread.
752 static inline int wants_signal(int sig, struct task_struct *p)
754 if (sigismember(&p->blocked, sig))
756 if (p->flags & PF_EXITING)
760 if (p->state & (TASK_STOPPED | TASK_TRACED))
762 return task_curr(p) || !signal_pending(p);
766 __group_complete_signal(int sig, struct task_struct *p)
768 struct task_struct *t;
771 * Now find a thread we can wake up to take the signal off the queue.
773 * If the main thread wants the signal, it gets first crack.
774 * Probably the least surprising to the average bear.
776 if (wants_signal(sig, p))
778 else if (thread_group_empty(p))
780 * There is just one thread and it does not need to be woken.
781 * It will dequeue unblocked signals before it runs again.
786 * Otherwise try to find a suitable thread.
788 t = p->signal->curr_target;
790 /* restart balancing at this thread */
791 t = p->signal->curr_target = p;
793 while (!wants_signal(sig, t)) {
795 if (t == p->signal->curr_target)
797 * No thread needs to be woken.
798 * Any eligible threads will see
799 * the signal in the queue soon.
803 p->signal->curr_target = t;
807 * Found a killable thread. If the signal will be fatal,
808 * then start taking the whole group down immediately.
810 if (sig_fatal(p, sig) && !(p->signal->flags & SIGNAL_GROUP_EXIT) &&
811 !sigismember(&t->real_blocked, sig) &&
812 (sig == SIGKILL || !(t->ptrace & PT_PTRACED))) {
814 * This signal will be fatal to the whole group.
816 if (!sig_kernel_coredump(sig)) {
818 * Start a group exit and wake everybody up.
819 * This way we don't have other threads
820 * running and doing things after a slower
821 * thread has the fatal signal pending.
823 p->signal->flags = SIGNAL_GROUP_EXIT;
824 p->signal->group_exit_code = sig;
825 p->signal->group_stop_count = 0;
828 sigaddset(&t->pending.signal, SIGKILL);
829 signal_wake_up(t, 1);
836 * There will be a core dump. We make all threads other
837 * than the chosen one go into a group stop so that nothing
838 * happens until it gets scheduled, takes the signal off
839 * the shared queue, and does the core dump. This is a
840 * little more complicated than strictly necessary, but it
841 * keeps the signal state that winds up in the core dump
842 * unchanged from the death state, e.g. which thread had
843 * the core-dump signal unblocked.
845 rm_from_queue(SIG_KERNEL_STOP_MASK, &t->pending);
846 rm_from_queue(SIG_KERNEL_STOP_MASK, &p->signal->shared_pending);
847 p->signal->group_stop_count = 0;
848 p->signal->group_exit_task = t;
851 p->signal->group_stop_count++;
852 signal_wake_up(t, 0);
855 wake_up_process(p->signal->group_exit_task);
860 * The signal is already in the shared-pending queue.
861 * Tell the chosen thread to wake up and dequeue it.
863 signal_wake_up(t, sig == SIGKILL);
868 __group_send_sig_info(int sig, struct siginfo *info, struct task_struct *p)
872 assert_spin_locked(&p->sighand->siglock);
873 handle_stop_signal(sig, p);
875 /* Short-circuit ignored signals. */
876 if (sig_ignored(p, sig))
879 if (LEGACY_QUEUE(&p->signal->shared_pending, sig))
880 /* This is a non-RT signal and we already have one queued. */
884 * Put this signal on the shared-pending queue, or fail with EAGAIN.
885 * We always use the shared queue for process-wide signals,
886 * to avoid several races.
888 ret = send_signal(sig, info, p, &p->signal->shared_pending);
892 __group_complete_signal(sig, p);
897 * Nuke all other threads in the group.
899 void zap_other_threads(struct task_struct *p)
901 struct task_struct *t;
903 p->signal->flags = SIGNAL_GROUP_EXIT;
904 p->signal->group_stop_count = 0;
906 if (thread_group_empty(p))
909 for (t = next_thread(p); t != p; t = next_thread(t)) {
911 * Don't bother with already dead threads
916 /* SIGKILL will be handled before any pending SIGSTOP */
917 sigaddset(&t->pending.signal, SIGKILL);
918 signal_wake_up(t, 1);
923 * Must be called under rcu_read_lock() or with tasklist_lock read-held.
925 struct sighand_struct *lock_task_sighand(struct task_struct *tsk, unsigned long *flags)
927 struct sighand_struct *sighand;
930 sighand = rcu_dereference(tsk->sighand);
931 if (unlikely(sighand == NULL))
934 spin_lock_irqsave(&sighand->siglock, *flags);
935 if (likely(sighand == tsk->sighand))
937 spin_unlock_irqrestore(&sighand->siglock, *flags);
943 int group_send_sig_info(int sig, struct siginfo *info, struct task_struct *p)
948 ret = check_kill_permission(sig, info, p);
952 if (lock_task_sighand(p, &flags)) {
953 ret = __group_send_sig_info(sig, info, p);
954 unlock_task_sighand(p, &flags);
962 * kill_pgrp_info() sends a signal to a process group: this is what the tty
963 * control characters do (^C, ^Z etc)
966 int __kill_pgrp_info(int sig, struct siginfo *info, struct pid *pgrp)
968 struct task_struct *p = NULL;
973 do_each_pid_task(pgrp, PIDTYPE_PGID, p) {
974 int err = group_send_sig_info(sig, info, p);
977 } while_each_pid_task(pgrp, PIDTYPE_PGID, p);
978 return success ? 0 : retval;
981 int kill_pgrp_info(int sig, struct siginfo *info, struct pid *pgrp)
985 read_lock(&tasklist_lock);
986 retval = __kill_pgrp_info(sig, info, pgrp);
987 read_unlock(&tasklist_lock);
992 int kill_pid_info(int sig, struct siginfo *info, struct pid *pid)
995 struct task_struct *p;
998 if (unlikely(sig_needs_tasklist(sig)))
999 read_lock(&tasklist_lock);
1001 p = pid_task(pid, PIDTYPE_PID);
1004 error = group_send_sig_info(sig, info, p);
1006 if (unlikely(sig_needs_tasklist(sig)))
1007 read_unlock(&tasklist_lock);
1013 kill_proc_info(int sig, struct siginfo *info, pid_t pid)
1017 error = kill_pid_info(sig, info, find_pid(pid));
1022 /* like kill_pid_info(), but doesn't use uid/euid of "current" */
1023 int kill_pid_info_as_uid(int sig, struct siginfo *info, struct pid *pid,
1024 uid_t uid, uid_t euid, u32 secid)
1027 struct task_struct *p;
1029 if (!valid_signal(sig))
1032 read_lock(&tasklist_lock);
1033 p = pid_task(pid, PIDTYPE_PID);
1038 if ((info == SEND_SIG_NOINFO || (!is_si_special(info) && SI_FROMUSER(info)))
1039 && (euid != p->suid) && (euid != p->uid)
1040 && (uid != p->suid) && (uid != p->uid)) {
1044 ret = security_task_kill(p, info, sig, secid);
1047 if (sig && p->sighand) {
1048 unsigned long flags;
1049 spin_lock_irqsave(&p->sighand->siglock, flags);
1050 ret = __group_send_sig_info(sig, info, p);
1051 spin_unlock_irqrestore(&p->sighand->siglock, flags);
1054 read_unlock(&tasklist_lock);
1057 EXPORT_SYMBOL_GPL(kill_pid_info_as_uid);
1060 * kill_something_info() interprets pid in interesting ways just like kill(2).
1062 * POSIX specifies that kill(-1,sig) is unspecified, but what we have
1063 * is probably wrong. Should make it like BSD or SYSV.
1066 static int kill_something_info(int sig, struct siginfo *info, int pid)
1071 ret = kill_pgrp_info(sig, info, task_pgrp(current));
1072 } else if (pid == -1) {
1073 int retval = 0, count = 0;
1074 struct task_struct * p;
1076 read_lock(&tasklist_lock);
1077 for_each_process(p) {
1078 if (p->pid > 1 && p->tgid != current->tgid) {
1079 int err = group_send_sig_info(sig, info, p);
1085 read_unlock(&tasklist_lock);
1086 ret = count ? retval : -ESRCH;
1087 } else if (pid < 0) {
1088 ret = kill_pgrp_info(sig, info, find_pid(-pid));
1090 ret = kill_pid_info(sig, info, find_pid(pid));
1097 * These are for backward compatibility with the rest of the kernel source.
1101 * These two are the most common entry points. They send a signal
1102 * just to the specific thread.
1105 send_sig_info(int sig, struct siginfo *info, struct task_struct *p)
1108 unsigned long flags;
1111 * Make sure legacy kernel users don't send in bad values
1112 * (normal paths check this in check_kill_permission).
1114 if (!valid_signal(sig))
1118 * We need the tasklist lock even for the specific
1119 * thread case (when we don't need to follow the group
1120 * lists) in order to avoid races with "p->sighand"
1121 * going away or changing from under us.
1123 read_lock(&tasklist_lock);
1124 spin_lock_irqsave(&p->sighand->siglock, flags);
1125 ret = specific_send_sig_info(sig, info, p);
1126 spin_unlock_irqrestore(&p->sighand->siglock, flags);
1127 read_unlock(&tasklist_lock);
1131 #define __si_special(priv) \
1132 ((priv) ? SEND_SIG_PRIV : SEND_SIG_NOINFO)
1135 send_sig(int sig, struct task_struct *p, int priv)
1137 return send_sig_info(sig, __si_special(priv), p);
1141 * This is the entry point for "process-wide" signals.
1142 * They will go to an appropriate thread in the thread group.
1145 send_group_sig_info(int sig, struct siginfo *info, struct task_struct *p)
1148 read_lock(&tasklist_lock);
1149 ret = group_send_sig_info(sig, info, p);
1150 read_unlock(&tasklist_lock);
1155 force_sig(int sig, struct task_struct *p)
1157 force_sig_info(sig, SEND_SIG_PRIV, p);
1161 * When things go south during signal handling, we
1162 * will force a SIGSEGV. And if the signal that caused
1163 * the problem was already a SIGSEGV, we'll want to
1164 * make sure we don't even try to deliver the signal..
1167 force_sigsegv(int sig, struct task_struct *p)
1169 if (sig == SIGSEGV) {
1170 unsigned long flags;
1171 spin_lock_irqsave(&p->sighand->siglock, flags);
1172 p->sighand->action[sig - 1].sa.sa_handler = SIG_DFL;
1173 spin_unlock_irqrestore(&p->sighand->siglock, flags);
1175 force_sig(SIGSEGV, p);
1179 int kill_pgrp(struct pid *pid, int sig, int priv)
1181 return kill_pgrp_info(sig, __si_special(priv), pid);
1183 EXPORT_SYMBOL(kill_pgrp);
1185 int kill_pid(struct pid *pid, int sig, int priv)
1187 return kill_pid_info(sig, __si_special(priv), pid);
1189 EXPORT_SYMBOL(kill_pid);
1192 kill_proc(pid_t pid, int sig, int priv)
1194 return kill_proc_info(sig, __si_special(priv), pid);
1198 * These functions support sending signals using preallocated sigqueue
1199 * structures. This is needed "because realtime applications cannot
1200 * afford to lose notifications of asynchronous events, like timer
1201 * expirations or I/O completions". In the case of Posix Timers
1202 * we allocate the sigqueue structure from the timer_create. If this
1203 * allocation fails we are able to report the failure to the application
1204 * with an EAGAIN error.
1207 struct sigqueue *sigqueue_alloc(void)
1211 if ((q = __sigqueue_alloc(current, GFP_KERNEL, 0)))
1212 q->flags |= SIGQUEUE_PREALLOC;
1216 void sigqueue_free(struct sigqueue *q)
1218 unsigned long flags;
1219 BUG_ON(!(q->flags & SIGQUEUE_PREALLOC));
1221 * If the signal is still pending remove it from the
1224 if (unlikely(!list_empty(&q->list))) {
1225 spinlock_t *lock = ¤t->sighand->siglock;
1226 read_lock(&tasklist_lock);
1227 spin_lock_irqsave(lock, flags);
1228 if (!list_empty(&q->list))
1229 list_del_init(&q->list);
1230 spin_unlock_irqrestore(lock, flags);
1231 read_unlock(&tasklist_lock);
1233 q->flags &= ~SIGQUEUE_PREALLOC;
1237 int send_sigqueue(int sig, struct sigqueue *q, struct task_struct *p)
1239 unsigned long flags;
1242 BUG_ON(!(q->flags & SIGQUEUE_PREALLOC));
1245 * The rcu based delayed sighand destroy makes it possible to
1246 * run this without tasklist lock held. The task struct itself
1247 * cannot go away as create_timer did get_task_struct().
1249 * We return -1, when the task is marked exiting, so
1250 * posix_timer_event can redirect it to the group leader
1254 if (!likely(lock_task_sighand(p, &flags))) {
1259 if (unlikely(!list_empty(&q->list))) {
1261 * If an SI_TIMER entry is already queue just increment
1262 * the overrun count.
1264 BUG_ON(q->info.si_code != SI_TIMER);
1265 q->info.si_overrun++;
1268 /* Short-circuit ignored signals. */
1269 if (sig_ignored(p, sig)) {
1274 list_add_tail(&q->list, &p->pending.list);
1275 sigaddset(&p->pending.signal, sig);
1276 if (!sigismember(&p->blocked, sig))
1277 signal_wake_up(p, sig == SIGKILL);
1280 unlock_task_sighand(p, &flags);
1288 send_group_sigqueue(int sig, struct sigqueue *q, struct task_struct *p)
1290 unsigned long flags;
1293 BUG_ON(!(q->flags & SIGQUEUE_PREALLOC));
1295 read_lock(&tasklist_lock);
1296 /* Since it_lock is held, p->sighand cannot be NULL. */
1297 spin_lock_irqsave(&p->sighand->siglock, flags);
1298 handle_stop_signal(sig, p);
1300 /* Short-circuit ignored signals. */
1301 if (sig_ignored(p, sig)) {
1306 if (unlikely(!list_empty(&q->list))) {
1308 * If an SI_TIMER entry is already queue just increment
1309 * the overrun count. Other uses should not try to
1310 * send the signal multiple times.
1312 BUG_ON(q->info.si_code != SI_TIMER);
1313 q->info.si_overrun++;
1318 * Put this signal on the shared-pending queue.
1319 * We always use the shared queue for process-wide signals,
1320 * to avoid several races.
1322 list_add_tail(&q->list, &p->signal->shared_pending.list);
1323 sigaddset(&p->signal->shared_pending.signal, sig);
1325 __group_complete_signal(sig, p);
1327 spin_unlock_irqrestore(&p->sighand->siglock, flags);
1328 read_unlock(&tasklist_lock);
1333 * Wake up any threads in the parent blocked in wait* syscalls.
1335 static inline void __wake_up_parent(struct task_struct *p,
1336 struct task_struct *parent)
1338 wake_up_interruptible_sync(&parent->signal->wait_chldexit);
1342 * Let a parent know about the death of a child.
1343 * For a stopped/continued status change, use do_notify_parent_cldstop instead.
1346 void do_notify_parent(struct task_struct *tsk, int sig)
1348 struct siginfo info;
1349 unsigned long flags;
1350 struct sighand_struct *psig;
1354 /* do_notify_parent_cldstop should have been called instead. */
1355 BUG_ON(tsk->state & (TASK_STOPPED|TASK_TRACED));
1357 BUG_ON(!tsk->ptrace &&
1358 (tsk->group_leader != tsk || !thread_group_empty(tsk)));
1360 info.si_signo = sig;
1362 info.si_pid = tsk->pid;
1363 info.si_uid = tsk->uid;
1365 /* FIXME: find out whether or not this is supposed to be c*time. */
1366 info.si_utime = cputime_to_jiffies(cputime_add(tsk->utime,
1367 tsk->signal->utime));
1368 info.si_stime = cputime_to_jiffies(cputime_add(tsk->stime,
1369 tsk->signal->stime));
1371 info.si_status = tsk->exit_code & 0x7f;
1372 if (tsk->exit_code & 0x80)
1373 info.si_code = CLD_DUMPED;
1374 else if (tsk->exit_code & 0x7f)
1375 info.si_code = CLD_KILLED;
1377 info.si_code = CLD_EXITED;
1378 info.si_status = tsk->exit_code >> 8;
1381 psig = tsk->parent->sighand;
1382 spin_lock_irqsave(&psig->siglock, flags);
1383 if (!tsk->ptrace && sig == SIGCHLD &&
1384 (psig->action[SIGCHLD-1].sa.sa_handler == SIG_IGN ||
1385 (psig->action[SIGCHLD-1].sa.sa_flags & SA_NOCLDWAIT))) {
1387 * We are exiting and our parent doesn't care. POSIX.1
1388 * defines special semantics for setting SIGCHLD to SIG_IGN
1389 * or setting the SA_NOCLDWAIT flag: we should be reaped
1390 * automatically and not left for our parent's wait4 call.
1391 * Rather than having the parent do it as a magic kind of
1392 * signal handler, we just set this to tell do_exit that we
1393 * can be cleaned up without becoming a zombie. Note that
1394 * we still call __wake_up_parent in this case, because a
1395 * blocked sys_wait4 might now return -ECHILD.
1397 * Whether we send SIGCHLD or not for SA_NOCLDWAIT
1398 * is implementation-defined: we do (if you don't want
1399 * it, just use SIG_IGN instead).
1401 tsk->exit_signal = -1;
1402 if (psig->action[SIGCHLD-1].sa.sa_handler == SIG_IGN)
1405 if (valid_signal(sig) && sig > 0)
1406 __group_send_sig_info(sig, &info, tsk->parent);
1407 __wake_up_parent(tsk, tsk->parent);
1408 spin_unlock_irqrestore(&psig->siglock, flags);
1411 static void do_notify_parent_cldstop(struct task_struct *tsk, int why)
1413 struct siginfo info;
1414 unsigned long flags;
1415 struct task_struct *parent;
1416 struct sighand_struct *sighand;
1418 if (tsk->ptrace & PT_PTRACED)
1419 parent = tsk->parent;
1421 tsk = tsk->group_leader;
1422 parent = tsk->real_parent;
1425 info.si_signo = SIGCHLD;
1427 info.si_pid = tsk->pid;
1428 info.si_uid = tsk->uid;
1430 /* FIXME: find out whether or not this is supposed to be c*time. */
1431 info.si_utime = cputime_to_jiffies(tsk->utime);
1432 info.si_stime = cputime_to_jiffies(tsk->stime);
1437 info.si_status = SIGCONT;
1440 info.si_status = tsk->signal->group_exit_code & 0x7f;
1443 info.si_status = tsk->exit_code & 0x7f;
1449 sighand = parent->sighand;
1450 spin_lock_irqsave(&sighand->siglock, flags);
1451 if (sighand->action[SIGCHLD-1].sa.sa_handler != SIG_IGN &&
1452 !(sighand->action[SIGCHLD-1].sa.sa_flags & SA_NOCLDSTOP))
1453 __group_send_sig_info(SIGCHLD, &info, parent);
1455 * Even if SIGCHLD is not generated, we must wake up wait4 calls.
1457 __wake_up_parent(tsk, parent);
1458 spin_unlock_irqrestore(&sighand->siglock, flags);
1461 static inline int may_ptrace_stop(void)
1463 if (!likely(current->ptrace & PT_PTRACED))
1466 if (unlikely(current->parent == current->real_parent &&
1467 (current->ptrace & PT_ATTACHED)))
1470 if (unlikely(current->signal == current->parent->signal) &&
1471 unlikely(current->signal->flags & SIGNAL_GROUP_EXIT))
1475 * Are we in the middle of do_coredump?
1476 * If so and our tracer is also part of the coredump stopping
1477 * is a deadlock situation, and pointless because our tracer
1478 * is dead so don't allow us to stop.
1479 * If SIGKILL was already sent before the caller unlocked
1480 * ->siglock we must see ->core_waiters != 0. Otherwise it
1481 * is safe to enter schedule().
1483 if (unlikely(current->mm->core_waiters) &&
1484 unlikely(current->mm == current->parent->mm))
1491 * This must be called with current->sighand->siglock held.
1493 * This should be the path for all ptrace stops.
1494 * We always set current->last_siginfo while stopped here.
1495 * That makes it a way to test a stopped process for
1496 * being ptrace-stopped vs being job-control-stopped.
1498 * If we actually decide not to stop at all because the tracer is gone,
1499 * we leave nostop_code in current->exit_code.
1501 static void ptrace_stop(int exit_code, int nostop_code, siginfo_t *info)
1504 * If there is a group stop in progress,
1505 * we must participate in the bookkeeping.
1507 if (current->signal->group_stop_count > 0)
1508 --current->signal->group_stop_count;
1510 current->last_siginfo = info;
1511 current->exit_code = exit_code;
1513 /* Let the debugger run. */
1514 set_current_state(TASK_TRACED);
1515 spin_unlock_irq(¤t->sighand->siglock);
1517 read_lock(&tasklist_lock);
1518 if (may_ptrace_stop()) {
1519 do_notify_parent_cldstop(current, CLD_TRAPPED);
1520 read_unlock(&tasklist_lock);
1524 * By the time we got the lock, our tracer went away.
1527 read_unlock(&tasklist_lock);
1528 set_current_state(TASK_RUNNING);
1529 current->exit_code = nostop_code;
1533 * We are back. Now reacquire the siglock before touching
1534 * last_siginfo, so that we are sure to have synchronized with
1535 * any signal-sending on another CPU that wants to examine it.
1537 spin_lock_irq(¤t->sighand->siglock);
1538 current->last_siginfo = NULL;
1541 * Queued signals ignored us while we were stopped for tracing.
1542 * So check for any that we should take before resuming user mode.
1544 recalc_sigpending();
1547 void ptrace_notify(int exit_code)
1551 BUG_ON((exit_code & (0x7f | ~0xffff)) != SIGTRAP);
1553 memset(&info, 0, sizeof info);
1554 info.si_signo = SIGTRAP;
1555 info.si_code = exit_code;
1556 info.si_pid = current->pid;
1557 info.si_uid = current->uid;
1559 /* Let the debugger run. */
1560 spin_lock_irq(¤t->sighand->siglock);
1561 ptrace_stop(exit_code, 0, &info);
1562 spin_unlock_irq(¤t->sighand->siglock);
1566 finish_stop(int stop_count)
1569 * If there are no other threads in the group, or if there is
1570 * a group stop in progress and we are the last to stop,
1571 * report to the parent. When ptraced, every thread reports itself.
1573 if (stop_count == 0 || (current->ptrace & PT_PTRACED)) {
1574 read_lock(&tasklist_lock);
1575 do_notify_parent_cldstop(current, CLD_STOPPED);
1576 read_unlock(&tasklist_lock);
1581 } while (try_to_freeze());
1583 * Now we don't run again until continued.
1585 current->exit_code = 0;
1589 * This performs the stopping for SIGSTOP and other stop signals.
1590 * We have to stop all threads in the thread group.
1591 * Returns nonzero if we've actually stopped and released the siglock.
1592 * Returns zero if we didn't stop and still hold the siglock.
1594 static int do_signal_stop(int signr)
1596 struct signal_struct *sig = current->signal;
1599 if (!likely(sig->flags & SIGNAL_STOP_DEQUEUED))
1602 if (sig->group_stop_count > 0) {
1604 * There is a group stop in progress. We don't need to
1605 * start another one.
1607 stop_count = --sig->group_stop_count;
1610 * There is no group stop already in progress.
1611 * We must initiate one now.
1613 struct task_struct *t;
1615 sig->group_exit_code = signr;
1618 for (t = next_thread(current); t != current; t = next_thread(t))
1620 * Setting state to TASK_STOPPED for a group
1621 * stop is always done with the siglock held,
1622 * so this check has no races.
1624 if (!t->exit_state &&
1625 !(t->state & (TASK_STOPPED|TASK_TRACED))) {
1627 signal_wake_up(t, 0);
1629 sig->group_stop_count = stop_count;
1632 if (stop_count == 0)
1633 sig->flags = SIGNAL_STOP_STOPPED;
1634 current->exit_code = sig->group_exit_code;
1635 __set_current_state(TASK_STOPPED);
1637 spin_unlock_irq(¤t->sighand->siglock);
1638 finish_stop(stop_count);
1643 * Do appropriate magic when group_stop_count > 0.
1644 * We return nonzero if we stopped, after releasing the siglock.
1645 * We return zero if we still hold the siglock and should look
1646 * for another signal without checking group_stop_count again.
1648 static int handle_group_stop(void)
1652 if (current->signal->group_exit_task == current) {
1654 * Group stop is so we can do a core dump,
1655 * We are the initiating thread, so get on with it.
1657 current->signal->group_exit_task = NULL;
1661 if (current->signal->flags & SIGNAL_GROUP_EXIT)
1663 * Group stop is so another thread can do a core dump,
1664 * or else we are racing against a death signal.
1665 * Just punt the stop so we can get the next signal.
1670 * There is a group stop in progress. We stop
1671 * without any associated signal being in our queue.
1673 stop_count = --current->signal->group_stop_count;
1674 if (stop_count == 0)
1675 current->signal->flags = SIGNAL_STOP_STOPPED;
1676 current->exit_code = current->signal->group_exit_code;
1677 set_current_state(TASK_STOPPED);
1678 spin_unlock_irq(¤t->sighand->siglock);
1679 finish_stop(stop_count);
1683 int get_signal_to_deliver(siginfo_t *info, struct k_sigaction *return_ka,
1684 struct pt_regs *regs, void *cookie)
1686 sigset_t *mask = ¤t->blocked;
1692 spin_lock_irq(¤t->sighand->siglock);
1694 struct k_sigaction *ka;
1696 if (unlikely(current->signal->group_stop_count > 0) &&
1697 handle_group_stop())
1700 signr = dequeue_signal(current, mask, info);
1703 break; /* will return 0 */
1705 if ((current->ptrace & PT_PTRACED) && signr != SIGKILL) {
1706 ptrace_signal_deliver(regs, cookie);
1708 /* Let the debugger run. */
1709 ptrace_stop(signr, signr, info);
1711 /* We're back. Did the debugger cancel the sig? */
1712 signr = current->exit_code;
1716 current->exit_code = 0;
1718 /* Update the siginfo structure if the signal has
1719 changed. If the debugger wanted something
1720 specific in the siginfo structure then it should
1721 have updated *info via PTRACE_SETSIGINFO. */
1722 if (signr != info->si_signo) {
1723 info->si_signo = signr;
1725 info->si_code = SI_USER;
1726 info->si_pid = current->parent->pid;
1727 info->si_uid = current->parent->uid;
1730 /* If the (new) signal is now blocked, requeue it. */
1731 if (sigismember(¤t->blocked, signr)) {
1732 specific_send_sig_info(signr, info, current);
1737 ka = ¤t->sighand->action[signr-1];
1738 if (ka->sa.sa_handler == SIG_IGN) /* Do nothing. */
1740 if (ka->sa.sa_handler != SIG_DFL) {
1741 /* Run the handler. */
1744 if (ka->sa.sa_flags & SA_ONESHOT)
1745 ka->sa.sa_handler = SIG_DFL;
1747 break; /* will return non-zero "signr" value */
1751 * Now we are doing the default action for this signal.
1753 if (sig_kernel_ignore(signr)) /* Default is nothing. */
1757 * Init of a pid space gets no signals it doesn't want from
1758 * within that pid space. It can of course get signals from
1759 * its parent pid space.
1761 if (current == child_reaper(current))
1764 if (sig_kernel_stop(signr)) {
1766 * The default action is to stop all threads in
1767 * the thread group. The job control signals
1768 * do nothing in an orphaned pgrp, but SIGSTOP
1769 * always works. Note that siglock needs to be
1770 * dropped during the call to is_orphaned_pgrp()
1771 * because of lock ordering with tasklist_lock.
1772 * This allows an intervening SIGCONT to be posted.
1773 * We need to check for that and bail out if necessary.
1775 if (signr != SIGSTOP) {
1776 spin_unlock_irq(¤t->sighand->siglock);
1778 /* signals can be posted during this window */
1780 if (is_current_pgrp_orphaned())
1783 spin_lock_irq(¤t->sighand->siglock);
1786 if (likely(do_signal_stop(signr))) {
1787 /* It released the siglock. */
1792 * We didn't actually stop, due to a race
1793 * with SIGCONT or something like that.
1798 spin_unlock_irq(¤t->sighand->siglock);
1801 * Anything else is fatal, maybe with a core dump.
1803 current->flags |= PF_SIGNALED;
1804 if (sig_kernel_coredump(signr)) {
1806 * If it was able to dump core, this kills all
1807 * other threads in the group and synchronizes with
1808 * their demise. If we lost the race with another
1809 * thread getting here, it set group_exit_code
1810 * first and our do_group_exit call below will use
1811 * that value and ignore the one we pass it.
1813 do_coredump((long)signr, signr, regs);
1817 * Death signals, no core dump.
1819 do_group_exit(signr);
1822 spin_unlock_irq(¤t->sighand->siglock);
1826 EXPORT_SYMBOL(recalc_sigpending);
1827 EXPORT_SYMBOL_GPL(dequeue_signal);
1828 EXPORT_SYMBOL(flush_signals);
1829 EXPORT_SYMBOL(force_sig);
1830 EXPORT_SYMBOL(kill_proc);
1831 EXPORT_SYMBOL(ptrace_notify);
1832 EXPORT_SYMBOL(send_sig);
1833 EXPORT_SYMBOL(send_sig_info);
1834 EXPORT_SYMBOL(sigprocmask);
1835 EXPORT_SYMBOL(block_all_signals);
1836 EXPORT_SYMBOL(unblock_all_signals);
1840 * System call entry points.
1843 asmlinkage long sys_restart_syscall(void)
1845 struct restart_block *restart = ¤t_thread_info()->restart_block;
1846 return restart->fn(restart);
1849 long do_no_restart_syscall(struct restart_block *param)
1855 * We don't need to get the kernel lock - this is all local to this
1856 * particular thread.. (and that's good, because this is _heavily_
1857 * used by various programs)
1861 * This is also useful for kernel threads that want to temporarily
1862 * (or permanently) block certain signals.
1864 * NOTE! Unlike the user-mode sys_sigprocmask(), the kernel
1865 * interface happily blocks "unblockable" signals like SIGKILL
1868 int sigprocmask(int how, sigset_t *set, sigset_t *oldset)
1872 spin_lock_irq(¤t->sighand->siglock);
1874 *oldset = current->blocked;
1879 sigorsets(¤t->blocked, ¤t->blocked, set);
1882 signandsets(¤t->blocked, ¤t->blocked, set);
1885 current->blocked = *set;
1890 recalc_sigpending();
1891 spin_unlock_irq(¤t->sighand->siglock);
1897 sys_rt_sigprocmask(int how, sigset_t __user *set, sigset_t __user *oset, size_t sigsetsize)
1899 int error = -EINVAL;
1900 sigset_t old_set, new_set;
1902 /* XXX: Don't preclude handling different sized sigset_t's. */
1903 if (sigsetsize != sizeof(sigset_t))
1908 if (copy_from_user(&new_set, set, sizeof(*set)))
1910 sigdelsetmask(&new_set, sigmask(SIGKILL)|sigmask(SIGSTOP));
1912 error = sigprocmask(how, &new_set, &old_set);
1918 spin_lock_irq(¤t->sighand->siglock);
1919 old_set = current->blocked;
1920 spin_unlock_irq(¤t->sighand->siglock);
1924 if (copy_to_user(oset, &old_set, sizeof(*oset)))
1932 long do_sigpending(void __user *set, unsigned long sigsetsize)
1934 long error = -EINVAL;
1937 if (sigsetsize > sizeof(sigset_t))
1940 spin_lock_irq(¤t->sighand->siglock);
1941 sigorsets(&pending, ¤t->pending.signal,
1942 ¤t->signal->shared_pending.signal);
1943 spin_unlock_irq(¤t->sighand->siglock);
1945 /* Outside the lock because only this thread touches it. */
1946 sigandsets(&pending, ¤t->blocked, &pending);
1949 if (!copy_to_user(set, &pending, sigsetsize))
1957 sys_rt_sigpending(sigset_t __user *set, size_t sigsetsize)
1959 return do_sigpending(set, sigsetsize);
1962 #ifndef HAVE_ARCH_COPY_SIGINFO_TO_USER
1964 int copy_siginfo_to_user(siginfo_t __user *to, siginfo_t *from)
1968 if (!access_ok (VERIFY_WRITE, to, sizeof(siginfo_t)))
1970 if (from->si_code < 0)
1971 return __copy_to_user(to, from, sizeof(siginfo_t))
1974 * If you change siginfo_t structure, please be sure
1975 * this code is fixed accordingly.
1976 * It should never copy any pad contained in the structure
1977 * to avoid security leaks, but must copy the generic
1978 * 3 ints plus the relevant union member.
1980 err = __put_user(from->si_signo, &to->si_signo);
1981 err |= __put_user(from->si_errno, &to->si_errno);
1982 err |= __put_user((short)from->si_code, &to->si_code);
1983 switch (from->si_code & __SI_MASK) {
1985 err |= __put_user(from->si_pid, &to->si_pid);
1986 err |= __put_user(from->si_uid, &to->si_uid);
1989 err |= __put_user(from->si_tid, &to->si_tid);
1990 err |= __put_user(from->si_overrun, &to->si_overrun);
1991 err |= __put_user(from->si_ptr, &to->si_ptr);
1994 err |= __put_user(from->si_band, &to->si_band);
1995 err |= __put_user(from->si_fd, &to->si_fd);
1998 err |= __put_user(from->si_addr, &to->si_addr);
1999 #ifdef __ARCH_SI_TRAPNO
2000 err |= __put_user(from->si_trapno, &to->si_trapno);
2004 err |= __put_user(from->si_pid, &to->si_pid);
2005 err |= __put_user(from->si_uid, &to->si_uid);
2006 err |= __put_user(from->si_status, &to->si_status);
2007 err |= __put_user(from->si_utime, &to->si_utime);
2008 err |= __put_user(from->si_stime, &to->si_stime);
2010 case __SI_RT: /* This is not generated by the kernel as of now. */
2011 case __SI_MESGQ: /* But this is */
2012 err |= __put_user(from->si_pid, &to->si_pid);
2013 err |= __put_user(from->si_uid, &to->si_uid);
2014 err |= __put_user(from->si_ptr, &to->si_ptr);
2016 default: /* this is just in case for now ... */
2017 err |= __put_user(from->si_pid, &to->si_pid);
2018 err |= __put_user(from->si_uid, &to->si_uid);
2027 sys_rt_sigtimedwait(const sigset_t __user *uthese,
2028 siginfo_t __user *uinfo,
2029 const struct timespec __user *uts,
2038 /* XXX: Don't preclude handling different sized sigset_t's. */
2039 if (sigsetsize != sizeof(sigset_t))
2042 if (copy_from_user(&these, uthese, sizeof(these)))
2046 * Invert the set of allowed signals to get those we
2049 sigdelsetmask(&these, sigmask(SIGKILL)|sigmask(SIGSTOP));
2053 if (copy_from_user(&ts, uts, sizeof(ts)))
2055 if (ts.tv_nsec >= 1000000000L || ts.tv_nsec < 0
2060 spin_lock_irq(¤t->sighand->siglock);
2061 sig = dequeue_signal(current, &these, &info);
2063 timeout = MAX_SCHEDULE_TIMEOUT;
2065 timeout = (timespec_to_jiffies(&ts)
2066 + (ts.tv_sec || ts.tv_nsec));
2069 /* None ready -- temporarily unblock those we're
2070 * interested while we are sleeping in so that we'll
2071 * be awakened when they arrive. */
2072 current->real_blocked = current->blocked;
2073 sigandsets(¤t->blocked, ¤t->blocked, &these);
2074 recalc_sigpending();
2075 spin_unlock_irq(¤t->sighand->siglock);
2077 timeout = schedule_timeout_interruptible(timeout);
2079 spin_lock_irq(¤t->sighand->siglock);
2080 sig = dequeue_signal(current, &these, &info);
2081 current->blocked = current->real_blocked;
2082 siginitset(¤t->real_blocked, 0);
2083 recalc_sigpending();
2086 spin_unlock_irq(¤t->sighand->siglock);
2091 if (copy_siginfo_to_user(uinfo, &info))
2104 sys_kill(int pid, int sig)
2106 struct siginfo info;
2108 info.si_signo = sig;
2110 info.si_code = SI_USER;
2111 info.si_pid = current->tgid;
2112 info.si_uid = current->uid;
2114 return kill_something_info(sig, &info, pid);
2117 static int do_tkill(int tgid, int pid, int sig)
2120 struct siginfo info;
2121 struct task_struct *p;
2124 info.si_signo = sig;
2126 info.si_code = SI_TKILL;
2127 info.si_pid = current->tgid;
2128 info.si_uid = current->uid;
2130 read_lock(&tasklist_lock);
2131 p = find_task_by_pid(pid);
2132 if (p && (tgid <= 0 || p->tgid == tgid)) {
2133 error = check_kill_permission(sig, &info, p);
2135 * The null signal is a permissions and process existence
2136 * probe. No signal is actually delivered.
2138 if (!error && sig && p->sighand) {
2139 spin_lock_irq(&p->sighand->siglock);
2140 handle_stop_signal(sig, p);
2141 error = specific_send_sig_info(sig, &info, p);
2142 spin_unlock_irq(&p->sighand->siglock);
2145 read_unlock(&tasklist_lock);
2151 * sys_tgkill - send signal to one specific thread
2152 * @tgid: the thread group ID of the thread
2153 * @pid: the PID of the thread
2154 * @sig: signal to be sent
2156 * This syscall also checks the @tgid and returns -ESRCH even if the PID
2157 * exists but it's not belonging to the target process anymore. This
2158 * method solves the problem of threads exiting and PIDs getting reused.
2160 asmlinkage long sys_tgkill(int tgid, int pid, int sig)
2162 /* This is only valid for single tasks */
2163 if (pid <= 0 || tgid <= 0)
2166 return do_tkill(tgid, pid, sig);
2170 * Send a signal to only one task, even if it's a CLONE_THREAD task.
2173 sys_tkill(int pid, int sig)
2175 /* This is only valid for single tasks */
2179 return do_tkill(0, pid, sig);
2183 sys_rt_sigqueueinfo(int pid, int sig, siginfo_t __user *uinfo)
2187 if (copy_from_user(&info, uinfo, sizeof(siginfo_t)))
2190 /* Not even root can pretend to send signals from the kernel.
2191 Nor can they impersonate a kill(), which adds source info. */
2192 if (info.si_code >= 0)
2194 info.si_signo = sig;
2196 /* POSIX.1b doesn't mention process groups. */
2197 return kill_proc_info(sig, &info, pid);
2200 int do_sigaction(int sig, struct k_sigaction *act, struct k_sigaction *oact)
2202 struct k_sigaction *k;
2205 if (!valid_signal(sig) || sig < 1 || (act && sig_kernel_only(sig)))
2208 k = ¤t->sighand->action[sig-1];
2210 spin_lock_irq(¤t->sighand->siglock);
2211 if (signal_pending(current)) {
2213 * If there might be a fatal signal pending on multiple
2214 * threads, make sure we take it before changing the action.
2216 spin_unlock_irq(¤t->sighand->siglock);
2217 return -ERESTARTNOINTR;
2224 sigdelsetmask(&act->sa.sa_mask,
2225 sigmask(SIGKILL) | sigmask(SIGSTOP));
2229 * "Setting a signal action to SIG_IGN for a signal that is
2230 * pending shall cause the pending signal to be discarded,
2231 * whether or not it is blocked."
2233 * "Setting a signal action to SIG_DFL for a signal that is
2234 * pending and whose default action is to ignore the signal
2235 * (for example, SIGCHLD), shall cause the pending signal to
2236 * be discarded, whether or not it is blocked"
2238 if (act->sa.sa_handler == SIG_IGN ||
2239 (act->sa.sa_handler == SIG_DFL && sig_kernel_ignore(sig))) {
2240 struct task_struct *t = current;
2242 sigaddset(&mask, sig);
2243 rm_from_queue_full(&mask, &t->signal->shared_pending);
2245 rm_from_queue_full(&mask, &t->pending);
2246 recalc_sigpending_tsk(t);
2248 } while (t != current);
2252 spin_unlock_irq(¤t->sighand->siglock);
2257 do_sigaltstack (const stack_t __user *uss, stack_t __user *uoss, unsigned long sp)
2263 oss.ss_sp = (void __user *) current->sas_ss_sp;
2264 oss.ss_size = current->sas_ss_size;
2265 oss.ss_flags = sas_ss_flags(sp);
2274 if (!access_ok(VERIFY_READ, uss, sizeof(*uss))
2275 || __get_user(ss_sp, &uss->ss_sp)
2276 || __get_user(ss_flags, &uss->ss_flags)
2277 || __get_user(ss_size, &uss->ss_size))
2281 if (on_sig_stack(sp))
2287 * Note - this code used to test ss_flags incorrectly
2288 * old code may have been written using ss_flags==0
2289 * to mean ss_flags==SS_ONSTACK (as this was the only
2290 * way that worked) - this fix preserves that older
2293 if (ss_flags != SS_DISABLE && ss_flags != SS_ONSTACK && ss_flags != 0)
2296 if (ss_flags == SS_DISABLE) {
2301 if (ss_size < MINSIGSTKSZ)
2305 current->sas_ss_sp = (unsigned long) ss_sp;
2306 current->sas_ss_size = ss_size;
2311 if (copy_to_user(uoss, &oss, sizeof(oss)))
2320 #ifdef __ARCH_WANT_SYS_SIGPENDING
2323 sys_sigpending(old_sigset_t __user *set)
2325 return do_sigpending(set, sizeof(*set));
2330 #ifdef __ARCH_WANT_SYS_SIGPROCMASK
2331 /* Some platforms have their own version with special arguments others
2332 support only sys_rt_sigprocmask. */
2335 sys_sigprocmask(int how, old_sigset_t __user *set, old_sigset_t __user *oset)
2338 old_sigset_t old_set, new_set;
2342 if (copy_from_user(&new_set, set, sizeof(*set)))
2344 new_set &= ~(sigmask(SIGKILL) | sigmask(SIGSTOP));
2346 spin_lock_irq(¤t->sighand->siglock);
2347 old_set = current->blocked.sig[0];
2355 sigaddsetmask(¤t->blocked, new_set);
2358 sigdelsetmask(¤t->blocked, new_set);
2361 current->blocked.sig[0] = new_set;
2365 recalc_sigpending();
2366 spin_unlock_irq(¤t->sighand->siglock);
2372 old_set = current->blocked.sig[0];
2375 if (copy_to_user(oset, &old_set, sizeof(*oset)))
2382 #endif /* __ARCH_WANT_SYS_SIGPROCMASK */
2384 #ifdef __ARCH_WANT_SYS_RT_SIGACTION
2386 sys_rt_sigaction(int sig,
2387 const struct sigaction __user *act,
2388 struct sigaction __user *oact,
2391 struct k_sigaction new_sa, old_sa;
2394 /* XXX: Don't preclude handling different sized sigset_t's. */
2395 if (sigsetsize != sizeof(sigset_t))
2399 if (copy_from_user(&new_sa.sa, act, sizeof(new_sa.sa)))
2403 ret = do_sigaction(sig, act ? &new_sa : NULL, oact ? &old_sa : NULL);
2406 if (copy_to_user(oact, &old_sa.sa, sizeof(old_sa.sa)))
2412 #endif /* __ARCH_WANT_SYS_RT_SIGACTION */
2414 #ifdef __ARCH_WANT_SYS_SGETMASK
2417 * For backwards compatibility. Functionality superseded by sigprocmask.
2423 return current->blocked.sig[0];
2427 sys_ssetmask(int newmask)
2431 spin_lock_irq(¤t->sighand->siglock);
2432 old = current->blocked.sig[0];
2434 siginitset(¤t->blocked, newmask & ~(sigmask(SIGKILL)|
2436 recalc_sigpending();
2437 spin_unlock_irq(¤t->sighand->siglock);
2441 #endif /* __ARCH_WANT_SGETMASK */
2443 #ifdef __ARCH_WANT_SYS_SIGNAL
2445 * For backwards compatibility. Functionality superseded by sigaction.
2447 asmlinkage unsigned long
2448 sys_signal(int sig, __sighandler_t handler)
2450 struct k_sigaction new_sa, old_sa;
2453 new_sa.sa.sa_handler = handler;
2454 new_sa.sa.sa_flags = SA_ONESHOT | SA_NOMASK;
2455 sigemptyset(&new_sa.sa.sa_mask);
2457 ret = do_sigaction(sig, &new_sa, &old_sa);
2459 return ret ? ret : (unsigned long)old_sa.sa.sa_handler;
2461 #endif /* __ARCH_WANT_SYS_SIGNAL */
2463 #ifdef __ARCH_WANT_SYS_PAUSE
2468 current->state = TASK_INTERRUPTIBLE;
2470 return -ERESTARTNOHAND;
2475 #ifdef __ARCH_WANT_SYS_RT_SIGSUSPEND
2476 asmlinkage long sys_rt_sigsuspend(sigset_t __user *unewset, size_t sigsetsize)
2480 /* XXX: Don't preclude handling different sized sigset_t's. */
2481 if (sigsetsize != sizeof(sigset_t))
2484 if (copy_from_user(&newset, unewset, sizeof(newset)))
2486 sigdelsetmask(&newset, sigmask(SIGKILL)|sigmask(SIGSTOP));
2488 spin_lock_irq(¤t->sighand->siglock);
2489 current->saved_sigmask = current->blocked;
2490 current->blocked = newset;
2491 recalc_sigpending();
2492 spin_unlock_irq(¤t->sighand->siglock);
2494 current->state = TASK_INTERRUPTIBLE;
2496 set_thread_flag(TIF_RESTORE_SIGMASK);
2497 return -ERESTARTNOHAND;
2499 #endif /* __ARCH_WANT_SYS_RT_SIGSUSPEND */
2501 __attribute__((weak)) const char *arch_vma_name(struct vm_area_struct *vma)
2506 void __init signals_init(void)
2508 sigqueue_cachep = KMEM_CACHE(sigqueue, SLAB_PANIC);