| /Linux-v6.6/net/rxrpc/ | 
| D | call_object.c | 2 /* RxRPC individual remote procedure call handling46 void rxrpc_poke_call(struct rxrpc_call *call, enum rxrpc_call_poke_trace what)  in rxrpc_poke_call()  argument
 48 	struct rxrpc_local *local = call->local;  in rxrpc_poke_call()
 51 	if (!test_bit(RXRPC_CALL_DISCONNECTED, &call->flags)) {  in rxrpc_poke_call()
 53 		busy = !list_empty(&call->attend_link);  in rxrpc_poke_call()
 54 		trace_rxrpc_poke_call(call, busy, what);  in rxrpc_poke_call()
 55 		if (!busy && !rxrpc_try_get_call(call, rxrpc_call_get_poke))  in rxrpc_poke_call()
 58 			list_add_tail(&call->attend_link, &local->call_attend_q);  in rxrpc_poke_call()
 68 	struct rxrpc_call *call = from_timer(call, t, timer);  in rxrpc_call_timer_expired()  local
 70 	_enter("%d", call->debug_id);  in rxrpc_call_timer_expired()
 [all …]
 
 | 
| D | input.c | 12 static void rxrpc_proto_abort(struct rxrpc_call *call, rxrpc_seq_t seq,  in rxrpc_proto_abort()  argument15 	rxrpc_abort_call(call, seq, RX_PROTOCOL_ERROR, -EBADMSG, why);  in rxrpc_proto_abort()
 21 static void rxrpc_congestion_management(struct rxrpc_call *call,  in rxrpc_congestion_management()  argument
 27 	unsigned int cumulative_acks = call->cong_cumul_acks;  in rxrpc_congestion_management()
 28 	unsigned int cwnd = call->cong_cwnd;  in rxrpc_congestion_management()
 32 		(call->tx_top - call->acks_hard_ack) - summary->nr_acks;  in rxrpc_congestion_management()
 34 	if (test_and_clear_bit(RXRPC_CALL_RETRANS_TIMEOUT, &call->flags)) {  in rxrpc_congestion_management()
 36 		call->cong_ssthresh = max_t(unsigned int,  in rxrpc_congestion_management()
 39 		if (cwnd >= call->cong_ssthresh &&  in rxrpc_congestion_management()
 40 		    call->cong_mode == RXRPC_CALL_SLOW_START) {  in rxrpc_congestion_management()
 [all …]
 
 | 
| D | call_event.c | 23 void rxrpc_propose_ping(struct rxrpc_call *call, u32 serial,  in rxrpc_propose_ping()  argument29 	if (time_before(ping_at, call->ping_at)) {  in rxrpc_propose_ping()
 30 		WRITE_ONCE(call->ping_at, ping_at);  in rxrpc_propose_ping()
 31 		rxrpc_reduce_call_timer(call, ping_at, now,  in rxrpc_propose_ping()
 33 		trace_rxrpc_propose_ack(call, why, RXRPC_ACK_PING, serial);  in rxrpc_propose_ping()
 40 void rxrpc_propose_delay_ACK(struct rxrpc_call *call, rxrpc_serial_t serial,  in rxrpc_propose_delay_ACK()  argument
 46 	call->ackr_serial = serial;  in rxrpc_propose_delay_ACK()
 50 	if (call->peer->srtt_us != 0)  in rxrpc_propose_delay_ACK()
 51 		ack_at = usecs_to_jiffies(call->peer->srtt_us >> 3);  in rxrpc_propose_delay_ACK()
 55 	ack_at += READ_ONCE(call->tx_backoff);  in rxrpc_propose_delay_ACK()
 [all …]
 
 | 
| D | sendmsg.c | 23 bool rxrpc_propose_abort(struct rxrpc_call *call, s32 abort_code, int error,  in rxrpc_propose_abort()  argument26 	_enter("{%d},%d,%d,%u", call->debug_id, abort_code, error, why);  in rxrpc_propose_abort()
 28 	if (!call->send_abort && !rxrpc_call_is_complete(call)) {  in rxrpc_propose_abort()
 29 		call->send_abort_why = why;  in rxrpc_propose_abort()
 30 		call->send_abort_err = error;  in rxrpc_propose_abort()
 31 		call->send_abort_seq = 0;  in rxrpc_propose_abort()
 33 		smp_store_release(&call->send_abort, abort_code);  in rxrpc_propose_abort()
 34 		rxrpc_poke_call(call, rxrpc_call_poke_abort);  in rxrpc_propose_abort()
 42  * Wait for a call to become connected.  Interruption here doesn't cause the
 43  * call to be aborted.
 [all …]
 
 | 
| D | rxperf.c | 65 	int (*deliver)(struct rxperf_call *call);74 static int rxperf_deliver_param_block(struct rxperf_call *call);
 75 static int rxperf_deliver_request(struct rxperf_call *call);
 76 static int rxperf_process_call(struct rxperf_call *call);
 82 static inline void rxperf_set_call_state(struct rxperf_call *call,  in rxperf_set_call_state()  argument
 85 	call->state = to;  in rxperf_set_call_state()
 88 static inline void rxperf_set_call_complete(struct rxperf_call *call,  in rxperf_set_call_complete()  argument
 91 	if (call->state != RXPERF_CALL_COMPLETE) {  in rxperf_set_call_complete()
 92 		call->abort_code = remote_abort;  in rxperf_set_call_complete()
 93 		call->error = error;  in rxperf_set_call_complete()
 [all …]
 
 | 
| D | recvmsg.c | 20  * Post a call for attention by the socket or kernel service.  Further23 void rxrpc_notify_socket(struct rxrpc_call *call)  in rxrpc_notify_socket()  argument
 28 	_enter("%d", call->debug_id);  in rxrpc_notify_socket()
 30 	if (!list_empty(&call->recvmsg_link))  in rxrpc_notify_socket()
 35 	rx = rcu_dereference(call->socket);  in rxrpc_notify_socket()
 38 		if (call->notify_rx) {  in rxrpc_notify_socket()
 39 			spin_lock(&call->notify_lock);  in rxrpc_notify_socket()
 40 			call->notify_rx(sk, call, call->user_call_ID);  in rxrpc_notify_socket()
 41 			spin_unlock(&call->notify_lock);  in rxrpc_notify_socket()
 44 			if (list_empty(&call->recvmsg_link)) {  in rxrpc_notify_socket()
 [all …]
 
 | 
| D | call_state.c | 2 /* Call state changing functions.11  * Transition a call to the complete state.
 13 bool rxrpc_set_call_completion(struct rxrpc_call *call,  in rxrpc_set_call_completion()  argument
 18 	if (__rxrpc_call_state(call) == RXRPC_CALL_COMPLETE)  in rxrpc_set_call_completion()
 21 	call->abort_code = abort_code;  in rxrpc_set_call_completion()
 22 	call->error = error;  in rxrpc_set_call_completion()
 23 	call->completion = compl;  in rxrpc_set_call_completion()
 25 	rxrpc_set_call_state(call, RXRPC_CALL_COMPLETE);  in rxrpc_set_call_completion()
 26 	trace_rxrpc_call_complete(call);  in rxrpc_set_call_completion()
 27 	wake_up(&call->waitq);  in rxrpc_set_call_completion()
 [all …]
 
 | 
| D | output.c | 48 static void rxrpc_tx_backoff(struct rxrpc_call *call, int ret)  in rxrpc_tx_backoff()  argument51 		u16 tx_backoff = READ_ONCE(call->tx_backoff);  in rxrpc_tx_backoff()
 54 			WRITE_ONCE(call->tx_backoff, tx_backoff + 1);  in rxrpc_tx_backoff()
 56 		WRITE_ONCE(call->tx_backoff, 0);  in rxrpc_tx_backoff()
 62  * lets the far side know we're still interested in this call and helps keep
 68 static void rxrpc_set_keepalive(struct rxrpc_call *call)  in rxrpc_set_keepalive()  argument
 70 	unsigned long now = jiffies, keepalive_at = call->next_rx_timo / 6;  in rxrpc_set_keepalive()
 73 	WRITE_ONCE(call->keepalive_at, keepalive_at);  in rxrpc_set_keepalive()
 74 	rxrpc_reduce_call_timer(call, keepalive_at, now,  in rxrpc_set_keepalive()
 82 				 struct rxrpc_call *call,  in rxrpc_fill_out_ack()  argument
 [all …]
 
 | 
| D | call_accept.c | 2 /* incoming call handling25 static void rxrpc_dummy_notify(struct sock *sk, struct rxrpc_call *call,  in rxrpc_dummy_notify()  argument
 31  * Preallocate a single service call, connection and peer and, if possible,
 41 	struct rxrpc_call *call, *xcall;  in rxrpc_service_prealloc_one()  local
 98 	call = rxrpc_alloc_call(rx, gfp, debug_id);  in rxrpc_service_prealloc_one()
 99 	if (!call)  in rxrpc_service_prealloc_one()
 101 	call->flags |= (1 << RXRPC_CALL_IS_SERVICE);  in rxrpc_service_prealloc_one()
 102 	rxrpc_set_call_state(call, RXRPC_CALL_SERVER_PREALLOC);  in rxrpc_service_prealloc_one()
 103 	__set_bit(RXRPC_CALL_EV_INITIAL_PING, &call->events);  in rxrpc_service_prealloc_one()
 105 	trace_rxrpc_call(call->debug_id, refcount_read(&call->ref),  in rxrpc_service_prealloc_one()
 [all …]
 
 | 
| D | conn_client.c | 8  * call so as to handle retransmitted DATA packets in case the server didn't15  *      or a call ID counter overflows.
 73 static struct rxrpc_bundle *rxrpc_alloc_bundle(struct rxrpc_call *call,  in rxrpc_alloc_bundle()  argument
 80 		bundle->local		= call->local;  in rxrpc_alloc_bundle()
 81 		bundle->peer		= rxrpc_get_peer(call->peer, rxrpc_peer_get_bundle);  in rxrpc_alloc_bundle()
 82 		bundle->key		= key_get(call->key);  in rxrpc_alloc_bundle()
 83 		bundle->security	= call->security;  in rxrpc_alloc_bundle()
 84 		bundle->exclusive	= test_bit(RXRPC_CALL_EXCLUSIVE, &call->flags);  in rxrpc_alloc_bundle()
 85 		bundle->upgrade		= test_bit(RXRPC_CALL_UPGRADE, &call->flags);  in rxrpc_alloc_bundle()
 86 		bundle->service_id	= call->dest_srx.srx_service;  in rxrpc_alloc_bundle()
 [all …]
 
 | 
| D | txbuf.c | 19 struct rxrpc_txbuf *rxrpc_alloc_txbuf(struct rxrpc_call *call, u8 packet_type,  in rxrpc_alloc_txbuf()  argument29 		txb->call_debug_id	= call->debug_id;  in rxrpc_alloc_txbuf()
 36 		txb->seq		= call->tx_prepared + 1;  in rxrpc_alloc_txbuf()
 37 		txb->wire.epoch		= htonl(call->conn->proto.epoch);  in rxrpc_alloc_txbuf()
 38 		txb->wire.cid		= htonl(call->cid);  in rxrpc_alloc_txbuf()
 39 		txb->wire.callNumber	= htonl(call->call_id);  in rxrpc_alloc_txbuf()
 42 		txb->wire.flags		= call->conn->out_clientflag;  in rxrpc_alloc_txbuf()
 44 		txb->wire.securityIndex	= call->security_ix;  in rxrpc_alloc_txbuf()
 46 		txb->wire.serviceId	= htons(call->dest_srx.srx_service);  in rxrpc_alloc_txbuf()
 105 void rxrpc_shrink_call_tx_buffer(struct rxrpc_call *call)  in rxrpc_shrink_call_tx_buffer()  argument
 [all …]
 
 | 
| /Linux-v6.6/fs/afs/ | 
| D | rxrpc.c | 28 /* asynchronous incoming call initial processing */134  * Allocate a call.
 140 	struct afs_call *call;  in afs_alloc_call()  local
 143 	call = kzalloc(sizeof(*call), gfp);  in afs_alloc_call()
 144 	if (!call)  in afs_alloc_call()
 147 	call->type = type;  in afs_alloc_call()
 148 	call->net = net;  in afs_alloc_call()
 149 	call->debug_id = atomic_inc_return(&rxrpc_debug_id);  in afs_alloc_call()
 150 	refcount_set(&call->ref, 1);  in afs_alloc_call()
 151 	INIT_WORK(&call->async_work, afs_process_async_call);  in afs_alloc_call()
 [all …]
 
 | 
| D | cmservice.c | 105  * route an incoming cache manager call108 bool afs_cm_incoming_call(struct afs_call *call)  in afs_cm_incoming_call()  argument
 110 	_enter("{%u, CB.OP %u}", call->service_id, call->operation_ID);  in afs_cm_incoming_call()
 112 	switch (call->operation_ID) {  in afs_cm_incoming_call()
 114 		call->type = &afs_SRXCBCallBack;  in afs_cm_incoming_call()
 117 		call->type = &afs_SRXCBInitCallBackState;  in afs_cm_incoming_call()
 120 		call->type = &afs_SRXCBInitCallBackState3;  in afs_cm_incoming_call()
 123 		call->type = &afs_SRXCBProbe;  in afs_cm_incoming_call()
 126 		call->type = &afs_SRXCBProbeUuid;  in afs_cm_incoming_call()
 129 		call->type = &afs_SRXCBTellMeAboutYourself;  in afs_cm_incoming_call()
 [all …]
 
 | 
| D | vlclient.c | 15  * Deliver reply data to a VL.GetEntryByNameU call.17 static int afs_deliver_vl_get_entry_by_name_u(struct afs_call *call)  in afs_deliver_vl_get_entry_by_name_u()  argument
 27 	ret = afs_transfer_reply(call);  in afs_deliver_vl_get_entry_by_name_u()
 32 	uvldb = call->buffer;  in afs_deliver_vl_get_entry_by_name_u()
 33 	entry = call->ret_vldb;  in afs_deliver_vl_get_entry_by_name_u()
 109 static void afs_destroy_vl_get_entry_by_name_u(struct afs_call *call)  in afs_destroy_vl_get_entry_by_name_u()  argument
 111 	kfree(call->ret_vldb);  in afs_destroy_vl_get_entry_by_name_u()
 112 	afs_flat_call_destructor(call);  in afs_destroy_vl_get_entry_by_name_u()
 134 	struct afs_call *call;  in afs_vl_get_entry_by_name_u()  local
 148 	call = afs_alloc_flat_call(net, &afs_RXVLGetEntryByNameU, reqsz,  in afs_vl_get_entry_by_name_u()
 [all …]
 
 | 
| D | yfsclient.c | 138 static void yfs_check_req(struct afs_call *call, __be32 *bp)  in yfs_check_req()  argument140 	size_t len = (void *)bp - call->request;  in yfs_check_req()
 142 	if (len > call->request_size)  in yfs_check_req()
 144 		       call->type->name, len, call->request_size);  in yfs_check_req()
 145 	else if (len < call->request_size)  in yfs_check_req()
 147 			call->type->name, len, call->request_size);  in yfs_check_req()
 174 				      struct afs_call *call,  in xdr_decode_YFSFetchStatus()  argument
 220 	afs_protocol_error(call, afs_eproto_bad_status);  in xdr_decode_YFSFetchStatus()
 228 				   struct afs_call *call,  in xdr_decode_YFSCallBack()  argument
 235 	cb_expiry = ktime_add(call->issue_time, xdr_to_u64(x->expiration_time) * 100);  in xdr_decode_YFSCallBack()
 [all …]
 
 | 
| D | fsclient.c | 55 				      struct afs_call *call,  in xdr_decode_AFSFetchStatus()  argument60 	bool inline_error = (call->operation_ID == afs_FS_InlineBulkStatus);  in xdr_decode_AFSFetchStatus()
 128 	afs_protocol_error(call, afs_eproto_bad_status);  in xdr_decode_AFSFetchStatus()
 132 static time64_t xdr_decode_expiry(struct afs_call *call, u32 expiry)  in xdr_decode_expiry()  argument
 134 	return ktime_divns(call->issue_time, NSEC_PER_SEC) + expiry;  in xdr_decode_expiry()
 138 				   struct afs_call *call,  in xdr_decode_AFSCallBack()  argument
 145 	cb->expires_at	= xdr_decode_expiry(call, ntohl(*bp++));  in xdr_decode_AFSCallBack()
 238 static int afs_deliver_fs_fetch_status(struct afs_call *call)  in afs_deliver_fs_fetch_status()  argument
 240 	struct afs_operation *op = call->op;  in afs_deliver_fs_fetch_status()
 245 	ret = afs_transfer_reply(call);  in afs_deliver_fs_fetch_status()
 [all …]
 
 | 
| /Linux-v6.6/include/trace/ | 
| D | trace_events.h | 8  * struct trace_event_raw_<call> {101  * struct trace_event_data_offsets_<call> {
 115 #define DECLARE_EVENT_CLASS(call, proto, args, tstruct, assign, print)	\  argument
 116 	struct trace_event_data_offsets_##call {			\
 141  * trace_raw_output_<call>(struct trace_iterator *iter, int flags)
 144  *	struct trace_event_raw_<call> *field; <-- defined in stage 1
 153  *	if (entry->type != event_<call>->event.type) {
 161  *	return trace_output_call(iter, <call>, <TP_printk> "\n");
 187 #define DECLARE_EVENT_CLASS(call, proto, args, tstruct, assign, print)	\  argument
 189 trace_raw_output_##call(struct trace_iterator *iter, int flags,		\
 [all …]
 
 | 
| D | trace_custom_events.h | 62 #define DECLARE_CUSTOM_EVENT_CLASS(call, proto, args, tstruct, assign, print)	\  argument63 	struct trace_custom_event_data_offsets_##call {			\
 77 #define DECLARE_CUSTOM_EVENT_CLASS(call, proto, args, tstruct, assign, print) \  argument
 79 trace_custom_raw_output_##call(struct trace_iterator *iter, int flags,	\
 84 	struct trace_custom_event_raw_##call *field;			\
 97 static struct trace_event_functions trace_custom_event_type_funcs_##call = { \
 98 	.trace			= trace_custom_raw_output_##call,	\
 108 #define DECLARE_CUSTOM_EVENT_CLASS(call, proto, args, tstruct, func, print)	\  argument
 109 static struct trace_event_fields trace_custom_event_fields_##call[] = {	\
 120 #define DECLARE_CUSTOM_EVENT_CLASS(call, proto, args, tstruct, assign, print) \  argument
 [all …]
 
 | 
| D | bpf_probe.h | 45 #define __BPF_DECLARE_TRACE(call, proto, args)				\  argument47 __bpf_trace_##call(void *__data, proto)					\
 54 #define DECLARE_EVENT_CLASS(call, proto, args, tstruct, assign, print)	\  argument
 55 	__BPF_DECLARE_TRACE(call, PARAMS(proto), PARAMS(args))
 62 #define __DEFINE_EVENT(template, call, proto, args, size)		\  argument
 63 static inline void bpf_test_probe_##call(void)				\
 65 	check_trace_callback_type_##call(__bpf_trace_##template);	\
 67 typedef void (*btf_trace_##call)(void *__data, proto);			\
 70 	btf_trace_##call handler;					\
 71 } __bpf_trace_tp_map_##call __used					\
 [all …]
 
 | 
| /Linux-v6.6/include/asm-generic/ | 
| D | syscall.h | 3  * Access to user system call parameters and results23  * syscall_get_nr - find what system call a task is executing
 27  * If @task is executing a system call or is at system call
 28  * tracing about to attempt one, returns the system call number.
 29  * If @task is not executing a system call, i.e. it's blocked
 33  * system call number can be meaningful.  If the actual arch value
 36  * It's only valid to call this when @task is known to be blocked.
 41  * syscall_rollback - roll back registers after an aborted system call
 42  * @task:	task of interest, must be in system call exit tracing
 45  * It's only valid to call this when @task is stopped for system
 [all …]
 
 | 
| /Linux-v6.6/include/trace/events/ | 
| D | rxrpc.h | 51 	EM(rxkad_abort_resp_call_ctr,		"rxkad-resp-call-ctr") \52 	EM(rxkad_abort_resp_call_state,		"rxkad-resp-call-state") \
 72 	EM(rxrpc_abort_call_improper_term,	"call-improper-term")	\
 73 	EM(rxrpc_abort_call_reset,		"call-reset")		\
 74 	EM(rxrpc_abort_call_sendmsg,		"call-sendmsg")		\
 75 	EM(rxrpc_abort_call_sock_release,	"call-sock-rel")	\
 76 	EM(rxrpc_abort_call_sock_release_tba,	"call-sock-rel-tba")	\
 77 	EM(rxrpc_abort_call_timeout,		"call-timeout")		\
 89 	EM(rxrpc_badmsg_zero_call,		"zero-call")		\
 101 	EM(rxrpc_eproto_no_client_call,		"no-cl-call")		\
 [all …]
 
 | 
| /Linux-v6.6/tools/ | 
| D | Makefile | 67 	$(call descend,power/$@)70 	$(call descend,power/$@)
 73 	$(call descend,$@)
 76 	$(call descend,$@)
 79 	$(call descend,lib/api)
 82 	$(call descend,include/nolibc)
 85 	$(call descend,include/nolibc,$(patsubst nolibc_%,%,$@))
 96 	$(call descend,testing/$@)
 99 	$(call descend,lib/$@)
 102 	$(call descend,power/x86/$@)
 [all …]
 
 | 
| /Linux-v6.6/Documentation/networking/ | 
| D | rxrpc.rst | 64  (3) Retention of the reusable bits of the transport system set up for one call122  (#) Each RxRPC operation is a "call".  A connection may make up to four
 147      explicitly sequenced per call.
 158  (#) An call is complete when the request has been sent, the reply has been
 162  (#) An call may be aborted by either end at any time up to its completion.
 182      the last call currently using it has completed in case a new call is made
 215      be used in all other sendmsgs or recvmsgs associated with that call.  The
 220      first sendmsg() of a call (struct msghdr::msg_name).
 226      first sendmsg() of the call must specify the target address.  The server's
 229  (#) Once the application has received the last message associated with a call,
 [all …]
 
 | 
| /Linux-v6.6/include/linux/firmware/intel/ | 
| D | stratix10-smc.h | 13  * This file defines the Secure Monitor Call (SMC) message protocol used for29  * FAST call executes atomic operations, returns when the requested operation
 31  * STD call starts a operation which can be preempted by a non-secure
 32  * interrupt. The call can return before the requested operation has
 51  * Return values in INTEL_SIP_SMC_* call
 81  * Sync call used by service driver at EL1 to request the FPGA in EL3 to
 84  * Call register usage:
 101  * Async call used by service driver at EL1 to provide FPGA configuration data
 104  * Call register usage:
 127  * Sync call used by service driver at EL1 to track the completed write
 [all …]
 
 | 
| /Linux-v6.6/tools/perf/util/ | 
| D | thread-stack.h | 3  * thread-stack.h: Synthesize a thread's stack using call / return events24  * Call/Return flags.
 26  * CALL_RETURN_NO_CALL: 'return' but no matching 'call'
 27  * CALL_RETURN_NO_RETURN: 'call' but no matching 'return'
 28  * CALL_RETURN_NON_CALL: a branch but not a 'call' to the start of a different
 38  * struct call_return - paired call/return information.
 39  * @thread: thread in which call/return occurred
 40  * @comm: comm in which call/return occurred
 41  * @cp: call path
 42  * @call_time: timestamp of call (if known)
 [all …]
 
 |