ptrace: ptrace_check_attach() should not do s/STOPPED/TRACED/
[pandora-kernel.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/module.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/audit.h>
21 #include <linux/pid_namespace.h>
22 #include <linux/syscalls.h>
23 #include <linux/uaccess.h>
24 #include <linux/regset.h>
25
26
27 /*
28  * ptrace a task: make the debugger its new parent and
29  * move it to the ptrace list.
30  *
31  * Must be called with the tasklist lock write-held.
32  */
33 void __ptrace_link(struct task_struct *child, struct task_struct *new_parent)
34 {
35         BUG_ON(!list_empty(&child->ptrace_entry));
36         list_add(&child->ptrace_entry, &new_parent->ptraced);
37         child->parent = new_parent;
38 }
39
40 /**
41  * __ptrace_unlink - unlink ptracee and restore its execution state
42  * @child: ptracee to be unlinked
43  *
44  * Remove @child from the ptrace list, move it back to the original parent,
45  * and restore the execution state so that it conforms to the group stop
46  * state.
47  *
48  * Unlinking can happen via two paths - explicit PTRACE_DETACH or ptracer
49  * exiting.  For PTRACE_DETACH, unless the ptracee has been killed between
50  * ptrace_check_attach() and here, it's guaranteed to be in TASK_TRACED.
51  * If the ptracer is exiting, the ptracee can be in any state.
52  *
53  * After detach, the ptracee should be in a state which conforms to the
54  * group stop.  If the group is stopped or in the process of stopping, the
55  * ptracee should be put into TASK_STOPPED; otherwise, it should be woken
56  * up from TASK_TRACED.
57  *
58  * If the ptracee is in TASK_TRACED and needs to be moved to TASK_STOPPED,
59  * it goes through TRACED -> RUNNING -> STOPPED transition which is similar
60  * to but in the opposite direction of what happens while attaching to a
61  * stopped task.  However, in this direction, the intermediate RUNNING
62  * state is not hidden even from the current ptracer and if it immediately
63  * re-attaches and performs a WNOHANG wait(2), it may fail.
64  *
65  * CONTEXT:
66  * write_lock_irq(tasklist_lock)
67  */
68 void __ptrace_unlink(struct task_struct *child)
69 {
70         BUG_ON(!child->ptrace);
71
72         child->ptrace = 0;
73         child->parent = child->real_parent;
74         list_del_init(&child->ptrace_entry);
75
76         spin_lock(&child->sighand->siglock);
77
78         /*
79          * Reinstate GROUP_STOP_PENDING if group stop is in effect and
80          * @child isn't dead.
81          */
82         if (!(child->flags & PF_EXITING) &&
83             (child->signal->flags & SIGNAL_STOP_STOPPED ||
84              child->signal->group_stop_count))
85                 child->group_stop |= GROUP_STOP_PENDING;
86
87         /*
88          * If transition to TASK_STOPPED is pending or in TASK_TRACED, kick
89          * @child in the butt.  Note that @resume should be used iff @child
90          * is in TASK_TRACED; otherwise, we might unduly disrupt
91          * TASK_KILLABLE sleeps.
92          */
93         if (child->group_stop & GROUP_STOP_PENDING || task_is_traced(child))
94                 signal_wake_up(child, task_is_traced(child));
95
96         spin_unlock(&child->sighand->siglock);
97 }
98
99 /*
100  * Check that we have indeed attached to the thing..
101  */
102 int ptrace_check_attach(struct task_struct *child, int kill)
103 {
104         int ret = -ESRCH;
105
106         /*
107          * We take the read lock around doing both checks to close a
108          * possible race where someone else was tracing our child and
109          * detached between these two checks.  After this locked check,
110          * we are sure that this is our traced child and that can only
111          * be changed by us so it's not changing right after this.
112          */
113         read_lock(&tasklist_lock);
114         if ((child->ptrace & PT_PTRACED) && child->parent == current) {
115                 /*
116                  * child->sighand can't be NULL, release_task()
117                  * does ptrace_unlink() before __exit_signal().
118                  */
119                 spin_lock_irq(&child->sighand->siglock);
120                 WARN_ON_ONCE(task_is_stopped(child));
121                 if (task_is_traced(child) || kill)
122                         ret = 0;
123                 spin_unlock_irq(&child->sighand->siglock);
124         }
125         read_unlock(&tasklist_lock);
126
127         if (!ret && !kill)
128                 ret = wait_task_inactive(child, TASK_TRACED) ? 0 : -ESRCH;
129
130         /* All systems go.. */
131         return ret;
132 }
133
134 int __ptrace_may_access(struct task_struct *task, unsigned int mode)
135 {
136         const struct cred *cred = current_cred(), *tcred;
137
138         /* May we inspect the given task?
139          * This check is used both for attaching with ptrace
140          * and for allowing access to sensitive information in /proc.
141          *
142          * ptrace_attach denies several cases that /proc allows
143          * because setting up the necessary parent/child relationship
144          * or halting the specified task is impossible.
145          */
146         int dumpable = 0;
147         /* Don't let security modules deny introspection */
148         if (task == current)
149                 return 0;
150         rcu_read_lock();
151         tcred = __task_cred(task);
152         if ((cred->uid != tcred->euid ||
153              cred->uid != tcred->suid ||
154              cred->uid != tcred->uid  ||
155              cred->gid != tcred->egid ||
156              cred->gid != tcred->sgid ||
157              cred->gid != tcred->gid) &&
158             !capable(CAP_SYS_PTRACE)) {
159                 rcu_read_unlock();
160                 return -EPERM;
161         }
162         rcu_read_unlock();
163         smp_rmb();
164         if (task->mm)
165                 dumpable = get_dumpable(task->mm);
166         if (!dumpable && !capable(CAP_SYS_PTRACE))
167                 return -EPERM;
168
169         return security_ptrace_access_check(task, mode);
170 }
171
172 bool ptrace_may_access(struct task_struct *task, unsigned int mode)
173 {
174         int err;
175         task_lock(task);
176         err = __ptrace_may_access(task, mode);
177         task_unlock(task);
178         return !err;
179 }
180
181 static int ptrace_attach(struct task_struct *task)
182 {
183         bool wait_trap = false;
184         int retval;
185
186         audit_ptrace(task);
187
188         retval = -EPERM;
189         if (unlikely(task->flags & PF_KTHREAD))
190                 goto out;
191         if (same_thread_group(task, current))
192                 goto out;
193
194         /*
195          * Protect exec's credential calculations against our interference;
196          * interference; SUID, SGID and LSM creds get determined differently
197          * under ptrace.
198          */
199         retval = -ERESTARTNOINTR;
200         if (mutex_lock_interruptible(&task->signal->cred_guard_mutex))
201                 goto out;
202
203         task_lock(task);
204         retval = __ptrace_may_access(task, PTRACE_MODE_ATTACH);
205         task_unlock(task);
206         if (retval)
207                 goto unlock_creds;
208
209         write_lock_irq(&tasklist_lock);
210         retval = -EPERM;
211         if (unlikely(task->exit_state))
212                 goto unlock_tasklist;
213         if (task->ptrace)
214                 goto unlock_tasklist;
215
216         task->ptrace = PT_PTRACED;
217         if (capable(CAP_SYS_PTRACE))
218                 task->ptrace |= PT_PTRACE_CAP;
219
220         __ptrace_link(task, current);
221         send_sig_info(SIGSTOP, SEND_SIG_FORCED, task);
222
223         spin_lock(&task->sighand->siglock);
224
225         /*
226          * If the task is already STOPPED, set GROUP_STOP_PENDING and
227          * TRAPPING, and kick it so that it transits to TRACED.  TRAPPING
228          * will be cleared if the child completes the transition or any
229          * event which clears the group stop states happens.  We'll wait
230          * for the transition to complete before returning from this
231          * function.
232          *
233          * This hides STOPPED -> RUNNING -> TRACED transition from the
234          * attaching thread but a different thread in the same group can
235          * still observe the transient RUNNING state.  IOW, if another
236          * thread's WNOHANG wait(2) on the stopped tracee races against
237          * ATTACH, the wait(2) may fail due to the transient RUNNING.
238          *
239          * The following task_is_stopped() test is safe as both transitions
240          * in and out of STOPPED are protected by siglock.
241          */
242         if (task_is_stopped(task)) {
243                 task->group_stop |= GROUP_STOP_PENDING | GROUP_STOP_TRAPPING;
244                 signal_wake_up(task, 1);
245                 wait_trap = true;
246         }
247
248         spin_unlock(&task->sighand->siglock);
249
250         retval = 0;
251 unlock_tasklist:
252         write_unlock_irq(&tasklist_lock);
253 unlock_creds:
254         mutex_unlock(&task->signal->cred_guard_mutex);
255 out:
256         if (wait_trap)
257                 wait_event(current->signal->wait_chldexit,
258                            !(task->group_stop & GROUP_STOP_TRAPPING));
259         return retval;
260 }
261
262 /**
263  * ptrace_traceme  --  helper for PTRACE_TRACEME
264  *
265  * Performs checks and sets PT_PTRACED.
266  * Should be used by all ptrace implementations for PTRACE_TRACEME.
267  */
268 static int ptrace_traceme(void)
269 {
270         int ret = -EPERM;
271
272         write_lock_irq(&tasklist_lock);
273         /* Are we already being traced? */
274         if (!current->ptrace) {
275                 ret = security_ptrace_traceme(current->parent);
276                 /*
277                  * Check PF_EXITING to ensure ->real_parent has not passed
278                  * exit_ptrace(). Otherwise we don't report the error but
279                  * pretend ->real_parent untraces us right after return.
280                  */
281                 if (!ret && !(current->real_parent->flags & PF_EXITING)) {
282                         current->ptrace = PT_PTRACED;
283                         __ptrace_link(current, current->real_parent);
284                 }
285         }
286         write_unlock_irq(&tasklist_lock);
287
288         return ret;
289 }
290
291 /*
292  * Called with irqs disabled, returns true if childs should reap themselves.
293  */
294 static int ignoring_children(struct sighand_struct *sigh)
295 {
296         int ret;
297         spin_lock(&sigh->siglock);
298         ret = (sigh->action[SIGCHLD-1].sa.sa_handler == SIG_IGN) ||
299               (sigh->action[SIGCHLD-1].sa.sa_flags & SA_NOCLDWAIT);
300         spin_unlock(&sigh->siglock);
301         return ret;
302 }
303
304 /*
305  * Called with tasklist_lock held for writing.
306  * Unlink a traced task, and clean it up if it was a traced zombie.
307  * Return true if it needs to be reaped with release_task().
308  * (We can't call release_task() here because we already hold tasklist_lock.)
309  *
310  * If it's a zombie, our attachedness prevented normal parent notification
311  * or self-reaping.  Do notification now if it would have happened earlier.
312  * If it should reap itself, return true.
313  *
314  * If it's our own child, there is no notification to do. But if our normal
315  * children self-reap, then this child was prevented by ptrace and we must
316  * reap it now, in that case we must also wake up sub-threads sleeping in
317  * do_wait().
318  */
319 static bool __ptrace_detach(struct task_struct *tracer, struct task_struct *p)
320 {
321         __ptrace_unlink(p);
322
323         if (p->exit_state == EXIT_ZOMBIE) {
324                 if (!task_detached(p) && thread_group_empty(p)) {
325                         if (!same_thread_group(p->real_parent, tracer))
326                                 do_notify_parent(p, p->exit_signal);
327                         else if (ignoring_children(tracer->sighand)) {
328                                 __wake_up_parent(p, tracer);
329                                 p->exit_signal = -1;
330                         }
331                 }
332                 if (task_detached(p)) {
333                         /* Mark it as in the process of being reaped. */
334                         p->exit_state = EXIT_DEAD;
335                         return true;
336                 }
337         }
338
339         return false;
340 }
341
342 static int ptrace_detach(struct task_struct *child, unsigned int data)
343 {
344         bool dead = false;
345
346         if (!valid_signal(data))
347                 return -EIO;
348
349         /* Architecture-specific hardware disable .. */
350         ptrace_disable(child);
351         clear_tsk_thread_flag(child, TIF_SYSCALL_TRACE);
352
353         write_lock_irq(&tasklist_lock);
354         /*
355          * This child can be already killed. Make sure de_thread() or
356          * our sub-thread doing do_wait() didn't do release_task() yet.
357          */
358         if (child->ptrace) {
359                 child->exit_code = data;
360                 dead = __ptrace_detach(current, child);
361         }
362         write_unlock_irq(&tasklist_lock);
363
364         if (unlikely(dead))
365                 release_task(child);
366
367         return 0;
368 }
369
370 /*
371  * Detach all tasks we were using ptrace on. Called with tasklist held
372  * for writing, and returns with it held too. But note it can release
373  * and reacquire the lock.
374  */
375 void exit_ptrace(struct task_struct *tracer)
376         __releases(&tasklist_lock)
377         __acquires(&tasklist_lock)
378 {
379         struct task_struct *p, *n;
380         LIST_HEAD(ptrace_dead);
381
382         if (likely(list_empty(&tracer->ptraced)))
383                 return;
384
385         list_for_each_entry_safe(p, n, &tracer->ptraced, ptrace_entry) {
386                 if (__ptrace_detach(tracer, p))
387                         list_add(&p->ptrace_entry, &ptrace_dead);
388         }
389
390         write_unlock_irq(&tasklist_lock);
391         BUG_ON(!list_empty(&tracer->ptraced));
392
393         list_for_each_entry_safe(p, n, &ptrace_dead, ptrace_entry) {
394                 list_del_init(&p->ptrace_entry);
395                 release_task(p);
396         }
397
398         write_lock_irq(&tasklist_lock);
399 }
400
401 int ptrace_readdata(struct task_struct *tsk, unsigned long src, char __user *dst, int len)
402 {
403         int copied = 0;
404
405         while (len > 0) {
406                 char buf[128];
407                 int this_len, retval;
408
409                 this_len = (len > sizeof(buf)) ? sizeof(buf) : len;
410                 retval = access_process_vm(tsk, src, buf, this_len, 0);
411                 if (!retval) {
412                         if (copied)
413                                 break;
414                         return -EIO;
415                 }
416                 if (copy_to_user(dst, buf, retval))
417                         return -EFAULT;
418                 copied += retval;
419                 src += retval;
420                 dst += retval;
421                 len -= retval;
422         }
423         return copied;
424 }
425
426 int ptrace_writedata(struct task_struct *tsk, char __user *src, unsigned long dst, int len)
427 {
428         int copied = 0;
429
430         while (len > 0) {
431                 char buf[128];
432                 int this_len, retval;
433
434                 this_len = (len > sizeof(buf)) ? sizeof(buf) : len;
435                 if (copy_from_user(buf, src, this_len))
436                         return -EFAULT;
437                 retval = access_process_vm(tsk, dst, buf, this_len, 1);
438                 if (!retval) {
439                         if (copied)
440                                 break;
441                         return -EIO;
442                 }
443                 copied += retval;
444                 src += retval;
445                 dst += retval;
446                 len -= retval;
447         }
448         return copied;
449 }
450
451 static int ptrace_setoptions(struct task_struct *child, unsigned long data)
452 {
453         child->ptrace &= ~PT_TRACE_MASK;
454
455         if (data & PTRACE_O_TRACESYSGOOD)
456                 child->ptrace |= PT_TRACESYSGOOD;
457
458         if (data & PTRACE_O_TRACEFORK)
459                 child->ptrace |= PT_TRACE_FORK;
460
461         if (data & PTRACE_O_TRACEVFORK)
462                 child->ptrace |= PT_TRACE_VFORK;
463
464         if (data & PTRACE_O_TRACECLONE)
465                 child->ptrace |= PT_TRACE_CLONE;
466
467         if (data & PTRACE_O_TRACEEXEC)
468                 child->ptrace |= PT_TRACE_EXEC;
469
470         if (data & PTRACE_O_TRACEVFORKDONE)
471                 child->ptrace |= PT_TRACE_VFORK_DONE;
472
473         if (data & PTRACE_O_TRACEEXIT)
474                 child->ptrace |= PT_TRACE_EXIT;
475
476         return (data & ~PTRACE_O_MASK) ? -EINVAL : 0;
477 }
478
479 static int ptrace_getsiginfo(struct task_struct *child, siginfo_t *info)
480 {
481         unsigned long flags;
482         int error = -ESRCH;
483
484         if (lock_task_sighand(child, &flags)) {
485                 error = -EINVAL;
486                 if (likely(child->last_siginfo != NULL)) {
487                         *info = *child->last_siginfo;
488                         error = 0;
489                 }
490                 unlock_task_sighand(child, &flags);
491         }
492         return error;
493 }
494
495 static int ptrace_setsiginfo(struct task_struct *child, const siginfo_t *info)
496 {
497         unsigned long flags;
498         int error = -ESRCH;
499
500         if (lock_task_sighand(child, &flags)) {
501                 error = -EINVAL;
502                 if (likely(child->last_siginfo != NULL)) {
503                         *child->last_siginfo = *info;
504                         error = 0;
505                 }
506                 unlock_task_sighand(child, &flags);
507         }
508         return error;
509 }
510
511
512 #ifdef PTRACE_SINGLESTEP
513 #define is_singlestep(request)          ((request) == PTRACE_SINGLESTEP)
514 #else
515 #define is_singlestep(request)          0
516 #endif
517
518 #ifdef PTRACE_SINGLEBLOCK
519 #define is_singleblock(request)         ((request) == PTRACE_SINGLEBLOCK)
520 #else
521 #define is_singleblock(request)         0
522 #endif
523
524 #ifdef PTRACE_SYSEMU
525 #define is_sysemu_singlestep(request)   ((request) == PTRACE_SYSEMU_SINGLESTEP)
526 #else
527 #define is_sysemu_singlestep(request)   0
528 #endif
529
530 static int ptrace_resume(struct task_struct *child, long request,
531                          unsigned long data)
532 {
533         if (!valid_signal(data))
534                 return -EIO;
535
536         if (request == PTRACE_SYSCALL)
537                 set_tsk_thread_flag(child, TIF_SYSCALL_TRACE);
538         else
539                 clear_tsk_thread_flag(child, TIF_SYSCALL_TRACE);
540
541 #ifdef TIF_SYSCALL_EMU
542         if (request == PTRACE_SYSEMU || request == PTRACE_SYSEMU_SINGLESTEP)
543                 set_tsk_thread_flag(child, TIF_SYSCALL_EMU);
544         else
545                 clear_tsk_thread_flag(child, TIF_SYSCALL_EMU);
546 #endif
547
548         if (is_singleblock(request)) {
549                 if (unlikely(!arch_has_block_step()))
550                         return -EIO;
551                 user_enable_block_step(child);
552         } else if (is_singlestep(request) || is_sysemu_singlestep(request)) {
553                 if (unlikely(!arch_has_single_step()))
554                         return -EIO;
555                 user_enable_single_step(child);
556         } else {
557                 user_disable_single_step(child);
558         }
559
560         child->exit_code = data;
561         wake_up_process(child);
562
563         return 0;
564 }
565
566 #ifdef CONFIG_HAVE_ARCH_TRACEHOOK
567
568 static const struct user_regset *
569 find_regset(const struct user_regset_view *view, unsigned int type)
570 {
571         const struct user_regset *regset;
572         int n;
573
574         for (n = 0; n < view->n; ++n) {
575                 regset = view->regsets + n;
576                 if (regset->core_note_type == type)
577                         return regset;
578         }
579
580         return NULL;
581 }
582
583 static int ptrace_regset(struct task_struct *task, int req, unsigned int type,
584                          struct iovec *kiov)
585 {
586         const struct user_regset_view *view = task_user_regset_view(task);
587         const struct user_regset *regset = find_regset(view, type);
588         int regset_no;
589
590         if (!regset || (kiov->iov_len % regset->size) != 0)
591                 return -EINVAL;
592
593         regset_no = regset - view->regsets;
594         kiov->iov_len = min(kiov->iov_len,
595                             (__kernel_size_t) (regset->n * regset->size));
596
597         if (req == PTRACE_GETREGSET)
598                 return copy_regset_to_user(task, view, regset_no, 0,
599                                            kiov->iov_len, kiov->iov_base);
600         else
601                 return copy_regset_from_user(task, view, regset_no, 0,
602                                              kiov->iov_len, kiov->iov_base);
603 }
604
605 #endif
606
607 int ptrace_request(struct task_struct *child, long request,
608                    unsigned long addr, unsigned long data)
609 {
610         int ret = -EIO;
611         siginfo_t siginfo;
612         void __user *datavp = (void __user *) data;
613         unsigned long __user *datalp = datavp;
614
615         switch (request) {
616         case PTRACE_PEEKTEXT:
617         case PTRACE_PEEKDATA:
618                 return generic_ptrace_peekdata(child, addr, data);
619         case PTRACE_POKETEXT:
620         case PTRACE_POKEDATA:
621                 return generic_ptrace_pokedata(child, addr, data);
622
623 #ifdef PTRACE_OLDSETOPTIONS
624         case PTRACE_OLDSETOPTIONS:
625 #endif
626         case PTRACE_SETOPTIONS:
627                 ret = ptrace_setoptions(child, data);
628                 break;
629         case PTRACE_GETEVENTMSG:
630                 ret = put_user(child->ptrace_message, datalp);
631                 break;
632
633         case PTRACE_GETSIGINFO:
634                 ret = ptrace_getsiginfo(child, &siginfo);
635                 if (!ret)
636                         ret = copy_siginfo_to_user(datavp, &siginfo);
637                 break;
638
639         case PTRACE_SETSIGINFO:
640                 if (copy_from_user(&siginfo, datavp, sizeof siginfo))
641                         ret = -EFAULT;
642                 else
643                         ret = ptrace_setsiginfo(child, &siginfo);
644                 break;
645
646         case PTRACE_DETACH:      /* detach a process that was attached. */
647                 ret = ptrace_detach(child, data);
648                 break;
649
650 #ifdef CONFIG_BINFMT_ELF_FDPIC
651         case PTRACE_GETFDPIC: {
652                 struct mm_struct *mm = get_task_mm(child);
653                 unsigned long tmp = 0;
654
655                 ret = -ESRCH;
656                 if (!mm)
657                         break;
658
659                 switch (addr) {
660                 case PTRACE_GETFDPIC_EXEC:
661                         tmp = mm->context.exec_fdpic_loadmap;
662                         break;
663                 case PTRACE_GETFDPIC_INTERP:
664                         tmp = mm->context.interp_fdpic_loadmap;
665                         break;
666                 default:
667                         break;
668                 }
669                 mmput(mm);
670
671                 ret = put_user(tmp, datalp);
672                 break;
673         }
674 #endif
675
676 #ifdef PTRACE_SINGLESTEP
677         case PTRACE_SINGLESTEP:
678 #endif
679 #ifdef PTRACE_SINGLEBLOCK
680         case PTRACE_SINGLEBLOCK:
681 #endif
682 #ifdef PTRACE_SYSEMU
683         case PTRACE_SYSEMU:
684         case PTRACE_SYSEMU_SINGLESTEP:
685 #endif
686         case PTRACE_SYSCALL:
687         case PTRACE_CONT:
688                 return ptrace_resume(child, request, data);
689
690         case PTRACE_KILL:
691                 if (child->exit_state)  /* already dead */
692                         return 0;
693                 return ptrace_resume(child, request, SIGKILL);
694
695 #ifdef CONFIG_HAVE_ARCH_TRACEHOOK
696         case PTRACE_GETREGSET:
697         case PTRACE_SETREGSET:
698         {
699                 struct iovec kiov;
700                 struct iovec __user *uiov = datavp;
701
702                 if (!access_ok(VERIFY_WRITE, uiov, sizeof(*uiov)))
703                         return -EFAULT;
704
705                 if (__get_user(kiov.iov_base, &uiov->iov_base) ||
706                     __get_user(kiov.iov_len, &uiov->iov_len))
707                         return -EFAULT;
708
709                 ret = ptrace_regset(child, request, addr, &kiov);
710                 if (!ret)
711                         ret = __put_user(kiov.iov_len, &uiov->iov_len);
712                 break;
713         }
714 #endif
715         default:
716                 break;
717         }
718
719         return ret;
720 }
721
722 static struct task_struct *ptrace_get_task_struct(pid_t pid)
723 {
724         struct task_struct *child;
725
726         rcu_read_lock();
727         child = find_task_by_vpid(pid);
728         if (child)
729                 get_task_struct(child);
730         rcu_read_unlock();
731
732         if (!child)
733                 return ERR_PTR(-ESRCH);
734         return child;
735 }
736
737 #ifndef arch_ptrace_attach
738 #define arch_ptrace_attach(child)       do { } while (0)
739 #endif
740
741 SYSCALL_DEFINE4(ptrace, long, request, long, pid, unsigned long, addr,
742                 unsigned long, data)
743 {
744         struct task_struct *child;
745         long ret;
746
747         if (request == PTRACE_TRACEME) {
748                 ret = ptrace_traceme();
749                 if (!ret)
750                         arch_ptrace_attach(current);
751                 goto out;
752         }
753
754         child = ptrace_get_task_struct(pid);
755         if (IS_ERR(child)) {
756                 ret = PTR_ERR(child);
757                 goto out;
758         }
759
760         if (request == PTRACE_ATTACH) {
761                 ret = ptrace_attach(child);
762                 /*
763                  * Some architectures need to do book-keeping after
764                  * a ptrace attach.
765                  */
766                 if (!ret)
767                         arch_ptrace_attach(child);
768                 goto out_put_task_struct;
769         }
770
771         ret = ptrace_check_attach(child, request == PTRACE_KILL);
772         if (ret < 0)
773                 goto out_put_task_struct;
774
775         ret = arch_ptrace(child, request, addr, data);
776
777  out_put_task_struct:
778         put_task_struct(child);
779  out:
780         return ret;
781 }
782
783 int generic_ptrace_peekdata(struct task_struct *tsk, unsigned long addr,
784                             unsigned long data)
785 {
786         unsigned long tmp;
787         int copied;
788
789         copied = access_process_vm(tsk, addr, &tmp, sizeof(tmp), 0);
790         if (copied != sizeof(tmp))
791                 return -EIO;
792         return put_user(tmp, (unsigned long __user *)data);
793 }
794
795 int generic_ptrace_pokedata(struct task_struct *tsk, unsigned long addr,
796                             unsigned long data)
797 {
798         int copied;
799
800         copied = access_process_vm(tsk, addr, &data, sizeof(data), 1);
801         return (copied == sizeof(data)) ? 0 : -EIO;
802 }
803
804 #if defined CONFIG_COMPAT
805 #include <linux/compat.h>
806
807 int compat_ptrace_request(struct task_struct *child, compat_long_t request,
808                           compat_ulong_t addr, compat_ulong_t data)
809 {
810         compat_ulong_t __user *datap = compat_ptr(data);
811         compat_ulong_t word;
812         siginfo_t siginfo;
813         int ret;
814
815         switch (request) {
816         case PTRACE_PEEKTEXT:
817         case PTRACE_PEEKDATA:
818                 ret = access_process_vm(child, addr, &word, sizeof(word), 0);
819                 if (ret != sizeof(word))
820                         ret = -EIO;
821                 else
822                         ret = put_user(word, datap);
823                 break;
824
825         case PTRACE_POKETEXT:
826         case PTRACE_POKEDATA:
827                 ret = access_process_vm(child, addr, &data, sizeof(data), 1);
828                 ret = (ret != sizeof(data) ? -EIO : 0);
829                 break;
830
831         case PTRACE_GETEVENTMSG:
832                 ret = put_user((compat_ulong_t) child->ptrace_message, datap);
833                 break;
834
835         case PTRACE_GETSIGINFO:
836                 ret = ptrace_getsiginfo(child, &siginfo);
837                 if (!ret)
838                         ret = copy_siginfo_to_user32(
839                                 (struct compat_siginfo __user *) datap,
840                                 &siginfo);
841                 break;
842
843         case PTRACE_SETSIGINFO:
844                 memset(&siginfo, 0, sizeof siginfo);
845                 if (copy_siginfo_from_user32(
846                             &siginfo, (struct compat_siginfo __user *) datap))
847                         ret = -EFAULT;
848                 else
849                         ret = ptrace_setsiginfo(child, &siginfo);
850                 break;
851 #ifdef CONFIG_HAVE_ARCH_TRACEHOOK
852         case PTRACE_GETREGSET:
853         case PTRACE_SETREGSET:
854         {
855                 struct iovec kiov;
856                 struct compat_iovec __user *uiov =
857                         (struct compat_iovec __user *) datap;
858                 compat_uptr_t ptr;
859                 compat_size_t len;
860
861                 if (!access_ok(VERIFY_WRITE, uiov, sizeof(*uiov)))
862                         return -EFAULT;
863
864                 if (__get_user(ptr, &uiov->iov_base) ||
865                     __get_user(len, &uiov->iov_len))
866                         return -EFAULT;
867
868                 kiov.iov_base = compat_ptr(ptr);
869                 kiov.iov_len = len;
870
871                 ret = ptrace_regset(child, request, addr, &kiov);
872                 if (!ret)
873                         ret = __put_user(kiov.iov_len, &uiov->iov_len);
874                 break;
875         }
876 #endif
877
878         default:
879                 ret = ptrace_request(child, request, addr, data);
880         }
881
882         return ret;
883 }
884
885 asmlinkage long compat_sys_ptrace(compat_long_t request, compat_long_t pid,
886                                   compat_long_t addr, compat_long_t data)
887 {
888         struct task_struct *child;
889         long ret;
890
891         if (request == PTRACE_TRACEME) {
892                 ret = ptrace_traceme();
893                 goto out;
894         }
895
896         child = ptrace_get_task_struct(pid);
897         if (IS_ERR(child)) {
898                 ret = PTR_ERR(child);
899                 goto out;
900         }
901
902         if (request == PTRACE_ATTACH) {
903                 ret = ptrace_attach(child);
904                 /*
905                  * Some architectures need to do book-keeping after
906                  * a ptrace attach.
907                  */
908                 if (!ret)
909                         arch_ptrace_attach(child);
910                 goto out_put_task_struct;
911         }
912
913         ret = ptrace_check_attach(child, request == PTRACE_KILL);
914         if (!ret)
915                 ret = compat_arch_ptrace(child, request, addr, data);
916
917  out_put_task_struct:
918         put_task_struct(child);
919  out:
920         return ret;
921 }
922 #endif  /* CONFIG_COMPAT */