cregit-Linux how code gets into the kernel

Release 4.15 kernel/time/posix-cpu-timers.c

Directory: kernel/time
// SPDX-License-Identifier: GPL-2.0
/*
 * Implement CPU time clocks for the POSIX clock interface.
 */

#include <linux/sched/signal.h>
#include <linux/sched/cputime.h>
#include <linux/posix-timers.h>
#include <linux/errno.h>
#include <linux/math64.h>
#include <linux/uaccess.h>
#include <linux/kernel_stat.h>
#include <trace/events/timer.h>
#include <linux/tick.h>
#include <linux/workqueue.h>
#include <linux/compat.h>

#include "posix-timers.h"

static void posix_cpu_timer_rearm(struct k_itimer *timer);

/*
 * Called after updating RLIMIT_CPU to run cpu timer and update
 * tsk->signal->cputime_expires expiration cache if necessary. Needs
 * siglock protection since other code may update expiration cache as
 * well.
 */

void update_rlimit_cpu(struct task_struct *task, unsigned long rlim_new) { u64 nsecs = rlim_new * NSEC_PER_SEC; spin_lock_irq(&task->sighand->siglock); set_process_cpu_timer(task, CPUCLOCK_PROF, &nsecs, NULL); spin_unlock_irq(&task->sighand->siglock); }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar2750.94%116.67%
Roland McGrath1120.75%233.33%
Jiri Slaby815.09%116.67%
Frédéric Weisbecker59.43%116.67%
Stanislaw Gruszka23.77%116.67%
Total53100.00%6100.00%


static int check_clock(const clockid_t which_clock) { int error = 0; struct task_struct *p; const pid_t pid = CPUCLOCK_PID(which_clock); if (CPUCLOCK_WHICH(which_clock) >= CPUCLOCK_MAX) return -EINVAL; if (pid == 0) return 0; rcu_read_lock(); p = find_task_by_vpid(pid); if (!p || !(CPUCLOCK_PERTHREAD(which_clock) ? same_thread_group(p, current) : has_group_leader_pid(p))) { error = -EINVAL; } rcu_read_unlock(); return error; }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar7272.73%120.00%
Roland McGrath2121.21%240.00%
Sergey Senozhatsky55.05%120.00%
Thomas Gleixner11.01%120.00%
Total99100.00%5100.00%

/* * Update expiry time from increment, and increase overrun count, * given the current clock sample. */
static void bump_cpu_timer(struct k_itimer *timer, u64 now) { int i; u64 delta, incr; if (timer->it.cpu.incr == 0) return; if (now < timer->it.cpu.expires) return; incr = timer->it.cpu.incr; delta = now + incr - timer->it.cpu.expires; /* Don't use (incr*2 < delta), incr*2 might overflow. */ for (i = 0; incr < delta - incr; i++) incr = incr << 1; for (; i >= 0; incr >>= 1, i--) { if (delta < incr) continue; timer->it.cpu.expires += incr; timer->it_overrun += 1 << i; delta -= incr; } }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar9870.50%120.00%
Roland McGrath2417.27%120.00%
Martin Schwidefsky96.47%120.00%
Frédéric Weisbecker85.76%240.00%
Total139100.00%5100.00%

/** * task_cputime_zero - Check a task_cputime struct for all zero fields. * * @cputime: The struct to compare. * * Checks @cputime to see if all fields are zero. Returns true if all fields * are zero, false if any field is nonzero. */
static inline int task_cputime_zero(const struct task_cputime *cputime) { if (!cputime->utime && !cputime->stime && !cputime->sum_exec_runtime) return 1; return 0; }

Contributors

PersonTokensPropCommitsCommitProp
Frédéric Weisbecker36100.00%2100.00%
Total36100.00%2100.00%


static inline u64 prof_ticks(struct task_struct *p) { u64 utime, stime; task_cputime(p, &utime, &stime); return utime + stime; }

Contributors

PersonTokensPropCommitsCommitProp
Frédéric Weisbecker1751.52%233.33%
Frank Mayhar1236.36%116.67%
Roland McGrath39.09%233.33%
Martin Schwidefsky13.03%116.67%
Total33100.00%6100.00%


static inline u64 virt_ticks(struct task_struct *p) { u64 utime, stime; task_cputime(p, &utime, &stime); return utime; }

Contributors

PersonTokensPropCommitsCommitProp
Frédéric Weisbecker1341.94%240.00%
Frank Mayhar1238.71%120.00%
Stanislaw Gruszka412.90%120.00%
Roland McGrath26.45%120.00%
Total31100.00%5100.00%


static int posix_cpu_clock_getres(const clockid_t which_clock, struct timespec64 *tp) { int error = check_clock(which_clock); if (!error) { tp->tv_sec = 0; tp->tv_nsec = ((NSEC_PER_SEC + HZ - 1) / HZ); if (CPUCLOCK_WHICH(which_clock) == CPUCLOCK_SCHED) { /* * If sched_clock is using a cycle counter, we * don't have any idea of its true resolution * exported, but it is much more than 1s/HZ. */ tp->tv_nsec = 1; } } return error; }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar4764.38%116.67%
Roland McGrath2331.51%233.33%
Thomas Gleixner22.74%233.33%
Deepa Dinamani11.37%116.67%
Total73100.00%6100.00%


static int posix_cpu_clock_set(const clockid_t which_clock, const struct timespec64 *tp) { /* * You can never reset a CPU clock, but we check for other errors * in the call before failing with EPERM. */ int error = check_clock(which_clock); if (error == 0) { error = -EPERM; } return error; }

Contributors

PersonTokensPropCommitsCommitProp
Roland McGrath2765.85%120.00%
Frank Mayhar1126.83%120.00%
Thomas Gleixner24.88%240.00%
Deepa Dinamani12.44%120.00%
Total41100.00%5100.00%

/* * Sample a per-thread clock for the given task. */
static int cpu_clock_sample(const clockid_t which_clock, struct task_struct *p, u64 *sample) { switch (CPUCLOCK_WHICH(which_clock)) { default: return -EINVAL; case CPUCLOCK_PROF: *sample = prof_ticks(p); break; case CPUCLOCK_VIRT: *sample = virt_ticks(p); break; case CPUCLOCK_SCHED: *sample = task_sched_runtime(p); break; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar3650.00%116.67%
Roland McGrath2534.72%116.67%
Frédéric Weisbecker811.11%233.33%
Pavel Emelyanov22.78%116.67%
Hidetoshi Seto11.39%116.67%
Total72100.00%6100.00%

/* * Set cputime to sum_cputime if sum_cputime > cputime. Use cmpxchg * to avoid race conditions with concurrent updates to cputime. */
static inline void __update_gt_cputime(atomic64_t *cputime, u64 sum_cputime) { u64 curr_cputime; retry: curr_cputime = atomic64_read(cputime); if (sum_cputime > curr_cputime) { if (atomic64_cmpxchg(cputime, curr_cputime, sum_cputime) != curr_cputime) goto retry; } }

Contributors

PersonTokensPropCommitsCommitProp
Jason Low50100.00%1100.00%
Total50100.00%1100.00%


static void update_gt_cputime(struct task_cputime_atomic *cputime_atomic, struct task_cputime *sum) { __update_gt_cputime(&cputime_atomic->utime, sum->utime); __update_gt_cputime(&cputime_atomic->stime, sum->stime); __update_gt_cputime(&cputime_atomic->sum_exec_runtime, sum->sum_exec_runtime); }

Contributors

PersonTokensPropCommitsCommitProp
Jason Low3669.23%240.00%
Peter Zijlstra1426.92%120.00%
Frédéric Weisbecker23.85%240.00%
Total52100.00%5100.00%

/* Sample task_cputime_atomic values in "atomic_timers", store results in "times". */
static inline void sample_cputime_atomic(struct task_cputime *times, struct task_cputime_atomic *atomic_times) { times->utime = atomic64_read(&atomic_times->utime); times->stime = atomic64_read(&atomic_times->stime); times->sum_exec_runtime = atomic64_read(&atomic_times->sum_exec_runtime); }

Contributors

PersonTokensPropCommitsCommitProp
Jason Low3362.26%250.00%
Peter Zijlstra1935.85%125.00%
Frédéric Weisbecker11.89%125.00%
Total53100.00%4100.00%


void thread_group_cputimer(struct task_struct *tsk, struct task_cputime *times) { struct thread_group_cputimer *cputimer = &tsk->signal->cputimer; struct task_cputime sum; /* Check if cputimer isn't running. This is accessed without locking. */ if (!READ_ONCE(cputimer->running)) { /* * The POSIX timer interface allows for absolute time expiry * values through the TIMER_ABSTIME flag, therefore we have * to synchronize the timer to the clock every time we start it. */ thread_group_cputime(tsk, &sum); update_gt_cputime(&cputimer->cputime_atomic, &sum); /* * We're setting cputimer->running without a lock. Ensure * this only gets written to in one operation. We set * running after update_gt_cputime() as a small optimization, * but barriers are not required because update_gt_cputime() * can handle concurrent updates. */ WRITE_ONCE(cputimer->running, true); } sample_cputime_atomic(times, &cputimer->cputime_atomic); }

Contributors

PersonTokensPropCommitsCommitProp
Peter Zijlstra6273.81%233.33%
Jason Low1922.62%350.00%
Frédéric Weisbecker33.57%116.67%
Total84100.00%6100.00%

/* * Sample a process (thread group) clock for the given group_leader task. * Must be called with task sighand lock held for safe while_each_thread() * traversal. */
static int cpu_clock_sample_group(const clockid_t which_clock, struct task_struct *p, u64 *sample) { struct task_cputime cputime; switch (CPUCLOCK_WHICH(which_clock)) { default: return -EINVAL; case CPUCLOCK_PROF: thread_group_cputime(p, &cputime); *sample = cputime.utime + cputime.stime; break; case CPUCLOCK_VIRT: thread_group_cputime(p, &cputime); *sample = cputime.utime; break; case CPUCLOCK_SCHED: thread_group_cputime(p, &cputime); *sample = cputime.sum_exec_runtime; break; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar3938.61%222.22%
Roland McGrath2221.78%111.11%
Hidetoshi Seto1413.86%111.11%
Frédéric Weisbecker1211.88%222.22%
Peter Zijlstra109.90%111.11%
Petr Tesarik32.97%111.11%
Martin Schwidefsky10.99%111.11%
Total101100.00%9100.00%


static int posix_cpu_clock_get_task(struct task_struct *tsk, const clockid_t which_clock, struct timespec64 *tp) { int err = -EINVAL; u64 rtn; if (CPUCLOCK_PERTHREAD(which_clock)) { if (same_thread_group(tsk, current)) err = cpu_clock_sample(which_clock, tsk, &rtn); } else { if (tsk == current || thread_group_leader(tsk)) err = cpu_clock_sample_group(which_clock, tsk, &rtn); } if (!err) *tp = ns_to_timespec64(rtn); return err; }

Contributors

PersonTokensPropCommitsCommitProp
Frédéric Weisbecker4241.58%333.33%
Frank Mayhar3635.64%111.11%
Roland McGrath1110.89%111.11%
Oleg Nesterov65.94%111.11%
Linus Torvalds32.97%111.11%
Deepa Dinamani21.98%111.11%
Thomas Gleixner10.99%111.11%
Total101100.00%9100.00%


static int posix_cpu_clock_get(const clockid_t which_clock, struct timespec64 *tp) { const pid_t pid = CPUCLOCK_PID(which_clock); int err = -EINVAL; if (pid == 0) { /* * Special case constant value for our own clocks. * We don't have to do any lookup to find ourselves. */ err = posix_cpu_clock_get_task(current, which_clock, tp); } else { /* * Find the given PID, and validate that the caller * should be able to see it. */ struct task_struct *p; rcu_read_lock(); p = find_task_by_vpid(pid); if (p) err = posix_cpu_clock_get_task(p, which_clock, tp); rcu_read_unlock(); } return err; }

Contributors

PersonTokensPropCommitsCommitProp
Frédéric Weisbecker5561.11%116.67%
Frank Mayhar2527.78%116.67%
Roland McGrath66.67%116.67%
Linus Torvalds22.22%116.67%
Oleg Nesterov11.11%116.67%
Deepa Dinamani11.11%116.67%
Total90100.00%6100.00%

/* * Validate the clockid_t for a new CPU-clock timer, and initialize the timer. * This is called from sys_timer_create() and do_cpu_nanosleep() with the * new timer already all-zeros initialized. */
static int posix_cpu_timer_create(struct k_itimer *new_timer) { int ret = 0; const pid_t pid = CPUCLOCK_PID(new_timer->it_clock); struct task_struct *p; if (CPUCLOCK_WHICH(new_timer->it_clock) >= CPUCLOCK_MAX) return -EINVAL; new_timer->kclock = &clock_posix_cpu; INIT_LIST_HEAD(&new_timer->it.cpu.entry); rcu_read_lock(); if (CPUCLOCK_PERTHREAD(new_timer->it_clock)) { if (pid == 0) { p = current; } else { p = find_task_by_vpid(pid); if (p && !same_thread_group(p, current)) p = NULL; } } else { if (pid == 0) { p = current->group_leader; } else { p = find_task_by_vpid(pid); if (p && !has_group_leader_pid(p)) p = NULL; } } new_timer->it.cpu.task = p; if (p) { get_task_struct(p); } else { ret = -EINVAL; } rcu_read_unlock(); return ret; }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar11559.28%120.00%
Roland McGrath6634.02%120.00%
Thomas Gleixner84.12%240.00%
Sergey Senozhatsky52.58%120.00%
Total194100.00%5100.00%

/* * Clean up a CPU-clock timer that is about to be destroyed. * This is called from timer deletion with the timer already locked. * If we return TIMER_RETRY, it's necessary to release the timer's lock * and try again. (This happens when the timer is in the middle of firing.) */
static int posix_cpu_timer_del(struct k_itimer *timer) { int ret = 0; unsigned long flags; struct sighand_struct *sighand; struct task_struct *p = timer->it.cpu.task; WARN_ON_ONCE(p == NULL); /* * Protect against sighand release/switch in exit/exec and process/ * thread timer list entry concurrent read/writes. */ sighand = lock_task_sighand(p, &flags); if (unlikely(sighand == NULL)) { /* * We raced with the reaping of the task. * The deletion should have cleared us off the list. */ WARN_ON_ONCE(!list_empty(&timer->it.cpu.entry)); } else { if (timer->it.cpu.firing) ret = TIMER_RETRY; else list_del(&timer->it.cpu.entry); unlock_task_sighand(p, &flags); } if (!ret) put_task_struct(p); return ret; }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar8663.70%112.50%
Frédéric Weisbecker3022.22%337.50%
Roland McGrath1611.85%112.50%
Ingo Molnar10.74%112.50%
Thomas Gleixner10.74%112.50%
Oleg Nesterov10.74%112.50%
Total135100.00%8100.00%


static void cleanup_timers_list(struct list_head *head) { struct cpu_timer_list *timer, *next; list_for_each_entry_safe(timer, next, head, entry) list_del_init(&timer->entry); }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar1951.35%120.00%
Roland McGrath1437.84%240.00%
Martin Schwidefsky25.41%120.00%
Frédéric Weisbecker25.41%120.00%
Total37100.00%5100.00%

/* * Clean out CPU timers still ticking when a thread exited. The task * pointer is cleared, and the expiry time is replaced with the residual * time for later timer_gettime calls to return. * This must be called with the siglock held. */
static void cleanup_timers(struct list_head *head) { cleanup_timers_list(head); cleanup_timers_list(++head); cleanup_timers_list(++head); }

Contributors

PersonTokensPropCommitsCommitProp
Frédéric Weisbecker1967.86%250.00%
Roland McGrath517.86%125.00%
Frank Mayhar414.29%125.00%
Total28100.00%4100.00%

/* * These are both called with the siglock held, when the current thread * is being reaped. When the final (leader) thread in the group is reaped, * posix_cpu_timers_exit_group will be called after posix_cpu_timers_exit. */
void posix_cpu_timers_exit(struct task_struct *tsk) { cleanup_timers(tsk->cpu_timers); }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar1376.47%150.00%
Roland McGrath423.53%150.00%
Total17100.00%2100.00%


void posix_cpu_timers_exit_group(struct task_struct *tsk) { cleanup_timers(tsk->signal->cpu_timers); }

Contributors

PersonTokensPropCommitsCommitProp
Frank Mayhar1894.74%150.00%
Roland McGrath15.26%150.00%
Total19100.00%2100.00%


static inline int expires_gt(u64 expires, u64 new_exp) { return expires == 0 || expires > new_exp; }

Contributors

PersonTokensPropCommitsCommitProp
Stanislaw Gruszka1777.27%133.33%
Martin Schwidefsky313.64%133.33%
Frédéric Weisbecker29.09%133.33%
Total22100.00%3100.00%

/* * Insert the timer on the appropriate list before any timers that * expire later. This must be called with the sighand lock held. */
static void arm_timer(struct k_itimer *timer) { struct task_struct *p = timer->it.cpu.task; struct list_head *head, *listpos; struct task_cputime *cputime_expires; struct cpu_timer_list *const nt = &timer->it.cpu; struct cpu_timer_list *next; if (CPUCLOCK_PERTHREAD(timer->it_clock)) { head = p->cpu_timers; cputime_expires = &p->cputime_expires; } else { head = p->signal->cpu_timers; cputime_expires = &p->signal->cputime_expires; } head += CPUCLOCK_WHICH(timer->it_clock); listpos = head; list_for_each_entry(next, head, entry) { if (nt->expires < next->expires) break; listpos = &next->entry; } list_add(&nt->entry, listpos); if (listpos == head) { u64 exp = nt->expires; /* * We are the new earliest-expiring POSIX 1.b timer, hence * need to update expiration cache. Take into account that * for process timers we share expiration cache with itimers * and RLIMIT_CPU and for thread timers with RLIMIT_RTTIME. */ switch (CPUCLOCK_WHICH(timer->it_clock)) { case CPUCLOCK_PROF: if (expires_gt(cputime_expires->prof_exp, exp)) cputime_expires->prof_exp = exp; break; case CPUCLOCK_VIRT: if (expires_gt(cputime_expires->virt_exp, exp)) cputime_expires->virt_exp = exp; break; case CPUCLOCK_SCHED: if (expires_gt(cputime_expires->sched_exp, exp)) cputime_expires->sched_exp = exp; break; } if (CPUCLOCK_PERTHREAD(timer->it_clock)) tick_dep_set_task(p, TICK_DEP_BIT_POSIX_TIMER); else tick_dep_set_signal(p->signal, TICK_DEP_BIT_POSIX_TIMER); } }

Contributors

PersonTokensPropCommitsCommitProp
Roland McGrath14052.63%218.18%
Stanislaw Gruszka5319.92%327.27%
Frédéric Weisbecker3513.16%327.27%
Martin Schwidefsky238.65%19.09%
Frank Mayhar145.26%19.09%
Linus Torvalds10.38%19.09%
Total266100.00%11100.00%

/* * The timer is locked, fire it and arrange for its reload. */
static void cpu_timer_fire(struct k_itimer *timer) { if ((timer->it_sigev_notify & ~SIGEV_THREAD_ID) == SIGEV_NONE) { /* * User don't want any signal. */ timer->it.cpu.expires = 0; } else if (unlikely(timer->sigq == NULL)) { /* * This a special case for clock_nanosleep, * not a normal timer from sys_timer_create. */ wake_up_process(timer->it_process); timer->it.cpu.expires = 0; } else if (timer->it.cpu.incr == 0) { /* * One-shot timer. Clear it as soon as it's fired. */ posix_timer_event(timer, 0); timer->it.cpu.expires = 0; } else if (posix_timer_event(timer, ++timer->it_requeue_pending)) { /* * The signal did not get queued because the signal * was ignored, so we won't get any callback to * reload the timer. But we need to keep it * ticking in case the signal is deliverable next time. */ posix_cpu_timer_rearm(timer); ++timer->it_requeue_pending; } }

Contributors

PersonTokensPropCommitsCommitProp
Roland McGrath9574.22%240.00%
Stanislaw Gruszka2721.09%120.00%
Thomas Gleixner64.69%240.00%
Total128100.00%5100.00%

/* * Sample a process (thread group) timer for the given group_leader task. * Must be called with task sighand lock held for safe while_each_thread() * traversal. */
static int cpu_timer_sample_group(const clockid_t which_clock, struct task_struct *p, u64 *sample) { struct task_cputime cputime; thread_group_cputimer(p, &cputime); switch (CPUCLOCK_WHICH(which_clock)) { default: return -EINVAL; case CPUCLOCK_PROF: *sample = cputime.utime + cputime.stime; break; case CPUCLOCK_VIRT: *sample = cputime.utime; break; case CPUCLOCK_SCHED: *sample = cputime.sum_exec_runtime; break; } return 0; }

Contributors

PersonTokensPropCommitsCommitProp
Peter Zijlstra7588.24%125.00%
Frédéric Weisbecker910.59%250.00%
Martin Schwidefsky11.18%125.00%
Total85100.00%4100.00%

/* * Guts of sys_timer_settime for CPU timers. * This is called with the timer locked and interrupts disabled. * If we return TIMER_RETRY, it's necessary to release the timer's lock * and try again. (This happens when the timer is in the middle of firing.) */
static int posix_cpu_timer_set(struct k_itimer *timer, int timer_flags, struct itimerspec64 *new, struct itimerspec64 *old) { unsigned long flags; struct sighand_struct *sighand; struct task_struct *p = timer->it.cpu.task; u64 old_expires, new_expires, old_incr, val; int ret; WARN_ON_ONCE(p == NULL); /* * Use the to_ktime conversion because that clamps the maximum * value to KTIME_MAX and avoid multiplication overflows. */ new_expires = ktime_to_ns(timespec64_to_ktime(new->it_value)); /* * Protect against sighand release/switch in exit/exec and p->cpu_timers * and p->signal->cpu_timers read/write in arm_timer() */ sighand = lock_task_sighand(p, &flags); /* * If p has just been reaped, we can no * longer get any information about it at all. */ if (unlikely(sighand == NULL)) { return -ESRCH; } /* * Disarm any old timer after extracting its expiry time. */ lockdep_assert_irqs_disabled(); ret = 0; old_incr = timer->it.cpu.incr; old_expires = timer->it.cpu.expires; if (unlikely(timer->it.cpu.firing)) { timer->it.cpu.firing = -1; ret = TIMER_RETRY; } else list_del_init(&timer->it.cpu.entry); /* * We need to sample the current value to convert the new * value from to relative and absolute, and to convert the * old value from absolute to relative. To set a process * timer, we need a sample to balance the thread expiry * times (in arm_timer). With an absolute time, we must * check if it's already passed. In short, we need a sample. */ if (CPUCLOCK_PERTHREAD(timer->it_clock)) { cpu_clock_sample(timer->it_clock, p, &val); } else { cpu_timer_sample_group(timer->it_clock, p, &val); } if (old) { if (old_expires == 0) { old->it_value.tv_sec = 0; old->it_value.tv_nsec = 0; } else { /* * Update the timer in case it has * overrun already. If it has, * we'll report it as having overrun * and with the next reloaded timer * already ticking, though we are * swallowing that pending * notification here to install the * new setting. */ bump_cpu_timer(timer, val); if (val < timer->it.cpu.expires) { old_expires = timer->it.cpu.expires - val; old->it_value = ns_to_timespec64(old_expires); } else { old->it_value.tv_nsec = 1; old->it_value.tv_sec = 0; } } } if (unlikely(ret)) { /* * We are colliding with the timer actually firing. * Punt after filling in the timer's old value, and * disable this firing since we are already reporting * it as an overrun (thanks to bump_cpu_timer above). */ unlock_task_sighand(p, &flags); goto out; } if (new_expires != 0 && !(timer_flags & TIMER_ABSTIME)) { new_expires += val; } /* * Install the new expiry time (or zero). * For a timer with no notification action, we don't actually * arm the timer (we'll just fake it for timer_gettime). */ timer->it.cpu.expires = new_expires; if (new_expires != 0 && val < new_expires) { arm_timer(timer); } unlock_task_sighand(p, &flags); /* * Install the new reload setting, and * set up the signal and overrun bookkeeping. */ timer->it.cpu.incr = timespec64_to_ns(&new->it_interval); /* * This acts as a modification timestamp for the timer, * so any automatic reload attempt will punt on seeing * that we have reset the timer manually. */ timer->it_requeue_pending = (timer->it_requeue_pending + 2) & ~REQUEUE_PENDING; timer->it_overrun_last = 0; timer->it_overrun = -1; if (new_expires != 0 && !(val < new_expires)) { /* * The designated time already passed, so we notify * immediately, even if the thread never runs to * accumulate more time on this clock. */ cpu_timer_fire(timer); } ret = 0; out: if (old) old->it_interval = ns_to_timespec64(old_incr); return ret; }

Contributors

PersonTokensPropCommitsCommitProp
Roland McGrath36877.47%17.14%
Frédéric Weisbecker428.84%535.71%
Oleg Nesterov377.79%214.29%
Stanislaw Gruszka163.37%214.29%
Thomas Gleixner61.26%214.29%
Deepa Dinamani51.05%17.14%
Peter Zijlstra10.21%17.14%
Total475100.00%14100.00%


static void posix_cpu_timer_get(struct k_itimer *timer, struct itimerspec64 *itp) { u64 now; struct task_struct *p = timer->it.cpu.task; WARN_ON_ONCE(p == NULL); /* * Easy part: convert the reload time. */ itp->it_interval = ns_to_timespec64(timer->it.cpu.incr); if (!timer->it.cpu.expires) return; /* * Sample the clock to take the difference with the expiry time. */ if (CPUCLOCK_PERTHREAD(timer->it_clock)) { cpu_clock_sample(timer->it_clock, p, &now); } else { struct sighand_struct *sighand; unsigned long flags; /* * Protect against sighand release/switch in exit/exec and * also make timer sampling safe if it ends up calling * thread_group_cputime(). */ sighand = lock_task_sighand(p, &flags); if (unlikely(sighand