mirror of
https://github.com/denoland/deno.git
synced 2024-12-22 07:14:47 -05:00
refactor(core): Strongly typed deserialization of JSON ops (#9423)
This PR makes json_op_sync/async generic to all Deserialize/Serialize types instead of the loosely-typed serde_json::Value. Since serde_json::Value implements Deserialize/Serialize, very little existing code needs to be updated, however as json_op_sync/async are now generic, type inference is broken in some cases (see cli/build.rs:146). I've found this reduces a good bit of boilerplate, as seen in the updated deno_core examples. This change may also reduce serialization and deserialization overhead as serde has a better idea of what types it is working with. I am currently working on benchmarks to confirm this and I will update this PR with my findings.
This commit is contained in:
parent
af460fc464
commit
b50691efed
8 changed files with 67 additions and 109 deletions
|
@ -8,6 +8,7 @@ use deno_core::JsRuntime;
|
|||
use deno_core::RuntimeOptions;
|
||||
use regex::Regex;
|
||||
use serde::Deserialize;
|
||||
use serde_json::Value;
|
||||
use std::collections::HashMap;
|
||||
use std::env;
|
||||
use std::path::Path;
|
||||
|
@ -142,7 +143,7 @@ fn create_compiler_snapshot(
|
|||
});
|
||||
js_runtime.register_op(
|
||||
"op_build_info",
|
||||
json_op_sync(move |_state, _args, _bufs| {
|
||||
json_op_sync(move |_state, _args: Value, _bufs| {
|
||||
Ok(json!({
|
||||
"buildSpecifier": build_specifier,
|
||||
"libs": build_libs,
|
||||
|
|
|
@ -21,22 +21,8 @@ unitTest(function malformedJsonControlBuffer(): void {
|
|||
|
||||
unitTest(function invalidPromiseId(): void {
|
||||
const opId = Deno.core.ops()["op_open_async"];
|
||||
const argsObj = {
|
||||
promiseId: "1. NEIN!",
|
||||
path: "/tmp/P.I.S.C.I.X/yeah",
|
||||
mode: 0o666,
|
||||
options: {
|
||||
read: true,
|
||||
write: true,
|
||||
create: true,
|
||||
truncate: false,
|
||||
append: false,
|
||||
createNew: false,
|
||||
},
|
||||
};
|
||||
const argsText = JSON.stringify(argsObj);
|
||||
const argsBuf = new TextEncoder().encode(argsText);
|
||||
const resBuf = Deno.core.send(opId, argsBuf);
|
||||
const reqBuf = new Uint8Array([0, 0, 0, 0, 0, 0, 0]);
|
||||
const resBuf = Deno.core.send(opId, reqBuf);
|
||||
const resText = new TextDecoder().decode(resBuf);
|
||||
const resObj = JSON.parse(resText);
|
||||
console.error(resText);
|
||||
|
|
13
core/core.js
13
core/core.js
|
@ -213,12 +213,13 @@ SharedQueue Binary Layout
|
|||
throw new ErrorClass(res.err.message);
|
||||
}
|
||||
|
||||
async function jsonOpAsync(opName, args = {}, ...zeroCopy) {
|
||||
async function jsonOpAsync(opName, args = null, ...zeroCopy) {
|
||||
setAsyncHandler(opsCache[opName], jsonOpAsyncHandler);
|
||||
|
||||
args.promiseId = nextPromiseId++;
|
||||
const argsBuf = encodeJson(args);
|
||||
dispatch(opName, argsBuf, ...zeroCopy);
|
||||
const promiseId = nextPromiseId++;
|
||||
const reqBuf = core.encode("\0".repeat(8) + JSON.stringify(args));
|
||||
new DataView(reqBuf.buffer).setBigUint64(0, BigInt(promiseId));
|
||||
dispatch(opName, reqBuf, ...zeroCopy);
|
||||
let resolve, reject;
|
||||
const promise = new Promise((resolve_, reject_) => {
|
||||
resolve = resolve_;
|
||||
|
@ -226,11 +227,11 @@ SharedQueue Binary Layout
|
|||
});
|
||||
promise.resolve = resolve;
|
||||
promise.reject = reject;
|
||||
promiseTable[args.promiseId] = promise;
|
||||
promiseTable[promiseId] = promise;
|
||||
return processResponse(await promise);
|
||||
}
|
||||
|
||||
function jsonOpSync(opName, args = {}, ...zeroCopy) {
|
||||
function jsonOpSync(opName, args = null, ...zeroCopy) {
|
||||
const argsBuf = encodeJson(args);
|
||||
const res = dispatch(opName, argsBuf, ...zeroCopy);
|
||||
return processResponse(decodeJson(res));
|
||||
|
|
|
@ -50,27 +50,13 @@ fn main() {
|
|||
// The json_op_sync function automatically deserializes
|
||||
// the first ZeroCopyBuf and serializes the return value
|
||||
// to reduce boilerplate
|
||||
json_op_sync(|_state, json, zero_copy| {
|
||||
// We check that we only got the JSON value,
|
||||
// and that it's of the right type.
|
||||
json_op_sync(|_state, json: Vec<f64>, zero_copy| {
|
||||
// We check that we only got the JSON value.
|
||||
if !zero_copy.is_empty() {
|
||||
Err(anyhow!("Expected exactly one argument"))
|
||||
} else if !json.is_array() {
|
||||
Err(anyhow!("Argument is not of type array"))
|
||||
} else if !json
|
||||
.as_array()
|
||||
.unwrap()
|
||||
.iter()
|
||||
.all(|value| value.is_number())
|
||||
{
|
||||
Err(anyhow!("Argument is not array of numbers"))
|
||||
} else {
|
||||
// And if everything checks out we do our actual task
|
||||
let sum = json
|
||||
.as_array()
|
||||
.unwrap()
|
||||
.iter()
|
||||
.fold(0.0, |a, v| a + v.as_f64().unwrap());
|
||||
// And if we did, do our actual task
|
||||
let sum = json.iter().fold(0.0, |a, v| a + v);
|
||||
|
||||
// Finally we return a JSON value
|
||||
Ok(Value::from(sum))
|
||||
|
|
|
@ -11,7 +11,7 @@ const responseBuf = new Uint8Array(
|
|||
|
||||
/** Listens on 0.0.0.0:4500, returns rid. */
|
||||
function listen() {
|
||||
const { rid } = Deno.core.jsonOpSync("listen", {});
|
||||
const { rid } = Deno.core.jsonOpSync("listen");
|
||||
return rid;
|
||||
}
|
||||
|
||||
|
|
|
@ -14,10 +14,11 @@ use deno_core::OpState;
|
|||
use deno_core::RcRef;
|
||||
use deno_core::Resource;
|
||||
use deno_core::ZeroCopyBuf;
|
||||
use serde::Deserialize;
|
||||
use serde::Serialize;
|
||||
use serde_json::Value;
|
||||
use std::cell::RefCell;
|
||||
use std::convert::TryFrom;
|
||||
use std::convert::TryInto;
|
||||
use std::env;
|
||||
use std::io::Error;
|
||||
use std::net::SocketAddr;
|
||||
|
@ -124,83 +125,67 @@ fn create_js_runtime() -> JsRuntime {
|
|||
runtime
|
||||
}
|
||||
|
||||
#[derive(Deserialize, Serialize)]
|
||||
struct ResourceId {
|
||||
rid: u32,
|
||||
}
|
||||
|
||||
fn op_listen(
|
||||
state: &mut OpState,
|
||||
_args: Value,
|
||||
_args: (),
|
||||
_bufs: &mut [ZeroCopyBuf],
|
||||
) -> Result<Value, AnyError> {
|
||||
) -> Result<ResourceId, AnyError> {
|
||||
debug!("listen");
|
||||
let addr = "127.0.0.1:4544".parse::<SocketAddr>().unwrap();
|
||||
let std_listener = std::net::TcpListener::bind(&addr)?;
|
||||
std_listener.set_nonblocking(true)?;
|
||||
let listener = TcpListener::try_from(std_listener)?;
|
||||
let rid = state.resource_table.add(listener);
|
||||
Ok(serde_json::json!({ "rid": rid }))
|
||||
Ok(ResourceId { rid })
|
||||
}
|
||||
|
||||
fn op_close(
|
||||
state: &mut OpState,
|
||||
args: Value,
|
||||
args: ResourceId,
|
||||
_buf: &mut [ZeroCopyBuf],
|
||||
) -> Result<Value, AnyError> {
|
||||
let rid: u32 = args
|
||||
.get("rid")
|
||||
.unwrap()
|
||||
.as_u64()
|
||||
.unwrap()
|
||||
.try_into()
|
||||
.unwrap();
|
||||
debug!("close rid={}", rid);
|
||||
) -> Result<(), AnyError> {
|
||||
debug!("close rid={}", args.rid);
|
||||
state
|
||||
.resource_table
|
||||
.close(rid)
|
||||
.map(|_| serde_json::json!(()))
|
||||
.close(args.rid)
|
||||
.map(|_| ())
|
||||
.ok_or_else(bad_resource_id)
|
||||
}
|
||||
|
||||
async fn op_accept(
|
||||
state: Rc<RefCell<OpState>>,
|
||||
args: Value,
|
||||
args: ResourceId,
|
||||
_bufs: BufVec,
|
||||
) -> Result<Value, AnyError> {
|
||||
let rid: u32 = args
|
||||
.get("rid")
|
||||
.unwrap()
|
||||
.as_u64()
|
||||
.unwrap()
|
||||
.try_into()
|
||||
.unwrap();
|
||||
debug!("accept rid={}", rid);
|
||||
) -> Result<ResourceId, AnyError> {
|
||||
debug!("accept rid={}", args.rid);
|
||||
|
||||
let listener = state
|
||||
.borrow()
|
||||
.resource_table
|
||||
.get::<TcpListener>(rid)
|
||||
.get::<TcpListener>(args.rid)
|
||||
.ok_or_else(bad_resource_id)?;
|
||||
let stream = listener.accept().await?;
|
||||
let rid = state.borrow_mut().resource_table.add(stream);
|
||||
Ok(serde_json::json!({ "rid": rid }))
|
||||
Ok(ResourceId { rid })
|
||||
}
|
||||
|
||||
async fn op_read(
|
||||
state: Rc<RefCell<OpState>>,
|
||||
args: Value,
|
||||
args: ResourceId,
|
||||
mut bufs: BufVec,
|
||||
) -> Result<Value, AnyError> {
|
||||
assert_eq!(bufs.len(), 1, "Invalid number of arguments");
|
||||
let rid: u32 = args
|
||||
.get("rid")
|
||||
.unwrap()
|
||||
.as_u64()
|
||||
.unwrap()
|
||||
.try_into()
|
||||
.unwrap();
|
||||
debug!("read rid={}", rid);
|
||||
debug!("read rid={}", args.rid);
|
||||
|
||||
let stream = state
|
||||
.borrow()
|
||||
.resource_table
|
||||
.get::<TcpStream>(rid)
|
||||
.get::<TcpStream>(args.rid)
|
||||
.ok_or_else(bad_resource_id)?;
|
||||
let nread = stream.read(&mut bufs[0]).await?;
|
||||
Ok(serde_json::json!({ "nread": nread }))
|
||||
|
@ -208,23 +193,16 @@ async fn op_read(
|
|||
|
||||
async fn op_write(
|
||||
state: Rc<RefCell<OpState>>,
|
||||
args: Value,
|
||||
args: ResourceId,
|
||||
bufs: BufVec,
|
||||
) -> Result<Value, AnyError> {
|
||||
assert_eq!(bufs.len(), 1, "Invalid number of arguments");
|
||||
let rid: u32 = args
|
||||
.get("rid")
|
||||
.unwrap()
|
||||
.as_u64()
|
||||
.unwrap()
|
||||
.try_into()
|
||||
.unwrap();
|
||||
debug!("write rid={}", rid);
|
||||
debug!("write rid={}", args.rid);
|
||||
|
||||
let stream = state
|
||||
.borrow()
|
||||
.resource_table
|
||||
.get::<TcpStream>(rid)
|
||||
.get::<TcpStream>(args.rid)
|
||||
.ok_or_else(bad_resource_id)?;
|
||||
let nwritten = stream.write(&bufs[0]).await?;
|
||||
Ok(serde_json::json!({ "nwritten": nwritten }))
|
||||
|
|
4
core/lib.deno_core.d.ts
vendored
4
core/lib.deno_core.d.ts
vendored
|
@ -10,14 +10,14 @@ declare namespace Deno {
|
|||
/** Send a JSON op to Rust, and synchronously receive the result. */
|
||||
function jsonOpSync(
|
||||
opName: string,
|
||||
args: any,
|
||||
args?: any,
|
||||
...zeroCopy: Uint8Array[]
|
||||
): any;
|
||||
|
||||
/** Send a JSON op to Rust, and asynchronously receive the result. */
|
||||
function jsonOpAsync(
|
||||
opName: string,
|
||||
args: any,
|
||||
args?: any,
|
||||
...zeroCopy: Uint8Array[]
|
||||
): Promise<any>;
|
||||
|
||||
|
|
40
core/ops.rs
40
core/ops.rs
|
@ -10,10 +10,13 @@ use crate::BufVec;
|
|||
use crate::ZeroCopyBuf;
|
||||
use futures::Future;
|
||||
use indexmap::IndexMap;
|
||||
use serde::de::DeserializeOwned;
|
||||
use serde::Serialize;
|
||||
use serde_json::json;
|
||||
use serde_json::Value;
|
||||
use std::cell::RefCell;
|
||||
use std::collections::HashMap;
|
||||
use std::convert::TryInto;
|
||||
use std::iter::once;
|
||||
use std::ops::Deref;
|
||||
use std::ops::DerefMut;
|
||||
|
@ -118,10 +121,10 @@ impl Default for OpTable {
|
|||
///
|
||||
/// The provided function `op_fn` has the following parameters:
|
||||
/// * `&mut OpState`: the op state, can be used to read/write resources in the runtime from an op.
|
||||
/// * `Value`: the JSON value that is passed to the Rust function.
|
||||
/// * `V`: the deserializable value that is passed to the Rust function.
|
||||
/// * `&mut [ZeroCopyBuf]`: raw bytes passed along, usually not needed if the JSON value is used.
|
||||
///
|
||||
/// `op_fn` returns a JSON value, which is directly returned to JavaScript.
|
||||
/// `op_fn` returns a serializable value, which is directly returned to JavaScript.
|
||||
///
|
||||
/// When registering an op like this...
|
||||
/// ```ignore
|
||||
|
@ -137,10 +140,11 @@ impl Default for OpTable {
|
|||
///
|
||||
/// The `Deno.core.ops()` statement is needed once before any op calls, for initialization.
|
||||
/// A more complete example is available in the examples directory.
|
||||
pub fn json_op_sync<F>(op_fn: F) -> Box<OpFn>
|
||||
pub fn json_op_sync<F, V, R>(op_fn: F) -> Box<OpFn>
|
||||
where
|
||||
F: Fn(&mut OpState, Value, &mut [ZeroCopyBuf]) -> Result<Value, AnyError>
|
||||
+ 'static,
|
||||
F: Fn(&mut OpState, V, &mut [ZeroCopyBuf]) -> Result<R, AnyError> + 'static,
|
||||
V: DeserializeOwned,
|
||||
R: Serialize,
|
||||
{
|
||||
Box::new(move |state: Rc<RefCell<OpState>>, mut bufs: BufVec| -> Op {
|
||||
let result = serde_json::from_slice(&bufs[0])
|
||||
|
@ -156,10 +160,10 @@ where
|
|||
///
|
||||
/// The provided function `op_fn` has the following parameters:
|
||||
/// * `Rc<RefCell<OpState>`: the op state, can be used to read/write resources in the runtime from an op.
|
||||
/// * `Value`: the JSON value that is passed to the Rust function.
|
||||
/// * `V`: the deserializable value that is passed to the Rust function.
|
||||
/// * `BufVec`: raw bytes passed along, usually not needed if the JSON value is used.
|
||||
///
|
||||
/// `op_fn` returns a future, whose output is a JSON value. This value will be asynchronously
|
||||
/// `op_fn` returns a future, whose output is a serializable value. This value will be asynchronously
|
||||
/// returned to JavaScript.
|
||||
///
|
||||
/// When registering an op like this...
|
||||
|
@ -176,18 +180,20 @@ where
|
|||
///
|
||||
/// The `Deno.core.ops()` statement is needed once before any op calls, for initialization.
|
||||
/// A more complete example is available in the examples directory.
|
||||
pub fn json_op_async<F, R>(op_fn: F) -> Box<OpFn>
|
||||
pub fn json_op_async<F, V, R, RV>(op_fn: F) -> Box<OpFn>
|
||||
where
|
||||
F: Fn(Rc<RefCell<OpState>>, Value, BufVec) -> R + 'static,
|
||||
R: Future<Output = Result<Value, AnyError>> + 'static,
|
||||
F: Fn(Rc<RefCell<OpState>>, V, BufVec) -> R + 'static,
|
||||
V: DeserializeOwned,
|
||||
R: Future<Output = Result<RV, AnyError>> + 'static,
|
||||
RV: Serialize,
|
||||
{
|
||||
let try_dispatch_op =
|
||||
move |state: Rc<RefCell<OpState>>, bufs: BufVec| -> Result<Op, AnyError> {
|
||||
let args: Value = serde_json::from_slice(&bufs[0])?;
|
||||
let promise_id = args
|
||||
.get("promiseId")
|
||||
.and_then(Value::as_u64)
|
||||
let promise_id = bufs[0]
|
||||
.get(0..8)
|
||||
.map(|b| u64::from_be_bytes(b.try_into().unwrap()))
|
||||
.ok_or_else(|| type_error("missing or invalid `promiseId`"))?;
|
||||
let args = serde_json::from_slice(&bufs[0][8..])?;
|
||||
let bufs = bufs[1..].into();
|
||||
use crate::futures::FutureExt;
|
||||
let fut = op_fn(state.clone(), args, bufs).map(move |result| {
|
||||
|
@ -205,16 +211,16 @@ where
|
|||
Ok(op) => op,
|
||||
Err(err) => Op::Sync(json_serialize_op_result(
|
||||
None,
|
||||
Err(err),
|
||||
Err::<(), AnyError>(err),
|
||||
state.borrow().get_error_class_fn,
|
||||
)),
|
||||
}
|
||||
})
|
||||
}
|
||||
|
||||
fn json_serialize_op_result(
|
||||
fn json_serialize_op_result<R: Serialize>(
|
||||
promise_id: Option<u64>,
|
||||
result: Result<serde_json::Value, AnyError>,
|
||||
result: Result<R, AnyError>,
|
||||
get_error_class_fn: crate::runtime::GetErrorClassFn,
|
||||
) -> Box<[u8]> {
|
||||
let value = match result {
|
||||
|
|
Loading…
Reference in a new issue