Home
last modified time | relevance | path

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

12345678910>>...43

/Linux-v5.4/net/sunrpc/
Dsched.c49 static void rpc_release_task(struct rpc_task *task);
65 rpc_task_timeout(const struct rpc_task *task) in rpc_task_timeout() argument
67 unsigned long timeout = READ_ONCE(task->tk_timeout); in rpc_task_timeout()
84 __rpc_disable_timer(struct rpc_wait_queue *queue, struct rpc_task *task) in __rpc_disable_timer() argument
86 if (list_empty(&task->u.tk_wait.timer_list)) in __rpc_disable_timer()
88 dprintk("RPC: %5u disabling timer\n", task->tk_pid); in __rpc_disable_timer()
89 task->tk_timeout = 0; in __rpc_disable_timer()
90 list_del(&task->u.tk_wait.timer_list); in __rpc_disable_timer()
111 __rpc_add_timer(struct rpc_wait_queue *queue, struct rpc_task *task, in __rpc_add_timer() argument
115 task->tk_pid, jiffies_to_msecs(timeout - jiffies)); in __rpc_add_timer()
[all …]
Dclnt.c61 static void call_start(struct rpc_task *task);
62 static void call_reserve(struct rpc_task *task);
63 static void call_reserveresult(struct rpc_task *task);
64 static void call_allocate(struct rpc_task *task);
65 static void call_encode(struct rpc_task *task);
66 static void call_decode(struct rpc_task *task);
67 static void call_bind(struct rpc_task *task);
68 static void call_bind_status(struct rpc_task *task);
69 static void call_transmit(struct rpc_task *task);
70 static void call_status(struct rpc_task *task);
[all …]
Dxprt.c202 int xprt_reserve_xprt(struct rpc_xprt *xprt, struct rpc_task *task) in xprt_reserve_xprt() argument
204 struct rpc_rqst *req = task->tk_rqstp; in xprt_reserve_xprt()
207 if (task == xprt->snd_task) in xprt_reserve_xprt()
213 xprt->snd_task = task; in xprt_reserve_xprt()
221 task->tk_pid, xprt); in xprt_reserve_xprt()
222 task->tk_status = -EAGAIN; in xprt_reserve_xprt()
223 if (RPC_IS_SOFT(task)) in xprt_reserve_xprt()
224 rpc_sleep_on_timeout(&xprt->sending, task, NULL, in xprt_reserve_xprt()
227 rpc_sleep_on(&xprt->sending, task, NULL); in xprt_reserve_xprt()
266 int xprt_reserve_xprt_cong(struct rpc_xprt *xprt, struct rpc_task *task) in xprt_reserve_xprt_cong() argument
[all …]
/Linux-v5.4/drivers/infiniband/sw/rxe/
Drxe_task.c40 int __rxe_do_task(struct rxe_task *task) in __rxe_do_task() argument
45 while ((ret = task->func(task->arg)) == 0) in __rxe_do_task()
48 task->ret = ret; in __rxe_do_task()
63 struct rxe_task *task = (struct rxe_task *)data; in rxe_do_task() local
65 spin_lock_irqsave(&task->state_lock, flags); in rxe_do_task()
66 switch (task->state) { in rxe_do_task()
68 task->state = TASK_STATE_BUSY; in rxe_do_task()
69 spin_unlock_irqrestore(&task->state_lock, flags); in rxe_do_task()
73 task->state = TASK_STATE_ARMED; in rxe_do_task()
76 spin_unlock_irqrestore(&task->state_lock, flags); in rxe_do_task()
[all …]
/Linux-v5.4/kernel/livepatch/
Dtransition.c73 struct task_struct *g, *task; in klp_complete_transition() local
110 for_each_process_thread(g, task) { in klp_complete_transition()
111 WARN_ON_ONCE(test_tsk_thread_flag(task, TIF_PATCH_PENDING)); in klp_complete_transition()
112 task->patch_state = KLP_UNDEFINED; in klp_complete_transition()
117 task = idle_task(cpu); in klp_complete_transition()
118 WARN_ON_ONCE(test_tsk_thread_flag(task, TIF_PATCH_PENDING)); in klp_complete_transition()
119 task->patch_state = KLP_UNDEFINED; in klp_complete_transition()
163 void klp_update_patch_state(struct task_struct *task) in klp_update_patch_state() argument
183 if (test_and_clear_tsk_thread_flag(task, TIF_PATCH_PENDING)) in klp_update_patch_state()
184 task->patch_state = READ_ONCE(klp_target_state); in klp_update_patch_state()
[all …]
/Linux-v5.4/arch/arm64/kernel/
Dssbd.c15 static void ssbd_ssbs_enable(struct task_struct *task) in ssbd_ssbs_enable() argument
17 u64 val = is_compat_thread(task_thread_info(task)) ? in ssbd_ssbs_enable()
20 task_pt_regs(task)->pstate |= val; in ssbd_ssbs_enable()
23 static void ssbd_ssbs_disable(struct task_struct *task) in ssbd_ssbs_disable() argument
25 u64 val = is_compat_thread(task_thread_info(task)) ? in ssbd_ssbs_disable()
28 task_pt_regs(task)->pstate &= ~val; in ssbd_ssbs_disable()
34 static int ssbd_prctl_set(struct task_struct *task, unsigned long ctrl) in ssbd_prctl_set() argument
62 task_spec_ssb_force_disable(task)) in ssbd_prctl_set()
64 task_clear_spec_ssb_disable(task); in ssbd_prctl_set()
65 clear_tsk_thread_flag(task, TIF_SSBD); in ssbd_prctl_set()
[all …]
/Linux-v5.4/drivers/gpu/drm/exynos/
Dexynos_drm_ipp.c85 WARN_ON(ipp->task); in exynos_drm_ipp_unregister()
259 struct exynos_drm_ipp_task *task; in exynos_drm_ipp_task_alloc() local
261 task = kzalloc(sizeof(*task), GFP_KERNEL); in exynos_drm_ipp_task_alloc()
262 if (!task) in exynos_drm_ipp_task_alloc()
265 task->dev = ipp->dev; in exynos_drm_ipp_task_alloc()
266 task->ipp = ipp; in exynos_drm_ipp_task_alloc()
269 task->src.rect.w = task->dst.rect.w = UINT_MAX; in exynos_drm_ipp_task_alloc()
270 task->src.rect.h = task->dst.rect.h = UINT_MAX; in exynos_drm_ipp_task_alloc()
271 task->transform.rotation = DRM_MODE_ROTATE_0; in exynos_drm_ipp_task_alloc()
273 DRM_DEV_DEBUG_DRIVER(task->dev, "Allocated task %pK\n", task); in exynos_drm_ipp_task_alloc()
[all …]
/Linux-v5.4/drivers/gpu/drm/lima/
Dlima_sched.c108 int lima_sched_task_init(struct lima_sched_task *task, in lima_sched_task_init() argument
115 task->bos = kmemdup(bos, sizeof(*bos) * num_bos, GFP_KERNEL); in lima_sched_task_init()
116 if (!task->bos) in lima_sched_task_init()
122 err = drm_sched_job_init(&task->base, &context->base, vm); in lima_sched_task_init()
124 kfree(task->bos); in lima_sched_task_init()
128 task->num_bos = num_bos; in lima_sched_task_init()
129 task->vm = lima_vm_get(vm); in lima_sched_task_init()
131 xa_init_flags(&task->deps, XA_FLAGS_ALLOC); in lima_sched_task_init()
136 void lima_sched_task_fini(struct lima_sched_task *task) in lima_sched_task_fini() argument
142 drm_sched_job_cleanup(&task->base); in lima_sched_task_fini()
[all …]
/Linux-v5.4/drivers/scsi/aic94xx/
Daic94xx_task.c36 static int asd_map_scatterlist(struct sas_task *task, in asd_map_scatterlist() argument
40 struct asd_ascb *ascb = task->lldd_task; in asd_map_scatterlist()
45 if (task->data_dir == DMA_NONE) in asd_map_scatterlist()
48 if (task->num_scatter == 0) { in asd_map_scatterlist()
49 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()
54 sg_arr[0].size = cpu_to_le32(task->total_xfer_len); in asd_map_scatterlist()
61 if (sas_protocol_ata(task->task_proto)) in asd_map_scatterlist()
62 num_sg = task->num_scatter; in asd_map_scatterlist()
[all …]
/Linux-v5.4/include/linux/
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);
27 void proc_ptrace_connector(struct task_struct *task, int which_id);
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
[all …]
/Linux-v5.4/drivers/scsi/pm8001/
Dpm8001_sas.c49 static int pm8001_find_tag(struct sas_task *task, u32 *tag) in pm8001_find_tag() argument
51 if (task->lldd_task) { in pm8001_find_tag()
53 ccb = task->lldd_task; in pm8001_find_tag()
300 u32 pm8001_get_ncq_tag(struct sas_task *task, u32 *tag) in pm8001_get_ncq_tag() argument
302 struct ata_queued_cmd *qc = task->uldd_task; in pm8001_get_ncq_tag()
378 static int pm8001_task_exec(struct sas_task *task, in pm8001_task_exec() argument
381 struct domain_device *dev = task->dev; in pm8001_task_exec()
385 struct sas_task *t = task; in pm8001_task_exec()
398 pm8001_ha = pm8001_find_ha_by_dev(task->dev); in pm8001_task_exec()
453 ccb->task = t; in pm8001_task_exec()
[all …]
/Linux-v5.4/drivers/video/fbdev/
Duvesafb.c75 struct uvesafb_ktask *task; in uvesafb_cn_callback() local
84 task = uvfb_tasks[msg->seq]; in uvesafb_cn_callback()
86 if (!task || msg->ack != task->ack) { in uvesafb_cn_callback()
94 if (task->t.buf_len < utask->buf_len || in uvesafb_cn_callback()
103 memcpy(&task->t, utask, sizeof(*utask)); 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()
108 complete(task->done); in uvesafb_cn_callback()
144 static int uvesafb_exec(struct uvesafb_ktask *task) in uvesafb_exec() argument
149 int len = sizeof(task->t) + task->t.buf_len; in uvesafb_exec()
[all …]
/Linux-v5.4/drivers/scsi/isci/
Dtask.c76 static void isci_task_refuse(struct isci_host *ihost, struct sas_task *task, in isci_task_refuse() argument
85 __func__, task, response, status); in isci_task_refuse()
87 spin_lock_irqsave(&task->task_state_lock, flags); in isci_task_refuse()
89 task->task_status.resp = response; in isci_task_refuse()
90 task->task_status.stat = status; in isci_task_refuse()
93 task->task_state_flags |= SAS_TASK_STATE_DONE; in isci_task_refuse()
94 task->task_state_flags &= ~(SAS_TASK_AT_INITIATOR | in isci_task_refuse()
96 task->lldd_task = NULL; in isci_task_refuse()
97 spin_unlock_irqrestore(&task->task_state_lock, flags); in isci_task_refuse()
99 task->task_done(task); in isci_task_refuse()
[all …]
/Linux-v5.4/fs/proc/
Dbase.c170 static int get_task_root(struct task_struct *task, struct path *root) in get_task_root() argument
174 task_lock(task); in get_task_root()
175 if (task->fs) { in get_task_root()
176 get_fs_root(task->fs, root); in get_task_root()
179 task_unlock(task); in get_task_root()
185 struct task_struct *task = get_proc_task(d_inode(dentry)); in proc_cwd_link() local
188 if (task) { in proc_cwd_link()
189 task_lock(task); in proc_cwd_link()
190 if (task->fs) { in proc_cwd_link()
191 get_fs_pwd(task->fs, path); in proc_cwd_link()
[all …]
Dnamespaces.c43 struct task_struct *task; in proc_ns_get_link() local
50 task = get_proc_task(inode); in proc_ns_get_link()
51 if (!task) in proc_ns_get_link()
54 if (ptrace_may_access(task, PTRACE_MODE_READ_FSCREDS)) { in proc_ns_get_link()
55 error = ns_get_path(&ns_path, task, ns_ops); in proc_ns_get_link()
59 put_task_struct(task); in proc_ns_get_link()
67 struct task_struct *task; in proc_ns_readlink() local
71 task = get_proc_task(inode); in proc_ns_readlink()
72 if (!task) in proc_ns_readlink()
75 if (ptrace_may_access(task, PTRACE_MODE_READ_FSCREDS)) { in proc_ns_readlink()
[all …]
Darray.c381 static void task_cpus_allowed(struct seq_file *m, struct task_struct *task) in task_cpus_allowed() argument
384 cpumask_pr_args(task->cpus_ptr)); in task_cpus_allowed()
386 cpumask_pr_args(task->cpus_ptr)); in task_cpus_allowed()
405 struct pid *pid, struct task_struct *task) in proc_pid_status() argument
407 struct mm_struct *mm = get_task_mm(task); in proc_pid_status()
410 proc_task_name(m, task, true); in proc_pid_status()
413 task_state(m, ns, pid, task); in proc_pid_status()
421 task_sig(m, task); in proc_pid_status()
422 task_cap(m, task); in proc_pid_status()
423 task_seccomp(m, task); in proc_pid_status()
[all …]
Dfd.c25 struct task_struct *task; in seq_show() local
27 task = get_proc_task(m->private); in seq_show()
28 if (!task) in seq_show()
31 files = get_files_struct(task); in seq_show()
32 put_task_struct(task); in seq_show()
84 static bool tid_fd_mode(struct task_struct *task, unsigned fd, fmode_t *mode) in tid_fd_mode() argument
86 struct files_struct *files = get_files_struct(task); in tid_fd_mode()
101 static void tid_fd_update_inode(struct task_struct *task, struct inode *inode, in tid_fd_update_inode() argument
104 task_dump_owner(task, 0, &inode->i_uid, &inode->i_gid); in tid_fd_update_inode()
114 security_task_to_inode(task, inode); in tid_fd_update_inode()
[all …]
/Linux-v5.4/scripts/gdb/linux/
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()
76 for task in task_lists():
78 address=task,
79 pid=task["pid"],
80 comm=task["comm"].string()))
[all …]
/Linux-v5.4/arch/mips/include/asm/
Dsyscall.h29 static inline bool mips_syscall_is_indirect(struct task_struct *task, in mips_syscall_is_indirect() argument
34 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
44 static inline void mips_syscall_update_nr(struct task_struct *task, in mips_syscall_update_nr() argument
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()
58 struct task_struct *task, struct pt_regs *regs, unsigned int n) in mips_get_syscall_arg() argument
77 if (test_tsk_thread_flag(task, TIF_32BIT_REGS)) in mips_get_syscall_arg()
93 static inline long syscall_get_error(struct task_struct *task, in syscall_get_error() argument
[all …]
/Linux-v5.4/drivers/scsi/
Dlibiscsi.c134 void iscsi_prep_data_out_pdu(struct iscsi_task *task, struct iscsi_r2t_info *r2t, in iscsi_prep_data_out_pdu() argument
137 struct iscsi_conn *conn = task->conn; in iscsi_prep_data_out_pdu()
140 task->hdr_len = sizeof(struct iscsi_data); in iscsi_prep_data_out_pdu()
147 hdr->lun = task->lun; in iscsi_prep_data_out_pdu()
148 hdr->itt = task->hdr_itt; in iscsi_prep_data_out_pdu()
164 static int iscsi_add_hdr(struct iscsi_task *task, unsigned len) in iscsi_add_hdr() argument
166 unsigned exp_len = task->hdr_len + len; in iscsi_add_hdr()
168 if (exp_len > task->hdr_max) { in iscsi_add_hdr()
174 task->hdr_len = exp_len; in iscsi_add_hdr()
181 static int iscsi_prep_ecdb_ahs(struct iscsi_task *task) in iscsi_prep_ecdb_ahs() argument
[all …]
/Linux-v5.4/kernel/
Dtask_work.c28 task_work_add(struct task_struct *task, struct callback_head *work, bool notify) in task_work_add() argument
33 head = READ_ONCE(task->task_works); in task_work_add()
37 } while (cmpxchg(&task->task_works, head, work) != head); in task_work_add()
40 set_notify_resume(task); in task_work_add()
56 task_work_cancel(struct task_struct *task, task_work_func_t func) in task_work_cancel() argument
58 struct callback_head **pprev = &task->task_works; in task_work_cancel()
62 if (likely(!task->task_works)) in task_work_cancel()
70 raw_spin_lock_irqsave(&task->pi_lock, flags); in task_work_cancel()
77 raw_spin_unlock_irqrestore(&task->pi_lock, flags); in task_work_cancel()
92 struct task_struct *task = current; in task_work_run() local
[all …]
/Linux-v5.4/kernel/locking/
Drtmutex-debug.c60 void rt_mutex_debug_task_free(struct task_struct *task) in rt_mutex_debug_task_free() argument
62 DEBUG_LOCKS_WARN_ON(!RB_EMPTY_ROOT(&task->pi_waiters.rb_root)); in rt_mutex_debug_task_free()
63 DEBUG_LOCKS_WARN_ON(task->pi_blocked_on); in rt_mutex_debug_task_free()
75 struct task_struct *task; in debug_rt_mutex_deadlock() local
80 task = rt_mutex_owner(act_waiter->lock); in debug_rt_mutex_deadlock()
81 if (task && task != current) { in debug_rt_mutex_deadlock()
82 act_waiter->deadlock_task_pid = get_pid(task_pid(task)); in debug_rt_mutex_deadlock()
89 struct task_struct *task; in debug_rt_mutex_print_deadlock() local
95 task = pid_task(waiter->deadlock_task_pid, PIDTYPE_PID); in debug_rt_mutex_print_deadlock()
96 if (!task) { in debug_rt_mutex_print_deadlock()
[all …]
Drtmutex.c306 rt_mutex_enqueue_pi(struct task_struct *task, struct rt_mutex_waiter *waiter) in rt_mutex_enqueue_pi() argument
308 struct rb_node **link = &task->pi_waiters.rb_root.rb_node; in rt_mutex_enqueue_pi()
325 rb_insert_color_cached(&waiter->pi_tree_entry, &task->pi_waiters, leftmost); in rt_mutex_enqueue_pi()
329 rt_mutex_dequeue_pi(struct task_struct *task, struct rt_mutex_waiter *waiter) in rt_mutex_dequeue_pi() argument
334 rb_erase_cached(&waiter->pi_tree_entry, &task->pi_waiters); in rt_mutex_dequeue_pi()
345 pi_task = task_top_pi_waiter(p)->task; in rt_mutex_adjust_prio()
449 static int rt_mutex_adjust_prio_chain(struct task_struct *task, in rt_mutex_adjust_prio_chain() argument
488 put_task_struct(task); in rt_mutex_adjust_prio_chain()
503 raw_spin_lock_irq(&task->pi_lock); in rt_mutex_adjust_prio_chain()
508 waiter = task->pi_blocked_on; in rt_mutex_adjust_prio_chain()
[all …]
/Linux-v5.4/drivers/scsi/mvsas/
Dmv_sas.c12 static int mvs_find_tag(struct mvs_info *mvi, struct sas_task *task, u32 *tag) in mvs_find_tag() argument
14 if (task->lldd_task) { in mvs_find_tag()
16 slot = task->lldd_task; in mvs_find_tag()
304 struct sas_task *task = tei->task; in mvs_task_prep_smp() local
306 struct domain_device *dev = task->dev; in mvs_task_prep_smp()
322 sg_req = &task->smp_task.smp_req; in mvs_task_prep_smp()
328 sg_resp = &task->smp_task.smp_resp; in mvs_task_prep_smp()
397 MVS_CHIP_DISP->make_prd(task->scatter, tei->n_elem, buf_prd); in mvs_task_prep_smp()
402 dma_unmap_sg(mvi->dev, &tei->task->smp_task.smp_resp, 1, in mvs_task_prep_smp()
405 dma_unmap_sg(mvi->dev, &tei->task->smp_task.smp_req, 1, in mvs_task_prep_smp()
[all …]
/Linux-v5.4/drivers/scsi/libsas/
Dsas_scsi_host.c37 static void sas_end_task(struct scsi_cmnd *sc, struct sas_task *task) in sas_end_task() argument
39 struct task_status_struct *ts = &task->task_status; in sas_end_task()
80 task->dev->port->ha->sas_ha_name); in sas_end_task()
98 sas_free_task(task); in sas_end_task()
101 static void sas_scsi_task_done(struct sas_task *task) in sas_scsi_task_done() argument
103 struct scsi_cmnd *sc = task->uldd_task; in sas_scsi_task_done()
104 struct domain_device *dev = task->dev; in sas_scsi_task_done()
110 task = NULL; in sas_scsi_task_done()
115 if (unlikely(!task)) { in sas_scsi_task_done()
123 sas_free_task(task); in sas_scsi_task_done()
[all …]

12345678910>>...43