These changes are the raw update to linux-4.4.6-rt14. Kernel sources
[kvmfornfv.git] / kernel / drivers / staging / lustre / lustre / ptlrpc / ptlrpcd.c
index 0c178ec..ce036a1 100644 (file)
 
 #include "ptlrpc_internal.h"
 
+/* One of these per CPT. */
 struct ptlrpcd {
-       int             pd_size;
-       int             pd_index;
-       int             pd_nthreads;
-       struct ptlrpcd_ctl pd_thread_rcv;
+       int pd_size;
+       int pd_index;
+       int pd_cpt;
+       int pd_cursor;
+       int pd_nthreads;
+       int pd_groupsize;
        struct ptlrpcd_ctl pd_threads[0];
 };
 
+/*
+ * max_ptlrpcds is obsolete, but retained to ensure that the kernel
+ * module will load on a system where it has been tuned.
+ * A value other than 0 implies it was tuned, in which case the value
+ * is used to derive a setting for ptlrpcd_per_cpt_max.
+ */
 static int max_ptlrpcds;
 module_param(max_ptlrpcds, int, 0644);
 MODULE_PARM_DESC(max_ptlrpcds, "Max ptlrpcd thread count to be started.");
 
-static int ptlrpcd_bind_policy = PDB_POLICY_PAIR;
+/*
+ * ptlrpcd_bind_policy is obsolete, but retained to ensure that
+ * the kernel module will load on a system where it has been tuned.
+ * A value other than 0 implies it was tuned, in which case the value
+ * is used to derive a setting for ptlrpcd_partner_group_size.
+ */
+static int ptlrpcd_bind_policy;
 module_param(ptlrpcd_bind_policy, int, 0644);
-MODULE_PARM_DESC(ptlrpcd_bind_policy, "Ptlrpcd threads binding mode.");
-static struct ptlrpcd *ptlrpcds;
+MODULE_PARM_DESC(ptlrpcd_bind_policy,
+                "Ptlrpcd threads binding mode (obsolete).");
+
+/*
+ * ptlrpcd_per_cpt_max: The maximum number of ptlrpcd threads to run
+ * in a CPT.
+ */
+static int ptlrpcd_per_cpt_max;
+module_param(ptlrpcd_per_cpt_max, int, 0644);
+MODULE_PARM_DESC(ptlrpcd_per_cpt_max,
+                "Max ptlrpcd thread count to be started per cpt.");
+
+/*
+ * ptlrpcd_partner_group_size: The desired number of threads in each
+ * ptlrpcd partner thread group. Default is 2, corresponding to the
+ * old PDB_POLICY_PAIR. A negative value makes all ptlrpcd threads in
+ * a CPT partners of each other.
+ */
+static int ptlrpcd_partner_group_size;
+module_param(ptlrpcd_partner_group_size, int, 0644);
+MODULE_PARM_DESC(ptlrpcd_partner_group_size,
+                "Number of ptlrpcd threads in a partner group.");
+
+/*
+ * ptlrpcd_cpts: A CPT string describing the CPU partitions that
+ * ptlrpcd threads should run on. Used to make ptlrpcd threads run on
+ * a subset of all CPTs.
+ *
+ * ptlrpcd_cpts=2
+ * ptlrpcd_cpts=[2]
+ *   run ptlrpcd threads only on CPT 2.
+ *
+ * ptlrpcd_cpts=0-3
+ * ptlrpcd_cpts=[0-3]
+ *   run ptlrpcd threads on CPTs 0, 1, 2, and 3.
+ *
+ * ptlrpcd_cpts=[0-3,5,7]
+ *   run ptlrpcd threads on CPTS 0, 1, 2, 3, 5, and 7.
+ */
+static char *ptlrpcd_cpts;
+module_param(ptlrpcd_cpts, charp, 0644);
+MODULE_PARM_DESC(ptlrpcd_cpts,
+                "CPU partitions ptlrpcd threads should run in");
+
+/* ptlrpcds_cpt_idx maps cpt numbers to an index in the ptlrpcds array. */
+static int             *ptlrpcds_cpt_idx;
+
+/* ptlrpcds_num is the number of entries in the ptlrpcds array. */
+static int             ptlrpcds_num;
+static struct ptlrpcd  **ptlrpcds;
+
+/*
+ * In addition to the regular thread pool above, there is a single
+ * global recovery thread. Recovery isn't critical for performance,
+ * and doesn't block, but must always be able to proceed, and it is
+ * possible that all normal ptlrpcd threads are blocked. Hence the
+ * need for a dedicated thread.
+ */
+static struct ptlrpcd_ctl ptlrpcd_rcv;
 
 struct mutex ptlrpcd_mutex;
 static int ptlrpcd_users;
@@ -98,88 +170,30 @@ void ptlrpcd_wake(struct ptlrpc_request *req)
 EXPORT_SYMBOL(ptlrpcd_wake);
 
 static struct ptlrpcd_ctl *
-ptlrpcd_select_pc(struct ptlrpc_request *req, pdl_policy_t policy, int index)
+ptlrpcd_select_pc(struct ptlrpc_request *req)
 {
-       int idx = 0;
+       struct ptlrpcd  *pd;
+       int             cpt;
+       int             idx;
 
        if (req != NULL && req->rq_send_state != LUSTRE_IMP_FULL)
-               return &ptlrpcds->pd_thread_rcv;
-
-       switch (policy) {
-       case PDL_POLICY_SAME:
-               idx = smp_processor_id() % ptlrpcds->pd_nthreads;
-               break;
-       case PDL_POLICY_LOCAL:
-               /* Before CPU partition patches available, process it the same
-                * as "PDL_POLICY_ROUND". */
-# ifdef CFS_CPU_MODE_NUMA
-# warning "fix this code to use new CPU partition APIs"
-# endif
-               /* Fall through to PDL_POLICY_ROUND until the CPU
-                * CPU partition patches are available. */
-               index = -1;
-       case PDL_POLICY_PREFERRED:
-               if (index >= 0 && index < num_online_cpus()) {
-                       idx = index % ptlrpcds->pd_nthreads;
-                       break;
-               }
-               /* Fall through to PDL_POLICY_ROUND for bad index. */
-       default:
-               /* Fall through to PDL_POLICY_ROUND for unknown policy. */
-       case PDL_POLICY_ROUND:
-               /* We do not care whether it is strict load balance. */
-               idx = ptlrpcds->pd_index + 1;
-               if (idx == smp_processor_id())
-                       idx++;
-               idx %= ptlrpcds->pd_nthreads;
-               ptlrpcds->pd_index = idx;
-               break;
-       }
-
-       return &ptlrpcds->pd_threads[idx];
-}
-
-/**
- * Move all request from an existing request set to the ptlrpcd queue.
- * All requests from the set must be in phase RQ_PHASE_NEW.
- */
-void ptlrpcd_add_rqset(struct ptlrpc_request_set *set)
-{
-       struct list_head *tmp, *pos;
-       struct ptlrpcd_ctl *pc;
-       struct ptlrpc_request_set *new;
-       int count, i;
+               return &ptlrpcd_rcv;
 
-       pc = ptlrpcd_select_pc(NULL, PDL_POLICY_LOCAL, -1);
-       new = pc->pc_set;
+       cpt = cfs_cpt_current(cfs_cpt_table, 1);
+       if (!ptlrpcds_cpt_idx)
+               idx = cpt;
+       else
+               idx = ptlrpcds_cpt_idx[cpt];
+       pd = ptlrpcds[idx];
 
-       list_for_each_safe(pos, tmp, &set->set_requests) {
-               struct ptlrpc_request *req =
-                       list_entry(pos, struct ptlrpc_request,
-                                      rq_set_chain);
-
-               LASSERT(req->rq_phase == RQ_PHASE_NEW);
-               req->rq_set = new;
-               req->rq_queued_time = cfs_time_current();
-       }
+               /* We do not care whether it is strict load balance. */
+       idx = pd->pd_cursor;
+       if (++idx == pd->pd_nthreads)
+               idx = 0;
+       pd->pd_cursor = idx;
 
-       spin_lock(&new->set_new_req_lock);
-       list_splice_init(&set->set_requests, &new->set_new_requests);
-       i = atomic_read(&set->set_remaining);
-       count = atomic_add_return(i, &new->set_new_count);
-       atomic_set(&set->set_remaining, 0);
-       spin_unlock(&new->set_new_req_lock);
-       if (count == i) {
-               wake_up(&new->set_waitq);
-
-               /* XXX: It maybe unnecessary to wakeup all the partners. But to
-                *      guarantee the async RPC can be processed ASAP, we have
-                *      no other better choice. It maybe fixed in future. */
-               for (i = 0; i < pc->pc_npartners; i++)
-                       wake_up(&pc->pc_partners[i]->pc_set->set_waitq);
-       }
+       return &pd->pd_threads[idx];
 }
-EXPORT_SYMBOL(ptlrpcd_add_rqset);
 
 /**
  * Return transferred RPCs count.
@@ -212,7 +226,7 @@ static int ptlrpcd_steal_rqset(struct ptlrpc_request_set *des,
  * Requests that are added to the ptlrpcd queue are sent via
  * ptlrpcd_check->ptlrpc_check_set().
  */
-void ptlrpcd_add_req(struct ptlrpc_request *req, pdl_policy_t policy, int idx)
+void ptlrpcd_add_req(struct ptlrpc_request *req)
 {
        struct ptlrpcd_ctl *pc;
 
@@ -242,7 +256,7 @@ void ptlrpcd_add_req(struct ptlrpc_request *req, pdl_policy_t policy, int idx)
                spin_unlock(&req->rq_lock);
        }
 
-       pc = ptlrpcd_select_pc(req, policy, idx);
+       pc = ptlrpcd_select_pc(req);
 
        DEBUG_REQ(D_INFO, req, "add req [%p] to pc [%s:%d]",
                  req, pc->pc_name, pc->pc_index);
@@ -372,25 +386,29 @@ static int ptlrpcd_check(struct lu_env *env, struct ptlrpcd_ctl *pc)
 static int ptlrpcd(void *arg)
 {
        struct ptlrpcd_ctl *pc = arg;
-       struct ptlrpc_request_set *set = pc->pc_set;
+       struct ptlrpc_request_set *set;
        struct lu_env env = { .le_ses = NULL };
-       int rc, exit = 0;
+       int rc = 0;
+       int exit = 0;
 
        unshare_fs_struct();
-#if defined(CONFIG_SMP)
-       if (test_bit(LIOD_BIND, &pc->pc_flags)) {
-               int index = pc->pc_index;
-
-               if (index >= 0 && index < num_possible_cpus()) {
-                       while (!cpu_online(index)) {
-                               if (++index >= num_possible_cpus())
-                                       index = 0;
-                       }
-                       set_cpus_allowed_ptr(current,
-                                       cpumask_of_node(cpu_to_node(index)));
-               }
+       if (cfs_cpt_bind(cfs_cpt_table, pc->pc_cpt) != 0)
+               CWARN("Failed to bind %s on CPT %d\n", pc->pc_name, pc->pc_cpt);
+
+       /*
+        * Allocate the request set after the thread has been bound
+        * above. This is safe because no requests will be queued
+        * until all ptlrpcd threads have confirmed that they have
+        * successfully started.
+        */
+       set = ptlrpc_prep_set();
+       if (!set) {
+               rc = -ENOMEM;
+               goto failed;
        }
-#endif
+       spin_lock(&pc->pc_lock);
+       pc->pc_set = set;
+       spin_unlock(&pc->pc_lock);
        /*
         * XXX So far only "client" ptlrpcd uses an environment. In
         * the future, ptlrpcd thread (or a thread-set) has to given
@@ -398,10 +416,10 @@ static int ptlrpcd(void *arg)
         */
        rc = lu_context_init(&env.le_ctx,
                             LCT_CL_THREAD|LCT_REMEMBER|LCT_NOREF);
-       complete(&pc->pc_starting);
-
        if (rc != 0)
-               return rc;
+               goto failed;
+
+       complete(&pc->pc_starting);
 
        /*
         * This mainloop strongly resembles ptlrpc_set_wait() except that our
@@ -447,173 +465,97 @@ static int ptlrpcd(void *arg)
        complete(&pc->pc_finishing);
 
        return 0;
+failed:
+       pc->pc_error = rc;
+       complete(&pc->pc_starting);
+       return rc;
 }
 
-/* XXX: We want multiple CPU cores to share the async RPC load. So we start many
- *      ptlrpcd threads. We also want to reduce the ptlrpcd overhead caused by
- *      data transfer cross-CPU cores. So we bind ptlrpcd thread to specified
- *      CPU core. But binding all ptlrpcd threads maybe cause response delay
- *      because of some CPU core(s) busy with other loads.
- *
- *      For example: "ls -l", some async RPCs for statahead are assigned to
- *      ptlrpcd_0, and ptlrpcd_0 is bound to CPU_0, but CPU_0 may be quite busy
- *      with other non-ptlrpcd, like "ls -l" itself (we want to the "ls -l"
- *      thread, statahead thread, and ptlrpcd thread can run in parallel), under
- *      such case, the statahead async RPCs can not be processed in time, it is
- *      unexpected. If ptlrpcd_0 can be re-scheduled on other CPU core, it may
- *      be better. But it breaks former data transfer policy.
- *
- *      So we shouldn't be blind for avoiding the data transfer. We make some
- *      compromise: divide the ptlrpcd threads pool into two parts. One part is
- *      for bound mode, each ptlrpcd thread in this part is bound to some CPU
- *      core. The other part is for free mode, all the ptlrpcd threads in the
- *      part can be scheduled on any CPU core. We specify some partnership
- *      between bound mode ptlrpcd thread(s) and free mode ptlrpcd thread(s),
- *      and the async RPC load within the partners are shared.
+static void ptlrpcd_ctl_init(struct ptlrpcd_ctl *pc, int index, int cpt)
+{
+       pc->pc_index = index;
+       pc->pc_cpt = cpt;
+       init_completion(&pc->pc_starting);
+       init_completion(&pc->pc_finishing);
+       spin_lock_init(&pc->pc_lock);
+
+       if (index < 0) {
+               /* Recovery thread. */
+               snprintf(pc->pc_name, sizeof(pc->pc_name), "ptlrpcd_rcv");
+       } else {
+               /* Regular thread. */
+               snprintf(pc->pc_name, sizeof(pc->pc_name),
+                        "ptlrpcd_%02d_%02d", cpt, index);
+       }
+}
+
+/* XXX: We want multiple CPU cores to share the async RPC load. So we
+ *     start many ptlrpcd threads. We also want to reduce the ptlrpcd
+ *     overhead caused by data transfer cross-CPU cores. So we bind
+ *     all ptlrpcd threads to a CPT, in the expectation that CPTs
+ *     will be defined in a way that matches these boundaries. Within
+ *     a CPT a ptlrpcd thread can be scheduled on any available core.
  *
- *      It can partly avoid data transfer cross-CPU (if the bound mode ptlrpcd
- *      thread can be scheduled in time), and try to guarantee the async RPC
- *      processed ASAP (as long as the free mode ptlrpcd thread can be scheduled
- *      on any CPU core).
+ *     Each ptlrpcd thread has its own request queue. This can cause
+ *     response delay if the thread is already busy. To help with
+ *     this we define partner threads: these are other threads bound
+ *     to the same CPT which will check for work in each other's
+ *     request queues if they have no work to do.
  *
- *      As for how to specify the partnership between bound mode ptlrpcd
- *      thread(s) and free mode ptlrpcd thread(s), the simplest way is to use
- *      <free bound> pair. In future, we can specify some more complex
- *      partnership based on the patches for CPU partition. But before such
- *      patches are available, we prefer to use the simplest one.
+ *     The desired number of partner threads can be tuned by setting
+ *     ptlrpcd_partner_group_size. The default is to create pairs of
+ *     partner threads.
  */
-# ifdef CFS_CPU_MODE_NUMA
-# warning "fix ptlrpcd_bind() to use new CPU partition APIs"
-# endif
-static int ptlrpcd_bind(int index, int max)
+static int ptlrpcd_partners(struct ptlrpcd *pd, int index)
 {
        struct ptlrpcd_ctl *pc;
+       struct ptlrpcd_ctl **ppc;
+       int first;
+       int i;
        int rc = 0;
-#if defined(CONFIG_NUMA)
-       cpumask_t mask;
-#endif
+       int size;
 
-       LASSERT(index <= max - 1);
-       pc = &ptlrpcds->pd_threads[index];
-       switch (ptlrpcd_bind_policy) {
-       case PDB_POLICY_NONE:
-               pc->pc_npartners = -1;
-               break;
-       case PDB_POLICY_FULL:
+       LASSERT(index >= 0 && index < pd->pd_nthreads);
+       pc = &pd->pd_threads[index];
+       pc->pc_npartners = pd->pd_groupsize - 1;
+
+       if (pc->pc_npartners <= 0)
+               goto out;
+
+       size = sizeof(struct ptlrpcd_ctl *) * pc->pc_npartners;
+       pc->pc_partners = kzalloc_node(size, GFP_NOFS,
+                                      cfs_cpt_spread_node(cfs_cpt_table,
+                                                          pc->pc_cpt));
+       if (!pc->pc_partners) {
                pc->pc_npartners = 0;
-               set_bit(LIOD_BIND, &pc->pc_flags);
-               break;
-       case PDB_POLICY_PAIR:
-               LASSERT(max % 2 == 0);
-               pc->pc_npartners = 1;
-               break;
-       case PDB_POLICY_NEIGHBOR:
-#if defined(CONFIG_NUMA)
-       {
-               int i;
-               cpumask_copy(&mask, cpumask_of_node(cpu_to_node(index)));
-               for (i = max; i < num_online_cpus(); i++)
-                       cpumask_clear_cpu(i, &mask);
-               pc->pc_npartners = cpumask_weight(&mask) - 1;
-               set_bit(LIOD_BIND, &pc->pc_flags);
-       }
-#else
-               LASSERT(max >= 3);
-               pc->pc_npartners = 2;
-#endif
-               break;
-       default:
-               CERROR("unknown ptlrpcd bind policy %d\n", ptlrpcd_bind_policy);
-               rc = -EINVAL;
+               rc = -ENOMEM;
+               goto out;
        }
 
-       if (rc == 0 && pc->pc_npartners > 0) {
-               OBD_ALLOC(pc->pc_partners,
-                         sizeof(struct ptlrpcd_ctl *) * pc->pc_npartners);
-               if (pc->pc_partners == NULL) {
-                       pc->pc_npartners = 0;
-                       rc = -ENOMEM;
-               } else {
-                       switch (ptlrpcd_bind_policy) {
-                       case PDB_POLICY_PAIR:
-                               if (index & 0x1) {
-                                       set_bit(LIOD_BIND, &pc->pc_flags);
-                                       pc->pc_partners[0] = &ptlrpcds->
-                                               pd_threads[index - 1];
-                                       ptlrpcds->pd_threads[index - 1].
-                                               pc_partners[0] = pc;
-                               }
-                               break;
-                       case PDB_POLICY_NEIGHBOR:
-#if defined(CONFIG_NUMA)
-                       {
-                               struct ptlrpcd_ctl *ppc;
-                               int i, pidx;
-                               /* partners are cores in the same NUMA node.
-                                * setup partnership only with ptlrpcd threads
-                                * that are already initialized
-                                */
-                               for (pidx = 0, i = 0; i < index; i++) {
-                                       if (cpumask_test_cpu(i, &mask)) {
-                                               ppc = &ptlrpcds->pd_threads[i];
-                                               pc->pc_partners[pidx++] = ppc;
-                                               ppc->pc_partners[ppc->
-                                                         pc_npartners++] = pc;
-                                       }
-                               }
-                               /* adjust number of partners to the number
-                                * of partnership really setup */
-                               pc->pc_npartners = pidx;
-                       }
-#else
-                               if (index & 0x1)
-                                       set_bit(LIOD_BIND, &pc->pc_flags);
-                               if (index > 0) {
-                                       pc->pc_partners[0] = &ptlrpcds->
-                                               pd_threads[index - 1];
-                                       ptlrpcds->pd_threads[index - 1].
-                                               pc_partners[1] = pc;
-                                       if (index == max - 1) {
-                                               pc->pc_partners[1] =
-                                               &ptlrpcds->pd_threads[0];
-                                               ptlrpcds->pd_threads[0].
-                                               pc_partners[0] = pc;
-                                       }
-                               }
-#endif
-                               break;
-                       }
-               }
+       first = index - index % pd->pd_groupsize;
+       ppc = pc->pc_partners;
+       for (i = first; i < first + pd->pd_groupsize; i++) {
+               if (i != index)
+                       *ppc++ = &pd->pd_threads[i];
        }
-
+out:
        return rc;
 }
 
-
-int ptlrpcd_start(int index, int max, const char *name, struct ptlrpcd_ctl *pc)
+int ptlrpcd_start(struct ptlrpcd_ctl *pc)
 {
-       int rc;
+       struct task_struct *task;
+       int rc = 0;
 
        /*
         * Do not allow start second thread for one pc.
         */
        if (test_and_set_bit(LIOD_START, &pc->pc_flags)) {
                CWARN("Starting second thread (%s) for same pc %p\n",
-                     name, pc);
+                     pc->pc_name, pc);
                return 0;
        }
 
-       pc->pc_index = index;
-       init_completion(&pc->pc_starting);
-       init_completion(&pc->pc_finishing);
-       spin_lock_init(&pc->pc_lock);
-       strlcpy(pc->pc_name, name, sizeof(pc->pc_name));
-       pc->pc_set = ptlrpc_prep_set();
-       if (pc->pc_set == NULL) {
-               rc = -ENOMEM;
-               goto out;
-       }
-
        /*
         * So far only "client" ptlrpcd uses an environment. In the future,
         * ptlrpcd thread (or a thread-set) has to be given an argument,
@@ -621,29 +563,21 @@ int ptlrpcd_start(int index, int max, const char *name, struct ptlrpcd_ctl *pc)
         */
        rc = lu_context_init(&pc->pc_env.le_ctx, LCT_CL_THREAD|LCT_REMEMBER);
        if (rc != 0)
-               goto out_set;
+               goto out;
 
-       {
-               struct task_struct *task;
-               if (index >= 0) {
-                       rc = ptlrpcd_bind(index, max);
-                       if (rc < 0)
-                               goto out_env;
-               }
+       task = kthread_run(ptlrpcd, pc, "%s", pc->pc_name);
+       if (IS_ERR(task)) {
+               rc = PTR_ERR(task);
+               goto out_set;
+       }
 
-               task = kthread_run(ptlrpcd, pc, "%s", pc->pc_name);
-               if (IS_ERR(task)) {
-                       rc = PTR_ERR(task);
-                       goto out_env;
-               }
+       wait_for_completion(&pc->pc_starting);
+       rc = pc->pc_error;
+       if (rc != 0)
+               goto out_set;
 
-               wait_for_completion(&pc->pc_starting);
-       }
        return 0;
 
-out_env:
-       lu_context_fini(&pc->pc_env.le_ctx);
-
 out_set:
        if (pc->pc_set != NULL) {
                struct ptlrpc_request_set *set = pc->pc_set;
@@ -653,7 +587,7 @@ out_set:
                spin_unlock(&pc->pc_lock);
                ptlrpc_set_destroy(set);
        }
-       clear_bit(LIOD_BIND, &pc->pc_flags);
+       lu_context_fini(&pc->pc_env.le_ctx);
 
 out:
        clear_bit(LIOD_START, &pc->pc_flags);
@@ -693,99 +627,271 @@ void ptlrpcd_free(struct ptlrpcd_ctl *pc)
        clear_bit(LIOD_START, &pc->pc_flags);
        clear_bit(LIOD_STOP, &pc->pc_flags);
        clear_bit(LIOD_FORCE, &pc->pc_flags);
-       clear_bit(LIOD_BIND, &pc->pc_flags);
 
 out:
        if (pc->pc_npartners > 0) {
                LASSERT(pc->pc_partners != NULL);
 
-               OBD_FREE(pc->pc_partners,
-                        sizeof(struct ptlrpcd_ctl *) * pc->pc_npartners);
+               kfree(pc->pc_partners);
                pc->pc_partners = NULL;
        }
        pc->pc_npartners = 0;
+       pc->pc_error = 0;
 }
 
 static void ptlrpcd_fini(void)
 {
        int i;
+       int j;
 
        if (ptlrpcds != NULL) {
-               for (i = 0; i < ptlrpcds->pd_nthreads; i++)
-                       ptlrpcd_stop(&ptlrpcds->pd_threads[i], 0);
-               for (i = 0; i < ptlrpcds->pd_nthreads; i++)
-                       ptlrpcd_free(&ptlrpcds->pd_threads[i]);
-               ptlrpcd_stop(&ptlrpcds->pd_thread_rcv, 0);
-               ptlrpcd_free(&ptlrpcds->pd_thread_rcv);
-               OBD_FREE(ptlrpcds, ptlrpcds->pd_size);
-               ptlrpcds = NULL;
+               for (i = 0; i < ptlrpcds_num; i++) {
+                       if (!ptlrpcds[i])
+                               break;
+                       for (j = 0; j < ptlrpcds[i]->pd_nthreads; j++)
+                               ptlrpcd_stop(&ptlrpcds[i]->pd_threads[j], 0);
+                       for (j = 0; j < ptlrpcds[i]->pd_nthreads; j++)
+                               ptlrpcd_free(&ptlrpcds[i]->pd_threads[j]);
+                       kfree(ptlrpcds[i]);
+                       ptlrpcds[i] = NULL;
+               }
+               kfree(ptlrpcds);
        }
+       ptlrpcds_num = 0;
+
+       ptlrpcd_stop(&ptlrpcd_rcv, 0);
+       ptlrpcd_free(&ptlrpcd_rcv);
+
+       kfree(ptlrpcds_cpt_idx);
+       ptlrpcds_cpt_idx = NULL;
 }
 
 static int ptlrpcd_init(void)
 {
-       int nthreads = num_online_cpus();
-       char name[16];
-       int size, i = -1, j, rc = 0;
-
-       if (max_ptlrpcds > 0 && max_ptlrpcds < nthreads)
-               nthreads = max_ptlrpcds;
-       if (nthreads < 2)
-               nthreads = 2;
-       if (nthreads < 3 && ptlrpcd_bind_policy == PDB_POLICY_NEIGHBOR)
-               ptlrpcd_bind_policy = PDB_POLICY_PAIR;
-       else if (nthreads % 2 != 0 && ptlrpcd_bind_policy == PDB_POLICY_PAIR)
-               nthreads &= ~1; /* make sure it is even */
-
-       size = offsetof(struct ptlrpcd, pd_threads[nthreads]);
-       OBD_ALLOC(ptlrpcds, size);
-       if (ptlrpcds == NULL) {
+       int nthreads;
+       int groupsize;
+       int size;
+       int i;
+       int j;
+       int rc = 0;
+       struct cfs_cpt_table *cptable;
+       __u32 *cpts = NULL;
+       int ncpts;
+       int cpt;
+       struct ptlrpcd *pd;
+
+       /*
+        * Determine the CPTs that ptlrpcd threads will run on.
+        */
+       cptable = cfs_cpt_table;
+       ncpts = cfs_cpt_number(cptable);
+       if (ptlrpcd_cpts) {
+               struct cfs_expr_list *el;
+
+               size = ncpts * sizeof(ptlrpcds_cpt_idx[0]);
+               ptlrpcds_cpt_idx = kzalloc(size, GFP_KERNEL);
+               if (!ptlrpcds_cpt_idx) {
+                       rc = -ENOMEM;
+                       goto out;
+               }
+
+               rc = cfs_expr_list_parse(ptlrpcd_cpts,
+                                        strlen(ptlrpcd_cpts),
+                                        0, ncpts - 1, &el);
+
+               if (rc != 0) {
+                       CERROR("ptlrpcd_cpts: invalid CPT pattern string: %s",
+                              ptlrpcd_cpts);
+                       rc = -EINVAL;
+                       goto out;
+               }
+
+               rc = cfs_expr_list_values(el, ncpts, &cpts);
+               cfs_expr_list_free(el);
+               if (rc <= 0) {
+                       CERROR("ptlrpcd_cpts: failed to parse CPT array %s: %d\n",
+                              ptlrpcd_cpts, rc);
+                       if (rc == 0)
+                               rc = -EINVAL;
+                       goto out;
+               }
+
+               /*
+                * Create the cpt-to-index map. When there is no match
+                * in the cpt table, pick a cpt at random. This could
+                * be changed to take the topology of the system into
+                * account.
+                */
+               for (cpt = 0; cpt < ncpts; cpt++) {
+                       for (i = 0; i < rc; i++)
+                               if (cpts[i] == cpt)
+                                       break;
+                       if (i >= rc)
+                               i = cpt % rc;
+                       ptlrpcds_cpt_idx[cpt] = i;
+               }
+
+               cfs_expr_list_values_free(cpts, rc);
+               ncpts = rc;
+       }
+       ptlrpcds_num = ncpts;
+
+       size = ncpts * sizeof(ptlrpcds[0]);
+       ptlrpcds = kzalloc(size, GFP_KERNEL);
+       if (!ptlrpcds) {
                rc = -ENOMEM;
                goto out;
        }
 
-       snprintf(name, sizeof(name), "ptlrpcd_rcv");
-       set_bit(LIOD_RECOVERY, &ptlrpcds->pd_thread_rcv.pc_flags);
-       rc = ptlrpcd_start(-1, nthreads, name, &ptlrpcds->pd_thread_rcv);
+       /*
+        * The max_ptlrpcds parameter is obsolete, but do something
+        * sane if it has been tuned, and complain if
+        * ptlrpcd_per_cpt_max has also been tuned.
+        */
+       if (max_ptlrpcds != 0) {
+               CWARN("max_ptlrpcds is obsolete.\n");
+               if (ptlrpcd_per_cpt_max == 0) {
+                       ptlrpcd_per_cpt_max = max_ptlrpcds / ncpts;
+                       /* Round up if there is a remainder. */
+                       if (max_ptlrpcds % ncpts != 0)
+                               ptlrpcd_per_cpt_max++;
+                       CWARN("Setting ptlrpcd_per_cpt_max = %d\n",
+                             ptlrpcd_per_cpt_max);
+               } else {
+                       CWARN("ptlrpd_per_cpt_max is also set!\n");
+               }
+       }
+
+       /*
+        * The ptlrpcd_bind_policy parameter is obsolete, but do
+        * something sane if it has been tuned, and complain if
+        * ptlrpcd_partner_group_size is also tuned.
+        */
+       if (ptlrpcd_bind_policy != 0) {
+               CWARN("ptlrpcd_bind_policy is obsolete.\n");
+               if (ptlrpcd_partner_group_size == 0) {
+                       switch (ptlrpcd_bind_policy) {
+                       case 1: /* PDB_POLICY_NONE */
+                       case 2: /* PDB_POLICY_FULL */
+                               ptlrpcd_partner_group_size = 1;
+                               break;
+                       case 3: /* PDB_POLICY_PAIR */
+                               ptlrpcd_partner_group_size = 2;
+                               break;
+                       case 4: /* PDB_POLICY_NEIGHBOR */
+#ifdef CONFIG_NUMA
+                               ptlrpcd_partner_group_size = -1; /* CPT */
+#else
+                               ptlrpcd_partner_group_size = 3; /* Triplets */
+#endif
+                               break;
+                       default: /* Illegal value, use the default. */
+                               ptlrpcd_partner_group_size = 2;
+                               break;
+                       }
+                       CWARN("Setting ptlrpcd_partner_group_size = %d\n",
+                             ptlrpcd_partner_group_size);
+               } else {
+                       CWARN("ptlrpcd_partner_group_size is also set!\n");
+               }
+       }
+
+       if (ptlrpcd_partner_group_size == 0)
+               ptlrpcd_partner_group_size = 2;
+       else if (ptlrpcd_partner_group_size < 0)
+               ptlrpcd_partner_group_size = -1;
+       else if (ptlrpcd_per_cpt_max > 0 &&
+                ptlrpcd_partner_group_size > ptlrpcd_per_cpt_max)
+               ptlrpcd_partner_group_size = ptlrpcd_per_cpt_max;
+
+       /*
+        * Start the recovery thread first.
+        */
+       set_bit(LIOD_RECOVERY, &ptlrpcd_rcv.pc_flags);
+       ptlrpcd_ctl_init(&ptlrpcd_rcv, -1, CFS_CPT_ANY);
+       rc = ptlrpcd_start(&ptlrpcd_rcv);
        if (rc < 0)
                goto out;
 
-       /* XXX: We start nthreads ptlrpc daemons. Each of them can process any
-        *      non-recovery async RPC to improve overall async RPC efficiency.
-        *
-        *      But there are some issues with async I/O RPCs and async non-I/O
-        *      RPCs processed in the same set under some cases. The ptlrpcd may
-        *      be blocked by some async I/O RPC(s), then will cause other async
-        *      non-I/O RPC(s) can not be processed in time.
-        *
-        *      Maybe we should distinguish blocked async RPCs from non-blocked
-        *      async RPCs, and process them in different ptlrpcd sets to avoid
-        *      unnecessary dependency. But how to distribute async RPCs load
-        *      among all the ptlrpc daemons becomes another trouble. */
-       for (i = 0; i < nthreads; i++) {
-               snprintf(name, sizeof(name), "ptlrpcd_%d", i);
-               rc = ptlrpcd_start(i, nthreads, name, &ptlrpcds->pd_threads[i]);
-               if (rc < 0)
+       for (i = 0; i < ncpts; i++) {
+               if (!cpts)
+                       cpt = i;
+               else
+                       cpt = cpts[i];
+
+               nthreads = cfs_cpt_weight(cptable, cpt);
+               if (ptlrpcd_per_cpt_max > 0 && ptlrpcd_per_cpt_max < nthreads)
+                       nthreads = ptlrpcd_per_cpt_max;
+               if (nthreads < 2)
+                       nthreads = 2;
+
+               if (ptlrpcd_partner_group_size <= 0) {
+                       groupsize = nthreads;
+               } else if (nthreads <= ptlrpcd_partner_group_size) {
+                       groupsize = nthreads;
+               } else {
+                       groupsize = ptlrpcd_partner_group_size;
+                       if (nthreads % groupsize != 0)
+                               nthreads += groupsize - (nthreads % groupsize);
+               }
+
+               size = offsetof(struct ptlrpcd, pd_threads[nthreads]);
+               pd = kzalloc_node(size, GFP_NOFS,
+                                 cfs_cpt_spread_node(cfs_cpt_table, cpt));
+               if (!pd) {
+                       rc = -ENOMEM;
                        goto out;
-       }
+               }
+               pd->pd_size = size;
+               pd->pd_index = i;
+               pd->pd_cpt = cpt;
+               pd->pd_cursor = 0;
+               pd->pd_nthreads = nthreads;
+               pd->pd_groupsize = groupsize;
+               ptlrpcds[i] = pd;
 
-       ptlrpcds->pd_size = size;
-       ptlrpcds->pd_index = 0;
-       ptlrpcds->pd_nthreads = nthreads;
+               /*
+                * The ptlrpcd threads in a partner group can access
+                * each other's struct ptlrpcd_ctl, so these must be
+                * initialized before any thread is started.
+                */
+               for (j = 0; j < nthreads; j++) {
+                       ptlrpcd_ctl_init(&pd->pd_threads[j], j, cpt);
+                       rc = ptlrpcd_partners(pd, j);
+                       if (rc < 0)
+                               goto out;
+               }
 
-out:
-       if (rc != 0 && ptlrpcds != NULL) {
-               for (j = 0; j <= i; j++)
-                       ptlrpcd_stop(&ptlrpcds->pd_threads[j], 0);
-               for (j = 0; j <= i; j++)
-                       ptlrpcd_free(&ptlrpcds->pd_threads[j]);
-               ptlrpcd_stop(&ptlrpcds->pd_thread_rcv, 0);
-               ptlrpcd_free(&ptlrpcds->pd_thread_rcv);
-               OBD_FREE(ptlrpcds, size);
-               ptlrpcds = NULL;
+               /* XXX: We start nthreads ptlrpc daemons.
+                *      Each of them can process any non-recovery
+                *      async RPC to improve overall async RPC
+                *      efficiency.
+                *
+                *      But there are some issues with async I/O RPCs
+                *      and async non-I/O RPCs processed in the same
+                *      set under some cases. The ptlrpcd may be
+                *      blocked by some async I/O RPC(s), then will
+                *      cause other async non-I/O RPC(s) can not be
+                *      processed in time.
+                *
+                *      Maybe we should distinguish blocked async RPCs
+                *      from non-blocked async RPCs, and process them
+                *      in different ptlrpcd sets to avoid unnecessary
+                *      dependency. But how to distribute async RPCs
+                *      load among all the ptlrpc daemons becomes
+                *      another trouble.
+                */
+               for (j = 0; j < nthreads; j++) {
+                       rc = ptlrpcd_start(&pd->pd_threads[j]);
+                       if (rc < 0)
+                               goto out;
+               }
        }
+out:
+       if (rc != 0)
+               ptlrpcd_fini();
 
-       return 0;
+       return rc;
 }
 
 int ptlrpcd_addref(void)