Revert "fix(ext/flash): graceful server startup/shutdown with unsettl… (#16839)

…ed promises in mind (#16616)"

This reverts commit fd023cf793.

There are reports saying that Vite is often hanging in 1.28.2 and this
is
the only PR that changed something with HTTP server. I think we should
hold off on trying to fix this and instead focus on #16787

CC @magurotuna
This commit is contained in:
Bartek Iwańczuk 2022-11-27 04:50:14 +01:00 committed by GitHub
parent 95fb4b886b
commit 0012484f4f
No known key found for this signature in database
GPG key ID: 4AEE18F83AFDEB23
6 changed files with 148 additions and 305 deletions

View file

@ -57,42 +57,32 @@ Deno.test(async function httpServerCanResolveHostnames() {
await server;
});
// TODO(magurotuna): ignore this case for now because it's flaky on GitHub Actions,
// although it acts as expected when running locally.
// See https://github.com/denoland/deno/pull/16616
Deno.test({ ignore: true }, async function httpServerRejectsOnAddrInUse() {
const ac1 = new AbortController();
Deno.test(async function httpServerRejectsOnAddrInUse() {
const ac = new AbortController();
const listeningPromise = deferred();
let port: number;
const server = Deno.serve({
handler: (_req) => new Response("ok"),
hostname: "localhost",
port: 0,
signal: ac1.signal,
onListen: (addr) => {
port = addr.port;
listeningPromise.resolve();
},
onError: createOnErrorCb(ac1),
port: 4501,
signal: ac.signal,
onListen: onListen(listeningPromise),
onError: createOnErrorCb(ac),
});
await listeningPromise;
const ac2 = new AbortController();
assertRejects(
() =>
Deno.serve({
handler: (_req) => new Response("ok"),
hostname: "localhost",
port,
signal: ac2.signal,
port: 4501,
signal: ac.signal,
onListen: onListen(listeningPromise),
onError: createOnErrorCb(ac),
}),
Deno.errors.AddrInUse,
);
ac1.abort();
ac2.abort();
ac.abort();
await server;
});

View file

@ -1179,69 +1179,4 @@ mod watcher {
check_alive_then_kill(child);
}
// https://github.com/denoland/deno/issues/16267
#[test]
fn run_watch_flash() {
let filename = "watch_flash.js";
let t = TempDir::new();
let file_to_watch = t.path().join(filename);
write(
&file_to_watch,
r#"
console.log("Starting flash server...");
Deno.serve({
onListen() {
console.error("First server is listening");
},
handler: () => {},
port: 4601,
});
"#,
)
.unwrap();
let mut child = util::deno_cmd()
.current_dir(t.path())
.arg("run")
.arg("--watch")
.arg("--unstable")
.arg("--allow-net")
.arg("-L")
.arg("debug")
.arg(&file_to_watch)
.env("NO_COLOR", "1")
.stdout(std::process::Stdio::piped())
.stderr(std::process::Stdio::piped())
.spawn()
.unwrap();
let (mut stdout_lines, mut stderr_lines) = child_lines(&mut child);
wait_contains("Starting flash server...", &mut stdout_lines);
wait_for(
|m| m.contains("Watching paths") && m.contains(filename),
&mut stderr_lines,
);
write(
&file_to_watch,
r#"
console.log("Restarting flash server...");
Deno.serve({
onListen() {
console.error("Second server is listening");
},
handler: () => {},
port: 4601,
});
"#,
)
.unwrap();
wait_contains("File change detected! Restarting!", &mut stderr_lines);
wait_contains("Restarting flash server...", &mut stdout_lines);
wait_contains("Second server is listening", &mut stderr_lines);
check_alive_then_kill(child);
}
}

View file

@ -188,8 +188,8 @@
return str;
}
function prepareFastCalls(serverId) {
return core.ops.op_flash_make_request(serverId);
function prepareFastCalls() {
return core.ops.op_flash_make_request();
}
function hostnameForDisplay(hostname) {
@ -495,11 +495,15 @@
const serverId = opFn(listenOpts);
const serverPromise = core.opAsync("op_flash_drive_server", serverId);
const listenPromise = PromisePrototypeThen(
core.opAsync("op_flash_wait_for_listening", serverId),
(port) => {
onListen({ hostname: listenOpts.hostname, port });
},
PromisePrototypeCatch(
PromisePrototypeThen(
core.opAsync("op_flash_wait_for_listening", serverId),
(port) => {
onListen({ hostname: listenOpts.hostname, port });
},
),
() => {},
);
const finishedPromise = PromisePrototypeCatch(serverPromise, () => {});
@ -515,7 +519,7 @@
return;
}
server.closed = true;
core.ops.op_flash_close_server(serverId);
await core.opAsync("op_flash_close_server", serverId);
await server.finished;
},
async serve() {
@ -630,7 +634,7 @@
signal?.addEventListener("abort", () => {
clearInterval(dateInterval);
server.close();
PromisePrototypeThen(server.close(), () => {}, () => {});
}, {
once: true,
});
@ -664,7 +668,7 @@
);
}
const fastOp = prepareFastCalls(serverId);
const fastOp = prepareFastCalls();
let nextRequestSync = () => fastOp.nextRequest();
let getMethodSync = (token) => fastOp.getMethod(token);
let respondFast = (token, response, shutdown) =>
@ -684,8 +688,8 @@
}
await SafePromiseAll([
listenPromise,
PromisePrototypeCatch(server.serve(), console.error),
serverPromise,
]);
};
}

View file

@ -35,7 +35,6 @@ use mio::Events;
use mio::Interest;
use mio::Poll;
use mio::Token;
use mio::Waker;
use serde::Deserialize;
use serde::Serialize;
use socket2::Socket;
@ -48,7 +47,6 @@ use std::intrinsics::transmute;
use std::io::BufReader;
use std::io::Read;
use std::io::Write;
use std::marker::PhantomPinned;
use std::mem::replace;
use std::net::SocketAddr;
use std::net::ToSocketAddrs;
@ -57,8 +55,8 @@ use std::rc::Rc;
use std::sync::Arc;
use std::sync::Mutex;
use std::task::Context;
use std::time::Duration;
use tokio::sync::mpsc;
use tokio::sync::oneshot;
use tokio::task::JoinHandle;
mod chunked;
@ -78,24 +76,15 @@ pub struct FlashContext {
pub servers: HashMap<u32, ServerContext>,
}
impl Drop for FlashContext {
fn drop(&mut self) {
// Signal each server instance to shutdown.
for (_, server) in self.servers.drain() {
let _ = server.waker.wake();
}
}
}
pub struct ServerContext {
_addr: SocketAddr,
tx: mpsc::Sender<Request>,
rx: Option<mpsc::Receiver<Request>>,
rx: mpsc::Receiver<Request>,
requests: HashMap<u32, Request>,
next_token: u32,
listening_rx: Option<mpsc::Receiver<Result<u16, std::io::Error>>>,
listening_rx: Option<mpsc::Receiver<u16>>,
close_tx: mpsc::Sender<()>,
cancel_handle: Rc<CancelHandle>,
waker: Arc<Waker>,
}
#[derive(Debug, Eq, PartialEq)]
@ -113,10 +102,7 @@ fn op_flash_respond(
shutdown: bool,
) -> u32 {
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let ctx = match flash_ctx.servers.get_mut(&server_id) {
Some(ctx) => ctx,
None => return 0,
};
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
flash_respond(ctx, token, shutdown, &response)
}
@ -130,7 +116,7 @@ fn op_try_flash_respond_chuncked(
) -> u32 {
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
let tx = ctx.requests.get_mut(&token).unwrap();
let tx = ctx.requests.get(&token).unwrap();
let sock = tx.socket();
// TODO(@littledivy): Use writev when `UnixIoSlice` lands.
@ -167,20 +153,17 @@ async fn op_flash_respond_async(
let sock = {
let mut op_state = state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let ctx = match flash_ctx.servers.get_mut(&server_id) {
Some(ctx) => ctx,
None => return Ok(()),
};
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
match shutdown {
true => {
let mut tx = ctx.requests.remove(&token).unwrap();
let tx = ctx.requests.remove(&token).unwrap();
close = !tx.keep_alive;
tx.socket()
}
// In case of a websocket upgrade or streaming response.
false => {
let tx = ctx.requests.get_mut(&token).unwrap();
let tx = ctx.requests.get(&token).unwrap();
tx.socket()
}
}
@ -214,12 +197,12 @@ async fn op_flash_respond_chuncked(
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
let sock = match shutdown {
true => {
let mut tx = ctx.requests.remove(&token).unwrap();
let tx = ctx.requests.remove(&token).unwrap();
tx.socket()
}
// In case of a websocket upgrade or streaming response.
false => {
let tx = ctx.requests.get_mut(&token).unwrap();
let tx = ctx.requests.get(&token).unwrap();
tx.socket()
}
};
@ -361,7 +344,7 @@ fn flash_respond(
shutdown: bool,
response: &[u8],
) -> u32 {
let tx = ctx.requests.get_mut(&token).unwrap();
let tx = ctx.requests.get(&token).unwrap();
let sock = tx.socket();
sock.read_tx.take();
@ -445,36 +428,15 @@ fn op_flash_method(state: &mut OpState, server_id: u32, token: u32) -> u32 {
}
#[op]
fn op_flash_drive_server(
state: &mut OpState,
server_id: u32,
) -> Result<impl Future<Output = Result<(), AnyError>> + 'static, AnyError> {
let join_handle = {
let flash_ctx = state.borrow_mut::<FlashContext>();
flash_ctx
.join_handles
.remove(&server_id)
.ok_or_else(|| type_error("server not found"))?
async fn op_flash_close_server(state: Rc<RefCell<OpState>>, server_id: u32) {
let close_tx = {
let mut op_state = state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
ctx.cancel_handle.cancel();
ctx.close_tx.clone()
};
Ok(async move {
join_handle
.await
.map_err(|_| type_error("server join error"))??;
Ok(())
})
}
#[op]
fn op_flash_close_server(state: &mut OpState, server_id: u32) {
let flash_ctx = state.borrow_mut::<FlashContext>();
let ctx = flash_ctx.servers.get(&server_id).unwrap();
// NOTE: We don't drop ServerContext associated with the given `server_id`,
// because it may still be in use by some unsettled promise after the flash
// thread is finished.
ctx.cancel_handle.cancel();
let _ = ctx.waker.wake();
let _ = close_tx.send(()).await;
}
#[op]
@ -501,7 +463,7 @@ fn op_flash_path(
fn next_request_sync(ctx: &mut ServerContext) -> u32 {
let offset = ctx.next_token;
while let Ok(token) = ctx.rx.as_mut().unwrap().try_recv() {
while let Ok(token) = ctx.rx.try_recv() {
ctx.requests.insert(ctx.next_token, token);
ctx.next_token += 1;
}
@ -564,7 +526,6 @@ unsafe fn op_flash_get_method_fast(
fn op_flash_make_request<'scope>(
scope: &mut v8::HandleScope<'scope>,
state: &mut OpState,
server_id: u32,
) -> serde_v8::Value<'scope> {
let object_template = v8::ObjectTemplate::new(scope);
assert!(object_template
@ -572,7 +533,7 @@ fn op_flash_make_request<'scope>(
let obj = object_template.new_instance(scope).unwrap();
let ctx = {
let flash_ctx = state.borrow_mut::<FlashContext>();
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
let ctx = flash_ctx.servers.get_mut(&0).unwrap();
ctx as *mut ServerContext
};
obj.set_aligned_pointer_in_internal_field(V8_WRAPPER_OBJECT_INDEX, ctx as _);
@ -664,7 +625,7 @@ fn op_flash_make_request<'scope>(
}
#[inline]
fn has_body_stream(req: &mut Request) -> bool {
fn has_body_stream(req: &Request) -> bool {
let sock = req.socket();
sock.read_rx.is_some()
}
@ -788,10 +749,7 @@ async fn op_flash_read_body(
{
let op_state = &mut state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
match flash_ctx.servers.get_mut(&server_id) {
Some(ctx) => ctx as *mut ServerContext,
None => return 0,
}
flash_ctx.servers.get_mut(&server_id).unwrap() as *mut ServerContext
}
.as_mut()
.unwrap()
@ -893,40 +851,41 @@ pub struct ListenOpts {
reuseport: bool,
}
const SERVER_TOKEN: Token = Token(0);
// Token reserved for the thread close signal.
const WAKER_TOKEN: Token = Token(1);
#[allow(clippy::too_many_arguments)]
fn run_server(
tx: mpsc::Sender<Request>,
listening_tx: mpsc::Sender<Result<u16, std::io::Error>>,
listening_tx: mpsc::Sender<u16>,
mut close_rx: mpsc::Receiver<()>,
addr: SocketAddr,
maybe_cert: Option<String>,
maybe_key: Option<String>,
reuseport: bool,
mut poll: Poll,
// We put a waker as an unused argument here as it needs to be alive both in
// the flash thread and in the main thread (otherwise the notification would
// not be caught by the event loop on Linux).
// See the comment in mio's example:
// https://docs.rs/mio/0.8.4/x86_64-unknown-linux-gnu/mio/struct.Waker.html#examples
_waker: Arc<Waker>,
) -> Result<(), AnyError> {
let mut listener = match listen(addr, reuseport) {
Ok(listener) => listener,
Err(e) => {
listening_tx.blocking_send(Err(e)).unwrap();
return Err(generic_error(
"failed to start listening on the specified address",
));
}
let domain = if addr.is_ipv4() {
socket2::Domain::IPV4
} else {
socket2::Domain::IPV6
};
let socket = Socket::new(domain, socket2::Type::STREAM, None)?;
// Register server.
#[cfg(not(windows))]
socket.set_reuse_address(true)?;
if reuseport {
#[cfg(target_os = "linux")]
socket.set_reuse_port(true)?;
}
let socket_addr = socket2::SockAddr::from(addr);
socket.bind(&socket_addr)?;
socket.listen(128)?;
socket.set_nonblocking(true)?;
let std_listener: std::net::TcpListener = socket.into();
let mut listener = TcpListener::from_std(std_listener);
let mut poll = Poll::new()?;
let token = Token(0);
poll
.registry()
.register(&mut listener, SERVER_TOKEN, Interest::READABLE)
.register(&mut listener, token, Interest::READABLE)
.unwrap();
let tls_context: Option<Arc<rustls::ServerConfig>> = {
@ -948,25 +907,30 @@ fn run_server(
};
listening_tx
.blocking_send(Ok(listener.local_addr().unwrap().port()))
.blocking_send(listener.local_addr().unwrap().port())
.unwrap();
let mut sockets = HashMap::with_capacity(1000);
let mut socket_senders = HashMap::with_capacity(1000);
let mut counter: usize = 2;
let mut counter: usize = 1;
let mut events = Events::with_capacity(1024);
'outer: loop {
match poll.poll(&mut events, None) {
let result = close_rx.try_recv();
if result.is_ok() {
break 'outer;
}
// FIXME(bartlomieju): how does Tokio handle it? I just put random 100ms
// timeout here to handle close signal.
match poll.poll(&mut events, Some(Duration::from_millis(100))) {
Err(ref e) if e.kind() == std::io::ErrorKind::Interrupted => continue,
Err(e) => panic!("{}", e),
Ok(()) => (),
}
'events: for event in &events {
if close_rx.try_recv().is_ok() {
break 'outer;
}
let token = event.token();
match token {
WAKER_TOKEN => {
break 'outer;
}
SERVER_TOKEN => loop {
Token(0) => loop {
match listener.accept() {
Ok((mut socket, _)) => {
counter += 1;
@ -994,7 +958,6 @@ fn run_server(
read_lock: Arc::new(Mutex::new(())),
parse_done: ParseStatus::None,
buffer: UnsafeCell::new(vec![0_u8; 1024]),
_pinned: PhantomPinned,
});
trace!("New connection: {}", token.0);
@ -1011,6 +974,7 @@ fn run_server(
let mut_ref: Pin<&mut Stream> = Pin::as_mut(socket);
Pin::get_unchecked_mut(mut_ref)
};
let sock_ptr = socket as *mut _;
if socket.detached {
match &mut socket.inner {
@ -1024,7 +988,6 @@ fn run_server(
let boxed = sockets.remove(&token).unwrap();
std::mem::forget(boxed);
socket_senders.remove(&token);
trace!("Socket detached: {}", token.0);
continue;
}
@ -1210,10 +1173,8 @@ fn run_server(
continue 'events;
}
let (socket_tx, socket_rx) = oneshot::channel();
tx.blocking_send(Request {
socket: socket as *mut _,
socket: sock_ptr,
// SAFETY: headers backing buffer outlives the mio event loop ('static)
inner: inner_req,
keep_alive,
@ -1222,57 +1183,16 @@ fn run_server(
content_read: 0,
content_length,
expect_continue,
socket_rx,
owned_socket: None,
})
.ok();
socket_senders.insert(token, socket_tx);
}
}
}
}
// Now the flash thread is about to finish, but there may be some unsettled
// promises in the main thread that will use the socket. To make the socket
// alive longer enough, we move its ownership to the main thread.
for (tok, socket) in sockets {
if let Some(sender) = socket_senders.remove(&tok) {
// Do nothing if the receiver has already been dropped.
_ = sender.send(socket);
}
}
Ok(())
}
#[inline]
fn listen(
addr: SocketAddr,
reuseport: bool,
) -> Result<TcpListener, std::io::Error> {
let domain = if addr.is_ipv4() {
socket2::Domain::IPV4
} else {
socket2::Domain::IPV6
};
let socket = Socket::new(domain, socket2::Type::STREAM, None)?;
#[cfg(not(windows))]
socket.set_reuse_address(true)?;
if reuseport {
#[cfg(target_os = "linux")]
socket.set_reuse_port(true)?;
}
let socket_addr = socket2::SockAddr::from(addr);
socket.bind(&socket_addr)?;
socket.listen(128)?;
socket.set_nonblocking(true)?;
let std_listener: std::net::TcpListener = socket.into();
Ok(TcpListener::from_std(std_listener))
}
fn make_addr_port_pair(hostname: &str, port: u16) -> (&str, u16) {
// Default to localhost if given just the port. Example: ":80"
if hostname.is_empty() {
@ -1310,19 +1230,17 @@ where
.next()
.ok_or_else(|| generic_error("No resolved address found"))?;
let (tx, rx) = mpsc::channel(100);
let (close_tx, close_rx) = mpsc::channel(1);
let (listening_tx, listening_rx) = mpsc::channel(1);
let poll = Poll::new()?;
let waker = Arc::new(Waker::new(poll.registry(), WAKER_TOKEN).unwrap());
let ctx = ServerContext {
_addr: addr,
tx,
rx: Some(rx),
rx,
requests: HashMap::with_capacity(1000),
next_token: 0,
close_tx,
listening_rx: Some(listening_rx),
cancel_handle: CancelHandle::new_rc(),
waker: waker.clone(),
};
let tx = ctx.tx.clone();
let maybe_cert = opts.cert;
@ -1332,12 +1250,11 @@ where
run_server(
tx,
listening_tx,
close_rx,
addr,
maybe_cert,
maybe_key,
reuseport,
poll,
waker,
)
});
let flash_ctx = state.borrow_mut::<FlashContext>();
@ -1372,26 +1289,45 @@ where
}
#[op]
async fn op_flash_wait_for_listening(
state: Rc<RefCell<OpState>>,
fn op_flash_wait_for_listening(
state: &mut OpState,
server_id: u32,
) -> Result<u16, AnyError> {
) -> Result<impl Future<Output = Result<u16, AnyError>> + 'static, AnyError> {
let mut listening_rx = {
let mut op_state = state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let flash_ctx = state.borrow_mut::<FlashContext>();
let server_ctx = flash_ctx
.servers
.get_mut(&server_id)
.ok_or_else(|| type_error("server not found"))?;
server_ctx.listening_rx.take().unwrap()
};
match listening_rx.recv().await {
Some(Ok(port)) => Ok(port),
Some(Err(e)) => Err(e.into()),
_ => Err(generic_error(
"unknown error occurred while waiting for listening",
)),
}
Ok(async move {
if let Some(port) = listening_rx.recv().await {
Ok(port)
} else {
Err(generic_error("This error will be discarded"))
}
})
}
#[op]
fn op_flash_drive_server(
state: &mut OpState,
server_id: u32,
) -> Result<impl Future<Output = Result<(), AnyError>> + 'static, AnyError> {
let join_handle = {
let flash_ctx = state.borrow_mut::<FlashContext>();
flash_ctx
.join_handles
.remove(&server_id)
.ok_or_else(|| type_error("server not found"))?
};
Ok(async move {
join_handle
.await
.map_err(|_| type_error("server join error"))??;
Ok(())
})
}
// Asychronous version of op_flash_next. This can be a bottleneck under
@ -1399,34 +1335,26 @@ async fn op_flash_wait_for_listening(
// requests i.e `op_flash_next() == 0`.
#[op]
async fn op_flash_next_async(
state: Rc<RefCell<OpState>>,
op_state: Rc<RefCell<OpState>>,
server_id: u32,
) -> u32 {
let mut op_state = state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
let cancel_handle = ctx.cancel_handle.clone();
let mut rx = ctx.rx.take().unwrap();
// We need to drop the borrow before await point.
drop(op_state);
if let Ok(Some(req)) = rx.recv().or_cancel(&cancel_handle).await {
let mut op_state = state.borrow_mut();
let ctx = {
let mut op_state = op_state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
let ctx = flash_ctx.servers.get_mut(&server_id).unwrap();
ctx as *mut ServerContext
};
// SAFETY: we cannot hold op_state borrow across the await point. The JS caller
// is responsible for ensuring this is not called concurrently.
let ctx = unsafe { &mut *ctx };
let cancel_handle = &ctx.cancel_handle;
if let Ok(Some(req)) = ctx.rx.recv().or_cancel(cancel_handle).await {
ctx.requests.insert(ctx.next_token, req);
ctx.next_token += 1;
// Set the rx back.
ctx.rx = Some(rx);
return 1;
}
// Set the rx back.
let mut op_state = state.borrow_mut();
let flash_ctx = op_state.borrow_mut::<FlashContext>();
if let Some(ctx) = flash_ctx.servers.get_mut(&server_id) {
ctx.rx = Some(rx);
}
0
}
@ -1499,7 +1427,7 @@ pub fn detach_socket(
// dropped on the server thread.
// * conversion from mio::net::TcpStream -> tokio::net::TcpStream. There is no public API so we
// use raw fds.
let mut tx = ctx
let tx = ctx
.requests
.remove(&token)
.ok_or_else(|| type_error("request closed"))?;
@ -1594,11 +1522,11 @@ pub fn init<P: FlashPermissions + 'static>(unstable: bool) -> Extension {
op_flash_next_async::decl(),
op_flash_read_body::decl(),
op_flash_upgrade_websocket::decl(),
op_flash_drive_server::decl(),
op_flash_wait_for_listening::decl(),
op_flash_first_packet::decl(),
op_flash_has_body_stream::decl(),
op_flash_close_server::decl(),
op_flash_drive_server::decl(),
op_flash_make_request::decl(),
op_flash_write_resource::decl(),
op_try_flash_respond_chuncked::decl(),

View file

@ -2,7 +2,6 @@
use crate::Stream;
use std::pin::Pin;
use tokio::sync::oneshot;
#[derive(Debug)]
pub struct InnerRequest {
@ -21,7 +20,8 @@ pub struct Request {
pub inner: InnerRequest,
// Pointer to stream owned by the server loop thread.
//
// Dereferencing is safe until websocket upgrade is performed.
// Dereferencing is safe until server thread finishes and
// op_flash_serve resolves or websocket upgrade is performed.
pub socket: *mut Stream,
pub keep_alive: bool,
pub content_read: usize,
@ -29,8 +29,6 @@ pub struct Request {
pub remaining_chunk_size: Option<usize>,
pub te_chunked: bool,
pub expect_continue: bool,
pub socket_rx: oneshot::Receiver<Pin<Box<Stream>>>,
pub owned_socket: Option<Pin<Box<Stream>>>,
}
// SAFETY: Sent from server thread to JS thread.
@ -39,16 +37,8 @@ unsafe impl Send for Request {}
impl Request {
#[inline(always)]
pub fn socket<'a>(&mut self) -> &'a mut Stream {
if let Ok(mut sock) = self.socket_rx.try_recv() {
// SAFETY: We never move the data out of the acquired mutable reference.
self.socket = unsafe { sock.as_mut().get_unchecked_mut() };
// Let the struct own the socket so that it won't get dropped.
self.owned_socket = Some(sock);
}
// SAFETY: Dereferencing is safe until server thread detaches socket.
pub fn socket<'a>(&self) -> &'a mut Stream {
// SAFETY: Dereferencing is safe until server thread detaches socket or finishes.
unsafe { &mut *self.socket }
}

View file

@ -1,26 +1,23 @@
use deno_core::error::AnyError;
use mio::net::TcpStream;
use std::cell::UnsafeCell;
use std::future::Future;
use std::io::Read;
use std::io::Write;
use std::marker::PhantomPinned;
use std::pin::Pin;
use std::sync::Arc;
use std::sync::Mutex;
use std::{
cell::UnsafeCell,
future::Future,
io::{Read, Write},
pin::Pin,
sync::{Arc, Mutex},
};
use tokio::sync::mpsc;
use crate::ParseStatus;
type TlsTcpStream = rustls::StreamOwned<rustls::ServerConnection, TcpStream>;
#[derive(Debug)]
pub enum InnerStream {
Tcp(TcpStream),
Tls(Box<TlsTcpStream>),
}
#[derive(Debug)]
pub struct Stream {
pub inner: InnerStream,
pub detached: bool,
@ -29,7 +26,6 @@ pub struct Stream {
pub parse_done: ParseStatus,
pub buffer: UnsafeCell<Vec<u8>>,
pub read_lock: Arc<Mutex<()>>,
pub _pinned: PhantomPinned,
}
impl Stream {