|
@@ -1,73 +1,80 @@
|
|
|
use crate::{
|
|
|
- message::{ActorMessage, Envelope},
|
|
|
- runtime::Runtime,
|
|
|
- Actor, ActorCommand, ActorHandle, ActorStatus, Error, Handler,
|
|
|
+ message::Envelope, runtime::Runtime, Actor, ActorCommand, ActorHandle, ActorStatus, Error,
|
|
|
+ Handler, Hello,
|
|
|
};
|
|
|
use async_trait::async_trait;
|
|
|
use flume::Receiver;
|
|
|
use futures::{
|
|
|
- sink::Feed,
|
|
|
stream::{SplitSink, SplitStream},
|
|
|
Future, SinkExt, Stream, StreamExt,
|
|
|
};
|
|
|
-use parking_lot::Mutex;
|
|
|
use pin_project::pin_project;
|
|
|
use std::{
|
|
|
collections::VecDeque,
|
|
|
pin::Pin,
|
|
|
sync::atomic::AtomicUsize,
|
|
|
task::{Context, Poll},
|
|
|
+ time::Duration,
|
|
|
};
|
|
|
-use std::{sync::Arc, time::Duration};
|
|
|
+use std::{sync::Arc, task::ready};
|
|
|
+use tokio::sync::Mutex;
|
|
|
use warp::ws::{Message, WebSocket};
|
|
|
|
|
|
+const WS_QUEUE_SIZE: usize = 128;
|
|
|
+
|
|
|
pub struct WebsocketActor {
|
|
|
websocket: Option<WebSocket>,
|
|
|
+ hello: ActorHandle<Hello>,
|
|
|
}
|
|
|
|
|
|
impl WebsocketActor {
|
|
|
- pub fn new(ws: WebSocket) -> Self {
|
|
|
+ pub fn new(ws: WebSocket, handle: ActorHandle<Hello>) -> Self {
|
|
|
Self {
|
|
|
websocket: Some(ws),
|
|
|
+ hello: handle,
|
|
|
}
|
|
|
}
|
|
|
}
|
|
|
|
|
|
+#[async_trait]
|
|
|
impl Actor for WebsocketActor {
|
|
|
- fn start(self) -> ActorHandle<Self> {
|
|
|
- WebsocketRuntime::run(Arc::new(Mutex::new(self)))
|
|
|
+ async fn start(self) -> ActorHandle<Self> {
|
|
|
+ WebsocketRuntime::run(Arc::new(Mutex::new(self))).await
|
|
|
}
|
|
|
}
|
|
|
type WsFuture = Pin<Box<dyn Future<Output = Result<Option<Message>, Error>> + Send>>;
|
|
|
|
|
|
struct ActorItem {
|
|
|
- message: Option<Message>,
|
|
|
+ message: Option<Box<Message>>,
|
|
|
future: Option<WsFuture>,
|
|
|
}
|
|
|
|
|
|
impl ActorItem {
|
|
|
+ pub fn new(message: Message) -> Self {
|
|
|
+ Self {
|
|
|
+ message: Some(Box::new(message)),
|
|
|
+ future: None,
|
|
|
+ }
|
|
|
+ }
|
|
|
+
|
|
|
fn poll(
|
|
|
mut self: Pin<&mut Self>,
|
|
|
actor: Arc<Mutex<WebsocketActor>>,
|
|
|
cx: &mut std::task::Context<'_>,
|
|
|
) -> Poll<Result<Option<Message>, warp::Error>> {
|
|
|
- // let mut this = self.project();
|
|
|
let message = self.as_mut().message.take();
|
|
|
|
|
|
match message {
|
|
|
Some(message) => {
|
|
|
let fut = WebsocketActor::handle(actor, message);
|
|
|
self.future = Some(fut);
|
|
|
- // let Some(ref mut fut) = self.future else {panic!("Rust no longer works")};
|
|
|
- match self.future.as_mut().unwrap().as_mut().poll(cx) {
|
|
|
- Poll::Ready(result) => match result {
|
|
|
- Ok(response) => Poll::Ready(Ok(response)),
|
|
|
- Err(e) => {
|
|
|
- println!("Shit's fucked son {e}");
|
|
|
- Poll::Ready(Ok(None))
|
|
|
- }
|
|
|
- },
|
|
|
- Poll::Pending => Poll::Pending,
|
|
|
+ let result = ready!(self.future.as_mut().unwrap().as_mut().poll(cx));
|
|
|
+ match result {
|
|
|
+ Ok(response) => Poll::Ready(Ok(response)),
|
|
|
+ Err(e) => {
|
|
|
+ println!("Shit's fucked son {e}");
|
|
|
+ Poll::Ready(Ok(None))
|
|
|
+ }
|
|
|
}
|
|
|
}
|
|
|
None => match self.future {
|
|
@@ -79,59 +86,20 @@ impl ActorItem {
|
|
|
Poll::Ready(Ok(None))
|
|
|
}
|
|
|
},
|
|
|
- Poll::Pending => Poll::Pending,
|
|
|
- },
|
|
|
- None => Poll::Pending,
|
|
|
- },
|
|
|
- }
|
|
|
- }
|
|
|
-}
|
|
|
-
|
|
|
-impl ActorItem {
|
|
|
- pub fn new(message: Message) -> Self {
|
|
|
- Self {
|
|
|
- message: Some(message),
|
|
|
- future: None,
|
|
|
- }
|
|
|
- }
|
|
|
-}
|
|
|
-/*
|
|
|
-trait WsActorFuture {
|
|
|
- fn poll(
|
|
|
- self: Pin<&mut Self>,
|
|
|
- actor: &mut WebsocketActor,
|
|
|
- sink: Pin<&mut SplitSink<WebSocket, Message>>,
|
|
|
- cx: &mut std::task::Context<'_>,
|
|
|
- ) -> Poll<Result<(), warp::Error>>;
|
|
|
-}
|
|
|
-
|
|
|
-impl WsActorFuture for Message {
|
|
|
- fn poll(
|
|
|
- mut self: Pin<&mut Self>,
|
|
|
- actor: &mut WebsocketActor,
|
|
|
- mut sink: Pin<&mut SplitSink<WebSocket, Message>>,
|
|
|
- cx: &mut std::task::Context<'_>,
|
|
|
- ) -> Poll<Result<(), warp::Error>> {
|
|
|
- match actor.handle(self.as_mut().clone()).as_mut().poll(cx) {
|
|
|
- Poll::Ready(result) => match result {
|
|
|
- Ok(response) => {
|
|
|
- if let Some(response) = response {
|
|
|
- Pin::new(&mut sink.feed(response)).poll(cx)
|
|
|
- } else {
|
|
|
+ Poll::Pending => {
|
|
|
+ PENDING.fetch_add(1, std::sync::atomic::Ordering::AcqRel);
|
|
|
+ // println!("Websocket Future pending - COUNT {PENDING:?}");
|
|
|
Poll::Pending
|
|
|
}
|
|
|
- }
|
|
|
- Err(e) => {
|
|
|
- println!("Shit's fucked son {e}");
|
|
|
- Poll::Ready(Ok(()))
|
|
|
- }
|
|
|
+ },
|
|
|
+ None => panic!("Impossibru"),
|
|
|
},
|
|
|
- Poll::Pending => Poll::Pending,
|
|
|
}
|
|
|
}
|
|
|
}
|
|
|
- */
|
|
|
+
|
|
|
static PROCESSED: AtomicUsize = AtomicUsize::new(0);
|
|
|
+static PENDING: AtomicUsize = AtomicUsize::new(0);
|
|
|
|
|
|
#[pin_project]
|
|
|
pub struct WebsocketRuntime {
|
|
@@ -164,13 +132,14 @@ pub struct WebsocketRuntime {
|
|
|
}
|
|
|
|
|
|
impl WebsocketRuntime {
|
|
|
- pub fn new(
|
|
|
+ pub async fn new(
|
|
|
actor: Arc<Mutex<WebsocketActor>>,
|
|
|
command_rx: Receiver<ActorCommand>,
|
|
|
message_rx: Receiver<Envelope<WebsocketActor>>,
|
|
|
) -> Self {
|
|
|
let (ws_sink, ws_stream) = actor
|
|
|
.lock()
|
|
|
+ .await
|
|
|
.websocket
|
|
|
.take()
|
|
|
.expect("Websocket runtime already started")
|
|
@@ -196,28 +165,31 @@ impl Future for WebsocketRuntime {
|
|
|
fn poll(self: std::pin::Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
|
|
let mut this = self.project();
|
|
|
|
|
|
- loop {
|
|
|
- // Poll command receiver and immediatelly process it
|
|
|
- match Pin::new(&mut this.command_rx.recv_async()).poll(cx) {
|
|
|
- Poll::Ready(Ok(message)) => match message {
|
|
|
- ActorCommand::Stop => {
|
|
|
- println!("Actor stopping");
|
|
|
- break Poll::Ready(Ok(())); // TODO drain the queue and all that graceful stuff
|
|
|
+ // Poll command receiver and immediatelly process it
|
|
|
+ if let Poll::Ready(result) = Pin::new(&mut this.command_rx.recv_async()).poll(cx) {
|
|
|
+ match result {
|
|
|
+ Ok(command) => {
|
|
|
+ match command {
|
|
|
+ ActorCommand::Stop => {
|
|
|
+ println!("Actor stopping");
|
|
|
+ return Poll::Ready(Ok(())); // TODO drain the queue and all that graceful stuff
|
|
|
+ }
|
|
|
}
|
|
|
- },
|
|
|
- Poll::Ready(Err(_)) => {
|
|
|
- println!("Actor stopping"); // TODO drain the queue and all that graceful stuff
|
|
|
- break Poll::Ready(Err(Error::ActorChannelClosed));
|
|
|
}
|
|
|
- Poll::Pending => {}
|
|
|
- };
|
|
|
+ Err(e) => {
|
|
|
+ println!("Actor stopping - {e}"); // TODO drain the queue and all that graceful stuff
|
|
|
+ return Poll::Ready(Err(Error::ActorChannelClosed));
|
|
|
+ }
|
|
|
+ }
|
|
|
+ };
|
|
|
|
|
|
- // Poll the websocket stream for any messages and store them to the queue
|
|
|
+ // Poll the websocket stream for any messages and store them to the queue
|
|
|
+ if this.processing_queue.is_empty() {
|
|
|
while let Poll::Ready(Some(ws_message)) = this.ws_stream.as_mut().poll_next(cx) {
|
|
|
match ws_message {
|
|
|
Ok(message) => {
|
|
|
this.processing_queue.push_back(ActorItem::new(message));
|
|
|
- if this.processing_queue.len() > 500 {
|
|
|
+ if this.processing_queue.len() >= WS_QUEUE_SIZE {
|
|
|
break;
|
|
|
}
|
|
|
}
|
|
@@ -226,79 +198,70 @@ impl Future for WebsocketRuntime {
|
|
|
}
|
|
|
}
|
|
|
}
|
|
|
+ }
|
|
|
|
|
|
- let mut idx = 0;
|
|
|
- // let actor = &mut this.actor.lock();
|
|
|
- while idx < this.processing_queue.len() {
|
|
|
- let job = &mut this.processing_queue[idx];
|
|
|
- match ActorItem::poll(Pin::new(job), this.actor.clone(), cx) {
|
|
|
- Poll::Ready(result) => match result {
|
|
|
- Ok(response) => {
|
|
|
- if let Some(response) = response {
|
|
|
- let feed = &mut this.ws_sink.feed(response);
|
|
|
- let mut feed = Pin::new(feed);
|
|
|
- while feed.as_mut().poll(cx).is_pending() {
|
|
|
- let _ = feed.as_mut().poll(cx);
|
|
|
- }
|
|
|
- }
|
|
|
- PROCESSED.fetch_add(1, std::sync::atomic::Ordering::Acquire);
|
|
|
- this.processing_queue.swap_remove_front(idx);
|
|
|
- }
|
|
|
- Err(e) => {
|
|
|
- println!("Shit's fucked my dude {e}")
|
|
|
+ let mut idx = 0;
|
|
|
+ while idx < this.processing_queue.len() {
|
|
|
+ let job = Pin::new(&mut this.processing_queue[idx]);
|
|
|
+ match ActorItem::poll(job, this.actor.clone(), cx) {
|
|
|
+ Poll::Ready(result) => match result {
|
|
|
+ Ok(response) => {
|
|
|
+ if let Some(response) = response {
|
|
|
+ let feed = &mut this.ws_sink.feed(response);
|
|
|
+ let mut feed = Pin::new(feed);
|
|
|
+ let _ = feed.as_mut().poll(cx);
|
|
|
}
|
|
|
- },
|
|
|
- Poll::Pending => idx += 1,
|
|
|
- }
|
|
|
+ PROCESSED.fetch_add(1, std::sync::atomic::Ordering::Acquire);
|
|
|
+ this.processing_queue.swap_remove_front(idx);
|
|
|
+ }
|
|
|
+ Err(e) => {
|
|
|
+ println!("Shit's fucked my dude {e}")
|
|
|
+ }
|
|
|
+ },
|
|
|
+ Poll::Pending => idx += 1,
|
|
|
}
|
|
|
+ }
|
|
|
|
|
|
- println!(
|
|
|
- "PROCESSED {} CURRENT IN QUEUE {}",
|
|
|
- PROCESSED.load(std::sync::atomic::Ordering::Acquire),
|
|
|
- this.processing_queue.len(),
|
|
|
- );
|
|
|
+ // println!(
|
|
|
+ // "PROCESSED {} CURRENT IN QUEUE {}",
|
|
|
+ // PROCESSED.load(std::sync::atomic::Ordering::Acquire),
|
|
|
+ // this.processing_queue.len(),
|
|
|
+ // );
|
|
|
|
|
|
- let _ = Pin::new(&mut this.ws_sink.flush()).poll(cx);
|
|
|
+ let _ = Pin::new(&mut this.ws_sink.flush()).poll(cx);
|
|
|
|
|
|
- // Process all messages
|
|
|
- /* this.message_queue
|
|
|
- .retain_mut(|message| message.handle(actor).as_mut().poll(cx).is_pending()); */
|
|
|
+ // Process all messages
|
|
|
+ /* this.message_queue
|
|
|
+ .retain_mut(|message| message.handle(actor).as_mut().poll(cx).is_pending()); */
|
|
|
+
|
|
|
+ // Poll message receiver and continue to process if anything comes up
|
|
|
+ while let Poll::Ready(Ok(message)) = Pin::new(&mut this.message_rx.recv_async()).poll(cx) {
|
|
|
+ this.message_queue.push_back(message);
|
|
|
+ }
|
|
|
|
|
|
- // Poll message receiver and continue to process if anything comes up
|
|
|
- while let Poll::Ready(Ok(message)) =
|
|
|
- Pin::new(&mut this.message_rx.recv_async()).poll(cx)
|
|
|
- {
|
|
|
+ // Poll again and process new messages if any
|
|
|
+ match Pin::new(&mut this.message_rx.recv_async()).poll(cx) {
|
|
|
+ Poll::Ready(Ok(message)) => {
|
|
|
this.message_queue.push_back(message);
|
|
|
}
|
|
|
+ Poll::Ready(Err(_)) => {
|
|
|
+ println!("Message channel closed, ungracefully stopping actor");
|
|
|
+ return Poll::Ready(Err(Error::ActorChannelClosed));
|
|
|
+ }
|
|
|
+ Poll::Pending => {}
|
|
|
+ };
|
|
|
|
|
|
- // Poll again and process new messages if any
|
|
|
- match Pin::new(&mut this.message_rx.recv_async()).poll(cx) {
|
|
|
- Poll::Ready(Ok(message)) => {
|
|
|
- this.message_queue.push_back(message);
|
|
|
- continue;
|
|
|
- }
|
|
|
- Poll::Ready(Err(_)) => {
|
|
|
- println!("Message channel closed, ungracefully stopping actor");
|
|
|
- break Poll::Ready(Err(Error::ActorChannelClosed));
|
|
|
- }
|
|
|
- Poll::Pending => {
|
|
|
- if !this.message_queue.is_empty() {
|
|
|
- continue;
|
|
|
- }
|
|
|
- }
|
|
|
- };
|
|
|
-
|
|
|
- cx.waker().wake_by_ref();
|
|
|
- return Poll::Pending;
|
|
|
- }
|
|
|
+ cx.waker().wake_by_ref();
|
|
|
+ Poll::Pending
|
|
|
}
|
|
|
}
|
|
|
|
|
|
+#[async_trait]
|
|
|
impl Runtime<WebsocketActor> for WebsocketRuntime {
|
|
|
- fn run(actor: Arc<Mutex<WebsocketActor>>) -> ActorHandle<WebsocketActor> {
|
|
|
+ async fn run(actor: Arc<Mutex<WebsocketActor>>) -> ActorHandle<WebsocketActor> {
|
|
|
let (message_tx, message_rx) = flume::unbounded();
|
|
|
let (command_tx, command_rx) = flume::unbounded();
|
|
|
- tokio::spawn(WebsocketRuntime::new(actor, command_rx, message_rx));
|
|
|
+ tokio::spawn(WebsocketRuntime::new(actor, command_rx, message_rx).await);
|
|
|
ActorHandle::new(message_tx, command_tx)
|
|
|
}
|
|
|
}
|
|
@@ -311,12 +274,21 @@ impl crate::Message for Message {
|
|
|
impl Handler<Message> for WebsocketActor {
|
|
|
async fn handle(
|
|
|
this: Arc<Mutex<Self>>,
|
|
|
- message: Message,
|
|
|
+ message: Box<Message>,
|
|
|
) -> Result<<Message as crate::message::Message>::Response, crate::Error> {
|
|
|
- println!("Actor received message {message:?}");
|
|
|
- // tokio::time::sleep(Duration::from_micros(500)).await;
|
|
|
+ //let mut act = this.lock().await;
|
|
|
+ this.lock()
|
|
|
+ .await
|
|
|
+ .hello
|
|
|
+ .send(crate::Msg {
|
|
|
+ content: message.to_str().unwrap().to_owned(),
|
|
|
+ })
|
|
|
+ .unwrap_or_else(|e| println!("{e}"));
|
|
|
+ // println!("Actor retreived lock and sent message got response {res}");
|
|
|
+ tokio::time::sleep(Duration::from_micros(1)).await;
|
|
|
+ //act.wait().await;
|
|
|
if message.is_text() {
|
|
|
- Ok(Some(message))
|
|
|
+ Ok(Some(*message.clone()))
|
|
|
} else {
|
|
|
Ok(None)
|
|
|
}
|