perf_counter: call atomic64_set for counter->count
[deliverable/linux.git] / kernel / perf_counter.c
index 4af98f943d3b504ef5d44bd5fa58e17676e91e3c..5ea0240adab230a65216ba0b5c137c7c74ed131b 100644 (file)
@@ -1,9 +1,10 @@
 /*
  * Performance counter core code
  *
- *  Copyright(C) 2008 Thomas Gleixner <tglx@linutronix.de>
- *  Copyright(C) 2008 Red Hat, Inc., Ingo Molnar
- *
+ *  Copyright (C) 2008 Thomas Gleixner <tglx@linutronix.de>
+ *  Copyright (C) 2008-2009 Red Hat, Inc., Ingo Molnar
+ *  Copyright (C) 2008-2009 Red Hat, Inc., Peter Zijlstra <pzijlstr@redhat.com>
+ *  Copyright  ©  2009 Paul Mackerras, IBM Corp. <paulus@au1.ibm.com>
  *
  *  For licensing details see kernel-base/COPYING
  */
@@ -38,16 +39,23 @@ int perf_max_counters __read_mostly = 1;
 static int perf_reserved_percpu __read_mostly;
 static int perf_overcommit __read_mostly = 1;
 
+static atomic_t nr_counters __read_mostly;
+static atomic_t nr_mmap_tracking __read_mostly;
+static atomic_t nr_munmap_tracking __read_mostly;
+static atomic_t nr_comm_tracking __read_mostly;
+
+int sysctl_perf_counter_priv __read_mostly; /* do we need to be privileged */
+int sysctl_perf_counter_mlock __read_mostly = 128; /* 'free' kb per counter */
+
 /*
- * Mutex for (sysadmin-configurable) counter reservations:
+ * Lock for (sysadmin-configurable) counter reservations:
  */
-static DEFINE_MUTEX(perf_resource_mutex);
+static DEFINE_SPINLOCK(perf_resource_lock);
 
 /*
  * Architecture provided APIs - weak aliases:
  */
-extern __weak const struct hw_perf_counter_ops *
-hw_perf_counter_init(struct perf_counter *counter)
+extern __weak const struct pmu *hw_perf_counter_init(struct perf_counter *counter)
 {
        return NULL;
 }
@@ -74,7 +82,7 @@ list_add_counter(struct perf_counter *counter, struct perf_counter_context *ctx)
         * add it straight to the context's counter list, or to the group
         * leader's sibling list:
         */
-       if (counter->group_leader == counter)
+       if (group_leader == counter)
                list_add_tail(&counter->list_entry, &ctx->counter_list);
        else {
                list_add_tail(&counter->list_entry, &group_leader->sibling_list);
@@ -118,7 +126,7 @@ counter_sched_out(struct perf_counter *counter,
 
        counter->state = PERF_COUNTER_STATE_INACTIVE;
        counter->tstamp_stopped = ctx->time;
-       counter->hw_ops->disable(counter);
+       counter->pmu->disable(counter);
        counter->oncpu = -1;
 
        if (!is_software_counter(counter))
@@ -377,24 +385,6 @@ static void perf_counter_disable(struct perf_counter *counter)
        spin_unlock_irq(&ctx->lock);
 }
 
-/*
- * Disable a counter and all its children.
- */
-static void perf_counter_disable_family(struct perf_counter *counter)
-{
-       struct perf_counter *child;
-
-       perf_counter_disable(counter);
-
-       /*
-        * Lock the mutex to protect the list of children
-        */
-       mutex_lock(&counter->mutex);
-       list_for_each_entry(child, &counter->child_list, child_list)
-               perf_counter_disable(child);
-       mutex_unlock(&counter->mutex);
-}
-
 static int
 counter_sched_in(struct perf_counter *counter,
                 struct perf_cpu_context *cpuctx,
@@ -411,7 +401,7 @@ counter_sched_in(struct perf_counter *counter,
         */
        smp_wmb();
 
-       if (counter->hw_ops->enable(counter)) {
+       if (counter->pmu->enable(counter)) {
                counter->state = PERF_COUNTER_STATE_INACTIVE;
                counter->oncpu = -1;
                return -EAGAIN;
@@ -429,6 +419,54 @@ counter_sched_in(struct perf_counter *counter,
        return 0;
 }
 
+static int
+group_sched_in(struct perf_counter *group_counter,
+              struct perf_cpu_context *cpuctx,
+              struct perf_counter_context *ctx,
+              int cpu)
+{
+       struct perf_counter *counter, *partial_group;
+       int ret;
+
+       if (group_counter->state == PERF_COUNTER_STATE_OFF)
+               return 0;
+
+       ret = hw_perf_group_sched_in(group_counter, cpuctx, ctx, cpu);
+       if (ret)
+               return ret < 0 ? ret : 0;
+
+       group_counter->prev_state = group_counter->state;
+       if (counter_sched_in(group_counter, cpuctx, ctx, cpu))
+               return -EAGAIN;
+
+       /*
+        * Schedule in siblings as one group (if any):
+        */
+       list_for_each_entry(counter, &group_counter->sibling_list, list_entry) {
+               counter->prev_state = counter->state;
+               if (counter_sched_in(counter, cpuctx, ctx, cpu)) {
+                       partial_group = counter;
+                       goto group_error;
+               }
+       }
+
+       return 0;
+
+group_error:
+       /*
+        * Groups can be scheduled in as one unit only, so undo any
+        * partial group before returning:
+        */
+       list_for_each_entry(counter, &group_counter->sibling_list, list_entry) {
+               if (counter == partial_group)
+                       break;
+               counter_sched_out(counter, cpuctx, ctx);
+       }
+       counter_sched_out(group_counter, cpuctx, ctx);
+
+       return -EAGAIN;
+}
+
 /*
  * Return 1 for a group consisting entirely of software counters,
  * 0 if the group contains any hardware counters.
@@ -653,6 +691,9 @@ static void __perf_counter_enable(void *info)
 
        if (!group_can_go_on(counter, cpuctx, 1))
                err = -EEXIST;
+       else if (counter == leader)
+               err = group_sched_in(counter, cpuctx, ctx,
+                                    smp_processor_id());
        else
                err = counter_sched_in(counter, cpuctx, ctx,
                                       smp_processor_id());
@@ -731,28 +772,18 @@ static void perf_counter_enable(struct perf_counter *counter)
        spin_unlock_irq(&ctx->lock);
 }
 
-static void perf_counter_refresh(struct perf_counter *counter, int refresh)
-{
-       atomic_add(refresh, &counter->event_limit);
-       perf_counter_enable(counter);
-}
-
-/*
- * Enable a counter and all its children.
- */
-static void perf_counter_enable_family(struct perf_counter *counter)
+static int perf_counter_refresh(struct perf_counter *counter, int refresh)
 {
-       struct perf_counter *child;
+       /*
+        * not supported on inherited counters
+        */
+       if (counter->hw_event.inherit)
+               return -EINVAL;
 
+       atomic_add(refresh, &counter->event_limit);
        perf_counter_enable(counter);
 
-       /*
-        * Lock the mutex to protect the list of children
-        */
-       mutex_lock(&counter->mutex);
-       list_for_each_entry(child, &counter->child_list, child_list)
-               perf_counter_enable(child);
-       mutex_unlock(&counter->mutex);
+       return 0;
 }
 
 void __perf_counter_sched_out(struct perf_counter_context *ctx,
@@ -800,63 +831,23 @@ void perf_counter_task_sched_out(struct task_struct *task, int cpu)
        update_context_time(ctx);
 
        regs = task_pt_regs(task);
-       perf_swcounter_event(PERF_COUNT_CONTEXT_SWITCHES, 1, 1, regs);
+       perf_swcounter_event(PERF_COUNT_CONTEXT_SWITCHES, 1, 1, regs, 0);
        __perf_counter_sched_out(ctx, cpuctx);
 
        cpuctx->task_ctx = NULL;
 }
 
-static void perf_counter_cpu_sched_out(struct perf_cpu_context *cpuctx)
+static void __perf_counter_task_sched_out(struct perf_counter_context *ctx)
 {
-       __perf_counter_sched_out(&cpuctx->ctx, cpuctx);
+       struct perf_cpu_context *cpuctx = &__get_cpu_var(perf_cpu_context);
+
+       __perf_counter_sched_out(ctx, cpuctx);
+       cpuctx->task_ctx = NULL;
 }
 
-static int
-group_sched_in(struct perf_counter *group_counter,
-              struct perf_cpu_context *cpuctx,
-              struct perf_counter_context *ctx,
-              int cpu)
+static void perf_counter_cpu_sched_out(struct perf_cpu_context *cpuctx)
 {
-       struct perf_counter *counter, *partial_group;
-       int ret;
-
-       if (group_counter->state == PERF_COUNTER_STATE_OFF)
-               return 0;
-
-       ret = hw_perf_group_sched_in(group_counter, cpuctx, ctx, cpu);
-       if (ret)
-               return ret < 0 ? ret : 0;
-
-       group_counter->prev_state = group_counter->state;
-       if (counter_sched_in(group_counter, cpuctx, ctx, cpu))
-               return -EAGAIN;
-
-       /*
-        * Schedule in siblings as one group (if any):
-        */
-       list_for_each_entry(counter, &group_counter->sibling_list, list_entry) {
-               counter->prev_state = counter->state;
-               if (counter_sched_in(counter, cpuctx, ctx, cpu)) {
-                       partial_group = counter;
-                       goto group_error;
-               }
-       }
-
-       return 0;
-
-group_error:
-       /*
-        * Groups can be scheduled in as one unit only, so undo any
-        * partial group before returning:
-        */
-       list_for_each_entry(counter, &group_counter->sibling_list, list_entry) {
-               if (counter == partial_group)
-                       break;
-               counter_sched_out(counter, cpuctx, ctx);
-       }
-       counter_sched_out(group_counter, cpuctx, ctx);
-
-       return -EAGAIN;
+       __perf_counter_sched_out(&cpuctx->ctx, cpuctx);
 }
 
 static void
@@ -960,15 +951,13 @@ int perf_counter_task_disable(void)
        struct perf_counter *counter;
        unsigned long flags;
        u64 perf_flags;
-       int cpu;
 
        if (likely(!ctx->nr_counters))
                return 0;
 
        local_irq_save(flags);
-       cpu = smp_processor_id();
 
-       perf_counter_task_sched_out(curr, cpu);
+       __perf_counter_task_sched_out(ctx);
 
        spin_lock(&ctx->lock);
 
@@ -1006,7 +995,7 @@ int perf_counter_task_enable(void)
        local_irq_save(flags);
        cpu = smp_processor_id();
 
-       perf_counter_task_sched_out(curr, cpu);
+       __perf_counter_task_sched_out(ctx);
 
        spin_lock(&ctx->lock);
 
@@ -1061,20 +1050,22 @@ static void rotate_ctx(struct perf_counter_context *ctx)
 
 void perf_counter_task_tick(struct task_struct *curr, int cpu)
 {
-       struct perf_cpu_context *cpuctx = &per_cpu(perf_cpu_context, cpu);
-       struct perf_counter_context *ctx = &curr->perf_counter_ctx;
-       const int rotate_percpu = 0;
+       struct perf_cpu_context *cpuctx;
+       struct perf_counter_context *ctx;
+
+       if (!atomic_read(&nr_counters))
+               return;
+
+       cpuctx = &per_cpu(perf_cpu_context, cpu);
+       ctx = &curr->perf_counter_ctx;
 
-       if (rotate_percpu)
-               perf_counter_cpu_sched_out(cpuctx);
-       perf_counter_task_sched_out(curr, cpu);
+       perf_counter_cpu_sched_out(cpuctx);
+       __perf_counter_task_sched_out(ctx);
 
-       if (rotate_percpu)
-               rotate_ctx(&cpuctx->ctx);
+       rotate_ctx(&cpuctx->ctx);
        rotate_ctx(ctx);
 
-       if (rotate_percpu)
-               perf_counter_cpu_sched_in(cpuctx, cpu);
+       perf_counter_cpu_sched_in(cpuctx, cpu);
        perf_counter_task_sched_in(curr, cpu);
 }
 
@@ -1090,7 +1081,7 @@ static void __read(void *info)
        local_irq_save(flags);
        if (ctx->is_active)
                update_context_time(ctx);
-       counter->hw_ops->read(counter);
+       counter->pmu->read(counter);
        update_counter_times(counter);
        local_irq_restore(flags);
 }
@@ -1128,7 +1119,7 @@ static struct perf_counter_context *find_get_context(pid_t pid, int cpu)
         */
        if (cpu != -1) {
                /* Must be root to operate on a CPU counter: */
-               if (!capable(CAP_SYS_ADMIN))
+               if (sysctl_perf_counter_priv && !capable(CAP_SYS_ADMIN))
                        return ERR_PTR(-EACCES);
 
                if (cpu < 0 || cpu > num_possible_cpus())
@@ -1186,6 +1177,14 @@ static void free_counter(struct perf_counter *counter)
 {
        perf_pending_sync(counter);
 
+       atomic_dec(&nr_counters);
+       if (counter->hw_event.mmap)
+               atomic_dec(&nr_mmap_tracking);
+       if (counter->hw_event.munmap)
+               atomic_dec(&nr_munmap_tracking);
+       if (counter->hw_event.comm)
+               atomic_dec(&nr_comm_tracking);
+
        if (counter->destroy)
                counter->destroy(counter);
 
@@ -1266,14 +1265,12 @@ static unsigned int perf_poll(struct file *file, poll_table *wait)
 {
        struct perf_counter *counter = file->private_data;
        struct perf_mmap_data *data;
-       unsigned int events;
+       unsigned int events = POLL_HUP;
 
        rcu_read_lock();
        data = rcu_dereference(counter->data);
        if (data)
-               events = atomic_xchg(&data->wakeup, 0);
-       else
-               events = POLL_HUP;
+               events = atomic_xchg(&data->poll, 0);
        rcu_read_unlock();
 
        poll_wait(file, &counter->waitq, wait);
@@ -1281,25 +1278,81 @@ static unsigned int perf_poll(struct file *file, poll_table *wait)
        return events;
 }
 
+static void perf_counter_reset(struct perf_counter *counter)
+{
+       (void)perf_counter_read(counter);
+       atomic64_set(&counter->count, 0);
+       perf_counter_update_userpage(counter);
+}
+
+static void perf_counter_for_each_sibling(struct perf_counter *counter,
+                                         void (*func)(struct perf_counter *))
+{
+       struct perf_counter_context *ctx = counter->ctx;
+       struct perf_counter *sibling;
+
+       spin_lock_irq(&ctx->lock);
+       counter = counter->group_leader;
+
+       func(counter);
+       list_for_each_entry(sibling, &counter->sibling_list, list_entry)
+               func(sibling);
+       spin_unlock_irq(&ctx->lock);
+}
+
+static void perf_counter_for_each_child(struct perf_counter *counter,
+                                       void (*func)(struct perf_counter *))
+{
+       struct perf_counter *child;
+
+       mutex_lock(&counter->mutex);
+       func(counter);
+       list_for_each_entry(child, &counter->child_list, child_list)
+               func(child);
+       mutex_unlock(&counter->mutex);
+}
+
+static void perf_counter_for_each(struct perf_counter *counter,
+                                 void (*func)(struct perf_counter *))
+{
+       struct perf_counter *child;
+
+       mutex_lock(&counter->mutex);
+       perf_counter_for_each_sibling(counter, func);
+       list_for_each_entry(child, &counter->child_list, child_list)
+               perf_counter_for_each_sibling(child, func);
+       mutex_unlock(&counter->mutex);
+}
+
 static long perf_ioctl(struct file *file, unsigned int cmd, unsigned long arg)
 {
        struct perf_counter *counter = file->private_data;
-       int err = 0;
+       void (*func)(struct perf_counter *);
+       u32 flags = arg;
 
        switch (cmd) {
        case PERF_COUNTER_IOC_ENABLE:
-               perf_counter_enable_family(counter);
+               func = perf_counter_enable;
                break;
        case PERF_COUNTER_IOC_DISABLE:
-               perf_counter_disable_family(counter);
+               func = perf_counter_disable;
                break;
-       case PERF_COUNTER_IOC_REFRESH:
-               perf_counter_refresh(counter, arg);
+       case PERF_COUNTER_IOC_RESET:
+               func = perf_counter_reset;
                break;
+
+       case PERF_COUNTER_IOC_REFRESH:
+               return perf_counter_refresh(counter, arg);
        default:
-               err = -ENOTTY;
+               return -ENOTTY;
        }
-       return err;
+
+       if (flags & PERF_IOC_FLAG_GROUP)
+               perf_counter_for_each(counter, func);
+       else
+               perf_counter_for_each_child(counter, func);
+
+       return 0;
 }
 
 /*
@@ -1393,6 +1446,7 @@ static int perf_mmap_data_alloc(struct perf_counter *counter, int nr_pages)
        }
 
        data->nr_pages = nr_pages;
+       atomic_set(&data->lock, -1);
 
        rcu_assign_pointer(counter->data, data);
 
@@ -1446,7 +1500,7 @@ static void perf_mmap_close(struct vm_area_struct *vma)
 
        if (atomic_dec_and_mutex_lock(&counter->mmap_count,
                                      &counter->mmap_mutex)) {
-               vma->vm_mm->locked_vm -= counter->data->nr_pages + 1;
+               vma->vm_mm->locked_vm -= counter->data->nr_locked;
                perf_mmap_data_free(counter);
                mutex_unlock(&counter->mmap_mutex);
        }
@@ -1465,6 +1519,7 @@ static int perf_mmap(struct file *file, struct vm_area_struct *vma)
        unsigned long nr_pages;
        unsigned long locked, lock_limit;
        int ret = 0;
+       long extra;
 
        if (!(vma->vm_flags & VM_SHARED) || (vma->vm_flags & VM_WRITE))
                return -EINVAL;
@@ -1492,8 +1547,12 @@ static int perf_mmap(struct file *file, struct vm_area_struct *vma)
                goto unlock;
        }
 
-       locked = vma->vm_mm->locked_vm;
-       locked += nr_pages + 1;
+       extra = nr_pages /* + 1 only account the data pages */;
+       extra -= sysctl_perf_counter_mlock >> (PAGE_SHIFT - 10);
+       if (extra < 0)
+               extra = 0;
+
+       locked = vma->vm_mm->locked_vm + extra;
 
        lock_limit = current->signal->rlim[RLIMIT_MEMLOCK].rlim_cur;
        lock_limit >>= PAGE_SHIFT;
@@ -1509,7 +1568,8 @@ static int perf_mmap(struct file *file, struct vm_area_struct *vma)
                goto unlock;
 
        atomic_set(&counter->mmap_count, 1);
-       vma->vm_mm->locked_vm += nr_pages + 1;
+       vma->vm_mm->locked_vm += extra;
+       counter->data->nr_locked = extra;
 unlock:
        mutex_unlock(&counter->mmap_mutex);
 
@@ -1555,22 +1615,6 @@ static const struct file_operations perf_fops = {
 
 void perf_counter_wakeup(struct perf_counter *counter)
 {
-       struct perf_mmap_data *data;
-
-       rcu_read_lock();
-       data = rcu_dereference(counter->data);
-       if (data) {
-               atomic_set(&data->wakeup, POLL_IN);
-               /*
-                * Ensure all data writes are issued before updating the
-                * user-space data head information. The matching rmb()
-                * will be in userspace after reading this value.
-                */
-               smp_wmb();
-               data->user_page->data_head = atomic_read(&data->head);
-       }
-       rcu_read_unlock();
-
        wake_up_all(&counter->waitq);
 
        if (counter->pending_kill) {
@@ -1705,13 +1749,16 @@ struct perf_output_handle {
        struct perf_mmap_data   *data;
        unsigned int            offset;
        unsigned int            head;
-       int                     wakeup;
        int                     nmi;
        int                     overflow;
+       int                     locked;
+       unsigned long           flags;
 };
 
-static inline void __perf_output_wakeup(struct perf_output_handle *handle)
+static void perf_output_wakeup(struct perf_output_handle *handle)
 {
+       atomic_set(&handle->data->poll, POLL_IN);
+
        if (handle->nmi) {
                handle->counter->pending_wakeup = 1;
                perf_pending_queue(&handle->counter->pending,
@@ -1720,6 +1767,83 @@ static inline void __perf_output_wakeup(struct perf_output_handle *handle)
                perf_counter_wakeup(handle->counter);
 }
 
+/*
+ * Curious locking construct.
+ *
+ * We need to ensure a later event doesn't publish a head when a former
+ * event isn't done writing. However since we need to deal with NMIs we
+ * cannot fully serialize things.
+ *
+ * What we do is serialize between CPUs so we only have to deal with NMI
+ * nesting on a single CPU.
+ *
+ * We only publish the head (and generate a wakeup) when the outer-most
+ * event completes.
+ */
+static void perf_output_lock(struct perf_output_handle *handle)
+{
+       struct perf_mmap_data *data = handle->data;
+       int cpu;
+
+       handle->locked = 0;
+
+       local_irq_save(handle->flags);
+       cpu = smp_processor_id();
+
+       if (in_nmi() && atomic_read(&data->lock) == cpu)
+               return;
+
+       while (atomic_cmpxchg(&data->lock, -1, cpu) != -1)
+               cpu_relax();
+
+       handle->locked = 1;
+}
+
+static void perf_output_unlock(struct perf_output_handle *handle)
+{
+       struct perf_mmap_data *data = handle->data;
+       int head, cpu;
+
+       data->done_head = data->head;
+
+       if (!handle->locked)
+               goto out;
+
+again:
+       /*
+        * The xchg implies a full barrier that ensures all writes are done
+        * before we publish the new head, matched by a rmb() in userspace when
+        * reading this position.
+        */
+       while ((head = atomic_xchg(&data->done_head, 0)))
+               data->user_page->data_head = head;
+
+       /*
+        * NMI can happen here, which means we can miss a done_head update.
+        */
+
+       cpu = atomic_xchg(&data->lock, -1);
+       WARN_ON_ONCE(cpu != smp_processor_id());
+
+       /*
+        * Therefore we have to validate we did not indeed do so.
+        */
+       if (unlikely(atomic_read(&data->done_head))) {
+               /*
+                * Since we had it locked, we can lock it again.
+                */
+               while (atomic_cmpxchg(&data->lock, -1, cpu) != -1)
+                       cpu_relax();
+
+               goto again;
+       }
+
+       if (atomic_xchg(&data->wakeup, 0))
+               perf_output_wakeup(handle);
+out:
+       local_irq_restore(handle->flags);
+}
+
 static int perf_output_begin(struct perf_output_handle *handle,
                             struct perf_counter *counter, unsigned int size,
                             int nmi, int overflow)
@@ -1727,11 +1851,18 @@ static int perf_output_begin(struct perf_output_handle *handle,
        struct perf_mmap_data *data;
        unsigned int offset, head;
 
+       /*
+        * For inherited counters we send all the output towards the parent.
+        */
+       if (counter->parent)
+               counter = counter->parent;
+
        rcu_read_lock();
        data = rcu_dereference(counter->data);
        if (!data)
                goto out;
 
+       handle->data     = data;
        handle->counter  = counter;
        handle->nmi      = nmi;
        handle->overflow = overflow;
@@ -1739,20 +1870,23 @@ static int perf_output_begin(struct perf_output_handle *handle,
        if (!data->nr_pages)
                goto fail;
 
+       perf_output_lock(handle);
+
        do {
                offset = head = atomic_read(&data->head);
                head += size;
        } while (atomic_cmpxchg(&data->head, offset, head) != offset);
 
-       handle->data    = data;
        handle->offset  = offset;
        handle->head    = head;
-       handle->wakeup  = (offset >> PAGE_SHIFT) != (head >> PAGE_SHIFT);
+
+       if ((offset >> PAGE_SHIFT) != (head >> PAGE_SHIFT))
+               atomic_set(&data->wakeup, 1);
 
        return 0;
 
 fail:
-       __perf_output_wakeup(handle);
+       perf_output_wakeup(handle);
 out:
        rcu_read_unlock();
 
@@ -1796,21 +1930,25 @@ static void perf_output_copy(struct perf_output_handle *handle,
 
 static void perf_output_end(struct perf_output_handle *handle)
 {
-       int wakeup_events = handle->counter->hw_event.wakeup_events;
+       struct perf_counter *counter = handle->counter;
+       struct perf_mmap_data *data = handle->data;
+
+       int wakeup_events = counter->hw_event.wakeup_events;
 
        if (handle->overflow && wakeup_events) {
-               int events = atomic_inc_return(&handle->data->events);
+               int events = atomic_inc_return(&data->events);
                if (events >= wakeup_events) {
-                       atomic_sub(wakeup_events, &handle->data->events);
-                       __perf_output_wakeup(handle);
+                       atomic_sub(wakeup_events, &data->events);
+                       atomic_set(&data->wakeup, 1);
                }
-       } else if (handle->wakeup)
-               __perf_output_wakeup(handle);
+       }
+
+       perf_output_unlock(handle);
        rcu_read_unlock();
 }
 
 static void perf_counter_output(struct perf_counter *counter,
-                               int nmi, struct pt_regs *regs)
+                               int nmi, struct pt_regs *regs, u64 addr)
 {
        int ret;
        u64 record_type = counter->hw_event.record_type;
@@ -1827,16 +1965,20 @@ static void perf_counter_output(struct perf_counter *counter,
        struct perf_callchain_entry *callchain = NULL;
        int callchain_size = 0;
        u64 time;
+       struct {
+               u32 cpu, reserved;
+       } cpu_entry;
 
-       header.type = PERF_EVENT_COUNTER_OVERFLOW;
+       header.type = 0;
        header.size = sizeof(header);
 
-       header.misc = user_mode(regs) ?
+       header.misc = PERF_EVENT_MISC_OVERFLOW;
+       header.misc |= user_mode(regs) ?
                PERF_EVENT_MISC_USER : PERF_EVENT_MISC_KERNEL;
 
        if (record_type & PERF_RECORD_IP) {
                ip = instruction_pointer(regs);
-               header.type |= __PERF_EVENT_IP;
+               header.type |= PERF_RECORD_IP;
                header.size += sizeof(ip);
        }
 
@@ -1845,12 +1987,39 @@ static void perf_counter_output(struct perf_counter *counter,
                tid_entry.pid = current->group_leader->pid;
                tid_entry.tid = current->pid;
 
-               header.type |= __PERF_EVENT_TID;
+               header.type |= PERF_RECORD_TID;
                header.size += sizeof(tid_entry);
        }
 
+       if (record_type & PERF_RECORD_TIME) {
+               /*
+                * Maybe do better on x86 and provide cpu_clock_nmi()
+                */
+               time = sched_clock();
+
+               header.type |= PERF_RECORD_TIME;
+               header.size += sizeof(u64);
+       }
+
+       if (record_type & PERF_RECORD_ADDR) {
+               header.type |= PERF_RECORD_ADDR;
+               header.size += sizeof(u64);
+       }
+
+       if (record_type & PERF_RECORD_CONFIG) {
+               header.type |= PERF_RECORD_CONFIG;
+               header.size += sizeof(u64);
+       }
+
+       if (record_type & PERF_RECORD_CPU) {
+               header.type |= PERF_RECORD_CPU;
+               header.size += sizeof(cpu_entry);
+
+               cpu_entry.cpu = raw_smp_processor_id();
+       }
+
        if (record_type & PERF_RECORD_GROUP) {
-               header.type |= __PERF_EVENT_GROUP;
+               header.type |= PERF_RECORD_GROUP;
                header.size += sizeof(u64) +
                        counter->nr_siblings * sizeof(group_entry);
        }
@@ -1861,21 +2030,11 @@ static void perf_counter_output(struct perf_counter *counter,
                if (callchain) {
                        callchain_size = (1 + callchain->nr) * sizeof(u64);
 
-                       header.type |= __PERF_EVENT_CALLCHAIN;
+                       header.type |= PERF_RECORD_CALLCHAIN;
                        header.size += callchain_size;
                }
        }
 
-       if (record_type & PERF_RECORD_TIME) {
-               /*
-                * Maybe do better on x86 and provide cpu_clock_nmi()
-                */
-               time = sched_clock();
-
-               header.type |= __PERF_EVENT_TIME;
-               header.size += sizeof(u64);
-       }
-
        ret = perf_output_begin(&handle, counter, header.size, nmi, 1);
        if (ret)
                return;
@@ -1888,6 +2047,21 @@ static void perf_counter_output(struct perf_counter *counter,
        if (record_type & PERF_RECORD_TID)
                perf_output_put(&handle, tid_entry);
 
+       if (record_type & PERF_RECORD_TIME)
+               perf_output_put(&handle, time);
+
+       if (record_type & PERF_RECORD_ADDR)
+               perf_output_put(&handle, addr);
+
+       if (record_type & PERF_RECORD_CONFIG)
+               perf_output_put(&handle, counter->hw_event.config);
+
+       if (record_type & PERF_RECORD_CPU)
+               perf_output_put(&handle, cpu_entry);
+
+       /*
+        * XXX PERF_RECORD_GROUP vs inherited counters seems difficult.
+        */
        if (record_type & PERF_RECORD_GROUP) {
                struct perf_counter *leader, *sub;
                u64 nr = counter->nr_siblings;
@@ -1897,7 +2071,7 @@ static void perf_counter_output(struct perf_counter *counter,
                leader = counter->group_leader;
                list_for_each_entry(sub, &leader->sibling_list, list_entry) {
                        if (sub != counter)
-                               sub->hw_ops->read(sub);
+                               sub->pmu->read(sub);
 
                        group_entry.event = sub->hw_event.config;
                        group_entry.counter = atomic64_read(&sub->count);
@@ -1909,12 +2083,107 @@ static void perf_counter_output(struct perf_counter *counter,
        if (callchain)
                perf_output_copy(&handle, callchain, callchain_size);
 
-       if (record_type & PERF_RECORD_TIME)
-               perf_output_put(&handle, time);
+       perf_output_end(&handle);
+}
+
+/*
+ * comm tracking
+ */
+
+struct perf_comm_event {
+       struct task_struct      *task;
+       char                    *comm;
+       int                     comm_size;
+
+       struct {
+               struct perf_event_header        header;
+
+               u32                             pid;
+               u32                             tid;
+       } event;
+};
+
+static void perf_counter_comm_output(struct perf_counter *counter,
+                                    struct perf_comm_event *comm_event)
+{
+       struct perf_output_handle handle;
+       int size = comm_event->event.header.size;
+       int ret = perf_output_begin(&handle, counter, size, 0, 0);
+
+       if (ret)
+               return;
 
+       perf_output_put(&handle, comm_event->event);
+       perf_output_copy(&handle, comm_event->comm,
+                                  comm_event->comm_size);
        perf_output_end(&handle);
 }
 
+static int perf_counter_comm_match(struct perf_counter *counter,
+                                  struct perf_comm_event *comm_event)
+{
+       if (counter->hw_event.comm &&
+           comm_event->event.header.type == PERF_EVENT_COMM)
+               return 1;
+
+       return 0;
+}
+
+static void perf_counter_comm_ctx(struct perf_counter_context *ctx,
+                                 struct perf_comm_event *comm_event)
+{
+       struct perf_counter *counter;
+
+       if (system_state != SYSTEM_RUNNING || list_empty(&ctx->event_list))
+               return;
+
+       rcu_read_lock();
+       list_for_each_entry_rcu(counter, &ctx->event_list, event_entry) {
+               if (perf_counter_comm_match(counter, comm_event))
+                       perf_counter_comm_output(counter, comm_event);
+       }
+       rcu_read_unlock();
+}
+
+static void perf_counter_comm_event(struct perf_comm_event *comm_event)
+{
+       struct perf_cpu_context *cpuctx;
+       unsigned int size;
+       char *comm = comm_event->task->comm;
+
+       size = ALIGN(strlen(comm)+1, sizeof(u64));
+
+       comm_event->comm = comm;
+       comm_event->comm_size = size;
+
+       comm_event->event.header.size = sizeof(comm_event->event) + size;
+
+       cpuctx = &get_cpu_var(perf_cpu_context);
+       perf_counter_comm_ctx(&cpuctx->ctx, comm_event);
+       put_cpu_var(perf_cpu_context);
+
+       perf_counter_comm_ctx(&current->perf_counter_ctx, comm_event);
+}
+
+void perf_counter_comm(struct task_struct *task)
+{
+       struct perf_comm_event comm_event;
+
+       if (!atomic_read(&nr_comm_tracking))
+               return;
+       
+       comm_event = (struct perf_comm_event){
+               .task   = task,
+               .event  = {
+                       .header = { .type = PERF_EVENT_COMM, },
+                       .pid    = task->group_leader->pid,
+                       .tid    = task->pid,
+               },
+       };
+
+       perf_counter_comm_event(&comm_event);
+}
+
 /*
  * mmap tracking
  */
@@ -1996,7 +2265,7 @@ static void perf_counter_mmap_event(struct perf_mmap_event *mmap_event)
                        name = strncpy(tmp, "//enomem", sizeof(tmp));
                        goto got_name;
                }
-               name = dentry_path(file->f_dentry, buf, PATH_MAX);
+               name = d_path(&file->f_path, buf, PATH_MAX);
                if (IS_ERR(name)) {
                        name = strncpy(tmp, "//toolong", sizeof(tmp));
                        goto got_name;
@@ -2007,7 +2276,7 @@ static void perf_counter_mmap_event(struct perf_mmap_event *mmap_event)
        }
 
 got_name:
-       size = ALIGN(strlen(name), sizeof(u64));
+       size = ALIGN(strlen(name)+1, sizeof(u64));
 
        mmap_event->file_name = name;
        mmap_event->file_size = size;
@@ -2026,7 +2295,12 @@ got_name:
 void perf_counter_mmap(unsigned long addr, unsigned long len,
                       unsigned long pgoff, struct file *file)
 {
-       struct perf_mmap_event mmap_event = {
+       struct perf_mmap_event mmap_event;
+
+       if (!atomic_read(&nr_mmap_tracking))
+               return;
+
+       mmap_event = (struct perf_mmap_event){
                .file   = file,
                .event  = {
                        .header = { .type = PERF_EVENT_MMAP, },
@@ -2044,7 +2318,12 @@ void perf_counter_mmap(unsigned long addr, unsigned long len,
 void perf_counter_munmap(unsigned long addr, unsigned long len,
                         unsigned long pgoff, struct file *file)
 {
-       struct perf_mmap_event mmap_event = {
+       struct perf_mmap_event mmap_event;
+
+       if (!atomic_read(&nr_munmap_tracking))
+               return;
+
+       mmap_event = (struct perf_mmap_event){
                .file   = file,
                .event  = {
                        .header = { .type = PERF_EVENT_MUNMAP, },
@@ -2064,11 +2343,16 @@ void perf_counter_munmap(unsigned long addr, unsigned long len,
  */
 
 int perf_counter_overflow(struct perf_counter *counter,
-                         int nmi, struct pt_regs *regs)
+                         int nmi, struct pt_regs *regs, u64 addr)
 {
        int events = atomic_read(&counter->event_limit);
        int ret = 0;
 
+       /*
+        * XXX event_limit might not quite work as expected on inherited
+        * counters
+        */
+
        counter->pending_kill = POLL_IN;
        if (events && atomic_dec_and_test(&counter->event_limit)) {
                ret = 1;
@@ -2081,7 +2365,7 @@ int perf_counter_overflow(struct perf_counter *counter,
                        perf_counter_disable(counter);
        }
 
-       perf_counter_output(counter, nmi, regs);
+       perf_counter_output(counter, nmi, regs, addr);
        return ret;
 }
 
@@ -2134,7 +2418,7 @@ static enum hrtimer_restart perf_swcounter_hrtimer(struct hrtimer *hrtimer)
        struct pt_regs *regs;
 
        counter = container_of(hrtimer, struct perf_counter, hw.hrtimer);
-       counter->hw_ops->read(counter);
+       counter->pmu->read(counter);
 
        regs = get_irq_regs();
        /*
@@ -2146,7 +2430,7 @@ static enum hrtimer_restart perf_swcounter_hrtimer(struct hrtimer *hrtimer)
                regs = task_pt_regs(current);
 
        if (regs) {
-               if (perf_counter_overflow(counter, 0, regs))
+               if (perf_counter_overflow(counter, 0, regs, 0))
                        ret = HRTIMER_NORESTART;
        }
 
@@ -2156,11 +2440,11 @@ static enum hrtimer_restart perf_swcounter_hrtimer(struct hrtimer *hrtimer)
 }
 
 static void perf_swcounter_overflow(struct perf_counter *counter,
-                                   int nmi, struct pt_regs *regs)
+                                   int nmi, struct pt_regs *regs, u64 addr)
 {
        perf_swcounter_update(counter);
        perf_swcounter_set_period(counter);
-       if (perf_counter_overflow(counter, nmi, regs))
+       if (perf_counter_overflow(counter, nmi, regs, addr))
                /* soft-disable the counter */
                ;
 
@@ -2192,16 +2476,17 @@ static int perf_swcounter_match(struct perf_counter *counter,
 }
 
 static void perf_swcounter_add(struct perf_counter *counter, u64 nr,
-                              int nmi, struct pt_regs *regs)
+                              int nmi, struct pt_regs *regs, u64 addr)
 {
        int neg = atomic64_add_negative(nr, &counter->hw.count);
        if (counter->hw.irq_period && !neg)
-               perf_swcounter_overflow(counter, nmi, regs);
+               perf_swcounter_overflow(counter, nmi, regs, addr);
 }
 
 static void perf_swcounter_ctx_event(struct perf_counter_context *ctx,
                                     enum perf_event_types type, u32 event,
-                                    u64 nr, int nmi, struct pt_regs *regs)
+                                    u64 nr, int nmi, struct pt_regs *regs,
+                                    u64 addr)
 {
        struct perf_counter *counter;
 
@@ -2211,7 +2496,7 @@ static void perf_swcounter_ctx_event(struct perf_counter_context *ctx,
        rcu_read_lock();
        list_for_each_entry_rcu(counter, &ctx->event_list, event_entry) {
                if (perf_swcounter_match(counter, type, event, regs))
-                       perf_swcounter_add(counter, nr, nmi, regs);
+                       perf_swcounter_add(counter, nr, nmi, regs, addr);
        }
        rcu_read_unlock();
 }
@@ -2231,7 +2516,8 @@ static int *perf_swcounter_recursion_context(struct perf_cpu_context *cpuctx)
 }
 
 static void __perf_swcounter_event(enum perf_event_types type, u32 event,
-                                  u64 nr, int nmi, struct pt_regs *regs)
+                                  u64 nr, int nmi, struct pt_regs *regs,
+                                  u64 addr)
 {
        struct perf_cpu_context *cpuctx = &get_cpu_var(perf_cpu_context);
        int *recursion = perf_swcounter_recursion_context(cpuctx);
@@ -2242,10 +2528,11 @@ static void __perf_swcounter_event(enum perf_event_types type, u32 event,
        (*recursion)++;
        barrier();
 
-       perf_swcounter_ctx_event(&cpuctx->ctx, type, event, nr, nmi, regs);
+       perf_swcounter_ctx_event(&cpuctx->ctx, type, event,
+                                nr, nmi, regs, addr);
        if (cpuctx->task_ctx) {
                perf_swcounter_ctx_event(cpuctx->task_ctx, type, event,
-                               nr, nmi, regs);
+                                        nr, nmi, regs, addr);
        }
 
        barrier();
@@ -2255,9 +2542,10 @@ out:
        put_cpu_var(perf_cpu_context);
 }
 
-void perf_swcounter_event(u32 event, u64 nr, int nmi, struct pt_regs *regs)
+void
+perf_swcounter_event(u32 event, u64 nr, int nmi, struct pt_regs *regs, u64 addr)
 {
-       __perf_swcounter_event(PERF_TYPE_SOFTWARE, event, nr, nmi, regs);
+       __perf_swcounter_event(PERF_TYPE_SOFTWARE, event, nr, nmi, regs, addr);
 }
 
 static void perf_swcounter_read(struct perf_counter *counter)
@@ -2276,7 +2564,7 @@ static void perf_swcounter_disable(struct perf_counter *counter)
        perf_swcounter_update(counter);
 }
 
-static const struct hw_perf_counter_ops perf_ops_generic = {
+static const struct pmu perf_ops_generic = {
        .enable         = perf_swcounter_enable,
        .disable        = perf_swcounter_disable,
        .read           = perf_swcounter_read,
@@ -2326,7 +2614,7 @@ static void cpu_clock_perf_counter_read(struct perf_counter *counter)
        cpu_clock_perf_counter_update(counter);
 }
 
-static const struct hw_perf_counter_ops perf_ops_cpu_clock = {
+static const struct pmu perf_ops_cpu_clock = {
        .enable         = cpu_clock_perf_counter_enable,
        .disable        = cpu_clock_perf_counter_disable,
        .read           = cpu_clock_perf_counter_read,
@@ -2388,7 +2676,7 @@ static void task_clock_perf_counter_read(struct perf_counter *counter)
        task_clock_perf_counter_update(counter, time);
 }
 
-static const struct hw_perf_counter_ops perf_ops_task_clock = {
+static const struct pmu perf_ops_task_clock = {
        .enable         = task_clock_perf_counter_enable,
        .disable        = task_clock_perf_counter_disable,
        .read           = task_clock_perf_counter_read,
@@ -2440,7 +2728,7 @@ static void cpu_migrations_perf_counter_disable(struct perf_counter *counter)
        cpu_migrations_perf_counter_update(counter);
 }
 
-static const struct hw_perf_counter_ops perf_ops_cpu_migrations = {
+static const struct pmu perf_ops_cpu_migrations = {
        .enable         = cpu_migrations_perf_counter_enable,
        .disable        = cpu_migrations_perf_counter_disable,
        .read           = cpu_migrations_perf_counter_read,
@@ -2454,8 +2742,9 @@ void perf_tpcounter_event(int event_id)
        if (!regs)
                regs = task_pt_regs(current);
 
-       __perf_swcounter_event(PERF_TYPE_TRACEPOINT, event_id, 1, 1, regs);
+       __perf_swcounter_event(PERF_TYPE_TRACEPOINT, event_id, 1, 1, regs, 0);
 }
+EXPORT_SYMBOL_GPL(perf_tpcounter_event);
 
 extern int ftrace_profile_enable(int);
 extern void ftrace_profile_disable(int);
@@ -2465,8 +2754,7 @@ static void tp_perf_counter_destroy(struct perf_counter *counter)
        ftrace_profile_disable(perf_event_id(&counter->hw_event));
 }
 
-static const struct hw_perf_counter_ops *
-tp_perf_counter_init(struct perf_counter *counter)
+static const struct pmu *tp_perf_counter_init(struct perf_counter *counter)
 {
        int event_id = perf_event_id(&counter->hw_event);
        int ret;
@@ -2481,18 +2769,16 @@ tp_perf_counter_init(struct perf_counter *counter)
        return &perf_ops_generic;
 }
 #else
-static const struct hw_perf_counter_ops *
-tp_perf_counter_init(struct perf_counter *counter)
+static const struct pmu *tp_perf_counter_init(struct perf_counter *counter)
 {
        return NULL;
 }
 #endif
 
-static const struct hw_perf_counter_ops *
-sw_perf_counter_init(struct perf_counter *counter)
+static const struct pmu *sw_perf_counter_init(struct perf_counter *counter)
 {
        struct perf_counter_hw_event *hw_event = &counter->hw_event;
-       const struct hw_perf_counter_ops *hw_ops = NULL;
+       const struct pmu *pmu = NULL;
        struct hw_perf_counter *hwc = &counter->hw;
 
        /*
@@ -2504,7 +2790,7 @@ sw_perf_counter_init(struct perf_counter *counter)
         */
        switch (perf_event_id(&counter->hw_event)) {
        case PERF_COUNT_CPU_CLOCK:
-               hw_ops = &perf_ops_cpu_clock;
+               pmu = &perf_ops_cpu_clock;
 
                if (hw_event->irq_period && hw_event->irq_period < 10000)
                        hw_event->irq_period = 10000;
@@ -2515,9 +2801,9 @@ sw_perf_counter_init(struct perf_counter *counter)
                 * use the cpu_clock counter instead.
                 */
                if (counter->ctx->task)
-                       hw_ops = &perf_ops_task_clock;
+                       pmu = &perf_ops_task_clock;
                else
-                       hw_ops = &perf_ops_cpu_clock;
+                       pmu = &perf_ops_cpu_clock;
 
                if (hw_event->irq_period && hw_event->irq_period < 10000)
                        hw_event->irq_period = 10000;
@@ -2526,18 +2812,18 @@ sw_perf_counter_init(struct perf_counter *counter)
        case PERF_COUNT_PAGE_FAULTS_MIN:
        case PERF_COUNT_PAGE_FAULTS_MAJ:
        case PERF_COUNT_CONTEXT_SWITCHES:
-               hw_ops = &perf_ops_generic;
+               pmu = &perf_ops_generic;
                break;
        case PERF_COUNT_CPU_MIGRATIONS:
                if (!counter->hw_event.exclude_kernel)
-                       hw_ops = &perf_ops_cpu_migrations;
+                       pmu = &perf_ops_cpu_migrations;
                break;
        }
 
-       if (hw_ops)
+       if (pmu)
                hwc->irq_period = hw_event->irq_period;
 
-       return hw_ops;
+       return pmu;
 }
 
 /*
@@ -2550,7 +2836,7 @@ perf_counter_alloc(struct perf_counter_hw_event *hw_event,
                   struct perf_counter *group_leader,
                   gfp_t gfpflags)
 {
-       const struct hw_perf_counter_ops *hw_ops;
+       const struct pmu *pmu;
        struct perf_counter *counter;
        long err;
 
@@ -2578,46 +2864,60 @@ perf_counter_alloc(struct perf_counter_hw_event *hw_event,
        counter->cpu                    = cpu;
        counter->hw_event               = *hw_event;
        counter->group_leader           = group_leader;
-       counter->hw_ops                 = NULL;
+       counter->pmu                    = NULL;
        counter->ctx                    = ctx;
 
        counter->state = PERF_COUNTER_STATE_INACTIVE;
        if (hw_event->disabled)
                counter->state = PERF_COUNTER_STATE_OFF;
 
-       hw_ops = NULL;
+       pmu = NULL;
+
+       /*
+        * we currently do not support PERF_RECORD_GROUP on inherited counters
+        */
+       if (hw_event->inherit && (hw_event->record_type & PERF_RECORD_GROUP))
+               goto done;
 
        if (perf_event_raw(hw_event)) {
-               hw_ops = hw_perf_counter_init(counter);
+               pmu = hw_perf_counter_init(counter);
                goto done;
        }
 
        switch (perf_event_type(hw_event)) {
        case PERF_TYPE_HARDWARE:
-               hw_ops = hw_perf_counter_init(counter);
+               pmu = hw_perf_counter_init(counter);
                break;
 
        case PERF_TYPE_SOFTWARE:
-               hw_ops = sw_perf_counter_init(counter);
+               pmu = sw_perf_counter_init(counter);
                break;
 
        case PERF_TYPE_TRACEPOINT:
-               hw_ops = tp_perf_counter_init(counter);
+               pmu = tp_perf_counter_init(counter);
                break;
        }
 done:
        err = 0;
-       if (!hw_ops)
+       if (!pmu)
                err = -EINVAL;
-       else if (IS_ERR(hw_ops))
-               err = PTR_ERR(hw_ops);
+       else if (IS_ERR(pmu))
+               err = PTR_ERR(pmu);
 
        if (err) {
                kfree(counter);
                return ERR_PTR(err);
        }
 
-       counter->hw_ops = hw_ops;
+       counter->pmu = pmu;
+
+       atomic_inc(&nr_counters);
+       if (counter->hw_event.mmap)
+               atomic_inc(&nr_mmap_tracking);
+       if (counter->hw_event.munmap)
+               atomic_inc(&nr_munmap_tracking);
+       if (counter->hw_event.comm)
+               atomic_inc(&nr_comm_tracking);
 
        return counter;
 }
@@ -3000,9 +3300,9 @@ static void __cpuinit perf_counter_init_cpu(int cpu)
        cpuctx = &per_cpu(perf_cpu_context, cpu);
        __perf_counter_init_context(&cpuctx->ctx, NULL);
 
-       mutex_lock(&perf_resource_mutex);
+       spin_lock(&perf_resource_lock);
        cpuctx->max_pertask = perf_max_counters - perf_reserved_percpu;
-       mutex_unlock(&perf_resource_mutex);
+       spin_unlock(&perf_resource_lock);
 
        hw_perf_counter_setup(cpu);
 }
@@ -3058,15 +3358,12 @@ static struct notifier_block __cpuinitdata perf_cpu_nb = {
        .notifier_call          = perf_cpu_notify,
 };
 
-static int __init perf_counter_init(void)
+void __init perf_counter_init(void)
 {
        perf_cpu_notify(&perf_cpu_nb, (unsigned long)CPU_UP_PREPARE,
                        (void *)(long)smp_processor_id());
        register_cpu_notifier(&perf_cpu_nb);
-
-       return 0;
 }
-early_initcall(perf_counter_init);
 
 static ssize_t perf_show_reserve_percpu(struct sysdev_class *class, char *buf)
 {
@@ -3088,7 +3385,7 @@ perf_set_reserve_percpu(struct sysdev_class *class,
        if (val > perf_max_counters)
                return -EINVAL;
 
-       mutex_lock(&perf_resource_mutex);
+       spin_lock(&perf_resource_lock);
        perf_reserved_percpu = val;
        for_each_online_cpu(cpu) {
                cpuctx = &per_cpu(perf_cpu_context, cpu);
@@ -3098,7 +3395,7 @@ perf_set_reserve_percpu(struct sysdev_class *class,
                cpuctx->max_pertask = mpt;
                spin_unlock_irq(&cpuctx->ctx.lock);
        }
-       mutex_unlock(&perf_resource_mutex);
+       spin_unlock(&perf_resource_lock);
 
        return count;
 }
@@ -3120,9 +3417,9 @@ perf_set_overcommit(struct sysdev_class *class, const char *buf, size_t count)
        if (val > 1)
                return -EINVAL;
 
-       mutex_lock(&perf_resource_mutex);
+       spin_lock(&perf_resource_lock);
        perf_overcommit = val;
-       mutex_unlock(&perf_resource_mutex);
+       spin_unlock(&perf_resource_lock);
 
        return count;
 }
This page took 0.043789 seconds and 5 git commands to generate.