mirror of
git://git.kernel.org/pub/scm/linux/kernel/git/torvalds/linux.git
synced 2025-08-05 16:54:27 +00:00

Currently, rxrpc gives the connection's work item a ref on the connection when it queues it - and this is called from the timer expiration function. The problem comes when queue_work() fails (ie. the work item is already queued): the timer routine must put the ref - but this may cause the cleanup code to run. This has the unfortunate effect that the cleanup code may then be run in softirq context - which means that any spinlocks it might need to touch have to be guarded to disable softirqs (ie. they need a "_bh" suffix). (1) Don't give a ref to the work item. (2) Simplify handling of service connections by adding a separate active count so that the refcount isn't also used for this. (3) Connection destruction for both client and service connections can then be cleaned up by putting rxrpc_put_connection() out of line and making a tidy progression through the destruction code (offloaded to a workqueue if put from softirq or processor function context). The RCU part of the cleanup then only deals with the freeing at the end. (4) Make rxrpc_queue_conn() return immediately if it sees the active count is -1 rather then queuing the connection. (5) Make sure that the cleanup routine waits for the work item to complete. (6) Stash the rxrpc_net pointer in the conn struct so that the rcu free routine can use it, even if the local endpoint has been freed. Unfortunately, neither the timer nor the work item can simply get around the problem by just using refcount_inc_not_zero() as the waits would still have to be done, and there would still be the possibility of having to put the ref in the expiration function. Note the connection work item is mostly going to go away with the main event work being transferred to the I/O thread, so the wait in (6) will become obsolete. Signed-off-by: David Howells <dhowells@redhat.com> cc: Marc Dionne <marc.dionne@auristor.com> cc: linux-afs@lists.infradead.org
506 lines
13 KiB
C
506 lines
13 KiB
C
// SPDX-License-Identifier: GPL-2.0-or-later
|
|
/* RxRPC virtual connection handler, common bits.
|
|
*
|
|
* Copyright (C) 2007, 2016 Red Hat, Inc. All Rights Reserved.
|
|
* Written by David Howells (dhowells@redhat.com)
|
|
*/
|
|
|
|
#define pr_fmt(fmt) KBUILD_MODNAME ": " fmt
|
|
|
|
#include <linux/module.h>
|
|
#include <linux/slab.h>
|
|
#include <linux/net.h>
|
|
#include <linux/skbuff.h>
|
|
#include "ar-internal.h"
|
|
|
|
/*
|
|
* Time till a connection expires after last use (in seconds).
|
|
*/
|
|
unsigned int __read_mostly rxrpc_connection_expiry = 10 * 60;
|
|
unsigned int __read_mostly rxrpc_closed_conn_expiry = 10;
|
|
|
|
static void rxrpc_clean_up_connection(struct work_struct *work);
|
|
static void rxrpc_set_service_reap_timer(struct rxrpc_net *rxnet,
|
|
unsigned long reap_at);
|
|
|
|
static void rxrpc_connection_timer(struct timer_list *timer)
|
|
{
|
|
struct rxrpc_connection *conn =
|
|
container_of(timer, struct rxrpc_connection, timer);
|
|
|
|
rxrpc_queue_conn(conn, rxrpc_conn_queue_timer);
|
|
}
|
|
|
|
/*
|
|
* allocate a new connection
|
|
*/
|
|
struct rxrpc_connection *rxrpc_alloc_connection(struct rxrpc_net *rxnet,
|
|
gfp_t gfp)
|
|
{
|
|
struct rxrpc_connection *conn;
|
|
|
|
_enter("");
|
|
|
|
conn = kzalloc(sizeof(struct rxrpc_connection), gfp);
|
|
if (conn) {
|
|
INIT_LIST_HEAD(&conn->cache_link);
|
|
timer_setup(&conn->timer, &rxrpc_connection_timer, 0);
|
|
INIT_WORK(&conn->processor, rxrpc_process_connection);
|
|
INIT_WORK(&conn->destructor, rxrpc_clean_up_connection);
|
|
INIT_LIST_HEAD(&conn->proc_link);
|
|
INIT_LIST_HEAD(&conn->link);
|
|
skb_queue_head_init(&conn->rx_queue);
|
|
conn->rxnet = rxnet;
|
|
conn->security = &rxrpc_no_security;
|
|
spin_lock_init(&conn->state_lock);
|
|
conn->debug_id = atomic_inc_return(&rxrpc_debug_id);
|
|
conn->idle_timestamp = jiffies;
|
|
}
|
|
|
|
_leave(" = %p{%d}", conn, conn ? conn->debug_id : 0);
|
|
return conn;
|
|
}
|
|
|
|
/*
|
|
* Look up a connection in the cache by protocol parameters.
|
|
*
|
|
* If successful, a pointer to the connection is returned, but no ref is taken.
|
|
* NULL is returned if there is no match.
|
|
*
|
|
* When searching for a service call, if we find a peer but no connection, we
|
|
* return that through *_peer in case we need to create a new service call.
|
|
*
|
|
* The caller must be holding the RCU read lock.
|
|
*/
|
|
struct rxrpc_connection *rxrpc_find_connection_rcu(struct rxrpc_local *local,
|
|
struct sk_buff *skb,
|
|
struct rxrpc_peer **_peer)
|
|
{
|
|
struct rxrpc_connection *conn;
|
|
struct rxrpc_conn_proto k;
|
|
struct rxrpc_skb_priv *sp = rxrpc_skb(skb);
|
|
struct sockaddr_rxrpc srx;
|
|
struct rxrpc_peer *peer;
|
|
|
|
_enter(",%x", sp->hdr.cid & RXRPC_CIDMASK);
|
|
|
|
if (rxrpc_extract_addr_from_skb(&srx, skb) < 0)
|
|
goto not_found;
|
|
|
|
if (srx.transport.family != local->srx.transport.family &&
|
|
(srx.transport.family == AF_INET &&
|
|
local->srx.transport.family != AF_INET6)) {
|
|
pr_warn_ratelimited("AF_RXRPC: Protocol mismatch %u not %u\n",
|
|
srx.transport.family,
|
|
local->srx.transport.family);
|
|
goto not_found;
|
|
}
|
|
|
|
k.epoch = sp->hdr.epoch;
|
|
k.cid = sp->hdr.cid & RXRPC_CIDMASK;
|
|
|
|
if (rxrpc_to_server(sp)) {
|
|
/* We need to look up service connections by the full protocol
|
|
* parameter set. We look up the peer first as an intermediate
|
|
* step and then the connection from the peer's tree.
|
|
*/
|
|
peer = rxrpc_lookup_peer_rcu(local, &srx);
|
|
if (!peer)
|
|
goto not_found;
|
|
*_peer = peer;
|
|
conn = rxrpc_find_service_conn_rcu(peer, skb);
|
|
if (!conn || refcount_read(&conn->ref) == 0)
|
|
goto not_found;
|
|
_leave(" = %p", conn);
|
|
return conn;
|
|
} else {
|
|
/* Look up client connections by connection ID alone as their
|
|
* IDs are unique for this machine.
|
|
*/
|
|
conn = idr_find(&rxrpc_client_conn_ids,
|
|
sp->hdr.cid >> RXRPC_CIDSHIFT);
|
|
if (!conn || refcount_read(&conn->ref) == 0) {
|
|
_debug("no conn");
|
|
goto not_found;
|
|
}
|
|
|
|
if (conn->proto.epoch != k.epoch ||
|
|
conn->local != local)
|
|
goto not_found;
|
|
|
|
peer = conn->peer;
|
|
switch (srx.transport.family) {
|
|
case AF_INET:
|
|
if (peer->srx.transport.sin.sin_port !=
|
|
srx.transport.sin.sin_port ||
|
|
peer->srx.transport.sin.sin_addr.s_addr !=
|
|
srx.transport.sin.sin_addr.s_addr)
|
|
goto not_found;
|
|
break;
|
|
#ifdef CONFIG_AF_RXRPC_IPV6
|
|
case AF_INET6:
|
|
if (peer->srx.transport.sin6.sin6_port !=
|
|
srx.transport.sin6.sin6_port ||
|
|
memcmp(&peer->srx.transport.sin6.sin6_addr,
|
|
&srx.transport.sin6.sin6_addr,
|
|
sizeof(struct in6_addr)) != 0)
|
|
goto not_found;
|
|
break;
|
|
#endif
|
|
default:
|
|
BUG();
|
|
}
|
|
|
|
_leave(" = %p", conn);
|
|
return conn;
|
|
}
|
|
|
|
not_found:
|
|
_leave(" = NULL");
|
|
return NULL;
|
|
}
|
|
|
|
/*
|
|
* Disconnect a call and clear any channel it occupies when that call
|
|
* terminates. The caller must hold the channel_lock and must release the
|
|
* call's ref on the connection.
|
|
*/
|
|
void __rxrpc_disconnect_call(struct rxrpc_connection *conn,
|
|
struct rxrpc_call *call)
|
|
{
|
|
struct rxrpc_channel *chan =
|
|
&conn->channels[call->cid & RXRPC_CHANNELMASK];
|
|
|
|
_enter("%d,%x", conn->debug_id, call->cid);
|
|
|
|
if (rcu_access_pointer(chan->call) == call) {
|
|
/* Save the result of the call so that we can repeat it if necessary
|
|
* through the channel, whilst disposing of the actual call record.
|
|
*/
|
|
trace_rxrpc_disconnect_call(call);
|
|
switch (call->completion) {
|
|
case RXRPC_CALL_SUCCEEDED:
|
|
chan->last_seq = call->rx_highest_seq;
|
|
chan->last_type = RXRPC_PACKET_TYPE_ACK;
|
|
break;
|
|
case RXRPC_CALL_LOCALLY_ABORTED:
|
|
chan->last_abort = call->abort_code;
|
|
chan->last_type = RXRPC_PACKET_TYPE_ABORT;
|
|
break;
|
|
default:
|
|
chan->last_abort = RX_CALL_DEAD;
|
|
chan->last_type = RXRPC_PACKET_TYPE_ABORT;
|
|
break;
|
|
}
|
|
|
|
/* Sync with rxrpc_conn_retransmit(). */
|
|
smp_wmb();
|
|
chan->last_call = chan->call_id;
|
|
chan->call_id = chan->call_counter;
|
|
|
|
rcu_assign_pointer(chan->call, NULL);
|
|
}
|
|
|
|
_leave("");
|
|
}
|
|
|
|
/*
|
|
* Disconnect a call and clear any channel it occupies when that call
|
|
* terminates.
|
|
*/
|
|
void rxrpc_disconnect_call(struct rxrpc_call *call)
|
|
{
|
|
struct rxrpc_connection *conn = call->conn;
|
|
|
|
call->peer->cong_ssthresh = call->cong_ssthresh;
|
|
|
|
if (!hlist_unhashed(&call->error_link)) {
|
|
spin_lock_bh(&call->peer->lock);
|
|
hlist_del_rcu(&call->error_link);
|
|
spin_unlock_bh(&call->peer->lock);
|
|
}
|
|
|
|
if (rxrpc_is_client_call(call))
|
|
return rxrpc_disconnect_client_call(conn->bundle, call);
|
|
|
|
spin_lock(&conn->bundle->channel_lock);
|
|
__rxrpc_disconnect_call(conn, call);
|
|
spin_unlock(&conn->bundle->channel_lock);
|
|
|
|
set_bit(RXRPC_CALL_DISCONNECTED, &call->flags);
|
|
conn->idle_timestamp = jiffies;
|
|
if (atomic_dec_and_test(&conn->active))
|
|
rxrpc_set_service_reap_timer(conn->rxnet,
|
|
jiffies + rxrpc_connection_expiry);
|
|
}
|
|
|
|
/*
|
|
* Queue a connection's work processor, getting a ref to pass to the work
|
|
* queue.
|
|
*/
|
|
void rxrpc_queue_conn(struct rxrpc_connection *conn, enum rxrpc_conn_trace why)
|
|
{
|
|
if (atomic_read(&conn->active) >= 0 &&
|
|
rxrpc_queue_work(&conn->processor))
|
|
rxrpc_see_connection(conn, why);
|
|
}
|
|
|
|
/*
|
|
* Note the re-emergence of a connection.
|
|
*/
|
|
void rxrpc_see_connection(struct rxrpc_connection *conn,
|
|
enum rxrpc_conn_trace why)
|
|
{
|
|
if (conn) {
|
|
int r = refcount_read(&conn->ref);
|
|
|
|
trace_rxrpc_conn(conn->debug_id, r, why);
|
|
}
|
|
}
|
|
|
|
/*
|
|
* Get a ref on a connection.
|
|
*/
|
|
struct rxrpc_connection *rxrpc_get_connection(struct rxrpc_connection *conn,
|
|
enum rxrpc_conn_trace why)
|
|
{
|
|
int r;
|
|
|
|
__refcount_inc(&conn->ref, &r);
|
|
trace_rxrpc_conn(conn->debug_id, r + 1, why);
|
|
return conn;
|
|
}
|
|
|
|
/*
|
|
* Try to get a ref on a connection.
|
|
*/
|
|
struct rxrpc_connection *
|
|
rxrpc_get_connection_maybe(struct rxrpc_connection *conn,
|
|
enum rxrpc_conn_trace why)
|
|
{
|
|
int r;
|
|
|
|
if (conn) {
|
|
if (__refcount_inc_not_zero(&conn->ref, &r))
|
|
trace_rxrpc_conn(conn->debug_id, r + 1, why);
|
|
else
|
|
conn = NULL;
|
|
}
|
|
return conn;
|
|
}
|
|
|
|
/*
|
|
* Set the service connection reap timer.
|
|
*/
|
|
static void rxrpc_set_service_reap_timer(struct rxrpc_net *rxnet,
|
|
unsigned long reap_at)
|
|
{
|
|
if (rxnet->live)
|
|
timer_reduce(&rxnet->service_conn_reap_timer, reap_at);
|
|
}
|
|
|
|
/*
|
|
* destroy a virtual connection
|
|
*/
|
|
static void rxrpc_rcu_free_connection(struct rcu_head *rcu)
|
|
{
|
|
struct rxrpc_connection *conn =
|
|
container_of(rcu, struct rxrpc_connection, rcu);
|
|
struct rxrpc_net *rxnet = conn->rxnet;
|
|
|
|
_enter("{%d,u=%d}", conn->debug_id, refcount_read(&conn->ref));
|
|
|
|
trace_rxrpc_conn(conn->debug_id, refcount_read(&conn->ref),
|
|
rxrpc_conn_free);
|
|
kfree(conn);
|
|
|
|
if (atomic_dec_and_test(&rxnet->nr_conns))
|
|
wake_up_var(&rxnet->nr_conns);
|
|
}
|
|
|
|
/*
|
|
* Clean up a dead connection.
|
|
*/
|
|
static void rxrpc_clean_up_connection(struct work_struct *work)
|
|
{
|
|
struct rxrpc_connection *conn =
|
|
container_of(work, struct rxrpc_connection, destructor);
|
|
struct rxrpc_net *rxnet = conn->rxnet;
|
|
|
|
ASSERT(!rcu_access_pointer(conn->channels[0].call) &&
|
|
!rcu_access_pointer(conn->channels[1].call) &&
|
|
!rcu_access_pointer(conn->channels[2].call) &&
|
|
!rcu_access_pointer(conn->channels[3].call));
|
|
ASSERT(list_empty(&conn->cache_link));
|
|
|
|
del_timer_sync(&conn->timer);
|
|
cancel_work_sync(&conn->processor); /* Processing may restart the timer */
|
|
del_timer_sync(&conn->timer);
|
|
|
|
write_lock(&rxnet->conn_lock);
|
|
list_del_init(&conn->proc_link);
|
|
write_unlock(&rxnet->conn_lock);
|
|
|
|
rxrpc_purge_queue(&conn->rx_queue);
|
|
|
|
rxrpc_kill_client_conn(conn);
|
|
|
|
conn->security->clear(conn);
|
|
key_put(conn->key);
|
|
rxrpc_put_bundle(conn->bundle, rxrpc_bundle_put_conn);
|
|
rxrpc_put_peer(conn->peer, rxrpc_peer_put_conn);
|
|
rxrpc_put_local(conn->local, rxrpc_local_put_kill_conn);
|
|
|
|
/* Drain the Rx queue. Note that even though we've unpublished, an
|
|
* incoming packet could still be being added to our Rx queue, so we
|
|
* will need to drain it again in the RCU cleanup handler.
|
|
*/
|
|
rxrpc_purge_queue(&conn->rx_queue);
|
|
|
|
call_rcu(&conn->rcu, rxrpc_rcu_free_connection);
|
|
}
|
|
|
|
/*
|
|
* Drop a ref on a connection.
|
|
*/
|
|
void rxrpc_put_connection(struct rxrpc_connection *conn,
|
|
enum rxrpc_conn_trace why)
|
|
{
|
|
unsigned int debug_id;
|
|
bool dead;
|
|
int r;
|
|
|
|
if (!conn)
|
|
return;
|
|
|
|
debug_id = conn->debug_id;
|
|
dead = __refcount_dec_and_test(&conn->ref, &r);
|
|
trace_rxrpc_conn(debug_id, r - 1, why);
|
|
if (dead) {
|
|
del_timer(&conn->timer);
|
|
cancel_work(&conn->processor);
|
|
|
|
if (in_softirq() || work_busy(&conn->processor) ||
|
|
timer_pending(&conn->timer))
|
|
/* Can't use the rxrpc workqueue as we need to cancel/flush
|
|
* something that may be running/waiting there.
|
|
*/
|
|
schedule_work(&conn->destructor);
|
|
else
|
|
rxrpc_clean_up_connection(&conn->destructor);
|
|
}
|
|
}
|
|
|
|
/*
|
|
* reap dead service connections
|
|
*/
|
|
void rxrpc_service_connection_reaper(struct work_struct *work)
|
|
{
|
|
struct rxrpc_connection *conn, *_p;
|
|
struct rxrpc_net *rxnet =
|
|
container_of(work, struct rxrpc_net, service_conn_reaper);
|
|
unsigned long expire_at, earliest, idle_timestamp, now;
|
|
int active;
|
|
|
|
LIST_HEAD(graveyard);
|
|
|
|
_enter("");
|
|
|
|
now = jiffies;
|
|
earliest = now + MAX_JIFFY_OFFSET;
|
|
|
|
write_lock(&rxnet->conn_lock);
|
|
list_for_each_entry_safe(conn, _p, &rxnet->service_conns, link) {
|
|
ASSERTCMP(atomic_read(&conn->active), >=, 0);
|
|
if (likely(atomic_read(&conn->active) > 0))
|
|
continue;
|
|
if (conn->state == RXRPC_CONN_SERVICE_PREALLOC)
|
|
continue;
|
|
|
|
if (rxnet->live && !conn->local->dead) {
|
|
idle_timestamp = READ_ONCE(conn->idle_timestamp);
|
|
expire_at = idle_timestamp + rxrpc_connection_expiry * HZ;
|
|
if (conn->local->service_closed)
|
|
expire_at = idle_timestamp + rxrpc_closed_conn_expiry * HZ;
|
|
|
|
_debug("reap CONN %d { a=%d,t=%ld }",
|
|
conn->debug_id, atomic_read(&conn->active),
|
|
(long)expire_at - (long)now);
|
|
|
|
if (time_before(now, expire_at)) {
|
|
if (time_before(expire_at, earliest))
|
|
earliest = expire_at;
|
|
continue;
|
|
}
|
|
}
|
|
|
|
/* The activity count sits at 0 whilst the conn is unused on
|
|
* the list; we reduce that to -1 to make the conn unavailable.
|
|
*/
|
|
active = 0;
|
|
if (!atomic_try_cmpxchg(&conn->active, &active, -1))
|
|
continue;
|
|
rxrpc_see_connection(conn, rxrpc_conn_see_reap_service);
|
|
|
|
if (rxrpc_conn_is_client(conn))
|
|
BUG();
|
|
else
|
|
rxrpc_unpublish_service_conn(conn);
|
|
|
|
list_move_tail(&conn->link, &graveyard);
|
|
}
|
|
write_unlock(&rxnet->conn_lock);
|
|
|
|
if (earliest != now + MAX_JIFFY_OFFSET) {
|
|
_debug("reschedule reaper %ld", (long)earliest - (long)now);
|
|
ASSERT(time_after(earliest, now));
|
|
rxrpc_set_service_reap_timer(rxnet, earliest);
|
|
}
|
|
|
|
while (!list_empty(&graveyard)) {
|
|
conn = list_entry(graveyard.next, struct rxrpc_connection,
|
|
link);
|
|
list_del_init(&conn->link);
|
|
|
|
ASSERTCMP(atomic_read(&conn->active), ==, -1);
|
|
rxrpc_put_connection(conn, rxrpc_conn_put_service_reaped);
|
|
}
|
|
|
|
_leave("");
|
|
}
|
|
|
|
/*
|
|
* preemptively destroy all the service connection records rather than
|
|
* waiting for them to time out
|
|
*/
|
|
void rxrpc_destroy_all_connections(struct rxrpc_net *rxnet)
|
|
{
|
|
struct rxrpc_connection *conn, *_p;
|
|
bool leak = false;
|
|
|
|
_enter("");
|
|
|
|
atomic_dec(&rxnet->nr_conns);
|
|
rxrpc_destroy_all_client_connections(rxnet);
|
|
|
|
del_timer_sync(&rxnet->service_conn_reap_timer);
|
|
rxrpc_queue_work(&rxnet->service_conn_reaper);
|
|
flush_workqueue(rxrpc_workqueue);
|
|
|
|
write_lock(&rxnet->conn_lock);
|
|
list_for_each_entry_safe(conn, _p, &rxnet->service_conns, link) {
|
|
pr_err("AF_RXRPC: Leaked conn %p {%d}\n",
|
|
conn, refcount_read(&conn->ref));
|
|
leak = true;
|
|
}
|
|
write_unlock(&rxnet->conn_lock);
|
|
BUG_ON(leak);
|
|
|
|
ASSERT(list_empty(&rxnet->conn_proc_list));
|
|
|
|
/* We need to wait for the connections to be destroyed by RCU as they
|
|
* pin things that we still need to get rid of.
|
|
*/
|
|
wait_var_event(&rxnet->nr_conns, !atomic_read(&rxnet->nr_conns));
|
|
_leave("");
|
|
}
|