1
0
Fork 0
mirror of https://github.com/denoland/deno.git synced 2024-12-25 16:49:18 -05:00

refactor: IO resource types, fix concurrent read/write and graceful close (#9118)

Fixes: 9032.
This commit is contained in:
Bert Belder 2021-01-14 20:32:27 -08:00
parent c8a5e3c1e4
commit 98878bd812
No known key found for this signature in database
GPG key ID: 7A77887B2E2ED461
12 changed files with 613 additions and 425 deletions

View file

@ -1710,9 +1710,9 @@ declare namespace Deno {
readonly remoteAddr: Addr; readonly remoteAddr: Addr;
/** The resource ID of the connection. */ /** The resource ID of the connection. */
readonly rid: number; readonly rid: number;
/** Shuts down (`shutdown(2)`) the writing side of the TCP connection. Most /** Shuts down (`shutdown(2)`) the write side of the connection. Most
* callers should just use `close()`. */ * callers should just use `close()`. */
closeWrite(): void; closeWrite(): Promise<void>;
} }
export interface ListenOptions { export interface ListenOptions {

View file

@ -2,6 +2,7 @@
import { import {
assert, assert,
assertEquals, assertEquals,
assertStrictEquals,
assertThrows, assertThrows,
assertThrowsAsync, assertThrowsAsync,
deferred, deferred,
@ -182,6 +183,149 @@ unitTest(
}, },
); );
async function tlsPair(port: number): Promise<[Deno.Conn, Deno.Conn]> {
const listener = Deno.listenTls({
hostname: "localhost",
port,
certFile: "cli/tests/tls/localhost.crt",
keyFile: "cli/tests/tls/localhost.key",
});
const acceptPromise = listener.accept();
const connectPromise = Deno.connectTls({
hostname: "localhost",
port,
certFile: "cli/tests/tls/RootCA.pem",
});
const connections = await Promise.all([acceptPromise, connectPromise]);
listener.close();
return connections;
}
async function sendCloseWrite(conn: Deno.Conn): Promise<void> {
const buf = new Uint8Array(1024);
let n: number | null;
// Send 1.
n = await conn.write(new Uint8Array([1]));
assertStrictEquals(n, 1);
// Send EOF.
await conn.closeWrite();
// Receive 2.
n = await conn.read(buf);
assertStrictEquals(n, 1);
assertStrictEquals(buf[0], 2);
conn.close();
}
async function receiveCloseWrite(conn: Deno.Conn): Promise<void> {
const buf = new Uint8Array(1024);
let n: number | null;
// Receive 1.
n = await conn.read(buf);
assertStrictEquals(n, 1);
assertStrictEquals(buf[0], 1);
// Receive EOF.
n = await conn.read(buf);
assertStrictEquals(n, null);
// Send 2.
n = await conn.write(new Uint8Array([2]));
assertStrictEquals(n, 1);
conn.close();
}
async function sendAlotReceiveNothing(conn: Deno.Conn): Promise<void> {
// Start receive op.
const readBuf = new Uint8Array(1024);
const readPromise = conn.read(readBuf);
// Send 1 MB of data.
const writeBuf = new Uint8Array(1 << 20);
writeBuf.fill(42);
await conn.write(writeBuf);
// Send EOF.
await conn.closeWrite();
// Close the connection.
conn.close();
// Read op should be canceled.
await assertThrowsAsync(
async () => await readPromise,
Deno.errors.Interrupted,
);
}
async function receiveAlotSendNothing(conn: Deno.Conn): Promise<void> {
const readBuf = new Uint8Array(1024);
let n: number | null;
// Receive 1 MB of data.
for (let nread = 0; nread < 1 << 20; nread += n!) {
n = await conn.read(readBuf);
assertStrictEquals(typeof n, "number");
assert(n! > 0);
assertStrictEquals(readBuf[0], 42);
}
// Close the connection, without sending anything at all.
conn.close();
}
unitTest(
{ perms: { read: true, net: true } },
async function tlsServerStreamHalfClose(): Promise<void> {
const [serverConn, clientConn] = await tlsPair(3501);
await Promise.all([
sendCloseWrite(serverConn),
receiveCloseWrite(clientConn),
]);
},
);
unitTest(
{ perms: { read: true, net: true } },
async function tlsClientStreamHalfClose(): Promise<void> {
const [serverConn, clientConn] = await tlsPair(3502);
await Promise.all([
sendCloseWrite(clientConn),
receiveCloseWrite(serverConn),
]);
},
);
unitTest(
{ perms: { read: true, net: true } },
async function tlsServerStreamCancelRead(): Promise<void> {
const [serverConn, clientConn] = await tlsPair(3503);
await Promise.all([
sendAlotReceiveNothing(serverConn),
receiveAlotSendNothing(clientConn),
]);
},
);
unitTest(
{ perms: { read: true, net: true } },
async function tlsClientStreamCancelRead(): Promise<void> {
const [serverConn, clientConn] = await tlsPair(3504);
await Promise.all([
sendAlotReceiveNothing(clientConn),
receiveAlotSendNothing(serverConn),
]);
},
);
unitTest( unitTest(
{ perms: { read: true, net: true } }, { perms: { read: true, net: true } },
async function startTls(): Promise<void> { async function startTls(): Promise<void> {

View file

@ -72,7 +72,7 @@
} }
closeWrite() { closeWrite() {
shutdown(this.rid); return shutdown(this.rid);
} }
} }

View file

@ -1,7 +1,6 @@
// Copyright 2018-2021 the Deno authors. All rights reserved. MIT license. // Copyright 2018-2021 the Deno authors. All rights reserved. MIT license.
// Some deserializer fields are only used on Unix and Windows build fails without it // Some deserializer fields are only used on Unix and Windows build fails without it
use super::io::std_file_resource; use super::io::StdFileResource;
use super::io::StreamResource;
use crate::fs_util::canonicalize_path; use crate::fs_util::canonicalize_path;
use crate::permissions::Permissions; use crate::permissions::Permissions;
use deno_core::error::bad_resource_id; use deno_core::error::bad_resource_id;
@ -188,7 +187,7 @@ fn op_open_sync(
let (path, open_options) = open_helper(state, args)?; let (path, open_options) = open_helper(state, args)?;
let std_file = open_options.open(path)?; let std_file = open_options.open(path)?;
let tokio_file = tokio::fs::File::from_std(std_file); let tokio_file = tokio::fs::File::from_std(std_file);
let resource = StreamResource::fs_file(tokio_file); let resource = StdFileResource::fs_file(tokio_file);
let rid = state.resource_table.add(resource); let rid = state.resource_table.add(resource);
Ok(json!(rid)) Ok(json!(rid))
} }
@ -202,7 +201,7 @@ async fn op_open_async(
let tokio_file = tokio::fs::OpenOptions::from(open_options) let tokio_file = tokio::fs::OpenOptions::from(open_options)
.open(path) .open(path)
.await?; .await?;
let resource = StreamResource::fs_file(tokio_file); let resource = StdFileResource::fs_file(tokio_file);
let rid = state.borrow_mut().resource_table.add(resource); let rid = state.borrow_mut().resource_table.add(resource);
Ok(json!(rid)) Ok(json!(rid))
} }
@ -239,7 +238,7 @@ fn op_seek_sync(
_zero_copy: &mut [ZeroCopyBuf], _zero_copy: &mut [ZeroCopyBuf],
) -> Result<Value, AnyError> { ) -> Result<Value, AnyError> {
let (rid, seek_from) = seek_helper(args)?; let (rid, seek_from) = seek_helper(args)?;
let pos = std_file_resource(state, rid, |r| match r { let pos = StdFileResource::with(state, rid, |r| match r {
Ok(std_file) => std_file.seek(seek_from).map_err(AnyError::from), Ok(std_file) => std_file.seek(seek_from).map_err(AnyError::from),
Err(_) => Err(type_error( Err(_) => Err(type_error(
"cannot seek on this type of resource".to_string(), "cannot seek on this type of resource".to_string(),
@ -258,7 +257,7 @@ async fn op_seek_async(
let resource = state let resource = state
.borrow_mut() .borrow_mut()
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {
@ -286,7 +285,7 @@ fn op_fdatasync_sync(
) -> Result<Value, AnyError> { ) -> Result<Value, AnyError> {
let args: FdatasyncArgs = serde_json::from_value(args)?; let args: FdatasyncArgs = serde_json::from_value(args)?;
let rid = args.rid as u32; let rid = args.rid as u32;
std_file_resource(state, rid, |r| match r { StdFileResource::with(state, rid, |r| match r {
Ok(std_file) => std_file.sync_data().map_err(AnyError::from), Ok(std_file) => std_file.sync_data().map_err(AnyError::from),
Err(_) => Err(type_error("cannot sync this type of resource".to_string())), Err(_) => Err(type_error("cannot sync this type of resource".to_string())),
})?; })?;
@ -304,7 +303,7 @@ async fn op_fdatasync_async(
let resource = state let resource = state
.borrow_mut() .borrow_mut()
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {
@ -332,7 +331,7 @@ fn op_fsync_sync(
) -> Result<Value, AnyError> { ) -> Result<Value, AnyError> {
let args: FsyncArgs = serde_json::from_value(args)?; let args: FsyncArgs = serde_json::from_value(args)?;
let rid = args.rid as u32; let rid = args.rid as u32;
std_file_resource(state, rid, |r| match r { StdFileResource::with(state, rid, |r| match r {
Ok(std_file) => std_file.sync_all().map_err(AnyError::from), Ok(std_file) => std_file.sync_all().map_err(AnyError::from),
Err(_) => Err(type_error("cannot sync this type of resource".to_string())), Err(_) => Err(type_error("cannot sync this type of resource".to_string())),
})?; })?;
@ -350,7 +349,7 @@ async fn op_fsync_async(
let resource = state let resource = state
.borrow_mut() .borrow_mut()
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {
@ -379,7 +378,7 @@ fn op_fstat_sync(
super::check_unstable(state, "Deno.fstat"); super::check_unstable(state, "Deno.fstat");
let args: FstatArgs = serde_json::from_value(args)?; let args: FstatArgs = serde_json::from_value(args)?;
let rid = args.rid as u32; let rid = args.rid as u32;
let metadata = std_file_resource(state, rid, |r| match r { let metadata = StdFileResource::with(state, rid, |r| match r {
Ok(std_file) => std_file.metadata().map_err(AnyError::from), Ok(std_file) => std_file.metadata().map_err(AnyError::from),
Err(_) => Err(type_error("cannot stat this type of resource".to_string())), Err(_) => Err(type_error("cannot stat this type of resource".to_string())),
})?; })?;
@ -399,7 +398,7 @@ async fn op_fstat_async(
let resource = state let resource = state
.borrow_mut() .borrow_mut()
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {
@ -1365,7 +1364,7 @@ fn op_ftruncate_sync(
let args: FtruncateArgs = serde_json::from_value(args)?; let args: FtruncateArgs = serde_json::from_value(args)?;
let rid = args.rid as u32; let rid = args.rid as u32;
let len = args.len as u64; let len = args.len as u64;
std_file_resource(state, rid, |r| match r { StdFileResource::with(state, rid, |r| match r {
Ok(std_file) => std_file.set_len(len).map_err(AnyError::from), Ok(std_file) => std_file.set_len(len).map_err(AnyError::from),
Err(_) => Err(type_error("cannot truncate this type of resource")), Err(_) => Err(type_error("cannot truncate this type of resource")),
})?; })?;
@ -1385,7 +1384,7 @@ async fn op_ftruncate_async(
let resource = state let resource = state
.borrow_mut() .borrow_mut()
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {
@ -1648,7 +1647,7 @@ fn op_futime_sync(
let atime = filetime::FileTime::from_unix_time(args.atime.0, args.atime.1); let atime = filetime::FileTime::from_unix_time(args.atime.0, args.atime.1);
let mtime = filetime::FileTime::from_unix_time(args.mtime.0, args.mtime.1); let mtime = filetime::FileTime::from_unix_time(args.mtime.0, args.mtime.1);
std_file_resource(state, rid, |r| match r { StdFileResource::with(state, rid, |r| match r {
Ok(std_file) => { Ok(std_file) => {
filetime::set_file_handle_times(std_file, Some(atime), Some(mtime)) filetime::set_file_handle_times(std_file, Some(atime), Some(mtime))
.map_err(AnyError::from) .map_err(AnyError::from)
@ -1675,7 +1674,7 @@ async fn op_futime_async(
let resource = state let resource = state
.borrow_mut() .borrow_mut()
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {

View file

@ -3,11 +3,14 @@
use super::dispatch_minimal::minimal_op; use super::dispatch_minimal::minimal_op;
use super::dispatch_minimal::MinimalOp; use super::dispatch_minimal::MinimalOp;
use crate::metrics::metrics_op; use crate::metrics::metrics_op;
use deno_core::error::bad_resource_id;
use deno_core::error::resource_unavailable; use deno_core::error::resource_unavailable;
use deno_core::error::type_error; use deno_core::error::type_error;
use deno_core::error::AnyError; use deno_core::error::AnyError;
use deno_core::error::{bad_resource_id, not_supported};
use deno_core::futures::future::FutureExt; use deno_core::futures::future::FutureExt;
use deno_core::serde_json;
use deno_core::serde_json::json;
use deno_core::serde_json::Value;
use deno_core::AsyncMutFuture; use deno_core::AsyncMutFuture;
use deno_core::AsyncRefCell; use deno_core::AsyncRefCell;
use deno_core::BufVec; use deno_core::BufVec;
@ -17,20 +20,30 @@ use deno_core::JsRuntime;
use deno_core::OpState; use deno_core::OpState;
use deno_core::RcRef; use deno_core::RcRef;
use deno_core::Resource; use deno_core::Resource;
use deno_core::ZeroCopyBuf;
use serde::Deserialize;
use std::borrow::Cow; use std::borrow::Cow;
use std::cell::RefCell; use std::cell::RefCell;
use std::convert::TryInto;
use std::io::Read;
use std::io::Write;
use std::rc::Rc; use std::rc::Rc;
use tokio::io::split;
use tokio::io::AsyncRead; use tokio::io::AsyncRead;
use tokio::io::AsyncReadExt; use tokio::io::AsyncReadExt;
use tokio::io::AsyncWrite; use tokio::io::AsyncWrite;
use tokio::io::AsyncWriteExt; use tokio::io::AsyncWriteExt;
use tokio::io::ReadHalf;
use tokio::io::WriteHalf;
use tokio::net::tcp; use tokio::net::tcp;
use tokio::net::TcpStream; use tokio::net::TcpStream;
use tokio_rustls::client::TlsStream as ClientTlsStream; use tokio::process;
use tokio_rustls::server::TlsStream as ServerTlsStream; use tokio_rustls as tls;
#[cfg(unix)] #[cfg(unix)]
use std::os::unix::io::FromRawFd; use std::os::unix::io::FromRawFd;
#[cfg(unix)]
use tokio::net::unix;
#[cfg(windows)] #[cfg(windows)]
use std::os::windows::io::FromRawHandle; use std::os::windows::io::FromRawHandle;
@ -94,12 +107,13 @@ lazy_static! {
pub fn init(rt: &mut JsRuntime) { pub fn init(rt: &mut JsRuntime) {
rt.register_op("op_read", metrics_op(minimal_op(op_read))); rt.register_op("op_read", metrics_op(minimal_op(op_read)));
rt.register_op("op_write", metrics_op(minimal_op(op_write))); rt.register_op("op_write", metrics_op(minimal_op(op_write)));
super::reg_json_async(rt, "op_shutdown", op_shutdown);
} }
pub fn get_stdio() -> ( pub fn get_stdio() -> (
Option<StreamResource>, Option<StdFileResource>,
Option<StreamResource>, Option<StdFileResource>,
Option<StreamResource>, Option<StdFileResource>,
) { ) {
let stdin = get_stdio_stream(&STDIN_HANDLE, "stdin"); let stdin = get_stdio_stream(&STDIN_HANDLE, "stdin");
let stdout = get_stdio_stream(&STDOUT_HANDLE, "stdout"); let stdout = get_stdio_stream(&STDOUT_HANDLE, "stdout");
@ -111,13 +125,13 @@ pub fn get_stdio() -> (
fn get_stdio_stream( fn get_stdio_stream(
handle: &Option<std::fs::File>, handle: &Option<std::fs::File>,
name: &str, name: &str,
) -> Option<StreamResource> { ) -> Option<StdFileResource> {
match handle { match handle {
None => None, None => None,
Some(file_handle) => match file_handle.try_clone() { Some(file_handle) => match file_handle.try_clone() {
Ok(clone) => { Ok(clone) => {
let tokio_file = tokio::fs::File::from_std(clone); let tokio_file = tokio::fs::File::from_std(clone);
Some(StreamResource::stdio(tokio_file, name)) Some(StdFileResource::stdio(tokio_file, name))
} }
Err(_e) => None, Err(_e) => None,
}, },
@ -142,6 +156,80 @@ pub struct FileMetadata {
pub tty: TTYMetadata, pub tty: TTYMetadata,
} }
#[derive(Debug)]
pub struct WriteOnlyResource<S> {
stream: AsyncRefCell<S>,
}
impl<S: 'static> From<S> for WriteOnlyResource<S> {
fn from(stream: S) -> Self {
Self {
stream: stream.into(),
}
}
}
impl<S> WriteOnlyResource<S>
where
S: AsyncWrite + Unpin + 'static,
{
pub fn borrow_mut(self: &Rc<Self>) -> AsyncMutFuture<S> {
RcRef::map(self, |r| &r.stream).borrow_mut()
}
async fn write(self: &Rc<Self>, buf: &[u8]) -> Result<usize, AnyError> {
let mut stream = self.borrow_mut().await;
let nwritten = stream.write(buf).await?;
Ok(nwritten)
}
async fn shutdown(self: &Rc<Self>) -> Result<(), AnyError> {
let mut stream = self.borrow_mut().await;
stream.shutdown().await?;
Ok(())
}
}
#[derive(Debug)]
pub struct ReadOnlyResource<S> {
stream: AsyncRefCell<S>,
cancel_handle: CancelHandle,
}
impl<S: 'static> From<S> for ReadOnlyResource<S> {
fn from(stream: S) -> Self {
Self {
stream: stream.into(),
cancel_handle: Default::default(),
}
}
}
impl<S> ReadOnlyResource<S>
where
S: AsyncRead + Unpin + 'static,
{
pub fn borrow_mut(self: &Rc<Self>) -> AsyncMutFuture<S> {
RcRef::map(self, |r| &r.stream).borrow_mut()
}
pub fn cancel_handle(self: &Rc<Self>) -> RcRef<CancelHandle> {
RcRef::map(self, |r| &r.cancel_handle)
}
pub fn cancel_read_ops(&self) {
self.cancel_handle.cancel()
}
async fn read(self: &Rc<Self>, buf: &mut [u8]) -> Result<usize, AnyError> {
let mut rd = self.borrow_mut().await;
let nread = rd.read(buf).try_or_cancel(self.cancel_handle()).await?;
Ok(nread)
}
}
/// A full duplex resource has a read and write ends that are completely
/// independent, like TCP/Unix sockets and TLS streams.
#[derive(Debug)] #[derive(Debug)]
pub struct FullDuplexResource<R, W> { pub struct FullDuplexResource<R, W> {
rd: AsyncRefCell<R>, rd: AsyncRefCell<R>,
@ -152,7 +240,11 @@ pub struct FullDuplexResource<R, W> {
cancel_handle: CancelHandle, cancel_handle: CancelHandle,
} }
impl<R: 'static, W: 'static> FullDuplexResource<R, W> { impl<R, W> FullDuplexResource<R, W>
where
R: AsyncRead + Unpin + 'static,
W: AsyncWrite + Unpin + 'static,
{
pub fn new((rd, wr): (R, W)) -> Self { pub fn new((rd, wr): (R, W)) -> Self {
Self { Self {
rd: rd.into(), rd: rd.into(),
@ -180,13 +272,7 @@ impl<R: 'static, W: 'static> FullDuplexResource<R, W> {
pub fn cancel_read_ops(&self) { pub fn cancel_read_ops(&self) {
self.cancel_handle.cancel() self.cancel_handle.cancel()
} }
}
impl<R, W> FullDuplexResource<R, W>
where
R: AsyncRead + Unpin + 'static,
W: AsyncWrite + Unpin + 'static,
{
async fn read(self: &Rc<Self>, buf: &mut [u8]) -> Result<usize, AnyError> { async fn read(self: &Rc<Self>, buf: &mut [u8]) -> Result<usize, AnyError> {
let mut rd = self.rd_borrow_mut().await; let mut rd = self.rd_borrow_mut().await;
let nread = rd.read(buf).try_or_cancel(self.cancel_handle()).await?; let nread = rd.read(buf).try_or_cancel(self.cancel_handle()).await?;
@ -198,6 +284,56 @@ where
let nwritten = wr.write(buf).await?; let nwritten = wr.write(buf).await?;
Ok(nwritten) Ok(nwritten)
} }
async fn shutdown(self: &Rc<Self>) -> Result<(), AnyError> {
let mut wr = self.wr_borrow_mut().await;
wr.shutdown().await?;
Ok(())
}
}
pub type FullDuplexSplitResource<S> =
FullDuplexResource<ReadHalf<S>, WriteHalf<S>>;
impl<S> From<S> for FullDuplexSplitResource<S>
where
S: AsyncRead + AsyncWrite + 'static,
{
fn from(stream: S) -> Self {
Self::new(split(stream))
}
}
pub type ChildStdinResource = WriteOnlyResource<process::ChildStdin>;
impl Resource for ChildStdinResource {
fn name(&self) -> Cow<str> {
"childStdin".into()
}
}
pub type ChildStdoutResource = ReadOnlyResource<process::ChildStdout>;
impl Resource for ChildStdoutResource {
fn name(&self) -> Cow<str> {
"childStdout".into()
}
fn close(self: Rc<Self>) {
self.cancel_read_ops();
}
}
pub type ChildStderrResource = ReadOnlyResource<process::ChildStderr>;
impl Resource for ChildStderrResource {
fn name(&self) -> Cow<str> {
"childStderr".into()
}
fn close(self: Rc<Self>) {
self.cancel_read_ops();
}
} }
pub type TcpStreamResource = pub type TcpStreamResource =
@ -213,35 +349,74 @@ impl Resource for TcpStreamResource {
} }
} }
#[derive(Default)] pub type TlsClientStreamResource =
pub struct StreamResource { FullDuplexSplitResource<tls::client::TlsStream<TcpStream>>;
impl Resource for TlsClientStreamResource {
fn name(&self) -> Cow<str> {
"tlsClientStream".into()
}
fn close(self: Rc<Self>) {
self.cancel_read_ops();
}
}
pub type TlsServerStreamResource =
FullDuplexSplitResource<tls::server::TlsStream<TcpStream>>;
impl Resource for TlsServerStreamResource {
fn name(&self) -> Cow<str> {
"tlsServerStream".into()
}
fn close(self: Rc<Self>) {
self.cancel_read_ops();
}
}
#[cfg(unix)]
pub type UnixStreamResource =
FullDuplexResource<unix::OwnedReadHalf, unix::OwnedWriteHalf>;
#[cfg(not(unix))]
struct UnixStreamResource;
#[cfg(not(unix))]
impl UnixStreamResource {
async fn read(self: &Rc<Self>, _buf: &mut [u8]) -> Result<usize, AnyError> {
unreachable!()
}
async fn write(self: &Rc<Self>, _buf: &[u8]) -> Result<usize, AnyError> {
unreachable!()
}
async fn shutdown(self: &Rc<Self>) -> Result<(), AnyError> {
unreachable!()
}
fn cancel_read_ops(&self) {
unreachable!()
}
}
impl Resource for UnixStreamResource {
fn name(&self) -> Cow<str> {
"unixStream".into()
}
fn close(self: Rc<Self>) {
self.cancel_read_ops();
}
}
#[derive(Debug, Default)]
pub struct StdFileResource {
pub fs_file: pub fs_file:
Option<AsyncRefCell<(Option<tokio::fs::File>, Option<FileMetadata>)>>, Option<AsyncRefCell<(Option<tokio::fs::File>, Option<FileMetadata>)>>,
#[cfg(unix)]
pub unix_stream: Option<AsyncRefCell<tokio::net::UnixStream>>,
child_stdin: Option<AsyncRefCell<tokio::process::ChildStdin>>,
child_stdout: Option<AsyncRefCell<tokio::process::ChildStdout>>,
child_stderr: Option<AsyncRefCell<tokio::process::ChildStderr>>,
client_tls_stream: Option<AsyncRefCell<ClientTlsStream<TcpStream>>>,
server_tls_stream: Option<AsyncRefCell<ServerTlsStream<TcpStream>>>,
cancel: CancelHandle, cancel: CancelHandle,
name: String, name: String,
} }
impl std::fmt::Debug for StreamResource { impl StdFileResource {
fn fmt(&self, f: &mut std::fmt::Formatter) -> std::fmt::Result {
write!(f, "StreamResource")
}
}
impl StreamResource {
pub fn stdio(fs_file: tokio::fs::File, name: &str) -> Self { pub fn stdio(fs_file: tokio::fs::File, name: &str) -> Self {
Self { Self {
fs_file: Some(AsyncRefCell::new(( fs_file: Some(AsyncRefCell::new((
@ -264,194 +439,89 @@ impl StreamResource {
} }
} }
#[cfg(unix)] async fn read(self: &Rc<Self>, buf: &mut [u8]) -> Result<usize, AnyError> {
pub fn unix_stream(unix_stream: tokio::net::UnixStream) -> Self {
Self {
unix_stream: Some(AsyncRefCell::new(unix_stream)),
name: "unixStream".to_string(),
..Default::default()
}
}
pub fn child_stdout(child: tokio::process::ChildStdout) -> Self {
Self {
child_stdout: Some(AsyncRefCell::new(child)),
name: "childStdout".to_string(),
..Default::default()
}
}
pub fn child_stderr(child: tokio::process::ChildStderr) -> Self {
Self {
child_stderr: Some(AsyncRefCell::new(child)),
name: "childStderr".to_string(),
..Default::default()
}
}
pub fn child_stdin(child: tokio::process::ChildStdin) -> Self {
Self {
child_stdin: Some(AsyncRefCell::new(child)),
name: "childStdin".to_string(),
..Default::default()
}
}
pub fn client_tls_stream(stream: ClientTlsStream<TcpStream>) -> Self {
Self {
client_tls_stream: Some(AsyncRefCell::new(stream)),
name: "clientTlsStream".to_string(),
..Default::default()
}
}
pub fn server_tls_stream(stream: ServerTlsStream<TcpStream>) -> Self {
Self {
server_tls_stream: Some(AsyncRefCell::new(stream)),
name: "serverTlsStream".to_string(),
..Default::default()
}
}
async fn read(self: Rc<Self>, buf: &mut [u8]) -> Result<usize, AnyError> {
// TODO(bartlomieju): in the future, it would be better for `StreamResource`
// to be an enum instead a struct with many `Option` fields, however I
// wasn't able to get it to work with `AsyncRefCell`s.
if self.fs_file.is_some() { if self.fs_file.is_some() {
debug_assert!(self.child_stdin.is_none()); let mut fs_file = RcRef::map(&*self, |r| r.fs_file.as_ref().unwrap())
debug_assert!(self.child_stdout.is_none());
debug_assert!(self.child_stderr.is_none());
debug_assert!(self.server_tls_stream.is_none());
debug_assert!(self.client_tls_stream.is_none());
let mut fs_file = RcRef::map(&self, |r| r.fs_file.as_ref().unwrap())
.borrow_mut() .borrow_mut()
.await; .await;
let nwritten = (*fs_file).0.as_mut().unwrap().read(buf).await?; let nwritten = fs_file.0.as_mut().unwrap().read(buf).await?;
return Ok(nwritten); return Ok(nwritten);
} else if self.child_stdout.is_some() { } else {
debug_assert!(self.child_stdin.is_none()); Err(resource_unavailable())
debug_assert!(self.child_stderr.is_none());
debug_assert!(self.server_tls_stream.is_none());
debug_assert!(self.client_tls_stream.is_none());
let mut child_stdout =
RcRef::map(&self, |r| r.child_stdout.as_ref().unwrap())
.borrow_mut()
.await;
let cancel = RcRef::map(self, |r| &r.cancel);
let nread = child_stdout.read(buf).try_or_cancel(cancel).await?;
return Ok(nread);
} else if self.child_stderr.is_some() {
debug_assert!(self.child_stdin.is_none());
debug_assert!(self.server_tls_stream.is_none());
debug_assert!(self.client_tls_stream.is_none());
let mut child_stderr =
RcRef::map(&self, |r| r.child_stderr.as_ref().unwrap())
.borrow_mut()
.await;
let cancel = RcRef::map(self, |r| &r.cancel);
let nread = child_stderr.read(buf).try_or_cancel(cancel).await?;
return Ok(nread);
} else if self.client_tls_stream.is_some() {
debug_assert!(self.server_tls_stream.is_none());
let mut client_tls_stream =
RcRef::map(&self, |r| r.client_tls_stream.as_ref().unwrap())
.borrow_mut()
.await;
let cancel = RcRef::map(self, |r| &r.cancel);
let nread = client_tls_stream.read(buf).try_or_cancel(cancel).await?;
return Ok(nread);
} else if self.server_tls_stream.is_some() {
let mut server_tls_stream =
RcRef::map(&self, |r| r.server_tls_stream.as_ref().unwrap())
.borrow_mut()
.await;
let cancel = RcRef::map(self, |r| &r.cancel);
let nread = server_tls_stream.read(buf).try_or_cancel(cancel).await?;
return Ok(nread);
} }
#[cfg(unix)]
if self.unix_stream.is_some() {
let mut unix_stream =
RcRef::map(&self, |r| r.unix_stream.as_ref().unwrap())
.borrow_mut()
.await;
let cancel = RcRef::map(self, |r| &r.cancel);
let nread = unix_stream.read(buf).try_or_cancel(cancel).await?;
return Ok(nread);
}
Err(bad_resource_id())
} }
async fn write(self: Rc<Self>, buf: &[u8]) -> Result<usize, AnyError> { async fn write(self: &Rc<Self>, buf: &[u8]) -> Result<usize, AnyError> {
// TODO(bartlomieju): in the future, it would be better for `StreamResource`
// to be an enum instead a struct with many `Option` fields, however I
// wasn't able to get it to work with `AsyncRefCell`s.
if self.fs_file.is_some() { if self.fs_file.is_some() {
debug_assert!(self.child_stdin.is_none()); let mut fs_file = RcRef::map(&*self, |r| r.fs_file.as_ref().unwrap())
debug_assert!(self.child_stdout.is_none());
debug_assert!(self.child_stderr.is_none());
debug_assert!(self.server_tls_stream.is_none());
debug_assert!(self.client_tls_stream.is_none());
let mut fs_file = RcRef::map(&self, |r| r.fs_file.as_ref().unwrap())
.borrow_mut() .borrow_mut()
.await; .await;
let nwritten = (*fs_file).0.as_mut().unwrap().write(buf).await?; let nwritten = fs_file.0.as_mut().unwrap().write(buf).await?;
(*fs_file).0.as_mut().unwrap().flush().await?; fs_file.0.as_mut().unwrap().flush().await?;
return Ok(nwritten);
} else if self.child_stdin.is_some() {
debug_assert!(self.child_stdout.is_none());
debug_assert!(self.child_stderr.is_none());
debug_assert!(self.server_tls_stream.is_none());
debug_assert!(self.client_tls_stream.is_none());
let mut child_stdin =
RcRef::map(&self, |r| r.child_stdin.as_ref().unwrap())
.borrow_mut()
.await;
let nwritten = child_stdin.write(buf).await?;
child_stdin.flush().await?;
return Ok(nwritten);
} else if self.client_tls_stream.is_some() {
debug_assert!(self.server_tls_stream.is_none());
let mut client_tls_stream =
RcRef::map(&self, |r| r.client_tls_stream.as_ref().unwrap())
.borrow_mut()
.await;
let nwritten = client_tls_stream.write(buf).await?;
client_tls_stream.flush().await?;
return Ok(nwritten);
} else if self.server_tls_stream.is_some() {
let mut server_tls_stream =
RcRef::map(&self, |r| r.server_tls_stream.as_ref().unwrap())
.borrow_mut()
.await;
let nwritten = server_tls_stream.write(buf).await?;
server_tls_stream.flush().await?;
return Ok(nwritten); return Ok(nwritten);
} else {
Err(resource_unavailable())
}
}
pub fn with<F, R>(
state: &mut OpState,
rid: u32,
mut f: F,
) -> Result<R, AnyError>
where
F: FnMut(Result<&mut std::fs::File, ()>) -> Result<R, AnyError>,
{
// First we look up the rid in the resource table.
let resource = state
.resource_table
.get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?;
// Sync write only works for FsFile. It doesn't make sense to do this
// for non-blocking sockets. So we error out if not FsFile.
if resource.fs_file.is_none() {
return f(Err(()));
} }
#[cfg(unix)] // The object in the resource table is a tokio::fs::File - but in
if self.unix_stream.is_some() { // order to do a blocking write on it, we must turn it into a
let mut unix_stream = // std::fs::File. Hopefully this code compiles down to nothing.
RcRef::map(&self, |r| r.unix_stream.as_ref().unwrap()) let fs_file_resource =
.borrow_mut() RcRef::map(&resource, |r| r.fs_file.as_ref().unwrap()).try_borrow_mut();
.await;
let nwritten = unix_stream.write(buf).await?;
unix_stream.flush().await?;
return Ok(nwritten);
}
Err(bad_resource_id()) if let Some(mut fs_file) = fs_file_resource {
let tokio_file = fs_file.0.take().unwrap();
match tokio_file.try_into_std() {
Ok(mut std_file) => {
let result = f(Ok(&mut std_file));
// Turn the std_file handle back into a tokio file, put it back
// in the resource table.
let tokio_file = tokio::fs::File::from_std(std_file);
fs_file.0 = Some(tokio_file);
// return the result.
result
}
Err(tokio_file) => {
// This function will return an error containing the file if
// some operation is in-flight.
fs_file.0 = Some(tokio_file);
Err(resource_unavailable())
}
}
} else {
Err(resource_unavailable())
}
} }
} }
impl Resource for StreamResource { impl Resource for StdFileResource {
fn name(&self) -> Cow<str> { fn name(&self) -> Cow<str> {
self.name.clone().into() self.name.as_str().into()
} }
fn close(self: Rc<Self>) { fn close(self: Rc<Self>) {
// TODO: do not cancel file I/O when file is writable.
self.cancel.cancel() self.cancel.cancel()
} }
} }
@ -460,153 +530,163 @@ pub fn op_read(
state: Rc<RefCell<OpState>>, state: Rc<RefCell<OpState>>,
is_sync: bool, is_sync: bool,
rid: i32, rid: i32,
mut zero_copy: BufVec, bufs: BufVec,
) -> MinimalOp { ) -> MinimalOp {
debug!("read rid={}", rid); match bufs.len() {
match zero_copy.len() {
0 => return MinimalOp::Sync(Err(no_buffer_specified())), 0 => return MinimalOp::Sync(Err(no_buffer_specified())),
1 => {} 1 => {}
_ => panic!("Invalid number of arguments"), _ => panic!("Invalid number of arguments"),
} };
let buf = bufs.into_iter().next().unwrap();
if is_sync { if is_sync {
MinimalOp::Sync({ MinimalOp::Sync(op_read_sync(state, rid, buf))
// First we look up the rid in the resource table.
std_file_resource(&mut state.borrow_mut(), rid as u32, move |r| match r {
Ok(std_file) => {
use std::io::Read;
std_file
.read(&mut zero_copy[0])
.map(|n: usize| n as i32)
.map_err(AnyError::from)
}
Err(_) => Err(type_error("sync read not allowed on this resource")),
})
})
} else { } else {
let mut zero_copy = zero_copy[0].clone(); MinimalOp::Async(op_read_async(state, rid, buf).boxed_local())
MinimalOp::Async({
async move {
let resource = state
.borrow()
.resource_table
.get_any(rid as u32)
.ok_or_else(bad_resource_id)?;
let nread = if let Some(stream) =
resource.downcast_rc::<TcpStreamResource>()
{
stream.read(&mut zero_copy).await?
} else if let Some(stream) = resource.downcast_rc::<StreamResource>() {
stream.clone().read(&mut zero_copy).await?
} else {
return Err(bad_resource_id());
};
Ok(nread as i32)
}
.boxed_local()
})
} }
} }
fn op_read_sync(
state: Rc<RefCell<OpState>>,
rid: i32,
mut buf: ZeroCopyBuf,
) -> Result<i32, AnyError> {
let rid = rid.try_into().map_err(|_| bad_resource_id())?;
StdFileResource::with(&mut state.borrow_mut(), rid, move |r| match r {
Ok(std_file) => std_file
.read(&mut buf)
.map(|n: usize| n as i32)
.map_err(AnyError::from),
Err(_) => Err(not_supported()),
})
}
async fn op_read_async(
state: Rc<RefCell<OpState>>,
rid: i32,
mut buf: ZeroCopyBuf,
) -> Result<i32, AnyError> {
let rid = rid.try_into().map_err(|_| bad_resource_id())?;
let resource = state
.borrow()
.resource_table
.get_any(rid)
.ok_or_else(bad_resource_id)?;
let nread = if let Some(s) = resource.downcast_rc::<ChildStdoutResource>() {
s.read(&mut buf).await?
} else if let Some(s) = resource.downcast_rc::<ChildStderrResource>() {
s.read(&mut buf).await?
} else if let Some(s) = resource.downcast_rc::<TcpStreamResource>() {
s.read(&mut buf).await?
} else if let Some(s) = resource.downcast_rc::<TlsClientStreamResource>() {
s.read(&mut buf).await?
} else if let Some(s) = resource.downcast_rc::<TlsServerStreamResource>() {
s.read(&mut buf).await?
} else if let Some(s) = resource.downcast_rc::<UnixStreamResource>() {
s.read(&mut buf).await?
} else if let Some(s) = resource.downcast_rc::<StdFileResource>() {
s.read(&mut buf).await?
} else {
return Err(not_supported());
};
Ok(nread as i32)
}
pub fn op_write( pub fn op_write(
state: Rc<RefCell<OpState>>, state: Rc<RefCell<OpState>>,
is_sync: bool, is_sync: bool,
rid: i32, rid: i32,
zero_copy: BufVec, bufs: BufVec,
) -> MinimalOp { ) -> MinimalOp {
debug!("write rid={}", rid); match bufs.len() {
match zero_copy.len() {
0 => return MinimalOp::Sync(Err(no_buffer_specified())), 0 => return MinimalOp::Sync(Err(no_buffer_specified())),
1 => {} 1 => {}
_ => panic!("Invalid number of arguments"), _ => panic!("Invalid number of arguments"),
} };
let buf = bufs.into_iter().next().unwrap();
if is_sync { if is_sync {
MinimalOp::Sync({ MinimalOp::Sync(op_write_sync(state, rid, buf))
// First we look up the rid in the resource table.
std_file_resource(&mut state.borrow_mut(), rid as u32, move |r| match r {
Ok(std_file) => {
use std::io::Write;
std_file
.write(&zero_copy[0])
.map(|nwritten: usize| nwritten as i32)
.map_err(AnyError::from)
}
Err(_) => Err(type_error("sync read not allowed on this resource")),
})
})
} else { } else {
let zero_copy = zero_copy[0].clone(); MinimalOp::Async(op_write_async(state, rid, buf).boxed_local())
MinimalOp::Async({
async move {
let resource = state
.borrow()
.resource_table
.get_any(rid as u32)
.ok_or_else(bad_resource_id)?;
let nwritten = if let Some(stream) =
resource.downcast_rc::<TcpStreamResource>()
{
stream.write(&zero_copy).await?
} else if let Some(stream) = resource.downcast_rc::<StreamResource>() {
stream.clone().write(&zero_copy).await?
} else {
return Err(bad_resource_id());
};
Ok(nwritten as i32)
}
.boxed_local()
})
} }
} }
pub fn std_file_resource<F, T>( fn op_write_sync(
state: &mut OpState, state: Rc<RefCell<OpState>>,
rid: u32, rid: i32,
mut f: F, buf: ZeroCopyBuf,
) -> Result<T, AnyError> ) -> Result<i32, AnyError> {
where let rid = rid.try_into().map_err(|_| bad_resource_id())?;
F: FnMut(Result<&mut std::fs::File, ()>) -> Result<T, AnyError>, StdFileResource::with(&mut state.borrow_mut(), rid, move |r| match r {
{ Ok(std_file) => std_file
// First we look up the rid in the resource table. .write(&buf)
.map(|nwritten: usize| nwritten as i32)
.map_err(AnyError::from),
Err(_) => Err(not_supported()),
})
}
async fn op_write_async(
state: Rc<RefCell<OpState>>,
rid: i32,
buf: ZeroCopyBuf,
) -> Result<i32, AnyError> {
let rid = rid.try_into().map_err(|_| bad_resource_id())?;
let resource = state let resource = state
.borrow()
.resource_table .resource_table
.get::<StreamResource>(rid) .get_any(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
let nwritten = if let Some(s) = resource.downcast_rc::<ChildStdinResource>() {
// Sync write only works for FsFile. It doesn't make sense to do this s.write(&buf).await?
// for non-blocking sockets. So we error out if not FsFile. } else if let Some(s) = resource.downcast_rc::<TcpStreamResource>() {
if resource.fs_file.is_none() { s.write(&buf).await?
return f(Err(())); } else if let Some(s) = resource.downcast_rc::<TlsClientStreamResource>() {
} s.write(&buf).await?
} else if let Some(s) = resource.downcast_rc::<TlsServerStreamResource>() {
// The object in the resource table is a tokio::fs::File - but in s.write(&buf).await?
// order to do a blocking write on it, we must turn it into a } else if let Some(s) = resource.downcast_rc::<UnixStreamResource>() {
// std::fs::File. Hopefully this code compiles down to nothing. s.write(&buf).await?
} else if let Some(s) = resource.downcast_rc::<StdFileResource>() {
let fs_file_resource = s.write(&buf).await?
RcRef::map(&resource, |r| r.fs_file.as_ref().unwrap()).try_borrow_mut();
if let Some(mut fs_file) = fs_file_resource {
let tokio_file = fs_file.0.take().unwrap();
match tokio_file.try_into_std() {
Ok(mut std_file) => {
let result = f(Ok(&mut std_file));
// Turn the std_file handle back into a tokio file, put it back
// in the resource table.
let tokio_file = tokio::fs::File::from_std(std_file);
fs_file.0 = Some(tokio_file);
// return the result.
result
}
Err(tokio_file) => {
// This function will return an error containing the file if
// some operation is in-flight.
fs_file.0 = Some(tokio_file);
Err(resource_unavailable())
}
}
} else { } else {
Err(resource_unavailable()) return Err(not_supported());
} };
Ok(nwritten as i32)
}
#[derive(Deserialize)]
struct ShutdownArgs {
rid: i32,
}
async fn op_shutdown(
state: Rc<RefCell<OpState>>,
args: Value,
_zero_copy: BufVec,
) -> Result<Value, AnyError> {
let rid = serde_json::from_value::<ShutdownArgs>(args)?
.rid
.try_into()
.map_err(|_| bad_resource_id())?;
let resource = state
.borrow()
.resource_table
.get_any(rid)
.ok_or_else(bad_resource_id)?;
if let Some(s) = resource.downcast_rc::<ChildStdinResource>() {
s.shutdown().await?;
} else if let Some(s) = resource.downcast_rc::<TcpStreamResource>() {
s.shutdown().await?;
} else if let Some(s) = resource.downcast_rc::<TlsClientStreamResource>() {
s.shutdown().await?;
} else if let Some(s) = resource.downcast_rc::<TlsServerStreamResource>() {
s.shutdown().await?;
} else if let Some(s) = resource.downcast_rc::<UnixStreamResource>() {
s.shutdown().await?;
} else {
return Err(not_supported());
}
Ok(json!({}))
} }

View file

@ -5,7 +5,6 @@ use crate::permissions::Permissions;
use crate::resolve_addr::resolve_addr; use crate::resolve_addr::resolve_addr;
use crate::resolve_addr::resolve_addr_sync; use crate::resolve_addr::resolve_addr_sync;
use deno_core::error::bad_resource; use deno_core::error::bad_resource;
use deno_core::error::bad_resource_id;
use deno_core::error::custom_error; use deno_core::error::custom_error;
use deno_core::error::generic_error; use deno_core::error::generic_error;
use deno_core::error::type_error; use deno_core::error::type_error;
@ -27,7 +26,6 @@ use std::borrow::Cow;
use std::cell::RefCell; use std::cell::RefCell;
use std::net::SocketAddr; use std::net::SocketAddr;
use std::rc::Rc; use std::rc::Rc;
use tokio::io::AsyncWriteExt;
use tokio::net::TcpListener; use tokio::net::TcpListener;
use tokio::net::TcpStream; use tokio::net::TcpStream;
use tokio::net::UdpSocket; use tokio::net::UdpSocket;
@ -42,14 +40,13 @@ use trust_dns_resolver::AsyncResolver;
#[cfg(unix)] #[cfg(unix)]
use super::net_unix; use super::net_unix;
#[cfg(unix)] #[cfg(unix)]
use crate::ops::io::StreamResource; use crate::ops::io::UnixStreamResource;
#[cfg(unix)] #[cfg(unix)]
use std::path::Path; use std::path::Path;
pub fn init(rt: &mut deno_core::JsRuntime) { pub fn init(rt: &mut deno_core::JsRuntime) {
super::reg_json_async(rt, "op_accept", op_accept); super::reg_json_async(rt, "op_accept", op_accept);
super::reg_json_async(rt, "op_connect", op_connect); super::reg_json_async(rt, "op_connect", op_connect);
super::reg_json_async(rt, "op_shutdown", op_shutdown);
super::reg_json_sync(rt, "op_listen", op_listen); super::reg_json_sync(rt, "op_listen", op_listen);
super::reg_json_async(rt, "op_datagram_receive", op_datagram_receive); super::reg_json_async(rt, "op_datagram_receive", op_datagram_receive);
super::reg_json_async(rt, "op_datagram_send", op_datagram_send); super::reg_json_async(rt, "op_datagram_send", op_datagram_send);
@ -318,7 +315,7 @@ async fn op_connect(
let remote_addr = unix_stream.peer_addr()?; let remote_addr = unix_stream.peer_addr()?;
let mut state_ = state.borrow_mut(); let mut state_ = state.borrow_mut();
let resource = StreamResource::unix_stream(unix_stream); let resource = UnixStreamResource::new(unix_stream.into_split());
let rid = state_.resource_table.add(resource); let rid = state_.resource_table.add(resource);
Ok(json!({ Ok(json!({
"rid": rid, "rid": rid,
@ -336,44 +333,6 @@ async fn op_connect(
} }
} }
#[derive(Deserialize)]
struct ShutdownArgs {
rid: i32,
}
async fn op_shutdown(
state: Rc<RefCell<OpState>>,
args: Value,
_zero_copy: BufVec,
) -> Result<Value, AnyError> {
let args: ShutdownArgs = serde_json::from_value(args)?;
let rid = args.rid as u32;
let resource = state
.borrow()
.resource_table
.get_any(rid)
.ok_or_else(bad_resource_id)?;
if let Some(stream) = resource.downcast_rc::<TcpStreamResource>() {
let mut wr = stream.wr_borrow_mut().await;
wr.shutdown().await?;
return Ok(json!({}));
}
#[cfg(unix)]
if let Some(stream) = resource.downcast_rc::<StreamResource>() {
if stream.unix_stream.is_some() {
let mut wr = RcRef::map(stream, |r| r.unix_stream.as_ref().unwrap())
.borrow_mut()
.await;
wr.shutdown().await?;
return Ok(json!({}));
}
}
Err(bad_resource_id())
}
struct TcpListenerResource { struct TcpListenerResource {
listener: AsyncRefCell<TcpListener>, listener: AsyncRefCell<TcpListener>,
cancel: CancelHandle, cancel: CancelHandle,

View file

@ -1,6 +1,6 @@
// Copyright 2018-2021 the Deno authors. All rights reserved. MIT license. // Copyright 2018-2021 the Deno authors. All rights reserved. MIT license.
use crate::ops::io::StreamResource; use crate::ops::io::UnixStreamResource;
use crate::ops::net::AcceptArgs; use crate::ops::net::AcceptArgs;
use crate::ops::net::ReceiveArgs; use crate::ops::net::ReceiveArgs;
use deno_core::error::bad_resource; use deno_core::error::bad_resource;
@ -81,7 +81,7 @@ pub(crate) async fn accept_unix(
let local_addr = unix_stream.local_addr()?; let local_addr = unix_stream.local_addr()?;
let remote_addr = unix_stream.peer_addr()?; let remote_addr = unix_stream.peer_addr()?;
let resource = StreamResource::unix_stream(unix_stream); let resource = UnixStreamResource::new(unix_stream.into_split());
let mut state = state.borrow_mut(); let mut state = state.borrow_mut();
let rid = state.resource_table.add(resource); let rid = state.resource_table.add(resource);
Ok(json!({ Ok(json!({

View file

@ -1,6 +1,9 @@
// Copyright 2018-2021 the Deno authors. All rights reserved. MIT license. // Copyright 2018-2021 the Deno authors. All rights reserved. MIT license.
use super::io::{std_file_resource, StreamResource}; use super::io::ChildStderrResource;
use super::io::ChildStdinResource;
use super::io::ChildStdoutResource;
use super::io::StdFileResource;
use crate::permissions::Permissions; use crate::permissions::Permissions;
use deno_core::error::bad_resource_id; use deno_core::error::bad_resource_id;
use deno_core::error::type_error; use deno_core::error::type_error;
@ -34,7 +37,7 @@ fn clone_file(
state: &mut OpState, state: &mut OpState,
rid: u32, rid: u32,
) -> Result<std::fs::File, AnyError> { ) -> Result<std::fs::File, AnyError> {
std_file_resource(state, rid, move |r| match r { StdFileResource::with(state, rid, move |r| match r {
Ok(std_file) => std_file.try_clone().map_err(AnyError::from), Ok(std_file) => std_file.try_clone().map_err(AnyError::from),
Err(_) => Err(bad_resource_id()), Err(_) => Err(bad_resource_id()),
}) })
@ -134,7 +137,7 @@ fn op_run(
Some(child_stdin) => { Some(child_stdin) => {
let rid = state let rid = state
.resource_table .resource_table
.add(StreamResource::child_stdin(child_stdin)); .add(ChildStdinResource::from(child_stdin));
Some(rid) Some(rid)
} }
None => None, None => None,
@ -144,7 +147,7 @@ fn op_run(
Some(child_stdout) => { Some(child_stdout) => {
let rid = state let rid = state
.resource_table .resource_table
.add(StreamResource::child_stdout(child_stdout)); .add(ChildStdoutResource::from(child_stdout));
Some(rid) Some(rid)
} }
None => None, None => None,
@ -154,7 +157,7 @@ fn op_run(
Some(child_stderr) => { Some(child_stderr) => {
let rid = state let rid = state
.resource_table .resource_table
.add(StreamResource::child_stderr(child_stderr)); .add(ChildStderrResource::from(child_stderr));
Some(rid) Some(rid)
} }
None => None, None => None,

View file

@ -1,7 +1,8 @@
// Copyright 2018-2021 the Deno authors. All rights reserved. MIT license. // Copyright 2018-2021 the Deno authors. All rights reserved. MIT license.
use super::io::StreamResource;
use super::io::TcpStreamResource; use super::io::TcpStreamResource;
use super::io::TlsClientStreamResource;
use super::io::TlsServerStreamResource;
use crate::permissions::Permissions; use crate::permissions::Permissions;
use crate::resolve_addr::resolve_addr; use crate::resolve_addr::resolve_addr;
use crate::resolve_addr::resolve_addr_sync; use crate::resolve_addr::resolve_addr_sync;
@ -148,7 +149,7 @@ async fn op_start_tls(
let mut state_ = state.borrow_mut(); let mut state_ = state.borrow_mut();
state_ state_
.resource_table .resource_table
.add(StreamResource::client_tls_stream(tls_stream)) .add(TlsClientStreamResource::from(tls_stream))
}; };
Ok(json!({ Ok(json!({
"rid": rid, "rid": rid,
@ -210,7 +211,7 @@ async fn op_connect_tls(
let mut state_ = state.borrow_mut(); let mut state_ = state.borrow_mut();
state_ state_
.resource_table .resource_table
.add(StreamResource::client_tls_stream(tls_stream)) .add(TlsClientStreamResource::from(tls_stream))
}; };
Ok(json!({ Ok(json!({
"rid": rid, "rid": rid,
@ -402,7 +403,7 @@ async fn op_accept_tls(
let mut state_ = state.borrow_mut(); let mut state_ = state.borrow_mut();
state_ state_
.resource_table .resource_table
.add(StreamResource::server_tls_stream(tls_stream)) .add(TlsServerStreamResource::from(tls_stream))
}; };
Ok(json!({ Ok(json!({

View file

@ -1,7 +1,6 @@
// Copyright 2018-2021 the Deno authors. All rights reserved. MIT license. // Copyright 2018-2021 the Deno authors. All rights reserved. MIT license.
use super::io::std_file_resource; use super::io::StdFileResource;
use super::io::StreamResource;
use deno_core::error::bad_resource_id; use deno_core::error::bad_resource_id;
use deno_core::error::not_supported; use deno_core::error::not_supported;
use deno_core::error::resource_unavailable; use deno_core::error::resource_unavailable;
@ -90,7 +89,7 @@ fn op_set_raw(
let resource = state let resource = state
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if cbreak { if cbreak {
@ -157,7 +156,7 @@ fn op_set_raw(
let resource = state let resource = state
.resource_table .resource_table
.get::<StreamResource>(rid) .get::<StdFileResource>(rid)
.ok_or_else(bad_resource_id)?; .ok_or_else(bad_resource_id)?;
if resource.fs_file.is_none() { if resource.fs_file.is_none() {
@ -229,26 +228,27 @@ fn op_isatty(
let args: IsattyArgs = serde_json::from_value(args)?; let args: IsattyArgs = serde_json::from_value(args)?;
let rid = args.rid; let rid = args.rid;
let isatty: bool = std_file_resource(state, rid as u32, move |r| match r { let isatty: bool =
Ok(std_file) => { StdFileResource::with(state, rid as u32, move |r| match r {
#[cfg(windows)] Ok(std_file) => {
{ #[cfg(windows)]
use winapi::um::consoleapi; {
use winapi::um::consoleapi;
let handle = get_windows_handle(&std_file)?; let handle = get_windows_handle(&std_file)?;
let mut test_mode: DWORD = 0; let mut test_mode: DWORD = 0;
// If I cannot get mode out of console, it is not a console. // If I cannot get mode out of console, it is not a console.
Ok(unsafe { consoleapi::GetConsoleMode(handle, &mut test_mode) != 0 }) Ok(unsafe { consoleapi::GetConsoleMode(handle, &mut test_mode) != 0 })
}
#[cfg(unix)]
{
use std::os::unix::io::AsRawFd;
let raw_fd = std_file.as_raw_fd();
Ok(unsafe { libc::isatty(raw_fd as libc::c_int) == 1 })
}
} }
#[cfg(unix)] _ => Ok(false),
{ })?;
use std::os::unix::io::AsRawFd;
let raw_fd = std_file.as_raw_fd();
Ok(unsafe { libc::isatty(raw_fd as libc::c_int) == 1 })
}
}
_ => Ok(false),
})?;
Ok(json!(isatty)) Ok(json!(isatty))
} }
@ -273,7 +273,7 @@ fn op_console_size(
let args: ConsoleSizeArgs = serde_json::from_value(args)?; let args: ConsoleSizeArgs = serde_json::from_value(args)?;
let rid = args.rid; let rid = args.rid;
let size = std_file_resource(state, rid as u32, move |r| match r { let size = StdFileResource::with(state, rid as u32, move |r| match r {
Ok(std_file) => { Ok(std_file) => {
#[cfg(windows)] #[cfg(windows)]
{ {

View file

@ -14,7 +14,9 @@ export function mockConn(base: Partial<Deno.Conn> = {}): Deno.Conn {
port: 0, port: 0,
}, },
rid: -1, rid: -1,
closeWrite: (): void => {}, closeWrite: (): Promise<void> => {
return Promise.resolve();
},
read: (): Promise<number | null> => { read: (): Promise<number | null> => {
return Promise.resolve(0); return Promise.resolve(0);
}, },

View file

@ -102,7 +102,7 @@ Deno.test("[ws] read unmasked ping / pong frame", async () => {
); );
assertEquals(actual1, "Hello"); assertEquals(actual1, "Hello");
// deno-fmt-ignore // deno-fmt-ignore
const pongFrame= [0x8a, 0x85, 0x37, 0xfa, 0x21, 0x3d, 0x7f, 0x9f, 0x4d, 0x51, 0x58] const pongFrame = [0x8a, 0x85, 0x37, 0xfa, 0x21, 0x3d, 0x7f, 0x9f, 0x4d, 0x51, 0x58]
const buf2 = new BufReader(new Deno.Buffer(new Uint8Array(pongFrame))); const buf2 = new BufReader(new Deno.Buffer(new Uint8Array(pongFrame)));
const pong = await readFrame(buf2); const pong = await readFrame(buf2);
assertEquals(pong.opcode, OpCode.Pong); assertEquals(pong.opcode, OpCode.Pong);
@ -283,7 +283,7 @@ Deno.test("[ws] ws.close() should use 1000 as close code", async () => {
function dummyConn(r: Deno.Reader, w: Deno.Writer): Deno.Conn { function dummyConn(r: Deno.Reader, w: Deno.Writer): Deno.Conn {
return { return {
rid: -1, rid: -1,
closeWrite: (): void => {}, closeWrite: (): Promise<void> => Promise.resolve(),
read: (x: Uint8Array): Promise<number | null> => r.read(x), read: (x: Uint8Array): Promise<number | null> => r.read(x),
write: (x: Uint8Array): Promise<number> => w.write(x), write: (x: Uint8Array): Promise<number> => w.write(x),
close: (): void => {}, close: (): void => {},