1 // SPDX-License-Identifier: GPL-2.0-only
2 /******************************************************************************
3 *******************************************************************************
5 ** Copyright (C) Sistina Software, Inc. 1997-2003 All rights reserved.
6 ** Copyright (C) 2004-2009 Red Hat, Inc. All rights reserved.
9 *******************************************************************************
10 ******************************************************************************/
15 * This is the "low-level" comms layer.
17 * It is responsible for sending/receiving messages
18 * from other nodes in the cluster.
20 * Cluster nodes are referred to by their nodeids. nodeids are
21 * simply 32 bit numbers to the locking module - if they need to
22 * be expanded for the cluster infrastructure then that is its
23 * responsibility. It is this layer's
24 * responsibility to resolve these into IP address or
25 * whatever it needs for inter-node communication.
27 * The comms level is two kernel threads that deal mainly with
28 * the receiving of messages from other nodes and passing them
29 * up to the mid-level comms layer (which understands the
30 * message format) for execution by the locking core, and
31 * a send thread which does all the setting up of connections
32 * to remote nodes and the sending of data. Threads are not allowed
33 * to send their own data because it may cause them to wait in times
34 * of high load. Also, this way, the sending thread can collect together
35 * messages bound for one node and send them in one block.
37 * lowcomms will choose to use either TCP or SCTP as its transport layer
38 * depending on the configuration variable 'protocol'. This should be set
39 * to 0 (default) for TCP or 1 for SCTP. It should be configured using a
40 * cluster-wide mechanism as it must be the same on all nodes of the cluster
41 * for the DLM to function.
45 #include <asm/ioctls.h>
48 #include <linux/pagemap.h>
49 #include <linux/file.h>
50 #include <linux/mutex.h>
51 #include <linux/sctp.h>
52 #include <linux/slab.h>
53 #include <net/sctp/sctp.h>
56 #include <trace/events/dlm.h>
58 #include "dlm_internal.h"
64 #define NEEDED_RMEM (4*1024*1024)
66 /* Number of messages to send before rescheduling */
67 #define MAX_SEND_MSG_COUNT 25
68 #define DLM_SHUTDOWN_WAIT_TIMEOUT msecs_to_jiffies(10000)
71 struct socket *sock; /* NULL if not connected */
72 uint32_t nodeid; /* So we know who we are in the list */
73 struct mutex sock_mutex;
75 #define CF_READ_PENDING 1
76 #define CF_WRITE_PENDING 2
77 #define CF_INIT_PENDING 4
78 #define CF_IS_OTHERCON 5
80 #define CF_APP_LIMITED 7
83 #define CF_CONNECTED 10
84 #define CF_RECONNECT 11
85 #define CF_DELAY_CONNECT 12
87 struct list_head writequeue; /* List of outgoing writequeue_entries */
88 spinlock_t writequeue_lock;
89 atomic_t writequeue_cnt;
91 #define MAX_CONNECT_RETRIES 3
92 struct hlist_node list;
93 struct connection *othercon;
94 struct connection *sendcon;
95 struct work_struct rwork; /* Receive workqueue */
96 struct work_struct swork; /* Send workqueue */
97 wait_queue_head_t shutdown_wait; /* wait for graceful shutdown */
98 unsigned char *rx_buf;
103 #define sock2con(x) ((struct connection *)(x)->sk_user_data)
105 struct listen_connection {
107 struct work_struct rwork;
110 #define DLM_WQ_REMAIN_BYTES(e) (PAGE_SIZE - e->end)
111 #define DLM_WQ_LENGTH_BYTES(e) (e->end - e->offset)
113 /* An entry waiting to be sent */
114 struct writequeue_entry {
115 struct list_head list;
122 struct connection *con;
123 struct list_head msgs;
128 struct writequeue_entry *entry;
129 struct dlm_msg *orig_msg;
133 int idx; /* new()/commit() idx exchange */
135 struct list_head list;
139 struct dlm_node_addr {
140 struct list_head list;
145 struct sockaddr_storage *addr[DLM_MAX_ADDR_COUNT];
148 struct dlm_proto_ops {
153 int (*connect)(struct connection *con, struct socket *sock,
154 struct sockaddr *addr, int addr_len);
155 void (*sockopts)(struct socket *sock);
156 int (*bind)(struct socket *sock);
157 int (*listen_validate)(void);
158 void (*listen_sockopts)(struct socket *sock);
159 int (*listen_bind)(struct socket *sock);
160 /* What to do to shutdown */
161 void (*shutdown_action)(struct connection *con);
162 /* What to do to eof check */
163 bool (*eof_condition)(struct connection *con);
166 static struct listen_sock_callbacks {
167 void (*sk_error_report)(struct sock *);
168 void (*sk_data_ready)(struct sock *);
169 void (*sk_state_change)(struct sock *);
170 void (*sk_write_space)(struct sock *);
173 static LIST_HEAD(dlm_node_addrs);
174 static DEFINE_SPINLOCK(dlm_node_addrs_spin);
176 static struct listen_connection listen_con;
177 static struct sockaddr_storage *dlm_local_addr[DLM_MAX_ADDR_COUNT];
178 static int dlm_local_count;
182 static struct workqueue_struct *recv_workqueue;
183 static struct workqueue_struct *send_workqueue;
185 static struct hlist_head connection_hash[CONN_HASH_SIZE];
186 static DEFINE_SPINLOCK(connections_lock);
187 DEFINE_STATIC_SRCU(connections_srcu);
189 static const struct dlm_proto_ops *dlm_proto_ops;
191 static void process_recv_sockets(struct work_struct *work);
192 static void process_send_sockets(struct work_struct *work);
194 static void writequeue_entry_ctor(void *data)
196 struct writequeue_entry *entry = data;
198 INIT_LIST_HEAD(&entry->msgs);
201 struct kmem_cache *dlm_lowcomms_writequeue_cache_create(void)
203 return kmem_cache_create("dlm_writequeue", sizeof(struct writequeue_entry),
204 0, 0, writequeue_entry_ctor);
207 struct kmem_cache *dlm_lowcomms_msg_cache_create(void)
209 return kmem_cache_create("dlm_msg", sizeof(struct dlm_msg), 0, 0, NULL);
212 /* need to held writequeue_lock */
213 static struct writequeue_entry *con_next_wq(struct connection *con)
215 struct writequeue_entry *e;
217 if (list_empty(&con->writequeue))
220 e = list_first_entry(&con->writequeue, struct writequeue_entry,
222 /* if len is zero nothing is to send, if there are users filling
223 * buffers we wait until the users are done so we can send more.
225 if (e->users || e->len == 0)
231 static struct connection *__find_con(int nodeid, int r)
233 struct connection *con;
235 hlist_for_each_entry_rcu(con, &connection_hash[r], list) {
236 if (con->nodeid == nodeid)
243 static bool tcp_eof_condition(struct connection *con)
245 return atomic_read(&con->writequeue_cnt);
248 static int dlm_con_init(struct connection *con, int nodeid)
250 con->rx_buflen = dlm_config.ci_buffer_size;
251 con->rx_buf = kmalloc(con->rx_buflen, GFP_NOFS);
255 con->nodeid = nodeid;
256 mutex_init(&con->sock_mutex);
257 INIT_LIST_HEAD(&con->writequeue);
258 spin_lock_init(&con->writequeue_lock);
259 atomic_set(&con->writequeue_cnt, 0);
260 INIT_WORK(&con->swork, process_send_sockets);
261 INIT_WORK(&con->rwork, process_recv_sockets);
262 init_waitqueue_head(&con->shutdown_wait);
268 * If 'allocation' is zero then we don't attempt to create a new
269 * connection structure for this node.
271 static struct connection *nodeid2con(int nodeid, gfp_t alloc)
273 struct connection *con, *tmp;
276 r = nodeid_hash(nodeid);
277 con = __find_con(nodeid, r);
281 con = kzalloc(sizeof(*con), alloc);
285 ret = dlm_con_init(con, nodeid);
291 spin_lock(&connections_lock);
292 /* Because multiple workqueues/threads calls this function it can
293 * race on multiple cpu's. Instead of locking hot path __find_con()
294 * we just check in rare cases of recently added nodes again
295 * under protection of connections_lock. If this is the case we
296 * abort our connection creation and return the existing connection.
298 tmp = __find_con(nodeid, r);
300 spin_unlock(&connections_lock);
306 hlist_add_head_rcu(&con->list, &connection_hash[r]);
307 spin_unlock(&connections_lock);
312 /* Loop round all connections */
313 static void foreach_conn(void (*conn_func)(struct connection *c))
316 struct connection *con;
318 for (i = 0; i < CONN_HASH_SIZE; i++) {
319 hlist_for_each_entry_rcu(con, &connection_hash[i], list)
324 static struct dlm_node_addr *find_node_addr(int nodeid)
326 struct dlm_node_addr *na;
328 list_for_each_entry(na, &dlm_node_addrs, list) {
329 if (na->nodeid == nodeid)
335 static int addr_compare(const struct sockaddr_storage *x,
336 const struct sockaddr_storage *y)
338 switch (x->ss_family) {
340 struct sockaddr_in *sinx = (struct sockaddr_in *)x;
341 struct sockaddr_in *siny = (struct sockaddr_in *)y;
342 if (sinx->sin_addr.s_addr != siny->sin_addr.s_addr)
344 if (sinx->sin_port != siny->sin_port)
349 struct sockaddr_in6 *sinx = (struct sockaddr_in6 *)x;
350 struct sockaddr_in6 *siny = (struct sockaddr_in6 *)y;
351 if (!ipv6_addr_equal(&sinx->sin6_addr, &siny->sin6_addr))
353 if (sinx->sin6_port != siny->sin6_port)
363 static int nodeid_to_addr(int nodeid, struct sockaddr_storage *sas_out,
364 struct sockaddr *sa_out, bool try_new_addr,
367 struct sockaddr_storage sas;
368 struct dlm_node_addr *na;
370 if (!dlm_local_count)
373 spin_lock(&dlm_node_addrs_spin);
374 na = find_node_addr(nodeid);
375 if (na && na->addr_count) {
376 memcpy(&sas, na->addr[na->curr_addr_index],
377 sizeof(struct sockaddr_storage));
380 na->curr_addr_index++;
381 if (na->curr_addr_index == na->addr_count)
382 na->curr_addr_index = 0;
385 spin_unlock(&dlm_node_addrs_spin);
396 memcpy(sas_out, &sas, sizeof(struct sockaddr_storage));
401 if (dlm_local_addr[0]->ss_family == AF_INET) {
402 struct sockaddr_in *in4 = (struct sockaddr_in *) &sas;
403 struct sockaddr_in *ret4 = (struct sockaddr_in *) sa_out;
404 ret4->sin_addr.s_addr = in4->sin_addr.s_addr;
406 struct sockaddr_in6 *in6 = (struct sockaddr_in6 *) &sas;
407 struct sockaddr_in6 *ret6 = (struct sockaddr_in6 *) sa_out;
408 ret6->sin6_addr = in6->sin6_addr;
414 static int addr_to_nodeid(struct sockaddr_storage *addr, int *nodeid,
417 struct dlm_node_addr *na;
421 spin_lock(&dlm_node_addrs_spin);
422 list_for_each_entry(na, &dlm_node_addrs, list) {
426 for (addr_i = 0; addr_i < na->addr_count; addr_i++) {
427 if (addr_compare(na->addr[addr_i], addr)) {
428 *nodeid = na->nodeid;
436 spin_unlock(&dlm_node_addrs_spin);
440 /* caller need to held dlm_node_addrs_spin lock */
441 static bool dlm_lowcomms_na_has_addr(const struct dlm_node_addr *na,
442 const struct sockaddr_storage *addr)
446 for (i = 0; i < na->addr_count; i++) {
447 if (addr_compare(na->addr[i], addr))
454 int dlm_lowcomms_addr(int nodeid, struct sockaddr_storage *addr, int len)
456 struct sockaddr_storage *new_addr;
457 struct dlm_node_addr *new_node, *na;
460 new_node = kzalloc(sizeof(struct dlm_node_addr), GFP_NOFS);
464 new_addr = kzalloc(sizeof(struct sockaddr_storage), GFP_NOFS);
470 memcpy(new_addr, addr, len);
472 spin_lock(&dlm_node_addrs_spin);
473 na = find_node_addr(nodeid);
475 new_node->nodeid = nodeid;
476 new_node->addr[0] = new_addr;
477 new_node->addr_count = 1;
478 new_node->mark = dlm_config.ci_mark;
479 list_add(&new_node->list, &dlm_node_addrs);
480 spin_unlock(&dlm_node_addrs_spin);
484 ret = dlm_lowcomms_na_has_addr(na, addr);
486 spin_unlock(&dlm_node_addrs_spin);
492 if (na->addr_count >= DLM_MAX_ADDR_COUNT) {
493 spin_unlock(&dlm_node_addrs_spin);
499 na->addr[na->addr_count++] = new_addr;
500 spin_unlock(&dlm_node_addrs_spin);
505 /* Data available on socket or listen socket received a connect */
506 static void lowcomms_data_ready(struct sock *sk)
508 struct connection *con;
511 if (con && !test_and_set_bit(CF_READ_PENDING, &con->flags))
512 queue_work(recv_workqueue, &con->rwork);
515 static void lowcomms_listen_data_ready(struct sock *sk)
520 queue_work(recv_workqueue, &listen_con.rwork);
523 static void lowcomms_write_space(struct sock *sk)
525 struct connection *con;
531 if (!test_and_set_bit(CF_CONNECTED, &con->flags)) {
532 log_print("connected to node %d", con->nodeid);
533 queue_work(send_workqueue, &con->swork);
537 clear_bit(SOCK_NOSPACE, &con->sock->flags);
539 if (test_and_clear_bit(CF_APP_LIMITED, &con->flags)) {
540 con->sock->sk->sk_write_pending--;
541 clear_bit(SOCKWQ_ASYNC_NOSPACE, &con->sock->flags);
544 queue_work(send_workqueue, &con->swork);
547 static inline void lowcomms_connect_sock(struct connection *con)
549 if (test_bit(CF_CLOSE, &con->flags))
551 queue_work(send_workqueue, &con->swork);
555 static void lowcomms_state_change(struct sock *sk)
557 /* SCTP layer is not calling sk_data_ready when the connection
558 * is done, so we catch the signal through here. Also, it
559 * doesn't switch socket state when entering shutdown, so we
560 * skip the write in that case.
562 if (sk->sk_shutdown) {
563 if (sk->sk_shutdown == RCV_SHUTDOWN)
564 lowcomms_data_ready(sk);
565 } else if (sk->sk_state == TCP_ESTABLISHED) {
566 lowcomms_write_space(sk);
570 int dlm_lowcomms_connect_node(int nodeid)
572 struct connection *con;
575 if (nodeid == dlm_our_nodeid())
578 idx = srcu_read_lock(&connections_srcu);
579 con = nodeid2con(nodeid, GFP_NOFS);
581 srcu_read_unlock(&connections_srcu, idx);
585 lowcomms_connect_sock(con);
586 srcu_read_unlock(&connections_srcu, idx);
591 int dlm_lowcomms_nodes_set_mark(int nodeid, unsigned int mark)
593 struct dlm_node_addr *na;
595 spin_lock(&dlm_node_addrs_spin);
596 na = find_node_addr(nodeid);
598 spin_unlock(&dlm_node_addrs_spin);
603 spin_unlock(&dlm_node_addrs_spin);
608 static void lowcomms_error_report(struct sock *sk)
610 struct connection *con;
611 void (*orig_report)(struct sock *) = NULL;
612 struct inet_sock *inet;
618 orig_report = listen_sock.sk_error_report;
621 switch (sk->sk_family) {
623 printk_ratelimited(KERN_ERR "dlm: node %d: socket error "
624 "sending to node %d at %pI4, dport %d, "
625 "sk_err=%d/%d\n", dlm_our_nodeid(),
626 con->nodeid, &inet->inet_daddr,
627 ntohs(inet->inet_dport), sk->sk_err,
630 #if IS_ENABLED(CONFIG_IPV6)
632 printk_ratelimited(KERN_ERR "dlm: node %d: socket error "
633 "sending to node %d at %pI6c, "
634 "dport %d, sk_err=%d/%d\n", dlm_our_nodeid(),
635 con->nodeid, &sk->sk_v6_daddr,
636 ntohs(inet->inet_dport), sk->sk_err,
641 printk_ratelimited(KERN_ERR "dlm: node %d: socket error "
642 "invalid socket family %d set, "
643 "sk_err=%d/%d\n", dlm_our_nodeid(),
644 sk->sk_family, sk->sk_err, sk->sk_err_soft);
648 /* below sendcon only handling */
649 if (test_bit(CF_IS_OTHERCON, &con->flags))
652 switch (sk->sk_err) {
654 set_bit(CF_DELAY_CONNECT, &con->flags);
660 if (!test_and_set_bit(CF_RECONNECT, &con->flags))
661 queue_work(send_workqueue, &con->swork);
668 /* Note: sk_callback_lock must be locked before calling this function. */
669 static void save_listen_callbacks(struct socket *sock)
671 struct sock *sk = sock->sk;
673 listen_sock.sk_data_ready = sk->sk_data_ready;
674 listen_sock.sk_state_change = sk->sk_state_change;
675 listen_sock.sk_write_space = sk->sk_write_space;
676 listen_sock.sk_error_report = sk->sk_error_report;
679 static void restore_callbacks(struct socket *sock)
681 struct sock *sk = sock->sk;
684 sk->sk_user_data = NULL;
685 sk->sk_data_ready = listen_sock.sk_data_ready;
686 sk->sk_state_change = listen_sock.sk_state_change;
687 sk->sk_write_space = listen_sock.sk_write_space;
688 sk->sk_error_report = listen_sock.sk_error_report;
692 static void add_listen_sock(struct socket *sock, struct listen_connection *con)
694 struct sock *sk = sock->sk;
697 save_listen_callbacks(sock);
700 sk->sk_user_data = con;
701 sk->sk_allocation = GFP_NOFS;
702 /* Install a data_ready callback */
703 sk->sk_data_ready = lowcomms_listen_data_ready;
707 /* Make a socket active */
708 static void add_sock(struct socket *sock, struct connection *con)
710 struct sock *sk = sock->sk;
715 sk->sk_user_data = con;
716 /* Install a data_ready callback */
717 sk->sk_data_ready = lowcomms_data_ready;
718 sk->sk_write_space = lowcomms_write_space;
719 sk->sk_state_change = lowcomms_state_change;
720 sk->sk_allocation = GFP_NOFS;
721 sk->sk_error_report = lowcomms_error_report;
725 /* Add the port number to an IPv6 or 4 sockaddr and return the address
727 static void make_sockaddr(struct sockaddr_storage *saddr, uint16_t port,
730 saddr->ss_family = dlm_local_addr[0]->ss_family;
731 if (saddr->ss_family == AF_INET) {
732 struct sockaddr_in *in4_addr = (struct sockaddr_in *)saddr;
733 in4_addr->sin_port = cpu_to_be16(port);
734 *addr_len = sizeof(struct sockaddr_in);
735 memset(&in4_addr->sin_zero, 0, sizeof(in4_addr->sin_zero));
737 struct sockaddr_in6 *in6_addr = (struct sockaddr_in6 *)saddr;
738 in6_addr->sin6_port = cpu_to_be16(port);
739 *addr_len = sizeof(struct sockaddr_in6);
741 memset((char *)saddr + *addr_len, 0, sizeof(struct sockaddr_storage) - *addr_len);
744 static void dlm_page_release(struct kref *kref)
746 struct writequeue_entry *e = container_of(kref, struct writequeue_entry,
749 __free_page(e->page);
750 dlm_free_writequeue(e);
753 static void dlm_msg_release(struct kref *kref)
755 struct dlm_msg *msg = container_of(kref, struct dlm_msg, ref);
757 kref_put(&msg->entry->ref, dlm_page_release);
761 static void free_entry(struct writequeue_entry *e)
763 struct dlm_msg *msg, *tmp;
765 list_for_each_entry_safe(msg, tmp, &e->msgs, list) {
767 msg->orig_msg->retransmit = false;
768 kref_put(&msg->orig_msg->ref, dlm_msg_release);
771 list_del(&msg->list);
772 kref_put(&msg->ref, dlm_msg_release);
776 atomic_dec(&e->con->writequeue_cnt);
777 kref_put(&e->ref, dlm_page_release);
780 static void dlm_close_sock(struct socket **sock)
783 restore_callbacks(*sock);
789 /* Close a remote connection and tidy up */
790 static void close_connection(struct connection *con, bool and_other,
793 bool closing = test_and_set_bit(CF_CLOSING, &con->flags);
794 struct writequeue_entry *e;
796 if (tx && !closing && cancel_work_sync(&con->swork)) {
797 log_print("canceled swork for node %d", con->nodeid);
798 clear_bit(CF_WRITE_PENDING, &con->flags);
800 if (rx && !closing && cancel_work_sync(&con->rwork)) {
801 log_print("canceled rwork for node %d", con->nodeid);
802 clear_bit(CF_READ_PENDING, &con->flags);
805 mutex_lock(&con->sock_mutex);
806 dlm_close_sock(&con->sock);
808 if (con->othercon && and_other) {
809 /* Will only re-enter once. */
810 close_connection(con->othercon, false, tx, rx);
813 /* if we send a writequeue entry only a half way, we drop the
814 * whole entry because reconnection and that we not start of the
815 * middle of a msg which will confuse the other end.
817 * we can always drop messages because retransmits, but what we
818 * cannot allow is to transmit half messages which may be processed
821 * our policy is to start on a clean state when disconnects, we don't
822 * know what's send/received on transport layer in this case.
824 spin_lock(&con->writequeue_lock);
825 if (!list_empty(&con->writequeue)) {
826 e = list_first_entry(&con->writequeue, struct writequeue_entry,
831 spin_unlock(&con->writequeue_lock);
833 con->rx_leftover = 0;
835 clear_bit(CF_APP_LIMITED, &con->flags);
836 clear_bit(CF_CONNECTED, &con->flags);
837 clear_bit(CF_DELAY_CONNECT, &con->flags);
838 clear_bit(CF_RECONNECT, &con->flags);
839 clear_bit(CF_EOF, &con->flags);
840 mutex_unlock(&con->sock_mutex);
841 clear_bit(CF_CLOSING, &con->flags);
844 static void shutdown_connection(struct connection *con)
848 flush_work(&con->swork);
850 mutex_lock(&con->sock_mutex);
851 /* nothing to shutdown */
853 mutex_unlock(&con->sock_mutex);
857 set_bit(CF_SHUTDOWN, &con->flags);
858 ret = kernel_sock_shutdown(con->sock, SHUT_WR);
859 mutex_unlock(&con->sock_mutex);
861 log_print("Connection %p failed to shutdown: %d will force close",
865 ret = wait_event_timeout(con->shutdown_wait,
866 !test_bit(CF_SHUTDOWN, &con->flags),
867 DLM_SHUTDOWN_WAIT_TIMEOUT);
869 log_print("Connection %p shutdown timed out, will force close",
878 clear_bit(CF_SHUTDOWN, &con->flags);
879 close_connection(con, false, true, true);
882 static void dlm_tcp_shutdown(struct connection *con)
885 shutdown_connection(con->othercon);
886 shutdown_connection(con);
889 static int con_realloc_receive_buf(struct connection *con, int newlen)
891 unsigned char *newbuf;
893 newbuf = kmalloc(newlen, GFP_NOFS);
897 /* copy any leftover from last receive */
898 if (con->rx_leftover)
899 memmove(newbuf, con->rx_buf, con->rx_leftover);
901 /* swap to new buffer space */
903 con->rx_buflen = newlen;
904 con->rx_buf = newbuf;
909 /* Data received from remote end */
910 static int receive_from_sock(struct connection *con)
916 mutex_lock(&con->sock_mutex);
918 if (con->sock == NULL) {
923 /* realloc if we get new buffer size to read out */
924 buflen = dlm_config.ci_buffer_size;
925 if (con->rx_buflen != buflen && con->rx_leftover <= buflen) {
926 ret = con_realloc_receive_buf(con, buflen);
932 /* calculate new buffer parameter regarding last receive and
933 * possible leftover bytes
935 iov.iov_base = con->rx_buf + con->rx_leftover;
936 iov.iov_len = con->rx_buflen - con->rx_leftover;
938 memset(&msg, 0, sizeof(msg));
939 msg.msg_flags = MSG_DONTWAIT | MSG_NOSIGNAL;
940 ret = kernel_recvmsg(con->sock, &msg, &iov, 1, iov.iov_len,
942 trace_dlm_recv(con->nodeid, ret);
948 /* new buflen according readed bytes and leftover from last receive */
949 buflen = ret + con->rx_leftover;
950 ret = dlm_process_incoming_buffer(con->nodeid, con->rx_buf, buflen);
954 /* calculate leftover bytes from process and put it into begin of
955 * the receive buffer, so next receive we have the full message
956 * at the start address of the receive buffer.
958 con->rx_leftover = buflen - ret;
959 if (con->rx_leftover) {
960 memmove(con->rx_buf, con->rx_buf + ret,
965 dlm_midcomms_receive_done(con->nodeid);
966 mutex_unlock(&con->sock_mutex);
970 if (!test_and_set_bit(CF_READ_PENDING, &con->flags))
971 queue_work(recv_workqueue, &con->rwork);
972 mutex_unlock(&con->sock_mutex);
977 log_print("connection %p got EOF from %d",
980 if (dlm_proto_ops->eof_condition &&
981 dlm_proto_ops->eof_condition(con)) {
982 set_bit(CF_EOF, &con->flags);
983 mutex_unlock(&con->sock_mutex);
985 mutex_unlock(&con->sock_mutex);
986 close_connection(con, false, true, false);
988 /* handling for tcp shutdown */
989 clear_bit(CF_SHUTDOWN, &con->flags);
990 wake_up(&con->shutdown_wait);
993 /* signal to breaking receive worker */
996 mutex_unlock(&con->sock_mutex);
1001 /* Listening socket is busy, accept a connection */
1002 static int accept_from_sock(struct listen_connection *con)
1005 struct sockaddr_storage peeraddr;
1006 struct socket *newsock;
1009 struct connection *newcon;
1010 struct connection *addcon;
1016 result = kernel_accept(con->sock, &newsock, O_NONBLOCK);
1020 /* Get the connected socket's peer */
1021 memset(&peeraddr, 0, sizeof(peeraddr));
1022 len = newsock->ops->getname(newsock, (struct sockaddr *)&peeraddr, 2);
1024 result = -ECONNABORTED;
1028 /* Get the new node's NODEID */
1029 make_sockaddr(&peeraddr, 0, &len);
1030 if (addr_to_nodeid(&peeraddr, &nodeid, &mark)) {
1031 switch (peeraddr.ss_family) {
1033 struct sockaddr_in *sin = (struct sockaddr_in *)&peeraddr;
1035 log_print("connect from non cluster IPv4 node %pI4",
1039 #if IS_ENABLED(CONFIG_IPV6)
1041 struct sockaddr_in6 *sin6 = (struct sockaddr_in6 *)&peeraddr;
1043 log_print("connect from non cluster IPv6 node %pI6c",
1049 log_print("invalid family from non cluster node");
1053 sock_release(newsock);
1057 log_print("got connection from %d", nodeid);
1059 /* Check to see if we already have a connection to this node. This
1060 * could happen if the two nodes initiate a connection at roughly
1061 * the same time and the connections cross on the wire.
1062 * In this case we store the incoming one in "othercon"
1064 idx = srcu_read_lock(&connections_srcu);
1065 newcon = nodeid2con(nodeid, GFP_NOFS);
1067 srcu_read_unlock(&connections_srcu, idx);
1072 sock_set_mark(newsock->sk, mark);
1074 mutex_lock(&newcon->sock_mutex);
1076 struct connection *othercon = newcon->othercon;
1079 othercon = kzalloc(sizeof(*othercon), GFP_NOFS);
1081 log_print("failed to allocate incoming socket");
1082 mutex_unlock(&newcon->sock_mutex);
1083 srcu_read_unlock(&connections_srcu, idx);
1088 result = dlm_con_init(othercon, nodeid);
1091 mutex_unlock(&newcon->sock_mutex);
1092 srcu_read_unlock(&connections_srcu, idx);
1096 lockdep_set_subclass(&othercon->sock_mutex, 1);
1097 set_bit(CF_IS_OTHERCON, &othercon->flags);
1098 newcon->othercon = othercon;
1099 othercon->sendcon = newcon;
1101 /* close other sock con if we have something new */
1102 close_connection(othercon, false, true, false);
1105 mutex_lock(&othercon->sock_mutex);
1106 add_sock(newsock, othercon);
1108 mutex_unlock(&othercon->sock_mutex);
1111 /* accept copies the sk after we've saved the callbacks, so we
1112 don't want to save them a second time or comm errors will
1113 result in calling sk_error_report recursively. */
1114 add_sock(newsock, newcon);
1118 set_bit(CF_CONNECTED, &addcon->flags);
1119 mutex_unlock(&newcon->sock_mutex);
1122 * Add it to the active queue in case we got data
1123 * between processing the accept adding the socket
1124 * to the read_sockets list
1126 if (!test_and_set_bit(CF_READ_PENDING, &addcon->flags))
1127 queue_work(recv_workqueue, &addcon->rwork);
1129 srcu_read_unlock(&connections_srcu, idx);
1135 sock_release(newsock);
1137 if (result != -EAGAIN)
1138 log_print("error accepting connection from node: %d", result);
1143 * writequeue_entry_complete - try to delete and free write queue entry
1144 * @e: write queue entry to try to delete
1145 * @completed: bytes completed
1147 * writequeue_lock must be held.
1149 static void writequeue_entry_complete(struct writequeue_entry *e, int completed)
1151 e->offset += completed;
1152 e->len -= completed;
1153 /* signal that page was half way transmitted */
1156 if (e->len == 0 && e->users == 0)
1161 * sctp_bind_addrs - bind a SCTP socket to all our addresses
1163 static int sctp_bind_addrs(struct socket *sock, uint16_t port)
1165 struct sockaddr_storage localaddr;
1166 struct sockaddr *addr = (struct sockaddr *)&localaddr;
1167 int i, addr_len, result = 0;
1169 for (i = 0; i < dlm_local_count; i++) {
1170 memcpy(&localaddr, dlm_local_addr[i], sizeof(localaddr));
1171 make_sockaddr(&localaddr, port, &addr_len);
1174 result = kernel_bind(sock, addr, addr_len);
1176 result = sock_bind_add(sock->sk, addr, addr_len);
1179 log_print("Can't bind to %d addr number %d, %d.\n",
1180 port, i + 1, result);
1187 /* Get local addresses */
1188 static void init_local(void)
1190 struct sockaddr_storage sas, *addr;
1193 dlm_local_count = 0;
1194 for (i = 0; i < DLM_MAX_ADDR_COUNT; i++) {
1195 if (dlm_our_addr(&sas, i))
1198 addr = kmemdup(&sas, sizeof(*addr), GFP_NOFS);
1201 dlm_local_addr[dlm_local_count++] = addr;
1205 static void deinit_local(void)
1209 for (i = 0; i < dlm_local_count; i++)
1210 kfree(dlm_local_addr[i]);
1213 static struct writequeue_entry *new_writequeue_entry(struct connection *con)
1215 struct writequeue_entry *entry;
1217 entry = dlm_allocate_writequeue();
1221 entry->page = alloc_page(GFP_ATOMIC | __GFP_ZERO);
1223 dlm_free_writequeue(entry);
1230 entry->dirty = false;
1233 kref_init(&entry->ref);
1237 static struct writequeue_entry *new_wq_entry(struct connection *con, int len,
1238 char **ppc, void (*cb)(void *data),
1241 struct writequeue_entry *e;
1243 spin_lock(&con->writequeue_lock);
1244 if (!list_empty(&con->writequeue)) {
1245 e = list_last_entry(&con->writequeue, struct writequeue_entry, list);
1246 if (DLM_WQ_REMAIN_BYTES(e) >= len) {
1249 *ppc = page_address(e->page) + e->end;
1259 e = new_writequeue_entry(con);
1264 *ppc = page_address(e->page);
1266 atomic_inc(&con->writequeue_cnt);
1270 list_add_tail(&e->list, &con->writequeue);
1273 spin_unlock(&con->writequeue_lock);
1277 static struct dlm_msg *dlm_lowcomms_new_msg_con(struct connection *con, int len,
1278 gfp_t allocation, char **ppc,
1279 void (*cb)(void *data),
1282 struct writequeue_entry *e;
1283 struct dlm_msg *msg;
1285 msg = dlm_allocate_msg(allocation);
1289 kref_init(&msg->ref);
1291 e = new_wq_entry(con, len, ppc, cb, data);
1297 msg->retransmit = false;
1298 msg->orig_msg = NULL;
1306 /* avoid false positive for nodes_srcu, unlock happens in
1307 * dlm_lowcomms_commit_msg which is a must call if success
1310 struct dlm_msg *dlm_lowcomms_new_msg(int nodeid, int len, gfp_t allocation,
1311 char **ppc, void (*cb)(void *data),
1314 struct connection *con;
1315 struct dlm_msg *msg;
1318 if (len > DLM_MAX_SOCKET_BUFSIZE ||
1319 len < sizeof(struct dlm_header)) {
1320 BUILD_BUG_ON(PAGE_SIZE < DLM_MAX_SOCKET_BUFSIZE);
1321 log_print("failed to allocate a buffer of size %d", len);
1326 idx = srcu_read_lock(&connections_srcu);
1327 con = nodeid2con(nodeid, allocation);
1329 srcu_read_unlock(&connections_srcu, idx);
1333 msg = dlm_lowcomms_new_msg_con(con, len, allocation, ppc, cb, data);
1335 srcu_read_unlock(&connections_srcu, idx);
1339 /* for dlm_lowcomms_commit_msg() */
1340 kref_get(&msg->ref);
1341 /* we assume if successful commit must called */
1347 static void _dlm_lowcomms_commit_msg(struct dlm_msg *msg)
1349 struct writequeue_entry *e = msg->entry;
1350 struct connection *con = e->con;
1353 spin_lock(&con->writequeue_lock);
1354 kref_get(&msg->ref);
1355 list_add(&msg->list, &e->msgs);
1361 e->len = DLM_WQ_LENGTH_BYTES(e);
1362 spin_unlock(&con->writequeue_lock);
1364 queue_work(send_workqueue, &con->swork);
1368 spin_unlock(&con->writequeue_lock);
1372 /* avoid false positive for nodes_srcu, lock was happen in
1373 * dlm_lowcomms_new_msg
1376 void dlm_lowcomms_commit_msg(struct dlm_msg *msg)
1378 _dlm_lowcomms_commit_msg(msg);
1379 srcu_read_unlock(&connections_srcu, msg->idx);
1380 /* because dlm_lowcomms_new_msg() */
1381 kref_put(&msg->ref, dlm_msg_release);
1385 void dlm_lowcomms_put_msg(struct dlm_msg *msg)
1387 kref_put(&msg->ref, dlm_msg_release);
1390 /* does not held connections_srcu, usage workqueue only */
1391 int dlm_lowcomms_resend_msg(struct dlm_msg *msg)
1393 struct dlm_msg *msg_resend;
1396 if (msg->retransmit)
1399 msg_resend = dlm_lowcomms_new_msg_con(msg->entry->con, msg->len,
1400 GFP_ATOMIC, &ppc, NULL, NULL);
1404 msg->retransmit = true;
1405 kref_get(&msg->ref);
1406 msg_resend->orig_msg = msg;
1408 memcpy(ppc, msg->ppc, msg->len);
1409 _dlm_lowcomms_commit_msg(msg_resend);
1410 dlm_lowcomms_put_msg(msg_resend);
1415 /* Send a message */
1416 static void send_to_sock(struct connection *con)
1418 const int msg_flags = MSG_DONTWAIT | MSG_NOSIGNAL;
1419 struct writequeue_entry *e;
1420 int len, offset, ret;
1423 mutex_lock(&con->sock_mutex);
1424 if (con->sock == NULL)
1427 spin_lock(&con->writequeue_lock);
1429 e = con_next_wq(con);
1435 BUG_ON(len == 0 && e->users == 0);
1436 spin_unlock(&con->writequeue_lock);
1438 ret = kernel_sendpage(con->sock, e->page, offset, len,
1440 trace_dlm_send(con->nodeid, ret);
1441 if (ret == -EAGAIN || ret == 0) {
1442 if (ret == -EAGAIN &&
1443 test_bit(SOCKWQ_ASYNC_NOSPACE, &con->sock->flags) &&
1444 !test_and_set_bit(CF_APP_LIMITED, &con->flags)) {
1445 /* Notify TCP that we're limited by the
1446 * application window size.
1448 set_bit(SOCK_NOSPACE, &con->sock->flags);
1449 con->sock->sk->sk_write_pending++;
1456 /* Don't starve people filling buffers */
1457 if (++count >= MAX_SEND_MSG_COUNT) {
1462 spin_lock(&con->writequeue_lock);
1463 writequeue_entry_complete(e, ret);
1465 spin_unlock(&con->writequeue_lock);
1467 /* close if we got EOF */
1468 if (test_and_clear_bit(CF_EOF, &con->flags)) {
1469 mutex_unlock(&con->sock_mutex);
1470 close_connection(con, false, false, true);
1472 /* handling for tcp shutdown */
1473 clear_bit(CF_SHUTDOWN, &con->flags);
1474 wake_up(&con->shutdown_wait);
1476 mutex_unlock(&con->sock_mutex);
1482 mutex_unlock(&con->sock_mutex);
1486 mutex_unlock(&con->sock_mutex);
1487 queue_work(send_workqueue, &con->swork);
1491 static void clean_one_writequeue(struct connection *con)
1493 struct writequeue_entry *e, *safe;
1495 spin_lock(&con->writequeue_lock);
1496 list_for_each_entry_safe(e, safe, &con->writequeue, list) {
1499 spin_unlock(&con->writequeue_lock);
1502 /* Called from recovery when it knows that a node has
1504 int dlm_lowcomms_close(int nodeid)
1506 struct connection *con;
1507 struct dlm_node_addr *na;
1510 log_print("closing connection to node %d", nodeid);
1511 idx = srcu_read_lock(&connections_srcu);
1512 con = nodeid2con(nodeid, 0);
1514 set_bit(CF_CLOSE, &con->flags);
1515 close_connection(con, true, true, true);
1516 clean_one_writequeue(con);
1518 clean_one_writequeue(con->othercon);
1520 srcu_read_unlock(&connections_srcu, idx);
1522 spin_lock(&dlm_node_addrs_spin);
1523 na = find_node_addr(nodeid);
1525 list_del(&na->list);
1526 while (na->addr_count--)
1527 kfree(na->addr[na->addr_count]);
1530 spin_unlock(&dlm_node_addrs_spin);
1535 /* Receive workqueue function */
1536 static void process_recv_sockets(struct work_struct *work)
1538 struct connection *con = container_of(work, struct connection, rwork);
1540 clear_bit(CF_READ_PENDING, &con->flags);
1541 receive_from_sock(con);
1544 static void process_listen_recv_socket(struct work_struct *work)
1546 accept_from_sock(&listen_con);
1549 static void dlm_connect(struct connection *con)
1551 struct sockaddr_storage addr;
1552 int result, addr_len;
1553 struct socket *sock;
1556 /* Some odd races can cause double-connects, ignore them */
1557 if (con->retries++ > MAX_CONNECT_RETRIES)
1561 log_print("node %d already connected.", con->nodeid);
1565 memset(&addr, 0, sizeof(addr));
1566 result = nodeid_to_addr(con->nodeid, &addr, NULL,
1567 dlm_proto_ops->try_new_addr, &mark);
1569 log_print("no address for nodeid %d", con->nodeid);
1573 /* Create a socket to communicate with */
1574 result = sock_create_kern(&init_net, dlm_local_addr[0]->ss_family,
1575 SOCK_STREAM, dlm_proto_ops->proto, &sock);
1579 sock_set_mark(sock->sk, mark);
1580 dlm_proto_ops->sockopts(sock);
1582 add_sock(sock, con);
1584 result = dlm_proto_ops->bind(sock);
1588 log_print_ratelimited("connecting to %d", con->nodeid);
1589 make_sockaddr(&addr, dlm_config.ci_tcp_port, &addr_len);
1590 result = dlm_proto_ops->connect(con, sock, (struct sockaddr *)&addr,
1598 dlm_close_sock(&con->sock);
1602 * Some errors are fatal and this list might need adjusting. For other
1603 * errors we try again until the max number of retries is reached.
1605 if (result != -EHOSTUNREACH &&
1606 result != -ENETUNREACH &&
1607 result != -ENETDOWN &&
1608 result != -EINVAL &&
1609 result != -EPROTONOSUPPORT) {
1610 log_print("connect %d try %d error %d", con->nodeid,
1611 con->retries, result);
1613 lowcomms_connect_sock(con);
1617 /* Send workqueue function */
1618 static void process_send_sockets(struct work_struct *work)
1620 struct connection *con = container_of(work, struct connection, swork);
1622 WARN_ON(test_bit(CF_IS_OTHERCON, &con->flags));
1624 clear_bit(CF_WRITE_PENDING, &con->flags);
1626 if (test_and_clear_bit(CF_RECONNECT, &con->flags)) {
1627 close_connection(con, false, false, true);
1628 dlm_midcomms_unack_msg_resend(con->nodeid);
1631 if (con->sock == NULL) {
1632 if (test_and_clear_bit(CF_DELAY_CONNECT, &con->flags))
1635 mutex_lock(&con->sock_mutex);
1637 mutex_unlock(&con->sock_mutex);
1640 if (!list_empty(&con->writequeue))
1644 static void work_stop(void)
1646 if (recv_workqueue) {
1647 destroy_workqueue(recv_workqueue);
1648 recv_workqueue = NULL;
1651 if (send_workqueue) {
1652 destroy_workqueue(send_workqueue);
1653 send_workqueue = NULL;
1657 static int work_start(void)
1659 recv_workqueue = alloc_ordered_workqueue("dlm_recv", WQ_MEM_RECLAIM);
1660 if (!recv_workqueue) {
1661 log_print("can't start dlm_recv");
1665 send_workqueue = alloc_ordered_workqueue("dlm_send", WQ_MEM_RECLAIM);
1666 if (!send_workqueue) {
1667 log_print("can't start dlm_send");
1668 destroy_workqueue(recv_workqueue);
1669 recv_workqueue = NULL;
1676 static void shutdown_conn(struct connection *con)
1678 if (dlm_proto_ops->shutdown_action)
1679 dlm_proto_ops->shutdown_action(con);
1682 void dlm_lowcomms_shutdown(void)
1686 /* Set all the flags to prevent any
1692 flush_workqueue(recv_workqueue);
1694 flush_workqueue(send_workqueue);
1696 dlm_close_sock(&listen_con.sock);
1698 idx = srcu_read_lock(&connections_srcu);
1699 foreach_conn(shutdown_conn);
1700 srcu_read_unlock(&connections_srcu, idx);
1703 static void _stop_conn(struct connection *con, bool and_other)
1705 mutex_lock(&con->sock_mutex);
1706 set_bit(CF_CLOSE, &con->flags);
1707 set_bit(CF_READ_PENDING, &con->flags);
1708 set_bit(CF_WRITE_PENDING, &con->flags);
1709 if (con->sock && con->sock->sk) {
1710 lock_sock(con->sock->sk);
1711 con->sock->sk->sk_user_data = NULL;
1712 release_sock(con->sock->sk);
1714 if (con->othercon && and_other)
1715 _stop_conn(con->othercon, false);
1716 mutex_unlock(&con->sock_mutex);
1719 static void stop_conn(struct connection *con)
1721 _stop_conn(con, true);
1724 static void connection_release(struct rcu_head *rcu)
1726 struct connection *con = container_of(rcu, struct connection, rcu);
1732 static void free_conn(struct connection *con)
1734 close_connection(con, true, true, true);
1735 spin_lock(&connections_lock);
1736 hlist_del_rcu(&con->list);
1737 spin_unlock(&connections_lock);
1738 if (con->othercon) {
1739 clean_one_writequeue(con->othercon);
1740 call_srcu(&connections_srcu, &con->othercon->rcu,
1741 connection_release);
1743 clean_one_writequeue(con);
1744 call_srcu(&connections_srcu, &con->rcu, connection_release);
1747 static void work_flush(void)
1751 struct connection *con;
1755 foreach_conn(stop_conn);
1757 flush_workqueue(recv_workqueue);
1759 flush_workqueue(send_workqueue);
1760 for (i = 0; i < CONN_HASH_SIZE && ok; i++) {
1761 hlist_for_each_entry_rcu(con, &connection_hash[i],
1763 ok &= test_bit(CF_READ_PENDING, &con->flags);
1764 ok &= test_bit(CF_WRITE_PENDING, &con->flags);
1765 if (con->othercon) {
1766 ok &= test_bit(CF_READ_PENDING,
1767 &con->othercon->flags);
1768 ok &= test_bit(CF_WRITE_PENDING,
1769 &con->othercon->flags);
1776 void dlm_lowcomms_stop(void)
1780 idx = srcu_read_lock(&connections_srcu);
1782 foreach_conn(free_conn);
1783 srcu_read_unlock(&connections_srcu, idx);
1787 dlm_proto_ops = NULL;
1790 static int dlm_listen_for_all(void)
1792 struct socket *sock;
1795 log_print("Using %s for communications",
1796 dlm_proto_ops->name);
1798 result = dlm_proto_ops->listen_validate();
1802 result = sock_create_kern(&init_net, dlm_local_addr[0]->ss_family,
1803 SOCK_STREAM, dlm_proto_ops->proto, &sock);
1805 log_print("Can't create comms socket: %d", result);
1809 sock_set_mark(sock->sk, dlm_config.ci_mark);
1810 dlm_proto_ops->listen_sockopts(sock);
1812 result = dlm_proto_ops->listen_bind(sock);
1816 save_listen_callbacks(sock);
1817 add_listen_sock(sock, &listen_con);
1819 INIT_WORK(&listen_con.rwork, process_listen_recv_socket);
1820 result = sock->ops->listen(sock, 5);
1822 dlm_close_sock(&listen_con.sock);
1833 static int dlm_tcp_bind(struct socket *sock)
1835 struct sockaddr_storage src_addr;
1836 int result, addr_len;
1838 /* Bind to our cluster-known address connecting to avoid
1841 memcpy(&src_addr, dlm_local_addr[0], sizeof(src_addr));
1842 make_sockaddr(&src_addr, 0, &addr_len);
1844 result = sock->ops->bind(sock, (struct sockaddr *)&src_addr,
1847 /* This *may* not indicate a critical error */
1848 log_print("could not bind for connect: %d", result);
1854 static int dlm_tcp_connect(struct connection *con, struct socket *sock,
1855 struct sockaddr *addr, int addr_len)
1859 ret = sock->ops->connect(sock, addr, addr_len, O_NONBLOCK);
1870 static int dlm_tcp_listen_validate(void)
1872 /* We don't support multi-homed hosts */
1873 if (dlm_local_count > 1) {
1874 log_print("TCP protocol can't handle multi-homed hosts, try SCTP");
1881 static void dlm_tcp_sockopts(struct socket *sock)
1883 /* Turn off Nagle's algorithm */
1884 tcp_sock_set_nodelay(sock->sk);
1887 static void dlm_tcp_listen_sockopts(struct socket *sock)
1889 dlm_tcp_sockopts(sock);
1890 sock_set_reuseaddr(sock->sk);
1893 static int dlm_tcp_listen_bind(struct socket *sock)
1897 /* Bind to our port */
1898 make_sockaddr(dlm_local_addr[0], dlm_config.ci_tcp_port, &addr_len);
1899 return sock->ops->bind(sock, (struct sockaddr *)dlm_local_addr[0],
1903 static const struct dlm_proto_ops dlm_tcp_ops = {
1905 .proto = IPPROTO_TCP,
1906 .connect = dlm_tcp_connect,
1907 .sockopts = dlm_tcp_sockopts,
1908 .bind = dlm_tcp_bind,
1909 .listen_validate = dlm_tcp_listen_validate,
1910 .listen_sockopts = dlm_tcp_listen_sockopts,
1911 .listen_bind = dlm_tcp_listen_bind,
1912 .shutdown_action = dlm_tcp_shutdown,
1913 .eof_condition = tcp_eof_condition,
1916 static int dlm_sctp_bind(struct socket *sock)
1918 return sctp_bind_addrs(sock, 0);
1921 static int dlm_sctp_connect(struct connection *con, struct socket *sock,
1922 struct sockaddr *addr, int addr_len)
1927 * Make sock->ops->connect() function return in specified time,
1928 * since O_NONBLOCK argument in connect() function does not work here,
1929 * then, we should restore the default value of this attribute.
1931 sock_set_sndtimeo(sock->sk, 5);
1932 ret = sock->ops->connect(sock, addr, addr_len, 0);
1933 sock_set_sndtimeo(sock->sk, 0);
1937 if (!test_and_set_bit(CF_CONNECTED, &con->flags))
1938 log_print("connected to node %d", con->nodeid);
1943 static int dlm_sctp_listen_validate(void)
1945 if (!IS_ENABLED(CONFIG_IP_SCTP)) {
1946 log_print("SCTP is not enabled by this kernel");
1950 request_module("sctp");
1954 static int dlm_sctp_bind_listen(struct socket *sock)
1956 return sctp_bind_addrs(sock, dlm_config.ci_tcp_port);
1959 static void dlm_sctp_sockopts(struct socket *sock)
1961 /* Turn off Nagle's algorithm */
1962 sctp_sock_set_nodelay(sock->sk);
1963 sock_set_rcvbuf(sock->sk, NEEDED_RMEM);
1966 static const struct dlm_proto_ops dlm_sctp_ops = {
1968 .proto = IPPROTO_SCTP,
1969 .try_new_addr = true,
1970 .connect = dlm_sctp_connect,
1971 .sockopts = dlm_sctp_sockopts,
1972 .bind = dlm_sctp_bind,
1973 .listen_validate = dlm_sctp_listen_validate,
1974 .listen_sockopts = dlm_sctp_sockopts,
1975 .listen_bind = dlm_sctp_bind_listen,
1978 int dlm_lowcomms_start(void)
1980 int error = -EINVAL;
1983 for (i = 0; i < CONN_HASH_SIZE; i++)
1984 INIT_HLIST_HEAD(&connection_hash[i]);
1987 if (!dlm_local_count) {
1989 log_print("no local IP address has been set");
1993 INIT_WORK(&listen_con.rwork, process_listen_recv_socket);
1995 error = work_start();
2001 /* Start listening */
2002 switch (dlm_config.ci_protocol) {
2004 dlm_proto_ops = &dlm_tcp_ops;
2006 case DLM_PROTO_SCTP:
2007 dlm_proto_ops = &dlm_sctp_ops;
2010 log_print("Invalid protocol identifier %d set",
2011 dlm_config.ci_protocol);
2013 goto fail_proto_ops;
2016 error = dlm_listen_for_all();
2023 dlm_proto_ops = NULL;
2026 dlm_close_sock(&listen_con.sock);
2034 void dlm_lowcomms_exit(void)
2036 struct dlm_node_addr *na, *safe;
2038 spin_lock(&dlm_node_addrs_spin);
2039 list_for_each_entry_safe(na, safe, &dlm_node_addrs, list) {
2040 list_del(&na->list);
2041 while (na->addr_count--)
2042 kfree(na->addr[na->addr_count]);
2045 spin_unlock(&dlm_node_addrs_spin);