fix ring buffer stuck when using multi thread runtime
Some checks are pending
EasyTier Core / pre_job (push) Waiting to run
EasyTier Core / build (freebsd-13.2-x86_64, 13.2, ubuntu-latest, x86_64-unknown-freebsd) (push) Blocked by required conditions
EasyTier Core / build (linux-aarch64, ubuntu-latest, aarch64-unknown-linux-musl) (push) Blocked by required conditions
EasyTier Core / build (linux-arm, ubuntu-latest, arm-unknown-linux-musleabi) (push) Blocked by required conditions
EasyTier Core / build (linux-armhf, ubuntu-latest, arm-unknown-linux-musleabihf) (push) Blocked by required conditions
EasyTier Core / build (linux-armv7, ubuntu-latest, armv7-unknown-linux-musleabi) (push) Blocked by required conditions
EasyTier Core / build (linux-armv7hf, ubuntu-latest, armv7-unknown-linux-musleabihf) (push) Blocked by required conditions
EasyTier Core / build (linux-mips, ubuntu-latest, mips-unknown-linux-musl) (push) Blocked by required conditions
EasyTier Core / build (linux-mipsel, ubuntu-latest, mipsel-unknown-linux-musl) (push) Blocked by required conditions
EasyTier Core / build (linux-x86_64, ubuntu-latest, x86_64-unknown-linux-musl) (push) Blocked by required conditions
EasyTier Core / build (macos-aarch64, macos-latest, aarch64-apple-darwin) (push) Blocked by required conditions
EasyTier Core / build (macos-x86_64, macos-latest, x86_64-apple-darwin) (push) Blocked by required conditions
EasyTier Core / build (windows-x86_64, windows-latest, x86_64-pc-windows-msvc) (push) Blocked by required conditions
EasyTier Core / core-result (push) Blocked by required conditions
EasyTier GUI / pre_job (push) Waiting to run
EasyTier GUI / build-gui (linux-aarch64, aarch64-unknown-linux-gnu, ubuntu-latest, aarch64-unknown-linux-musl) (push) Blocked by required conditions
EasyTier GUI / build-gui (linux-x86_64, x86_64-unknown-linux-gnu, ubuntu-latest, x86_64-unknown-linux-musl) (push) Blocked by required conditions
EasyTier GUI / build-gui (macos-aarch64, aarch64-apple-darwin, macos-latest, aarch64-apple-darwin) (push) Blocked by required conditions
EasyTier GUI / build-gui (macos-x86_64, x86_64-apple-darwin, macos-latest, x86_64-apple-darwin) (push) Blocked by required conditions
EasyTier GUI / build-gui (windows-x86_64, x86_64-pc-windows-msvc, windows-latest, x86_64-pc-windows-msvc) (push) Blocked by required conditions
EasyTier GUI / gui-result (push) Blocked by required conditions
EasyTier Mobile / pre_job (push) Waiting to run
EasyTier Mobile / build-mobile (android, ubuntu-latest, android) (push) Blocked by required conditions
EasyTier Mobile / mobile-result (push) Blocked by required conditions
EasyTier Test / pre_job (push) Waiting to run
EasyTier Test / test (push) Blocked by required conditions

This commit is contained in:
sijie.sun 2024-09-26 00:18:17 +08:00 committed by Sijie.Sun
parent 3f9a1d8f2e
commit 7b4a01e7fb
9 changed files with 119 additions and 150 deletions

21
Cargo.lock generated
View File

@ -289,6 +289,16 @@ dependencies = [
"syn 2.0.74", "syn 2.0.74",
] ]
[[package]]
name = "async-ringbuf"
version = "0.3.1"
source = "registry+https://github.com/rust-lang/crates.io-index"
checksum = "32690af15155711360e74119b99605416c9e4dfd45b0859bd9af795a50693bec"
dependencies = [
"futures",
"ringbuf",
]
[[package]] [[package]]
name = "async-signal" name = "async-signal"
version = "0.2.10" version = "0.2.10"
@ -1534,6 +1544,7 @@ dependencies = [
"aes-gcm", "aes-gcm",
"anyhow", "anyhow",
"async-recursion", "async-recursion",
"async-ringbuf",
"async-stream", "async-stream",
"async-trait", "async-trait",
"atomic-shim", "atomic-shim",
@ -1580,6 +1591,7 @@ dependencies = [
"regex", "regex",
"reqwest 0.11.27", "reqwest 0.11.27",
"ring 0.17.8", "ring 0.17.8",
"ringbuf",
"rpc_build", "rpc_build",
"rstest", "rstest",
"rust-i18n", "rust-i18n",
@ -4882,6 +4894,15 @@ dependencies = [
"windows-sys 0.52.0", "windows-sys 0.52.0",
] ]
[[package]]
name = "ringbuf"
version = "0.4.6"
source = "registry+https://github.com/rust-lang/crates.io-index"
checksum = "fb0d14419487131a897031a7e81c3b23d092296984fac4eb6df48cc4e3b2f3c5"
dependencies = [
"crossbeam-utils",
]
[[package]] [[package]]
name = "rpc_build" name = "rpc_build"
version = "0.1.0" version = "0.1.0"

View File

@ -178,6 +178,9 @@ wildmatch = "2.3.4"
rust-i18n = "3" rust-i18n = "3"
sys-locale = "0.3" sys-locale = "0.3"
ringbuf = "0.4.5"
async-ringbuf = "0.3.1"
[target.'cfg(windows)'.dependencies] [target.'cfg(windows)'.dependencies]
windows-sys = { version = "0.52", features = [ windows-sys = { version = "0.52", features = [
"Win32_Networking_WinSock", "Win32_Networking_WinSock",

View File

@ -292,7 +292,6 @@ rust_i18n::i18n!("locales", fallback = "en");
impl Cli { impl Cli {
fn parse_listeners(no_listener: bool, listeners: Vec<String>) -> Vec<String> { fn parse_listeners(no_listener: bool, listeners: Vec<String>) -> Vec<String> {
println!("parsing listeners: {:?}", listeners);
let proto_port_offset = vec![("tcp", 0), ("udp", 0), ("wg", 1), ("ws", 1), ("wss", 2)]; let proto_port_offset = vec![("tcp", 0), ("udp", 0), ("wg", 1), ("ws", 1), ("wss", 2)];
if no_listener || listeners.is_empty() { if no_listener || listeners.is_empty() {
@ -376,7 +375,6 @@ impl From<Cli> for TomlConfigLoader {
let cfg = TomlConfigLoader::default(); let cfg = TomlConfigLoader::default();
cfg.set_hostname(cli.hostname); cfg.set_hostname(cli.hostname);
cfg.set_network_identity(NetworkIdentity::new(cli.network_name, cli.network_secret)); cfg.set_network_identity(NetworkIdentity::new(cli.network_name, cli.network_secret));

View File

@ -598,6 +598,7 @@ impl NicCtx {
} }
Self::do_forward_nic_to_peers_ipv4(ret.unwrap(), mgr.as_ref()).await; Self::do_forward_nic_to_peers_ipv4(ret.unwrap(), mgr.as_ref()).await;
} }
panic!("nic stream closed");
}); });
Ok(()) Ok(())
@ -618,6 +619,7 @@ impl NicCtx {
tracing::error!(?ret, "do_forward_tunnel_to_nic sink error"); tracing::error!(?ret, "do_forward_tunnel_to_nic sink error");
} }
} }
panic!("peer packet receiver closed");
}); });
} }

View File

@ -522,7 +522,7 @@ mod tests {
tests::{connect_peer_manager, wait_route_appear}, tests::{connect_peer_manager, wait_route_appear},
}, },
proto::common::NatType, proto::common::NatType,
tunnel::common::tests::{enable_log, wait_for_condition}, tunnel::common::tests::wait_for_condition,
}; };
use super::*; use super::*;

View File

@ -25,6 +25,7 @@ use zerocopy::AsBytes;
use crate::{ use crate::{
common::{ common::{
config::{NetworkIdentity, NetworkSecretDigest}, config::{NetworkIdentity, NetworkSecretDigest},
defer,
error::Error, error::Error,
global_ctx::ArcGlobalCtx, global_ctx::ArcGlobalCtx,
PeerId, PeerId,
@ -103,7 +104,9 @@ impl PeerConn {
my_peer_id, my_peer_id,
global_ctx, global_ctx,
tunnel: Arc::new(Mutex::new(Box::new(mpsc_tunnel))), tunnel: Arc::new(Mutex::new(Box::new(defer::Defer::new(move || {
mpsc_tunnel.close()
})))),
sink, sink,
recv: Arc::new(Mutex::new(Some(recv))), recv: Arc::new(Mutex::new(Some(recv))),
tunnel_info, tunnel_info,

View File

@ -7,11 +7,10 @@ use tokio::time::timeout;
use crate::common::scoped_task::ScopedTask; use crate::common::scoped_task::ScopedTask;
use super::{ use super::{packet_def::ZCPacket, Tunnel, TunnelError, ZCPacketSink, ZCPacketStream};
packet_def::ZCPacket, Tunnel, TunnelError, ZCPacketSink, ZCPacketStream,
};
use tachyonix::{channel, Receiver, Sender}; // use tokio::sync::mpsc::{channel, error::TrySendError, Receiver, Sender};
use tachyonix::{channel, Receiver, Sender, TrySendError};
use futures::SinkExt; use futures::SinkExt;
@ -26,8 +25,8 @@ impl MpscTunnelSender {
pub fn try_send(&self, item: ZCPacket) -> Result<(), TunnelError> { pub fn try_send(&self, item: ZCPacket) -> Result<(), TunnelError> {
self.0.try_send(item).map_err(|e| match e { self.0.try_send(item).map_err(|e| match e {
tachyonix::TrySendError::Full(_) => TunnelError::BufferFull, TrySendError::Full(_) => TunnelError::BufferFull,
tachyonix::TrySendError::Closed(_) => TunnelError::Shutdown, TrySendError::Closed(_) => TunnelError::Shutdown,
}) })
} }
} }
@ -53,6 +52,7 @@ impl<T: Tunnel> MpscTunnel<T> {
break; break;
} }
} }
rx.close();
let close_ret = timeout(Duration::from_secs(5), sink.close()).await; let close_ret = timeout(Duration::from_secs(5), sink.close()).await;
tracing::warn!(?close_ret, "mpsc close sink"); tracing::warn!(?close_ret, "mpsc close sink");
}); });
@ -72,7 +72,10 @@ impl<T: Tunnel> MpscTunnel<T> {
let item = rx.recv().await.with_context(|| "recv error")?; let item = rx.recv().await.with_context(|| "recv error")?;
sink.feed(item).await?; sink.feed(item).await?;
while let Ok(item) = rx.try_recv() { while let Ok(item) = rx.try_recv() {
if let Err(e) = sink.feed(item).await { if let Err(e) = timeout(Duration::from_secs(5), sink.feed(item))
.await
.unwrap()
{
tracing::error!(?e, "feed error"); tracing::error!(?e, "feed error");
break; break;
} }

View File

@ -1,17 +1,15 @@
use std::{ use std::{
collections::HashMap, collections::HashMap,
sync::{ fmt::Debug,
atomic::{AtomicBool, Ordering}, sync::Arc,
Arc, task::{ready, Poll},
},
task::{Poll, Waker},
}; };
use atomicbox::AtomicOptionBox; use async_ringbuf::{traits::*, AsyncHeapCons, AsyncHeapProd, AsyncHeapRb};
use crossbeam_queue::ArrayQueue; use crossbeam::atomic::AtomicCell;
use async_trait::async_trait; use async_trait::async_trait;
use futures::{Sink, Stream}; use futures::{Sink, SinkExt, Stream, StreamExt};
use once_cell::sync::Lazy; use once_cell::sync::Lazy;
use tokio::sync::{ use tokio::sync::{
@ -30,83 +28,30 @@ use super::{
static RING_TUNNEL_CAP: usize = 128; static RING_TUNNEL_CAP: usize = 128;
#[derive(Debug)] type RingLock = parking_lot::Mutex<()>;
type RingItem = SinkItem;
pub struct RingTunnel { pub struct RingTunnel {
id: Uuid, id: Uuid,
ring: ArrayQueue<SinkItem>,
closed: AtomicBool,
wait_for_new_item: AtomicOptionBox<Waker>, ring_cons_impl: AtomicCell<Option<AsyncHeapCons<RingItem>>>,
wait_for_empty_slot: AtomicOptionBox<Waker>, ring_prod_impl: AtomicCell<Option<AsyncHeapProd<RingItem>>>,
} }
impl RingTunnel { impl RingTunnel {
fn wait_for_new_item<T>(&self, cx: &mut std::task::Context<'_>) -> Poll<T> {
let ret = self
.wait_for_new_item
.swap(Some(Box::new(cx.waker().clone())), Ordering::AcqRel);
if let Some(old_waker) = ret {
assert!(old_waker.will_wake(cx.waker()));
}
Poll::Pending
}
fn wait_for_empty_slot<T>(&self, cx: &mut std::task::Context<'_>) -> Poll<T> {
let ret = self
.wait_for_empty_slot
.swap(Some(Box::new(cx.waker().clone())), Ordering::AcqRel);
if let Some(old_waker) = ret {
assert!(old_waker.will_wake(cx.waker()));
}
Poll::Pending
}
fn notify_new_item(&self) {
if let Some(w) = self.wait_for_new_item.take(Ordering::AcqRel) {
tracing::trace!(?self.id, "notify new item");
w.wake();
}
}
fn notify_empty_slot(&self) {
if let Some(w) = self.wait_for_empty_slot.take(Ordering::AcqRel) {
tracing::trace!(?self.id, "notify empty slot");
w.wake();
}
}
fn id(&self) -> &Uuid { fn id(&self) -> &Uuid {
&self.id &self.id
} }
pub fn len(&self) -> usize {
self.ring.len()
}
pub fn capacity(&self) -> usize {
self.ring.capacity()
}
fn close(&self) {
tracing::info!("close ring tunnel {:?}", self.id);
self.closed
.store(true, std::sync::atomic::Ordering::Relaxed);
self.notify_new_item();
}
fn closed(&self) -> bool {
self.closed.load(std::sync::atomic::Ordering::Relaxed)
}
pub fn new(cap: usize) -> Self { pub fn new(cap: usize) -> Self {
let id = Uuid::new_v4(); let id = Uuid::new_v4();
let ring_impl = AsyncHeapRb::new(cap);
let (ring_prod_impl, ring_cons_impl) = ring_impl.split();
Self { Self {
id: id.clone(), id: id.clone(),
ring: ArrayQueue::new(cap), ring_cons_impl: AtomicCell::new(Some(ring_cons_impl)),
closed: AtomicBool::new(false), ring_prod_impl: AtomicCell::new(Some(ring_prod_impl)),
wait_for_new_item: AtomicOptionBox::new(None),
wait_for_empty_slot: AtomicOptionBox::new(None),
} }
} }
@ -117,14 +62,23 @@ impl RingTunnel {
} }
} }
#[derive(Debug)] impl Debug for RingTunnel {
fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
f.debug_struct("RingTunnel").field("id", &self.id).finish()
}
}
pub struct RingStream { pub struct RingStream {
tunnel: Arc<RingTunnel>, id: Uuid,
ring_cons_impl: AsyncHeapCons<RingItem>,
} }
impl RingStream { impl RingStream {
pub fn new(tunnel: Arc<RingTunnel>) -> Self { pub fn new(tunnel: Arc<RingTunnel>) -> Self {
Self { tunnel } Self {
id: tunnel.id.clone(),
ring_cons_impl: tunnel.ring_cons_impl.take().unwrap(),
}
} }
} }
@ -135,56 +89,39 @@ impl Stream for RingStream {
self: std::pin::Pin<&mut Self>, self: std::pin::Pin<&mut Self>,
cx: &mut std::task::Context<'_>, cx: &mut std::task::Context<'_>,
) -> Poll<Option<Self::Item>> { ) -> Poll<Option<Self::Item>> {
let s = self.get_mut(); let ret = ready!(self.get_mut().ring_cons_impl.poll_next_unpin(cx));
let ret = s.tunnel.ring.pop();
match ret { match ret {
Some(v) => { Some(item) => Poll::Ready(Some(Ok(item))),
s.tunnel.notify_empty_slot(); None => Poll::Ready(None),
return Poll::Ready(Some(Ok(v)));
}
None => {
if s.tunnel.closed() {
tracing::warn!("ring recv tunnel {:?} closed", s.tunnel.id());
return Poll::Ready(None);
} else {
tracing::trace!("waiting recv buffer, id: {}", s.tunnel.id());
}
s.tunnel.wait_for_new_item(cx)
}
} }
} }
} }
#[derive(Debug)] impl Debug for RingStream {
pub struct RingSink { fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
tunnel: Arc<RingTunnel>, f.debug_struct("RingStream")
.field("id", &self.id)
.field("len", &self.ring_cons_impl.base().occupied_len())
.field("cap", &self.ring_cons_impl.base().capacity())
.finish()
}
} }
impl Drop for RingSink { pub struct RingSink {
fn drop(&mut self) { id: Uuid,
self.tunnel.close(); ring_prod_impl: AsyncHeapProd<RingItem>,
}
} }
impl RingSink { impl RingSink {
pub fn new(tunnel: Arc<RingTunnel>) -> Self { pub fn new(tunnel: Arc<RingTunnel>) -> Self {
Self { tunnel } Self {
} id: tunnel.id.clone(),
ring_prod_impl: tunnel.ring_prod_impl.take().unwrap(),
pub fn push_no_check(&self, item: SinkItem) -> Result<(), TunnelError> {
if self.tunnel.closed() {
return Err(TunnelError::Shutdown);
} }
tracing::trace!(id=?self.tunnel.id(), ?item, "send buffer");
let _ = self.tunnel.ring.push(item);
self.tunnel.notify_new_item();
Ok(())
} }
pub fn has_empty_slot(&self) -> bool { pub fn try_send(&mut self, item: RingItem) -> Result<(), RingItem> {
self.tunnel.len() < self.tunnel.capacity() self.ring_prod_impl.try_push(item)
} }
} }
@ -195,37 +132,41 @@ impl Sink<SinkItem> for RingSink {
self: std::pin::Pin<&mut Self>, self: std::pin::Pin<&mut Self>,
cx: &mut std::task::Context<'_>, cx: &mut std::task::Context<'_>,
) -> std::task::Poll<Result<(), Self::Error>> { ) -> std::task::Poll<Result<(), Self::Error>> {
let self_mut = self.get_mut(); let ret = ready!(self.get_mut().ring_prod_impl.poll_ready_unpin(cx));
if !self_mut.has_empty_slot() { Poll::Ready(ret.map_err(|_| TunnelError::Shutdown))
if self_mut.tunnel.closed() {
return Poll::Ready(Err(TunnelError::Shutdown));
}
self_mut.tunnel.wait_for_empty_slot(cx)
} else {
Poll::Ready(Ok(()))
}
} }
fn start_send(self: std::pin::Pin<&mut Self>, item: SinkItem) -> Result<(), Self::Error> { fn start_send(self: std::pin::Pin<&mut Self>, item: SinkItem) -> Result<(), Self::Error> {
self.push_no_check(item) self.get_mut()
.ring_prod_impl
.start_send_unpin(item)
.map_err(|_| TunnelError::Shutdown)
} }
fn poll_flush( fn poll_flush(
self: std::pin::Pin<&mut Self>, self: std::pin::Pin<&mut Self>,
_cx: &mut std::task::Context<'_>, cx: &mut std::task::Context<'_>,
) -> std::task::Poll<Result<(), Self::Error>> { ) -> std::task::Poll<Result<(), Self::Error>> {
if self.tunnel.closed() { let ret = ready!(self.get_mut().ring_prod_impl.poll_flush_unpin(cx));
return Poll::Ready(Err(TunnelError::Shutdown)); Poll::Ready(ret.map_err(|_| TunnelError::Shutdown))
}
Poll::Ready(Ok(()))
} }
fn poll_close( fn poll_close(
self: std::pin::Pin<&mut Self>, self: std::pin::Pin<&mut Self>,
_cx: &mut std::task::Context<'_>, cx: &mut std::task::Context<'_>,
) -> std::task::Poll<Result<(), Self::Error>> { ) -> std::task::Poll<Result<(), Self::Error>> {
self.tunnel.close(); let ret = ready!(self.get_mut().ring_prod_impl.poll_close_unpin(cx));
Poll::Ready(Ok(())) Poll::Ready(ret.map_err(|_| TunnelError::Shutdown))
}
}
impl Debug for RingSink {
fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
f.debug_struct("RingSink")
.field("id", &self.id)
.field("len", &self.ring_prod_impl.base().occupied_len())
.field("cap", &self.ring_prod_impl.base().capacity())
.finish()
} }
} }

View File

@ -151,9 +151,9 @@ async fn forward_from_ring_to_udp(
} }
} }
async fn udp_recv_from_socket_forward_task<F>(socket: Arc<UdpSocket>, f: F) async fn udp_recv_from_socket_forward_task<F>(socket: Arc<UdpSocket>, mut f: F)
where where
F: Fn(ZCPacket, SocketAddr) -> (), F: FnMut(ZCPacket, SocketAddr) -> (),
{ {
let mut buf = BytesMut::new(); let mut buf = BytesMut::new();
loop { loop {
@ -220,7 +220,7 @@ impl UdpConnection {
} }
} }
pub fn handle_packet_from_remote(&self, zc_packet: ZCPacket) -> Result<(), TunnelError> { pub fn handle_packet_from_remote(&mut self, zc_packet: ZCPacket) -> Result<(), TunnelError> {
let header = zc_packet.udp_tunnel_header().unwrap(); let header = zc_packet.udp_tunnel_header().unwrap();
let conn_id = header.conn_id.get(); let conn_id = header.conn_id.get();
@ -232,12 +232,10 @@ impl UdpConnection {
return Err(TunnelError::ConnIdNotMatch(self.conn_id, conn_id)); return Err(TunnelError::ConnIdNotMatch(self.conn_id, conn_id));
} }
if !self.ring_sender.has_empty_slot() { if let Err(e) = self.ring_sender.try_send(zc_packet) {
return Err(TunnelError::BufferFull); tracing::trace!(?e, "ring sender full, drop packet");
} }
self.ring_sender.push_no_check(zc_packet)?;
Ok(()) Ok(())
} }
} }
@ -294,8 +292,8 @@ impl UdpTunnelListenerData {
return; return;
} }
let ring_for_send_udp = Arc::new(RingTunnel::new(128)); let ring_for_send_udp = Arc::new(RingTunnel::new(32));
let ring_for_recv_udp = Arc::new(RingTunnel::new(128)); let ring_for_recv_udp = Arc::new(RingTunnel::new(32));
tracing::debug!( tracing::debug!(
?ring_for_send_udp, ?ring_for_send_udp,
?ring_for_recv_udp, ?ring_for_recv_udp,
@ -336,7 +334,7 @@ impl UdpTunnelListenerData {
if header.msg_type == UdpPacketType::Syn as u8 { if header.msg_type == UdpPacketType::Syn as u8 {
tokio::spawn(Self::handle_new_connect(self.clone(), addr, zc_packet)); tokio::spawn(Self::handle_new_connect(self.clone(), addr, zc_packet));
} else if header.msg_type != UdpPacketType::HolePunch as u8 { } else if header.msg_type != UdpPacketType::HolePunch as u8 {
let Some(conn) = self.sock_map.get(&addr) else { let Some(mut conn) = self.sock_map.get_mut(&addr) else {
tracing::trace!(?header, "udp forward packet error, connection not found"); tracing::trace!(?header, "udp forward packet error, connection not found");
return; return;
}; };
@ -569,7 +567,7 @@ impl UdpTunnelConnector {
let ring_recv = RingStream::new(ring_for_send_udp.clone()); let ring_recv = RingStream::new(ring_for_send_udp.clone());
let ring_sender = RingSink::new(ring_for_recv_udp.clone()); let ring_sender = RingSink::new(ring_for_recv_udp.clone());
let udp_conn = UdpConnection::new( let mut udp_conn = UdpConnection::new(
socket.clone(), socket.clone(),
conn_id, conn_id,
dst_addr, dst_addr,