Home
last modified time | relevance | path

Searched refs:task (Results 1 – 25 of 421) sorted by relevance

12345678910>>...17

/freebsd/contrib/ntp/libntp/lib/isc/
H A Dtask.c71 task, isc_thread_self(), (m))
197 isc__task_purge(isc_task_t *task, void *sender, isc_eventtype_t type,
202 isc__task_unsendrange(isc_task_t *task, void *sender, isc_eventtype_t first,
206 isc__task_unsend(isc_task_t *task, void *sender, isc_eventtype_t type,
229 isc__task_beginexclusive(isc_task_t *task);
248 push_readyq(isc__taskmgr_t *manager, isc__task_t *task);
297 task_finished(isc__task_t *task) { in task_finished() argument
298 isc__taskmgr_t *manager = task->manager; in task_finished()
300 REQUIRE(EMPTY(task->events)); in task_finished()
301 REQUIRE(EMPTY(task->on_shutdown)); in task_finished()
[all …]
H A Dondestroy.c42 isc_ondestroy_register(isc_ondestroy_t *ondest, isc_task_t *task, in isc_ondestroy_register() argument
49 REQUIRE(task != NULL); in isc_ondestroy_register()
56 isc_task_attach(task, &thetask); in isc_ondestroy_register()
68 isc_task_t *task; in isc_ondestroy_notify() local
76 task = eventp->ev_sender; in isc_ondestroy_notify()
79 isc_task_sendanddetach(&task, &eventp); in isc_ondestroy_notify()
/freebsd/sys/compat/linuxkpi/common/src/
H A Dlinux_kthread.c44 linux_kthread_should_stop_task(struct task_struct *task) in linux_kthread_should_stop_task() argument
47 return (atomic_read(&task->kthread_flags) & KTHREAD_SHOULD_STOP_MASK); in linux_kthread_should_stop_task()
58 linux_kthread_stop(struct task_struct *task) in linux_kthread_stop() argument
66 atomic_or(KTHREAD_SHOULD_STOP_MASK, &task->kthread_flags); in linux_kthread_stop()
67 kthread_unpark(task); in linux_kthread_stop()
68 wake_up_process(task); in linux_kthread_stop()
69 wait_for_completion(&task->exited); in linux_kthread_stop()
74 retval = task->task_ret; in linux_kthread_stop()
75 put_task_struct(task); in linux_kthread_stop()
81 linux_kthread_park(struct task_struct *task) in linux_kthread_park() argument
[all …]
H A Dlinux_schedule.c59 linux_add_to_sleepqueue(void *wchan, struct task_struct *task, in linux_add_to_sleepqueue() argument
91 linux_schedule_save_interrupt_value(task, ret); in linux_add_to_sleepqueue()
117 wake_up_task(struct task_struct *task, unsigned int state) in wake_up_task() argument
122 sleepq_lock(task); in wake_up_task()
123 if ((atomic_read(&task->state) & state) != 0) { in wake_up_task()
124 set_task_state(task, TASK_WAKING); in wake_up_task()
125 sleepq_signal(task, SLEEPQ_SLEEP, 0, 0); in wake_up_task()
128 sleepq_release(task); in wake_up_task()
133 linux_signal_pending(struct task_struct *task) in linux_signal_pending() argument
138 td = task->task_thread; in linux_signal_pending()
[all …]
/freebsd/sys/compat/linuxkpi/common/include/linux/
H A Dsched.h101 #define task_pid_group_leader(task) (task)->task_thread->td_proc->p_pid argument
102 #define task_pid(task) ((task)->pid) argument
103 #define task_pid_nr(task) ((task)->pid) argument
104 #define task_pid_vnr(task) ((task)->pid) argument
108 #define task_euid(task) ((task)->task_thread->td_ucred->cr_uid) argument
110 #define get_task_state(task) atomic_read(&(task)->state) argument
111 #define set_task_state(task, x) atomic_set(&(task)->state, (x)) argument
112 #define __set_task_state(task, x) ((task)->state.counter = (x)) argument
117 get_task_struct(struct task_struct *task) in get_task_struct() argument
119 atomic_inc(&task->usage); in get_task_struct()
[all …]
H A Dkthread.h48 struct task_struct *task; member
54 struct task task; member
82 #define kthread_stop(task) linux_kthread_stop(task) argument
84 #define kthread_should_stop_task(task) linux_kthread_should_stop_task(task) argument
85 #define kthread_park(task) linux_kthread_park(task) argument
88 #define kthread_unpark(task) linux_kthread_unpark(task) argument
101 struct task __task; \
126 TASK_INIT(&work->task, 0, lkpi_kthread_work_fn, work); in kthread_init_work()
134 error = taskqueue_enqueue_flags(worker->tq, &work->task, in kthread_queue_work()
147 taskqueue_cancel(work->tq, &work->task, &pending) != 0) in kthread_cancel_work_sync()
[all …]
/freebsd/contrib/ntp/libntp/lib/isc/include/isc/
H A Dtask.h124 void (*send)(isc_task_t *task, isc_event_t **eventp);
126 unsigned int (*unsend)(isc_task_t *task, void *sender, isc_eventtype_t type,
128 isc_result_t (*onshutdown)(isc_task_t *task, isc_taskaction_t action,
130 void (*shutdown)(isc_task_t *task);
131 void (*setname)(isc_task_t *task, const char *name, void *tag);
132 unsigned int (*purgeevents)(isc_task_t *task, void *sender,
134 unsigned int (*purgerange)(isc_task_t *task, void *sender,
137 isc_result_t (*beginexclusive)(isc_task_t *task);
138 void (*endexclusive)(isc_task_t *task);
139 void (*setprivilege)(isc_task_t *task, isc_boolean_t priv);
[all …]
H A Dsocket.h272 void *cbarg, isc_task_t *task,
283 isc_task_t *task, isc_taskaction_t action,
287 isc_task_t *task, isc_taskaction_t action,
290 unsigned int minimum, isc_task_t *task,
292 void (*cancel)(isc_socket_t *sock, isc_task_t *task,
358 isc_task_t *task,
462 isc_socket_cancel(isc_socket_t *sock, isc_task_t *task,
670 isc_task_t *task, isc_taskaction_t action, const void *arg);
693 isc_task_t *task, isc_taskaction_t action,
761 isc_task_t *task, isc_taskaction_t action, const void *arg);
[all …]
/freebsd/sys/contrib/openzfs/module/os/freebsd/spl/
H A Dspl_taskq.c346 taskq_free(taskq_ent_t *task) in taskq_free() argument
348 taskq_remove(task); in taskq_free()
349 if (refcount_release(&task->tqent_rc)) in taskq_free()
350 uma_zfree(taskq_zone, task); in taskq_free()
397 taskq_ent_t *task = arg; in taskq_run() local
401 task->tqent_func(task->tqent_arg); in taskq_run()
402 taskq_free(task); in taskq_run()
409 taskq_ent_t *task; in taskq_dispatch_delay() local
423 task = uma_zalloc(taskq_zone, mflag); in taskq_dispatch_delay()
424 if (task == NULL) in taskq_dispatch_delay()
[all …]
/freebsd/sys/cddl/compat/opensolaris/kern/
H A Dopensolaris_taskq.c114 taskq_ent_t *task = arg; in taskq_run() local
116 task->tqent_func(task->tqent_arg); in taskq_run()
118 uma_zfree(taskq_zone, task); in taskq_run()
124 taskq_ent_t *task; in taskq_dispatch() local
137 task = uma_zalloc(taskq_zone, mflag); in taskq_dispatch()
138 if (task == NULL) in taskq_dispatch()
141 task->tqent_func = func; in taskq_dispatch()
142 task->tqent_arg = arg; in taskq_dispatch()
144 TASK_INIT(&task->tqent_task, prio, taskq_run, task); in taskq_dispatch()
145 taskqueue_enqueue(tq->tq_queue, &task->tqent_task); in taskq_dispatch()
[all …]
/freebsd/contrib/llvm-project/openmp/runtime/src/
H A Dkmp_taskdeps.h94 static inline void __kmp_release_deps(kmp_int32 gtid, kmp_taskdata_t *task) { in __kmp_release_deps() argument
97 if (task->is_taskgraph && !(__kmp_tdg_is_recording(task->tdg->tdg_status))) { in __kmp_release_deps()
98 kmp_node_info_t *TaskInfo = &(task->tdg->record_map[task->td_task_id]); in __kmp_release_deps()
102 kmp_node_info_t *successor = &(task->tdg->record_map[successorNumber]); in __kmp_release_deps()
104 if (successor->task != nullptr && npredecessors == 0) { in __kmp_release_deps()
105 __kmp_omp_task(gtid, successor->task, false); in __kmp_release_deps()
113 kmp_depnode_t *node = task->td_depnode; in __kmp_release_deps()
125 if (task->td_dephash) { in __kmp_release_deps()
128 gtid, task)); in __kmp_release_deps()
129 __kmp_dephash_free(thread, task->td_dephash); in __kmp_release_deps()
[all …]
H A Dkmp_tasking.cpp477 static kmp_int32 __kmp_push_task(kmp_int32 gtid, kmp_task_t *task) { argument
479 kmp_taskdata_t *taskdata = KMP_TASK_TO_TASKDATA(task);
487 __kmpc_give_task(task, __kmp_tid_from_gtid(shadow_gtid));
528 if (taskdata->td_flags.priority_specified && task->data2.priority > 0 &&
530 int pri = KMP_MIN(task->data2.priority, __kmp_max_task_priority);
670 static void __kmp_task_start(kmp_int32 gtid, kmp_task_t *task, argument
672 kmp_taskdata_t *taskdata = KMP_TASK_TO_TASKDATA(task);
721 static inline void __ompt_task_init(kmp_taskdata_t *task, int tid) { argument
723 task->ompt_task_info.task_data.value = 0;
724 task->ompt_task_info.frame.exit_frame = ompt_data_none;
[all …]
H A Dkmp_taskdeps.cpp38 node->dn.task = NULL; // will point to the right task in __kmp_init_node()
222 kmp_taskdata_t *task_source = KMP_TASK_TO_TASKDATA(source->dn.task); in __kmp_track_dependence()
224 if (source->dn.task && sink_task) { in __kmp_track_dependence()
260 kmp_taskdata_t *task_source = KMP_TASK_TO_TASKDATA(source->dn.task); in __kmp_track_dependence()
274 kmp_taskdata_t *task_source = KMP_TASK_TO_TASKDATA(source->dn.task); in __kmp_track_dependence()
287 kmp_base_depnode_t *__kmpc_task_get_depnode(kmp_task_t *task) { in __kmpc_task_get_depnode() argument
288 kmp_taskdata_t *td = KMP_TASK_TO_TASKDATA(task); in __kmpc_task_get_depnode()
292 kmp_depnode_list_t *__kmpc_task_get_successors(kmp_task_t *task) { in __kmpc_task_get_successors() argument
293 kmp_taskdata_t *td = KMP_TASK_TO_TASKDATA(task); in __kmpc_task_get_successors()
299 kmp_task_t *task, kmp_depnode_t *node, in __kmp_depnode_link_successor() argument
[all …]
H A Dkmp_cancel.cpp81 kmp_taskdata_t *task; in __kmpc_cancel() local
84 task = this_thr->th.th_current_task; in __kmpc_cancel()
85 KMP_DEBUG_ASSERT(task); in __kmpc_cancel()
87 taskgroup = task->td_taskgroup; in __kmpc_cancel()
194 kmp_taskdata_t *task; in __kmpc_cancellationpoint() local
197 task = this_thr->th.th_current_task; in __kmpc_cancellationpoint()
198 KMP_DEBUG_ASSERT(task); in __kmpc_cancellationpoint()
200 taskgroup = task->td_taskgroup; in __kmpc_cancellationpoint()
321 kmp_taskdata_t *task; in __kmp_get_cancellation_status() local
323 task = this_thr->th.th_current_task; in __kmp_get_cancellation_status()
[all …]
H A Dkmp_gsupport.cpp381 __kmp_GOMP_microtask_wrapper(int *gtid, int *npr, void (*task)(void *), in __kmp_GOMP_microtask_wrapper()
402 task(data); in __kmp_GOMP_microtask_wrapper()
420 void (*task)(void *), void *data, in __kmp_GOMP_parallel_microtask_wrapper()
448 task(data); in __kmp_GOMP_parallel_microtask_wrapper()
505 void KMP_EXPAND_NAME(KMP_API_NAME_GOMP_PARALLEL_START)(void (*task)(void *), in KMP_EXPAND_NAME()
522 __kmp_GOMP_fork_call(&loc, gtid, num_threads, 0u, task, in KMP_EXPAND_NAME()
523 (microtask_t)__kmp_GOMP_microtask_wrapper, 2, task, in KMP_EXPAND_NAME()
1160 void func(void (*task)(void *), void *data, unsigned num_threads, long lb, \
1172 __kmp_GOMP_fork_call(&loc, gtid, num_threads, 0u, task, \
1174 9, task, data, num_threads, &loc, (schedule), lb, \
[all …]
/freebsd/sys/kern/
H A Dsubr_taskqueue.c57 struct task *tb_running;
64 STAILQ_HEAD(, task) tq_queue;
66 struct task *tq_hint;
127 task_get_busy(struct taskqueue *queue, struct task *task) in task_get_busy() argument
133 if (tb->tb_running == task) in task_get_busy()
231 taskqueue_enqueue_locked(struct taskqueue *queue, struct task *task, int flags) in taskqueue_enqueue_locked() argument
233 struct task *ins; in taskqueue_enqueue_locked()
234 struct task *prev; in taskqueue_enqueue_locked()
237 KASSERT(task->ta_func != NULL, ("enqueueing task with NULL func")); in taskqueue_enqueue_locked()
242 tb = task_get_busy(queue, task); in taskqueue_enqueue_locked()
[all …]
/freebsd/sys/contrib/dev/mediatek/mt76/
H A Dutil.h19 struct task_struct *task; member
69 w->task = kthread_run(__mt76_worker_fn, w, in mt76_worker_setup()
72 if (IS_ERR(w->task)) { in mt76_worker_setup()
73 ret = PTR_ERR(w->task); in mt76_worker_setup()
74 w->task = NULL; in mt76_worker_setup()
83 if (!w->task) in mt76_worker_schedule()
88 wake_up_process(w->task); in mt76_worker_schedule()
93 if (!w->task) in mt76_worker_disable()
96 kthread_park(w->task); in mt76_worker_disable()
102 if (!w->task) in mt76_worker_enable()
[all …]
/freebsd/sys/sys/
H A Dtaskqueue.h78 int taskqueue_enqueue(struct taskqueue *queue, struct task *task);
79 int taskqueue_enqueue_flags(struct taskqueue *queue, struct task *task,
86 int taskqueue_poll_is_busy(struct taskqueue *queue, struct task *task);
87 int taskqueue_cancel(struct taskqueue *queue, struct task *task,
91 void taskqueue_drain(struct taskqueue *queue, struct task *task);
119 #define TASK_INIT_FLAGS(task, priority, func, context, flags) do { \ argument
120 (task)->ta_pending = 0; \
121 (task)->ta_priority = (priority); \
122 (task)->ta_flags = (flags); \
123 (task)->ta_func = (func); \
[all …]
/freebsd/sys/contrib/openzfs/module/zfs/
H A Dzvol.c137 zv_request_task_t *task; in zv_request_task_create() local
138 task = kmem_alloc(sizeof (zv_request_task_t), KM_SLEEP); in zv_request_task_create()
139 taskq_init_ent(&task->ent); in zv_request_task_create()
140 task->zvr = zvr; in zv_request_task_create()
141 return (task); in zv_request_task_create()
145 zv_request_task_free(zv_request_task_t *task) in zv_request_task_free() argument
147 kmem_free(task, sizeof (*task)); in zv_request_task_free()
1454 zvol_task_update_status(zvol_task_t *task, uint64_t total, uint64_t done, in zvol_task_update_status() argument
1458 task->zt_total += total; in zvol_task_update_status()
1459 task->zt_done += done; in zvol_task_update_status()
[all …]
/freebsd/sys/dev/usb/net/
H A Dusb_ethernet.c105 struct usb_ether_cfg_task *task; in ue_queue_command() local
117 task = (struct usb_ether_cfg_task *) in ue_queue_command()
121 task->hdr.pm_callback = fn; in ue_queue_command()
122 task->ue = ue; in ue_queue_command()
203 struct usb_ether_cfg_task *task = in ue_attach_post_task() local
205 struct usb_ether *ue = task->ue; in ue_attach_post_task()
367 struct usb_ether_cfg_task *task = in ue_start_task() local
369 struct usb_ether *ue = task->ue; in ue_start_task()
386 struct usb_ether_cfg_task *task = in ue_stop_task() local
388 struct usb_ether *ue = task->ue; in ue_stop_task()
[all …]
/freebsd/sys/net80211/
H A Dieee80211_var.h150 struct task ic_parent_task; /* deferred parent processing */
151 struct task ic_promisc_task;/* deferred promisc update */
152 struct task ic_mcast_task; /* deferred mcast update */
153 struct task ic_chan_task; /* deferred channel change */
154 struct task ic_bmiss_task; /* deferred beacon miss hndlr */
155 struct task ic_chw_task; /* deferred HT CHW update */
156 struct task ic_restart_task; /* deferred device restart */
427 struct task iv_nstate_task[NET80211_IV_NSTATE_NUM];
429 struct task iv_swbmiss_task;/* deferred iv_bmiss call */
586 struct task iv_wme_task; /* deferred VAP WME update */
[all …]
/freebsd/sys/arm64/spe/
H A Darm_spe_dev.h78 struct task task; member
107 struct task task[2]; member
108 struct task flush_task;
/freebsd/cddl/contrib/opensolaris/lib/pyzfs/common/
H A Dutil.py67 def __init__(self, eno, task=None, why=None): argument
75 self.task = task
80 if self.task:
81 s += self.task + ": "
/freebsd/sys/dev/hyperv/vmbus/
H A Dvmbus_chanvar.h58 struct task ch_task;
59 struct task ch_poll_task;
128 struct task ch_attach_task; /* run in ch_mgmt_tq */
129 struct task ch_detach_task; /* run in ch_mgmt_tq */
/freebsd/sys/contrib/openzfs/config/
H A Dkernel-kthread.m421 dnl # int dequeue_signal(struct task_struct *task, sigset_t *mask,
25 dnl # int dequeue_signal(struct task_struct *task, sigset_t *mask,
29 dnl # int dequeue_signal(struct task_struct *task, sigset_t *mask,
69 struct task_struct *task = NULL;
75 error = dequeue_signal(task, mask, info, type);

12345678910>>...17