LCOV - code coverage report
Current view: top level - proxy/src/serverless - websocket.rs (source / functions) Coverage Total Hit
Test: b4ae4c4857f9ef3e144e982a35ee23bc84c71983.info Lines: 61.9 % 139 86
Test Date: 2024-10-22 22:13:45 Functions: 38.5 % 26 10

            Line data    Source code
       1              : use std::pin::Pin;
       2              : use std::sync::Arc;
       3              : use std::task::{ready, Context, Poll};
       4              : 
       5              : use anyhow::Context as _;
       6              : use bytes::{Buf, BufMut, Bytes, BytesMut};
       7              : use framed_websockets::{Frame, OpCode, WebSocketServer};
       8              : use futures::{Sink, Stream};
       9              : use hyper::upgrade::OnUpgrade;
      10              : use hyper_util::rt::TokioIo;
      11              : use pin_project_lite::pin_project;
      12              : use tokio::io::{self, AsyncBufRead, AsyncRead, AsyncWrite, ReadBuf};
      13              : use tracing::warn;
      14              : 
      15              : use crate::cancellation::CancellationHandlerMain;
      16              : use crate::config::ProxyConfig;
      17              : use crate::context::RequestMonitoring;
      18              : use crate::error::{io_error, ReportableError};
      19              : use crate::metrics::Metrics;
      20              : use crate::proxy::{handle_client, ClientMode, ErrorSource};
      21              : use crate::rate_limiter::EndpointRateLimiter;
      22              : 
      23              : pin_project! {
      24              :     /// This is a wrapper around a [`WebSocketStream`] that
      25              :     /// implements [`AsyncRead`] and [`AsyncWrite`].
      26              :     pub(crate) struct WebSocketRw<S> {
      27              :         #[pin]
      28              :         stream: WebSocketServer<S>,
      29              :         recv: Bytes,
      30              :         send: BytesMut,
      31              :     }
      32              : }
      33              : 
      34              : impl<S> WebSocketRw<S> {
      35            1 :     pub(crate) fn new(stream: WebSocketServer<S>) -> Self {
      36            1 :         Self {
      37            1 :             stream,
      38            1 :             recv: Bytes::new(),
      39            1 :             send: BytesMut::new(),
      40            1 :         }
      41            1 :     }
      42              : }
      43              : 
      44              : impl<S: AsyncRead + AsyncWrite + Unpin> AsyncWrite for WebSocketRw<S> {
      45            1 :     fn poll_write(
      46            1 :         self: Pin<&mut Self>,
      47            1 :         cx: &mut Context<'_>,
      48            1 :         buf: &[u8],
      49            1 :     ) -> Poll<io::Result<usize>> {
      50            1 :         let this = self.project();
      51            1 :         let mut stream = this.stream;
      52              : 
      53            1 :         ready!(stream.as_mut().poll_ready(cx).map_err(io_error))?;
      54              : 
      55            1 :         this.send.put(buf);
      56            1 :         match stream.as_mut().start_send(Frame::binary(this.send.split())) {
      57            1 :             Ok(()) => Poll::Ready(Ok(buf.len())),
      58            0 :             Err(e) => Poll::Ready(Err(io_error(e))),
      59              :         }
      60            1 :     }
      61              : 
      62            1 :     fn poll_flush(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<io::Result<()>> {
      63            1 :         let stream = self.project().stream;
      64            1 :         stream.poll_flush(cx).map_err(io_error)
      65            1 :     }
      66              : 
      67            0 :     fn poll_shutdown(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<io::Result<()>> {
      68            0 :         let stream = self.project().stream;
      69            0 :         stream.poll_close(cx).map_err(io_error)
      70            0 :     }
      71              : }
      72              : 
      73              : impl<S: AsyncRead + AsyncWrite + Unpin> AsyncRead for WebSocketRw<S> {
      74            3 :     fn poll_read(
      75            3 :         mut self: Pin<&mut Self>,
      76            3 :         cx: &mut Context<'_>,
      77            3 :         buf: &mut ReadBuf<'_>,
      78            3 :     ) -> Poll<io::Result<()>> {
      79            3 :         let bytes = ready!(self.as_mut().poll_fill_buf(cx))?;
      80            2 :         let len = std::cmp::min(bytes.len(), buf.remaining());
      81            2 :         buf.put_slice(&bytes[..len]);
      82            2 :         self.consume(len);
      83            2 :         Poll::Ready(Ok(()))
      84            3 :     }
      85              : }
      86              : 
      87              : impl<S: AsyncRead + AsyncWrite + Unpin> AsyncBufRead for WebSocketRw<S> {
      88            3 :     fn poll_fill_buf(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<io::Result<&[u8]>> {
      89              :         // Please refer to poll_fill_buf's documentation.
      90              :         const EOF: Poll<io::Result<&[u8]>> = Poll::Ready(Ok(&[]));
      91              : 
      92            3 :         let mut this = self.project();
      93              :         loop {
      94            4 :             if !this.recv.chunk().is_empty() {
      95            1 :                 let chunk = (*this.recv).chunk();
      96            1 :                 return Poll::Ready(Ok(chunk));
      97            3 :             }
      98              : 
      99            3 :             let res = ready!(this.stream.as_mut().poll_next(cx));
     100            2 :             match res.transpose().map_err(io_error)? {
     101            2 :                 Some(message) => match message.opcode {
     102            0 :                     OpCode::Ping => {}
     103            0 :                     OpCode::Pong => {}
     104              :                     OpCode::Text => {
     105              :                         // We expect to see only binary messages.
     106            0 :                         let error = "unexpected text message in the websocket";
     107            0 :                         warn!(length = message.payload.len(), error);
     108            0 :                         return Poll::Ready(Err(io_error(error)));
     109              :                     }
     110              :                     OpCode::Binary | OpCode::Continuation => {
     111            1 :                         debug_assert!(this.recv.is_empty());
     112            1 :                         *this.recv = message.payload.freeze();
     113              :                     }
     114            1 :                     OpCode::Close => return EOF,
     115              :                 },
     116            0 :                 None => return EOF,
     117              :             }
     118              :         }
     119            3 :     }
     120              : 
     121            2 :     fn consume(self: Pin<&mut Self>, amount: usize) {
     122            2 :         self.project().recv.advance(amount);
     123            2 :     }
     124              : }
     125              : 
     126            0 : pub(crate) async fn serve_websocket(
     127            0 :     config: &'static ProxyConfig,
     128            0 :     auth_backend: &'static crate::auth::Backend<'static, ()>,
     129            0 :     ctx: RequestMonitoring,
     130            0 :     websocket: OnUpgrade,
     131            0 :     cancellation_handler: Arc<CancellationHandlerMain>,
     132            0 :     endpoint_rate_limiter: Arc<EndpointRateLimiter>,
     133            0 :     hostname: Option<String>,
     134            0 : ) -> anyhow::Result<()> {
     135            0 :     let websocket = websocket.await?;
     136            0 :     let websocket = WebSocketServer::after_handshake(TokioIo::new(websocket));
     137            0 : 
     138            0 :     let conn_gauge = Metrics::get()
     139            0 :         .proxy
     140            0 :         .client_connections
     141            0 :         .guard(crate::metrics::Protocol::Ws);
     142              : 
     143            0 :     let res = Box::pin(handle_client(
     144            0 :         config,
     145            0 :         auth_backend,
     146            0 :         &ctx,
     147            0 :         cancellation_handler,
     148            0 :         WebSocketRw::new(websocket),
     149            0 :         ClientMode::Websockets { hostname },
     150            0 :         endpoint_rate_limiter,
     151            0 :         conn_gauge,
     152            0 :     ))
     153            0 :     .await;
     154              : 
     155            0 :     match res {
     156            0 :         Err(e) => {
     157            0 :             // todo: log and push to ctx the error kind
     158            0 :             ctx.set_error_kind(e.get_error_kind());
     159            0 :             Err(e.into())
     160              :         }
     161              :         Ok(None) => {
     162            0 :             ctx.set_success();
     163            0 :             Ok(())
     164              :         }
     165            0 :         Ok(Some(p)) => {
     166            0 :             ctx.set_success();
     167            0 :             ctx.log_connect();
     168            0 :             match p.proxy_pass().await {
     169            0 :                 Ok(()) => Ok(()),
     170            0 :                 Err(ErrorSource::Client(err)) => Err(err).context("client"),
     171            0 :                 Err(ErrorSource::Compute(err)) => Err(err).context("compute"),
     172              :             }
     173              :         }
     174              :     }
     175            0 : }
     176              : 
     177              : #[cfg(test)]
     178              : mod tests {
     179              :     use std::pin::pin;
     180              : 
     181              :     use framed_websockets::WebSocketServer;
     182              :     use futures::{SinkExt, StreamExt};
     183              :     use tokio::io::{duplex, AsyncReadExt, AsyncWriteExt};
     184              :     use tokio::task::JoinSet;
     185              :     use tokio_tungstenite::tungstenite::protocol::Role;
     186              :     use tokio_tungstenite::tungstenite::Message;
     187              :     use tokio_tungstenite::WebSocketStream;
     188              : 
     189              :     use super::WebSocketRw;
     190              : 
     191              :     #[tokio::test]
     192            1 :     async fn websocket_stream_wrapper_happy_path() {
     193            1 :         let (stream1, stream2) = duplex(1024);
     194            1 : 
     195            1 :         let mut js = JoinSet::new();
     196            1 : 
     197            1 :         js.spawn(async move {
     198            1 :             let mut client = WebSocketStream::from_raw_socket(stream1, Role::Client, None).await;
     199            1 : 
     200            1 :             client
     201            1 :                 .send(Message::Binary(b"hello world".to_vec()))
     202            1 :                 .await
     203            1 :                 .unwrap();
     204            1 : 
     205            1 :             let message = client.next().await.unwrap().unwrap();
     206            1 :             assert_eq!(message, Message::Binary(b"websockets are cool".to_vec()));
     207            1 : 
     208            1 :             client.close(None).await.unwrap();
     209            1 :         });
     210            1 : 
     211            1 :         js.spawn(async move {
     212            1 :             let mut rw = pin!(WebSocketRw::new(WebSocketServer::after_handshake(stream2)));
     213            1 : 
     214            1 :             let mut buf = vec![0; 1024];
     215            1 :             let n = rw.read(&mut buf).await.unwrap();
     216            1 :             assert_eq!(&buf[..n], b"hello world");
     217            1 : 
     218            1 :             rw.write_all(b"websockets are cool").await.unwrap();
     219            1 :             rw.flush().await.unwrap();
     220            1 : 
     221            1 :             let n = rw.read_to_end(&mut buf).await.unwrap();
     222            1 :             assert_eq!(n, 0);
     223            1 :         });
     224            1 : 
     225            1 :         js.join_next().await.unwrap().unwrap();
     226            1 :         js.join_next().await.unwrap().unwrap();
     227            1 :     }
     228              : }
        

Generated by: LCOV version 2.1-beta