28 #define app_check_thread_and_barrier(_fn, _arg) \ 29 if (!vlib_thread_is_main_w_barrier ()) \ 31 vlib_rpc_call_main_thread (_fn, (u8 *) _arg, sizeof(*_arg)); \ 51 a->sep.is_ip4 = mp->
is_ip4;
53 a->sep.port = mp->
port;
54 a->sep.fib_index = mp->
vrf;
56 a->sep.transport_proto = mp->
proto;
61 a->sep_ext.transport_flags = mp->
flags;
87 a->uri = (
char *) mp->
uri;
111 a->sep.is_ip4 = mp->
is_ip4;
113 a->sep.port = mp->
port;
114 a->sep.transport_proto = mp->
proto;
115 a->sep.peer.fib_index = mp->
vrf;
127 a->sep_ext.transport_flags = mp->
flags;
163 a->uri = (
char *) mp->
uri;
261 (
u8 *) mp,
sizeof (*mp));
291 if (old_state >= SESSION_STATE_TRANSPORT_CLOSING)
319 if (!s || s->
session_state < SESSION_STATE_TRANSPORT_CLOSING)
352 session_event_t *evt;
367 clib_warning (
"could not disconnect session: %llu app: %u",
422 u32 owner_app_wrk_map;
423 session_event_t *evt;
500 session_event_t *evt;
536 s =
format (s,
"session index %d thread index %d",
541 #define foreach_session_queue_error \ 542 _(TX, "Packets transmitted") \ 543 _(TIMER, "Timer events") \ 544 _(NO_BUFFER, "Out of buffers") 548 #define _(sym,str) SESSION_QUEUE_ERROR_##sym, 555 #define _(sym,string) string, 569 u32 next_index,
u32 * to_next,
u16 n_segs,
572 while (n_trace && n_segs)
577 (vm, node, next_index, b, 1 )))
596 u32 chain_bi0, to_deq, left_from_seg;
598 u16 len_to_deq, n_bytes_read;
602 b->
flags |= VLIB_BUFFER_TOTAL_LENGTH_VALID;
608 to_deq = left_from_seg;
637 ASSERT (n_bytes_read > 0);
656 ASSERT (n_bytes_read == len_to_deq);
662 prev_b->
flags |= VLIB_BUFFER_NEXT_PRESENT;
667 to_deq -= n_bytes_read;
688 b->
flags = VNET_BUFFER_F_LOCALLY_ORIGINATED;
698 ASSERT (n_bytes_read > 0);
717 ASSERT (n_bytes_read > 0);
741 ASSERT (n_bytes_read > 0);
770 && (s->
flags & SESSION_F_CUSTOM_TX))
800 u32 max_segs,
u8 peek_data)
802 u32 n_bytes_per_buf, n_bytes_per_seg;
841 u32 first_dgram_len, dgram_len,
offset, max_offset;
846 first_dgram_len =
len;
849 while (offset < max_offset)
853 ASSERT (hdr.data_length > hdr.data_offset);
854 dgram_len = hdr.data_length - hdr.data_offset;
856 || first_dgram_len != dgram_len)
859 offset +=
sizeof (hdr) + hdr.data_length;
894 u32 n_bytes_last_seg, n_bufs_last_seg;
900 n_bufs_last_seg = ceil ((
f64) n_bytes_last_seg / n_bytes_per_buf);
934 int *n_tx_packets,
u8 peek_data)
936 u32 n_trace, n_left, pbi, next_index, max_burst;
939 session_event_t *e = &elt->
evt;
966 if (ctx->
s->
flags & SESSION_F_CUSTOM_TX)
969 ctx->
s->
flags &= ~SESSION_F_CUSTOM_TX;
972 *n_tx_packets += n_custom_tx;
976 max_burst -= n_custom_tx;
977 if (!max_burst || (ctx->
s->
flags & SESSION_F_CUSTOM_TX))
1014 snd_space - snd_space % ctx->
sp.
snd_mss : snd_space;
1036 SESSION_QUEUE_ERROR_NO_BUFFER, 1);
1169 s->
flags &= ~SESSION_F_CUSTOM_TX;
1175 *n_tx_packets += n_packets;
1177 if (s->
flags & SESSION_F_CUSTOM_TX)
1206 void (*fp) (
void *);
1213 switch (e->event_type)
1216 fp = e->rpc_args.fp;
1217 (*fp) (e->rpc_args.arg);
1272 clib_warning (
"unhandled event type %d", e->event_type);
1284 SESSION_EVT (SESSION_EVT_COUNTS, CNT_CTRL_EVTS, 1, wrk);
1300 switch (e->event_type)
1335 clib_warning (
"unhandled event type %d", e->event_type);
1338 SESSION_EVT (SESSION_IO_EVT_COUNTS, e->event_type, 1, wrk);
1348 #define _(symc, sym) \ 1349 [SESSION_CTRL_EVT_ ## symc] = sizeof (session_ ## sym ##_msg_t), 1366 elt->
evt.event_type = evt->event_type;
1404 int i = 0, n_tx_packets;
1405 session_event_t *evt;
1418 SESSION_EVT (SESSION_EVT_DSP_CNTRS, UPDATE_TIME, wrk);
1430 for (i = 0; i < n_to_dequeue; i++)
1440 SESSION_EVT (SESSION_EVT_DSP_CNTRS, MQ_DEQ, wrk, n_to_dequeue, !i);
1450 clib_llist_remove (wrk->event_elts, evt_list, elt);
1451 session_event_dispatch_ctrl (wrk, elt);
1455 SESSION_EVT (SESSION_EVT_DSP_CNTRS, CTRL_EVTS, wrk);
1474 SESSION_EVT (SESSION_EVT_DSP_CNTRS, NEW_IO_EVTS, wrk);
1500 SESSION_EVT (SESSION_EVT_DSP_CNTRS, OLD_IO_EVTS, wrk);
1506 SESSION_QUEUE_ERROR_TX, n_tx_packets);
1508 SESSION_EVT (SESSION_EVT_DISPATCH_END, wrk, n_tx_packets);
1510 return n_tx_packets;
1518 .name =
"session-queue",
1523 .state = VLIB_NODE_STATE_DISABLED,
1559 uword *event_data = 0;
1576 VLIB_NODE_STATE_DISABLED);
1594 .name =
"session-queue-process",
1595 .state = VLIB_NODE_STATE_DISABLED,
1615 .name =
"session-queue-main",
1616 .state = VLIB_NODE_STATE_DISABLED,
#define vec_validate(V, I)
Make sure vector is long enough for given index (no header, unspecified alignment) ...
static void session_tx_trace_frame(vlib_main_t *vm, vlib_node_runtime_t *node, u32 next_index, u32 *to_next, u16 n_segs, session_t *s, u32 n_trace)
u32 flags
buffer flags: VLIB_BUFFER_FREE_LIST_INDEX_MASK: bits used to store free list index, VLIB_BUFFER_IS_TRACED: trace this buffer.
int app_worker_lock_and_send_event(app_worker_t *app, session_t *s, u8 evt_type)
Send event to application.
u32 connection_index
Index of the transport connection associated to the session.
#define ENDPOINT_INVALID_INDEX
void session_transport_reset(session_t *s)
Force transport close.
void * svm_msg_q_msg_data(svm_msg_q_t *mq, svm_msg_q_msg_t *msg)
Get data for message in queue.
static void app_mq_detach_handler(void *data)
session_type_t session_type
Type built from transport and network protocol types.
static void session_mq_unlisten_handler(void *data)
void ip_copy(ip46_address_t *dst, ip46_address_t *src, u8 is_ip4)
int mq_send_session_connected_cb(u32 app_wrk_index, u32 api_context, session_t *s, session_error_t err)
static u32 vlib_get_trace_count(vlib_main_t *vm, vlib_node_runtime_t *rt)
svm_msg_q_t * vpp_event_queue
vpp event message queue for worker
static f64 vlib_process_wait_for_event_or_clock(vlib_main_t *vm, f64 dt)
Suspend a cooperative multi-tasking thread Waits for an event, or for the indicated number of seconds...
vlib_node_registration_t session_queue_pre_input_node
(constructor) VLIB_REGISTER_NODE (session_queue_pre_input_node)
static void vlib_buffer_free(vlib_main_t *vm, u32 *buffers, u32 n_buffers)
Free buffers Frees the entire buffer chain for each buffer.
session_main_t session_main
struct _vnet_connect_args vnet_connect_args_t
static void ip46_address_mask_ip4(ip46_address_t *ip46)
struct _vnet_unlisten_args_t vnet_unlisten_args_t
#define clib_llist_next_index(E, name)
u32 session_index
Index in thread pool where session was allocated.
i16 current_data
signed offset in data[], pre_data[] that we are currently processing.
#define clib_memcpy_fast(a, b, c)
static int svm_fifo_is_empty_prod(svm_fifo_t *f)
Check if fifo is empty optimized for producer.
static void session_event_dispatch_ctrl(session_worker_t *wrk, session_evt_elt_t *elt)
clib_memset(h->entries, 0, sizeof(h->entries[0]) *entries)
#define VLIB_NODE_FLAG_TRACE_SUPPORTED
static f64 vlib_time_now(vlib_main_t *vm)
static void session_mq_listen_uri_handler(void *data)
svm_fifo_t * rx_fifo
Pointers to rx/tx buffers.
session_worker_t * wrk
Worker contexts.
static session_t * session_get_if_valid(u64 si, u32 thread_index)
u16 current_length
Nbytes between current data and the end of this buffer.
#define vec_add1(V, E)
Add 1 element to end of vector (unspecified alignment).
static transport_proto_t session_get_transport_proto(session_t *s)
application_t * application_lookup(u32 api_client_index)
int svm_fifo_peek(svm_fifo_t *f, u32 offset, u32 len, u8 *dst)
Peek data from fifo.
u32 wrk_map_index
Worker index in app's map pool.
static clib_error_t * session_queue_exit(vlib_main_t *vm)
static uword session_queue_node_fn(vlib_main_t *vm, vlib_node_runtime_t *node, vlib_frame_t *frame)
int vnet_unlisten(vnet_unlisten_args_t *a)
session_evt_elt_t * event_elts
Pool of session event list elements.
static void * session_evt_ctrl_data(session_worker_t *wrk, session_evt_elt_t *elt)
void svm_fifo_overwrite_head(svm_fifo_t *f, u8 *src, u32 len)
Overwrite fifo head with new data.
#define vec_validate_aligned(V, I, A)
Make sure vector is long enough for given index (no header, specified alignment)
int session_tx_fifo_dequeue_and_snd(session_worker_t *wrk, vlib_node_runtime_t *node, session_evt_elt_t *e, int *n_tx_packets)
static u32 transport_connection_snd_params(transport_connection_t *tc, transport_send_params_t *sp)
Get send parameters for transport connection.
void session_node_enable_disable(u8 is_en)
vlib_main_t ** vlib_mains
static void session_parse_handle(session_handle_t handle, u32 *index, u32 *thread_index)
app_worker_t * application_get_worker(application_t *app, u32 wrk_map_index)
transport_send_params_t sp
u16 * pending_tx_nexts
Vector of nexts for the pending tx buffers.
static void session_tx_fill_buffer(vlib_main_t *vm, session_tx_context_t *ctx, vlib_buffer_t *b, u16 *n_bufs, u8 peek_data)
static u32 session_evt_ctrl_data_alloc(session_worker_t *wrk)
struct _vnet_bind_args_t vnet_listen_args_t
session_t * sessions
Worker session pool.
#define vec_reset_length(v)
Reset vector length to zero NULL-pointer tolerant.
#define vlib_worker_thread_barrier_sync(X)
void transport_update_time(clib_time_type_t time_now, u8 thread_index)
#define clib_memcpy(d, s, n)
static void session_mq_disconnect_handler(void *data)
u32 * tx_buffers
Vector of tx buffer free lists.
int svm_msg_q_lock_and_alloc_msg_w_ring(svm_msg_q_t *mq, u32 ring_index, u8 noblock, svm_msg_q_msg_t *msg)
Lock message queue and allocate message buffer on ring.
static int svm_fifo_is_empty(svm_fifo_t *f)
Check if fifo is empty.
static session_worker_t * session_main_get_worker(u32 thread_index)
#define static_always_inline
vlib_main_t * vm
Convenience pointer to this worker's vlib_main.
static uword vlib_process_get_events(vlib_main_t *vm, uword **data_vector)
Return the first event type which has occurred and a vector of per-event data of that type...
struct _vnet_disconnect_args_t vnet_disconnect_args_t
static void session_mq_connect_uri_handler(void *data)
clib_llist_index_t new_head
Head of list of elements.
static u32 svm_fifo_max_dequeue_cons(svm_fifo_t *f)
Fifo max bytes to dequeue optimized for consumer.
description fragment has unexpected format
u32 * session_type_to_next
Per session type output nodes.
#define vlib_prefetch_buffer_header(b, type)
Prefetch buffer metadata.
int svm_fifo_dequeue(svm_fifo_t *f, u32 len, u8 *dst)
Dequeue data from fifo.
int session_send_io_evt_to_thread(svm_fifo_t *f, session_evt_type_t evt_type)
u8 session_is_valid(u32 si, u8 thread_index)
#define TRANSPORT_PACER_MAX_BURST_PKTS
static char * session_queue_error_strings[]
int session_dequeue_notify(session_t *s)
transport_proto_vft_t * transport_protocol_get_vft(transport_proto_t transport_proto)
Get transport virtual function table.
vlib_error_t error
Error code for buffers to be enqueued to error handler.
u32 client_index
app client index
#define TRANSPORT_MAX_HDRS_LEN
#define pool_elt_at_index(p, i)
Returns pointer to element at given index.
#define CLIB_US_TIME_FREQ
static void * vlib_buffer_make_headroom(vlib_buffer_t *b, u8 size)
Make head room, typically for packet headers.
transport_proto_vft_t * transport_vft
static __clib_warn_unused_result u32 vlib_buffer_alloc(vlib_main_t *vm, u32 *buffers, u32 n_buffers)
Allocate buffers into supplied array.
static __clib_warn_unused_result int vlib_trace_buffer(vlib_main_t *vm, vlib_node_runtime_t *r, u32 next_index, vlib_buffer_t *b, int follow_chain)
static void session_evt_ctrl_data_free(session_worker_t *wrk, session_evt_elt_t *elt)
static void * vlib_buffer_get_current(vlib_buffer_t *b)
Get pointer to current data to process.
static uword session_queue_process(vlib_main_t *vm, vlib_node_runtime_t *rt, vlib_frame_t *f)
int mq_send_session_bound_cb(u32 app_wrk_index, u32 api_context, session_handle_t handle, int rv)
int session_tx_fifo_peek_and_snd(session_worker_t *wrk, vlib_node_runtime_t *node, session_evt_elt_t *e, int *n_tx_packets)
static void svm_fifo_unset_event(svm_fifo_t *f)
Unset fifo event flag.
static u8 transport_connection_is_tx_paced(transport_connection_t *tc)
Check if transport connection is paced.
u32 wrk_index
Worker index in global worker pool.
u32 node_index
Node index.
session_fifo_rx_fn ** session_tx_fns
Per transport rx function that can either dequeue or peek.
int session_tx_fifo_dequeue_internal(session_worker_t *wrk, vlib_node_runtime_t *node, session_evt_elt_t *elt, int *n_tx_packets)
u64 session_segment_handle(session_t *s)
static void vlib_node_increment_counter(vlib_main_t *vm, u32 node_index, u32 counter_index, u64 increment)
static session_t * session_get_from_handle_if_valid(session_handle_t handle)
static_always_inline u32 vlib_buffer_get_default_data_size(vlib_main_t *vm)
static u8 svm_fifo_set_event(svm_fifo_t *f)
Set fifo event flag.
#define foreach_session_ctrl_evt
The fine-grained event logger allows lightweight, thread-safe event logging at minimum cost...
static void session_event_dispatch_io(session_worker_t *wrk, vlib_node_runtime_t *node, session_evt_elt_t *elt, int *n_tx_packets)
static void session_evt_elt_free(session_worker_t *wrk, session_evt_elt_t *elt)
#define VLIB_REGISTER_NODE(x,...)
static u8 svm_fifo_needs_deq_ntf(svm_fifo_t *f, u32 n_last_deq)
Check if fifo needs dequeue notification.
static void session_tx_fifo_chain_tail(vlib_main_t *vm, session_tx_context_t *ctx, vlib_buffer_t *b, u16 *n_bufs, u8 peek_data)
static void session_evt_add_to_list(session_worker_t *wrk, session_event_t *evt)
static_always_inline uword vlib_get_thread_index(void)
#define CLIB_PREFETCH(addr, size, type)
static void svm_msg_q_unlock(svm_msg_q_t *mq)
Unlock message queue.
static_always_inline void vlib_buffer_enqueue_to_next(vlib_main_t *vm, vlib_node_runtime_t *node, u32 *buffers, u16 *nexts, uword count)
sll srl srl sll sra u16x4 i
#define vec_free(V)
Free vector's memory (no header).
#define SESSION_CONN_HDR_LEN
int app_worker_builtin_rx(app_worker_t *app_wrk, session_t *s)
#define VLIB_MAIN_LOOP_EXIT_FUNCTION(x)
#define clib_warning(format, args...)
static vlib_node_runtime_t * vlib_node_get_runtime(vlib_main_t *vm, u32 node_index)
Get node runtime by node index.
struct _transport_connection transport_connection_t
#define pool_is_free_index(P, I)
Use free bitmap to query whether given index is free.
static session_evt_elt_t * session_evt_alloc_new(session_worker_t *wrk)
static_always_inline uword session_queue_pre_input_inline(vlib_main_t *vm, vlib_node_runtime_t *node, vlib_frame_t *frame)
blocking call - best used in combination with condvars, for eventfds we don't yield the cpu ...
u32 * pending_tx_buffers
Vector of buffers to be sent.
static int svm_msg_q_try_lock(svm_msg_q_t *mq)
Try locking message queue.
static u32 session_thread_from_handle(session_handle_t handle)
vlib_main_t vlib_node_runtime_t * node
transport_snd_flags_t flags
static int transport_custom_tx(transport_proto_t tp, void *s, transport_send_params_t *sp)
#define foreach_session_queue_error
static void session_mq_app_wrk_rpc_handler(void *data)
static void session_mq_disconnected_reply_handler(void *data)
void svm_msg_q_add_and_unlock(svm_msg_q_t *mq, svm_msg_q_msg_t *msg)
Producer enqueue one message to queue with mutex held.
void transport_connection_tx_pacer_reset_bucket(transport_connection_t *tc, u32 bucket)
Reset tx pacer bucket.
int ct_session_connect_notify(session_t *ss)
session_tx_context_t ctx
Context for session tx.
int vnet_listen(vnet_listen_args_t *a)
static u8 * format_session_error(u8 *s, va_list *args)
int vnet_application_detach(vnet_app_detach_args_t *a)
Detach application from vpp.
#define TRANSPORT_PACER_MIN_BURST
enum _transport_proto transport_proto_t
#define clib_llist_elt_is_linked(E, name)
Check if element is linked in a list.
u32 wrk_index
dst worker index
static void vlib_node_set_state(vlib_main_t *vm, u32 node_index, vlib_node_state_t new_state)
Set node dispatch state.
clib_time_type_t last_vlib_time
vlib_time_now last time around the track
struct _vnet_app_detach_args_t vnet_app_detach_args_t
static uword pointer_to_uword(const void *p)
int vnet_connect(vnet_connect_args_t *a)
static u8 * format_session_queue_trace(u8 *s, va_list *args)
static int transport_app_rx_evt(transport_proto_t tp, u32 conn_index, u32 thread_index)
u8 thread_index
Index of the thread that allocated the session.
void transport_connection_tx_pacer_update_bytes(transport_connection_t *tc, u32 bytes)
static void session_tx_set_dequeue_params(vlib_main_t *vm, session_tx_context_t *ctx, u32 max_segs, u8 peek_data)
u32 app_index
App index in app pool.
struct _vlib_node_registration vlib_node_registration_t
template key/value backing page structure
app_worker_t * app_worker_get(u32 wrk_index)
void svm_msg_q_free_msg(svm_msg_q_t *mq, svm_msg_q_msg_t *msg)
Free message buffer.
#define vec_len(v)
Number of elements in vector (rvalue-only, NULL tolerant)
void vlib_rpc_call_main_thread(void *callback, u8 *args, u32 arg_size)
static u8 session_tx_not_ready(session_t *s, u8 peek_data)
clib_llist_index_t old_head
Head of list of pending events.
u32 next_buffer
Next buffer for this linked-list of buffers.
volatile u8 session_state
State in session layer state machine.
vlib_main_t vlib_node_runtime_t vlib_frame_t * frame
#define VLIB_BUFFER_TRACE_TRAJECTORY_INIT(b)
VLIB buffer representation.
int vnet_bind_uri(vnet_listen_args_t *a)
static const u32 session_evt_msg_sizes[]
static void session_mq_worker_update_handler(void *data)
static void session_evt_add_old(session_worker_t *wrk, session_evt_elt_t *elt)
int vnet_disconnect_session(vnet_disconnect_args_t *a)
static void session_mq_accepted_reply_handler(void *data)
static void session_evt_add_head_old(session_worker_t *wrk, session_evt_elt_t *elt)
vlib_node_registration_t session_queue_node
(constructor) VLIB_REGISTER_NODE (session_queue_node)
static session_evt_elt_t * session_evt_alloc_ctrl(session_worker_t *wrk)
struct clib_bihash_value offset
template key/value backing page structure
static void session_mq_disconnected_handler(void *data)
static u8 session_has_transport(session_t *s)
#define clib_llist_prev_index(E, name)
static transport_connection_t * session_tx_get_transport(session_tx_context_t *ctx, u8 peek_data)
u32 app_index
Index of owning app.
transport_connection_t * tc
static void session_flush_pending_tx_buffers(session_worker_t *wrk, vlib_node_runtime_t *node)
int app_worker_own_session(app_worker_t *app_wrk, session_t *s)
void vlib_worker_thread_barrier_release(vlib_main_t *vm)
clib_us_time_t last_vlib_us_time
vlib_time_now rounded to us precision and as u64
static u32 vlib_num_workers()
static u32 svm_msg_q_size(svm_msg_q_t *mq)
Check length of message queue.
static session_t * session_event_get_session(session_worker_t *wrk, session_event_t *e)
u32 app_wrk_index
Index of the app worker that owns the session.
static void session_mq_listen_handler(void *data)
static int session_tx_fifo_read_and_snd_i(session_worker_t *wrk, vlib_node_runtime_t *node, session_evt_elt_t *elt, int *n_tx_packets, u8 peek_data)
#define clib_llist_remove(LP, name, E)
Remove entry from list.
void * vlib_add_trace(vlib_main_t *vm, vlib_node_runtime_t *r, vlib_buffer_t *b, u32 n_data_bytes)
static session_main_t * vnet_get_session_main()
void session_transport_close(session_t *s)
Notify transport the session can be disconnected.
clib_llist_index_t ctrl_head
Head of control events list.
int app_worker_close_notify(app_worker_t *app_wrk, session_t *s)
static void vlib_set_trace_count(vlib_main_t *vm, vlib_node_runtime_t *rt, u32 count)
#define CLIB_CACHE_LINE_BYTES
u32 total_length_not_including_first_buffer
Only valid for first buffer in chain.
#define clib_llist_foreach_safe(LP, name, H, E, body)
Walk list starting at head safe.
int vnet_connect_uri(vnet_connect_args_t *a)
int svm_fifo_dequeue_drop(svm_fifo_t *f, u32 len)
Dequeue and drop bytes from fifo.
vlib_node_registration_t session_queue_process_node
(constructor) VLIB_REGISTER_NODE (session_queue_process_node)
static uword session_queue_run_on_main(vlib_main_t *vm)
svm_msg_q_t * event_queue
Application listens for events on this svm queue.
struct _svm_fifo svm_fifo_t
static void transport_connection_deschedule(transport_connection_t *tc)
#define SESSION_NODE_FRAME_SIZE
static vlib_buffer_t * vlib_get_buffer(vlib_main_t *vm, u32 buffer_index)
Translate buffer index into buffer pointer.
struct session_dgram_header_ session_dgram_hdr_t
#define SESSION_EVT(_evt, _args...)
static void session_mq_reset_reply_handler(void *data)
u32 transport_connection_tx_pacer_burst(transport_connection_t *tc)
Get tx pacer max burst.
static void session_mq_connect_handler(void *data)
void mq_send_unlisten_reply(app_worker_t *app_wrk, session_handle_t sh, u32 context, int rv)
#define app_check_thread_and_barrier(_fn, _arg)
static void session_tx_maybe_reschedule(session_worker_t *wrk, session_tx_context_t *ctx, session_evt_elt_t *elt)
#define clib_llist_entry_index(LP, E)
Get list entry index.
void svm_msg_q_sub_w_lock(svm_msg_q_t *mq, svm_msg_q_msg_t *msg)
Consumer dequeue one message from queue with mutex held.