tracehook: job control
[safe/jmp/linux-2.6] / kernel / signal.c
1 /*
2  *  linux/kernel/signal.c
3  *
4  *  Copyright (C) 1991, 1992  Linus Torvalds
5  *
6  *  1997-11-02  Modified for POSIX.1b signals by Richard Henderson
7  *
8  *  2003-06-02  Jim Houston - Concurrent Computer Corp.
9  *              Changes to use preallocated sigqueue structures
10  *              to allow signals to be sent reliably.
11  */
12
13 #include <linux/slab.h>
14 #include <linux/module.h>
15 #include <linux/init.h>
16 #include <linux/sched.h>
17 #include <linux/fs.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/signalfd.h>
25 #include <linux/tracehook.h>
26 #include <linux/capability.h>
27 #include <linux/freezer.h>
28 #include <linux/pid_namespace.h>
29 #include <linux/nsproxy.h>
30
31 #include <asm/param.h>
32 #include <asm/uaccess.h>
33 #include <asm/unistd.h>
34 #include <asm/siginfo.h>
35 #include "audit.h"      /* audit_signal_info() */
36
37 /*
38  * SLAB caches for signal bits.
39  */
40
41 static struct kmem_cache *sigqueue_cachep;
42
43 static void __user *sig_handler(struct task_struct *t, int sig)
44 {
45         return t->sighand->action[sig - 1].sa.sa_handler;
46 }
47
48 static int sig_handler_ignored(void __user *handler, int sig)
49 {
50         /* Is it explicitly or implicitly ignored? */
51         return handler == SIG_IGN ||
52                 (handler == SIG_DFL && sig_kernel_ignore(sig));
53 }
54
55 static int sig_ignored(struct task_struct *t, int sig)
56 {
57         void __user *handler;
58
59         /*
60          * Blocked signals are never ignored, since the
61          * signal handler may change by the time it is
62          * unblocked.
63          */
64         if (sigismember(&t->blocked, sig) || sigismember(&t->real_blocked, sig))
65                 return 0;
66
67         handler = sig_handler(t, sig);
68         if (!sig_handler_ignored(handler, sig))
69                 return 0;
70
71         /*
72          * Tracers may want to know about even ignored signals.
73          */
74         return !tracehook_consider_ignored_signal(t, sig, handler);
75 }
76
77 /*
78  * Re-calculate pending state from the set of locally pending
79  * signals, globally pending signals, and blocked signals.
80  */
81 static inline int has_pending_signals(sigset_t *signal, sigset_t *blocked)
82 {
83         unsigned long ready;
84         long i;
85
86         switch (_NSIG_WORDS) {
87         default:
88                 for (i = _NSIG_WORDS, ready = 0; --i >= 0 ;)
89                         ready |= signal->sig[i] &~ blocked->sig[i];
90                 break;
91
92         case 4: ready  = signal->sig[3] &~ blocked->sig[3];
93                 ready |= signal->sig[2] &~ blocked->sig[2];
94                 ready |= signal->sig[1] &~ blocked->sig[1];
95                 ready |= signal->sig[0] &~ blocked->sig[0];
96                 break;
97
98         case 2: ready  = signal->sig[1] &~ blocked->sig[1];
99                 ready |= signal->sig[0] &~ blocked->sig[0];
100                 break;
101
102         case 1: ready  = signal->sig[0] &~ blocked->sig[0];
103         }
104         return ready != 0;
105 }
106
107 #define PENDING(p,b) has_pending_signals(&(p)->signal, (b))
108
109 static int recalc_sigpending_tsk(struct task_struct *t)
110 {
111         if (t->signal->group_stop_count > 0 ||
112             PENDING(&t->pending, &t->blocked) ||
113             PENDING(&t->signal->shared_pending, &t->blocked)) {
114                 set_tsk_thread_flag(t, TIF_SIGPENDING);
115                 return 1;
116         }
117         /*
118          * We must never clear the flag in another thread, or in current
119          * when it's possible the current syscall is returning -ERESTART*.
120          * So we don't clear it here, and only callers who know they should do.
121          */
122         return 0;
123 }
124
125 /*
126  * After recalculating TIF_SIGPENDING, we need to make sure the task wakes up.
127  * This is superfluous when called on current, the wakeup is a harmless no-op.
128  */
129 void recalc_sigpending_and_wake(struct task_struct *t)
130 {
131         if (recalc_sigpending_tsk(t))
132                 signal_wake_up(t, 0);
133 }
134
135 void recalc_sigpending(void)
136 {
137         if (!recalc_sigpending_tsk(current) && !freezing(current))
138                 clear_thread_flag(TIF_SIGPENDING);
139
140 }
141
142 /* Given the mask, find the first available signal that should be serviced. */
143
144 int next_signal(struct sigpending *pending, sigset_t *mask)
145 {
146         unsigned long i, *s, *m, x;
147         int sig = 0;
148         
149         s = pending->signal.sig;
150         m = mask->sig;
151         switch (_NSIG_WORDS) {
152         default:
153                 for (i = 0; i < _NSIG_WORDS; ++i, ++s, ++m)
154                         if ((x = *s &~ *m) != 0) {
155                                 sig = ffz(~x) + i*_NSIG_BPW + 1;
156                                 break;
157                         }
158                 break;
159
160         case 2: if ((x = s[0] &~ m[0]) != 0)
161                         sig = 1;
162                 else if ((x = s[1] &~ m[1]) != 0)
163                         sig = _NSIG_BPW + 1;
164                 else
165                         break;
166                 sig += ffz(~x);
167                 break;
168
169         case 1: if ((x = *s &~ *m) != 0)
170                         sig = ffz(~x) + 1;
171                 break;
172         }
173         
174         return sig;
175 }
176
177 static struct sigqueue *__sigqueue_alloc(struct task_struct *t, gfp_t flags,
178                                          int override_rlimit)
179 {
180         struct sigqueue *q = NULL;
181         struct user_struct *user;
182
183         /*
184          * In order to avoid problems with "switch_user()", we want to make
185          * sure that the compiler doesn't re-load "t->user"
186          */
187         user = t->user;
188         barrier();
189         atomic_inc(&user->sigpending);
190         if (override_rlimit ||
191             atomic_read(&user->sigpending) <=
192                         t->signal->rlim[RLIMIT_SIGPENDING].rlim_cur)
193                 q = kmem_cache_alloc(sigqueue_cachep, flags);
194         if (unlikely(q == NULL)) {
195                 atomic_dec(&user->sigpending);
196         } else {
197                 INIT_LIST_HEAD(&q->list);
198                 q->flags = 0;
199                 q->user = get_uid(user);
200         }
201         return(q);
202 }
203
204 static void __sigqueue_free(struct sigqueue *q)
205 {
206         if (q->flags & SIGQUEUE_PREALLOC)
207                 return;
208         atomic_dec(&q->user->sigpending);
209         free_uid(q->user);
210         kmem_cache_free(sigqueue_cachep, q);
211 }
212
213 void flush_sigqueue(struct sigpending *queue)
214 {
215         struct sigqueue *q;
216
217         sigemptyset(&queue->signal);
218         while (!list_empty(&queue->list)) {
219                 q = list_entry(queue->list.next, struct sigqueue , list);
220                 list_del_init(&q->list);
221                 __sigqueue_free(q);
222         }
223 }
224
225 /*
226  * Flush all pending signals for a task.
227  */
228 void flush_signals(struct task_struct *t)
229 {
230         unsigned long flags;
231
232         spin_lock_irqsave(&t->sighand->siglock, flags);
233         clear_tsk_thread_flag(t, TIF_SIGPENDING);
234         flush_sigqueue(&t->pending);
235         flush_sigqueue(&t->signal->shared_pending);
236         spin_unlock_irqrestore(&t->sighand->siglock, flags);
237 }
238
239 static void __flush_itimer_signals(struct sigpending *pending)
240 {
241         sigset_t signal, retain;
242         struct sigqueue *q, *n;
243
244         signal = pending->signal;
245         sigemptyset(&retain);
246
247         list_for_each_entry_safe(q, n, &pending->list, list) {
248                 int sig = q->info.si_signo;
249
250                 if (likely(q->info.si_code != SI_TIMER)) {
251                         sigaddset(&retain, sig);
252                 } else {
253                         sigdelset(&signal, sig);
254                         list_del_init(&q->list);
255                         __sigqueue_free(q);
256                 }
257         }
258
259         sigorsets(&pending->signal, &signal, &retain);
260 }
261
262 void flush_itimer_signals(void)
263 {
264         struct task_struct *tsk = current;
265         unsigned long flags;
266
267         spin_lock_irqsave(&tsk->sighand->siglock, flags);
268         __flush_itimer_signals(&tsk->pending);
269         __flush_itimer_signals(&tsk->signal->shared_pending);
270         spin_unlock_irqrestore(&tsk->sighand->siglock, flags);
271 }
272
273 void ignore_signals(struct task_struct *t)
274 {
275         int i;
276
277         for (i = 0; i < _NSIG; ++i)
278                 t->sighand->action[i].sa.sa_handler = SIG_IGN;
279
280         flush_signals(t);
281 }
282
283 /*
284  * Flush all handlers for a task.
285  */
286
287 void
288 flush_signal_handlers(struct task_struct *t, int force_default)
289 {
290         int i;
291         struct k_sigaction *ka = &t->sighand->action[0];
292         for (i = _NSIG ; i != 0 ; i--) {
293                 if (force_default || ka->sa.sa_handler != SIG_IGN)
294                         ka->sa.sa_handler = SIG_DFL;
295                 ka->sa.sa_flags = 0;
296                 sigemptyset(&ka->sa.sa_mask);
297                 ka++;
298         }
299 }
300
301 int unhandled_signal(struct task_struct *tsk, int sig)
302 {
303         void __user *handler = tsk->sighand->action[sig-1].sa.sa_handler;
304         if (is_global_init(tsk))
305                 return 1;
306         if (handler != SIG_IGN && handler != SIG_DFL)
307                 return 0;
308         return !tracehook_consider_fatal_signal(tsk, sig, handler);
309 }
310
311
312 /* Notify the system that a driver wants to block all signals for this
313  * process, and wants to be notified if any signals at all were to be
314  * sent/acted upon.  If the notifier routine returns non-zero, then the
315  * signal will be acted upon after all.  If the notifier routine returns 0,
316  * then then signal will be blocked.  Only one block per process is
317  * allowed.  priv is a pointer to private data that the notifier routine
318  * can use to determine if the signal should be blocked or not.  */
319
320 void
321 block_all_signals(int (*notifier)(void *priv), void *priv, sigset_t *mask)
322 {
323         unsigned long flags;
324
325         spin_lock_irqsave(&current->sighand->siglock, flags);
326         current->notifier_mask = mask;
327         current->notifier_data = priv;
328         current->notifier = notifier;
329         spin_unlock_irqrestore(&current->sighand->siglock, flags);
330 }
331
332 /* Notify the system that blocking has ended. */
333
334 void
335 unblock_all_signals(void)
336 {
337         unsigned long flags;
338
339         spin_lock_irqsave(&current->sighand->siglock, flags);
340         current->notifier = NULL;
341         current->notifier_data = NULL;
342         recalc_sigpending();
343         spin_unlock_irqrestore(&current->sighand->siglock, flags);
344 }
345
346 static void collect_signal(int sig, struct sigpending *list, siginfo_t *info)
347 {
348         struct sigqueue *q, *first = NULL;
349
350         /*
351          * Collect the siginfo appropriate to this signal.  Check if
352          * there is another siginfo for the same signal.
353         */
354         list_for_each_entry(q, &list->list, list) {
355                 if (q->info.si_signo == sig) {
356                         if (first)
357                                 goto still_pending;
358                         first = q;
359                 }
360         }
361
362         sigdelset(&list->signal, sig);
363
364         if (first) {
365 still_pending:
366                 list_del_init(&first->list);
367                 copy_siginfo(info, &first->info);
368                 __sigqueue_free(first);
369         } else {
370                 /* Ok, it wasn't in the queue.  This must be
371                    a fast-pathed signal or we must have been
372                    out of queue space.  So zero out the info.
373                  */
374                 info->si_signo = sig;
375                 info->si_errno = 0;
376                 info->si_code = 0;
377                 info->si_pid = 0;
378                 info->si_uid = 0;
379         }
380 }
381
382 static int __dequeue_signal(struct sigpending *pending, sigset_t *mask,
383                         siginfo_t *info)
384 {
385         int sig = next_signal(pending, mask);
386
387         if (sig) {
388                 if (current->notifier) {
389                         if (sigismember(current->notifier_mask, sig)) {
390                                 if (!(current->notifier)(current->notifier_data)) {
391                                         clear_thread_flag(TIF_SIGPENDING);
392                                         return 0;
393                                 }
394                         }
395                 }
396
397                 collect_signal(sig, pending, info);
398         }
399
400         return sig;
401 }
402
403 /*
404  * Dequeue a signal and return the element to the caller, which is 
405  * expected to free it.
406  *
407  * All callers have to hold the siglock.
408  */
409 int dequeue_signal(struct task_struct *tsk, sigset_t *mask, siginfo_t *info)
410 {
411         int signr;
412
413         /* We only dequeue private signals from ourselves, we don't let
414          * signalfd steal them
415          */
416         signr = __dequeue_signal(&tsk->pending, mask, info);
417         if (!signr) {
418                 signr = __dequeue_signal(&tsk->signal->shared_pending,
419                                          mask, info);
420                 /*
421                  * itimer signal ?
422                  *
423                  * itimers are process shared and we restart periodic
424                  * itimers in the signal delivery path to prevent DoS
425                  * attacks in the high resolution timer case. This is
426                  * compliant with the old way of self restarting
427                  * itimers, as the SIGALRM is a legacy signal and only
428                  * queued once. Changing the restart behaviour to
429                  * restart the timer in the signal dequeue path is
430                  * reducing the timer noise on heavy loaded !highres
431                  * systems too.
432                  */
433                 if (unlikely(signr == SIGALRM)) {
434                         struct hrtimer *tmr = &tsk->signal->real_timer;
435
436                         if (!hrtimer_is_queued(tmr) &&
437                             tsk->signal->it_real_incr.tv64 != 0) {
438                                 hrtimer_forward(tmr, tmr->base->get_time(),
439                                                 tsk->signal->it_real_incr);
440                                 hrtimer_restart(tmr);
441                         }
442                 }
443         }
444
445         recalc_sigpending();
446         if (!signr)
447                 return 0;
448
449         if (unlikely(sig_kernel_stop(signr))) {
450                 /*
451                  * Set a marker that we have dequeued a stop signal.  Our
452                  * caller might release the siglock and then the pending
453                  * stop signal it is about to process is no longer in the
454                  * pending bitmasks, but must still be cleared by a SIGCONT
455                  * (and overruled by a SIGKILL).  So those cases clear this
456                  * shared flag after we've set it.  Note that this flag may
457                  * remain set after the signal we return is ignored or
458                  * handled.  That doesn't matter because its only purpose
459                  * is to alert stop-signal processing code when another
460                  * processor has come along and cleared the flag.
461                  */
462                 tsk->signal->flags |= SIGNAL_STOP_DEQUEUED;
463         }
464         if ((info->si_code & __SI_MASK) == __SI_TIMER && info->si_sys_private) {
465                 /*
466                  * Release the siglock to ensure proper locking order
467                  * of timer locks outside of siglocks.  Note, we leave
468                  * irqs disabled here, since the posix-timers code is
469                  * about to disable them again anyway.
470                  */
471                 spin_unlock(&tsk->sighand->siglock);
472                 do_schedule_next_timer(info);
473                 spin_lock(&tsk->sighand->siglock);
474         }
475         return signr;
476 }
477
478 /*
479  * Tell a process that it has a new active signal..
480  *
481  * NOTE! we rely on the previous spin_lock to
482  * lock interrupts for us! We can only be called with
483  * "siglock" held, and the local interrupt must
484  * have been disabled when that got acquired!
485  *
486  * No need to set need_resched since signal event passing
487  * goes through ->blocked
488  */
489 void signal_wake_up(struct task_struct *t, int resume)
490 {
491         unsigned int mask;
492
493         set_tsk_thread_flag(t, TIF_SIGPENDING);
494
495         /*
496          * For SIGKILL, we want to wake it up in the stopped/traced/killable
497          * case. We don't check t->state here because there is a race with it
498          * executing another processor and just now entering stopped state.
499          * By using wake_up_state, we ensure the process will wake up and
500          * handle its death signal.
501          */
502         mask = TASK_INTERRUPTIBLE;
503         if (resume)
504                 mask |= TASK_WAKEKILL;
505         if (!wake_up_state(t, mask))
506                 kick_process(t);
507 }
508
509 /*
510  * Remove signals in mask from the pending set and queue.
511  * Returns 1 if any signals were found.
512  *
513  * All callers must be holding the siglock.
514  *
515  * This version takes a sigset mask and looks at all signals,
516  * not just those in the first mask word.
517  */
518 static int rm_from_queue_full(sigset_t *mask, struct sigpending *s)
519 {
520         struct sigqueue *q, *n;
521         sigset_t m;
522
523         sigandsets(&m, mask, &s->signal);
524         if (sigisemptyset(&m))
525                 return 0;
526
527         signandsets(&s->signal, &s->signal, mask);
528         list_for_each_entry_safe(q, n, &s->list, list) {
529                 if (sigismember(mask, q->info.si_signo)) {
530                         list_del_init(&q->list);
531                         __sigqueue_free(q);
532                 }
533         }
534         return 1;
535 }
536 /*
537  * Remove signals in mask from the pending set and queue.
538  * Returns 1 if any signals were found.
539  *
540  * All callers must be holding the siglock.
541  */
542 static int rm_from_queue(unsigned long mask, struct sigpending *s)
543 {
544         struct sigqueue *q, *n;
545
546         if (!sigtestsetmask(&s->signal, mask))
547                 return 0;
548
549         sigdelsetmask(&s->signal, mask);
550         list_for_each_entry_safe(q, n, &s->list, list) {
551                 if (q->info.si_signo < SIGRTMIN &&
552                     (mask & sigmask(q->info.si_signo))) {
553                         list_del_init(&q->list);
554                         __sigqueue_free(q);
555                 }
556         }
557         return 1;
558 }
559
560 /*
561  * Bad permissions for sending the signal
562  */
563 static int check_kill_permission(int sig, struct siginfo *info,
564                                  struct task_struct *t)
565 {
566         struct pid *sid;
567         int error;
568
569         if (!valid_signal(sig))
570                 return -EINVAL;
571
572         if (info != SEND_SIG_NOINFO && (is_si_special(info) || SI_FROMKERNEL(info)))
573                 return 0;
574
575         error = audit_signal_info(sig, t); /* Let audit system see the signal */
576         if (error)
577                 return error;
578
579         if ((current->euid ^ t->suid) && (current->euid ^ t->uid) &&
580             (current->uid  ^ t->suid) && (current->uid  ^ t->uid) &&
581             !capable(CAP_KILL)) {
582                 switch (sig) {
583                 case SIGCONT:
584                         sid = task_session(t);
585                         /*
586                          * We don't return the error if sid == NULL. The
587                          * task was unhashed, the caller must notice this.
588                          */
589                         if (!sid || sid == task_session(current))
590                                 break;
591                 default:
592                         return -EPERM;
593                 }
594         }
595
596         return security_task_kill(t, info, sig, 0);
597 }
598
599 /*
600  * Handle magic process-wide effects of stop/continue signals. Unlike
601  * the signal actions, these happen immediately at signal-generation
602  * time regardless of blocking, ignoring, or handling.  This does the
603  * actual continuing for SIGCONT, but not the actual stopping for stop
604  * signals. The process stop is done as a signal action for SIG_DFL.
605  *
606  * Returns true if the signal should be actually delivered, otherwise
607  * it should be dropped.
608  */
609 static int prepare_signal(int sig, struct task_struct *p)
610 {
611         struct signal_struct *signal = p->signal;
612         struct task_struct *t;
613
614         if (unlikely(signal->flags & SIGNAL_GROUP_EXIT)) {
615                 /*
616                  * The process is in the middle of dying, nothing to do.
617                  */
618         } else if (sig_kernel_stop(sig)) {
619                 /*
620                  * This is a stop signal.  Remove SIGCONT from all queues.
621                  */
622                 rm_from_queue(sigmask(SIGCONT), &signal->shared_pending);
623                 t = p;
624                 do {
625                         rm_from_queue(sigmask(SIGCONT), &t->pending);
626                 } while_each_thread(p, t);
627         } else if (sig == SIGCONT) {
628                 unsigned int why;
629                 /*
630                  * Remove all stop signals from all queues,
631                  * and wake all threads.
632                  */
633                 rm_from_queue(SIG_KERNEL_STOP_MASK, &signal->shared_pending);
634                 t = p;
635                 do {
636                         unsigned int state;
637                         rm_from_queue(SIG_KERNEL_STOP_MASK, &t->pending);
638                         /*
639                          * If there is a handler for SIGCONT, we must make
640                          * sure that no thread returns to user mode before
641                          * we post the signal, in case it was the only
642                          * thread eligible to run the signal handler--then
643                          * it must not do anything between resuming and
644                          * running the handler.  With the TIF_SIGPENDING
645                          * flag set, the thread will pause and acquire the
646                          * siglock that we hold now and until we've queued
647                          * the pending signal.
648                          *
649                          * Wake up the stopped thread _after_ setting
650                          * TIF_SIGPENDING
651                          */
652                         state = __TASK_STOPPED;
653                         if (sig_user_defined(t, SIGCONT) && !sigismember(&t->blocked, SIGCONT)) {
654                                 set_tsk_thread_flag(t, TIF_SIGPENDING);
655                                 state |= TASK_INTERRUPTIBLE;
656                         }
657                         wake_up_state(t, state);
658                 } while_each_thread(p, t);
659
660                 /*
661                  * Notify the parent with CLD_CONTINUED if we were stopped.
662                  *
663                  * If we were in the middle of a group stop, we pretend it
664                  * was already finished, and then continued. Since SIGCHLD
665                  * doesn't queue we report only CLD_STOPPED, as if the next
666                  * CLD_CONTINUED was dropped.
667                  */
668                 why = 0;
669                 if (signal->flags & SIGNAL_STOP_STOPPED)
670                         why |= SIGNAL_CLD_CONTINUED;
671                 else if (signal->group_stop_count)
672                         why |= SIGNAL_CLD_STOPPED;
673
674                 if (why) {
675                         /*
676                          * The first thread which returns from finish_stop()
677                          * will take ->siglock, notice SIGNAL_CLD_MASK, and
678                          * notify its parent. See get_signal_to_deliver().
679                          */
680                         signal->flags = why | SIGNAL_STOP_CONTINUED;
681                         signal->group_stop_count = 0;
682                         signal->group_exit_code = 0;
683                 } else {
684                         /*
685                          * We are not stopped, but there could be a stop
686                          * signal in the middle of being processed after
687                          * being removed from the queue.  Clear that too.
688                          */
689                         signal->flags &= ~SIGNAL_STOP_DEQUEUED;
690                 }
691         }
692
693         return !sig_ignored(p, sig);
694 }
695
696 /*
697  * Test if P wants to take SIG.  After we've checked all threads with this,
698  * it's equivalent to finding no threads not blocking SIG.  Any threads not
699  * blocking SIG were ruled out because they are not running and already
700  * have pending signals.  Such threads will dequeue from the shared queue
701  * as soon as they're available, so putting the signal on the shared queue
702  * will be equivalent to sending it to one such thread.
703  */
704 static inline int wants_signal(int sig, struct task_struct *p)
705 {
706         if (sigismember(&p->blocked, sig))
707                 return 0;
708         if (p->flags & PF_EXITING)
709                 return 0;
710         if (sig == SIGKILL)
711                 return 1;
712         if (task_is_stopped_or_traced(p))
713                 return 0;
714         return task_curr(p) || !signal_pending(p);
715 }
716
717 static void complete_signal(int sig, struct task_struct *p, int group)
718 {
719         struct signal_struct *signal = p->signal;
720         struct task_struct *t;
721
722         /*
723          * Now find a thread we can wake up to take the signal off the queue.
724          *
725          * If the main thread wants the signal, it gets first crack.
726          * Probably the least surprising to the average bear.
727          */
728         if (wants_signal(sig, p))
729                 t = p;
730         else if (!group || thread_group_empty(p))
731                 /*
732                  * There is just one thread and it does not need to be woken.
733                  * It will dequeue unblocked signals before it runs again.
734                  */
735                 return;
736         else {
737                 /*
738                  * Otherwise try to find a suitable thread.
739                  */
740                 t = signal->curr_target;
741                 while (!wants_signal(sig, t)) {
742                         t = next_thread(t);
743                         if (t == signal->curr_target)
744                                 /*
745                                  * No thread needs to be woken.
746                                  * Any eligible threads will see
747                                  * the signal in the queue soon.
748                                  */
749                                 return;
750                 }
751                 signal->curr_target = t;
752         }
753
754         /*
755          * Found a killable thread.  If the signal will be fatal,
756          * then start taking the whole group down immediately.
757          */
758         if (sig_fatal(p, sig) &&
759             !(signal->flags & (SIGNAL_UNKILLABLE | SIGNAL_GROUP_EXIT)) &&
760             !sigismember(&t->real_blocked, sig) &&
761             (sig == SIGKILL ||
762              !tracehook_consider_fatal_signal(t, sig, SIG_DFL))) {
763                 /*
764                  * This signal will be fatal to the whole group.
765                  */
766                 if (!sig_kernel_coredump(sig)) {
767                         /*
768                          * Start a group exit and wake everybody up.
769                          * This way we don't have other threads
770                          * running and doing things after a slower
771                          * thread has the fatal signal pending.
772                          */
773                         signal->flags = SIGNAL_GROUP_EXIT;
774                         signal->group_exit_code = sig;
775                         signal->group_stop_count = 0;
776                         t = p;
777                         do {
778                                 sigaddset(&t->pending.signal, SIGKILL);
779                                 signal_wake_up(t, 1);
780                         } while_each_thread(p, t);
781                         return;
782                 }
783         }
784
785         /*
786          * The signal is already in the shared-pending queue.
787          * Tell the chosen thread to wake up and dequeue it.
788          */
789         signal_wake_up(t, sig == SIGKILL);
790         return;
791 }
792
793 static inline int legacy_queue(struct sigpending *signals, int sig)
794 {
795         return (sig < SIGRTMIN) && sigismember(&signals->signal, sig);
796 }
797
798 static int send_signal(int sig, struct siginfo *info, struct task_struct *t,
799                         int group)
800 {
801         struct sigpending *pending;
802         struct sigqueue *q;
803
804         assert_spin_locked(&t->sighand->siglock);
805         if (!prepare_signal(sig, t))
806                 return 0;
807
808         pending = group ? &t->signal->shared_pending : &t->pending;
809         /*
810          * Short-circuit ignored signals and support queuing
811          * exactly one non-rt signal, so that we can get more
812          * detailed information about the cause of the signal.
813          */
814         if (legacy_queue(pending, sig))
815                 return 0;
816         /*
817          * fast-pathed signals for kernel-internal things like SIGSTOP
818          * or SIGKILL.
819          */
820         if (info == SEND_SIG_FORCED)
821                 goto out_set;
822
823         /* Real-time signals must be queued if sent by sigqueue, or
824            some other real-time mechanism.  It is implementation
825            defined whether kill() does so.  We attempt to do so, on
826            the principle of least surprise, but since kill is not
827            allowed to fail with EAGAIN when low on memory we just
828            make sure at least one signal gets delivered and don't
829            pass on the info struct.  */
830
831         q = __sigqueue_alloc(t, GFP_ATOMIC, (sig < SIGRTMIN &&
832                                              (is_si_special(info) ||
833                                               info->si_code >= 0)));
834         if (q) {
835                 list_add_tail(&q->list, &pending->list);
836                 switch ((unsigned long) info) {
837                 case (unsigned long) SEND_SIG_NOINFO:
838                         q->info.si_signo = sig;
839                         q->info.si_errno = 0;
840                         q->info.si_code = SI_USER;
841                         q->info.si_pid = task_pid_vnr(current);
842                         q->info.si_uid = current->uid;
843                         break;
844                 case (unsigned long) SEND_SIG_PRIV:
845                         q->info.si_signo = sig;
846                         q->info.si_errno = 0;
847                         q->info.si_code = SI_KERNEL;
848                         q->info.si_pid = 0;
849                         q->info.si_uid = 0;
850                         break;
851                 default:
852                         copy_siginfo(&q->info, info);
853                         break;
854                 }
855         } else if (!is_si_special(info)) {
856                 if (sig >= SIGRTMIN && info->si_code != SI_USER)
857                 /*
858                  * Queue overflow, abort.  We may abort if the signal was rt
859                  * and sent by user using something other than kill().
860                  */
861                         return -EAGAIN;
862         }
863
864 out_set:
865         signalfd_notify(t, sig);
866         sigaddset(&pending->signal, sig);
867         complete_signal(sig, t, group);
868         return 0;
869 }
870
871 int print_fatal_signals;
872
873 static void print_fatal_signal(struct pt_regs *regs, int signr)
874 {
875         printk("%s/%d: potentially unexpected fatal signal %d.\n",
876                 current->comm, task_pid_nr(current), signr);
877
878 #if defined(__i386__) && !defined(__arch_um__)
879         printk("code at %08lx: ", regs->ip);
880         {
881                 int i;
882                 for (i = 0; i < 16; i++) {
883                         unsigned char insn;
884
885                         __get_user(insn, (unsigned char *)(regs->ip + i));
886                         printk("%02x ", insn);
887                 }
888         }
889 #endif
890         printk("\n");
891         show_regs(regs);
892 }
893
894 static int __init setup_print_fatal_signals(char *str)
895 {
896         get_option (&str, &print_fatal_signals);
897
898         return 1;
899 }
900
901 __setup("print-fatal-signals=", setup_print_fatal_signals);
902
903 int
904 __group_send_sig_info(int sig, struct siginfo *info, struct task_struct *p)
905 {
906         return send_signal(sig, info, p, 1);
907 }
908
909 static int
910 specific_send_sig_info(int sig, struct siginfo *info, struct task_struct *t)
911 {
912         return send_signal(sig, info, t, 0);
913 }
914
915 /*
916  * Force a signal that the process can't ignore: if necessary
917  * we unblock the signal and change any SIG_IGN to SIG_DFL.
918  *
919  * Note: If we unblock the signal, we always reset it to SIG_DFL,
920  * since we do not want to have a signal handler that was blocked
921  * be invoked when user space had explicitly blocked it.
922  *
923  * We don't want to have recursive SIGSEGV's etc, for example,
924  * that is why we also clear SIGNAL_UNKILLABLE.
925  */
926 int
927 force_sig_info(int sig, struct siginfo *info, struct task_struct *t)
928 {
929         unsigned long int flags;
930         int ret, blocked, ignored;
931         struct k_sigaction *action;
932
933         spin_lock_irqsave(&t->sighand->siglock, flags);
934         action = &t->sighand->action[sig-1];
935         ignored = action->sa.sa_handler == SIG_IGN;
936         blocked = sigismember(&t->blocked, sig);
937         if (blocked || ignored) {
938                 action->sa.sa_handler = SIG_DFL;
939                 if (blocked) {
940                         sigdelset(&t->blocked, sig);
941                         recalc_sigpending_and_wake(t);
942                 }
943         }
944         if (action->sa.sa_handler == SIG_DFL)
945                 t->signal->flags &= ~SIGNAL_UNKILLABLE;
946         ret = specific_send_sig_info(sig, info, t);
947         spin_unlock_irqrestore(&t->sighand->siglock, flags);
948
949         return ret;
950 }
951
952 void
953 force_sig_specific(int sig, struct task_struct *t)
954 {
955         force_sig_info(sig, SEND_SIG_FORCED, t);
956 }
957
958 /*
959  * Nuke all other threads in the group.
960  */
961 void zap_other_threads(struct task_struct *p)
962 {
963         struct task_struct *t;
964
965         p->signal->group_stop_count = 0;
966
967         for (t = next_thread(p); t != p; t = next_thread(t)) {
968                 /*
969                  * Don't bother with already dead threads
970                  */
971                 if (t->exit_state)
972                         continue;
973
974                 /* SIGKILL will be handled before any pending SIGSTOP */
975                 sigaddset(&t->pending.signal, SIGKILL);
976                 signal_wake_up(t, 1);
977         }
978 }
979
980 int __fatal_signal_pending(struct task_struct *tsk)
981 {
982         return sigismember(&tsk->pending.signal, SIGKILL);
983 }
984 EXPORT_SYMBOL(__fatal_signal_pending);
985
986 struct sighand_struct *lock_task_sighand(struct task_struct *tsk, unsigned long *flags)
987 {
988         struct sighand_struct *sighand;
989
990         rcu_read_lock();
991         for (;;) {
992                 sighand = rcu_dereference(tsk->sighand);
993                 if (unlikely(sighand == NULL))
994                         break;
995
996                 spin_lock_irqsave(&sighand->siglock, *flags);
997                 if (likely(sighand == tsk->sighand))
998                         break;
999                 spin_unlock_irqrestore(&sighand->siglock, *flags);
1000         }
1001         rcu_read_unlock();
1002
1003         return sighand;
1004 }
1005
1006 int group_send_sig_info(int sig, struct siginfo *info, struct task_struct *p)
1007 {
1008         unsigned long flags;
1009         int ret;
1010
1011         ret = check_kill_permission(sig, info, p);
1012
1013         if (!ret && sig) {
1014                 ret = -ESRCH;
1015                 if (lock_task_sighand(p, &flags)) {
1016                         ret = __group_send_sig_info(sig, info, p);
1017                         unlock_task_sighand(p, &flags);
1018                 }
1019         }
1020
1021         return ret;
1022 }
1023
1024 /*
1025  * __kill_pgrp_info() sends a signal to a process group: this is what the tty
1026  * control characters do (^C, ^Z etc)
1027  */
1028
1029 int __kill_pgrp_info(int sig, struct siginfo *info, struct pid *pgrp)
1030 {
1031         struct task_struct *p = NULL;
1032         int retval, success;
1033
1034         success = 0;
1035         retval = -ESRCH;
1036         do_each_pid_task(pgrp, PIDTYPE_PGID, p) {
1037                 int err = group_send_sig_info(sig, info, p);
1038                 success |= !err;
1039                 retval = err;
1040         } while_each_pid_task(pgrp, PIDTYPE_PGID, p);
1041         return success ? 0 : retval;
1042 }
1043
1044 int kill_pid_info(int sig, struct siginfo *info, struct pid *pid)
1045 {
1046         int error = -ESRCH;
1047         struct task_struct *p;
1048
1049         rcu_read_lock();
1050 retry:
1051         p = pid_task(pid, PIDTYPE_PID);
1052         if (p) {
1053                 error = group_send_sig_info(sig, info, p);
1054                 if (unlikely(error == -ESRCH))
1055                         /*
1056                          * The task was unhashed in between, try again.
1057                          * If it is dead, pid_task() will return NULL,
1058                          * if we race with de_thread() it will find the
1059                          * new leader.
1060                          */
1061                         goto retry;
1062         }
1063         rcu_read_unlock();
1064
1065         return error;
1066 }
1067
1068 int
1069 kill_proc_info(int sig, struct siginfo *info, pid_t pid)
1070 {
1071         int error;
1072         rcu_read_lock();
1073         error = kill_pid_info(sig, info, find_vpid(pid));
1074         rcu_read_unlock();
1075         return error;
1076 }
1077
1078 /* like kill_pid_info(), but doesn't use uid/euid of "current" */
1079 int kill_pid_info_as_uid(int sig, struct siginfo *info, struct pid *pid,
1080                       uid_t uid, uid_t euid, u32 secid)
1081 {
1082         int ret = -EINVAL;
1083         struct task_struct *p;
1084
1085         if (!valid_signal(sig))
1086                 return ret;
1087
1088         read_lock(&tasklist_lock);
1089         p = pid_task(pid, PIDTYPE_PID);
1090         if (!p) {
1091                 ret = -ESRCH;
1092                 goto out_unlock;
1093         }
1094         if ((info == SEND_SIG_NOINFO || (!is_si_special(info) && SI_FROMUSER(info)))
1095             && (euid != p->suid) && (euid != p->uid)
1096             && (uid != p->suid) && (uid != p->uid)) {
1097                 ret = -EPERM;
1098                 goto out_unlock;
1099         }
1100         ret = security_task_kill(p, info, sig, secid);
1101         if (ret)
1102                 goto out_unlock;
1103         if (sig && p->sighand) {
1104                 unsigned long flags;
1105                 spin_lock_irqsave(&p->sighand->siglock, flags);
1106                 ret = __group_send_sig_info(sig, info, p);
1107                 spin_unlock_irqrestore(&p->sighand->siglock, flags);
1108         }
1109 out_unlock:
1110         read_unlock(&tasklist_lock);
1111         return ret;
1112 }
1113 EXPORT_SYMBOL_GPL(kill_pid_info_as_uid);
1114
1115 /*
1116  * kill_something_info() interprets pid in interesting ways just like kill(2).
1117  *
1118  * POSIX specifies that kill(-1,sig) is unspecified, but what we have
1119  * is probably wrong.  Should make it like BSD or SYSV.
1120  */
1121
1122 static int kill_something_info(int sig, struct siginfo *info, pid_t pid)
1123 {
1124         int ret;
1125
1126         if (pid > 0) {
1127                 rcu_read_lock();
1128                 ret = kill_pid_info(sig, info, find_vpid(pid));
1129                 rcu_read_unlock();
1130                 return ret;
1131         }
1132
1133         read_lock(&tasklist_lock);
1134         if (pid != -1) {
1135                 ret = __kill_pgrp_info(sig, info,
1136                                 pid ? find_vpid(-pid) : task_pgrp(current));
1137         } else {
1138                 int retval = 0, count = 0;
1139                 struct task_struct * p;
1140
1141                 for_each_process(p) {
1142                         if (p->pid > 1 && !same_thread_group(p, current)) {
1143                                 int err = group_send_sig_info(sig, info, p);
1144                                 ++count;
1145                                 if (err != -EPERM)
1146                                         retval = err;
1147                         }
1148                 }
1149                 ret = count ? retval : -ESRCH;
1150         }
1151         read_unlock(&tasklist_lock);
1152
1153         return ret;
1154 }
1155
1156 /*
1157  * These are for backward compatibility with the rest of the kernel source.
1158  */
1159
1160 /*
1161  * The caller must ensure the task can't exit.
1162  */
1163 int
1164 send_sig_info(int sig, struct siginfo *info, struct task_struct *p)
1165 {
1166         int ret;
1167         unsigned long flags;
1168
1169         /*
1170          * Make sure legacy kernel users don't send in bad values
1171          * (normal paths check this in check_kill_permission).
1172          */
1173         if (!valid_signal(sig))
1174                 return -EINVAL;
1175
1176         spin_lock_irqsave(&p->sighand->siglock, flags);
1177         ret = specific_send_sig_info(sig, info, p);
1178         spin_unlock_irqrestore(&p->sighand->siglock, flags);
1179         return ret;
1180 }
1181
1182 #define __si_special(priv) \
1183         ((priv) ? SEND_SIG_PRIV : SEND_SIG_NOINFO)
1184
1185 int
1186 send_sig(int sig, struct task_struct *p, int priv)
1187 {
1188         return send_sig_info(sig, __si_special(priv), p);
1189 }
1190
1191 void
1192 force_sig(int sig, struct task_struct *p)
1193 {
1194         force_sig_info(sig, SEND_SIG_PRIV, p);
1195 }
1196
1197 /*
1198  * When things go south during signal handling, we
1199  * will force a SIGSEGV. And if the signal that caused
1200  * the problem was already a SIGSEGV, we'll want to
1201  * make sure we don't even try to deliver the signal..
1202  */
1203 int
1204 force_sigsegv(int sig, struct task_struct *p)
1205 {
1206         if (sig == SIGSEGV) {
1207                 unsigned long flags;
1208                 spin_lock_irqsave(&p->sighand->siglock, flags);
1209                 p->sighand->action[sig - 1].sa.sa_handler = SIG_DFL;
1210                 spin_unlock_irqrestore(&p->sighand->siglock, flags);
1211         }
1212         force_sig(SIGSEGV, p);
1213         return 0;
1214 }
1215
1216 int kill_pgrp(struct pid *pid, int sig, int priv)
1217 {
1218         int ret;
1219
1220         read_lock(&tasklist_lock);
1221         ret = __kill_pgrp_info(sig, __si_special(priv), pid);
1222         read_unlock(&tasklist_lock);
1223
1224         return ret;
1225 }
1226 EXPORT_SYMBOL(kill_pgrp);
1227
1228 int kill_pid(struct pid *pid, int sig, int priv)
1229 {
1230         return kill_pid_info(sig, __si_special(priv), pid);
1231 }
1232 EXPORT_SYMBOL(kill_pid);
1233
1234 /*
1235  * These functions support sending signals using preallocated sigqueue
1236  * structures.  This is needed "because realtime applications cannot
1237  * afford to lose notifications of asynchronous events, like timer
1238  * expirations or I/O completions".  In the case of Posix Timers 
1239  * we allocate the sigqueue structure from the timer_create.  If this
1240  * allocation fails we are able to report the failure to the application
1241  * with an EAGAIN error.
1242  */
1243  
1244 struct sigqueue *sigqueue_alloc(void)
1245 {
1246         struct sigqueue *q;
1247
1248         if ((q = __sigqueue_alloc(current, GFP_KERNEL, 0)))
1249                 q->flags |= SIGQUEUE_PREALLOC;
1250         return(q);
1251 }
1252
1253 void sigqueue_free(struct sigqueue *q)
1254 {
1255         unsigned long flags;
1256         spinlock_t *lock = &current->sighand->siglock;
1257
1258         BUG_ON(!(q->flags & SIGQUEUE_PREALLOC));
1259         /*
1260          * We must hold ->siglock while testing q->list
1261          * to serialize with collect_signal() or with
1262          * __exit_signal()->flush_sigqueue().
1263          */
1264         spin_lock_irqsave(lock, flags);
1265         q->flags &= ~SIGQUEUE_PREALLOC;
1266         /*
1267          * If it is queued it will be freed when dequeued,
1268          * like the "regular" sigqueue.
1269          */
1270         if (!list_empty(&q->list))
1271                 q = NULL;
1272         spin_unlock_irqrestore(lock, flags);
1273
1274         if (q)
1275                 __sigqueue_free(q);
1276 }
1277
1278 int send_sigqueue(struct sigqueue *q, struct task_struct *t, int group)
1279 {
1280         int sig = q->info.si_signo;
1281         struct sigpending *pending;
1282         unsigned long flags;
1283         int ret;
1284
1285         BUG_ON(!(q->flags & SIGQUEUE_PREALLOC));
1286
1287         ret = -1;
1288         if (!likely(lock_task_sighand(t, &flags)))
1289                 goto ret;
1290
1291         ret = 1; /* the signal is ignored */
1292         if (!prepare_signal(sig, t))
1293                 goto out;
1294
1295         ret = 0;
1296         if (unlikely(!list_empty(&q->list))) {
1297                 /*
1298                  * If an SI_TIMER entry is already queue just increment
1299                  * the overrun count.
1300                  */
1301                 BUG_ON(q->info.si_code != SI_TIMER);
1302                 q->info.si_overrun++;
1303                 goto out;
1304         }
1305
1306         signalfd_notify(t, sig);
1307         pending = group ? &t->signal->shared_pending : &t->pending;
1308         list_add_tail(&q->list, &pending->list);
1309         sigaddset(&pending->signal, sig);
1310         complete_signal(sig, t, group);
1311 out:
1312         unlock_task_sighand(t, &flags);
1313 ret:
1314         return ret;
1315 }
1316
1317 /*
1318  * Wake up any threads in the parent blocked in wait* syscalls.
1319  */
1320 static inline void __wake_up_parent(struct task_struct *p,
1321                                     struct task_struct *parent)
1322 {
1323         wake_up_interruptible_sync(&parent->signal->wait_chldexit);
1324 }
1325
1326 /*
1327  * Let a parent know about the death of a child.
1328  * For a stopped/continued status change, use do_notify_parent_cldstop instead.
1329  */
1330
1331 void do_notify_parent(struct task_struct *tsk, int sig)
1332 {
1333         struct siginfo info;
1334         unsigned long flags;
1335         struct sighand_struct *psig;
1336
1337         BUG_ON(sig == -1);
1338
1339         /* do_notify_parent_cldstop should have been called instead.  */
1340         BUG_ON(task_is_stopped_or_traced(tsk));
1341
1342         BUG_ON(!tsk->ptrace &&
1343                (tsk->group_leader != tsk || !thread_group_empty(tsk)));
1344
1345         info.si_signo = sig;
1346         info.si_errno = 0;
1347         /*
1348          * we are under tasklist_lock here so our parent is tied to
1349          * us and cannot exit and release its namespace.
1350          *
1351          * the only it can is to switch its nsproxy with sys_unshare,
1352          * bu uncharing pid namespaces is not allowed, so we'll always
1353          * see relevant namespace
1354          *
1355          * write_lock() currently calls preempt_disable() which is the
1356          * same as rcu_read_lock(), but according to Oleg, this is not
1357          * correct to rely on this
1358          */
1359         rcu_read_lock();
1360         info.si_pid = task_pid_nr_ns(tsk, tsk->parent->nsproxy->pid_ns);
1361         rcu_read_unlock();
1362
1363         info.si_uid = tsk->uid;
1364
1365         info.si_utime = cputime_to_clock_t(cputime_add(tsk->utime,
1366                                                        tsk->signal->utime));
1367         info.si_stime = cputime_to_clock_t(cputime_add(tsk->stime,
1368                                                        tsk->signal->stime));
1369
1370         info.si_status = tsk->exit_code & 0x7f;
1371         if (tsk->exit_code & 0x80)
1372                 info.si_code = CLD_DUMPED;
1373         else if (tsk->exit_code & 0x7f)
1374                 info.si_code = CLD_KILLED;
1375         else {
1376                 info.si_code = CLD_EXITED;
1377                 info.si_status = tsk->exit_code >> 8;
1378         }
1379
1380         psig = tsk->parent->sighand;
1381         spin_lock_irqsave(&psig->siglock, flags);
1382         if (!tsk->ptrace && sig == SIGCHLD &&
1383             (psig->action[SIGCHLD-1].sa.sa_handler == SIG_IGN ||
1384              (psig->action[SIGCHLD-1].sa.sa_flags & SA_NOCLDWAIT))) {
1385                 /*
1386                  * We are exiting and our parent doesn't care.  POSIX.1
1387                  * defines special semantics for setting SIGCHLD to SIG_IGN
1388                  * or setting the SA_NOCLDWAIT flag: we should be reaped
1389                  * automatically and not left for our parent's wait4 call.
1390                  * Rather than having the parent do it as a magic kind of
1391                  * signal handler, we just set this to tell do_exit that we
1392                  * can be cleaned up without becoming a zombie.  Note that
1393                  * we still call __wake_up_parent in this case, because a
1394                  * blocked sys_wait4 might now return -ECHILD.
1395                  *
1396                  * Whether we send SIGCHLD or not for SA_NOCLDWAIT
1397                  * is implementation-defined: we do (if you don't want
1398                  * it, just use SIG_IGN instead).
1399                  */
1400                 tsk->exit_signal = -1;
1401                 if (psig->action[SIGCHLD-1].sa.sa_handler == SIG_IGN)
1402                         sig = 0;
1403         }
1404         if (valid_signal(sig) && sig > 0)
1405                 __group_send_sig_info(sig, &info, tsk->parent);
1406         __wake_up_parent(tsk, tsk->parent);
1407         spin_unlock_irqrestore(&psig->siglock, flags);
1408 }
1409
1410 static void do_notify_parent_cldstop(struct task_struct *tsk, int why)
1411 {
1412         struct siginfo info;
1413         unsigned long flags;
1414         struct task_struct *parent;
1415         struct sighand_struct *sighand;
1416
1417         if (tsk->ptrace & PT_PTRACED)
1418                 parent = tsk->parent;
1419         else {
1420                 tsk = tsk->group_leader;
1421                 parent = tsk->real_parent;
1422         }
1423
1424         info.si_signo = SIGCHLD;
1425         info.si_errno = 0;
1426         /*
1427          * see comment in do_notify_parent() abot the following 3 lines
1428          */
1429         rcu_read_lock();
1430         info.si_pid = task_pid_nr_ns(tsk, tsk->parent->nsproxy->pid_ns);
1431         rcu_read_unlock();
1432
1433         info.si_uid = tsk->uid;
1434
1435         info.si_utime = cputime_to_clock_t(tsk->utime);
1436         info.si_stime = cputime_to_clock_t(tsk->stime);
1437
1438         info.si_code = why;
1439         switch (why) {
1440         case CLD_CONTINUED:
1441                 info.si_status = SIGCONT;
1442                 break;
1443         case CLD_STOPPED:
1444                 info.si_status = tsk->signal->group_exit_code & 0x7f;
1445                 break;
1446         case CLD_TRAPPED:
1447                 info.si_status = tsk->exit_code & 0x7f;
1448                 break;
1449         default:
1450                 BUG();
1451         }
1452
1453         sighand = parent->sighand;
1454         spin_lock_irqsave(&sighand->siglock, flags);
1455         if (sighand->action[SIGCHLD-1].sa.sa_handler != SIG_IGN &&
1456             !(sighand->action[SIGCHLD-1].sa.sa_flags & SA_NOCLDSTOP))
1457                 __group_send_sig_info(SIGCHLD, &info, parent);
1458         /*
1459          * Even if SIGCHLD is not generated, we must wake up wait4 calls.
1460          */
1461         __wake_up_parent(tsk, parent);
1462         spin_unlock_irqrestore(&sighand->siglock, flags);
1463 }
1464
1465 static inline int may_ptrace_stop(void)
1466 {
1467         if (!likely(current->ptrace & PT_PTRACED))
1468                 return 0;
1469         /*
1470          * Are we in the middle of do_coredump?
1471          * If so and our tracer is also part of the coredump stopping
1472          * is a deadlock situation, and pointless because our tracer
1473          * is dead so don't allow us to stop.
1474          * If SIGKILL was already sent before the caller unlocked
1475          * ->siglock we must see ->core_state != NULL. Otherwise it
1476          * is safe to enter schedule().
1477          */
1478         if (unlikely(current->mm->core_state) &&
1479             unlikely(current->mm == current->parent->mm))
1480                 return 0;
1481
1482         return 1;
1483 }
1484
1485 /*
1486  * Return nonzero if there is a SIGKILL that should be waking us up.
1487  * Called with the siglock held.
1488  */
1489 static int sigkill_pending(struct task_struct *tsk)
1490 {
1491         return  sigismember(&tsk->pending.signal, SIGKILL) ||
1492                 sigismember(&tsk->signal->shared_pending.signal, SIGKILL);
1493 }
1494
1495 /*
1496  * This must be called with current->sighand->siglock held.
1497  *
1498  * This should be the path for all ptrace stops.
1499  * We always set current->last_siginfo while stopped here.
1500  * That makes it a way to test a stopped process for
1501  * being ptrace-stopped vs being job-control-stopped.
1502  *
1503  * If we actually decide not to stop at all because the tracer
1504  * is gone, we keep current->exit_code unless clear_code.
1505  */
1506 static void ptrace_stop(int exit_code, int clear_code, siginfo_t *info)
1507 {
1508         if (arch_ptrace_stop_needed(exit_code, info)) {
1509                 /*
1510                  * The arch code has something special to do before a
1511                  * ptrace stop.  This is allowed to block, e.g. for faults
1512                  * on user stack pages.  We can't keep the siglock while
1513                  * calling arch_ptrace_stop, so we must release it now.
1514                  * To preserve proper semantics, we must do this before
1515                  * any signal bookkeeping like checking group_stop_count.
1516                  * Meanwhile, a SIGKILL could come in before we retake the
1517                  * siglock.  That must prevent us from sleeping in TASK_TRACED.
1518                  * So after regaining the lock, we must check for SIGKILL.
1519                  */
1520                 spin_unlock_irq(&current->sighand->siglock);
1521                 arch_ptrace_stop(exit_code, info);
1522                 spin_lock_irq(&current->sighand->siglock);
1523                 if (sigkill_pending(current))
1524                         return;
1525         }
1526
1527         /*
1528          * If there is a group stop in progress,
1529          * we must participate in the bookkeeping.
1530          */
1531         if (current->signal->group_stop_count > 0)
1532                 --current->signal->group_stop_count;
1533
1534         current->last_siginfo = info;
1535         current->exit_code = exit_code;
1536
1537         /* Let the debugger run.  */
1538         __set_current_state(TASK_TRACED);
1539         spin_unlock_irq(&current->sighand->siglock);
1540         read_lock(&tasklist_lock);
1541         if (may_ptrace_stop()) {
1542                 do_notify_parent_cldstop(current, CLD_TRAPPED);
1543                 read_unlock(&tasklist_lock);
1544                 schedule();
1545         } else {
1546                 /*
1547                  * By the time we got the lock, our tracer went away.
1548                  * Don't drop the lock yet, another tracer may come.
1549                  */
1550                 __set_current_state(TASK_RUNNING);
1551                 if (clear_code)
1552                         current->exit_code = 0;
1553                 read_unlock(&tasklist_lock);
1554         }
1555
1556         /*
1557          * While in TASK_TRACED, we were considered "frozen enough".
1558          * Now that we woke up, it's crucial if we're supposed to be
1559          * frozen that we freeze now before running anything substantial.
1560          */
1561         try_to_freeze();
1562
1563         /*
1564          * We are back.  Now reacquire the siglock before touching
1565          * last_siginfo, so that we are sure to have synchronized with
1566          * any signal-sending on another CPU that wants to examine it.
1567          */
1568         spin_lock_irq(&current->sighand->siglock);
1569         current->last_siginfo = NULL;
1570
1571         /*
1572          * Queued signals ignored us while we were stopped for tracing.
1573          * So check for any that we should take before resuming user mode.
1574          * This sets TIF_SIGPENDING, but never clears it.
1575          */
1576         recalc_sigpending_tsk(current);
1577 }
1578
1579 void ptrace_notify(int exit_code)
1580 {
1581         siginfo_t info;
1582
1583         BUG_ON((exit_code & (0x7f | ~0xffff)) != SIGTRAP);
1584
1585         memset(&info, 0, sizeof info);
1586         info.si_signo = SIGTRAP;
1587         info.si_code = exit_code;
1588         info.si_pid = task_pid_vnr(current);
1589         info.si_uid = current->uid;
1590
1591         /* Let the debugger run.  */
1592         spin_lock_irq(&current->sighand->siglock);
1593         ptrace_stop(exit_code, 1, &info);
1594         spin_unlock_irq(&current->sighand->siglock);
1595 }
1596
1597 static void
1598 finish_stop(int stop_count)
1599 {
1600         /*
1601          * If there are no other threads in the group, or if there is
1602          * a group stop in progress and we are the last to stop,
1603          * report to the parent.  When ptraced, every thread reports itself.
1604          */
1605         if (tracehook_notify_jctl(stop_count == 0, CLD_STOPPED)) {
1606                 read_lock(&tasklist_lock);
1607                 do_notify_parent_cldstop(current, CLD_STOPPED);
1608                 read_unlock(&tasklist_lock);
1609         }
1610
1611         do {
1612                 schedule();
1613         } while (try_to_freeze());
1614         /*
1615          * Now we don't run again until continued.
1616          */
1617         current->exit_code = 0;
1618 }
1619
1620 /*
1621  * This performs the stopping for SIGSTOP and other stop signals.
1622  * We have to stop all threads in the thread group.
1623  * Returns nonzero if we've actually stopped and released the siglock.
1624  * Returns zero if we didn't stop and still hold the siglock.
1625  */
1626 static int do_signal_stop(int signr)
1627 {
1628         struct signal_struct *sig = current->signal;
1629         int stop_count;
1630
1631         if (sig->group_stop_count > 0) {
1632                 /*
1633                  * There is a group stop in progress.  We don't need to
1634                  * start another one.
1635                  */
1636                 stop_count = --sig->group_stop_count;
1637         } else {
1638                 struct task_struct *t;
1639
1640                 if (!likely(sig->flags & SIGNAL_STOP_DEQUEUED) ||
1641                     unlikely(signal_group_exit(sig)))
1642                         return 0;
1643                 /*
1644                  * There is no group stop already in progress.
1645                  * We must initiate one now.
1646                  */
1647                 sig->group_exit_code = signr;
1648
1649                 stop_count = 0;
1650                 for (t = next_thread(current); t != current; t = next_thread(t))
1651                         /*
1652                          * Setting state to TASK_STOPPED for a group
1653                          * stop is always done with the siglock held,
1654                          * so this check has no races.
1655                          */
1656                         if (!(t->flags & PF_EXITING) &&
1657                             !task_is_stopped_or_traced(t)) {
1658                                 stop_count++;
1659                                 signal_wake_up(t, 0);
1660                         }
1661                 sig->group_stop_count = stop_count;
1662         }
1663
1664         if (stop_count == 0)
1665                 sig->flags = SIGNAL_STOP_STOPPED;
1666         current->exit_code = sig->group_exit_code;
1667         __set_current_state(TASK_STOPPED);
1668
1669         spin_unlock_irq(&current->sighand->siglock);
1670         finish_stop(stop_count);
1671         return 1;
1672 }
1673
1674 static int ptrace_signal(int signr, siginfo_t *info,
1675                          struct pt_regs *regs, void *cookie)
1676 {
1677         if (!(current->ptrace & PT_PTRACED))
1678                 return signr;
1679
1680         ptrace_signal_deliver(regs, cookie);
1681
1682         /* Let the debugger run.  */
1683         ptrace_stop(signr, 0, info);
1684
1685         /* We're back.  Did the debugger cancel the sig?  */
1686         signr = current->exit_code;
1687         if (signr == 0)
1688                 return signr;
1689
1690         current->exit_code = 0;
1691
1692         /* Update the siginfo structure if the signal has
1693            changed.  If the debugger wanted something
1694            specific in the siginfo structure then it should
1695            have updated *info via PTRACE_SETSIGINFO.  */
1696         if (signr != info->si_signo) {
1697                 info->si_signo = signr;
1698                 info->si_errno = 0;
1699                 info->si_code = SI_USER;
1700                 info->si_pid = task_pid_vnr(current->parent);
1701                 info->si_uid = current->parent->uid;
1702         }
1703
1704         /* If the (new) signal is now blocked, requeue it.  */
1705         if (sigismember(&current->blocked, signr)) {
1706                 specific_send_sig_info(signr, info, current);
1707                 signr = 0;
1708         }
1709
1710         return signr;
1711 }
1712
1713 int get_signal_to_deliver(siginfo_t *info, struct k_sigaction *return_ka,
1714                           struct pt_regs *regs, void *cookie)
1715 {
1716         struct sighand_struct *sighand = current->sighand;
1717         struct signal_struct *signal = current->signal;
1718         int signr;
1719
1720 relock:
1721         /*
1722          * We'll jump back here after any time we were stopped in TASK_STOPPED.
1723          * While in TASK_STOPPED, we were considered "frozen enough".
1724          * Now that we woke up, it's crucial if we're supposed to be
1725          * frozen that we freeze now before running anything substantial.
1726          */
1727         try_to_freeze();
1728
1729         spin_lock_irq(&sighand->siglock);
1730         /*
1731          * Every stopped thread goes here after wakeup. Check to see if
1732          * we should notify the parent, prepare_signal(SIGCONT) encodes
1733          * the CLD_ si_code into SIGNAL_CLD_MASK bits.
1734          */
1735         if (unlikely(signal->flags & SIGNAL_CLD_MASK)) {
1736                 int why = (signal->flags & SIGNAL_STOP_CONTINUED)
1737                                 ? CLD_CONTINUED : CLD_STOPPED;
1738                 signal->flags &= ~SIGNAL_CLD_MASK;
1739                 spin_unlock_irq(&sighand->siglock);
1740
1741                 if (unlikely(!tracehook_notify_jctl(1, why)))
1742                         goto relock;
1743
1744                 read_lock(&tasklist_lock);
1745                 do_notify_parent_cldstop(current->group_leader, why);
1746                 read_unlock(&tasklist_lock);
1747                 goto relock;
1748         }
1749
1750         for (;;) {
1751                 struct k_sigaction *ka;
1752
1753                 if (unlikely(signal->group_stop_count > 0) &&
1754                     do_signal_stop(0))
1755                         goto relock;
1756
1757                 /*
1758                  * Tracing can induce an artifical signal and choose sigaction.
1759                  * The return value in @signr determines the default action,
1760                  * but @info->si_signo is the signal number we will report.
1761                  */
1762                 signr = tracehook_get_signal(current, regs, info, return_ka);
1763                 if (unlikely(signr < 0))
1764                         goto relock;
1765                 if (unlikely(signr != 0))
1766                         ka = return_ka;
1767                 else {
1768                         signr = dequeue_signal(current, &current->blocked,
1769                                                info);
1770
1771                         if (!signr)
1772                                 break; /* will return 0 */
1773
1774                         if (signr != SIGKILL) {
1775                                 signr = ptrace_signal(signr, info,
1776                                                       regs, cookie);
1777                                 if (!signr)
1778                                         continue;
1779                         }
1780
1781                         ka = &sighand->action[signr-1];
1782                 }
1783
1784                 if (ka->sa.sa_handler == SIG_IGN) /* Do nothing.  */
1785                         continue;
1786                 if (ka->sa.sa_handler != SIG_DFL) {
1787                         /* Run the handler.  */
1788                         *return_ka = *ka;
1789
1790                         if (ka->sa.sa_flags & SA_ONESHOT)
1791                                 ka->sa.sa_handler = SIG_DFL;
1792
1793                         break; /* will return non-zero "signr" value */
1794                 }
1795
1796                 /*
1797                  * Now we are doing the default action for this signal.
1798                  */
1799                 if (sig_kernel_ignore(signr)) /* Default is nothing. */
1800                         continue;
1801
1802                 /*
1803                  * Global init gets no signals it doesn't want.
1804                  */
1805                 if (unlikely(signal->flags & SIGNAL_UNKILLABLE) &&
1806                     !signal_group_exit(signal))
1807                         continue;
1808
1809                 if (sig_kernel_stop(signr)) {
1810                         /*
1811                          * The default action is to stop all threads in
1812                          * the thread group.  The job control signals
1813                          * do nothing in an orphaned pgrp, but SIGSTOP
1814                          * always works.  Note that siglock needs to be
1815                          * dropped during the call to is_orphaned_pgrp()
1816                          * because of lock ordering with tasklist_lock.
1817                          * This allows an intervening SIGCONT to be posted.
1818                          * We need to check for that and bail out if necessary.
1819                          */
1820                         if (signr != SIGSTOP) {
1821                                 spin_unlock_irq(&sighand->siglock);
1822
1823                                 /* signals can be posted during this window */
1824
1825                                 if (is_current_pgrp_orphaned())
1826                                         goto relock;
1827
1828                                 spin_lock_irq(&sighand->siglock);
1829                         }
1830
1831                         if (likely(do_signal_stop(info->si_signo))) {
1832                                 /* It released the siglock.  */
1833                                 goto relock;
1834                         }
1835
1836                         /*
1837                          * We didn't actually stop, due to a race
1838                          * with SIGCONT or something like that.
1839                          */
1840                         continue;
1841                 }
1842
1843                 spin_unlock_irq(&sighand->siglock);
1844
1845                 /*
1846                  * Anything else is fatal, maybe with a core dump.
1847                  */
1848                 current->flags |= PF_SIGNALED;
1849
1850                 if (sig_kernel_coredump(signr)) {
1851                         if (print_fatal_signals)
1852                                 print_fatal_signal(regs, info->si_signo);
1853                         /*
1854                          * If it was able to dump core, this kills all
1855                          * other threads in the group and synchronizes with
1856                          * their demise.  If we lost the race with another
1857                          * thread getting here, it set group_exit_code
1858                          * first and our do_group_exit call below will use
1859                          * that value and ignore the one we pass it.
1860                          */
1861                         do_coredump(info->si_signo, info->si_signo, regs);
1862                 }
1863
1864                 /*
1865                  * Death signals, no core dump.
1866                  */
1867                 do_group_exit(info->si_signo);
1868                 /* NOTREACHED */
1869         }
1870         spin_unlock_irq(&sighand->siglock);
1871         return signr;
1872 }
1873
1874 void exit_signals(struct task_struct *tsk)
1875 {
1876         int group_stop = 0;
1877         struct task_struct *t;
1878
1879         if (thread_group_empty(tsk) || signal_group_exit(tsk->signal)) {
1880                 tsk->flags |= PF_EXITING;
1881                 return;
1882         }
1883
1884         spin_lock_irq(&tsk->sighand->siglock);
1885         /*
1886          * From now this task is not visible for group-wide signals,
1887          * see wants_signal(), do_signal_stop().
1888          */
1889         tsk->flags |= PF_EXITING;
1890         if (!signal_pending(tsk))
1891                 goto out;
1892
1893         /* It could be that __group_complete_signal() choose us to
1894          * notify about group-wide signal. Another thread should be
1895          * woken now to take the signal since we will not.
1896          */
1897         for (t = tsk; (t = next_thread(t)) != tsk; )
1898                 if (!signal_pending(t) && !(t->flags & PF_EXITING))
1899                         recalc_sigpending_and_wake(t);
1900
1901         if (unlikely(tsk->signal->group_stop_count) &&
1902                         !--tsk->signal->group_stop_count) {
1903                 tsk->signal->flags = SIGNAL_STOP_STOPPED;
1904                 group_stop = 1;
1905         }
1906 out:
1907         spin_unlock_irq(&tsk->sighand->siglock);
1908
1909         if (unlikely(group_stop) && tracehook_notify_jctl(1, CLD_STOPPED)) {
1910                 read_lock(&tasklist_lock);
1911                 do_notify_parent_cldstop(tsk, CLD_STOPPED);
1912                 read_unlock(&tasklist_lock);
1913         }
1914 }
1915
1916 EXPORT_SYMBOL(recalc_sigpending);
1917 EXPORT_SYMBOL_GPL(dequeue_signal);
1918 EXPORT_SYMBOL(flush_signals);
1919 EXPORT_SYMBOL(force_sig);
1920 EXPORT_SYMBOL(send_sig);
1921 EXPORT_SYMBOL(send_sig_info);
1922 EXPORT_SYMBOL(sigprocmask);
1923 EXPORT_SYMBOL(block_all_signals);
1924 EXPORT_SYMBOL(unblock_all_signals);
1925
1926
1927 /*
1928  * System call entry points.
1929  */
1930
1931 asmlinkage long sys_restart_syscall(void)
1932 {
1933         struct restart_block *restart = &current_thread_info()->restart_block;
1934         return restart->fn(restart);
1935 }
1936
1937 long do_no_restart_syscall(struct restart_block *param)
1938 {
1939         return -EINTR;
1940 }
1941
1942 /*
1943  * We don't need to get the kernel lock - this is all local to this
1944  * particular thread.. (and that's good, because this is _heavily_
1945  * used by various programs)
1946  */
1947
1948 /*
1949  * This is also useful for kernel threads that want to temporarily
1950  * (or permanently) block certain signals.
1951  *
1952  * NOTE! Unlike the user-mode sys_sigprocmask(), the kernel
1953  * interface happily blocks "unblockable" signals like SIGKILL
1954  * and friends.
1955  */
1956 int sigprocmask(int how, sigset_t *set, sigset_t *oldset)
1957 {
1958         int error;
1959
1960         spin_lock_irq(&current->sighand->siglock);
1961         if (oldset)
1962                 *oldset = current->blocked;
1963
1964         error = 0;
1965         switch (how) {
1966         case SIG_BLOCK:
1967                 sigorsets(&current->blocked, &current->blocked, set);
1968                 break;
1969         case SIG_UNBLOCK:
1970                 signandsets(&current->blocked, &current->blocked, set);
1971                 break;
1972         case SIG_SETMASK:
1973                 current->blocked = *set;
1974                 break;
1975         default:
1976                 error = -EINVAL;
1977         }
1978         recalc_sigpending();
1979         spin_unlock_irq(&current->sighand->siglock);
1980
1981         return error;
1982 }
1983
1984 asmlinkage long
1985 sys_rt_sigprocmask(int how, sigset_t __user *set, sigset_t __user *oset, size_t sigsetsize)
1986 {
1987         int error = -EINVAL;
1988         sigset_t old_set, new_set;
1989
1990         /* XXX: Don't preclude handling different sized sigset_t's.  */
1991         if (sigsetsize != sizeof(sigset_t))
1992                 goto out;
1993
1994         if (set) {
1995                 error = -EFAULT;
1996                 if (copy_from_user(&new_set, set, sizeof(*set)))
1997                         goto out;
1998                 sigdelsetmask(&new_set, sigmask(SIGKILL)|sigmask(SIGSTOP));
1999
2000                 error = sigprocmask(how, &new_set, &old_set);
2001                 if (error)
2002                         goto out;
2003                 if (oset)
2004                         goto set_old;
2005         } else if (oset) {
2006                 spin_lock_irq(&current->sighand->siglock);
2007                 old_set = current->blocked;
2008                 spin_unlock_irq(&current->sighand->siglock);
2009
2010         set_old:
2011                 error = -EFAULT;
2012                 if (copy_to_user(oset, &old_set, sizeof(*oset)))
2013                         goto out;
2014         }
2015         error = 0;
2016 out:
2017         return error;
2018 }
2019
2020 long do_sigpending(void __user *set, unsigned long sigsetsize)
2021 {
2022         long error = -EINVAL;
2023         sigset_t pending;
2024
2025         if (sigsetsize > sizeof(sigset_t))
2026                 goto out;
2027
2028         spin_lock_irq(&current->sighand->siglock);
2029         sigorsets(&pending, &current->pending.signal,
2030                   &current->signal->shared_pending.signal);
2031         spin_unlock_irq(&current->sighand->siglock);
2032
2033         /* Outside the lock because only this thread touches it.  */
2034         sigandsets(&pending, &current->blocked, &pending);
2035
2036         error = -EFAULT;
2037         if (!copy_to_user(set, &pending, sigsetsize))
2038                 error = 0;
2039
2040 out:
2041         return error;
2042 }       
2043
2044 asmlinkage long
2045 sys_rt_sigpending(sigset_t __user *set, size_t sigsetsize)
2046 {
2047         return do_sigpending(set, sigsetsize);
2048 }
2049
2050 #ifndef HAVE_ARCH_COPY_SIGINFO_TO_USER
2051
2052 int copy_siginfo_to_user(siginfo_t __user *to, siginfo_t *from)
2053 {
2054         int err;
2055
2056         if (!access_ok (VERIFY_WRITE, to, sizeof(siginfo_t)))
2057                 return -EFAULT;
2058         if (from->si_code < 0)
2059                 return __copy_to_user(to, from, sizeof(siginfo_t))
2060                         ? -EFAULT : 0;
2061         /*
2062          * If you change siginfo_t structure, please be sure
2063          * this code is fixed accordingly.
2064          * Please remember to update the signalfd_copyinfo() function
2065          * inside fs/signalfd.c too, in case siginfo_t changes.
2066          * It should never copy any pad contained in the structure
2067          * to avoid security leaks, but must copy the generic
2068          * 3 ints plus the relevant union member.
2069          */
2070         err = __put_user(from->si_signo, &to->si_signo);
2071         err |= __put_user(from->si_errno, &to->si_errno);
2072         err |= __put_user((short)from->si_code, &to->si_code);
2073         switch (from->si_code & __SI_MASK) {
2074         case __SI_KILL:
2075                 err |= __put_user(from->si_pid, &to->si_pid);
2076                 err |= __put_user(from->si_uid, &to->si_uid);
2077                 break;
2078         case __SI_TIMER:
2079                  err |= __put_user(from->si_tid, &to->si_tid);
2080                  err |= __put_user(from->si_overrun, &to->si_overrun);
2081                  err |= __put_user(from->si_ptr, &to->si_ptr);
2082                 break;
2083         case __SI_POLL:
2084                 err |= __put_user(from->si_band, &to->si_band);
2085                 err |= __put_user(from->si_fd, &to->si_fd);
2086                 break;
2087         case __SI_FAULT:
2088                 err |= __put_user(from->si_addr, &to->si_addr);
2089 #ifdef __ARCH_SI_TRAPNO
2090                 err |= __put_user(from->si_trapno, &to->si_trapno);
2091 #endif
2092                 break;
2093         case __SI_CHLD:
2094                 err |= __put_user(from->si_pid, &to->si_pid);
2095                 err |= __put_user(from->si_uid, &to->si_uid);
2096                 err |= __put_user(from->si_status, &to->si_status);
2097                 err |= __put_user(from->si_utime, &to->si_utime);
2098                 err |= __put_user(from->si_stime, &to->si_stime);
2099                 break;
2100         case __SI_RT: /* This is not generated by the kernel as of now. */
2101         case __SI_MESGQ: /* But this is */
2102                 err |= __put_user(from->si_pid, &to->si_pid);
2103                 err |= __put_user(from->si_uid, &to->si_uid);
2104                 err |= __put_user(from->si_ptr, &to->si_ptr);
2105                 break;
2106         default: /* this is just in case for now ... */
2107                 err |= __put_user(from->si_pid, &to->si_pid);
2108                 err |= __put_user(from->si_uid, &to->si_uid);
2109                 break;
2110         }
2111         return err;
2112 }
2113
2114 #endif
2115
2116 asmlinkage long
2117 sys_rt_sigtimedwait(const sigset_t __user *uthese,
2118                     siginfo_t __user *uinfo,
2119                     const struct timespec __user *uts,
2120                     size_t sigsetsize)
2121 {
2122         int ret, sig;
2123         sigset_t these;
2124         struct timespec ts;
2125         siginfo_t info;
2126         long timeout = 0;
2127
2128         /* XXX: Don't preclude handling different sized sigset_t's.  */
2129         if (sigsetsize != sizeof(sigset_t))
2130                 return -EINVAL;
2131
2132         if (copy_from_user(&these, uthese, sizeof(these)))
2133                 return -EFAULT;
2134                 
2135         /*
2136          * Invert the set of allowed signals to get those we
2137          * want to block.
2138          */
2139         sigdelsetmask(&these, sigmask(SIGKILL)|sigmask(SIGSTOP));
2140         signotset(&these);
2141
2142         if (uts) {
2143                 if (copy_from_user(&ts, uts, sizeof(ts)))
2144                         return -EFAULT;
2145                 if (ts.tv_nsec >= 1000000000L || ts.tv_nsec < 0
2146                     || ts.tv_sec < 0)
2147                         return -EINVAL;
2148         }
2149
2150         spin_lock_irq(&current->sighand->siglock);
2151         sig = dequeue_signal(current, &these, &info);
2152         if (!sig) {
2153                 timeout = MAX_SCHEDULE_TIMEOUT;
2154                 if (uts)
2155                         timeout = (timespec_to_jiffies(&ts)
2156                                    + (ts.tv_sec || ts.tv_nsec));
2157
2158                 if (timeout) {
2159                         /* None ready -- temporarily unblock those we're
2160                          * interested while we are sleeping in so that we'll
2161                          * be awakened when they arrive.  */
2162                         current->real_blocked = current->blocked;
2163                         sigandsets(&current->blocked, &current->blocked, &these);
2164                         recalc_sigpending();
2165                         spin_unlock_irq(&current->sighand->siglock);
2166
2167                         timeout = schedule_timeout_interruptible(timeout);
2168
2169                         spin_lock_irq(&current->sighand->siglock);
2170                         sig = dequeue_signal(current, &these, &info);
2171                         current->blocked = current->real_blocked;
2172                         siginitset(&current->real_blocked, 0);
2173                         recalc_sigpending();
2174                 }
2175         }
2176         spin_unlock_irq(&current->sighand->siglock);
2177
2178         if (sig) {
2179                 ret = sig;
2180                 if (uinfo) {
2181                         if (copy_siginfo_to_user(uinfo, &info))
2182                                 ret = -EFAULT;
2183                 }
2184         } else {
2185                 ret = -EAGAIN;
2186                 if (timeout)
2187                         ret = -EINTR;
2188         }
2189
2190         return ret;
2191 }
2192
2193 asmlinkage long
2194 sys_kill(pid_t pid, int sig)
2195 {
2196         struct siginfo info;
2197
2198         info.si_signo = sig;
2199         info.si_errno = 0;
2200         info.si_code = SI_USER;
2201         info.si_pid = task_tgid_vnr(current);
2202         info.si_uid = current->uid;
2203
2204         return kill_something_info(sig, &info, pid);
2205 }
2206
2207 static int do_tkill(pid_t tgid, pid_t pid, int sig)
2208 {
2209         int error;
2210         struct siginfo info;
2211         struct task_struct *p;
2212         unsigned long flags;
2213
2214         error = -ESRCH;
2215         info.si_signo = sig;
2216         info.si_errno = 0;
2217         info.si_code = SI_TKILL;
2218         info.si_pid = task_tgid_vnr(current);
2219         info.si_uid = current->uid;
2220
2221         rcu_read_lock();
2222         p = find_task_by_vpid(pid);
2223         if (p && (tgid <= 0 || task_tgid_vnr(p) == tgid)) {
2224                 error = check_kill_permission(sig, &info, p);
2225                 /*
2226                  * The null signal is a permissions and process existence
2227                  * probe.  No signal is actually delivered.
2228                  *
2229                  * If lock_task_sighand() fails we pretend the task dies
2230                  * after receiving the signal. The window is tiny, and the
2231                  * signal is private anyway.
2232                  */
2233                 if (!error && sig && lock_task_sighand(p, &flags)) {
2234                         error = specific_send_sig_info(sig, &info, p);
2235                         unlock_task_sighand(p, &flags);
2236                 }
2237         }
2238         rcu_read_unlock();
2239
2240         return error;
2241 }
2242
2243 /**
2244  *  sys_tgkill - send signal to one specific thread
2245  *  @tgid: the thread group ID of the thread
2246  *  @pid: the PID of the thread
2247  *  @sig: signal to be sent
2248  *
2249  *  This syscall also checks the @tgid and returns -ESRCH even if the PID
2250  *  exists but it's not belonging to the target process anymore. This
2251  *  method solves the problem of threads exiting and PIDs getting reused.
2252  */
2253 asmlinkage long sys_tgkill(pid_t tgid, pid_t pid, int sig)
2254 {
2255         /* This is only valid for single tasks */
2256         if (pid <= 0 || tgid <= 0)
2257                 return -EINVAL;
2258
2259         return do_tkill(tgid, pid, sig);
2260 }
2261
2262 /*
2263  *  Send a signal to only one task, even if it's a CLONE_THREAD task.
2264  */
2265 asmlinkage long
2266 sys_tkill(pid_t pid, int sig)
2267 {
2268         /* This is only valid for single tasks */
2269         if (pid <= 0)
2270                 return -EINVAL;
2271
2272         return do_tkill(0, pid, sig);
2273 }
2274
2275 asmlinkage long
2276 sys_rt_sigqueueinfo(pid_t pid, int sig, siginfo_t __user *uinfo)
2277 {
2278         siginfo_t info;
2279
2280         if (copy_from_user(&info, uinfo, sizeof(siginfo_t)))
2281                 return -EFAULT;
2282
2283         /* Not even root can pretend to send signals from the kernel.
2284            Nor can they impersonate a kill(), which adds source info.  */
2285         if (info.si_code >= 0)
2286                 return -EPERM;
2287         info.si_signo = sig;
2288
2289         /* POSIX.1b doesn't mention process groups.  */
2290         return kill_proc_info(sig, &info, pid);
2291 }
2292
2293 int do_sigaction(int sig, struct k_sigaction *act, struct k_sigaction *oact)
2294 {
2295         struct task_struct *t = current;
2296         struct k_sigaction *k;
2297         sigset_t mask;
2298
2299         if (!valid_signal(sig) || sig < 1 || (act && sig_kernel_only(sig)))
2300                 return -EINVAL;
2301
2302         k = &t->sighand->action[sig-1];
2303
2304         spin_lock_irq(&current->sighand->siglock);
2305         if (oact)
2306                 *oact = *k;
2307
2308         if (act) {
2309                 sigdelsetmask(&act->sa.sa_mask,
2310                               sigmask(SIGKILL) | sigmask(SIGSTOP));
2311                 *k = *act;
2312                 /*
2313                  * POSIX 3.3.1.3:
2314                  *  "Setting a signal action to SIG_IGN for a signal that is
2315                  *   pending shall cause the pending signal to be discarded,
2316                  *   whether or not it is blocked."
2317                  *
2318                  *  "Setting a signal action to SIG_DFL for a signal that is
2319                  *   pending and whose default action is to ignore the signal
2320                  *   (for example, SIGCHLD), shall cause the pending signal to
2321                  *   be discarded, whether or not it is blocked"
2322                  */
2323                 if (sig_handler_ignored(sig_handler(t, sig), sig)) {
2324                         sigemptyset(&mask);
2325                         sigaddset(&mask, sig);
2326                         rm_from_queue_full(&mask, &t->signal->shared_pending);
2327                         do {
2328                                 rm_from_queue_full(&mask, &t->pending);
2329                                 t = next_thread(t);
2330                         } while (t != current);
2331                 }
2332         }
2333
2334         spin_unlock_irq(&current->sighand->siglock);
2335         return 0;
2336 }
2337
2338 int 
2339 do_sigaltstack (const stack_t __user *uss, stack_t __user *uoss, unsigned long sp)
2340 {
2341         stack_t oss;
2342         int error;
2343
2344         if (uoss) {
2345                 oss.ss_sp = (void __user *) current->sas_ss_sp;
2346                 oss.ss_size = current->sas_ss_size;
2347                 oss.ss_flags = sas_ss_flags(sp);
2348         }
2349
2350         if (uss) {
2351                 void __user *ss_sp;
2352                 size_t ss_size;
2353                 int ss_flags;
2354
2355                 error = -EFAULT;
2356                 if (!access_ok(VERIFY_READ, uss, sizeof(*uss))
2357                     || __get_user(ss_sp, &uss->ss_sp)
2358                     || __get_user(ss_flags, &uss->ss_flags)
2359                     || __get_user(ss_size, &uss->ss_size))
2360                         goto out;
2361
2362                 error = -EPERM;
2363                 if (on_sig_stack(sp))
2364                         goto out;
2365
2366                 error = -EINVAL;
2367                 /*
2368                  *
2369                  * Note - this code used to test ss_flags incorrectly
2370                  *        old code may have been written using ss_flags==0
2371                  *        to mean ss_flags==SS_ONSTACK (as this was the only
2372                  *        way that worked) - this fix preserves that older
2373                  *        mechanism
2374                  */
2375                 if (ss_flags != SS_DISABLE && ss_flags != SS_ONSTACK && ss_flags != 0)
2376                         goto out;
2377
2378                 if (ss_flags == SS_DISABLE) {
2379                         ss_size = 0;
2380                         ss_sp = NULL;
2381                 } else {
2382                         error = -ENOMEM;
2383                         if (ss_size < MINSIGSTKSZ)
2384                                 goto out;
2385                 }
2386
2387                 current->sas_ss_sp = (unsigned long) ss_sp;
2388                 current->sas_ss_size = ss_size;
2389         }
2390
2391         if (uoss) {
2392                 error = -EFAULT;
2393                 if (copy_to_user(uoss, &oss, sizeof(oss)))
2394                         goto out;
2395         }
2396
2397         error = 0;
2398 out:
2399         return error;
2400 }
2401
2402 #ifdef __ARCH_WANT_SYS_SIGPENDING
2403
2404 asmlinkage long
2405 sys_sigpending(old_sigset_t __user *set)
2406 {
2407         return do_sigpending(set, sizeof(*set));
2408 }
2409
2410 #endif
2411
2412 #ifdef __ARCH_WANT_SYS_SIGPROCMASK
2413 /* Some platforms have their own version with special arguments others
2414    support only sys_rt_sigprocmask.  */
2415
2416 asmlinkage long
2417 sys_sigprocmask(int how, old_sigset_t __user *set, old_sigset_t __user *oset)
2418 {
2419         int error;
2420         old_sigset_t old_set, new_set;
2421
2422         if (set) {
2423                 error = -EFAULT;
2424                 if (copy_from_user(&new_set, set, sizeof(*set)))
2425                         goto out;
2426                 new_set &= ~(sigmask(SIGKILL) | sigmask(SIGSTOP));
2427
2428                 spin_lock_irq(&current->sighand->siglock);
2429                 old_set = current->blocked.sig[0];
2430
2431                 error = 0;
2432                 switch (how) {
2433                 default:
2434                         error = -EINVAL;
2435                         break;
2436                 case SIG_BLOCK:
2437                         sigaddsetmask(&current->blocked, new_set);
2438                         break;
2439                 case SIG_UNBLOCK:
2440                         sigdelsetmask(&current->blocked, new_set);
2441                         break;
2442                 case SIG_SETMASK:
2443                         current->blocked.sig[0] = new_set;
2444                         break;
2445                 }
2446
2447                 recalc_sigpending();
2448                 spin_unlock_irq(&current->sighand->siglock);
2449                 if (error)
2450                         goto out;
2451                 if (oset)
2452                         goto set_old;
2453         } else if (oset) {
2454                 old_set = current->blocked.sig[0];
2455         set_old:
2456                 error = -EFAULT;
2457                 if (copy_to_user(oset, &old_set, sizeof(*oset)))
2458                         goto out;
2459         }
2460         error = 0;
2461 out:
2462         return error;
2463 }
2464 #endif /* __ARCH_WANT_SYS_SIGPROCMASK */
2465
2466 #ifdef __ARCH_WANT_SYS_RT_SIGACTION
2467 asmlinkage long
2468 sys_rt_sigaction(int sig,
2469                  const struct sigaction __user *act,
2470                  struct sigaction __user *oact,
2471                  size_t sigsetsize)
2472 {
2473         struct k_sigaction new_sa, old_sa;
2474         int ret = -EINVAL;
2475
2476         /* XXX: Don't preclude handling different sized sigset_t's.  */
2477         if (sigsetsize != sizeof(sigset_t))
2478                 goto out;
2479
2480         if (act) {
2481                 if (copy_from_user(&new_sa.sa, act, sizeof(new_sa.sa)))
2482                         return -EFAULT;
2483         }
2484
2485         ret = do_sigaction(sig, act ? &new_sa : NULL, oact ? &old_sa : NULL);
2486
2487         if (!ret && oact) {
2488                 if (copy_to_user(oact, &old_sa.sa, sizeof(old_sa.sa)))
2489                         return -EFAULT;
2490         }
2491 out:
2492         return ret;
2493 }
2494 #endif /* __ARCH_WANT_SYS_RT_SIGACTION */
2495
2496 #ifdef __ARCH_WANT_SYS_SGETMASK
2497
2498 /*
2499  * For backwards compatibility.  Functionality superseded by sigprocmask.
2500  */
2501 asmlinkage long
2502 sys_sgetmask(void)
2503 {
2504         /* SMP safe */
2505         return current->blocked.sig[0];
2506 }
2507
2508 asmlinkage long
2509 sys_ssetmask(int newmask)
2510 {
2511         int old;
2512
2513         spin_lock_irq(&current->sighand->siglock);
2514         old = current->blocked.sig[0];
2515
2516         siginitset(&current->blocked, newmask & ~(sigmask(SIGKILL)|
2517                                                   sigmask(SIGSTOP)));
2518         recalc_sigpending();
2519         spin_unlock_irq(&current->sighand->siglock);
2520
2521         return old;
2522 }
2523 #endif /* __ARCH_WANT_SGETMASK */
2524
2525 #ifdef __ARCH_WANT_SYS_SIGNAL
2526 /*
2527  * For backwards compatibility.  Functionality superseded by sigaction.
2528  */
2529 asmlinkage unsigned long
2530 sys_signal(int sig, __sighandler_t handler)
2531 {
2532         struct k_sigaction new_sa, old_sa;
2533         int ret;
2534
2535         new_sa.sa.sa_handler = handler;
2536         new_sa.sa.sa_flags = SA_ONESHOT | SA_NOMASK;
2537         sigemptyset(&new_sa.sa.sa_mask);
2538
2539         ret = do_sigaction(sig, &new_sa, &old_sa);
2540
2541         return ret ? ret : (unsigned long)old_sa.sa.sa_handler;
2542 }
2543 #endif /* __ARCH_WANT_SYS_SIGNAL */
2544
2545 #ifdef __ARCH_WANT_SYS_PAUSE
2546
2547 asmlinkage long
2548 sys_pause(void)
2549 {
2550         current->state = TASK_INTERRUPTIBLE;
2551         schedule();
2552         return -ERESTARTNOHAND;
2553 }
2554
2555 #endif
2556
2557 #ifdef __ARCH_WANT_SYS_RT_SIGSUSPEND
2558 asmlinkage long sys_rt_sigsuspend(sigset_t __user *unewset, size_t sigsetsize)
2559 {
2560         sigset_t newset;
2561
2562         /* XXX: Don't preclude handling different sized sigset_t's.  */
2563         if (sigsetsize != sizeof(sigset_t))
2564                 return -EINVAL;
2565
2566         if (copy_from_user(&newset, unewset, sizeof(newset)))
2567                 return -EFAULT;
2568         sigdelsetmask(&newset, sigmask(SIGKILL)|sigmask(SIGSTOP));
2569
2570         spin_lock_irq(&current->sighand->siglock);
2571         current->saved_sigmask = current->blocked;
2572         current->blocked = newset;
2573         recalc_sigpending();
2574         spin_unlock_irq(&current->sighand->siglock);
2575
2576         current->state = TASK_INTERRUPTIBLE;
2577         schedule();
2578         set_restore_sigmask();
2579         return -ERESTARTNOHAND;
2580 }
2581 #endif /* __ARCH_WANT_SYS_RT_SIGSUSPEND */
2582
2583 __attribute__((weak)) const char *arch_vma_name(struct vm_area_struct *vma)
2584 {
2585         return NULL;
2586 }
2587
2588 void __init signals_init(void)
2589 {
2590         sigqueue_cachep = KMEM_CACHE(sigqueue, SLAB_PANIC);
2591 }