Home
last modified time | relevance | path

Searched refs:timeout (Results 1 – 25 of 220) sorted by relevance

123456789

/subsys/net/ip/
A Dnet_timeout.c16 timeout->timer_start = now; in net_timeout_set()
22 timeout->wrap_counter = 0; in net_timeout_set()
23 timeout->timer_timeout = 0; in net_timeout_set()
32 (uint64_t)timeout->wrap_counter; in net_timeout_set()
38 if (timeout->timer_timeout == 0U) { in net_timeout_set()
40 timeout->wrap_counter -= 1; in net_timeout_set()
93 : timeout->timer_timeout; in net_timeout_evaluate()
118 timeout->timer_start = now; in net_timeout_evaluate()
120 timeout->wrap_counter -= 1; in net_timeout_evaluate()
132 timeout->wrap_counter -= 1U; in net_timeout_evaluate()
[all …]
A Dnet_pkt.c393 timeout = K_NO_WAIT; in net_pkt_get_reserve_data_debug()
435 k_timeout_t timeout) in net_pkt_get_frag_debug()
449 timeout); in net_pkt_get_frag_debug()
1280 timeout = K_NO_WAIT;
1363 k_timeout_t timeout)
1374 timeout = K_NO_WAIT;
1391 timeout,
1399 timeout);
1423 timeout = K_NO_WAIT;
1478 timeout = K_NO_WAIT;
[all …]
/subsys/tracing/test/
A Dtracing_test.h29 #define sys_port_trace_k_thread_sleep_enter(timeout) sys_trace_k_thread_sleep_enter(timeout) argument
30 #define sys_port_trace_k_thread_sleep_exit(timeout, ret) sys_trace_k_thread_sleep_exit(timeout, ret) argument
559 k_timeout_t timeout);
631 k_timeout_t timeout);
633 k_timeout_t timeout);
637 k_timeout_t timeout);
643 k_timeout_t timeout);
645 k_timeout_t timeout);
656 k_timeout_t timeout);
660 k_timeout_t timeout);
[all …]
A Dtracing_string_format_test.c96 void sys_trace_k_thread_sleep_enter(k_timeout_t timeout) in sys_trace_k_thread_sleep_enter() argument
101 void sys_trace_k_thread_sleep_exit(k_timeout_t timeout, int ret) in sys_trace_k_thread_sleep_exit() argument
247 k_timeout_t timeout) in sys_trace_k_condvar_wait_enter() argument
253 k_timeout_t timeout, int ret) in sys_trace_k_condvar_wait_exit() argument
268 void sys_trace_k_sem_take_enter(struct k_sem *sem, k_timeout_t timeout) in sys_trace_k_sem_take_enter() argument
273 void sys_trace_k_sem_take_exit(struct k_sem *sem, k_timeout_t timeout, int ret) in sys_trace_k_sem_take_exit() argument
278 void sys_trace_k_sem_take_blocking(struct k_sem *sem, k_timeout_t timeout) in sys_trace_k_sem_take_blocking() argument
293 void sys_trace_k_mutex_lock_enter(struct k_mutex *mutex, k_timeout_t timeout) in sys_trace_k_mutex_lock_enter() argument
301 (uint32_t)timeout.ticks, ret); in sys_trace_k_mutex_lock_exit()
405 k_timeout_t timeout, void *ret) in sys_trace_k_heap_aligned_alloc_exit() argument
[all …]
/subsys/tracing/user/
A Dtracing_user.h111 #define sys_port_trace_k_thread_sleep_enter(timeout) argument
112 #define sys_port_trace_k_thread_sleep_exit(timeout, ret) argument
188 timeout) argument
190 timeout) argument
209 #define sys_port_trace_k_sem_take_enter(sem, timeout) argument
272 #define sys_port_trace_k_fifo_get_enter(fifo, timeout) argument
285 #define sys_port_trace_k_lifo_get_enter(lifo, timeout) argument
304 #define sys_port_trace_k_msgq_put_enter(msgq, timeout) argument
310 #define sys_port_trace_k_msgq_get_enter(msgq, timeout) argument
320 #define sys_port_trace_k_mbox_put_enter(mbox, timeout) argument
[all …]
/subsys/tracing/ctf/
A Dtracing_ctf.h36 sys_trace_k_thread_sleep_enter(timeout)
38 sys_trace_k_thread_sleep_exit(timeout, ret)
126 timeout) argument
128 timeout) argument
150 sys_trace_k_sem_take_enter(sem, timeout)
152 sys_trace_k_sem_take_blocking(sem, timeout)
154 sys_trace_k_sem_take_exit(sem, timeout, ret)
160 sys_trace_k_mutex_lock_enter(mutex, timeout)
162 sys_trace_k_mutex_lock_blocking(mutex, timeout)
405 k_timeout_t timeout);
[all …]
/subsys/tracing/sysview/
A Dtracing_sysview.h43 (uint32_t)timeout.ticks)
185 (uint32_t)timeout.ticks)
189 (uint32_t)timeout.ticks)
273 (uint32_t)timeout.ticks)
316 (uint32_t)timeout.ticks)
402 (uint32_t)timeout.ticks)
577 (uint32_t)timeout.ticks)
586 (uint32_t)timeout.ticks)
593 (uint32_t)timeout.ticks)
604 (uint32_t)timeout.ticks)
[all …]
/subsys/zbus/
A Dzbus_runtime_observers.c13 k_timeout_t timeout) in _zbus_runtime_observer_node_alloc() argument
15 ARG_UNUSED(timeout); in _zbus_runtime_observer_node_alloc()
39 k_timeout_t timeout) in _zbus_runtime_observer_node_alloc() argument
58 k_timeout_t timeout) in _zbus_runtime_take_chan_sem_and_obs_check() argument
69 err = k_sem_take(&chan->data->sem, timeout); in _zbus_runtime_take_chan_sem_and_obs_check()
101 struct zbus_observer_node *node, k_timeout_t timeout) in zbus_chan_add_obs_with_node() argument
106 err = _zbus_runtime_take_chan_sem_and_obs_check(chan, obs, timeout); in zbus_chan_add_obs_with_node()
130 k_timeout_t timeout) in zbus_chan_add_obs() argument
133 k_timepoint_t end_time = sys_timepoint_calc(timeout); in zbus_chan_add_obs()
161 k_timeout_t timeout) in zbus_chan_rm_obs() argument
[all …]
A Dzbus.c30 k_timeout_t timeout) in _zbus_create_net_buf() argument
32 return net_buf_alloc_len(pool, size, timeout); in _zbus_create_net_buf()
43 k_timeout_t timeout) in _zbus_create_net_buf() argument
49 return net_buf_alloc(pool, timeout); in _zbus_create_net_buf()
387 timeout = K_NO_WAIT; in zbus_chan_pub()
425 timeout = K_NO_WAIT; in zbus_chan_read()
449 timeout = K_NO_WAIT; in zbus_chan_notify()
475 timeout = K_NO_WAIT; in zbus_chan_claim()
497 k_timeout_t timeout) in zbus_sub_wait() argument
505 return k_msgq_get(sub->queue, chan, timeout); in zbus_sub_wait()
[all …]
/subsys/mgmt/hawkbit/
A Dhawkbit_autohandler.c86 enum hawkbit_response hawkbit_autohandler_wait(uint32_t events, k_timeout_t timeout) in hawkbit_autohandler_wait() argument
88 uint32_t ret = k_event_wait(&hawkbit_autohandler_event, events, false, timeout); in hawkbit_autohandler_wait()
103 int hawkbit_autohandler_set_delay(k_timeout_t timeout, bool if_bigger) in hawkbit_autohandler_set_delay() argument
105 if (!if_bigger || timeout.ticks > k_work_delayable_remaining_get(&hawkbit_work_handle)) { in hawkbit_autohandler_set_delay()
108 (uint32_t)(timeout.ticks / CONFIG_SYS_CLOCK_TICKS_PER_SEC) / 3600, in hawkbit_autohandler_set_delay()
109 (uint32_t)((timeout.ticks / CONFIG_SYS_CLOCK_TICKS_PER_SEC) % 3600) / 60, in hawkbit_autohandler_set_delay()
110 (uint32_t)(timeout.ticks / CONFIG_SYS_CLOCK_TICKS_PER_SEC) % 60); in hawkbit_autohandler_set_delay()
111 return k_work_reschedule(&hawkbit_work_handle, timeout); in hawkbit_autohandler_set_delay()
/subsys/net/lib/sntp/
A Dsntp_simple.c12 static int sntp_simple_helper(struct sockaddr *addr, socklen_t addr_len, uint32_t timeout, in sntp_simple_helper() argument
26 if (timeout == SYS_FOREVER_MS) { in sntp_simple_helper()
27 deadline = (uint64_t)timeout; in sntp_simple_helper()
29 deadline = k_uptime_get() + (uint64_t)timeout; in sntp_simple_helper()
74 int sntp_simple_addr(struct sockaddr *addr, socklen_t addr_len, uint32_t timeout, in sntp_simple_addr() argument
84 return sntp_simple_helper(addr, addr_len, timeout, ts); in sntp_simple_addr()
87 int sntp_simple(const char *server, uint32_t timeout, struct sntp_time *ts) in sntp_simple() argument
105 res = sntp_simple_helper(addr->ai_addr, addr->ai_addrlen, timeout, ts); in sntp_simple()
/subsys/portability/cmsis_rtos_v2/
A Dmsgq.c91 uint32_t timeout) in osMessageQueuePut() argument
103 if (timeout > 0 && k_is_in_isr()) { in osMessageQueuePut()
107 if (timeout == 0U) { in osMessageQueuePut()
109 } else if (timeout == osWaitForever) { in osMessageQueuePut()
112 retval = k_msgq_put(&msgq->z_msgq, (void *)msg_ptr, K_TICKS(timeout)); in osMessageQueuePut()
128 uint32_t timeout) in osMessageQueueGet() argument
140 if (timeout > 0 && k_is_in_isr()) { in osMessageQueueGet()
144 if (timeout == 0U) { in osMessageQueueGet()
146 } else if (timeout == osWaitForever) { in osMessageQueueGet()
149 retval = k_msgq_get(&msgq->z_msgq, msg_ptr, K_TICKS(timeout)); in osMessageQueueGet()
A Dsemaphore.c58 osStatus_t osSemaphoreAcquire(osSemaphoreId_t semaphore_id, uint32_t timeout) in osSemaphoreAcquire() argument
68 if (timeout > 0 && k_is_in_isr()) { in osSemaphoreAcquire()
72 if (timeout == osWaitForever) { in osSemaphoreAcquire()
74 } else if (timeout == 0U) { in osSemaphoreAcquire()
77 status = k_sem_take(&semaphore->z_semaphore, K_TICKS(timeout)); in osSemaphoreAcquire()
/subsys/bluetooth/host/
A Dbuf.c108 struct net_buf *bt_buf_get_rx(enum bt_buf_type type, k_timeout_t timeout) in bt_buf_get_rx() argument
116 return bt_iso_get_rx(timeout); in bt_buf_get_rx()
121 buf = net_buf_alloc(&evt_pool, timeout); in bt_buf_get_rx()
123 buf = net_buf_alloc(&acl_in_pool, timeout); in bt_buf_get_rx()
126 buf = net_buf_alloc(&hci_rx_pool, timeout); in bt_buf_get_rx()
149 k_timeout_t timeout) in bt_buf_get_evt() argument
159 buf = net_buf_alloc(&sync_evt_pool, timeout); in bt_buf_get_evt()
164 buf = net_buf_alloc(&discardable_pool, timeout); in bt_buf_get_evt()
166 return bt_buf_get_rx(BT_BUF_EVT, timeout); in bt_buf_get_evt()
A Dlong_wq.c18 int bt_long_wq_schedule(struct k_work_delayable *dwork, k_timeout_t timeout) in bt_long_wq_schedule() argument
20 return k_work_schedule_for_queue(&bt_long_wq, dwork, timeout); in bt_long_wq_schedule()
23 int bt_long_wq_reschedule(struct k_work_delayable *dwork, k_timeout_t timeout) in bt_long_wq_reschedule() argument
25 return k_work_reschedule_for_queue(&bt_long_wq, dwork, timeout); in bt_long_wq_reschedule()
A Dhci_raw.c80 struct net_buf *bt_buf_get_rx(enum bt_buf_type type, k_timeout_t timeout) in bt_buf_get_rx() argument
94 buf = net_buf_alloc(&hci_rx_pool, timeout); in bt_buf_get_rx()
109 struct net_buf *bt_buf_get_tx(enum bt_buf_type type, k_timeout_t timeout, in bt_buf_get_tx() argument
132 buf = net_buf_alloc(pool, timeout); in bt_buf_get_tx()
151 struct net_buf *bt_buf_get_evt(uint8_t evt, bool discardable, k_timeout_t timeout) in bt_buf_get_evt() argument
156 return bt_buf_get_rx(BT_BUF_EVT, timeout); in bt_buf_get_evt()
/subsys/net/lib/ocpp/
A Docpp_wamp_rpc.c13 int ocpp_send_to_server(struct ocpp_wamp_rpc_msg *snd, k_timeout_t timeout) in ocpp_send_to_server() argument
24 ret = k_mutex_lock(snd->sndlock, timeout); in ocpp_send_to_server()
61 ret = k_poll(events, 1, timeout); in ocpp_send_to_server()
76 uint32_t timeout) in ocpp_receive_from_server() argument
83 k_mutex_lock(&ctx->ilock, K_MSEC(timeout)); in ocpp_receive_from_server()
94 timeout); in ocpp_receive_from_server()
/subsys/portability/cmsis_rtos_v1/
A Dcmsis_mutex.c43 osStatus osMutexWait(osMutexId mutex_id, uint32_t timeout) in osMutexWait() argument
56 if (timeout == osWaitForever) { in osMutexWait()
58 } else if (timeout == 0U) { in osMutexWait()
61 status = k_mutex_lock(mutex, K_MSEC(timeout)); in osMutexWait()
64 if (timeout != 0 && (status == -EAGAIN || status == -EBUSY)) { in osMutexWait()
/subsys/net/lib/sockets/
A Dsockets_packet.c33 k_timeout_t timeout) in k_fifo_wait_non_empty() argument
40 return k_poll(events, ARRAY_SIZE(events), timeout); in k_fifo_wait_non_empty()
251 k_timeout_t timeout = K_FOREVER; in zpacket_sendto_ctx() local
260 timeout = K_NO_WAIT; in zpacket_sendto_ctx()
266 NULL, timeout, ctx->user_data); in zpacket_sendto_ctx()
278 k_timeout_t timeout = K_FOREVER; in zpacket_sendmsg_ctx() local
282 timeout = K_NO_WAIT; in zpacket_sendmsg_ctx()
301 k_timeout_t timeout = K_FOREVER; in zpacket_recvfrom_ctx() local
305 timeout = K_NO_WAIT; in zpacket_recvfrom_ctx()
313 res = k_fifo_wait_non_empty(&ctx->recv_q, timeout); in zpacket_recvfrom_ctx()
[all …]
/subsys/bluetooth/mesh/
A Drpr_cli.c332 status->timeout = net_buf_simple_pull_u8(buf); in handle_scan_status()
356 struct bt_mesh_rpr_cli, link.timeout); in link_timeout()
459 k_work_cancel_delayable(&cli->link.timeout); in link_reset()
504 const uint8_t uuid[16], uint8_t timeout, in bt_mesh_rpr_scan_start() argument
508 if (!timeout) { in bt_mesh_rpr_scan_start()
516 net_buf_simple_add_u8(&buf, timeout); in bt_mesh_rpr_scan_start()
546 net_buf_simple_add_u8(&buf, timeout); in bt_mesh_rpr_scan_start_ext()
585 uint8_t timeout) in link_open_prov() argument
686 tx_timeout = timeout; in bt_mesh_rpr_cli_timeout_set()
720 cli->link.time = timeout ? timeout : LINK_TIMEOUT_SECONDS_DEFAULT; in pb_link_open()
[all …]
A Dadv.c89 uint8_t xmit, k_timeout_t timeout) in adv_create_from_pool() argument
100 err = k_mem_slab_alloc(buf_pool, (void **)&adv, timeout); in adv_create_from_pool()
157 uint8_t xmit, k_timeout_t timeout) in bt_mesh_adv_create() argument
162 type, tag, xmit, timeout); in bt_mesh_adv_create()
169 type, tag, xmit, timeout); in bt_mesh_adv_create()
174 tag, xmit, timeout); in bt_mesh_adv_create()
197 struct bt_mesh_adv *bt_mesh_adv_get(k_timeout_t timeout) in bt_mesh_adv_get() argument
216 err = k_poll(events, ARRAY_SIZE(events), timeout); in bt_mesh_adv_get()
228 return k_fifo_get(&bt_mesh_friend_queue, timeout); in bt_mesh_adv_get_by_tag()
233 return k_fifo_get(&bt_mesh_relay_queue, timeout); in bt_mesh_adv_get_by_tag()
[all …]
A Dsar_cfg_cli.c82 return cli->timeout; in bt_mesh_sar_cfg_cli_timeout_get()
85 void bt_mesh_sar_cfg_cli_timeout_set(int32_t timeout) in bt_mesh_sar_cfg_cli_timeout_set() argument
87 cli->timeout = timeout; in bt_mesh_sar_cfg_cli_timeout_set()
104 cli->timeout = 2 * MSEC_PER_SEC; in bt_mesh_sar_cfg_cli_init()
149 return bt_mesh_msg_ack_ctx_wait(&cli->ack_ctx, K_MSEC(cli->timeout)); in bt_mesh_sar_cfg_cli_transmitter_get()
175 return bt_mesh_msg_ack_ctx_wait(&cli->ack_ctx, K_MSEC(cli->timeout)); in bt_mesh_sar_cfg_cli_transmitter_set()
199 return bt_mesh_msg_ack_ctx_wait(&cli->ack_ctx, K_MSEC(cli->timeout)); in bt_mesh_sar_cfg_cli_receiver_get()
225 return bt_mesh_msg_ack_ctx_wait(&cli->ack_ctx, K_MSEC(cli->timeout)); in bt_mesh_sar_cfg_cli_receiver_set()
/subsys/net/lib/websocket/
A Dwebsocket.c461 int timeout) in websocket_poll_offload() argument
495 fds, nfds, timeout); in websocket_poll_offload()
514 int timeout; in websocket_ioctl_vmeth() local
518 timeout = va_arg(args, int); in websocket_ioctl_vmeth()
610 int32_t timeout) in websocket_prepare_and_send() argument
643 tout = K_MSEC(timeout); in websocket_prepare_and_send()
657 int32_t timeout) in websocket_send_msg() argument
951 tout = K_MSEC(timeout); in websocket_recv_msg()
1105 &remaining, timeout); in websocket_recv()
1142 timeout = 0; in websocket_sendto_ctx()
[all …]
/subsys/net/lib/dhcpv4/
A Ddhcpv4.c462 uint32_t timeout; in dhcpv4_update_message_timeout() local
467 if (timeout < DHCPV4_INITIAL_RETRY_TIMEOUT || timeout > 64) { in dhcpv4_update_message_timeout()
468 timeout = 64; in dhcpv4_update_message_timeout()
477 return timeout; in dhcpv4_update_message_timeout()
500 return timeout; in dhcpv4_calculate_renew_rebind_timeout()
515 return timeout; in dhcpv4_update_renew_timeout()
530 return timeout; in dhcpv4_update_rebind_timeout()
614 timeout); in dhcpv4_send_request()
616 return timeout; in dhcpv4_send_request()
623 return timeout; in dhcpv4_send_request()
[all …]
/subsys/net/l2/ethernet/lldp/
A Dlldp.c54 static void lldp_submit_work(uint32_t timeout) in lldp_submit_work() argument
57 k_work_reschedule(&lldp_tx_timer, K_MSEC(timeout)); in lldp_submit_work()
64 static bool lldp_check_timeout(int64_t start, uint32_t time, int64_t timeout) in lldp_check_timeout() argument
69 if (start > timeout) { in lldp_check_timeout()
76 static bool lldp_timedout(struct ethernet_lldp *lldp, int64_t timeout) in lldp_timedout() argument
80 timeout); in lldp_timedout()
166 static uint32_t lldp_manage_timeouts(struct ethernet_lldp *lldp, int64_t timeout) in lldp_manage_timeouts() argument
170 if (lldp_timedout(lldp, timeout)) { in lldp_manage_timeouts()
174 next_timeout = timeout - (lldp->tx_timer_start + in lldp_manage_timeouts()
183 int64_t timeout = k_uptime_get(); in lldp_tx_timeout() local
[all …]

Completed in 99 milliseconds

123456789