123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155 |
- #include <linux/sched.h>
- #include <linux/kthread.h>
- #include <linux/completion.h>
- #include <linux/err.h>
- #include <linux/cpuset.h>
- #include <linux/unistd.h>
- #include <linux/file.h>
- #include <linux/export.h>
- #include <linux/mutex.h>
- #include <linux/slab.h>
- #include <linux/freezer.h>
- #include <linux/ptrace.h>
- #include <linux/uaccess.h>
- #include <linux/cgroup.h>
- #include <trace/events/sched.h>
- static DEFINE_SPINLOCK(kthread_create_lock);
- static LIST_HEAD(kthread_create_list);
- struct task_struct *kthreadd_task;
- struct kthread_create_info
- {
-
- int (*threadfn)(void *data);
- void *data;
- int node;
-
- struct task_struct *result;
- struct completion *done;
- struct list_head list;
- };
- struct kthread {
- unsigned long flags;
- unsigned int cpu;
- void *data;
- struct completion parked;
- struct completion exited;
- };
- enum KTHREAD_BITS {
- KTHREAD_IS_PER_CPU = 0,
- KTHREAD_SHOULD_STOP,
- KTHREAD_SHOULD_PARK,
- KTHREAD_IS_PARKED,
- };
- #define __to_kthread(vfork) \
- container_of(vfork, struct kthread, exited)
- static inline struct kthread *to_kthread(struct task_struct *k)
- {
- return __to_kthread(k->vfork_done);
- }
- static struct kthread *to_live_kthread(struct task_struct *k)
- {
- struct completion *vfork = ACCESS_ONCE(k->vfork_done);
- if (likely(vfork) && try_get_task_stack(k))
- return __to_kthread(vfork);
- return NULL;
- }
- bool kthread_should_stop(void)
- {
- return test_bit(KTHREAD_SHOULD_STOP, &to_kthread(current)->flags);
- }
- EXPORT_SYMBOL(kthread_should_stop);
- bool kthread_should_park(void)
- {
- return test_bit(KTHREAD_SHOULD_PARK, &to_kthread(current)->flags);
- }
- EXPORT_SYMBOL_GPL(kthread_should_park);
- bool kthread_freezable_should_stop(bool *was_frozen)
- {
- bool frozen = false;
- might_sleep();
- if (unlikely(freezing(current)))
- frozen = __refrigerator(true);
- if (was_frozen)
- *was_frozen = frozen;
- return kthread_should_stop();
- }
- EXPORT_SYMBOL_GPL(kthread_freezable_should_stop);
- void *kthread_data(struct task_struct *task)
- {
- return to_kthread(task)->data;
- }
- void *kthread_probe_data(struct task_struct *task)
- {
- struct kthread *kthread = to_kthread(task);
- void *data = NULL;
- probe_kernel_read(&data, &kthread->data, sizeof(data));
- return data;
- }
- static void __kthread_parkme(struct kthread *self)
- {
- __set_current_state(TASK_PARKED);
- while (test_bit(KTHREAD_SHOULD_PARK, &self->flags)) {
- if (!test_and_set_bit(KTHREAD_IS_PARKED, &self->flags))
- complete(&self->parked);
- schedule();
- __set_current_state(TASK_PARKED);
- }
- clear_bit(KTHREAD_IS_PARKED, &self->flags);
- __set_current_state(TASK_RUNNING);
- }
- void kthread_parkme(void)
- {
- __kthread_parkme(to_kthread(current));
- }
- EXPORT_SYMBOL_GPL(kthread_parkme);
- static int kthread(void *_create)
- {
-
- struct kthread_create_info *create = _create;
- int (*threadfn)(void *data) = create->threadfn;
- void *data = create->data;
- struct completion *done;
- struct kthread self;
- int ret;
- self.flags = 0;
- self.data = data;
- init_completion(&self.exited);
- init_completion(&self.parked);
- current->vfork_done = &self.exited;
-
- done = xchg(&create->done, NULL);
- if (!done) {
- kfree(create);
- do_exit(-EINTR);
- }
-
- __set_current_state(TASK_UNINTERRUPTIBLE);
- create->result = current;
- complete(done);
- schedule();
- ret = -EINTR;
- if (!test_bit(KTHREAD_SHOULD_STOP, &self.flags)) {
- cgroup_kthread_ready();
- __kthread_parkme(&self);
- ret = threadfn(data);
- }
-
- do_exit(ret);
- }
- int tsk_fork_get_node(struct task_struct *tsk)
- {
- #ifdef CONFIG_NUMA
- if (tsk == kthreadd_task)
- return tsk->pref_node_fork;
- #endif
- return NUMA_NO_NODE;
- }
- static void create_kthread(struct kthread_create_info *create)
- {
- int pid;
- #ifdef CONFIG_NUMA
- current->pref_node_fork = create->node;
- #endif
-
- pid = kernel_thread(kthread, create, CLONE_FS | CLONE_FILES | SIGCHLD);
- if (pid < 0) {
-
- struct completion *done = xchg(&create->done, NULL);
- if (!done) {
- kfree(create);
- return;
- }
- create->result = ERR_PTR(pid);
- complete(done);
- }
- }
- static struct task_struct *__kthread_create_on_node(int (*threadfn)(void *data),
- void *data, int node,
- const char namefmt[],
- va_list args)
- {
- DECLARE_COMPLETION_ONSTACK(done);
- struct task_struct *task;
- struct kthread_create_info *create = kmalloc(sizeof(*create),
- GFP_KERNEL);
- if (!create)
- return ERR_PTR(-ENOMEM);
- create->threadfn = threadfn;
- create->data = data;
- create->node = node;
- create->done = &done;
- spin_lock(&kthread_create_lock);
- list_add_tail(&create->list, &kthread_create_list);
- spin_unlock(&kthread_create_lock);
- wake_up_process(kthreadd_task);
-
- if (unlikely(wait_for_completion_killable(&done))) {
-
- if (xchg(&create->done, NULL))
- return ERR_PTR(-EINTR);
-
- wait_for_completion(&done);
- }
- task = create->result;
- if (!IS_ERR(task)) {
- static const struct sched_param param = { .sched_priority = 0 };
- vsnprintf(task->comm, sizeof(task->comm), namefmt, args);
-
- sched_setscheduler_nocheck(task, SCHED_NORMAL, ¶m);
- set_cpus_allowed_ptr(task, cpu_all_mask);
- }
- kfree(create);
- return task;
- }
- struct task_struct *kthread_create_on_node(int (*threadfn)(void *data),
- void *data, int node,
- const char namefmt[],
- ...)
- {
- struct task_struct *task;
- va_list args;
- va_start(args, namefmt);
- task = __kthread_create_on_node(threadfn, data, node, namefmt, args);
- va_end(args);
- return task;
- }
- EXPORT_SYMBOL(kthread_create_on_node);
- static void __kthread_bind_mask(struct task_struct *p, const struct cpumask *mask, long state)
- {
- unsigned long flags;
- if (!wait_task_inactive(p, state)) {
- WARN_ON(1);
- return;
- }
-
- raw_spin_lock_irqsave(&p->pi_lock, flags);
- do_set_cpus_allowed(p, mask);
- p->flags |= PF_NO_SETAFFINITY;
- raw_spin_unlock_irqrestore(&p->pi_lock, flags);
- }
- static void __kthread_bind(struct task_struct *p, unsigned int cpu, long state)
- {
- __kthread_bind_mask(p, cpumask_of(cpu), state);
- }
- void kthread_bind_mask(struct task_struct *p, const struct cpumask *mask)
- {
- __kthread_bind_mask(p, mask, TASK_UNINTERRUPTIBLE);
- }
- void kthread_bind(struct task_struct *p, unsigned int cpu)
- {
- __kthread_bind(p, cpu, TASK_UNINTERRUPTIBLE);
- }
- EXPORT_SYMBOL(kthread_bind);
- struct task_struct *kthread_create_on_cpu(int (*threadfn)(void *data),
- void *data, unsigned int cpu,
- const char *namefmt)
- {
- struct task_struct *p;
- p = kthread_create_on_node(threadfn, data, cpu_to_node(cpu), namefmt,
- cpu);
- if (IS_ERR(p))
- return p;
- kthread_bind(p, cpu);
-
- set_bit(KTHREAD_IS_PER_CPU, &to_kthread(p)->flags);
- to_kthread(p)->cpu = cpu;
- return p;
- }
- static void __kthread_unpark(struct task_struct *k, struct kthread *kthread)
- {
- clear_bit(KTHREAD_SHOULD_PARK, &kthread->flags);
-
- if (test_and_clear_bit(KTHREAD_IS_PARKED, &kthread->flags)) {
-
- if (test_bit(KTHREAD_IS_PER_CPU, &kthread->flags))
- __kthread_bind(k, kthread->cpu, TASK_PARKED);
- wake_up_state(k, TASK_PARKED);
- }
- }
- void kthread_unpark(struct task_struct *k)
- {
- struct kthread *kthread = to_live_kthread(k);
- if (kthread) {
- __kthread_unpark(k, kthread);
- put_task_stack(k);
- }
- }
- EXPORT_SYMBOL_GPL(kthread_unpark);
- int kthread_park(struct task_struct *k)
- {
- struct kthread *kthread = to_live_kthread(k);
- int ret = -ENOSYS;
- if (kthread) {
- if (!test_bit(KTHREAD_IS_PARKED, &kthread->flags)) {
- set_bit(KTHREAD_SHOULD_PARK, &kthread->flags);
- if (k != current) {
- wake_up_process(k);
- wait_for_completion(&kthread->parked);
- }
- }
- put_task_stack(k);
- ret = 0;
- }
- return ret;
- }
- EXPORT_SYMBOL_GPL(kthread_park);
- int kthread_stop(struct task_struct *k)
- {
- struct kthread *kthread;
- int ret;
- trace_sched_kthread_stop(k);
- get_task_struct(k);
- kthread = to_live_kthread(k);
- if (kthread) {
- set_bit(KTHREAD_SHOULD_STOP, &kthread->flags);
- __kthread_unpark(k, kthread);
- wake_up_process(k);
- wait_for_completion(&kthread->exited);
- put_task_stack(k);
- }
- ret = k->exit_code;
- put_task_struct(k);
- trace_sched_kthread_stop_ret(ret);
- return ret;
- }
- EXPORT_SYMBOL(kthread_stop);
- int kthreadd(void *unused)
- {
- struct task_struct *tsk = current;
-
- set_task_comm(tsk, "kthreadd");
- ignore_signals(tsk);
- set_cpus_allowed_ptr(tsk, cpu_all_mask);
- set_mems_allowed(node_states[N_MEMORY]);
- current->flags |= PF_NOFREEZE;
- cgroup_init_kthreadd();
- for (;;) {
- set_current_state(TASK_INTERRUPTIBLE);
- if (list_empty(&kthread_create_list))
- schedule();
- __set_current_state(TASK_RUNNING);
- spin_lock(&kthread_create_lock);
- while (!list_empty(&kthread_create_list)) {
- struct kthread_create_info *create;
- create = list_entry(kthread_create_list.next,
- struct kthread_create_info, list);
- list_del_init(&create->list);
- spin_unlock(&kthread_create_lock);
- create_kthread(create);
- spin_lock(&kthread_create_lock);
- }
- spin_unlock(&kthread_create_lock);
- }
- return 0;
- }
- void __kthread_init_worker(struct kthread_worker *worker,
- const char *name,
- struct lock_class_key *key)
- {
- memset(worker, 0, sizeof(struct kthread_worker));
- spin_lock_init(&worker->lock);
- lockdep_set_class_and_name(&worker->lock, key, name);
- INIT_LIST_HEAD(&worker->work_list);
- INIT_LIST_HEAD(&worker->delayed_work_list);
- }
- EXPORT_SYMBOL_GPL(__kthread_init_worker);
- int kthread_worker_fn(void *worker_ptr)
- {
- struct kthread_worker *worker = worker_ptr;
- struct kthread_work *work;
-
- WARN_ON(worker->task && worker->task != current);
- worker->task = current;
- if (worker->flags & KTW_FREEZABLE)
- set_freezable();
- repeat:
- set_current_state(TASK_INTERRUPTIBLE);
- if (kthread_should_stop()) {
- __set_current_state(TASK_RUNNING);
- spin_lock_irq(&worker->lock);
- worker->task = NULL;
- spin_unlock_irq(&worker->lock);
- return 0;
- }
- work = NULL;
- spin_lock_irq(&worker->lock);
- if (!list_empty(&worker->work_list)) {
- work = list_first_entry(&worker->work_list,
- struct kthread_work, node);
- list_del_init(&work->node);
- }
- worker->current_work = work;
- spin_unlock_irq(&worker->lock);
- if (work) {
- __set_current_state(TASK_RUNNING);
- work->func(work);
- } else if (!freezing(current))
- schedule();
- try_to_freeze();
- goto repeat;
- }
- EXPORT_SYMBOL_GPL(kthread_worker_fn);
- static struct kthread_worker *
- __kthread_create_worker(int cpu, unsigned int flags,
- const char namefmt[], va_list args)
- {
- struct kthread_worker *worker;
- struct task_struct *task;
- worker = kzalloc(sizeof(*worker), GFP_KERNEL);
- if (!worker)
- return ERR_PTR(-ENOMEM);
- kthread_init_worker(worker);
- if (cpu >= 0) {
- char name[TASK_COMM_LEN];
-
- vsnprintf(name, sizeof(name), namefmt, args);
- task = kthread_create_on_cpu(kthread_worker_fn, worker,
- cpu, name);
- } else {
- task = __kthread_create_on_node(kthread_worker_fn, worker,
- -1, namefmt, args);
- }
- if (IS_ERR(task))
- goto fail_task;
- worker->flags = flags;
- worker->task = task;
- wake_up_process(task);
- return worker;
- fail_task:
- kfree(worker);
- return ERR_CAST(task);
- }
- struct kthread_worker *
- kthread_create_worker(unsigned int flags, const char namefmt[], ...)
- {
- struct kthread_worker *worker;
- va_list args;
- va_start(args, namefmt);
- worker = __kthread_create_worker(-1, flags, namefmt, args);
- va_end(args);
- return worker;
- }
- EXPORT_SYMBOL(kthread_create_worker);
- struct kthread_worker *
- kthread_create_worker_on_cpu(int cpu, unsigned int flags,
- const char namefmt[], ...)
- {
- struct kthread_worker *worker;
- va_list args;
- va_start(args, namefmt);
- worker = __kthread_create_worker(cpu, flags, namefmt, args);
- va_end(args);
- return worker;
- }
- EXPORT_SYMBOL(kthread_create_worker_on_cpu);
- static inline bool queuing_blocked(struct kthread_worker *worker,
- struct kthread_work *work)
- {
- lockdep_assert_held(&worker->lock);
- return !list_empty(&work->node) || work->canceling;
- }
- static void kthread_insert_work_sanity_check(struct kthread_worker *worker,
- struct kthread_work *work)
- {
- lockdep_assert_held(&worker->lock);
- WARN_ON_ONCE(!list_empty(&work->node));
-
- WARN_ON_ONCE(work->worker && work->worker != worker);
- }
- static void kthread_insert_work(struct kthread_worker *worker,
- struct kthread_work *work,
- struct list_head *pos)
- {
- kthread_insert_work_sanity_check(worker, work);
- list_add_tail(&work->node, pos);
- work->worker = worker;
- if (!worker->current_work && likely(worker->task))
- wake_up_process(worker->task);
- }
- bool kthread_queue_work(struct kthread_worker *worker,
- struct kthread_work *work)
- {
- bool ret = false;
- unsigned long flags;
- spin_lock_irqsave(&worker->lock, flags);
- if (!queuing_blocked(worker, work)) {
- kthread_insert_work(worker, work, &worker->work_list);
- ret = true;
- }
- spin_unlock_irqrestore(&worker->lock, flags);
- return ret;
- }
- EXPORT_SYMBOL_GPL(kthread_queue_work);
- void kthread_delayed_work_timer_fn(unsigned long __data)
- {
- struct kthread_delayed_work *dwork =
- (struct kthread_delayed_work *)__data;
- struct kthread_work *work = &dwork->work;
- struct kthread_worker *worker = work->worker;
-
- if (WARN_ON_ONCE(!worker))
- return;
- spin_lock(&worker->lock);
-
- WARN_ON_ONCE(work->worker != worker);
-
- WARN_ON_ONCE(list_empty(&work->node));
- list_del_init(&work->node);
- kthread_insert_work(worker, work, &worker->work_list);
- spin_unlock(&worker->lock);
- }
- EXPORT_SYMBOL(kthread_delayed_work_timer_fn);
- void __kthread_queue_delayed_work(struct kthread_worker *worker,
- struct kthread_delayed_work *dwork,
- unsigned long delay)
- {
- struct timer_list *timer = &dwork->timer;
- struct kthread_work *work = &dwork->work;
- WARN_ON_ONCE(timer->function != kthread_delayed_work_timer_fn ||
- timer->data != (unsigned long)dwork);
-
- if (!delay) {
- kthread_insert_work(worker, work, &worker->work_list);
- return;
- }
-
- kthread_insert_work_sanity_check(worker, work);
- list_add(&work->node, &worker->delayed_work_list);
- work->worker = worker;
- timer_stats_timer_set_start_info(&dwork->timer);
- timer->expires = jiffies + delay;
- add_timer(timer);
- }
- bool kthread_queue_delayed_work(struct kthread_worker *worker,
- struct kthread_delayed_work *dwork,
- unsigned long delay)
- {
- struct kthread_work *work = &dwork->work;
- unsigned long flags;
- bool ret = false;
- spin_lock_irqsave(&worker->lock, flags);
- if (!queuing_blocked(worker, work)) {
- __kthread_queue_delayed_work(worker, dwork, delay);
- ret = true;
- }
- spin_unlock_irqrestore(&worker->lock, flags);
- return ret;
- }
- EXPORT_SYMBOL_GPL(kthread_queue_delayed_work);
- struct kthread_flush_work {
- struct kthread_work work;
- struct completion done;
- };
- static void kthread_flush_work_fn(struct kthread_work *work)
- {
- struct kthread_flush_work *fwork =
- container_of(work, struct kthread_flush_work, work);
- complete(&fwork->done);
- }
- void kthread_flush_work(struct kthread_work *work)
- {
- struct kthread_flush_work fwork = {
- KTHREAD_WORK_INIT(fwork.work, kthread_flush_work_fn),
- COMPLETION_INITIALIZER_ONSTACK(fwork.done),
- };
- struct kthread_worker *worker;
- bool noop = false;
- worker = work->worker;
- if (!worker)
- return;
- spin_lock_irq(&worker->lock);
-
- WARN_ON_ONCE(work->worker != worker);
- if (!list_empty(&work->node))
- kthread_insert_work(worker, &fwork.work, work->node.next);
- else if (worker->current_work == work)
- kthread_insert_work(worker, &fwork.work,
- worker->work_list.next);
- else
- noop = true;
- spin_unlock_irq(&worker->lock);
- if (!noop)
- wait_for_completion(&fwork.done);
- }
- EXPORT_SYMBOL_GPL(kthread_flush_work);
- static bool __kthread_cancel_work(struct kthread_work *work, bool is_dwork,
- unsigned long *flags)
- {
-
- if (is_dwork) {
- struct kthread_delayed_work *dwork =
- container_of(work, struct kthread_delayed_work, work);
- struct kthread_worker *worker = work->worker;
-
- work->canceling++;
- spin_unlock_irqrestore(&worker->lock, *flags);
- del_timer_sync(&dwork->timer);
- spin_lock_irqsave(&worker->lock, *flags);
- work->canceling--;
- }
-
- if (!list_empty(&work->node)) {
- list_del_init(&work->node);
- return true;
- }
- return false;
- }
- bool kthread_mod_delayed_work(struct kthread_worker *worker,
- struct kthread_delayed_work *dwork,
- unsigned long delay)
- {
- struct kthread_work *work = &dwork->work;
- unsigned long flags;
- int ret = false;
- spin_lock_irqsave(&worker->lock, flags);
-
- if (!work->worker)
- goto fast_queue;
-
- WARN_ON_ONCE(work->worker != worker);
-
- if (work->canceling)
- goto out;
- ret = __kthread_cancel_work(work, true, &flags);
- fast_queue:
- __kthread_queue_delayed_work(worker, dwork, delay);
- out:
- spin_unlock_irqrestore(&worker->lock, flags);
- return ret;
- }
- EXPORT_SYMBOL_GPL(kthread_mod_delayed_work);
- static bool __kthread_cancel_work_sync(struct kthread_work *work, bool is_dwork)
- {
- struct kthread_worker *worker = work->worker;
- unsigned long flags;
- int ret = false;
- if (!worker)
- goto out;
- spin_lock_irqsave(&worker->lock, flags);
-
- WARN_ON_ONCE(work->worker != worker);
- ret = __kthread_cancel_work(work, is_dwork, &flags);
- if (worker->current_work != work)
- goto out_fast;
-
- work->canceling++;
- spin_unlock_irqrestore(&worker->lock, flags);
- kthread_flush_work(work);
- spin_lock_irqsave(&worker->lock, flags);
- work->canceling--;
- out_fast:
- spin_unlock_irqrestore(&worker->lock, flags);
- out:
- return ret;
- }
- bool kthread_cancel_work_sync(struct kthread_work *work)
- {
- return __kthread_cancel_work_sync(work, false);
- }
- EXPORT_SYMBOL_GPL(kthread_cancel_work_sync);
- bool kthread_cancel_delayed_work_sync(struct kthread_delayed_work *dwork)
- {
- return __kthread_cancel_work_sync(&dwork->work, true);
- }
- EXPORT_SYMBOL_GPL(kthread_cancel_delayed_work_sync);
- void kthread_flush_worker(struct kthread_worker *worker)
- {
- struct kthread_flush_work fwork = {
- KTHREAD_WORK_INIT(fwork.work, kthread_flush_work_fn),
- COMPLETION_INITIALIZER_ONSTACK(fwork.done),
- };
- kthread_queue_work(worker, &fwork.work);
- wait_for_completion(&fwork.done);
- }
- EXPORT_SYMBOL_GPL(kthread_flush_worker);
- void kthread_destroy_worker(struct kthread_worker *worker)
- {
- struct task_struct *task;
- task = worker->task;
- if (WARN_ON(!task))
- return;
- kthread_flush_worker(worker);
- kthread_stop(task);
- WARN_ON(!list_empty(&worker->work_list));
- kfree(worker);
- }
- EXPORT_SYMBOL(kthread_destroy_worker);
|