Home
last modified time | relevance | path

Searched +full:wait +full:- +full:queue (Results 1 – 25 of 1119) sorted by relevance

12345678910>>...45

/linux/drivers/md/dm-vdo/indexer/
H A Dfunnel-requestqueue.c1 // SPDX-License-Identifier: GPL-2.0-only
6 #include "funnel-requestqueue.h"
10 #include <linux/wait.h>
12 #include "funnel-queue.h"
14 #include "memory-alloc.h"
15 #include "thread-utils.h"
18 * This queue will attempt to handle requests in reasonably sized batches instead of reacting
19 * immediately to each new request. The wait time between batches is dynamically adjusted up or
22 * If the wait time becomes long enough, the queue will become dormant and must be explicitly
24 * queue via xchg (which is a memory barrier), and later checks "dormant" to decide whether to do a
[all …]
/linux/include/linux/
H A Dsbitmap.h1 /* SPDX-License-Identifier: GPL-2.0-only */
6 * Copyright (C) 2013-2014 Jens Axboe
22 #include <linux/wait.h>
27 * struct sbitmap_word - Word in a &struct sbitmap.
41 * @swap_lock: serializes simultaneous updates of ->word and ->cleared
47 * struct sbitmap - Scalable bitmap.
49 * A &struct sbitmap is spread over multiple cachelines to avoid ping-pong. This
69 * @round_robin: Allocate bits in strict round-robin order.
81 * This is per-cpu, which allows multiple users to stick to different
91 * struct sbq_wait_state - Wait queue in a &struct sbitmap_queue.
[all …]
H A Dwait.h1 /* SPDX-License-Identifier: GPL-2.0 */
5 * Linux wait queue related types and methods
26 * A single wait-queue entry structure:
82 wq_entry->flags = 0; in init_waitqueue_entry()
83 wq_entry->private = p; in init_waitqueue_entry()
84 wq_entry->func = default_wake_function; in init_waitqueue_entry()
90 wq_entry->flags = 0; in init_waitqueue_func_entry()
91 wq_entry->private = NULL; in init_waitqueue_func_entry()
92 wq_entry->func = func; in init_waitqueue_func_entry()
96 * waitqueue_active -- locklessly test for waiters on the queue
[all …]
H A Duacce.h1 /* SPDX-License-Identifier: GPL-2.0-or-later */
17 * struct uacce_qfile_region - structure of queue file region
25 * struct uacce_ops - uacce device operations
27 * @get_queue: get a queue from the device
28 * @put_queue: free a queue to the device
29 * @start_queue: make the queue start work after get_queue
30 * @stop_queue: make the queue stop work before put_queue
32 * @mmap: mmap addresses of queue to user space
33 * @ioctl: ioctl for user space users of the queue
56 * struct uacce_interface - interface required for uacce_register()
[all …]
/linux/drivers/net/wwan/iosm/
H A Diosm_ipc_task_queue.h1 /* SPDX-License-Identifier: GPL-2.0-only
3 * Copyright (C) 2020-21 Intel Corporation.
9 /* Number of available element for the input message queue of the IPC
15 * struct ipc_task_queue_args - Struct for Task queue elements
18 * @completion: OS object used to wait for the tasklet function to finish for
40 * struct ipc_task_queue - Struct for Task queue
41 * @q_lock: Protect the message queue of the ipc ipc_task
42 * @args: Message queue of the IPC ipc_task
43 * @q_rpos: First queue element to process.
44 * @q_wpos: First free element of the input queue.
[all …]
H A Diosm_ipc_task_queue.c1 // SPDX-License-Identifier: GPL-2.0-only
3 * Copyright (C) 2020-21 Intel Corporation.
10 * Calls event handler involves callback for each element in the message queue
15 unsigned int q_rpos = ipc_task->q_rpos; in ipc_task_queue_handler()
17 /* Loop over the input queue contents. */ in ipc_task_queue_handler()
18 while (q_rpos != ipc_task->q_wpos) { in ipc_task_queue_handler()
19 /* Get the current first queue element. */ in ipc_task_queue_handler()
20 struct ipc_task_queue_args *args = &ipc_task->args[q_rpos]; in ipc_task_queue_handler()
23 if (args->func) in ipc_task_queue_handler()
24 args->response = args->func(args->ipc_imem, args->arg, in ipc_task_queue_handler()
[all …]
/linux/net/sunrpc/
H A Dsched.c1 // SPDX-License-Identifier: GPL-2.0-only
54 * rpciod-related stuff
62 if (current->flags & PF_WQ_WORKER) in rpc_task_gfp_mask()
70 if (cmpxchg(&task->tk_rpc_status, 0, rpc_status) == 0) in rpc_task_set_rpc_status()
78 unsigned long timeout = READ_ONCE(task->tk_timeout); in rpc_task_timeout()
83 return timeout - now; in rpc_task_timeout()
91 * queue->lock and bh_disabled in order to avoid races within
95 __rpc_disable_timer(struct rpc_wait_queue *queue, struct rpc_task *task) in __rpc_disable_timer() argument
97 if (list_empty(&task->u.tk_wait.timer_list)) in __rpc_disable_timer()
99 task->tk_timeout = 0; in __rpc_disable_timer()
[all …]
/linux/tools/testing/selftests/net/netfilter/
H A Dnft_queue.sh23 rm -f "$TMPINPUT"
24 rm -f "$TMPFILE0"
25 rm -f "$TMPFILE1"
26 rm -f "$TMPFILE2" "$TMPFILE3"
29 checktool "nft --version" "test without nft tool"
30 checktool "socat -h" "run test without socat"
32 modprobe -q sctp
55 ip -net "$nsrouter" link set veth0 up
56 ip -ne
[all...]
/linux/fs/autofs/
H A Dwaitq.c1 // SPDX-License-Identifier: GPL-2.0-or-later
3 * Copyright 1997-1998 Transmeta Corporation -- All Rights Reserved
4 * Copyright 2001-2006 Ian Kent <raven@themaw.net>
19 mutex_lock(&sbi->wq_mutex); in autofs_catatonic_mode()
20 if (sbi->flags & AUTOFS_SBI_CATATONIC) { in autofs_catatonic_mode()
21 mutex_unlock(&sbi->wq_mutex); in autofs_catatonic_mode()
27 sbi->flags |= AUTOFS_SBI_CATATONIC; in autofs_catatonic_mode()
28 wq = sbi->queues; in autofs_catatonic_mode()
29 sbi->queues = NULL; /* Erase all wait queues */ in autofs_catatonic_mode()
31 nwq = wq->next; in autofs_catatonic_mode()
[all …]
/linux/drivers/md/dm-vdo/
H A Dfunnel-workqueue.c1 // SPDX-License-Identifier: GPL-2.0-only
6 #include "funnel-workqueue.h"
15 #include "funnel-queue.h"
17 #include "memory-alloc.h"
20 #include "string-utils.h"
23 #include "status-codes.h"
28 * DOC: Work queue definition.
30 * There are two types of work queues: simple, with one worker thread, and round-robin, which uses
31 * a group of the former to do the work, and assigns work to them in round-robin fashion (roughly).
32 * Externally, both are represented via the same common sub-structure, though there's actually not
[all …]
/linux/drivers/gpu/drm/nouveau/nvkm/engine/gr/fuc/
H A Dcom.fuc27 // queue_put - add request to queue
29 // In : $r13 queue pointer
44 // store cmd/data on queue
59 // queue_get - fetch request from queue
61 // In : $r13 queue pointer
89 // nv_rd32 - read 32-bit value from nv register
107 // nv_wr32 - write 32-bit value to nv register
124 // wait_donez - wait on FUC_DONE bit to become clear
126 // In : $r10 bit to wait on
138 // wait_doneo - wait on FUC_DONE bit to become set
[all …]
/linux/kernel/sched/
H A Dwait.c1 // SPDX-License-Identifier: GPL-2.0-only
11 spin_lock_init(&wq_head->lock); in __init_waitqueue_head()
12 lockdep_set_class_and_name(&wq_head->lock, key, name); in __init_waitqueue_head()
13 INIT_LIST_HEAD(&wq_head->head); in __init_waitqueue_head()
22 wq_entry->flags &= ~WQ_FLAG_EXCLUSIVE; in add_wait_queue()
23 spin_lock_irqsave(&wq_head->lock, flags); in add_wait_queue()
25 spin_unlock_irqrestore(&wq_head->lock, flags); in add_wait_queue()
33 wq_entry->flags |= WQ_FLAG_EXCLUSIVE; in add_wait_queue_exclusive()
34 spin_lock_irqsave(&wq_head->lock, flags); in add_wait_queue_exclusive()
36 spin_unlock_irqrestore(&wq_head->lock, flags); in add_wait_queue_exclusive()
[all …]
/linux/drivers/scsi/aacraid/
H A Dcommsup.c1 // SPDX-License-Identifier: GPL-2.0-or-later
9 * Copyright (c) 2000-2010 Adaptec, Inc.
10 * 2010-2015 PMC-Sierra, Inc. (aacraid@pmc-sierra.com)
11 * 2016-2017 Microsemi Corp. (aacraid@microsemi.com)
42 * fib_map_alloc - allocate the fib objects
51 dev->max_cmd_size = AAC_MAX_NATIVE_SIZE; in fib_map_alloc()
55 &dev->pdev->dev, dev->max_cmd_size, dev->scsi_host_ptr->can_queue, in fib_map_alloc()
56 AAC_NUM_MGT_FIB, &dev->hw_fib_pa)); in fib_map_alloc()
57 dev->hw_fib_va = dma_alloc_coherent(&dev->pdev->dev, in fib_map_alloc()
58 (dev->max_cmd_size + sizeof(struct aac_fib_xporthdr)) in fib_map_alloc()
[all …]
/linux/net/core/
H A Dstream.c1 // SPDX-License-Identifier: GPL-2.0
6 * protocols. Even IP. Tonight 8-).
13 * Alan Cox <alan@lxorguk.ukuu.org.uk> (Borrowed comments 8-))
21 #include <linux/wait.h>
25 * sk_stream_write_space - stream socket write_space callback.
36 struct socket *sock = sk->sk_socket; in sk_stream_write_space()
40 clear_bit(SOCK_NOSPACE, &sock->flags); in sk_stream_write_space()
43 wq = rcu_dereference(sk->sk_wq); in sk_stream_write_space()
45 wake_up_interruptible_poll(&wq->wait, EPOLLOUT | in sk_stream_write_space()
47 if (wq && wq->fasync_list && !(sk->sk_shutdown & SEND_SHUTDOWN)) in sk_stream_write_space()
[all …]
/linux/drivers/accel/habanalabs/common/
H A Dhw_queue.c1 // SPDX-License-Identifier: GPL-2.0
4 * Copyright 2016-2019 HabanaLabs, Ltd.
13 * hl_queue_add_ptr - add to pi or ci and checks if it wraps around
18 * Add val to ptr. It can go until twice the queue length.
23 ptr &= ((HL_QUEUE_LENGTH << 1) - 1); in hl_hw_queue_add_ptr()
28 return atomic_read(ci) & ((queue_len << 1) - 1); in queue_ci_get()
33 int delta = (q->pi - queue_ci_get(&q->ci, queue_len)); in queue_free_slots()
36 return (queue_len - delta); in queue_free_slots()
38 return (abs(delta) - queue_len); in queue_free_slots()
43 struct hl_device *hdev = cs->ctx->hdev; in hl_hw_queue_update_ci()
[all …]
/linux/arch/mips/include/asm/octeon/
H A Dcvmx-pow.h7 * Copyright (c) 2003-2008 Cavium Networks
14 * AS-IS and WITHOUT ANY WARRANTY; without even the implied warranty
21 * Foundation, Inc., 51 Franklin St, Fifth Floor, Boston, MA 02110-1301 USA
31 * New, starting with SDK 1.7.0, cvmx-pow supports a number of
36 * enabled. For example, cvmx-pow will check for the following
38 * - Requesting a POW operation with an active tag switch in
40 * - Waiting for a tag switch to complete for an excessively
43 * - Illegal tag switches from NULL_NULL.
44 * - Illegal tag switches from NULL.
45 * - Illegal deschedule request.
[all …]
/linux/kernel/locking/
H A Dqspinlock_paravirt.h1 /* SPDX-License-Identifier: GPL-2.0 */
16 * pv_wait(u8 *ptr, u8 val) -- suspends the vcpu if *ptr == val
17 * pv_kick(cpu) -- wakes a suspended vcpu
27 * Queue Node Adaptive Spinning
29 * A queue node vCPU will stop spinning if the vCPU in the previous node is
31 * mitigates the slight slowdown for non-overcommitted guest with this
32 * aggressive wait-early mechanism.
41 * Queue node uses: VCPU_RUNNING & VCPU_HALTED.
42 * Queue head uses: VCPU_RUNNING & VCPU_HASHED.
63 * The pending bit is set by the queue head vCPU of the MCS wait queue in
[all …]
H A Dqspinlock.c1 // SPDX-License-Identifier: GPL-2.0-or-later
5 * (C) Copyright 2013-2015 Hewlett-Packard Development Company, L.P.
6 * (C) Copyright 2013-2014,2018 Red Hat, Inc.
8 * (C) Copyright 2015 Hewlett-Packard Enterprise Development LP
34 * The basic principle of a queue
[all...]
/linux/drivers/net/ethernet/sfc/falcon/
H A Dselftest.c1 // SPDX-License-Identifier: GPL-2.0-only
4 * Copyright 2005-2006 Fen Systems Ltd.
5 * Copyright 2006-2012 Solarflare Communications Inc.
26 * - All IRQs may be disabled on a CPU for a *long* time by e.g. a
28 * - The PREEMPT_RT patches mostly deal with this, but also allow a
38 * The self-test should stress every RSS vector, and unfortunately
42 char pad[2]; /* Ensures ip is 4-byte aligned */
65 [EF4_INT_MODE_MSIX] = "MSI-X",
70 STRING_TABLE_LOOKUP(efx->interrupt_mode, ef4_interrupt_mode)
73 * struct ef4_loopback_state - persistent state during a loopback selftest
[all …]
/linux/drivers/s390/crypto/
H A Dap_bus.h1 /* SPDX-License-Identifier: GPL-2.0+ */
79 * AP queue state machine states
93 * AP queue state machine events
102 * AP queue state wait behaviour
106 AP_SM_WAIT_HIGH_TIMEOUT, /* poll high freq, wait for timeout */
107 AP_SM_WAIT_LOW_TIMEOUT, /* poll low freq, wait for timeout */
108 AP_SM_WAIT_INTERRUPT, /* wait for thin interrupt (if available) */
109 AP_SM_WAIT_NONE, /* no wait */
114 * AP queue device states
118 AP_DEV_STATE_OPERATING, /* queue dev is working normal */
[all …]
/linux/net/qrtr/
H A Dtun.c1 // SPDX-License-Identifier: GPL-2.0
15 struct sk_buff_head queue; member
23 skb_queue_tail(&tun->queue, skb); in qrtr_tun_send()
26 wake_up_interruptible(&tun->readq); in qrtr_tun_send()
38 return -ENOMEM; in qrtr_tun_open()
40 skb_queue_head_init(&tun->queue); in qrtr_tun_open()
41 init_waitqueue_head(&tun->readq); in qrtr_tun_open()
43 tun->ep.xmit = qrtr_tun_send; in qrtr_tun_open()
45 filp->private_data = tun; in qrtr_tun_open()
47 ret = qrtr_endpoint_register(&tun->ep, QRTR_EP_NID_AUTO); in qrtr_tun_open()
[all …]
/linux/drivers/gpu/drm/v3d/
H A Dv3d_gem.c1 // SPDX-License-Identifier: GPL-2.0+
2 /* Copyright (C) 2014-2018 Broadcom */
5 #include <linux/dma-mapping.h>
28 if (v3d->ver < V3D_GEN_41) in v3d_init_core()
48 V3D_CORE_WRITE(core, V3D_GMP_CFG(v3d->ver), V3D_GMP_CFG_STOP_REQ); in v3d_idle_axi()
50 if (wait_for((V3D_CORE_READ(core, V3D_GMP_STATUS(v3d->ver)) & in v3d_idle_axi()
54 DRM_ERROR("Failed to wait for safe GMP shutdown\n"); in v3d_idle_axi()
61 if (v3d->ver >= V3D_GEN_41) in v3d_idle_gca()
69 DRM_ERROR("Failed to wait for safe GCA shutdown\n"); in v3d_idle_gca()
83 /* GFXH-1383: The SW_INIT may cause a stray write to address 0 in v3d_reset_by_bridge()
[all …]
/linux/tools/testing/selftests/bpf/progs/
H A Dbpf_arena_spin_lock.h1 // SPDX-License-Identifier: GPL-2.0
27 * PowerPC overrides the definition to define lock->val as u32 instead of
59 /* FIXME: Using typedef causes CO-RE relocation error */
78 * 0- 7: locked byte
80 * 9-15: not used
81 * 16-17: tail index
82 * 18-31: tail cpu (+1)
86 #define _Q_SET_MASK(type) (((1U << _Q_ ## type ## _BITS) - 1)\
101 #define _Q_TAIL_CPU_BITS (32 - _Q_TAIL_CPU_OFFSET)
124 u32 cpu = (tail >> _Q_TAIL_CPU_OFFSET) - 1; in decode_tail()
[all …]
/linux/kernel/bpf/
H A Drqspinlock.c1 // SPDX-License-Identifier: GPL-2.0-or-later
5 * (C) Copyright 2013-2015 Hewlett-Packard Development Company, L.P.
6 * (C) Copyright 2013-2014,2018 Red Hat, Inc.
8 * (C) Copyright 2015 Hewlett-Packard Enterprise Development LP
9 * (C) Copyright 2024-2025 Meta Platforms, Inc. and affiliates.
44 * The basic principle of a queue-based spinlock can best be understood
45 * by studying a classic queue-based spinlock implementation called the
47 * Synchronization on Shared-Memory Multiprocessors by Mellor-Crummey and
58 * unlock the next pending (next->locked), we compress both these: {tail,
59 * next->locked} into a single u32 value.
[all …]
/linux/drivers/misc/genwqe/
H A Dcard_base.h1 /* SPDX-License-Identifier: GPL-2.0-only */
11 * Author: Joerg-Stephan Vogt <jsvogt@de.ibm.com>
42 #define GENWQE_DDCB_MAX 32 /* DDCBs on the work-queue */
62 #define PCI_SUBSYSTEM_ID_GENWQE5 0x035f /* Genwqe A5 Subsystem-ID */
63 #define PCI_SUBSYSTEM_ID_GENWQE5_NEW 0x044b /* Genwqe A5 Subsystem-ID */
67 #define PCI_SUBSYSTEM_ID_GENWQE5_SRIOV 0x0000 /* Genwqe A5 Subsystem-ID */
73 * struct genwqe_reg - Genwqe data dump functionality
82 * enum genwqe_dbg_type - Specify chip unit to dump/debug
99 #define GENWQE_INJECT_HARDWARE_FAILURE 0x00000001 /* injects -1 reg reads */
107 * Error-handling in case of card malfunction
[all …]

12345678910>>...45