Home
last modified time | relevance | path

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

12345678910>>...67

/openbmc/linux/drivers/infiniband/sw/rxe/
H A Drxe_task.c41 rxe_get(task->qp); in __reserve_if_idle()
43 task->num_sched++; in __reserve_if_idle()
127 ret = task->func(task->qp); in do_task()
167 if (WARN_ON(task->num_done != task->num_sched)) in do_task()
169 task->qp, in do_task()
171 task->num_sched, task->num_done); in do_task()
176 task->ret = ret; in do_task()
195 task->qp = qp; in rxe_init_task()
217 if (!__is_done(task) && task->state < TASK_STATE_DRAINED) { in rxe_cleanup_task()
252 do_task(task); in rxe_run_task()
[all …]
/openbmc/qemu/io/
H A Dtask.c56 QIOTask *task; in qio_task_new() local
62 task->func = func; in qio_task_new()
70 return task; in qio_task_new()
78 task->thread->destroy(task->thread->opaque); in qio_task_free()
89 task->destroy(task->opaque); in qio_task_free()
92 task->destroyResult(task->result); in qio_task_free()
94 if (task->err) { in qio_task_free()
103 g_free(task); in qio_task_free()
124 task->thread->worker(task, task->thread->opaque); in qio_task_thread_worker()
184 qemu_cond_wait(&task->thread_cond, &task->thread_lock); in qio_task_wait_thread()
[all …]
/openbmc/linux/net/sunrpc/
H A Dsched.c778 trace_rpc_task_timeout(task, task->tk_action); in __rpc_queue_timer_fn()
811 task->tk_ops->rpc_call_prepare(task, task->tk_calldata); in rpc_prepare_task()
838 trace_rpc_task_end(task, task->tk_action); in rpc_exit_task()
841 task->tk_ops->rpc_count_stats(task, task->tk_calldata); in rpc_exit_task()
846 task->tk_ops->rpc_call_done(task, task->tk_calldata); in rpc_exit_task()
864 trace_rpc_task_signalled(task, task->tk_action); in rpc_signal_task()
943 xprt_needs_memalloc(task->tk_xprt, task)) in __rpc_execute()
1105 memset(task, 0, sizeof(*task)); in rpc_init_task()
1144 struct rpc_task *task = setup_data->task; in rpc_new_task() local
1237 rpc_do_put_task(task, task->tk_workqueue); in rpc_put_task_async()
[all …]
H A Dclnt.c1235 return task; in rpc_run_task()
1947 task->tk_status = rpcauth_wrap_req(task, &xdr); in rpc_xdr_encode()
1964 if (task->tk_status == 0 && rpc_reply_expected(task)) in call_encode()
1965 task->tk_status = xprt_request_enqueue_receive(task); in call_encode()
1976 rpc_call_rpcerror(task, task->tk_status); in call_encode()
1984 rpc_call_rpcerror(task, task->tk_status); in call_encode()
2322 rpc_call_rpcerror(task, task->tk_status); in call_transmit_status()
2432 trace_xprt_ping(task->tk_xprt, task->tk_status); in call_status()
2611 task->tk_status = rpcauth_unwrap_resp(task, &xdr); in call_decode()
3329 task->tk_pid, task->tk_flags, task->tk_status, in rpc_show_task()
[all …]
H A Dxprt.c276 xprt->snd_task = task; in xprt_reserve_xprt()
286 if (RPC_IS_SOFT(task)) in xprt_reserve_xprt()
352 if (RPC_IS_SOFT(task)) in xprt_reserve_xprt_cong()
380 xprt->snd_task = task; in __xprt_lock_write_func()
1504 task, 0); in xprt_prepare_transmit()
1643 if (task->tk_rqstp) in xprt_complete_request_init()
1753 task->tk_status = 0; in xprt_alloc_slot()
1877 req->rq_task = task; in xprt_request_init()
1914 task->tk_status = 0; in xprt_reserve()
1936 task->tk_status = 0; in xprt_retry_reserve()
[all …]
/openbmc/linux/tools/testing/selftests/bpf/progs/
H A Dtask_kfunc_failure.c37 v = insert_lookup_task(task); in BPF_PROG()
74 acquired = bpf_task_acquire(task); in BPF_PROG()
89 if (!task) { in BPF_PROG()
94 acquired = bpf_task_acquire(task); in BPF_PROG()
138 v = insert_lookup_task(task); in BPF_PROG()
170 v = insert_lookup_task(task); in BPF_PROG()
175 bpf_task_release(v->task); in BPF_PROG()
205 local.task = NULL; in BPF_PROG()
231 bpf_task_release(task); in BPF_PROG()
285 bpf_probe_read_kernel(task->comm, 16, task->comm); in BPF_PROG()
[all …]
H A Drcu_read_lock.c32 struct task_struct *task; in get_cgroup_id() local
35 task = bpf_get_current_task_btf(); in get_cgroup_id()
36 if (task->pid != target_pid) in get_cgroup_id()
41 cgroups = task->cgroups; in get_cgroup_id()
58 if (task->pid != target_pid) in task_succ()
63 real_parent = task->real_parent; in task_succ()
86 real_parent = task->real_parent; in no_lock()
101 real_parent = task->real_parent; in two_regions()
117 real_parent = task->real_parent; in non_sleepable_1()
176 struct task_struct *task; in miss_lock() local
[all …]
H A Dtask_kfunc_success.c56 acquired = bpf_task_acquire(task); in test_acquire_release()
115 return test_acquire_release(task); in BPF_PROG()
135 status = tasks_kfunc_map_insert(task); in BPF_PROG()
152 status = tasks_kfunc_map_insert(task); in BPF_PROG()
164 kptr = bpf_kptr_xchg(&v->task, NULL); in BPF_PROG()
185 status = tasks_kfunc_map_insert(task); in BPF_PROG()
198 kptr = v->task; in BPF_PROG()
252 lookup_compare_pid(task); in BPF_PROG()
285 bpf_strncmp(task->comm, 12, "foo"); in BPF_PROG()
286 bpf_strncmp(task->comm, 16, "foo"); in BPF_PROG()
[all …]
/openbmc/linux/kernel/livepatch/
H A Dtransition.c138 task = idle_task(cpu); in klp_complete_transition()
297 if (task_curr(task) && task != current) in klp_check_and_switch_task()
335 if (task == current) in klp_try_switch_task()
346 __func__, task->comm, task->pid); in klp_try_switch_task()
350 __func__, task->comm, task->pid); in klp_try_switch_task()
354 __func__, task->comm, task->pid, old_name); in klp_try_switch_task()
359 __func__, ret, task->comm, task->pid); in klp_try_switch_task()
437 set_notify_signal(task); in klp_send_signals()
480 task = idle_task(cpu); in klp_try_complete_transition()
558 task = idle_task(cpu); in klp_start_transition()
[all …]
/openbmc/linux/kernel/bpf/
H A Dtask_iter.c49 if (!task) in task_group_seq_get_next()
74 if (!task) in task_group_seq_get_next()
148 task->files == task->group_leader->files) { in task_seq_get_next()
209 ctx.task = task; in DEFINE_BPF_ITER_FUNC()
234 if ((!!linfo->task.tid + !!linfo->task.pid + !!linfo->task.pid_fd) > 1) in bpf_iter_attach_task()
240 aux->task.pid = linfo->task.tid; in bpf_iter_attach_task()
244 aux->task.pid = linfo->task.pid; in bpf_iter_attach_task()
386 ctx.task = info->task; in DEFINE_BPF_ITER_FUNC()
648 ctx.task = info->task; in DEFINE_BPF_ITER_FUNC()
700 info->iter.task.tid = aux->task.pid; in bpf_iter_fill_link_info()
[all …]
H A Dbpf_task_storage.c53 return &task->bpf_storage; in task_storage_ptr()
93 struct task_struct *task; in bpf_pid_task_storage_lookup_elem() local
108 if (!task) { in bpf_pid_task_storage_lookup_elem()
127 struct task_struct *task; in bpf_pid_task_storage_update_elem() local
142 if (!task) { in bpf_pid_task_storage_update_elem()
178 struct task_struct *task; in bpf_pid_task_storage_delete_elem() local
193 if (!task) { in bpf_pid_task_storage_delete_elem()
266 task) in BPF_CALL_2()
272 if (!task) in BPF_CALL_2()
287 task) in BPF_CALL_2()
[all …]
/openbmc/linux/drivers/scsi/libsas/
H A Dsas_scsi_host.c108 task = NULL; in sas_scsi_task_done()
136 if (!task) in sas_create_task()
143 task->task_proto = task->dev->tproto; /* BUG_ON(!SSP) */ in sas_create_task()
157 return task; in sas_create_task()
181 if (!task) in sas_queuecommand()
305 task); in sas_scsi_find_task()
445 if (task) in sas_eh_abort_handler()
546 if (!task) in sas_eh_handle_sas_errors()
596 task); in sas_eh_handle_sas_errors()
869 struct sas_task *task = slow->task; in sas_task_internal_timedout() local
[all …]
/openbmc/linux/drivers/gpu/drm/exynos/
H A Dexynos_drm_ipp.c262 task = kzalloc(sizeof(*task), GFP_KERNEL); in exynos_drm_ipp_task_alloc()
263 if (!task) in exynos_drm_ipp_task_alloc()
270 task->src.rect.w = task->dst.rect.w = UINT_MAX; in exynos_drm_ipp_task_alloc()
271 task->src.rect.h = task->dst.rect.h = UINT_MAX; in exynos_drm_ipp_task_alloc()
276 return task; in exynos_drm_ipp_task_alloc()
743 exynos_drm_ipp_task_free(task->ipp, task); in exynos_drm_ipp_task_cleanup()
771 if (ipp->task == task) in exynos_drm_ipp_task_done()
805 ipp->task = task; in exynos_drm_ipp_next_task()
839 } else if (ipp->task != task) { in exynos_drm_ipp_task_abort()
892 if (!task) in exynos_drm_ipp_commit_ioctl()
[all …]
/openbmc/linux/include/linux/
H A Dcn_proc.h23 void proc_fork_connector(struct task_struct *task);
24 void proc_exec_connector(struct task_struct *task);
25 void proc_id_connector(struct task_struct *task, int which_id);
26 void proc_sid_connector(struct task_struct *task);
28 void proc_comm_connector(struct task_struct *task);
29 void proc_coredump_connector(struct task_struct *task);
30 void proc_exit_connector(struct task_struct *task);
32 static inline void proc_fork_connector(struct task_struct *task) in proc_fork_connector() argument
35 static inline void proc_exec_connector(struct task_struct *task) in proc_exec_connector() argument
38 static inline void proc_id_connector(struct task_struct *task, in proc_id_connector() argument
[all …]
/openbmc/linux/arch/powerpc/kernel/
H A Dsignal.h39 struct task_struct *task);
41 struct task_struct *task);
52 struct task_struct *__t = task; \
62 struct task_struct *__t = task; \
72 struct task_struct *__t = task; \
82 struct task_struct *__t = task; \
93 struct task_struct *__t = task; \
103 struct task_struct *__t = task; \
113 struct task_struct *__t = task; \
123 struct task_struct *__t = task; \
[all …]
/openbmc/linux/drivers/scsi/aic94xx/
H A Daic94xx_task.c49 void *p = task->scatter; in asd_map_scatterlist()
51 task->total_xfer_len, in asd_map_scatterlist()
52 task->data_dir); in asd_map_scatterlist()
65 num_sg = task->num_scatter; in asd_map_scatterlist()
68 task->num_scatter, task->data_dir); in asd_map_scatterlist()
115 task->num_scatter, task->data_dir); in asd_map_scatterlist()
131 task->total_xfer_len, task->data_dir); in asd_unmap_scatterlist()
138 task->num_scatter, task->data_dir); in asd_unmap_scatterlist()
339 task->lldd_task = NULL; in asd_task_tasklet_complete()
342 task->task_done(task); in asd_task_tasklet_complete()
[all …]
/openbmc/openbmc/poky/scripts/
H A Dtest-reexec62 task=$2
64 task=`echo $task | sed 's/_setscene//'`
66 if [ -f $LOGS/force.$target.$task ]; then
70 case $task in
81 bitbake $target -c $task -f > $LOGS/force.$target.$task
83 echo "FAILURE for $target $task"
84 cp $LOGS/force.$target.$task $LOGS/failed.$target.$task
89 echo "FAILURE2 for $target $task"
90 cp $LOGS/force.$target.$task $LOGS/failed.$target.$task
105 for task in $tasks; do
[all …]
/openbmc/linux/arch/mips/include/asm/
H A Dsyscall.h34 test_tsk_thread_flag(task, TIF_32BIT_REGS)) && in mips_syscall_is_indirect()
38 static inline long syscall_get_nr(struct task_struct *task, in syscall_get_nr() argument
41 return task_thread_info(task)->syscall; in syscall_get_nr()
51 if (mips_syscall_is_indirect(task, regs)) in mips_syscall_update_nr()
52 task_thread_info(task)->syscall = regs->regs[4]; in mips_syscall_update_nr()
54 task_thread_info(task)->syscall = regs->regs[2]; in mips_syscall_update_nr()
77 if (test_tsk_thread_flag(task, TIF_32BIT_REGS)) in mips_get_syscall_arg()
132 if (mips_syscall_is_indirect(task, regs)) in syscall_get_arguments()
136 mips_get_syscall_arg(args++, task, regs, i++); in syscall_get_arguments()
147 if (!test_tsk_thread_flag(task, TIF_32BIT_REGS)) { in syscall_get_arch()
[all …]
/openbmc/linux/drivers/video/fbdev/
H A Duvesafb.c86 if (!task || msg->ack != task->ack) { in uvesafb_cn_callback()
105 if (task->t.buf_len && task->buf) in uvesafb_cn_callback()
106 memcpy(task->buf, utask + 1, task->t.buf_len); in uvesafb_cn_callback()
149 int len = sizeof(task->t) + task->t.buf_len; in uvesafb_exec()
173 memcpy(m + 1, &task->t, sizeof(task->t)); in uvesafb_exec()
176 memcpy((u8 *)(m + 1) + sizeof(task->t), task->buf, task->t.buf_len); in uvesafb_exec()
250 memset(task, 0, sizeof(*task)); in uvesafb_reset()
261 task = kzalloc(sizeof(*task), GFP_KERNEL); in uvesafb_prep()
399 if (!task) in uvesafb_vbe_state_restore()
574 (u16)task->t.regs.es, (u16)task->t.regs.edi); in uvesafb_vbe_getpmi()
[all …]
/openbmc/linux/kernel/
H A Dtask_work.c50 head = READ_ONCE(task->task_works); in task_work_add()
61 set_notify_resume(task); in task_work_add()
64 set_notify_signal(task); in task_work_add()
67 __set_notify_signal(task); in task_work_add()
95 if (likely(!task_work_pending(task))) in task_work_cancel_match()
103 raw_spin_lock_irqsave(&task->pi_lock, flags); in task_work_cancel_match()
149 struct task_struct *task = current; in task_work_run() local
157 work = READ_ONCE(task->task_works); in task_work_run()
161 if (task->flags & PF_EXITING) in task_work_run()
175 raw_spin_lock_irq(&task->pi_lock); in task_work_run()
[all …]
/openbmc/linux/drivers/scsi/
H A Dlibiscsi.c462 task->itt, task->state, task->sc); in iscsi_free_task()
531 task->itt, task->state, task->sc); in iscsi_complete_task()
603 if (conn->task == task) { in cleanup_queued_task()
1414 if (!task || !task->sc) in iscsi_itt_to_ctask()
1538 conn->task = task; in iscsi_xmit_task()
1554 conn->task = task; in iscsi_xmit_task()
1723 iscsi_cmd(sc)->task = task; in iscsi_alloc_task()
1992 task->sc, task->itt, task->state); in fail_scsi_tasks()
2090 task = iscsi_cmd(sc)->task; in iscsi_eh_cmd_timed_out()
2387 task = iscsi_cmd(sc)->task; in iscsi_eh_abort()
[all …]
/openbmc/linux/scripts/gdb/linux/
H A Dtasks.py43 for task in task_lists():
44 if int(task['pid']) == pid:
45 return task
59 task = get_task_by_pid(pid)
60 if task:
61 return task.dereference()
77 for task in task_lists():
92 def get_thread_info(task): argument
116 def invoke(self, task): argument
133 task = get_task_by_pid(pid)
[all …]
/openbmc/linux/drivers/scsi/isci/
H A Dtask.c90 task->task_status.stat = status; in isci_task_refuse()
95 task->lldd_task = NULL; in isci_task_refuse()
98 task->task_done(task); in isci_task_refuse()
103 task = list_entry(task->list.next, struct sas_task, list))
107 struct sas_task *task) in isci_device_io_ready() argument
140 task, task->dev, idev, idev ? idev->flags : 0, in isci_task_execute_task()
141 task->uldd_task); in isci_task_execute_task()
160 isci_task_refuse(ihost, task, in isci_task_execute_task()
518 task, old_request); in isci_task_abort_task()
539 __func__, task); in isci_task_abort_task()
[all …]
/openbmc/linux/fs/proc/
H A Dbase.c191 if (task) { in proc_cwd_link()
208 if (task) { in proc_root_link()
498 if (!task) in lstats_show_proc()
532 if (!task) in lstats_write()
738 if (!task) in proc_pid_permission()
774 if (!task) in proc_single_show()
1046 if (!task) in oom_adj_read()
1067 if (!task) in __set_oom_adj()
1205 if (!task) in oom_score_adj_read()
1258 if (!task) in proc_loginuid_read()
[all …]
/openbmc/linux/drivers/scsi/pm8001/
H A Dpm8001_sas.c399 struct sas_task *task = ccb->task; in pm8001_deliver_command() local
448 task->task_done(task); in pm8001_queue_command()
455 task->task_done(task); in pm8001_queue_command()
472 task->task_done(task); in pm8001_queue_command()
475 task->task_done(task); in pm8001_queue_command()
531 struct sas_task *task = ccb->task; in pm8001_ccb_task_free() local
768 task = ccb->task; in pm8001_open_reject_retry()
769 if (!task || !task->task_done) in pm8001_open_reject_retry()
794 task->task_done(task); in pm8001_open_reject_retry()
956 if (unlikely(!task || !task->lldd_task || !task->dev)) in pm8001_query_task()
[all …]

12345678910>>...67