Format code using 'cargo fmt'

pull/3/head
Atul Bhosale 5 years ago committed by Sebastian Dröge
parent 6cdf141a02
commit eb2c63ee73
  1. 2
      examples/autobahn-client.rs
  2. 4
      examples/autobahn-server.rs
  3. 2
      examples/client.rs
  4. 6
      examples/server.rs
  5. 8
      examples/split-client.rs
  6. 2
      src/compat.rs
  7. 4
      src/connect.rs
  8. 6
      src/handshake.rs
  9. 29
      src/lib.rs
  10. 15
      tests/communication.rs
  11. 2
      tests/handshakes.rs

@ -1,6 +1,6 @@
use async_tungstenite::{connect_async, tungstenite::Result};
use futures::StreamExt; use futures::StreamExt;
use log::*; use log::*;
use async_tungstenite::{connect_async, tungstenite::Result};
use url::Url; use url::Url;
const AGENT: &'static str = "Tungstenite"; const AGENT: &'static str = "Tungstenite";

@ -1,7 +1,7 @@
use async_std::net::{SocketAddr, TcpListener, TcpStream, ToSocketAddrs};
use async_tungstenite::accept_async;
use futures::StreamExt; use futures::StreamExt;
use log::*; use log::*;
use async_std::net::{TcpListener, TcpStream, SocketAddr, ToSocketAddrs};
use async_tungstenite::accept_async;
async fn accept_connection(peer: SocketAddr, stream: TcpStream) { async fn accept_connection(peer: SocketAddr, stream: TcpStream) {
let mut ws_stream = accept_async(stream).await.expect("Failed to accept"); let mut ws_stream = accept_async(stream).await.expect("Failed to accept");

@ -16,8 +16,8 @@ use futures::StreamExt;
use log::*; use log::*;
use tungstenite::protocol::Message; use tungstenite::protocol::Message;
use async_std::prelude::*;
use async_std::io; use async_std::io;
use async_std::prelude::*;
use async_std::task; use async_std::task;
use async_tungstenite::connect_async; use async_tungstenite::connect_async;

@ -20,12 +20,12 @@
use std::env; use std::env;
use std::io::Error; use std::io::Error;
use async_std::net::{SocketAddr, ToSocketAddrs};
use async_std::net::{TcpListener, TcpStream};
use async_std::task;
use futures::channel::mpsc::{UnboundedReceiver, UnboundedSender}; use futures::channel::mpsc::{UnboundedReceiver, UnboundedSender};
use futures::StreamExt; use futures::StreamExt;
use log::*; use log::*;
use async_std::task;
use async_std::net::{SocketAddr, ToSocketAddrs};
use async_std::net::{TcpListener, TcpStream};
use tungstenite::protocol::Message; use tungstenite::protocol::Message;
struct Connection { struct Connection {

@ -12,13 +12,13 @@
use std::env; use std::env;
use futures::{SinkExt, StreamExt};
use log::*;
use tungstenite::protocol::Message;
use async_std::prelude::*;
use async_std::io; use async_std::io;
use async_std::prelude::*;
use async_std::task; use async_std::task;
use async_tungstenite::connect_async; use async_tungstenite::connect_async;
use futures::{SinkExt, StreamExt};
use log::*;
use tungstenite::protocol::Message;
async fn run() { async fn run() {
let _ = env_logger::try_init(); let _ = env_logger::try_init();

@ -46,7 +46,7 @@ where
unsafe { unsafe {
if !self.context.0 { if !self.context.0 {
//was called by start_send without context //was called by start_send without context
return Poll::Pending return Poll::Pending;
} }
assert!(!self.context.1.is_null()); assert!(!self.context.1.is_null());
let waker = &mut *(self.context.1 as *mut _); let waker = &mut *(self.context.1 as *mut _);

@ -9,8 +9,8 @@ use super::{client_async, Request, WebSocketStream};
#[cfg(feature = "tls")] #[cfg(feature = "tls")]
pub(crate) mod encryption { pub(crate) mod encryption {
use async_tls::TlsConnector as AsyncTlsConnector;
use async_tls::client::TlsStream; use async_tls::client::TlsStream;
use async_tls::TlsConnector as AsyncTlsConnector;
use tungstenite::stream::Mode; use tungstenite::stream::Mode;
use tungstenite::Error; use tungstenite::Error;
@ -51,8 +51,8 @@ pub use self::encryption::MaybeTlsStream;
#[cfg(not(feature = "tls"))] #[cfg(not(feature = "tls"))]
pub(crate) mod encryption { pub(crate) mod encryption {
use futures::{future, Future};
use futures::io::{AsyncRead, AsyncWrite}; use futures::io::{AsyncRead, AsyncWrite};
use futures::{future, Future};
use tungstenite::stream::Mode; use tungstenite::stream::Mode;
use tungstenite::Error; use tungstenite::Error;

@ -1,12 +1,12 @@
use crate::compat::{AllowStd, HasContext}; use crate::compat::{AllowStd, HasContext};
use crate::WebSocketStream; use crate::WebSocketStream;
use futures::io::{AsyncRead, AsyncWrite};
use log::*; use log::*;
use pin_project::pin_project; use pin_project::pin_project;
use std::future::Future; use std::future::Future;
use std::io::{Read, Write}; use std::io::{Read, Write};
use std::pin::Pin; use std::pin::Pin;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use futures::io::{AsyncRead, AsyncWrite};
use tungstenite::handshake::client::Response; use tungstenite::handshake::client::Response;
use tungstenite::handshake::server::Callback; use tungstenite::handshake::server::Callback;
use tungstenite::handshake::{HandshakeError as Error, HandshakeRole, MidHandshake as WsHandshake}; use tungstenite::handshake::{HandshakeError as Error, HandshakeRole, MidHandshake as WsHandshake};
@ -165,7 +165,9 @@ where
let machine = s.get_mut(); let machine = s.get_mut();
trace!("Setting context in handshake"); trace!("Setting context in handshake");
machine.get_mut().set_context((true, cx as *mut _ as *mut ())); machine
.get_mut()
.set_context((true, cx as *mut _ as *mut ()));
match s.handshake() { match s.handshake() {
Ok(stream) => Poll::Ready(Ok(stream)), Ok(stream) => Poll::Ready(Ok(stream)),

@ -28,13 +28,13 @@ pub mod stream;
use std::io::{Read, Write}; use std::io::{Read, Write};
use compat::{cvt, AllowStd}; use compat::{cvt, AllowStd};
use futures::{Stream, Sink}; use futures::io::{AsyncRead, AsyncWrite};
use futures::{Sink, Stream};
use log::*; use log::*;
use pin_project::pin_project; use pin_project::pin_project;
use std::future::Future; use std::future::Future;
use std::pin::Pin; use std::pin::Pin;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use futures::io::{AsyncRead, AsyncWrite};
use tungstenite::{ use tungstenite::{
error::Error as WsError, error::Error as WsError,
@ -297,9 +297,9 @@ where
} }
impl<T> Sink<Message> for WebSocketStream<T> impl<T> Sink<Message> for WebSocketStream<T>
where where
T: AsyncRead + AsyncWrite + Unpin, T: AsyncRead + AsyncWrite + Unpin,
AllowStd<T>: Read + Write, AllowStd<T>: Read + Write,
{ {
type Error = WsError; type Error = WsError;
@ -310,7 +310,9 @@ impl<T> Sink<Message> for WebSocketStream<T>
fn start_send(mut self: Pin<&mut Self>, item: Message) -> Result<(), Self::Error> { fn start_send(mut self: Pin<&mut Self>, item: Message) -> Result<(), Self::Error> {
match (*self).with_context(None, |s| s.write_message(item)) { match (*self).with_context(None, |s| s.write_message(item)) {
Ok(()) => Ok(()), Ok(()) => Ok(()),
Err(::tungstenite::Error::Io(ref err)) if err.kind() == std::io::ErrorKind::WouldBlock => { Err(::tungstenite::Error::Io(ref err))
if err.kind() == std::io::ErrorKind::WouldBlock =>
{
// the message was accepted and queued // the message was accepted and queued
// isn't an error. // isn't an error.
Ok(()) Ok(())
@ -354,7 +356,10 @@ where
fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> { fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
let this = self.project(); let this = self.project();
let message = this.message.take().expect("Cannot poll twice"); let message = this.message.take().expect("Cannot poll twice");
Poll::Ready(this.stream.with_context(Some(cx), |s| s.write_message(message))) Poll::Ready(
this.stream
.with_context(Some(cx), |s| s.write_message(message)),
)
} }
} }
@ -381,11 +386,11 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use crate::compat::AllowStd; use crate::compat::AllowStd;
#[cfg(feature="connect")] #[cfg(feature = "connect")]
use crate::connect::encryption::AutoStream; use crate::connect::encryption::AutoStream;
use crate::WebSocketStream; use crate::WebSocketStream;
use std::io::{Read, Write};
use futures::io::{AsyncReadExt, AsyncWriteExt}; use futures::io::{AsyncReadExt, AsyncWriteExt};
use std::io::{Read, Write};
fn is_read<T: Read>() {} fn is_read<T: Read>() {}
fn is_write<T: Write>() {} fn is_write<T: Write>() {}
@ -398,13 +403,13 @@ mod tests {
is_read::<AllowStd<async_std::net::TcpStream>>(); is_read::<AllowStd<async_std::net::TcpStream>>();
is_write::<AllowStd<async_std::net::TcpStream>>(); is_write::<AllowStd<async_std::net::TcpStream>>();
#[cfg(feature="connect")] #[cfg(feature = "connect")]
is_async_read::<AutoStream<async_std::net::TcpStream>>(); is_async_read::<AutoStream<async_std::net::TcpStream>>();
#[cfg(feature="connect")] #[cfg(feature = "connect")]
is_async_write::<AutoStream<async_std::net::TcpStream>>(); is_async_write::<AutoStream<async_std::net::TcpStream>>();
is_unpin::<WebSocketStream<async_std::net::TcpStream>>(); is_unpin::<WebSocketStream<async_std::net::TcpStream>>();
#[cfg(feature="connect")] #[cfg(feature = "connect")]
is_unpin::<WebSocketStream<AutoStream<async_std::net::TcpStream>>>(); is_unpin::<WebSocketStream<AutoStream<async_std::net::TcpStream>>>();
} }
} }

@ -1,8 +1,8 @@
use futures::{SinkExt, StreamExt, AsyncRead, AsyncWrite};
use log::*;
use async_std::task;
use async_std::net::{TcpListener, TcpStream, ToSocketAddrs}; use async_std::net::{TcpListener, TcpStream, ToSocketAddrs};
use async_std::task;
use async_tungstenite::{accept_async, client_async, WebSocketStream}; use async_tungstenite::{accept_async, client_async, WebSocketStream};
use futures::{AsyncRead, AsyncWrite, SinkExt, StreamExt};
use log::*;
use tungstenite::Message; use tungstenite::Message;
async fn run_connection<S>( async fn run_connection<S>(
@ -67,7 +67,10 @@ async fn communication() {
for i in 1..10 { for i in 1..10 {
info!("Sending message"); info!("Sending message");
stream.send(Message::Text(format!("{}", i))).await.expect("Failed to send message"); stream
.send(Message::Text(format!("{}", i)))
.await
.expect("Failed to send message");
} }
stream.close(None).await.expect("Failed to close"); stream.close(None).await.expect("Failed to close");
@ -123,7 +126,9 @@ async fn split_communication() {
for i in 1..10 { for i in 1..10 {
info!("Sending message"); info!("Sending message");
tx.send(Message::Text(format!("{}", i))).await.expect("Failed to send message"); tx.send(Message::Text(format!("{}", i)))
.await
.expect("Failed to send message");
} }
tx.close().await.expect("Failed to close"); tx.close().await.expect("Failed to close");

@ -1,5 +1,5 @@
use async_std::task;
use async_std::net::{TcpListener, TcpStream, ToSocketAddrs}; use async_std::net::{TcpListener, TcpStream, ToSocketAddrs};
use async_std::task;
use async_tungstenite::{accept_async, client_async}; use async_tungstenite::{accept_async, client_async};
#[async_std::test] #[async_std::test]

Loading…
Cancel
Save