]> rtime.felk.cvut.cz Git - zynq/linux.git/blob - kernel/ptrace.c
Apply preempt_rt patch-4.9-rt1.patch.xz
[zynq/linux.git] / kernel / ptrace.c
1 /*
2  * linux/kernel/ptrace.c
3  *
4  * (C) Copyright 1999 Linus Torvalds
5  *
6  * Common interfaces for "ptrace()" which we do not want
7  * to continually duplicate across every architecture.
8  */
9
10 #include <linux/capability.h>
11 #include <linux/export.h>
12 #include <linux/sched.h>
13 #include <linux/errno.h>
14 #include <linux/mm.h>
15 #include <linux/highmem.h>
16 #include <linux/pagemap.h>
17 #include <linux/ptrace.h>
18 #include <linux/security.h>
19 #include <linux/signal.h>
20 #include <linux/uio.h>
21 #include <linux/audit.h>
22 #include <linux/pid_namespace.h>
23 #include <linux/syscalls.h>
24 #include <linux/uaccess.h>
25 #include <linux/regset.h>
26 #include <linux/hw_breakpoint.h>
27 #include <linux/cn_proc.h>
28 #include <linux/compat.h>
29
30
31 /*
32  * ptrace a task: make the debugger its new parent and
33  * move it to the ptrace list.
34  *
35  * Must be called with the tasklist lock write-held.
36  */
37 void __ptrace_link(struct task_struct *child, struct task_struct *new_parent)
38 {
39         BUG_ON(!list_empty(&child->ptrace_entry));
40         list_add(&child->ptrace_entry, &new_parent->ptraced);
41         child->parent = new_parent;
42 }
43
44 /**
45  * __ptrace_unlink - unlink ptracee and restore its execution state
46  * @child: ptracee to be unlinked
47  *
48  * Remove @child from the ptrace list, move it back to the original parent,
49  * and restore the execution state so that it conforms to the group stop
50  * state.
51  *
52  * Unlinking can happen via two paths - explicit PTRACE_DETACH or ptracer
53  * exiting.  For PTRACE_DETACH, unless the ptracee has been killed between
54  * ptrace_check_attach() and here, it's guaranteed to be in TASK_TRACED.
55  * If the ptracer is exiting, the ptracee can be in any state.
56  *
57  * After detach, the ptracee should be in a state which conforms to the
58  * group stop.  If the group is stopped or in the process of stopping, the
59  * ptracee should be put into TASK_STOPPED; otherwise, it should be woken
60  * up from TASK_TRACED.
61  *
62  * If the ptracee is in TASK_TRACED and needs to be moved to TASK_STOPPED,
63  * it goes through TRACED -> RUNNING -> STOPPED transition which is similar
64  * to but in the opposite direction of what happens while attaching to a
65  * stopped task.  However, in this direction, the intermediate RUNNING
66  * state is not hidden even from the current ptracer and if it immediately
67  * re-attaches and performs a WNOHANG wait(2), it may fail.
68  *
69  * CONTEXT:
70  * write_lock_irq(tasklist_lock)
71  */
72 void __ptrace_unlink(struct task_struct *child)
73 {
74         BUG_ON(!child->ptrace);
75
76         clear_tsk_thread_flag(child, TIF_SYSCALL_TRACE);
77
78         child->parent = child->real_parent;
79         list_del_init(&child->ptrace_entry);
80
81         spin_lock(&child->sighand->siglock);
82         child->ptrace = 0;
83         /*
84          * Clear all pending traps and TRAPPING.  TRAPPING should be
85          * cleared regardless of JOBCTL_STOP_PENDING.  Do it explicitly.
86          */
87         task_clear_jobctl_pending(child, JOBCTL_TRAP_MASK);
88         task_clear_jobctl_trapping(child);
89
90         /*
91          * Reinstate JOBCTL_STOP_PENDING if group stop is in effect and
92          * @child isn't dead.
93          */
94         if (!(child->flags & PF_EXITING) &&
95             (child->signal->flags & SIGNAL_STOP_STOPPED ||
96              child->signal->group_stop_count)) {
97                 child->jobctl |= JOBCTL_STOP_PENDING;
98
99                 /*
100                  * This is only possible if this thread was cloned by the
101                  * traced task running in the stopped group, set the signal
102                  * for the future reports.
103                  * FIXME: we should change ptrace_init_task() to handle this
104                  * case.
105                  */
106                 if (!(child->jobctl & JOBCTL_STOP_SIGMASK))
107                         child->jobctl |= SIGSTOP;
108         }
109
110         /*
111          * If transition to TASK_STOPPED is pending or in TASK_TRACED, kick
112          * @child in the butt.  Note that @resume should be used iff @child
113          * is in TASK_TRACED; otherwise, we might unduly disrupt
114          * TASK_KILLABLE sleeps.
115          */
116         if (child->jobctl & JOBCTL_STOP_PENDING || task_is_traced(child))
117                 ptrace_signal_wake_up(child, true);
118
119         spin_unlock(&child->sighand->siglock);
120 }
121
122 /* Ensure that nothing can wake it up, even SIGKILL */
123 static bool ptrace_freeze_traced(struct task_struct *task)
124 {
125         bool ret = false;
126
127         /* Lockless, nobody but us can set this flag */
128         if (task->jobctl & JOBCTL_LISTENING)
129                 return ret;
130
131         spin_lock_irq(&task->sighand->siglock);
132         if (task_is_traced(task) && !__fatal_signal_pending(task)) {
133                 unsigned long flags;
134
135                 raw_spin_lock_irqsave(&task->pi_lock, flags);
136                 if (task->state & __TASK_TRACED)
137                         task->state = __TASK_TRACED;
138                 else
139                         task->saved_state = __TASK_TRACED;
140                 raw_spin_unlock_irqrestore(&task->pi_lock, flags);
141                 ret = true;
142         }
143         spin_unlock_irq(&task->sighand->siglock);
144
145         return ret;
146 }
147
148 static void ptrace_unfreeze_traced(struct task_struct *task)
149 {
150         if (task->state != __TASK_TRACED)
151                 return;
152
153         WARN_ON(!task->ptrace || task->parent != current);
154
155         spin_lock_irq(&task->sighand->siglock);
156         if (__fatal_signal_pending(task))
157                 wake_up_state(task, __TASK_TRACED);
158         else
159                 task->state = TASK_TRACED;
160         spin_unlock_irq(&task->sighand->siglock);
161 }
162
163 /**
164  * ptrace_check_attach - check whether ptracee is ready for ptrace operation
165  * @child: ptracee to check for
166  * @ignore_state: don't check whether @child is currently %TASK_TRACED
167  *
168  * Check whether @child is being ptraced by %current and ready for further
169  * ptrace operations.  If @ignore_state is %false, @child also should be in
170  * %TASK_TRACED state and on return the child is guaranteed to be traced
171  * and not executing.  If @ignore_state is %true, @child can be in any
172  * state.
173  *
174  * CONTEXT:
175  * Grabs and releases tasklist_lock and @child->sighand->siglock.
176  *
177  * RETURNS:
178  * 0 on success, -ESRCH if %child is not ready.
179  */
180 static int ptrace_check_attach(struct task_struct *child, bool ignore_state)
181 {
182         int ret = -ESRCH;
183
184         /*
185          * We take the read lock around doing both checks to close a
186          * possible race where someone else was tracing our child and
187          * detached between these two checks.  After this locked check,
188          * we are sure that this is our traced child and that can only
189          * be changed by us so it's not changing right after this.
190          */
191         read_lock(&tasklist_lock);
192         if (child->ptrace && child->parent == current) {
193                 WARN_ON(child->state == __TASK_TRACED);
194                 /*
195                  * child->sighand can't be NULL, release_task()
196                  * does ptrace_unlink() before __exit_signal().
197                  */
198                 if (ignore_state || ptrace_freeze_traced(child))
199                         ret = 0;
200         }
201         read_unlock(&tasklist_lock);
202
203         if (!ret && !ignore_state) {
204                 if (!wait_task_inactive(child, __TASK_TRACED)) {
205                         /*
206                          * This can only happen if may_ptrace_stop() fails and
207                          * ptrace_stop() changes ->state back to TASK_RUNNING,
208                          * so we should not worry about leaking __TASK_TRACED.
209                          */
210                         WARN_ON(child->state == __TASK_TRACED);
211                         ret = -ESRCH;
212                 }
213         }
214
215         return ret;
216 }
217
218 static int ptrace_has_cap(struct user_namespace *ns, unsigned int mode)
219 {
220         if (mode & PTRACE_MODE_NOAUDIT)
221                 return has_ns_capability_noaudit(current, ns, CAP_SYS_PTRACE);
222         else
223                 return has_ns_capability(current, ns, CAP_SYS_PTRACE);
224 }
225
226 /* Returns 0 on success, -errno on denial. */
227 static int __ptrace_may_access(struct task_struct *task, unsigned int mode)
228 {
229         const struct cred *cred = current_cred(), *tcred;
230         int dumpable = 0;
231         kuid_t caller_uid;
232         kgid_t caller_gid;
233
234         if (!(mode & PTRACE_MODE_FSCREDS) == !(mode & PTRACE_MODE_REALCREDS)) {
235                 WARN(1, "denying ptrace access check without PTRACE_MODE_*CREDS\n");
236                 return -EPERM;
237         }
238
239         /* May we inspect the given task?
240          * This check is used both for attaching with ptrace
241          * and for allowing access to sensitive information in /proc.
242          *
243          * ptrace_attach denies several cases that /proc allows
244          * because setting up the necessary parent/child relationship
245          * or halting the specified task is impossible.
246          */
247
248         /* Don't let security modules deny introspection */
249         if (same_thread_group(task, current))
250                 return 0;
251         rcu_read_lock();
252         if (mode & PTRACE_MODE_FSCREDS) {
253                 caller_uid = cred->fsuid;
254                 caller_gid = cred->fsgid;
255         } else {
256                 /*
257                  * Using the euid would make more sense here, but something
258                  * in userland might rely on the old behavior, and this
259                  * shouldn't be a security problem since
260                  * PTRACE_MODE_REALCREDS implies that the caller explicitly
261                  * used a syscall that requests access to another process
262                  * (and not a filesystem syscall to procfs).
263                  */
264                 caller_uid = cred->uid;
265                 caller_gid = cred->gid;
266         }
267         tcred = __task_cred(task);
268         if (uid_eq(caller_uid, tcred->euid) &&
269             uid_eq(caller_uid, tcred->suid) &&
270             uid_eq(caller_uid, tcred->uid)  &&
271             gid_eq(caller_gid, tcred->egid) &&
272             gid_eq(caller_gid, tcred->sgid) &&
273             gid_eq(caller_gid, tcred->gid))
274                 goto ok;
275         if (ptrace_has_cap(tcred->user_ns, mode))
276                 goto ok;
277         rcu_read_unlock();
278         return -EPERM;
279 ok:
280         rcu_read_unlock();
281         smp_rmb();
282         if (task->mm)
283                 dumpable = get_dumpable(task->mm);
284         rcu_read_lock();
285         if (dumpable != SUID_DUMP_USER &&
286             !ptrace_has_cap(__task_cred(task)->user_ns, mode)) {
287                 rcu_read_unlock();
288                 return -EPERM;
289         }
290         rcu_read_unlock();
291
292         return security_ptrace_access_check(task, mode);
293 }
294
295 bool ptrace_may_access(struct task_struct *task, unsigned int mode)
296 {
297         int err;
298         task_lock(task);
299         err = __ptrace_may_access(task, mode);
300         task_unlock(task);
301         return !err;
302 }
303
304 static int ptrace_attach(struct task_struct *task, long request,
305                          unsigned long addr,
306                          unsigned long flags)
307 {
308         bool seize = (request == PTRACE_SEIZE);
309         int retval;
310
311         retval = -EIO;
312         if (seize) {
313                 if (addr != 0)
314                         goto out;
315                 if (flags & ~(unsigned long)PTRACE_O_MASK)
316                         goto out;
317                 flags = PT_PTRACED | PT_SEIZED | (flags << PT_OPT_FLAG_SHIFT);
318         } else {
319                 flags = PT_PTRACED;
320         }
321
322         audit_ptrace(task);
323
324         retval = -EPERM;
325         if (unlikely(task->flags & PF_KTHREAD))
326                 goto out;
327         if (same_thread_group(task, current))
328                 goto out;
329
330         /*
331          * Protect exec's credential calculations against our interference;
332          * SUID, SGID and LSM creds get determined differently
333          * under ptrace.
334          */
335         retval = -ERESTARTNOINTR;
336         if (mutex_lock_interruptible(&task->signal->cred_guard_mutex))
337                 goto out;
338
339         task_lock(task);
340         retval = __ptrace_may_access(task, PTRACE_MODE_ATTACH_REALCREDS);
341         task_unlock(task);
342         if (retval)
343                 goto unlock_creds;
344
345         write_lock_irq(&tasklist_lock);
346         retval = -EPERM;
347         if (unlikely(task->exit_state))
348                 goto unlock_tasklist;
349         if (task->ptrace)
350                 goto unlock_tasklist;
351
352         if (seize)
353                 flags |= PT_SEIZED;
354         rcu_read_lock();
355         if (ns_capable(__task_cred(task)->user_ns, CAP_SYS_PTRACE))
356                 flags |= PT_PTRACE_CAP;
357         rcu_read_unlock();
358         task->ptrace = flags;
359
360         __ptrace_link(task, current);
361
362         /* SEIZE doesn't trap tracee on attach */
363         if (!seize)
364                 send_sig_info(SIGSTOP, SEND_SIG_FORCED, task);
365
366         spin_lock(&task->sighand->siglock);
367
368         /*
369          * If the task is already STOPPED, set JOBCTL_TRAP_STOP and
370          * TRAPPING, and kick it so that it transits to TRACED.  TRAPPING
371          * will be cleared if the child completes the transition or any
372          * event which clears the group stop states happens.  We'll wait
373          * for the transition to complete before returning from this
374          * function.
375          *
376          * This hides STOPPED -> RUNNING -> TRACED transition from the
377          * attaching thread but a different thread in the same group can
378          * still observe the transient RUNNING state.  IOW, if another
379          * thread's WNOHANG wait(2) on the stopped tracee races against
380          * ATTACH, the wait(2) may fail due to the transient RUNNING.
381          *
382          * The following task_is_stopped() test is safe as both transitions
383          * in and out of STOPPED are protected by siglock.
384          */
385         if (task_is_stopped(task) &&
386             task_set_jobctl_pending(task, JOBCTL_TRAP_STOP | JOBCTL_TRAPPING))
387                 signal_wake_up_state(task, __TASK_STOPPED);
388
389         spin_unlock(&task->sighand->siglock);
390
391         retval = 0;
392 unlock_tasklist:
393         write_unlock_irq(&tasklist_lock);
394 unlock_creds:
395         mutex_unlock(&task->signal->cred_guard_mutex);
396 out:
397         if (!retval) {
398                 /*
399                  * We do not bother to change retval or clear JOBCTL_TRAPPING
400                  * if wait_on_bit() was interrupted by SIGKILL. The tracer will
401                  * not return to user-mode, it will exit and clear this bit in
402                  * __ptrace_unlink() if it wasn't already cleared by the tracee;
403                  * and until then nobody can ptrace this task.
404                  */
405                 wait_on_bit(&task->jobctl, JOBCTL_TRAPPING_BIT, TASK_KILLABLE);
406                 proc_ptrace_connector(task, PTRACE_ATTACH);
407         }
408
409         return retval;
410 }
411
412 /**
413  * ptrace_traceme  --  helper for PTRACE_TRACEME
414  *
415  * Performs checks and sets PT_PTRACED.
416  * Should be used by all ptrace implementations for PTRACE_TRACEME.
417  */
418 static int ptrace_traceme(void)
419 {
420         int ret = -EPERM;
421
422         write_lock_irq(&tasklist_lock);
423         /* Are we already being traced? */
424         if (!current->ptrace) {
425                 ret = security_ptrace_traceme(current->parent);
426                 /*
427                  * Check PF_EXITING to ensure ->real_parent has not passed
428                  * exit_ptrace(). Otherwise we don't report the error but
429                  * pretend ->real_parent untraces us right after return.
430                  */
431                 if (!ret && !(current->real_parent->flags & PF_EXITING)) {
432                         current->ptrace = PT_PTRACED;
433                         __ptrace_link(current, current->real_parent);
434                 }
435         }
436         write_unlock_irq(&tasklist_lock);
437
438         return ret;
439 }
440
441 /*
442  * Called with irqs disabled, returns true if childs should reap themselves.
443  */
444 static int ignoring_children(struct sighand_struct *sigh)
445 {
446         int ret;
447         spin_lock(&sigh->siglock);
448         ret = (sigh->action[SIGCHLD-1].sa.sa_handler == SIG_IGN) ||
449               (sigh->action[SIGCHLD-1].sa.sa_flags & SA_NOCLDWAIT);
450         spin_unlock(&sigh->siglock);
451         return ret;
452 }
453
454 /*
455  * Called with tasklist_lock held for writing.
456  * Unlink a traced task, and clean it up if it was a traced zombie.
457  * Return true if it needs to be reaped with release_task().
458  * (We can't call release_task() here because we already hold tasklist_lock.)
459  *
460  * If it's a zombie, our attachedness prevented normal parent notification
461  * or self-reaping.  Do notification now if it would have happened earlier.
462  * If it should reap itself, return true.
463  *
464  * If it's our own child, there is no notification to do. But if our normal
465  * children self-reap, then this child was prevented by ptrace and we must
466  * reap it now, in that case we must also wake up sub-threads sleeping in
467  * do_wait().
468  */
469 static bool __ptrace_detach(struct task_struct *tracer, struct task_struct *p)
470 {
471         bool dead;
472
473         __ptrace_unlink(p);
474
475         if (p->exit_state != EXIT_ZOMBIE)
476                 return false;
477
478         dead = !thread_group_leader(p);
479
480         if (!dead && thread_group_empty(p)) {
481                 if (!same_thread_group(p->real_parent, tracer))
482                         dead = do_notify_parent(p, p->exit_signal);
483                 else if (ignoring_children(tracer->sighand)) {
484                         __wake_up_parent(p, tracer);
485                         dead = true;
486                 }
487         }
488         /* Mark it as in the process of being reaped. */
489         if (dead)
490                 p->exit_state = EXIT_DEAD;
491         return dead;
492 }
493
494 static int ptrace_detach(struct task_struct *child, unsigned int data)
495 {
496         if (!valid_signal(data))
497                 return -EIO;
498
499         /* Architecture-specific hardware disable .. */
500         ptrace_disable(child);
501
502         write_lock_irq(&tasklist_lock);
503         /*
504          * We rely on ptrace_freeze_traced(). It can't be killed and
505          * untraced by another thread, it can't be a zombie.
506          */
507         WARN_ON(!child->ptrace || child->exit_state);
508         /*
509          * tasklist_lock avoids the race with wait_task_stopped(), see
510          * the comment in ptrace_resume().
511          */
512         child->exit_code = data;
513         __ptrace_detach(current, child);
514         write_unlock_irq(&tasklist_lock);
515
516         proc_ptrace_connector(child, PTRACE_DETACH);
517
518         return 0;
519 }
520
521 /*
522  * Detach all tasks we were using ptrace on. Called with tasklist held
523  * for writing.
524  */
525 void exit_ptrace(struct task_struct *tracer, struct list_head *dead)
526 {
527         struct task_struct *p, *n;
528
529         list_for_each_entry_safe(p, n, &tracer->ptraced, ptrace_entry) {
530                 if (unlikely(p->ptrace & PT_EXITKILL))
531                         send_sig_info(SIGKILL, SEND_SIG_FORCED, p);
532
533                 if (__ptrace_detach(tracer, p))
534                         list_add(&p->ptrace_entry, dead);
535         }
536 }
537
538 int ptrace_readdata(struct task_struct *tsk, unsigned long src, char __user *dst, int len)
539 {
540         int copied = 0;
541
542         while (len > 0) {
543                 char buf[128];
544                 int this_len, retval;
545
546                 this_len = (len > sizeof(buf)) ? sizeof(buf) : len;
547                 retval = access_process_vm(tsk, src, buf, this_len, FOLL_FORCE);
548                 if (!retval) {
549                         if (copied)
550                                 break;
551                         return -EIO;
552                 }
553                 if (copy_to_user(dst, buf, retval))
554                         return -EFAULT;
555                 copied += retval;
556                 src += retval;
557                 dst += retval;
558                 len -= retval;
559         }
560         return copied;
561 }
562
563 int ptrace_writedata(struct task_struct *tsk, char __user *src, unsigned long dst, int len)
564 {
565         int copied = 0;
566
567         while (len > 0) {
568                 char buf[128];
569                 int this_len, retval;
570
571                 this_len = (len > sizeof(buf)) ? sizeof(buf) : len;
572                 if (copy_from_user(buf, src, this_len))
573                         return -EFAULT;
574                 retval = access_process_vm(tsk, dst, buf, this_len,
575                                 FOLL_FORCE | FOLL_WRITE);
576                 if (!retval) {
577                         if (copied)
578                                 break;
579                         return -EIO;
580                 }
581                 copied += retval;
582                 src += retval;
583                 dst += retval;
584                 len -= retval;
585         }
586         return copied;
587 }
588
589 static int ptrace_setoptions(struct task_struct *child, unsigned long data)
590 {
591         unsigned flags;
592
593         if (data & ~(unsigned long)PTRACE_O_MASK)
594                 return -EINVAL;
595
596         if (unlikely(data & PTRACE_O_SUSPEND_SECCOMP)) {
597                 if (!IS_ENABLED(CONFIG_CHECKPOINT_RESTORE) ||
598                     !IS_ENABLED(CONFIG_SECCOMP))
599                         return -EINVAL;
600
601                 if (!capable(CAP_SYS_ADMIN))
602                         return -EPERM;
603
604                 if (seccomp_mode(&current->seccomp) != SECCOMP_MODE_DISABLED ||
605                     current->ptrace & PT_SUSPEND_SECCOMP)
606                         return -EPERM;
607         }
608
609         /* Avoid intermediate state when all opts are cleared */
610         flags = child->ptrace;
611         flags &= ~(PTRACE_O_MASK << PT_OPT_FLAG_SHIFT);
612         flags |= (data << PT_OPT_FLAG_SHIFT);
613         child->ptrace = flags;
614
615         return 0;
616 }
617
618 static int ptrace_getsiginfo(struct task_struct *child, siginfo_t *info)
619 {
620         unsigned long flags;
621         int error = -ESRCH;
622
623         if (lock_task_sighand(child, &flags)) {
624                 error = -EINVAL;
625                 if (likely(child->last_siginfo != NULL)) {
626                         *info = *child->last_siginfo;
627                         error = 0;
628                 }
629                 unlock_task_sighand(child, &flags);
630         }
631         return error;
632 }
633
634 static int ptrace_setsiginfo(struct task_struct *child, const siginfo_t *info)
635 {
636         unsigned long flags;
637         int error = -ESRCH;
638
639         if (lock_task_sighand(child, &flags)) {
640                 error = -EINVAL;
641                 if (likely(child->last_siginfo != NULL)) {
642                         *child->last_siginfo = *info;
643                         error = 0;
644                 }
645                 unlock_task_sighand(child, &flags);
646         }
647         return error;
648 }
649
650 static int ptrace_peek_siginfo(struct task_struct *child,
651                                 unsigned long addr,
652                                 unsigned long data)
653 {
654         struct ptrace_peeksiginfo_args arg;
655         struct sigpending *pending;
656         struct sigqueue *q;
657         int ret, i;
658
659         ret = copy_from_user(&arg, (void __user *) addr,
660                                 sizeof(struct ptrace_peeksiginfo_args));
661         if (ret)
662                 return -EFAULT;
663
664         if (arg.flags & ~PTRACE_PEEKSIGINFO_SHARED)
665                 return -EINVAL; /* unknown flags */
666
667         if (arg.nr < 0)
668                 return -EINVAL;
669
670         if (arg.flags & PTRACE_PEEKSIGINFO_SHARED)
671                 pending = &child->signal->shared_pending;
672         else
673                 pending = &child->pending;
674
675         for (i = 0; i < arg.nr; ) {
676                 siginfo_t info;
677                 s32 off = arg.off + i;
678
679                 spin_lock_irq(&child->sighand->siglock);
680                 list_for_each_entry(q, &pending->list, list) {
681                         if (!off--) {
682                                 copy_siginfo(&info, &q->info);
683                                 break;
684                         }
685                 }
686                 spin_unlock_irq(&child->sighand->siglock);
687
688                 if (off >= 0) /* beyond the end of the list */
689                         break;
690
691 #ifdef CONFIG_COMPAT
692                 if (unlikely(in_compat_syscall())) {
693                         compat_siginfo_t __user *uinfo = compat_ptr(data);
694
695                         if (copy_siginfo_to_user32(uinfo, &info) ||
696                             __put_user(info.si_code, &uinfo->si_code)) {
697                                 ret = -EFAULT;
698                                 break;
699                         }
700
701                 } else
702 #endif
703                 {
704                         siginfo_t __user *uinfo = (siginfo_t __user *) data;
705
706                         if (copy_siginfo_to_user(uinfo, &info) ||
707                             __put_user(info.si_code, &uinfo->si_code)) {
708                                 ret = -EFAULT;
709                                 break;
710                         }
711                 }
712
713                 data += sizeof(siginfo_t);
714                 i++;
715
716                 if (signal_pending(current))
717                         break;
718
719                 cond_resched();
720         }
721
722         if (i > 0)
723                 return i;
724
725         return ret;
726 }
727
728 #ifdef PTRACE_SINGLESTEP
729 #define is_singlestep(request)          ((request) == PTRACE_SINGLESTEP)
730 #else
731 #define is_singlestep(request)          0
732 #endif
733
734 #ifdef PTRACE_SINGLEBLOCK
735 #define is_singleblock(request)         ((request) == PTRACE_SINGLEBLOCK)
736 #else
737 #define is_singleblock(request)         0
738 #endif
739
740 #ifdef PTRACE_SYSEMU
741 #define is_sysemu_singlestep(request)   ((request) == PTRACE_SYSEMU_SINGLESTEP)
742 #else
743 #define is_sysemu_singlestep(request)   0
744 #endif
745
746 static int ptrace_resume(struct task_struct *child, long request,
747                          unsigned long data)
748 {
749         bool need_siglock;
750
751         if (!valid_signal(data))
752                 return -EIO;
753
754         if (request == PTRACE_SYSCALL)
755                 set_tsk_thread_flag(child, TIF_SYSCALL_TRACE);
756         else
757                 clear_tsk_thread_flag(child, TIF_SYSCALL_TRACE);
758
759 #ifdef TIF_SYSCALL_EMU
760         if (request == PTRACE_SYSEMU || request == PTRACE_SYSEMU_SINGLESTEP)
761                 set_tsk_thread_flag(child, TIF_SYSCALL_EMU);
762         else
763                 clear_tsk_thread_flag(child, TIF_SYSCALL_EMU);
764 #endif
765
766         if (is_singleblock(request)) {
767                 if (unlikely(!arch_has_block_step()))
768                         return -EIO;
769                 user_enable_block_step(child);
770         } else if (is_singlestep(request) || is_sysemu_singlestep(request)) {
771                 if (unlikely(!arch_has_single_step()))
772                         return -EIO;
773                 user_enable_single_step(child);
774         } else {
775                 user_disable_single_step(child);
776         }
777
778         /*
779          * Change ->exit_code and ->state under siglock to avoid the race
780          * with wait_task_stopped() in between; a non-zero ->exit_code will
781          * wrongly look like another report from tracee.
782          *
783          * Note that we need siglock even if ->exit_code == data and/or this
784          * status was not reported yet, the new status must not be cleared by
785          * wait_task_stopped() after resume.
786          *
787          * If data == 0 we do not care if wait_task_stopped() reports the old
788          * status and clears the code too; this can't race with the tracee, it
789          * takes siglock after resume.
790          */
791         need_siglock = data && !thread_group_empty(current);
792         if (need_siglock)
793                 spin_lock_irq(&child->sighand->siglock);
794         child->exit_code = data;
795         wake_up_state(child, __TASK_TRACED);
796         if (need_siglock)
797                 spin_unlock_irq(&child->sighand->siglock);
798
799         return 0;
800 }
801
802 #ifdef CONFIG_HAVE_ARCH_TRACEHOOK
803
804 static const struct user_regset *
805 find_regset(const struct user_regset_view *view, unsigned int type)
806 {
807         const struct user_regset *regset;
808         int n;
809
810         for (n = 0; n < view->n; ++n) {
811                 regset = view->regsets + n;
812                 if (regset->core_note_type == type)
813                         return regset;
814         }
815
816         return NULL;
817 }
818
819 static int ptrace_regset(struct task_struct *task, int req, unsigned int type,
820                          struct iovec *kiov)
821 {
822         const struct user_regset_view *view = task_user_regset_view(task);
823         const struct user_regset *regset = find_regset(view, type);
824         int regset_no;
825
826         if (!regset || (kiov->iov_len % regset->size) != 0)
827                 return -EINVAL;
828
829         regset_no = regset - view->regsets;
830         kiov->iov_len = min(kiov->iov_len,
831                             (__kernel_size_t) (regset->n * regset->size));
832
833         if (req == PTRACE_GETREGSET)
834                 return copy_regset_to_user(task, view, regset_no, 0,
835                                            kiov->iov_len, kiov->iov_base);
836         else
837                 return copy_regset_from_user(task, view, regset_no, 0,
838                                              kiov->iov_len, kiov->iov_base);
839 }
840
841 /*
842  * This is declared in linux/regset.h and defined in machine-dependent
843  * code.  We put the export here, near the primary machine-neutral use,
844  * to ensure no machine forgets it.
845  */
846 EXPORT_SYMBOL_GPL(task_user_regset_view);
847 #endif
848
849 int ptrace_request(struct task_struct *child, long request,
850                    unsigned long addr, unsigned long data)
851 {
852         bool seized = child->ptrace & PT_SEIZED;
853         int ret = -EIO;
854         siginfo_t siginfo, *si;
855         void __user *datavp = (void __user *) data;
856         unsigned long __user *datalp = datavp;
857         unsigned long flags;
858
859         switch (request) {
860         case PTRACE_PEEKTEXT:
861         case PTRACE_PEEKDATA:
862                 return generic_ptrace_peekdata(child, addr, data);
863         case PTRACE_POKETEXT:
864         case PTRACE_POKEDATA:
865                 return generic_ptrace_pokedata(child, addr, data);
866
867 #ifdef PTRACE_OLDSETOPTIONS
868         case PTRACE_OLDSETOPTIONS:
869 #endif
870         case PTRACE_SETOPTIONS:
871                 ret = ptrace_setoptions(child, data);
872                 break;
873         case PTRACE_GETEVENTMSG:
874                 ret = put_user(child->ptrace_message, datalp);
875                 break;
876
877         case PTRACE_PEEKSIGINFO:
878                 ret = ptrace_peek_siginfo(child, addr, data);
879                 break;
880
881         case PTRACE_GETSIGINFO:
882                 ret = ptrace_getsiginfo(child, &siginfo);
883                 if (!ret)
884                         ret = copy_siginfo_to_user(datavp, &siginfo);
885                 break;
886
887         case PTRACE_SETSIGINFO:
888                 if (copy_from_user(&siginfo, datavp, sizeof siginfo))
889                         ret = -EFAULT;
890                 else
891                         ret = ptrace_setsiginfo(child, &siginfo);
892                 break;
893
894         case PTRACE_GETSIGMASK:
895                 if (addr != sizeof(sigset_t)) {
896                         ret = -EINVAL;
897                         break;
898                 }
899
900                 if (copy_to_user(datavp, &child->blocked, sizeof(sigset_t)))
901                         ret = -EFAULT;
902                 else
903                         ret = 0;
904
905                 break;
906
907         case PTRACE_SETSIGMASK: {
908                 sigset_t new_set;
909
910                 if (addr != sizeof(sigset_t)) {
911                         ret = -EINVAL;
912                         break;
913                 }
914
915                 if (copy_from_user(&new_set, datavp, sizeof(sigset_t))) {
916                         ret = -EFAULT;
917                         break;
918                 }
919
920                 sigdelsetmask(&new_set, sigmask(SIGKILL)|sigmask(SIGSTOP));
921
922                 /*
923                  * Every thread does recalc_sigpending() after resume, so
924                  * retarget_shared_pending() and recalc_sigpending() are not
925                  * called here.
926                  */
927                 spin_lock_irq(&child->sighand->siglock);
928                 child->blocked = new_set;
929                 spin_unlock_irq(&child->sighand->siglock);
930
931                 ret = 0;
932                 break;
933         }
934
935         case PTRACE_INTERRUPT:
936                 /*
937                  * Stop tracee without any side-effect on signal or job
938                  * control.  At least one trap is guaranteed to happen
939                  * after this request.  If @child is already trapped, the
940                  * current trap is not disturbed and another trap will
941                  * happen after the current trap is ended with PTRACE_CONT.
942                  *
943                  * The actual trap might not be PTRACE_EVENT_STOP trap but
944                  * the pending condition is cleared regardless.
945                  */
946                 if (unlikely(!seized || !lock_task_sighand(child, &flags)))
947                         break;
948
949                 /*
950                  * INTERRUPT doesn't disturb existing trap sans one
951                  * exception.  If ptracer issued LISTEN for the current
952                  * STOP, this INTERRUPT should clear LISTEN and re-trap
953                  * tracee into STOP.
954                  */
955                 if (likely(task_set_jobctl_pending(child, JOBCTL_TRAP_STOP)))
956                         ptrace_signal_wake_up(child, child->jobctl & JOBCTL_LISTENING);
957
958                 unlock_task_sighand(child, &flags);
959                 ret = 0;
960                 break;
961
962         case PTRACE_LISTEN:
963                 /*
964                  * Listen for events.  Tracee must be in STOP.  It's not
965                  * resumed per-se but is not considered to be in TRACED by
966                  * wait(2) or ptrace(2).  If an async event (e.g. group
967                  * stop state change) happens, tracee will enter STOP trap
968                  * again.  Alternatively, ptracer can issue INTERRUPT to
969                  * finish listening and re-trap tracee into STOP.
970                  */
971                 if (unlikely(!seized || !lock_task_sighand(child, &flags)))
972                         break;
973
974                 si = child->last_siginfo;
975                 if (likely(si && (si->si_code >> 8) == PTRACE_EVENT_STOP)) {
976                         child->jobctl |= JOBCTL_LISTENING;
977                         /*
978                          * If NOTIFY is set, it means event happened between
979                          * start of this trap and now.  Trigger re-trap.
980                          */
981                         if (child->jobctl & JOBCTL_TRAP_NOTIFY)
982                                 ptrace_signal_wake_up(child, true);
983                         ret = 0;
984                 }
985                 unlock_task_sighand(child, &flags);
986                 break;
987
988         case PTRACE_DETACH:      /* detach a process that was attached. */
989                 ret = ptrace_detach(child, data);
990                 break;
991
992 #ifdef CONFIG_BINFMT_ELF_FDPIC
993         case PTRACE_GETFDPIC: {
994                 struct mm_struct *mm = get_task_mm(child);
995                 unsigned long tmp = 0;
996
997                 ret = -ESRCH;
998                 if (!mm)
999                         break;
1000
1001                 switch (addr) {
1002                 case PTRACE_GETFDPIC_EXEC:
1003                         tmp = mm->context.exec_fdpic_loadmap;
1004                         break;
1005                 case PTRACE_GETFDPIC_INTERP:
1006                         tmp = mm->context.interp_fdpic_loadmap;
1007                         break;
1008                 default:
1009                         break;
1010                 }
1011                 mmput(mm);
1012
1013                 ret = put_user(tmp, datalp);
1014                 break;
1015         }
1016 #endif
1017
1018 #ifdef PTRACE_SINGLESTEP
1019         case PTRACE_SINGLESTEP:
1020 #endif
1021 #ifdef PTRACE_SINGLEBLOCK
1022         case PTRACE_SINGLEBLOCK:
1023 #endif
1024 #ifdef PTRACE_SYSEMU
1025         case PTRACE_SYSEMU:
1026         case PTRACE_SYSEMU_SINGLESTEP:
1027 #endif
1028         case PTRACE_SYSCALL:
1029         case PTRACE_CONT:
1030                 return ptrace_resume(child, request, data);
1031
1032         case PTRACE_KILL:
1033                 if (child->exit_state)  /* already dead */
1034                         return 0;
1035                 return ptrace_resume(child, request, SIGKILL);
1036
1037 #ifdef CONFIG_HAVE_ARCH_TRACEHOOK
1038         case PTRACE_GETREGSET:
1039         case PTRACE_SETREGSET: {
1040                 struct iovec kiov;
1041                 struct iovec __user *uiov = datavp;
1042
1043                 if (!access_ok(VERIFY_WRITE, uiov, sizeof(*uiov)))
1044                         return -EFAULT;
1045
1046                 if (__get_user(kiov.iov_base, &uiov->iov_base) ||
1047                     __get_user(kiov.iov_len, &uiov->iov_len))
1048                         return -EFAULT;
1049
1050                 ret = ptrace_regset(child, request, addr, &kiov);
1051                 if (!ret)
1052                         ret = __put_user(kiov.iov_len, &uiov->iov_len);
1053                 break;
1054         }
1055 #endif
1056
1057         case PTRACE_SECCOMP_GET_FILTER:
1058                 ret = seccomp_get_filter(child, addr, datavp);
1059                 break;
1060
1061         default:
1062                 break;
1063         }
1064
1065         return ret;
1066 }
1067
1068 static struct task_struct *ptrace_get_task_struct(pid_t pid)
1069 {
1070         struct task_struct *child;
1071
1072         rcu_read_lock();
1073         child = find_task_by_vpid(pid);
1074         if (child)
1075                 get_task_struct(child);
1076         rcu_read_unlock();
1077
1078         if (!child)
1079                 return ERR_PTR(-ESRCH);
1080         return child;
1081 }
1082
1083 #ifndef arch_ptrace_attach
1084 #define arch_ptrace_attach(child)       do { } while (0)
1085 #endif
1086
1087 SYSCALL_DEFINE4(ptrace, long, request, long, pid, unsigned long, addr,
1088                 unsigned long, data)
1089 {
1090         struct task_struct *child;
1091         long ret;
1092
1093         if (request == PTRACE_TRACEME) {
1094                 ret = ptrace_traceme();
1095                 if (!ret)
1096                         arch_ptrace_attach(current);
1097                 goto out;
1098         }
1099
1100         child = ptrace_get_task_struct(pid);
1101         if (IS_ERR(child)) {
1102                 ret = PTR_ERR(child);
1103                 goto out;
1104         }
1105
1106         if (request == PTRACE_ATTACH || request == PTRACE_SEIZE) {
1107                 ret = ptrace_attach(child, request, addr, data);
1108                 /*
1109                  * Some architectures need to do book-keeping after
1110                  * a ptrace attach.
1111                  */
1112                 if (!ret)
1113                         arch_ptrace_attach(child);
1114                 goto out_put_task_struct;
1115         }
1116
1117         ret = ptrace_check_attach(child, request == PTRACE_KILL ||
1118                                   request == PTRACE_INTERRUPT);
1119         if (ret < 0)
1120                 goto out_put_task_struct;
1121
1122         ret = arch_ptrace(child, request, addr, data);
1123         if (ret || request != PTRACE_DETACH)
1124                 ptrace_unfreeze_traced(child);
1125
1126  out_put_task_struct:
1127         put_task_struct(child);
1128  out:
1129         return ret;
1130 }
1131
1132 int generic_ptrace_peekdata(struct task_struct *tsk, unsigned long addr,
1133                             unsigned long data)
1134 {
1135         unsigned long tmp;
1136         int copied;
1137
1138         copied = access_process_vm(tsk, addr, &tmp, sizeof(tmp), FOLL_FORCE);
1139         if (copied != sizeof(tmp))
1140                 return -EIO;
1141         return put_user(tmp, (unsigned long __user *)data);
1142 }
1143
1144 int generic_ptrace_pokedata(struct task_struct *tsk, unsigned long addr,
1145                             unsigned long data)
1146 {
1147         int copied;
1148
1149         copied = access_process_vm(tsk, addr, &data, sizeof(data),
1150                         FOLL_FORCE | FOLL_WRITE);
1151         return (copied == sizeof(data)) ? 0 : -EIO;
1152 }
1153
1154 #if defined CONFIG_COMPAT
1155
1156 int compat_ptrace_request(struct task_struct *child, compat_long_t request,
1157                           compat_ulong_t addr, compat_ulong_t data)
1158 {
1159         compat_ulong_t __user *datap = compat_ptr(data);
1160         compat_ulong_t word;
1161         siginfo_t siginfo;
1162         int ret;
1163
1164         switch (request) {
1165         case PTRACE_PEEKTEXT:
1166         case PTRACE_PEEKDATA:
1167                 ret = access_process_vm(child, addr, &word, sizeof(word),
1168                                 FOLL_FORCE);
1169                 if (ret != sizeof(word))
1170                         ret = -EIO;
1171                 else
1172                         ret = put_user(word, datap);
1173                 break;
1174
1175         case PTRACE_POKETEXT:
1176         case PTRACE_POKEDATA:
1177                 ret = access_process_vm(child, addr, &data, sizeof(data),
1178                                 FOLL_FORCE | FOLL_WRITE);
1179                 ret = (ret != sizeof(data) ? -EIO : 0);
1180                 break;
1181
1182         case PTRACE_GETEVENTMSG:
1183                 ret = put_user((compat_ulong_t) child->ptrace_message, datap);
1184                 break;
1185
1186         case PTRACE_GETSIGINFO:
1187                 ret = ptrace_getsiginfo(child, &siginfo);
1188                 if (!ret)
1189                         ret = copy_siginfo_to_user32(
1190                                 (struct compat_siginfo __user *) datap,
1191                                 &siginfo);
1192                 break;
1193
1194         case PTRACE_SETSIGINFO:
1195                 memset(&siginfo, 0, sizeof siginfo);
1196                 if (copy_siginfo_from_user32(
1197                             &siginfo, (struct compat_siginfo __user *) datap))
1198                         ret = -EFAULT;
1199                 else
1200                         ret = ptrace_setsiginfo(child, &siginfo);
1201                 break;
1202 #ifdef CONFIG_HAVE_ARCH_TRACEHOOK
1203         case PTRACE_GETREGSET:
1204         case PTRACE_SETREGSET:
1205         {
1206                 struct iovec kiov;
1207                 struct compat_iovec __user *uiov =
1208                         (struct compat_iovec __user *) datap;
1209                 compat_uptr_t ptr;
1210                 compat_size_t len;
1211
1212                 if (!access_ok(VERIFY_WRITE, uiov, sizeof(*uiov)))
1213                         return -EFAULT;
1214
1215                 if (__get_user(ptr, &uiov->iov_base) ||
1216                     __get_user(len, &uiov->iov_len))
1217                         return -EFAULT;
1218
1219                 kiov.iov_base = compat_ptr(ptr);
1220                 kiov.iov_len = len;
1221
1222                 ret = ptrace_regset(child, request, addr, &kiov);
1223                 if (!ret)
1224                         ret = __put_user(kiov.iov_len, &uiov->iov_len);
1225                 break;
1226         }
1227 #endif
1228
1229         default:
1230                 ret = ptrace_request(child, request, addr, data);
1231         }
1232
1233         return ret;
1234 }
1235
1236 COMPAT_SYSCALL_DEFINE4(ptrace, compat_long_t, request, compat_long_t, pid,
1237                        compat_long_t, addr, compat_long_t, data)
1238 {
1239         struct task_struct *child;
1240         long ret;
1241
1242         if (request == PTRACE_TRACEME) {
1243                 ret = ptrace_traceme();
1244                 goto out;
1245         }
1246
1247         child = ptrace_get_task_struct(pid);
1248         if (IS_ERR(child)) {
1249                 ret = PTR_ERR(child);
1250                 goto out;
1251         }
1252
1253         if (request == PTRACE_ATTACH || request == PTRACE_SEIZE) {
1254                 ret = ptrace_attach(child, request, addr, data);
1255                 /*
1256                  * Some architectures need to do book-keeping after
1257                  * a ptrace attach.
1258                  */
1259                 if (!ret)
1260                         arch_ptrace_attach(child);
1261                 goto out_put_task_struct;
1262         }
1263
1264         ret = ptrace_check_attach(child, request == PTRACE_KILL ||
1265                                   request == PTRACE_INTERRUPT);
1266         if (!ret) {
1267                 ret = compat_arch_ptrace(child, request, addr, data);
1268                 if (ret || request != PTRACE_DETACH)
1269                         ptrace_unfreeze_traced(child);
1270         }
1271
1272  out_put_task_struct:
1273         put_task_struct(child);
1274  out:
1275         return ret;
1276 }
1277 #endif  /* CONFIG_COMPAT */