Searched refs:task (Results 1 - 25 of 322) sorted by relevance

1234567891011>>

/freebsd-11-stable/sys/compat/linuxkpi/common/src/
H A Dlinux_kthread.c46 linux_kthread_should_stop_task(struct task_struct *task) argument
49 return (atomic_read(&task->kthread_flags) & KTHREAD_SHOULD_STOP_MASK);
60 linux_kthread_stop(struct task_struct *task) argument
65 * Assume task is still alive else caller should not call
68 atomic_or(KTHREAD_SHOULD_STOP_MASK, &task->kthread_flags);
69 kthread_unpark(task);
70 wake_up_process(task);
71 wait_for_completion(&task->exited);
74 * Get return code and free task structure:
76 retval = task
83 linux_kthread_park(struct task_struct *task) argument
95 struct task_struct *task; local
113 struct task_struct *task; local
120 linux_kthread_unpark(struct task_struct *task) argument
132 struct task_struct *task; local
153 struct task_struct *task = current; local
[all...]
H A Dlinux_schedule.c45 linux_add_to_sleepqueue(void *wchan, struct task_struct *task, argument
76 linux_schedule_save_interrupt_value(task, ret);
102 wake_up_task(struct task_struct *task, unsigned int state) argument
107 sleepq_lock(task);
108 if ((atomic_read(&task->state) & state) != 0) {
109 set_task_state(task, TASK_WAKING);
110 wakeup_swapper = sleepq_signal(task, SLEEPQ_SLEEP, 0, 0);
113 sleepq_release(task);
120 linux_signal_pending(struct task_struct *task) argument
125 td = task
135 linux_fatal_signal_pending(struct task_struct *task) argument
149 linux_signal_pending_state(long state, struct task_struct *task) argument
160 linux_send_sig(int signo, struct task_struct *task) argument
174 struct task_struct *task; local
260 struct task_struct *task; local
297 struct task_struct *task; local
364 struct task_struct *task; local
404 struct task_struct *task; local
428 linux_wake_up_state(struct task_struct *task, unsigned int state) argument
[all...]
/freebsd-11-stable/sys/compat/linuxkpi/common/include/linux/
H A Dsched.h93 #define task_pid_group_leader(task) (task)->task_thread->td_proc->p_pid
94 #define task_pid(task) ((task)->pid)
95 #define task_pid_nr(task) ((task)->pid)
96 #define task_pid_vnr(task) ((task)->pid)
101 #define set_task_state(task, x) atomic_set(&(task)
107 get_task_struct(struct task_struct *task) argument
113 put_task_struct(struct task_struct *task) argument
143 linux_schedule_save_interrupt_value(struct task_struct *task, int value) argument
154 linux_schedule_get_interrupt_value(struct task_struct *task) argument
189 get_task_comm(char *buf, struct task_struct *task) argument
[all...]
H A Dkthread.h63 #define kthread_stop(task) linux_kthread_stop(task)
65 #define kthread_should_stop_task(task) linux_kthread_should_stop_task(task)
66 #define kthread_park(task) linux_kthread_park(task)
69 #define kthread_unpark(task) linux_kthread_unpark(task)
H A Dpid.h61 #define get_task_pid(task, type) ({ \
63 (task)->task_thread->td_tid; \
/freebsd-11-stable/contrib/ntp/lib/isc/
H A Dtask.c25 * XXXRTH Need to document the states a task can be in, and the rules
38 #include <isc/task.h>
51 * when built without threads we share a single global task manager and use
52 * an integrated event loop for socket, timer, and other generic task events.
54 * we don't use either of them: an application can have multiple task managers
70 #define XTRACE(m) fprintf(stderr, "task %p thread %lu: %s\n", \
71 task, isc_thread_self(), (m))
72 #define XTTRACE(t, m) fprintf(stderr, "task %p thread %lu: %s\n", \
108 /* Locked by task lock. */
118 /* Locked by task manage
297 task_finished(isc__task_t *task) argument
333 isc__task_t *task; local
412 task_shutdown(isc__task_t *task) argument
455 task_ready(isc__task_t *task) argument
476 task_detach(isc__task_t *task) argument
506 isc__task_t *task; local
530 task_send(isc__task_t *task, isc_event_t **eventp) argument
561 isc__task_t *task = (isc__task_t *)task0; local
604 isc__task_t *task; local
638 dequeue_events(isc__task_t *task, void *sender, isc_eventtype_t first, isc_eventtype_t last, void *tag, isc_eventlist_t *events, isc_boolean_t purging) argument
681 isc__task_t *task = (isc__task_t *)task0; local
710 isc__task_purge(isc_task_t *task, void *sender, isc_eventtype_t type, void *tag) argument
724 isc__task_t *task = (isc__task_t *)task0; local
766 isc__task_unsendrange(isc_task_t *task, void *sender, isc_eventtype_t first, isc_eventtype_t last, void *tag, isc_eventlist_t *events) argument
781 isc__task_unsend(isc_task_t *task, void *sender, isc_eventtype_t type, void *tag, isc_eventlist_t *events) argument
798 isc__task_t *task = (isc__task_t *)task0; local
836 isc__task_t *task = (isc__task_t *)task0; local
868 isc__task_t *task = (isc__task_t *)task0; local
885 isc__task_t *task = (isc__task_t *)task0; local
894 isc__task_t *task = (isc__task_t *)task0; local
903 isc__task_t *task = (isc__task_t *)task0; local
946 isc__task_t *task; local
970 push_readyq(isc__taskmgr_t *manager, isc__task_t *task) argument
979 isc__task_t *task; local
1458 isc__task_t *task; local
1643 isc__task_t *task = (isc__task_t *)task0; local
1665 isc__task_t *task = (isc__task_t *)task0; local
1681 isc__task_t *task = (isc__task_t *)task0; local
1708 isc__task_t *task = (isc__task_t *)task0; local
1726 isc__task_t *task = (isc__task_t *)t; local
1737 isc__task_t *task; local
[all...]
H A Dtask_api.c27 #include <isc/task.h>
146 isc_task_send(isc_task_t *task, isc_event_t **eventp) { argument
147 REQUIRE(ISCAPI_TASK_VALID(task));
150 task->methods->send(task, eventp);
166 isc_task_unsend(isc_task_t *task, void *sender, isc_eventtype_t type, argument
169 REQUIRE(ISCAPI_TASK_VALID(task));
171 return (task->methods->unsend(task, sender, type, tag, events));
175 isc_task_onshutdown(isc_task_t *task, isc_taskaction_ argument
183 isc_task_shutdown(isc_task_t *task) argument
190 isc_task_setname(isc_task_t *task, const char *name, void *tag) argument
197 isc_task_purge(isc_task_t *task, void *sender, isc_eventtype_t type, void *tag) argument
205 isc_task_beginexclusive(isc_task_t *task) argument
212 isc_task_endexclusive(isc_task_t *task) argument
219 isc_task_setprivilege(isc_task_t *task, isc_boolean_t priv) argument
226 isc_task_privilege(isc_task_t *task) argument
238 isc_task_purgerange(isc_task_t *task, void *sender, isc_eventtype_t first, isc_eventtype_t last, void *tag) argument
[all...]
H A Dondestroy.c29 #include <isc/task.h>
42 isc_ondestroy_register(isc_ondestroy_t *ondest, isc_task_t *task, argument
49 REQUIRE(task != NULL);
56 isc_task_attach(task, &thetask);
68 isc_task_t *task; local
76 task = eventp->ev_sender;
79 isc_task_sendanddetach(&task, &eventp);
H A Dratelimiter.c26 #include <isc/task.h>
42 isc_task_t * task; member in struct:isc_ratelimiter
54 ratelimiter_tick(isc_task_t *task, isc_event_t *event);
57 ratelimiter_shutdowncomplete(isc_task_t *task, isc_event_t *event);
61 isc_task_t *task, isc_ratelimiter_t **ratelimiterp)
72 rl->task = task;
83 NULL, NULL, rl->task, ratelimiter_tick,
133 isc_ratelimiter_enqueue(isc_ratelimiter_t *rl, isc_task_t *task, argument
140 REQUIRE(task !
60 isc_ratelimiter_create(isc_mem_t *mctx, isc_timermgr_t *timermgr, isc_task_t *task, isc_ratelimiter_t **ratelimiterp) argument
169 ratelimiter_tick(isc_task_t *task, isc_event_t *event) argument
213 isc_task_t *task; local
236 ratelimiter_shutdowncomplete(isc_task_t *task, isc_event_t *event) argument
[all...]
/freebsd-11-stable/contrib/ntp/lib/isc/include/isc/
H A Dtask.h27 /*! \file isc/task.h
28 * \brief The task system provides a lightweight execution context, which is
31 * When a task's event queue is non-empty, the
32 * task is runnable. A small work crew of threads, typically one per CPU,
56 * Events which have been queued for a task but not delivered may be removed
57 * from the task's event queue by purging or unsending.
109 /*% Task and task manager methods */
124 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_
[all...]
H A Dondestroy.h56 * X_ondestroy(X *instance, isc_task_t *task,
58 * return(isc_ondestroy_register(&instance->ondest, task,eventp));
94 isc_ondestroy_register(isc_ondestroy_t *ondest, isc_task_t *task,
98 * Stores task and *eventp away inside *ondest. Ownership of **event is
99 * taken from the caller (and *eventp is set to NULL). The task is attached
106 * Dispatches the event(s) to the task(s) that were given in
H A Dsocket.h29 * sources in the task system.
32 * event queue of the task which requested the I/O.
37 * Clients of this module must not be holding a socket's task's lock when
272 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,
[all...]
H A Dhttpd.h28 #include <isc/task.h>
40 isc_httpdmgr_create(isc_mem_t *mctx, isc_socket_t *sock, isc_task_t *task,
H A Dratelimiter.h48 isc_task_t *task, isc_ratelimiter_t **ratelimiterp);
71 isc_ratelimiter_enqueue(isc_ratelimiter_t *rl, isc_task_t *task,
77 * to doing an isc_task_send() to the 'task', except that the
81 * '(*eventp)->ev_sender' is used to hold the task. The caller
82 * must ensure that the task exists until the event is delivered.
88 *\li 'task' to be non NULL.
99 * dispatched to the task are dispatched immediately with
105 *\li The rate limiter is no longer attached to its task.
/freebsd-11-stable/sys/dev/wtap/wtap_hal/
H A Dhandler.h46 struct task proc;
/freebsd-11-stable/sys/cddl/compat/opensolaris/kern/
H A Dopensolaris_taskq.c108 taskq_ent_t *task = arg; local
110 task->tqent_func(task->tqent_arg);
112 uma_zfree(taskq_zone, task);
118 taskq_ent_t *task; local
126 * If TQ_FRONT is given, we want higher priority for this task, so it
131 task = uma_zalloc(taskq_zone, mflag);
132 if (task == NULL)
135 task->tqent_func = func;
136 task
147 taskq_ent_t *task = arg; local
153 taskq_dispatch_ent(taskq_t *tq, task_func_t func, void *arg, u_int flags, taskq_ent_t *task) argument
[all...]
/freebsd-11-stable/sys/dev/isci/scil/
H A Dscic_task_request.h62 * task management requests.
76 * based task management request object.
78 * @return Return the size of the SCIC task request object.
86 * task management requests, regardless of protocol. Memory
87 * initialization and functionality common to all task request types
91 * the user task request object and the core task request object.
94 * for which to build the task managmement request.
96 * object for which to build the task management request.
99 * memory when the task i
[all...]
/freebsd-11-stable/sys/kern/
H A Dsubr_taskqueue.c57 struct task *tb_running;
63 STAILQ_HEAD(, task) tq_queue;
65 struct task *tq_hint;
217 taskqueue_enqueue_locked(struct taskqueue *queue, struct task *task) argument
219 struct task *ins;
220 struct task *prev;
222 KASSERT(task->ta_func != NULL, ("enqueueing task with NULL func"));
226 if (task
274 taskqueue_enqueue(struct taskqueue *queue, struct task *task) argument
444 struct task *task; local
481 task_is_running(struct taskqueue *queue, struct task *task) argument
499 taskqueue_poll_is_busy(struct taskqueue *queue, struct task *task) argument
511 taskqueue_cancel_locked(struct taskqueue *queue, struct task *task, u_int *pendp) argument
527 taskqueue_cancel(struct taskqueue *queue, struct task *task, u_int *pendp) argument
560 taskqueue_drain(struct taskqueue *queue, struct task *task) argument
[all...]
/freebsd-11-stable/sys/sys/
H A Dtaskqueue.h47 struct task t;
79 int taskqueue_enqueue(struct taskqueue *queue, struct task *task);
85 int taskqueue_poll_is_busy(struct taskqueue *queue, struct task *task);
86 int taskqueue_cancel(struct taskqueue *queue, struct task *task,
90 void taskqueue_drain(struct taskqueue *queue, struct task *task);
117 * Initialise a task structur
[all...]
H A Dgtaskqueue.h50 void gtaskqueue_drain(struct gtaskqueue *queue, struct gtask *task);
53 int grouptaskqueue_enqueue(struct gtaskqueue *queue, struct gtask *task);
67 #define GTASK_INIT(task, flags, priority, func, context) do { \
68 (task)->ta_flags = flags; \
69 (task)->ta_priority = (priority); \
70 (task)->ta_func = (func); \
71 (task)->ta_context = (context); \
H A D_task.h35 * Each task includes a function which is called from
37 * field of struct task and the second argument is a count of how many
38 * times the task was enqueued before the call to taskqueue_run().
47 struct task { struct
48 STAILQ_ENTRY(task) ta_link; /* (q) link for queue */
51 task_fn_t *ta_func; /* (c) task handler */
59 gtask_fn_t *ta_func; /* (c) task handler */
/freebsd-11-stable/contrib/llvm-project/openmp/runtime/src/
H A Dkmp_taskdeps.h88 static inline void __kmp_release_deps(kmp_int32 gtid, kmp_taskdata_t *task) { argument
90 kmp_depnode_t *node = task->td_depnode;
92 if (task->td_dephash) {
94 40, ("__kmp_release_deps: T#%d freeing dependencies hash of task %p.\n",
95 gtid, task));
96 __kmp_dephash_free(thread, task->td_dephash);
97 task->td_dephash = NULL;
103 KA_TRACE(20, ("__kmp_release_deps: T#%d notifying successors of task %p.\n",
104 gtid, task));
107 node->dn.task
[all...]
/freebsd-11-stable/sys/dev/smc/
H A Dif_smcvar.h49 struct task smc_intr;
50 struct task smc_rx;
51 struct task smc_tx;
/freebsd-11-stable/contrib/ntp/lib/isc/tests/
H A Dsocket_test.c47 event_done(isc_task_t *task, isc_event_t *event) { argument
51 UNUSED(task);
88 isc_task_t *task = NULL; local
116 result = isc_task_create(taskmgr, 0, &task);
124 result = isc_socket_sendto(s1, &r, task, event_done, &completion,
134 result = isc_socket_recv(s2, &r, 1, task, event_done, &completion);
141 isc_task_detach(&task);
159 isc_task_t *task = NULL; local
190 result = isc_task_create(taskmgr, 0, &task);
198 result = isc_socket_sendto(s1, &r, task, event_don
[all...]
H A Dtask_test.c27 #include <isc/task.h>
37 /* task event handler, sets a boolean to true */
42 set(isc_task_t *task, isc_event_t *event) { argument
45 UNUSED(task);
54 set_and_drop(isc_task_t *task, isc_event_t *event) { argument
57 UNUSED(task);
71 /* Create a task */
74 atf_tc_set_md_var(tc, "descr", "create and destroy a task");
78 isc_task_t *task = NULL; local
85 result = isc_task_create(taskmgr, 0, &task);
101 isc_task_t *task = NULL; local
[all...]

Completed in 291 milliseconds

1234567891011>>