Home
last modified time | relevance | path

Searched refs:queue (Results 1 – 25 of 615) sorted by relevance

12345678910>>...25

/freebsd/sys/contrib/vchiq/interface/vchiq_arm/
H A Dvchiq_util.c41 int vchiu_queue_init(VCHIU_QUEUE_T *queue, int size) in vchiu_queue_init() argument
45 queue->size = size; in vchiu_queue_init()
46 queue->read = 0; in vchiu_queue_init()
47 queue->write = 0; in vchiu_queue_init()
48 queue->initialized = 1; in vchiu_queue_init()
50 _sema_init(&queue->pop, 0); in vchiu_queue_init()
51 _sema_init(&queue->push, 0); in vchiu_queue_init()
53 queue->storage = kzalloc(size * sizeof(VCHIQ_HEADER_T *), GFP_KERNEL); in vchiu_queue_init()
54 if (queue->storage == NULL) { in vchiu_queue_init()
55 vchiu_queue_delete(queue); in vchiu_queue_init()
[all …]
/freebsd/sys/kern/
H A Dsubr_taskqueue.c107 _timeout_task_init(struct taskqueue *queue, struct timeout_task *timeout_task, in _timeout_task_init() argument
112 callout_init_mtx(&timeout_task->c, &queue->tq_mutex, in _timeout_task_init()
114 timeout_task->q = queue; in _timeout_task_init()
127 task_get_busy(struct taskqueue *queue, struct task *task) in task_get_busy() argument
131 TQ_ASSERT_LOCKED(queue); in task_get_busy()
132 LIST_FOREACH(tb, &queue->tq_active, tb_link) { in task_get_busy()
144 struct taskqueue *queue; in _taskqueue_create() local
151 queue = malloc(sizeof(struct taskqueue), M_TASKQUEUE, mflags | M_ZERO); in _taskqueue_create()
152 if (queue == NULL) { in _taskqueue_create()
159 STAILQ_INIT(&queue->tq_queue); in _taskqueue_create()
[all …]
H A Dsubr_gtaskqueue.c51 static int task_is_running(struct gtaskqueue *queue, struct gtask *gtask);
52 static void gtaskqueue_drain_locked(struct gtaskqueue *queue, struct gtask *gtask);
127 struct gtaskqueue *queue; in _gtaskqueue_create() local
136 queue = malloc(sizeof(struct gtaskqueue), M_GTASKQUEUE, mflags | M_ZERO); in _gtaskqueue_create()
137 if (!queue) { in _gtaskqueue_create()
142 STAILQ_INIT(&queue->tq_queue); in _gtaskqueue_create()
143 LIST_INIT(&queue->tq_active); in _gtaskqueue_create()
144 queue->tq_enqueue = enqueue; in _gtaskqueue_create()
145 queue->tq_context = context; in _gtaskqueue_create()
146 queue->tq_name = tq_name; in _gtaskqueue_create()
[all …]
/freebsd/share/man/man3/
H A DMakefile24 queue.3 \
199 MLINKS+= queue.3 LIST_CLASS_ENTRY.3 \
200 queue.3 LIST_CLASS_HEAD.3 \
201 queue.3 LIST_EMPTY.3 \
202 queue.3 LIST_ENTRY.3 \
203 queue.3 LIST_FIRST.3 \
204 queue.3 LIST_FOREACH.3 \
205 queue.3 LIST_FOREACH_FROM.3 \
206 queue.3 LIST_FOREACH_FROM_SAFE.3 \
207 queue.3 LIST_FOREACH_SAFE.3 \
[all …]
/freebsd/sys/cam/
H A Dcam_queue.c77 camq_fini(struct camq *queue) in camq_fini() argument
79 if (queue->queue_array != NULL) { in camq_fini()
80 free(queue->queue_array, M_CAMQ); in camq_fini()
85 camq_resize(struct camq *queue, int new_size) in camq_resize() argument
89 KASSERT(new_size >= queue->entries, ("camq_resize: " in camq_resize()
91 new_size, queue->entries)); in camq_resize()
103 if (queue->queue_array != NULL) { in camq_resize()
104 bcopy(queue->queue_array, new_array, in camq_resize()
105 (queue->entries + 1) * sizeof(cam_pinfo *)); in camq_resize()
106 free(queue->queue_array, M_CAMQ); in camq_resize()
[all …]
H A Dcam_queue.h61 struct camq queue; member
104 uint32_t camq_resize(struct camq *queue, int new_size);
114 void camq_fini(struct camq *queue);
120 void camq_insert(struct camq *queue, cam_pinfo *new_entry);
126 cam_pinfo *camq_remove(struct camq *queue, int index);
140 void camq_change_priority(struct camq *queue, int index,
146 return (ccbq->queue.entries + ccbq->queue_extra_entries); in cam_ccbq_pending_ccb_count()
160 struct camq *queue = &ccbq->queue; in cam_ccbq_insert_ccb() local
171 if (queue->entries == queue->array_size && in cam_ccbq_insert_ccb()
172 camq_resize(&ccbq->queue, queue->array_size * 2) != CAM_REQ_CMP) { in cam_ccbq_insert_ccb()
[all …]
/freebsd/contrib/dma/
H A Ddma.c99 set_from(struct queue *queue, const char *osender) in set_from() argument
133 queue->sender = sender; in set_from()
157 do_alias(struct queue *queue, const char *addr) in do_alias() argument
167 if (add_recp(queue, sit->str, EXPAND_ADDR) != 0) in do_alias()
177 add_recp(struct queue *queue, const char *str, int expand) in add_recp() argument
191 it->sender = queue->sender; in add_recp()
198 LIST_FOREACH(tit, &queue->queue, next) { in add_recp()
206 LIST_INSERT_HEAD(&queue->queue, it, next); in add_recp()
215 aliased = do_alias(queue, it->addr); in add_recp()
217 aliased = do_alias(queue, "*"); in add_recp()
[all …]
H A Dspool.c75 newspoolf(struct queue *queue) in newspoolf() argument
93 queue->tmpf = strdup(fn); in newspoolf()
94 if (queue->tmpf == NULL) in newspoolf()
102 if (asprintf(&queue->id, "%"PRIxMAX, (uintmax_t)st.st_ino) < 0) in newspoolf()
105 queue->mailf = fdopen(fd, "r+"); in newspoolf()
106 if (queue->mailf == NULL) in newspoolf()
111 t->str = queue->tmpf; in newspoolf()
117 if (queue->mailf != NULL) in newspoolf()
118 fclose(queue->mailf); in newspoolf()
157 readqueuef(struct queue *queue, char *queuefn) in readqueuef() argument
[all …]
H A Dmail.c52 struct queue bounceq; in bounce()
64 LIST_INIT(&bounceq.queue); in bounce()
168 parse_addrs(struct parse_state *ps, char *s, struct queue *queue) in parse_addrs() argument
343 if (add_recp(queue, addr, EXPAND_WILDCARD) != 0) in parse_addrs()
350 writeline(struct queue *queue, const char *line, ssize_t linelen) in writeline() argument
360 if (fwrite(line, len, 1, queue->mailf) != 1) in writeline()
366 if (fwrite("\n", 1, 1, queue->mailf) != 1) in writeline()
376 readmail(struct queue *queue, int nodot, int recp_from_header) in readmail() argument
395 error = fprintf(queue->mailf, in readmail()
402 queue->sender, in readmail()
[all …]
/freebsd/share/examples/pf/
H A Dfaq-example39 # enable queueing on the external interface to queue packets going out
11 # each queue can be controlled. the max outgoing bandwidth is 1.5Mbps.
13 altq on fxp0 cbq bandwidth 1.5Mb queue { std_ext, www_ext, boss_ext }
16 # std_ext - the standard queue. also the default queue for
18 # www_ext - container queue for WWW server queues. limit to
24 queue std_ext bandwidth 500Kb cbq(default borrow)
25 queue www_ext bandwidth 500Kb { www_ext_http, www_ext_misc }
26 queue www_ext_http bandwidth 50% priority 3 cbq(red borrow)
27 queue www_ext_misc bandwidth 50% priority 1 cbq(borrow)
28 queue boss_ext bandwidth 500Kb priority 3 cbq(borrow)
[all …]
H A Dqueue22 # advanced queue example.
9 altq on $ext_if cbq bandwidth 5Mb queue { std, http, mail, ssh }
11 queue std bandwidth 10% cbq(default)
12 queue http bandwidth 60% priority 2 cbq(borrow red) { employees, developers }
13 queue developers bandwidth 75% cbq(borrow)
14 queue employees bandwidth 15%
15 queue mail bandwidth 10% priority 0 cbq(borrow ecn)
16 queue ssh bandwidth 20% cbq(borrow) { ssh_interactive, ssh_bulk }
17 queue ssh_interactive bandwidth 25% priority 7
18 queue ssh_bulk bandwidth 75% priority 0
[all …]
H A Dfaq-example212 # ACK queue.
14 altq on fxp0 priq bandwidth 610Kb queue { std_out, ssh_im_out, dns_out, \
18 # std_out - the standard queue. any filter rule below that does not
19 # explicitly specify a queue will have its traffic added
20 # to this queue.
25 queue std_out priq(default)
26 queue ssh_im_out priority 4 priq(red)
27 queue dns_out priority 5
28 queue tcp_ack_out priority 6
34 altq on dc0 cbq bandwidth 2Mb queue { std_in, ssh_im_in, dns_in, bob_in }
[all …]
H A Dqueue16 queue { deflt, http, ssh, mail, rsets }
7 queue deflt bandwidth 10% priority 0 cbq(default ecn)
8 queue http bandwidth 1.5Mb priority 3 { http_vhosts, http_cust1 }
9 queue http_vhosts bandwidth 40% cbq(borrow red)
10 queue http_cust1 bandwidth 0.5Mb
11 queue mail bandwidth 10% priority 1
12 queue ssh bandwidth 100Kb priority 7 cbq(borrow)
13 queue rsets bandwidth 7500b priority 0 cbq(red)
15 block return in on $ext_if inet all queue rsets
16 pass in on $ext_if inet proto tcp from any to any port 80 queue http
[all …]
H A Dqueue410 # whenever there is no backlogged sibling queue but when a queue gets
11 # backlogged, it is guaranteed that the queue gets its linkshare.
13 altq on dc0 bandwidth 16Mb hfsc queue { eng law art }
14 queue eng bandwidth 10Mb { cs ee ie }
15 queue cs hfsc( default linkshare 50% )
16 queue ee hfsc( linkshare 30% )
17 queue ie hfsc( linkshare 20% )
18 queue law bandwidth 3Mb
19 queue art bandwidth 3Mb
/freebsd/sys/contrib/ck/src/
H A Dck_barrier_combining.c39 ck_barrier_combining_queue_dequeue(struct ck_barrier_combining_queue *queue) in ck_barrier_combining_queue_dequeue() argument
43 if (queue->head != NULL) { in ck_barrier_combining_queue_dequeue()
44 front = queue->head; in ck_barrier_combining_queue_dequeue()
45 queue->head = queue->head->next; in ck_barrier_combining_queue_dequeue()
76 ck_barrier_combining_queue_enqueue(struct ck_barrier_combining_queue *queue, in ck_barrier_combining_queue_enqueue() argument
81 if (queue->head == NULL) { in ck_barrier_combining_queue_enqueue()
82 queue->head = queue->tail = node_value; in ck_barrier_combining_queue_enqueue()
86 queue->tail->next = node_value; in ck_barrier_combining_queue_enqueue()
87 queue->tail = node_value; in ck_barrier_combining_queue_enqueue()
99 struct ck_barrier_combining_queue queue; in ck_barrier_combining_group_init() local
[all …]
/freebsd/sys/dev/vmware/vmci/
H A Dvmci_kernel_if.c498 * Allocates kernel queue pages of specified size with IOMMU mappings, plus
499 * space for the queue structure/kernel interface and the queue header.
502 * Pointer to the queue on success, NULL otherwise.
513 struct vmci_queue *queue; in vmci_alloc_queue() local
518 sizeof(*queue) + sizeof(*(queue->kernel_if)) + dmas_size; in vmci_alloc_queue()
526 queue = malloc(queue_size, M_DEVBUF, M_NOWAIT); in vmci_alloc_queue()
527 if (!queue) in vmci_alloc_queue()
530 queue in vmci_alloc_queue()
571 struct vmci_queue *queue = q; vmci_free_queue() local
817 __vmci_memcpy_to_queue(struct vmci_queue * queue,uint64_t queue_offset,const void * src,size_t size,bool is_iovec) __vmci_memcpy_to_queue() argument
874 __vmci_memcpy_from_queue(void * dest,const struct vmci_queue * queue,uint64_t queue_offset,size_t size,bool is_iovec) __vmci_memcpy_from_queue() argument
931 vmci_memcpy_to_queue(struct vmci_queue * queue,uint64_t queue_offset,const void * src,size_t src_offset,size_t size,int buf_type,bool can_block) vmci_memcpy_to_queue() argument
960 vmci_memcpy_from_queue(void * dest,size_t dest_offset,const struct vmci_queue * queue,uint64_t queue_offset,size_t size,int buf_type,bool can_block) vmci_memcpy_from_queue() argument
988 vmci_memcpy_to_queue_local(struct vmci_queue * queue,uint64_t queue_offset,const void * src,size_t src_offset,size_t size,int buf_type,bool can_block) vmci_memcpy_to_queue_local() argument
1017 vmci_memcpy_from_queue_local(void * dest,size_t dest_offset,const struct vmci_queue * queue,uint64_t queue_offset,size_t size,int buf_type,bool can_block) vmci_memcpy_from_queue_local() argument
1043 vmci_memcpy_to_queue_v(struct vmci_queue * queue,uint64_t queue_offset,const void * src,size_t src_offset,size_t size,int buf_type,bool can_block) vmci_memcpy_to_queue_v() argument
1076 vmci_memcpy_from_queue_v(void * dest,size_t dest_offset,const struct vmci_queue * queue,uint64_t queue_offset,size_t size,int buf_type,bool can_block) vmci_memcpy_from_queue_v() argument
[all...]
H A Dvmci_queue.h51 typedef int vmci_memcpy_to_queue_func(struct vmci_queue *queue,
55 const struct vmci_queue *queue, uint64_t queue_offset, size_t size,
75 int vmci_memcpy_to_queue(struct vmci_queue *queue, uint64_t queue_offset,
79 const struct vmci_queue *queue, uint64_t queue_offset, size_t size,
81 int vmci_memcpy_to_queue_local(struct vmci_queue *queue,
85 const struct vmci_queue *queue, uint64_t queue_offset, size_t size,
88 int vmci_memcpy_to_queue_v(struct vmci_queue *queue, uint64_t queue_offset,
92 const struct vmci_queue *queue, uint64_t queue_offset, size_t size,
96 vmci_memcpy_to_queue_v_local(struct vmci_queue *queue, uint64_t queue_offset, in vmci_memcpy_to_queue_v_local() argument
101 return (vmci_memcpy_to_queue_v(queue, queue_offset, src, src_offset, in vmci_memcpy_to_queue_v_local()
[all …]
/freebsd/sys/sys/
H A Dtaskqueue.h36 #include <sys/queue.h>
64 * queue to arrange to run itself later (e.g., by scheduling a software
78 int taskqueue_enqueue(struct taskqueue *queue, struct task *task);
79 int taskqueue_enqueue_flags(struct taskqueue *queue, struct task *task,
81 int taskqueue_enqueue_timeout(struct taskqueue *queue,
83 int taskqueue_enqueue_timeout_sbt(struct taskqueue *queue,
86 int taskqueue_poll_is_busy(struct taskqueue *queue, struct task *task);
87 int taskqueue_cancel(struct taskqueue *queue, struct task *task,
89 int taskqueue_cancel_timeout(struct taskqueue *queue,
91 void taskqueue_drain(struct taskqueue *queue, struc
140 TIMEOUT_TASK_INIT(queue,timeout_task,priority,func,context) global() argument
[all...]
/freebsd/sys/dev/mana/
H A Dgdma_main.c341 struct gdma_queue *queue) in mana_gd_create_hw_eq() argument
347 if (queue->type != GDMA_EQ) in mana_gd_create_hw_eq()
353 req.hdr.dev_id = queue->gdma_dev->dev_id; in mana_gd_create_hw_eq()
354 req.type = queue->type; in mana_gd_create_hw_eq()
355 req.pdid = queue->gdma_dev->pdid; in mana_gd_create_hw_eq()
356 req.doolbell_id = queue->gdma_dev->doorbell; in mana_gd_create_hw_eq()
357 req.gdma_region = queue->mem_info.dma_region_handle; in mana_gd_create_hw_eq()
358 req.queue_size = queue->queue_size; in mana_gd_create_hw_eq()
359 req.log2_throttle_limit = queue->eq.log2_throttle_limit; in mana_gd_create_hw_eq()
360 req.eq_pci_msix_index = queue->eq.msix_index; in mana_gd_create_hw_eq()
[all …]
/freebsd/contrib/ntp/include/
H A Dntp_prio_q.h35 } queue; typedef
44 void destroy_queue(queue *my_queue);
47 int empty(queue *my_queue);
48 void *queue_head(queue *my_queue);
49 queue *enqueue(queue *my_queue, void *my_node);
50 void append_queue(queue *q1, queue *q2);
51 void *dequeue(queue *my_queue);
52 int get_no_of_elements(queue *my_queue);
67 queue *debug_create_priority_queue(
/freebsd/sys/contrib/dev/iwlwifi/mvm/
H A Dsta.c306 static int iwl_mvm_invalidate_sta_queue(struct iwl_mvm *mvm, int queue, in iwl_mvm_invalidate_sta_queue() argument
319 sta_id = mvm->queue_info[queue].ra_sta_id; in iwl_mvm_invalidate_sta_queue()
347 /* Notify FW of queue removal from the STA queues */ in iwl_mvm_invalidate_sta_queue()
357 int queue = *queueptr; in iwl_mvm_disable_txq() local
359 .scd_queue = queue, in iwl_mvm_disable_txq()
387 iwl_trans_txq_free(mvm->trans, queue); in iwl_mvm_disable_txq()
393 if (WARN_ON(mvm->queue_info[queue].tid_bitmap == 0)) in iwl_mvm_disable_txq()
396 mvm->queue_info[queue].tid_bitmap &= ~BIT(tid); in iwl_mvm_disable_txq()
398 cmd.action = mvm->queue_info[queue].tid_bitmap ? in iwl_mvm_disable_txq()
401 mvm->queue_info[queue] in iwl_mvm_disable_txq()
447 iwl_mvm_get_queue_agg_tids(struct iwl_mvm * mvm,int queue) iwl_mvm_get_queue_agg_tids() argument
487 iwl_mvm_remove_sta_queue_marking(struct iwl_mvm * mvm,int queue) iwl_mvm_remove_sta_queue_marking() argument
550 iwl_mvm_free_inactive_queue(struct iwl_mvm * mvm,int queue,struct ieee80211_sta * old_sta,u8 new_sta_id) iwl_mvm_free_inactive_queue() argument
600 int queue = 0; iwl_mvm_get_shared_queue() local
666 iwl_mvm_reconfig_scd(struct iwl_mvm * mvm,int queue,int fifo,int sta_id,int tid,int frame_limit,u16 ssn) iwl_mvm_reconfig_scd() argument
704 iwl_mvm_redirect_queue(struct iwl_mvm * mvm,int queue,int tid,int ac,int ssn,unsigned int wdg_timeout,bool force,struct iwl_mvm_txq * txq) iwl_mvm_redirect_queue() argument
852 int queue, size; iwl_mvm_tvqm_enable_txq() local
921 int queue = -1; iwl_mvm_sta_alloc_queue_tvqm() local
948 iwl_mvm_update_txq_mapping(struct iwl_mvm * mvm,struct ieee80211_sta * sta,int queue,u8 sta_id,u8 tid) iwl_mvm_update_txq_mapping() argument
991 iwl_mvm_enable_txq(struct iwl_mvm * mvm,struct ieee80211_sta * sta,int queue,u16 ssn,const struct iwl_trans_txq_scd_cfg * cfg,unsigned int wdg_timeout) iwl_mvm_enable_txq() argument
1025 iwl_mvm_change_queue_tid(struct iwl_mvm * mvm,int queue) iwl_mvm_change_queue_tid() argument
1062 iwl_mvm_unshare_queue(struct iwl_mvm * mvm,int queue) iwl_mvm_unshare_queue() argument
1149 iwl_mvm_remove_inactive_tids(struct iwl_mvm * mvm,struct iwl_mvm_sta * mvmsta,int queue,unsigned long tid_bitmap,unsigned long * unshare_queues,unsigned long * changetid_queues) iwl_mvm_remove_inactive_tids() argument
1351 int queue = -1; iwl_mvm_sta_alloc_queue() local
1565 int queue; iwl_mvm_reserve_sta_stream() local
2174 iwl_mvm_enable_aux_snif_queue(struct iwl_mvm * mvm,u16 queue,u8 sta_id,u8 fifo) iwl_mvm_enable_aux_snif_queue() argument
2206 iwl_mvm_add_int_sta_with_queue(struct iwl_mvm * mvm,int macidx,int maccolor,u8 * addr,struct iwl_mvm_int_sta * sta,u16 * queue,int fifo) iwl_mvm_add_int_sta_with_queue() argument
2339 int queue; iwl_mvm_send_add_bcast_sta() local
2415 u16 *queueptr, queue; iwl_mvm_free_bcast_sta_queues() local
2592 int queue = iwl_mvm_tvqm_enable_txq(mvm, NULL, msta->sta_id, iwl_mvm_add_mcast_sta() local
3026 iwl_mvm_sta_tx_agg(struct iwl_mvm * mvm,struct ieee80211_sta * sta,int tid,u8 queue,bool start) iwl_mvm_sta_tx_agg() argument
3208 int queue, ret; iwl_mvm_sta_tx_agg_oper() local
4318 u16 queue; iwl_mvm_add_pasn_sta() local
[all...]
/freebsd/sys/contrib/ck/include/spinlock/
H A Dmcs.h48 ck_spinlock_mcs_init(struct ck_spinlock_mcs **queue) in ck_spinlock_mcs_init() argument
51 *queue = NULL; in ck_spinlock_mcs_init()
57 ck_spinlock_mcs_trylock(struct ck_spinlock_mcs **queue, in ck_spinlock_mcs_trylock() argument
66 r = ck_pr_cas_ptr(queue, NULL, node); in ck_spinlock_mcs_trylock()
72 ck_spinlock_mcs_locked(struct ck_spinlock_mcs **queue) in ck_spinlock_mcs_locked() argument
76 r = ck_pr_load_ptr(queue) != NULL; in ck_spinlock_mcs_locked()
82 ck_spinlock_mcs_lock(struct ck_spinlock_mcs **queue, in ck_spinlock_mcs_lock() argument
100 previous = ck_pr_fas_ptr(queue, node); in ck_spinlock_mcs_lock()
116 ck_spinlock_mcs_unlock(struct ck_spinlock_mcs **queue, in ck_spinlock_mcs_unlock() argument
130 if (ck_pr_load_ptr(queue) == node && in ck_spinlock_mcs_unlock()
[all …]
/freebsd/contrib/ntp/ntpd/
H A Dntp_prio_q.c24 queue *debug_create_priority_queue( in debug_create_priority_queue()
32 queue *my_queue; in debug_create_priority_queue()
35 my_queue = emalloc(sizeof(queue)); in debug_create_priority_queue()
38 my_queue = debug_erealloc(NULL, sizeof(queue), sourcefile, line_num); in debug_create_priority_queue()
53 queue *my_queue in destroy_queue()
126 queue *my_queue in empty()
135 queue *q in queue_head()
149 queue *enqueue( in enqueue()
150 queue * my_queue, in enqueue()
181 queue *my_queue in dequeue()
[all …]
/freebsd/usr.bin/posixmqcontrol/
H A Dposixmqcontrol.c135 sane_queue(const char *queue) in sane_queue() argument
139 if (queue[size] != '/') { in sane_queue()
140 warnx("queue name [%-.*s] must start with '/'.", NAME_MAX, queue); in sane_queue()
144 for (size++; queue[size] != 0 && size < NAME_MAX; size++) { in sane_queue()
145 if (queue[size] == '/') { in sane_queue()
147 NAME_MAX, queue); in sane_queue()
152 if (size == NAME_MAX && queue[size] != 0) { in sane_queue()
154 NAME_MAX, queue, NAME_MAX); in sane_queue()
242 parse_queue(const char *queue) in parse_queue() argument
244 if (sane_queue(queue)) { in parse_queue()
[all …]
/freebsd/contrib/llvm-project/libcxx/include/
H A Dqueue14 queue synopsis
20 class queue
33 queue() = default;
34 ~queue() = default;
36 queue(const queue& q) = default;
37 queue(queue&& q) = default;
39 queue& operator=(const queue& q) = default;
40 queue& operator=(queue&& q) = default;
42 explicit queue(const container_type& c);
43 explicit queue(container_type&& c)
[all …]

12345678910>>...25