1. Introduction
This section is non-normative.
Large swathes of the web platform are built on streaming data: that is, data that is created, processed, and consumed in an incremental fashion, without ever reading all of it into memory. The Streams Standard provides a common set of APIs for creating and interfacing with such streaming data, embodied in readable streams, writable streams, and transform streams.
This standard provides the base stream primitives which other parts of the web platform can use to expose their streaming data. For example, [FETCH] could expose request bodies as a writable stream, or response bodies as a readable stream. More generally, the platform is full of streaming abstractions waiting to be expressed as streams: multimedia streams, file streams, interprocess communication, and more benefit from being able to process data incrementally instead of buffering it all into memory and processing it in one go. By providing the foundation for these streams to be exposed to developers, the Streams Standard enables use cases like:
- Video effects: piping a readable video stream through a transform stream that applies effects in real time.
- Decompression: piping a file stream through a transform stream that selectively decompresses files from a .tgz archive, turning them into
imgelements as the user scrolls through an image gallery. - Image decoding: piping an HTTP response stream through a transform stream that decodes bytes into bitmap data,
and then through another transform that translates bitmaps into PNGs. If installed inside the
fetchhook of a service worker [SERVICE-WORKERS], this would allow developers to transparently polyfill new image formats.
The APIs described here provide unifying abstraction for all such streams, encouraging an ecosystem to grow around these shared and composable interfaces. At the same time, they have been carefully designed to map efficiently to low-level I/O concerns, and to encapsulate the trickier issues (such as backpressure) that come along for the ride.
2. Model
A chunk#chunkReferenced in:2.1. Readable Streams (2)2.2. Writable Streams2.4. Pipe Chains and Backpressure2.5. Internal Queues and Queuing Strategies (2) (3)2.6. Locking3.1. Using Readable Streams3.2. Class ReadableStream3.2.4.3. getReader(options = {}) (2) (3)3.2.4.6. tee()3.5.2. Internal Slots3.5.4.3. read()3.6.2. Internal Slots3.8.2. Internal Slots (2) (3)3.8.4.2. close()3.8.4.3. enqueue(chunk)3.9.5. Uint8Arrays, instead of single
bytes.
2.1. Readable Streams
A readable stream#readable-streamReferenced in:1. Introduction2.1. Readable Streams2.6. Locking3.2. Class ReadableStream3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})3.2.4.4. pipeThrough({ writable, readable }, options)3.2.4.5. pipeTo(dest, { preventClose, preventAbort, preventCancel } = {})4.1. Using Writable Streams6.1. Class ByteLengthQueuingStrategy6.2. Class CountQueuingStrategy8.1. A readable stream with an underlying push source (no backpressure support)8.2. A readable stream with an underlying push source and backpressure support8.4. A readable stream with an underlying pull source represents a source of data, from which you can read. In other words, data comes out of a readable stream.
Although a readable stream can be created with arbitrary behavior, most readable streams wrap a lower-level I/O source, called the underlying source#underlying-sourceReferenced in:2.1. Readable Streams (2) (3)2.4. Pipe Chains and Backpressure (2)2.5. Internal Queues and Queuing Strategies2.6. Locking3.2. Class ReadableStream3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2) (3)3.2.4.6. tee()3.4. Readable Stream Abstract Operations Used by Controllers3.5.4.3. read()3.8. Class ReadableStreamDefaultController3.8.2. Internal Slots (2) (3) (4) (5)3.8.4.1. get desiredSize3.10.2. Internal Slots3.10.4.2. get desiredSize6.1. Class ByteLengthQueuingStrategy6.2. Class CountQueuingStrategy8.2. A readable stream with an underlying push source and backpressure support. There are two types of underlying source: push sources and pull sources.
Push sources#push-sourceReferenced in:3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})8.1. A readable stream with an underlying push source (no backpressure support) push data at you, whether or not you are listening for it. They may also provide a mechanism for pausing and resuming the flow of data. An example push source is a TCP socket, where data is constantly being pushed from the OS level, at a rate that can be controlled by changing the TCP window size.
Pull sources#pull-sourceReferenced in:3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})8.4. A readable stream with an underlying pull source require you to request data from them. The data may be available synchronously, e.g. if it is held by the operating system’s in-memory buffers, or asynchronously, e.g. if it has to be read from disk. An example pull source is a file handle, where you seek to specific locations and read specific amounts.
Readable streams are designed to wrap both types of sources behind a single, unified interface.
Chunks are enqueued into the stream by the stream’s underlying source. They can then be read one at a time via the stream’s public interface.
Code that reads from a readable stream using its public interface is known as a consumer#consumerReferenced in:2.6. Locking3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2)3.5.2. Internal Slots3.6.2. Internal Slots3.8.4.2. close()3.10.4.3. close().
Consumers also have the ability to cancel#cancel-a-readable-streamReferenced in:2.6. Locking (2)3.2.4.2. cancel(reason)3.2.4.3. getReader(options = {})3.2.4.6. tee() a readable stream. This indicates that the consumer has lost interest in the stream, and will immediately close the stream, throw away any queued chunks, and execute any cancellation mechanism of the underlying source.
Consumers can also tee#tee-a-readable-streamReferenced in:2.4. Pipe Chains and Backpressure3.1. Using Readable Streams3.2.4.6. tee()3.3.6.
For streams representing bytes, an extended version of the readable stream is provided to handle bytes efficiently, in particular by minimizing copies. The underlying source for such a readable stream is called a underlying byte source#underlying-byte-sourceReferenced in:3.4. Readable Stream Abstract Operations Used by Controllers3.6.4.3. read(view)3.10. Class ReadableByteStreamController3.10.2. Internal Slots (2) (3) (4) (5)8.5. A readable byte stream with an underlying pull source. A readable stream whose underlying source is an underlying byte source is sometimes called a readable byte stream#readable-byte-streamReferenced in:2.6. Locking3.1. Using Readable Streams3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2)3.2.4.3. getReader(options = {})3.4. Readable Stream Abstract Operations Used by Controllers3.8. Class ReadableStreamDefaultController8.3. A readable byte stream with an underlying push source and backpressure support8.5. A readable byte stream with an underlying pull source.
2.2. Writable Streams
A writable stream#writable-streamReferenced in:1. Introduction3.1. Using Readable Streams (2)3.2.4.5. pipeTo(dest, { preventClose, preventAbort, preventCancel } = {})6.1. Class ByteLengthQueuingStrategy6.2. Class CountQueuingStrategy8.6. A writable stream with no backpressure or success signals8.7. A writable stream with backpressure and success signals represents a destination for data, into which you can write. In other words, data goes in to a writable stream.
Analogously to readable streams, most writable streams wrap a lower-level I/O sink, called the underlying sink#underlying-sinkReferenced in:2.2. Writable Streams (2)2.4. Pipe Chains and Backpressure2.5. Internal Queues and Queuing Strategies4.1. Using Writable Streams (2) (3)4.2.2. Internal Slots (2) (3) (4)4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {}) (2) (3) (4) (5)4.2.4.3. get state (2) (3)4.2.4.4. abort(reason)4.2.4.5. close()4.2.4.6. write(chunk)6.1. Class ByteLengthQueuingStrategy6.2. Class CountQueuingStrategy8.7. A writable stream with backpressure and success signals. Writable streams work to abstract away some of the complexity of the underlying sink, by queuing subsequent writes and only delivering them to the underlying sink one by one.
Chunks are written to the stream via its public interface, and are passed one at a time to the stream’s underlying sink.
Code that writes into a writable stream using its public interface is known as a producer#producerReferenced in:4.2.2. Internal Slots4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {})6.1. Class ByteLengthQueuingStrategy6.2. Class CountQueuingStrategy8.6. A writable stream with no backpressure or success signals8.7. A writable stream with backpressure and success signals.
Producers also have the ability to abort a writable stream. This indicates that the producer believes something has gone wrong, and that future writes should be discontinued. It puts the stream in an errored state, even without a signal from the underlying sink.
2.3. Transform Streams
A transform stream#transform-streamReferenced in:1. Introduction3.2.4.4. pipeThrough({ writable, readable }, options) consists of a pair of streams: a writable stream, and a readable stream. In a manner specific to the transform stream in question, writes to the writable side result in new data being made available for reading from the readable side.
Some examples of transform streams include:
- A GZIP compressor, to which uncompressed bytes are written and from which compressed bytes are read;
- A video decoder, to which encoded bytes are written and from which uncompressed video frames are read;
- A text decoder, to which bytes are written and from which strings are read;
- A CSV-to-JSON converter, to which strings representing lines of a CSV file are written and from which corresponding JavaScript objects are read.
2.4. Pipe Chains and Backpressure
Streams are primarily used by piping#pipingReferenced in:2.6. Locking3.1. Using Readable Streams (2) (3)3.2.4.4. pipeThrough({ writable, readable }, options)3.2.4.5. pipeTo(dest, { preventClose, preventAbort, preventCancel } = {})4.1. Using Writable Streams them to each other. A readable stream can be piped directly to a writable stream, or it can be piped through one or more transform streams first.
A set of streams piped together in this way is referred to as a pipe chain#pipe-chainReferenced in:3.2.4.4. pipeThrough({ writable, readable }, options). In a pipe chain, the original source is the underlying source of the first readable stream in the chain; the ultimate sink is the underlying sink of the final writable stream in the chain.
Once a pipe chain is constructed, it can be used to propagate signals regarding how fast chunks should flow through it. If any step in the chain cannot yet accept chunks, it propagates a signal backwards through the pipe chain, until eventually the original source is told to stop producing chunks so fast. This process of normalizing flow from the original source according to how fast the chain can process chunks is called backpressure#backpressureReferenced in:1. Introduction2.4. Pipe Chains and Backpressure2.5. Internal Queues and Queuing Strategies3.1. Using Readable Streams (2)3.8.2. Internal Slots3.8.4.1. get desiredSize3.10.2. Internal Slots3.10.4.2. get desiredSize4.1. Using Writable Streams4.2.2. Internal Slots4.2.4.3. get state6.1. Class ByteLengthQueuingStrategy (2)6.2. Class CountQueuingStrategy (2)8.2. A readable stream with an underlying push source and backpressure support8.3. A readable byte stream with an underlying push source and backpressure support8.6. A writable stream with no backpressure or success signals8.7. A writable stream with backpressure and success signals.
When teeing a readable stream, the backpressure signals from its two branches will aggregate, such that if neither branch is read from, a backpressure signal will be sent to the underlying source of the original stream.
2.5. Internal Queues and Queuing Strategies
Both readable and writable streams maintain internal queues#internal-queuesReferenced in:2.5. Internal Queues and Queuing Strategies3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})3.4. Readable Stream Abstract Operations Used by Controllers3.8. Class ReadableStreamDefaultController3.10. Class ReadableByteStreamController8.3. A readable byte stream with an underlying push source and backpressure support, which they use for similar purposes. In the case of a readable stream, the internal queue contains chunks that have been enqueued by the underlying source, but not yet read by the consumer. In the case of a writable stream, the internal queue contains chunks which have been written to the stream by the producer, but not yet processed and acknowledged by the underlying sink.
A queuing strategy#queuing-strategyReferenced in:3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})3.8.2. Internal Slots (2) (3)3.10.2. Internal Slots (2) (3)4.2.2. Internal Slots (2)4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {})4.2.4.6. write(chunk)6.1. Class ByteLengthQueuingStrategy (2)6.2. Class CountQueuingStrategy is an object that determines how a stream should signal backpressure based on
the state of its internal queue. The queuing strategy assigns a size to each chunk, and compares the
total size of all chunks in the queue to a specified number, known as the high water mark#high-water-markReferenced in:3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2)4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {}). The resulting
difference, high water mark minus total size, is used to determine the desired size to fill the stream’s queue#desired-size-to-fill-a-streams-internal-queueReferenced in:3.8.4.1. get desiredSize3.9.7.
For readable streams, an underlying source can use this desired size as a backpressure signal, slowing down chunk generation so as to try to keep the desired size above or at zero. For writable streams, a producer can behave similarly, avoiding writes that would cause the desired size to go negative.
2.6. Locking
A readable stream reader#readable-stream-readerReferenced in:3.1. Using Readable Streams3.3.6.
A given readable stream only has at most one reader at a time. We say in this case the stream is locked to the reader#locked-to-a-readerReferenced in:2.1. Readable Streams3.2.2. Internal Slots3.2.4.1. get locked3.2.4.3. getReader(options = {})3.2.4.4. pipeThrough({ writable, readable }, options)3.2.4.5. pipeTo(dest, { preventClose, preventAbort, preventCancel } = {})3.2.4.6. tee()3.3.5.
A reader also has the capability to release its read lock#release-a-read-lockReferenced in:3.2.4.3. getReader(options = {})3.5.4.1. get closed3.5.4.4. releaseLock()3.6.4.1. get closed3.6.4.2. cancel(reason)3.6.4.4. releaseLock(), which makes it no longer active. At this point another reader can be acquired at will. If the stream becomes closed or errored as a result of the behavior of its underlying source or via cancellation, its reader (if one exists) will automatically release its lock.
A readable byte stream has the ability to vend two types of readers: default readers#default-readersReferenced in:3.1. Using Readable Streams3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})3.2.4.3. getReader(options = {})3.3.2.
3. Readable Streams
3.1. Using Readable Streams
readableStream.pipeTo(writableStream)
.then(() => console.log("All data successfully written!"))
.catch(e => console.error("Something went wrong!", e));
readableStream.pipeTo(new WritableStream({
write(chunk) {
console.log("Chunk received", chunk);
},
close() {
console.log("All data successfully read!");
},
abort(e) {
console.error("Something went wrong!", e);
}
}));
By returning promises from your write implementation, you can signal backpressure to the readable
stream.
read() method to get successive
chunks. For example, this code logs the next chunk in the stream, if available:
const reader = readableStream.getReader();
reader.read().then(
({ value, done }) => {
if (done) {
console.log("The stream was already closed!");
} else {
console.log(value);
}
},
e => console.error("The stream became errored and cannot be read from!", e)
);
This more manual method of reading a stream is mainly useful for library authors building new high-level operations on streams, beyond the provided ones of piping and teeing.
const reader = readableStream.getReader({ mode: "byob" });
let startingAB = new ArrayBuffer(1024);
readInto(startingAB)
.then(buffer => console.log("The first 1024 bytes:", buffer))
.catch(e => console.error("Something went wrong!", e));
function readInto(buffer, offset = 0) {
if (offset === buffer.byteLength) {
return Promise.resolve(buffer);
}
const view = new Uint8Array(buffer, offset, buffer.byteLength - offset);
return reader.read(view).then(newView => {
return readInto(newView.buffer, offset + newView.byteLength);
});
}
An important thing to note here is that the final buffer value is different from the startingAB, but it (and all intermediate buffers) shares the same backing memory allocation. At each
step, the buffer is transferred to a new ArrayBuffer object. The newView is a new Uint8Array, with that ArrayBuffer object as its buffer property, the
offset that bytes were written to as its byteOffset property, and the number of bytes that were written
as its byteLength property.
3.2. Class ReadableStream#rs-classReferenced in:3.2. Class ReadableStream3.2.1. Class Definition3.2.2. Internal Slots3.2.4. Properties of the ReadableStream Prototype3.2.4.4. pipeThrough({ writable, readable }, options) (2)3.2.4.6. tee()3.3.6. ReadableStreamTee ( stream, shouldClone ) (2)3.4. Readable Stream Abstract Operations Used by Controllers (2) (3)3.5. Class ReadableStreamDefaultReader3.5.2. Internal Slots3.6. Class ReadableStreamBYOBReader3.6.2. Internal Slots3.8. Class ReadableStreamDefaultController (2)3.8.2. Internal Slots3.8.3. new ReadableStreamDefaultController(stream, underlyingSource, size, highWaterMark)3.10. Class ReadableByteStreamController (2)3.10.2. Internal Slots3.10.3. new ReadableByteStreamController(stream, underlyingByteSource, highWaterMark)7. Global Properties (2) (3)8. Examples of Creating Streams8.3. A readable byte stream with an underlying push source and backpressure support8.5. A readable byte stream with an underlying pull source
The ReadableStream class is a concrete instance of the general readable stream concept. It is
adaptable to any chunk type, and maintains an internal queue to keep track of data supplied by the underlying
source but not yet read by any consumer.
3.2.1. Class Definition
This section is non-normative.
If one were to write the ReadableStream class in something close to the syntax of [ECMASCRIPT], it would look
like
class ReadableStream {
constructor(underlyingSource = {}, { size, highWaterMark = 1 } = {})
get locked()
cancel(reason)
getReader()
pipeThrough({ writable, readable }, options)
pipeTo(dest, { preventClose, preventAbort, preventCancel } = {})
tee()
}
3.2.2. Internal Slots
Instances of ReadableStream are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[readableStreamController]] | A ReadableStreamDefaultController or ReadableByteStreamController created with the ability to control
the state and queue of this stream; also used for the |
| [[disturbed]] | A boolean flag set to |
| [[reader]] | A ReadableStreamDefaultReader or ReadableStreamBYOBReader instance, if the stream is locked to a
reader, or |
| [[state]] | A string containing the stream’s current state, used internally; one of "readable", "closed", or "errored".
|
| [[storedError]] | A value indicating how the stream failed, to be given as a failure reason or exception when trying to operate on an errored stream |
3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})
underlyingSource object passed to the constructor can implement any of the following methods to
govern how the constructed stream instance behaves:
-
start(controller)is called immediately, and is typically used to adapt a push source by setting up relevant event listeners, or to acquire access to a pull source. If this process is asynchronous, it can return a promise to signal success or failure. -
pull(controller)is called when the stream’s internal queue of chunks is not full, and will be called repeatedly until the queue reaches its high water mark. Ifpullreturns a promise, thenpullwill not be called again until that promise fulfills; if the promise rejects, the stream will become errored. -
cancel(reason)is called when the consumer signals that they are no longer interested in the stream. It should perform any actions necessary to release access to the underlying source. If this process is asynchronous, it can return a promise to signal success or failure.
Both start and pull are given the ability to manipulate the stream’s internal queue and
state via the passed controller object. This is an example of the revealing constructor pattern.
If the underlyingSource object contains a property type set to "bytes", this readable stream is a readable byte stream, and can successfully vend BYOB readers. In that case,
the passed controller object will be an instance of ReadableByteStreamController. Otherwise, it will
be an instance of ReadableStreamDefaultController.
For readable byte streams, underlyingSource can also contain a property autoAllocateChunkSize, which can be set to a positive integer to enable the auto-allocation feature for
this stream. In that case, when a consumer uses a default reader, the stream implementation will
automatically allocate an ArrayBuffer of the given size, and call the underlying source code
as if the consumer was using a BYOB reader. This can cut down on the amount of code needed when writing
the underlying source implementation, as can be seen by comparing §8.3 A readable byte stream with an underlying push source and backpressure support without auto-allocation
to §8.5 A readable byte stream with an underlying pull source with auto-allocation.
The constructor also accepts a second argument containing the queuing strategy object with
two properties: a non-negative number highWaterMark, and a function size(chunk). The
supplied strategy could be an instance of the built-in CountQueuingStrategy or ByteLengthQueuingStrategy classes, or it could be custom. If no strategy is supplied, the default
behavior will be the same as a CountQueuingStrategy with a high water mark of 1.
- Set
this @[[state]] to"readable". - Set
this @[[reader]] andthis @[[storedError]] toundefined . - Set
this @[[disturbed]] tofalse . - Set
this @[[readableStreamController]] toundefined . - Let type be
GetV (underlyingSource,"type"). ReturnIfAbrupt (type).- Let typeString be
ToString (type). - If typeString is
"bytes",- If highWaterMark is
undefined , let highWaterMark be 0. - Set
this @[[readableStreamController]] toConstruct (ReadableByteStreamController, «this , underlyingSource, highWaterMark»).
- If highWaterMark is
- Otherwise, if type is
undefined ,- If highWaterMark is
undefined , let highWaterMark be 1. - Set
this @[[readableStreamController]] toConstruct (ReadableStreamDefaultController, «this , underlyingSource, size, highWaterMark»).
- If highWaterMark is
- Otherwise, throw a
RangeError exception.
3.2.4. Properties of the ReadableStream Prototype
3.2.4.1. get locked
locked getter returns whether or not the readable stream is locked to a reader. - If
IsReadableStream (this ) isfalse , throw aTypeError exception. - Return
IsReadableStreamLocked (this ).
3.2.4.2. cancel(reason)#rs-cancelReferenced in:3.4.4. ReadableStreamClose ( stream )3.9.5. ReadableStreamDefaultControllerEnqueue ( controller, chunk )
cancel method cancels the stream, signaling a loss of interest
in the stream by a consumer. The supplied reason argument will be given to the underlying source, which
may or may not use it. - If
IsReadableStream (this ) isfalse , return a promise rejected with aTypeError exception. - If
IsReadableStreamLocked (this ) istrue , return a promise rejected with aTypeError exception. - Return
ReadableStreamCancel (this , reason).
3.2.4.3. getReader(options = {})#rs-get-readerReferenced in:3.5.3. new ReadableStreamDefaultReader(stream)3.6.3. new ReadableStreamBYOBReader(stream)7. Global Properties
getReader method creates a reader of the type specified by the options argument and locks the stream to the new reader. While the stream is locked, no other reader can be
acquired until this one is released.
This functionality is especially useful for creating abstractions that desire the ability to consume a stream in its entirety. By getting a reader for the stream, you can ensure nobody else can interleave reads with yours or cancel the stream, which would interfere with your abstraction.
When options.mode is ReadableStreamDefaultReader). The reader provides the ability to directly read individual chunks from the stream via the reader’s read() method.
When options.mode is "byob", the getReader method creates a BYOB reader (an instance of ReadableStreamBYOBReader). This feature only works on readable byte streams, i.e. streams
which were constructed specifically with the ability to handle "bring your own buffer" reading. The reader provides
the ability to directly read individual chunks from the stream via the reader’s read() method, into developer-supplied buffers, allowing more precise control over
allocation.
- If
IsReadableStream (this ) isfalse , throw aTypeError exception. - Let mode be
GetV (options,"mode"). - If mode is
"byob",- If
IsReadableByteStreamController (this @[[readableStreamController]]) isfalse , throw aTypeError exception. - Return
AcquireReadableStreamBYOBReader (this ).
- If
- If mode is
undefined , returnAcquireReadableStreamDefaultReader (this ). - Throw a
RangeError exception.
function readAllChunks(readableStream) {
const reader = readableStream.getReader();
const chunks = [];
return pump();
function pump() {
return reader.read().then(({ value, done })=> {
if (done) {
return chunks;
}
chunks.push(value);
return pump();
});
}
}
Note how the first thing it does is obtain a reader, and from then on it uses the reader exclusively. This ensures that no other consumer can interfere with the stream, either by reading chunks or by canceling the stream.
3.2.4.4. pipeThrough({ writable, readable }, options)#rs-pipe-throughReferenced in:3.2.4.4. pipeThrough({ writable, readable }, options)
pipeThrough method provides a convenient, chainable way of piping this readable stream through a transform stream (or any other { writable, readable } pair). It simply pipes the stream
into the writable side of the supplied pair, and returns the readable side for further use.
Piping a stream will generally lock it for the duration of the pipe, preventing any other consumer from acquiring a reader.
This method is intentionally generic; it does not require that its ReadableStream object. It also does not require that its writable argument be a WritableStream instance, or that its readable argument be a ReadableStream instance.
- Call-with-rethrow
Invoke (this ,"pipeTo", «writable, options»). - Return readable.
pipeThrough(transform, options) would look like
httpResponseBody
.pipeThrough(decompressorTransform)
.pipeThrough(ignoreNonImageFilesTransform)
.pipeTo(mediaGallery);
3.2.4.5. pipeTo(dest, { preventClose, preventAbort, preventCancel } = {})
pipeTo method pipes this readable stream to a given writable
stream. The way in which the piping process behaves under various error conditions can be customized with a
number of passed options. It returns a promise that fulfills when the piping process completes successfully, or
rejects if any errors were encountered.
Piping a stream will lock it for the duration of the pipe, preventing any other consumer from acquiring a reader.
The pipeTo method is still in some flux. Its design depends on the design of writable streams, which are still undergoing spec churn.
For now, the reference implementation and tests provide a guide to what this method is generally intended to do: reference-implementation/lib/readable-stream.js,
look for the pipeTo method. In addition to changing as the writable stream design changes, one major
aspect of pipeTo not captured by the reference implementation is that it will operate via unobservable
abstract operation calls, instead of using the JavaScript-exposed readable and writable stream APIs. This will better
allow optimization and specialization. See #407 and #97 for more information.
3.2.4.6. tee()
tee method tees this readable stream, returning a two-element
array containing the two resulting branches as new ReadableStream instances.
Teeing a stream will lock it, preventing any other consumer from acquiring a reader. To cancel the stream, cancel both of the resulting branches; a composite cancellation reason will then be propagated to the stream’s underlying source.
Note that the chunks seen in each branch will be the same object. If the chunks are not immutable, this could
allow interference between the two branches. (Let us know if you think we should add an option to tee that creates structured clones of the chunks for each
branch.)
- If
IsReadableStream (this ) isfalse , throw aTypeError exception. - Let branches be
ReadableStreamTee (this ,false ). ReturnIfAbrupt (branches).- Return
CreateArrayFromList (branches).
cacheEntry representing an
on-disk file, and another writable stream httpRequestBody representing an upload to a remote server,
you could pipe the same readable stream to both destinations at once:
const [forLocal, forRemote] = readableStream.tee();
Promise.all([
forLocal.pipeTo(cacheEntry),
forRemote.pipeTo(httpRequestBody)
])
.then(() => console.log("Saved the stream to the cache and also uploaded it!"))
.catch(e => console.error("Either caching or uploading failed: ", e));
3.3. General Readable Stream Abstract Operations
The following abstract operations, unlike most in this specification, are meant to be generally useful by other specifications, instead of just being part of the implementation of this spec’s classes.
3.3.1. AcquireReadableStreamBYOBReader ( stream ) throws
This abstract operation is meant to be called from other specifications that may wish to acquire a BYOB reader for a given stream.
- Return
Construct (ReadableStreamBYOBReader, «stream»).
3.3.2. AcquireReadableStreamDefaultReader ( stream ) throws
This abstract operation is meant to be called from other specifications that may wish to acquire a default reader for a given stream.
- Return
Construct (ReadableStreamDefaultReader, «stream»).
3.3.3. IsReadableStream ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have a [[readableStreamController]] internal slot, return
false . - Return
true .
3.3.4. IsReadableStreamDisturbed ( stream ) nothrow
This abstract operation is meant to be called from other specifications that may wish to query whether or not a readable stream has ever been read from or canceled.
- Assert:
IsReadableStream (stream) istrue . - Return stream@[[disturbed]].
3.3.5. IsReadableStreamLocked ( stream ) nothrow
This abstract operation is meant to be called from other specifications that may wish to query whether or not a readable stream is locked to a reader.
- Assert:
IsReadableStream (stream) istrue . - If stream@[[reader]] is
undefined , returnfalse . - Return
true .
3.3.6. ReadableStreamTee ( stream, shouldClone ) throws
This abstract operation is meant to be called from other specifications that may wish to tee a given readable stream. Its second argument governs whether or not the data from the original stream will be structured cloned before becoming visible in the returned branches. [HTML]
- Assert:
IsReadableStream (stream) istrue . - Assert:
Type (shouldClone) is Boolean. - Let reader be
AcquireReadableStreamDefaultReader (stream). ReturnIfAbrupt (reader).- Let teeState be Record{[[closedOrErrored]]:
false , [[canceled1]]:false , [[canceled2]]:false , [[reason1]]:undefined , [[reason2]]:undefined , [[promise]]: a new promise}. - Let pull be a new
ReadableStreamTee pull function. - Set pull@[[reader]] to reader, pull@[[teeState]] to teeState, and pull@[[shouldClone]] to shouldClone.
- Let cancel1 be a new
ReadableStreamTee branch 1 cancel function. - Set cancel1@[[stream]] to stream and cancel1@[[teeState]] to teeState.
- Let cancel2 be a new
ReadableStreamTee branch 2 cancel function. - Set cancel2@[[stream]] to stream and cancel2@[[teeState]] to teeState.
- Let underlyingSource1 be
ObjectCreate (%ObjectPrototype%). - Perform
CreateDataProperty (underlyingSource1,"pull", pull). - Perform
CreateDataProperty (underlyingSource1,"cancel", cancel1). - Let branch1Stream be
Construct (ReadableStream, underlyingSource1). - Let underlyingSource2 be
ObjectCreate (%ObjectPrototype%). - Perform
CreateDataProperty (underlyingSource2,"pull", pull). - Perform
CreateDataProperty (underlyingSource2,"cancel", cancel2). - Let branch2Stream be
Construct (ReadableStream, underlyingSource2). - Set pull@[[branch1]] to branch1Stream@[[readableStreamController]].
- Set pull@[[branch2]] to branch2Stream@[[readableStreamController]].
- Upon rejection of reader@[[closedPromise]] with reason r,
- If teeState.[[closedOrErrored]] is
true , returnundefined . - Perform
ReadableStreamDefaultControllerError (pull@[[branch1]], r). - Perform
ReadableStreamDefaultControllerError (pull@[[branch2]], r). - Set teeState.[[closedOrErrored]] to
true .
- If teeState.[[closedOrErrored]] is
- Return «branch1, branch2».
const r = /?:/; r.expando = "!"; is
distinguishable from the original since the clone will not have the expando property.
However, in specific cases implementations may be able to do something more optimal, without observable consequences. For example if each chunk is created by the implementation, and cannot otherwise be modified by the developer, it may be possible to ensure the original and its clone are not distinguishable, in which case only one clone operation would be necessary. But, be careful!
A
- Let reader be F@[[reader]], branch1 be F@[[branch1]], branch2 be F@[[branch2]], teeState be F@[[teeState]], and shouldClone be F@[[shouldClone]].
- Return the result of transforming
ReadableStreamDefaultReaderRead (reader) by a fulfillment handler which takes the argument result and performs the following steps:- Assert:
Type (result) is Object. - Let value be
Get (result,"value"). ReturnIfAbrupt (value).- Let done be
Get (result,"done"). ReturnIfAbrupt (done).- Assert:
Type (done) is Boolean. - If done is
true and teeState.[[closedOrErrored]] isfalse ,- If teeState.[[canceled1]] is
false ,- Perform
ReadableStreamDefaultControllerClose (branch1).
- Perform
- If teeState.[[canceled2]] is
false ,- Perform
ReadableStreamDefaultControllerClose (branch2).
- Perform
- Set teeState.[[closedOrErrored]] to
true .
- If teeState.[[canceled1]] is
- If teeState.[[closedOrErrored]] is
true , returnundefined . - If teeState.[[canceled1]] is
false ,- Let value1 be value.
- If shouldClone is
true , set value1 to StructuredClone(value). - Call-with-rethrow
ReadableStreamDefaultControllerEnqueue (branch1, value1).
- If teeState.[[canceled2]] is
false ,- Let value2 be value.
- If shouldClone is
true , set value2 to StructuredClone(value). - Call-with-rethrow
ReadableStreamDefaultControllerEnqueue (branch2, value2).
- Assert:
A
- Let stream be F@[[stream]] and teeState be F@[[teeState]].
- Set teeState.[[canceled1]] to
true . - Set teeState.[[reason1]] to reason.
- If teeState.[[canceled2]] is
true ,- Let compositeReason be
CreateArrayFromList («teeState.[[reason1]], teeState.[[reason2]]»). - Let cancelResult be
ReadableStreamCancel (stream, compositeReason). ReturnIfAbrupt (cancelResult).- Resolve teeState.[[promise]] with cancelResult.
- Let compositeReason be
- Return teeState.[[promise]].
A
- Let stream be F@[[stream]] and teeState be F@[[teeState]].
- Set teeState.[[canceled2]] to
true . - Set teeState.[[reason2]] to reason.
- If teeState.[[canceled1]] is
true ,- Let compositeReason be
CreateArrayFromList («teeState.[[reason1]], teeState.[[reason2]]»). - Let cancelResult be
ReadableStreamCancel (stream, compositeReason). ReturnIfAbrupt (cancelResult).- Resolve teeState.[[promise]] with cancelResult.
- Let compositeReason be
- Return teeState.[[promise]].
3.4. Readable Stream Abstract Operations Used by Controllers
In terms of specification factoring, the way that the ReadableStream class encapsulates the behavior of
both simple readable streams and readable byte streams into a single class is by centralizing most of the
potentially-varying logic inside the two controller classes, ReadableStreamDefaultController and ReadableByteStreamController. Those classes define most of the stateful internal slots and abstract
operations for how a stream’s internal queue is managed and how it interfaces with its underlying source or underlying byte source.
The abstract operations in this section are interfaces that are used by the controller implementations to affect their
associated ReadableStream object, translating those internal state changes into developer-facing results
visible through the ReadableStream's public API.
3.4.1. ReadableStreamAddReadIntoRequest ( stream ) nothrow
- Assert:
IsReadableStreamBYOBReader (stream@[[reader]]) istrue . - Let promise be a new promise.
- Let readIntoRequest be Record{[[promise]]: promise}.
- Append readIntoRequest as the last element of stream@[[reader]]@[[readIntoRequests]].
- Return promise.
3.4.2. ReadableStreamAddReadRequest ( stream ) nothrow
- Assert:
IsReadableStreamDefaultReader (stream@[[reader]]) istrue . - Let promise be a new promise.
- Let readRequest be Record{[[promise]]: promise}.
- Append readRequest as the last element of stream@[[reader]]@[[readRequests]].
- Return promise.
3.4.3. ReadableStreamCancel ( stream, reason ) nothrow
- Assert: stream is not
undefined . - Set stream@[[disturbed]] to
true . - If stream@[[state]] is
"closed", return a new promise resolved withundefined . - If stream@[[state]] is
"errored", return a new promise rejected with stream@[[storedError]]. - Perform
ReadableStreamClose (stream). - Let sourceCancelPromise be stream@[[readableStreamController]].[[Cancel]](reason).
- Return the result of transforming sourceCancelPromise by a fulfillment handler that returns
undefined .
3.4.4. ReadableStreamClose ( stream ) nothrow
This abstract operation can be called by other specifications that wish to close a readable stream, in the same way a developer-created stream would be closed by its associated controller object. Specifications should not do this to streams they did not create, and must ensure they have obeyed the preconditions (listed here as asserts).
- Assert: stream@[[state]] is
"readable". - Set stream@[[state]] to
"closed". - Let reader be stream@[[reader]].
- If reader is
undefined , returnundefined . - If
IsReadableStreamDefaultReader (reader) istrue ,- Repeat for each readRequest that is an element of reader@[[readRequests]],
- Resolve readRequest.[[promise]] with
CreateIterResultObject (undefined ,true ).
- Resolve readRequest.[[promise]] with
- Set reader@[[readRequests]] to an empty
List .
- Repeat for each readRequest that is an element of reader@[[readRequests]],
- Resolve reader@[[closedPromise]] with
undefined . - Return
undefined .
"closed", but stream@[[closeRequested]] is cancel(reason). In this case we allow the
controller’s close method to be called and silently do nothing, since the cancelation was outside the
control of the underlying source. 3.4.5. ReadableStreamError ( stream, e ) nothrow
This abstract operation can be called by other specifications that wish to move a readable stream to an errored state, in the same way a developer would error a stream using its associated controller object. Specifications should not do this to streams they did not create, and must ensure they have obeyed the precondition (listed here as an assert).
- Assert:
IsReadableStream (stream) istrue . - Assert: stream@[[state]] is
"readable". - Set stream@[[state]] to
"errored". - Set stream@[[storedError]] to e.
- Let reader be stream@[[reader]].
- If reader is
undefined , returnundefined . - If
IsReadableStreamDefaultReader (reader) istrue ,- Repeat for each readRequest that is an element of reader@[[readRequests]],
- Reject readRequest.[[promise]] with e.
- Set reader@[[readRequests]] to a new empty
List .
- Repeat for each readRequest that is an element of reader@[[readRequests]],
- Otherwise,
- Assert:
IsReadableStreamBYOBReader (reader). - Repeat for each readIntoRequest that is an element of reader@[[readIntoRequests]],
- Reject readIntoRequest.[[promise]] with e.
- Set reader@[[readIntoRequests]] to a new empty
List .
- Assert:
- Reject reader@[[closedPromise]] with e.
3.4.6. ReadableStreamFulfillReadIntoRequest ( stream, chunk, done ) nothrow
- Let reader be stream@[[reader]].
- Let readIntoRequest be the first element of reader@[[readIntoRequests]].
- Remove readIntoRequest from reader@[[readIntoRequests]], shifting all other elements downward (so that the second becomes the first, and so on).
- Resolve readIntoRequest.[[promise]] with
CreateIterResultObject (chunk, done).
3.4.7. ReadableStreamFulfillReadRequest ( stream, chunk, done ) nothrow
- Let reader be stream@[[reader]].
- Let readRequest be the first element of reader@[[readRequests]].
- Remove readRequest from reader@[[readRequests]], shifting all other elements downward (so that the second becomes the first, and so on).
- Resolve readRequest.[[promise]] with
CreateIterResultObject (chunk, done).
3.4.8. ReadableStreamGetNumReadIntoRequests ( stream ) nothrow
- Return the number of elements in stream@[[reader]]@[[readIntoRequests]].
3.4.9. ReadableStreamGetNumReadRequests ( stream ) nothrow
- Return the number of elements in stream@[[reader]]@[[readRequests]].
3.4.10. ReadableStreamHasBYOBReader ( stream ) nothrow
- Let reader be stream@[[reader]].
- If reader is
undefined , returnfalse . - If
IsReadableStreamBYOBReader (reader) isfalse , returnfalse . - Return
true .
3.4.11. ReadableStreamHasReader ( stream ) nothrow
- Let reader be stream@[[reader]].
- If reader is
undefined , returnfalse . - If
IsReadableStreamDefaultReader (reader) isfalse , returnfalse . - Return
true .
3.5. Class ReadableStreamDefaultReader#default-reader-classReferenced in:3.2.2. Internal Slots3.2.4.3. getReader(options = {})3.3.2. AcquireReadableStreamDefaultReader ( stream )3.5. Class ReadableStreamDefaultReader3.5.1. Class Definition3.5.2. Internal Slots3.5.4. Properties of the ReadableStreamDefaultReader Prototype7. Global Properties
The ReadableStreamDefaultReader class represents a default reader designed to be vended by a ReadableStream instance.
3.5.1. Class Definition
This section is non-normative.
If one were to write the ReadableStreamDefaultReader class in something close to the syntax of [ECMASCRIPT], it
would look like
class ReadableStreamDefaultReader {
constructor(stream)
get closed()
cancel(reason)
read()
releaseLock()
}
3.5.2. Internal Slots
Instances of ReadableStreamDefaultReader are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[closedPromise]] | A promise returned by the reader’s closed getter
|
| [[ownerReadableStream]] | A ReadableStream instance that owns this reader
|
| [[readRequests]] | A read() method that have
not yet been resolved, due to the consumer requesting chunks sooner than they are available; also
used for the |
3.5.3. new ReadableStreamDefaultReader(stream)
ReadableStreamDefaultReader constructor is generally not meant to be used directly; instead, a
stream’s getReader() method should be used. - If
IsReadableStream (stream) isfalse , throw aTypeError exception. - If
IsReadableStreamLocked (stream) istrue , throw aTypeError exception. - Perform
ReadableStreamReaderGenericInitialize (this , stream). - Set
this @[[readRequests]] to a new emptyList .
3.5.4. Properties of the ReadableStreamDefaultReader Prototype
3.5.4.1. get closed#default-reader-closedReferenced in:3.5.2. Internal Slots
closed getter returns a promise that will be fulfilled when the stream becomes closed or the
reader’s lock is released, or rejected if the stream ever errors. - If
IsReadableStreamDefaultReader (this ) isfalse , return a promise rejected with aTypeError exception. - Return
this @[[closedPromise]].
3.5.4.2. cancel(reason)
cancel method behaves the same as that for the
associated stream. - If
IsReadableStreamDefaultReader (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[ownerReadableStream]] isundefined , return a promise rejected with aTypeError exception. - Return
ReadableStreamCancel (this @[[ownerReadableStream]], reason).
3.5.4.3. read()#default-reader-readReferenced in:3.2.4.3. getReader(options = {})3.5.2. Internal Slots3.5.4.4. releaseLock()
read method will return a promise that allows access to the next chunk from the stream’s
internal queue, if available.
- If the chunk does become available, the promise will be fulfilled with an object of the form
{ value: theChunk, done: false }. - If the stream becomes closed, the promise will be fulfilled with an object of the form
{ value: undefined, done: true }. - If the stream becomes errored, the promise will be rejected with the relevant error.
If reading a chunk causes the queue to become empty, more data will be pulled from the underlying source.
- If
IsReadableStreamDefaultReader (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[ownerReadableStream]] isundefined , return a promise rejected with aTypeError exception. - Return
ReadableStreamDefaultReaderRead (this ).
3.5.4.4. releaseLock()
releaseLock method releases the reader’s lock on the corresponding
stream. After the lock is released, the reader is no longer active. If the associated
stream is errored when the lock is released, the reader will appear errored in the same way from now on; otherwise,
the reader will appear closed.
A reader’s lock cannot be released while it still has a pending read request, i.e., if a promise returned by the
reader’s read() method has not yet been settled. Attempting to do so will throw
a
- If
IsReadableStreamDefaultReader (this ) isfalse , throw aTypeError exception. - If
this @[[ownerReadableStream]] isundefined , returnundefined . - If
this @[[readRequests]] is not empty, throw aTypeError exception. - Perform
ReadableStreamReaderGenericRelease (this ).
3.6. Class ReadableStreamBYOBReader#byob-reader-classReferenced in:3.2.2. Internal Slots3.2.4.3. getReader(options = {})3.3.1. AcquireReadableStreamBYOBReader ( stream )3.6. Class ReadableStreamBYOBReader3.6.1. Class Definition3.6.2. Internal Slots3.6.4. Properties of the ReadableStreamBYOBReader Prototype7. Global Properties
The ReadableStreamBYOBReader class represents a BYOB reader designed to be vended by a ReadableStream instance.
3.6.1. Class Definition
This section is non-normative.
If one were to write the ReadableStreamBYOBReader class in something close to the syntax of [ECMASCRIPT], it
would look like
class ReadableStreamBYOBReader {
constructor(stream)
get closed()
cancel(reason)
read(view)
releaseLock()
}
3.6.2. Internal Slots
Instances of ReadableStreamBYOBReader are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[closedPromise]] | A promise returned by the reader’s closed getter
|
| [[ownerReadableStream]] | A ReadableStream instance that owns this reader
|
| [[readIntoRequests]] | A read(view) method that have
not yet been resolved, due to the consumer requesting chunks sooner than they are available; also
used for the |
3.6.3. new ReadableStreamBYOBReader(stream)
ReadableStreamBYOBReader constructor is generally not meant to be used directly; instead, a stream’s getReader() method should be used. - If
IsReadableStream (stream) isfalse , throw aTypeError exception. - If
IsReadableStreamLocked (stream) istrue , throw aTypeError exception. - Perform
ReadableStreamReaderGenericInitialize (this , stream). - Set
this @[[readIntoRequests]] to a new emptyList .
3.6.4. Properties of the ReadableStreamBYOBReader Prototype
3.6.4.1. get closed#byob-reader-closedReferenced in:3.6.2. Internal Slots
closed getter returns a promise that will be fulfilled when the stream becomes closed or the
reader’s lock is released, or rejected if the stream ever errors. - If
IsReadableStreamBYOBReader (this ) isfalse , return a promise rejected with aTypeError exception. - Return
this @[[closedPromise]].
3.6.4.2. cancel(reason)
cancel method behaves the same as that for the
associated stream. When done, it automatically releases the lock. - If
IsReadableStreamBYOBReader (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[ownerReadableStream]] isundefined , return a promise rejected with aTypeError exception. - Return
ReadableStreamCancel (this @[[ownerReadableStream]], reason).
3.6.4.3. read(view)#byob-reader-readReferenced in:3.2.4.3. getReader(options = {})3.6.2. Internal Slots3.6.4.4. releaseLock()
read method will write read bytes into view and return a promise resolved with a
possibly transferred buffer as described below.
- If the chunk does become available, the promise will be fulfilled with an object of the form
{ value: theChunk, done: false }. - If the stream becomes closed, the promise will be fulfilled with an object of the form
{ value: undefined, done: true }. - If the stream becomes errored, the promise will be rejected with the relevant error.
If reading a chunk causes the queue to become empty, more data will be pulled from the underlying byte source.
- If
IsReadableStreamBYOBReader (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[ownerReadableStream]] isundefined , return a promise rejected with aTypeError exception. - If
Type (view) is not Object, return a promise rejected with aTypeError exception. - If view does not have a [[ViewedArrayBuffer]] internal slot, return a promise rejected with a
TypeError exception. - If view@[[ByteLength]] is 0, return a promise rejected with a
TypeError exception. - Return
ReadableStreamBYOBReaderRead (this , view).
3.6.4.4. releaseLock()
releaseLock method releases the reader’s lock on the corresponding
stream. After the lock is released, the reader is no longer active. If the associated
stream is errored when the lock is released, the reader will appear errored in the same way from now on; otherwise,
the reader will appear closed.
A reader’s lock cannot be released while it still has a pending read request, i.e., if a promise returned by the
reader’s read() method has not yet been settled. Attempting to do so will throw
a
- If
IsReadableStreamBYOBReader (this ) isfalse , throw aTypeError exception. - If
this @[[ownerReadableStream]] isundefined , returnundefined . - If
this @[[readIntoRequests]] is not empty, throw aTypeError exception. - Perform
ReadableStreamReaderGenericRelease (this ).
3.7. Readable Stream Reader Abstract Operations
3.7.1. IsReadableStreamDefaultReader ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have a [[readRequests]] internal slot, return
false . - Return
true .
3.7.2. IsReadableStreamBYOBReader ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have a [[readIntoRequests]] internal slot, return
false . - Return
true .
3.7.3. ReadableStreamReaderGenericCancel ( reader, reason ) throws
- Return
ReadableStreamCancel (reader@[[ownerReadableStream]], reason).
3.7.4. ReadableStreamReaderGenericInitialize ( reader, stream ) nothrow
- Set reader@[[ownerReadableStream]] to stream.
- Set stream@[[reader]] to reader.
- If stream@[[state]] is
"readable",- Set reader@[[closedPromise]] to a new promise.
- Otherwise,
- If stream@[[state]] is
"closed",- Set reader@[[closedPromise]] to a new promise resolved with
undefined .
- Set reader@[[closedPromise]] to a new promise resolved with
- Otherwise,
- Assert: stream@[[state]] is
"errored". - Set reader@[[closedPromise]] to a new promise rejected with stream@[[storedError]].
- Assert: stream@[[state]] is
- If stream@[[state]] is
3.7.5. ReadableStreamReaderGenericRelease ( reader ) throws
- Assert: reader@[[ownerReadableStream]] is not
undefined . - Assert: reader@[[ownerReadableStream]]@[[reader]] is not
undefined . - If reader@[[ownerReadableStream]]@[[state]] is
"readable", reject reader@[[closedPromise]] with aTypeError exception. - Otherwise, set reader@[[closedPromise]] to a new promise rejected with a
TypeError exception. - Set reader@[[ownerReadableStream]]@[[reader]] to
undefined . - Set reader@[[ownerReadableStream]] to
undefined .
3.7.6. ReadableStreamBYOBReaderRead ( reader, view ) nothrow
- Let stream be reader@[[ownerReadableStream]].
- Assert: stream is not
undefined . - Set stream@[[disturbed]] to
true . - If stream@[[state]] is
"errored", return a promise rejected with stream@[[storedError]]. - Return
ReadableByteStreamControllerPullInto (stream@[[readableStreamController]], view).
3.7.7. ReadableStreamDefaultReaderRead ( reader ) nothrow
- Let stream be reader@[[ownerReadableStream]].
- Assert: stream is not
undefined . - Set stream@[[disturbed]] to
true . - If stream@[[state]] is
"closed", return a new promise resolved withCreateIterResultObject (undefined ,true ). - If stream@[[state]] is
"errored", return a new promise rejected with stream@[[storedError]]. - Assert: stream@[[state]] is
"readable". - Return stream@[[readableStreamController]].[[Pull]]().
3.8. Class ReadableStreamDefaultController#rs-default-controller-classReferenced in:3.2.2. Internal Slots3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2)3.4. Readable Stream Abstract Operations Used by Controllers3.8. Class ReadableStreamDefaultController (2)3.8.1. Class Definition3.8.2. Internal Slots3.8.4. Properties of the ReadableStreamDefaultController Prototype3.8.5. Readable Stream Default Controller Internal Methods7. Global Properties
The ReadableStreamDefaultController class has methods that allow control of a ReadableStream's state and internal queue. When constructing a ReadableStream that is not a readable byte stream, the underlying source is given a corresponding ReadableStreamDefaultController instance to manipulate.
3.8.1. Class Definition
This section is non-normative.
If one were to write the ReadableStreamDefaultController class in something close to the syntax of [ECMASCRIPT],
it would look like
class ReadableStreamDefaultController {
constructor(stream, underlyingSource, size, highWaterMark)
get desiredSize()
close()
enqueue(chunk)
error(e)
}
3.8.2. Internal Slots
Instances of ReadableStreamDefaultController are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[closeRequested]] | A boolean flag indicating whether the stream has been closed by its underlying source, but still has chunks in its internal queue that have not yet been read |
| [[controlledReadableStream]] | The ReadableStream instance controlled
|
| [[pullAgain]] | A boolean flag set to pull method to pull more data, but the pull could not yet be done since a previous call is
still executing
|
| [[pulling]] | A boolean flag set to pull method is
executing and has not yet fulfilled, used to prevent reentrant calls
|
| [[queue]] | A |
| [[started]] | A boolean flag indicating whether the underlying source has finished starting |
| [[strategyHWM]] | A number supplied to the constructor as part of the stream’s queuing strategy, indicating the point at which the stream will apply backpressure to its underlying source. |
| [[strategySize]] | A function supplied to the constructor as part of the stream’s queuing strategy, designed to calculate
the size of enqueued chunks; can be |
| [[underlyingSource]] | An object representation of the stream’s underlying source, including its queuing strategy; also
used for the |
3.8.3. new ReadableStreamDefaultController(stream, underlyingSource, size, highWaterMark)
ReadableStreamDefaultController constructor cannot be used directly; it only works on a ReadableStream that is in the middle of being constructed. - If
IsReadableStream (stream) isfalse , throw aTypeError exception. - If stream@[[readableStreamController]] is not
undefined , throw aTypeError exception. - Set
this @[[controlledReadableStream]] to stream. - Set
this @[[underlyingSource]] to underlyingSource. - Set
this @[[queue]] to a new emptyList . - Set
this @[[started]],this @[[closeRequested]],this @[[pullAgain]], andthis @[[pulling]] tofalse . - Let normalizedStrategy be
ValidateAndNormalizeQueuingStrategy (size, highWaterMark). - Set
this @[[strategySize]] to normalizedStrategy.[[size]] andthis @[[strategyHWM]] to normalizedStrategy.[[highWaterMark]]. - Let controller be
this . - Let startResult be
InvokeOrNoop (underlyingSource,"start", «this »). ReturnIfAbrupt (startResult).- Resolve startResult as a promise:
- Upon fulfillment,
- Set controller@[[started]] to
true . - Perform
ReadableStreamDefaultControllerCallPullIfNeeded (controller).
- Set controller@[[started]] to
- Upon rejection with reason r,
- If stream@[[state]] is
"readable", performReadableStreamDefaultControllerError (controller, r).
- If stream@[[state]] is
- Upon fulfillment,
3.8.4. Properties of the ReadableStreamDefaultController Prototype
3.8.4.1. get desiredSize#rs-default-controller-desired-sizeReferenced in:3.9.7. ReadableStreamDefaultControllerGetDesiredSize ( controller )
desiredSize getter returns the desired size
to fill the controlled stream’s internal queue. It can be negative, if the queue is over-full. An underlying
source should use this information to determine when and how to apply backpressure. - If
IsReadableStreamDefaultController (this ) isfalse , throw aTypeError exception. - Return
ReadableStreamDefaultControllerGetDesiredSize (this ).
3.8.4.2. close()
close method will close the controlled readable stream. Consumers will still be able to read
any previously-enqueued chunks from the stream, but once those are read, the stream will become closed. - If
IsReadableStreamDefaultController (this ) isfalse , throw aTypeError exception. - If
this @[[closeRequested]] istrue , throw aTypeError exception. - If
this @[[controlledReadableStream]]@[[state]] is not"readable", throw aTypeError exception. - Perform
ReadableStreamDefaultControllerClose (this ).
3.8.4.3. enqueue(chunk)
enqueue method will enqueue a given chunk in the controlled readable stream. - If
IsReadableStreamDefaultController (this ) isfalse , throw aTypeError exception. - If
this @[[closeRequested]] istrue , throw aTypeError exception. - If
this @[[controlledReadableStream]]@[[state]] is not"readable", throw aTypeError exception. - Return
ReadableStreamDefaultControllerEnqueue (this , chunk).
3.8.4.4. error(e)
error method will error the readable stream, making all future interactions with it fail with the
given error e. - If
IsReadableStreamDefaultController (this ) isfalse , throw aTypeError exception. - Let stream be
this @[[controlledReadableStream]]. - If stream@[[state]] is not
"readable", throw aTypeError exception. - Perform
ReadableStreamDefaultControllerError (this , e).
3.8.5. Readable Stream Default Controller Internal Methods
The following are additional internal methods implemented by each ReadableStreamDefaultController instance.
They are similar to the supporting abstract operations in the following section, but are in method form to allow
polymorphic dispatch from the readable stream implementation to either these or their counterparts for BYOB controllers.
3.8.5.1. [[Cancel]](reason)
- Set
this @[[queue]] to a new emptyList . - Return
PromiseInvokeOrNoop (this @[[underlyingSource]],"cancel", «reason»)
3.8.5.2. [[Pull]]()
- Let stream be
this @[[controlledReadableStream]]. - If
this [[queue]] is not empty,- Let chunk be
DequeueValue (this @[[queue]]). - If
this @[[closeRequested]] istrue andthis @[[queue]] is empty, performReadableStreamClose (stream). - Otherwise, perform
ReadableStreamDefaultControllerCallPullIfNeeded (this ). - Return a promise resolved with
CreateIterResultObject (chunk,false ).
- Let chunk be
- Let pendingPromise be
ReadableStreamAddReadRequest (stream). - Perform
ReadableStreamDefaultControllerCallPullIfNeeded (this ). - Return pendingPromise.
3.9. Readable Stream Default Controller Abstract Operations
3.9.1. IsReadableStreamDefaultController ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have an [[underlyingSource]] internal slot, return
false . - Return
true .
3.9.2. ReadableStreamDefaultControllerCallPullIfNeeded ( controller ) nothrow
- Let shouldPull be
ReadableStreamDefaultControllerShouldCallPull (controller). - If shouldPull is
false , returnundefined . - If controller@[[pulling]] is
true ,- Set controller@[[pullAgain]] to
true . - Return
undefined .
- Set controller@[[pullAgain]] to
- Set controller@[[pulling]] to
true . - Let pullPromise be
PromiseInvokeOrNoop (controller@[[underlyingSource]],"pull", «controller»). - Upon fulfillment of pullPromise,
- Set controller@[[pulling]] to
false . - If controller@[[pullAgain]] is
true ,- Set controller@[[pullAgain]] to
false . - Perform
ReadableStreamDefaultControllerCallPullIfNeeded (controller).
- Set controller@[[pullAgain]] to
- Set controller@[[pulling]] to
- Upon rejection of pullPromise with reason e,
- If controller@[[controlledReadableStream]]@[[state]] is
"readable", performReadableStreamDefaultControllerError (controller, e).
- If controller@[[controlledReadableStream]]@[[state]] is
- Return
undefined .
3.9.3. ReadableStreamDefaultControllerShouldCallPull ( controller ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- If stream@[[state]] is
"closed"or stream@[[state]] is"errored", returnfalse . - If controller@[[closeRequested]] is
true , returnfalse . - If controller@[[started]] is
false , returnfalse . - If
IsReadableStreamLocked (stream) istrue andReadableStreamGetNumReadRequests (stream) > 0, returntrue . - Let desiredSize be
ReadableStreamDefaultControllerGetDesiredSize (controller). - If desiredSize > 0, return
true . - Return
false .
3.9.4. ReadableStreamDefaultControllerClose ( controller ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- Assert: controller@[[closeRequested]] is
false . - Assert: stream@[[state]] is
"readable". - Set controller@[[closeRequested]] to
true . - If controller@[[queue]] is empty, perform
ReadableStreamClose (stream).
3.9.5. ReadableStreamDefaultControllerEnqueue ( controller, chunk ) nothrow
This abstract operation can be called by other specifications that wish to enqueue chunks in a readable stream, in the same way a developer would enqueue chunks using the stream’s associated controller object. Specifications should not do this to streams they did not create, and must ensure they have obeyed the preconditions (listed here as asserts).
- Let stream be controller@[[controlledReadableStream]].
- Assert: controller@[[closeRequested]] is
false . - Assert: stream@[[state]] is
"readable". - If
IsReadableStreamLocked (stream) istrue andReadableStreamGetNumReadRequests (stream) > 0, performReadableStreamFulfillReadRequest (stream, chunk,false ). - Otherwise,
- Let chunkSize be
1 . - If controller@[[strategySize]] is not
undefined ,- Set chunkSize to
Call (stream@[[strategySize]],undefined , «chunk»). - If chunkSize is an
abrupt completion ,- If stream@[[state]] is
"readable", performReadableStreamDefaultControllerError (controller, chunkSize.[[value]]). - Return chunkSize.
- If stream@[[state]] is
- Let chunkSize be chunkSize.[[value]].
- Set chunkSize to
- Let enqueueResult be
EnqueueValueWithSize (controller@[[queue]], chunk, chunkSize). - If enqueueResult is an
abrupt completion ,- If stream@[[state]] is
"readable", performReadableStreamDefaultControllerError (controller, enqueueResult.[[value]]). - Return enqueueResult.
- If stream@[[state]] is
- Let chunkSize be
- Perform
ReadableStreamDefaultControllerCallPullIfNeeded (controller). - Return
undefined .
"closed", but stream@[[closeRequested]]
is cancel(reason). In this case we allow the
controller’s enqueue method to be called and silently do nothing, since the cancelation was outside the
control of the underlying source. 3.9.6. ReadableStreamDefaultControllerError ( controller, e ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- Assert: stream@[[state]] is
"readable". - Set controller@[[queue]] to a new empty
List . - Perform
ReadableStreamError (stream, e).
3.9.7. ReadableStreamDefaultControllerGetDesiredSize ( controller ) nothrow
This abstract operation can be called by other specifications that wish to determine the desired size to fill this stream’s internal queue, similar
to how a developer would consult the desiredSize property of the stream’s
associated controller object. Specifications should not use this on streams they did not create.
- Let queueSize be
GetTotalQueueSize (controller@[[queue]]). - Return controller@[[strategyHWM]] − queueSize.
3.10. Class ReadableByteStreamController#rbs-controller-classReferenced in:3.2.2. Internal Slots3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2)3.4. Readable Stream Abstract Operations Used by Controllers3.10. Class ReadableByteStreamController (2)3.10.1. Class Definition3.10.2. Internal Slots3.10.4. Properties of the ReadableByteStreamController Prototype3.10.5. Readable Stream BYOB Controller Internal Methods3.11. Class ReadableStreamBYOBRequest3.11.2. Internal Slots7. Global Properties
The ReadableByteStreamController class has methods that allow control of a ReadableStream's state and internal queue. When constructing a ReadableStream, the underlying byte source is given a
corresponding ReadableByteStreamController instance to manipulate.
3.10.1. Class Definition
This section is non-normative.
If one were to write the ReadableByteStreamController class in something close to the syntax of [ECMASCRIPT], it
would look like
class ReadableByteStreamController {
constructor(stream, underlyingByteSource, highWaterMark)
get byobRequest()
get desiredSize()
close()
enqueue(chunk)
error(e)
}
3.10.2. Internal Slots
Instances of ReadableByteStreamController are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[autoAllocateChunkSize]] | A non negative integer when the automatic buffer allocation feature is enabled. In that case, this value
specifies the size of buffer to allocate. It is |
| [[closeRequested]] | A boolean flag indicating whether the stream has been closed by its underlying byte source, but still has chunks in its internal queue that have not yet been read |
| [[controlledReadableStream]] | The ReadableStream instance controlled
|
| [[pullAgain]] | A boolean flag set to pull method to pull more data, but the pull could not yet be done
since a previous call is still executing
|
| [[pulling]] | A boolean flag set to pull method is executing and has not yet fulfilled, used to prevent reentrant calls
|
| [[byobRequest]] | A ReadableStreamBYOBRequest instance representing the current BYOB pull request.
|
| [[pendingPullIntos]] | A |
| [[queue]] | A |
| [[started]] | A boolean flag indicating whether the underlying source has finished starting |
| [[strategyHWM]] | A number supplied to the constructor as part of the stream’s queuing strategy, indicating the point at which the stream will apply backpressure to its underlying byte source. |
| [[strategySize]] | A function supplied to the constructor as part of the stream’s queuing strategy, designed to calculate
the size of enqueued chunks; can be |
| [[totalQueuedBytes]] | The number of bytes stored in [[queue]] |
| [[underlyingByteSource]] | An object representation of the stream’s underlying byte source, including its queuing strategy;
also used for the |
3.10.3. new ReadableByteStreamController(stream, underlyingByteSource, highWaterMark)
ReadableByteStreamController constructor cannot be used directly; it only works on a ReadableStream that is in the middle of being constructed. - If
IsReadableStream (stream) isfalse , throw aTypeError exception. - If stream@[[readableStreamController]] is not
undefined , throw aTypeError exception. - Set
this @[[controlledReadableStream]] to stream. - Set
this @[[underlyingByteSource]] to underlyingByteSource. - Set
this @[[pullAgain]], andthis @[[pulling]] tofalse . - Perform
ReadableByteStreamControllerClearPendingPullIntos (this ). - Set
this @[[queue]] to a new emptyList . - Set
this @[[totalQueuedBytes]] to0 . - Set
this @[[started]], andthis @[[closeRequested]] tofalse . - Set
this @[[strategyHWM]] toValidateAndNormalizeHighWaterMark (highWaterMark). - Let autoAllocateChunkSize be
GetV (underlyingByteSource,"autoAllocateChunkSize"). - If autoAllocateChunkSize is not
undefined ,- Set autoAllocateChunkSize to
ToInteger (autoAllocateChunkSize). ReturnIfAbrupt (autoAllocateChunkSize).- If autoAllocateChunkSize ≤ 0, or if autoAllocateChunkSize is
+∞ or-∞ , throw aRangeError exception.
- Set autoAllocateChunkSize to
- Set
this @[[autoAllocateChunkSize]] to autoAllocateChunkSize. - Set
this @[[pendingPullIntos]] to a new emptyList . - Let controller be
this . - Let startResult be
InvokeOrNoop (underlyingByteSource,"start", «this »). ReturnIfAbrupt (startResult).- Resolve startResult as a promise:
- Upon fulfillment,
- Set controller@[[started]] to
true . - Assert: controller@[[pulling]] is
false . - Assert: controller@[[pullAgain]] is
false . - Perform
ReadableByteStreamControllerCallPullIfNeeded (controller).
- Set controller@[[started]] to
- Upon rejection with reason r,
- If stream@[[state]] is
"readable", performReadableByteStreamControllerError (controller, r).
- If stream@[[state]] is
- Upon fulfillment,
3.10.4. Properties of the ReadableByteStreamController Prototype
3.10.4.1. get byobRequest
byobRequest getter returns the current BYOB pull request. - If
IsReadableByteStreamController (this ) isfalse , throw aTypeError exception. - If
this @[[byobRequest]] isundefined andthis @[[pendingPullIntos]] is not empty,- Let firstDescriptor be the first element of
this @[[pendingPullIntos]]. - Let view be
Construct (%Uint8Array%, «firstDescriptor.[[buffer]], firstDescriptor.[[byteOffset]] + firstDescriptor.[[bytesFilled]], firstDescriptor.[[byteLength]] - firstDescriptor.[[bytesFilled]]»). - Set
this @[[byobRequest]] toConstruct (ReadableStreamBYOBRequest, «this , view»).
- Let firstDescriptor be the first element of
- Return
this @[[byobRequest]].
3.10.4.2. get desiredSize
desiredSize getter returns the desired size
to fill the controlled stream’s internal queue. It can be negative, if the queue is over-full. An underlying
source should use this information to determine when and how to apply backpressure. - If
IsReadableByteStreamController (this ) isfalse , throw aTypeError exception. - Return
ReadableByteStreamControllerGetDesiredSize (this ).
3.10.4.3. close()
close method will close the controlled readable stream. Consumers will still be able to read
any previously-enqueued chunks from the stream, but once those are read, the stream will become closed. - If
IsReadableByteStreamController (this ) isfalse , throw aTypeError exception. - If
this @[[closeRequested]] istrue , throw aTypeError exception. - If
this @[[controlledReadableStream]]@[[state]] is not"readable", throw aTypeError exception. - Perform
ReadableByteStreamControllerClose (this ).
3.10.4.4. enqueue(chunk)
enqueue method will enqueue a given chunk in the controlled readable stream. - If
IsReadableByteStreamController (this ) isfalse , throw aTypeError exception. - If
this @[[closeRequested]] istrue , throw aTypeError exception. - If
this @[[controlledReadableStream]]@[[state]] is not"readable", throw aTypeError exception. - If
Type (chunk) is not Object, throw aTypeError exception. - If chunk does not have a [[ViewedArrayBuffer]] internal slot, throw a
TypeError exception. - Return
ReadableByteStreamControllerEnqueue (this , chunk).
3.10.4.5. error(e)
error method will error the readable stream, making all future interactions with it fail with the
given error e. - If
IsReadableByteStreamController (this ) isfalse , throw aTypeError exception. - Let stream be
this @[[controlledReadableStream]]. - If stream@[[state]] is not
"readable", throw aTypeError exception. - Perform
ReadableByteStreamControllerError (this , e).
3.10.5. Readable Stream BYOB Controller Internal Methods
The following are additional internal methods implemented by each ReadableByteStreamController instance. They are
similar to the supporting abstract operations in the following section, but are in method form to allow polymorphic
dispatch from the readable stream implementation to either these or their counterparts for default controllers.
3.10.5.1. [[Cancel]](reason)
- If
this @[[pendingPullIntos]] is not empty,- Let firstDescriptor be the first element of
this @[[pendingPullIntos]]. - Set firstDescriptor.[[bytesFilled]] to 0.
- Let firstDescriptor be the first element of
- Set
this @[[queue]] to a new emptyList . - Set
this @[[totalQueuedBytes]] to 0. - Return
PromiseInvokeOrNoop (this @[[underlyingByteSource]],"cancel", «reason»)
3.10.5.2. [[Pull]]()
- Let stream be
this @[[controlledReadableStream]]. - If
ReadableStreamGetNumReadRequests (stream) is 0,- If
this [[totalQueuedBytes]] > 0,- Let entry be the first element of
this @[[queue]]. - Remove entry from
this @[[queue]], shifting all other elements downward (so that the second becomes the first, and so on). - Subtract entry.[[byteLength]] from
this @[[totalQueuedBytes]]. - Perform
ReadableByteStreamControllerHandleQueueDrain (this ). - Let view be
Construct (%Uint8Array%, «entry.[[buffer]], entry.[[byteOffset]], entry.[[byteLength]]»). - Return a promise resolved with
CreateIterResultObject (view,false ).
- Let entry be the first element of
- Let autoAllocateChunkSize be
this @[[autoAllocateChunkSize]]. - If autoAllocateChunkSize is not
undefined ,- Let buffer be
Construct (%ArrayBuffer%, «autoAllocateChunkSize»). - Let pullIntoDescriptor be Record{[[buffer]]: buffer, [[byteOffset]]: 0, [[byteLength]]: autoAllocateChunkSize, [[bytesFilled]]: 0, [[elementSize]]: 1, [[ctor]]: %Uint8Array%, [[readerType]]:
"default"}. - Append pullIntoDescriptor as the last element of
this @[[pendingPullIntos]].
- Let buffer be
- If
- Otherwise,
- Assert:
this @[[autoAllocateChunkSize]] isundefined .
- Assert:
- Let promise be
ReadableStreamAddReadRequest (stream). - Perform
ReadableByteStreamControllerCallPullIfNeeded (this ). - Return promise.
3.11. Class ReadableStreamBYOBRequest#rs-byob-request-classReferenced in:3.10.2. Internal Slots3.10.4.1. get byobRequest3.11. Class ReadableStreamBYOBRequest3.11.1. Class Definition3.11.2. Internal Slots3.11.4. Properties of the ReadableStreamBYOBRequest Prototype7. Global Properties
The ReadableStreamBYOBRequest class represents a pull into request in a ReadableByteStreamController.
3.11.1. Class Definition
This section is non-normative.
If one were to write the ReadableStreamBYOBRequest class in something close to the syntax of [ECMASCRIPT], it
would look like
class ReadableStreamBYOBRequest {
constructor(controller, view)
get view()
respond(bytesWritten)
respondWithNewView(view)
}
3.11.2. Internal Slots
Instances of ReadableStreamBYOBRequest are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[associatedReadableByteStreamController]] | The parent ReadableByteStreamController instance
|
| [[view]] | A typed array representing the destination region to which the controller may write generated data |
3.11.3. new ReadableStreamBYOBRequest(controller, view)
- Set
this @[[associatedReadableByteStreamController]] to controller. - Set
this @[[view]] to view.
3.11.4. Properties of the ReadableStreamBYOBRequest Prototype
3.11.4.1. get view
- If
IsReadableStreamBYOBRequest (this ) isfalse , throw aTypeError exception. - Return
this @[[view]].
3.11.4.2. respond(bytesWritten)
- If
IsReadableStreamBYOBRequest (this ) isfalse , throw aTypeError exception. - If
this @[[associatedReadableByteStreamController]] isundefined , throw aTypeError exception. - Return
ReadableByteStreamControllerRespond (this @[[associatedReadableByteStreamController]], bytesWritten).
3.11.4.3. respondWithNewView(view)
- If
IsReadableStreamBYOBRequest (this ) isfalse , throw aTypeError exception. - If
this @[[associatedReadableByteStreamController]] isundefined , throw aTypeError exception. - If
Type (chunk) is not Object, throw aTypeError exception. - If view does not have a [[ViewedArrayBuffer]] internal slot, throw a
TypeError exception. - Return
ReadableByteStreamControllerRespondWithNewView (this @[[associatedReadableByteStreamController]], view).
3.12. Readable Stream BYOB Controller Abstract Operations
3.12.1. IsReadableStreamBYOBRequest ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have an [[associatedReadableByteStreamController]] internal slot, return
false . - Return
true .
3.12.2. IsReadableByteStreamController ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have an [[underlyingByteSource]] internal slot, return
false . - Return
true .
3.12.3. ReadableByteStreamControllerCallPullIfNeeded ( controller ) nothrow
- Let shouldPull be
ReadableByteStreamControllerShouldCallPull (controller). - If shouldPull is
false , returnundefined . - If controller@[[pulling]] is
true ,- Set controller@[[pullAgain]] to
true . - Return
undefined .
- Set controller@[[pullAgain]] to
- Set controller@[[pullAgain]] to
false . - Set controller@[[pulling]] to
true . - Let pullPromise be
PromiseInvokeOrNoop (controller@[[underlyingByteSource]],"pull", «controller»). - Upon fulfillment of pullPromise,
- Set controller@[[pulling]] to
false . - If controller@[[pullAgain]] is
true ,- Set controller@[[pullAgain]] to
false . - Perform
ReadableByteStreamControllerCallPullIfNeeded (controller).
- Set controller@[[pullAgain]] to
- Set controller@[[pulling]] to
- Upon rejection of pullPromise with reason e,
- If controller@[[controlledReadableStream]]@[[state]] is
"readable", performReadableByteStreamControllerError (controller, e).
- If controller@[[controlledReadableStream]]@[[state]] is
- Return
undefined .
3.12.4. ReadableByteStreamControllerClearPendingPullIntos ( controller ) nothrow
- If controller@[[byobRequest]] is not
undefined ,- Perform
ReadableStreamBYOBRequestInvalidate (controller@[[byobRequest]]). - Set controller@[[byobRequest]] to
undefined .
- Perform
- Set controller@[[pendingPullIntos]] to a new empty
List .
3.12.5. ReadableByteStreamControllerClose ( controller ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- Assert: controller@[[closeRequested]] is
false . - Assert: stream@[[state]] is
"readable". - If controller@[[totalQueuedBytes]] > 0,
- Set controller@[[closeRequested]] to
true . - Return.
- Set controller@[[closeRequested]] to
- Let firstPendingPullInto be the first element of controller@[[pendingPullIntos]].
- If
ReadableStreamHasBYOBReader (stream) istrue and controller@[[pendingPullIntos]] is not empty and firstPendingPullInto.[[bytesFilled]] > 0.- Let e be a
TypeError exception. - Perform
ReadableByteStreamControllerError (controller, e). - Throw e.
- Let e be a
- Perform
ReadableStreamClose (stream).
3.12.6. ReadableByteStreamControllerCommitPullIntoDescriptor ( stream, pullIntoDescriptor ) nothrow
- Assert: stream@[[state]] is not
"errored". - Let done be
false . - If stream@[[state]] is
"closed",- Assert: pullIntoDescriptor.[[bytesFilled]] is not 0.
- Let done be
true .
- Let filledView be
ReadableByteStreamControllerConvertPullIntoDescriptor (pullIntoDescriptor). - If pullIntoDescriptor.[[readerType]] is
"default",ReadableStreamFulfillReadRequest (stream, filledView, done).
- Otherwise,
- Assert: pullIntoDescriptor.[[readerType]] is
"byob", ReadableStreamFulfillReadIntoRequest (stream, filledView, done).
- Assert: pullIntoDescriptor.[[readerType]] is
3.12.7. ReadableByteStreamControllerConvertPullIntoDescriptor ( pullIntoDescriptor ) nothrow
- Let bytesFilled be pullIntoDescriptor.[[bytesFilled]].
- Let elementSize be pullIntoDescriptor.[[elementSize]].
- Assert: bytesFilled ≤ pullIntoDescriptor.[[byteLength]].
- Assert: bytesFilled mod elementSize is 0.
- Return
Construct (pullIntoDescriptor.[[ctor]], «pullIntoDescriptor.[[buffer]], pullIntoDescriptor.[[byteOffset]], bytesFilled / elementSize»).
3.12.8. ReadableByteStreamControllerEnqueue ( controller, chunk ) throws
- Let stream be controller@[[controlledReadableStream]].
- Assert: controller@[[closeRequested]] is
false . - Assert: stream@[[state]] is
"readable". - Let buffer be chunk@[[ViewedArrayBuffer]].
- Let byteOffset be chunk@[[ByteOffset]].
- Let byteLength be chunk@[[ByteLength]].
- If
ReadableStreamHasReader (stream) istrue - If
ReadableStreamGetNumReadRequests (stream) is 0,- Transfer buffer and let transferredBuffer be the result.
- Perform
ReadableByteStreamControllerEnqueueChunkToQueue (controller, transferredBuffer, byteOffset, byteLength).
- Otherwise,
- Assert: controller@[[queue]] is empty.
- Transfer buffer and let transferredBuffer be the result.
- Let transferredView be
Construct (%Uint8Array%, «transferredBuffer, byteOffset, byteLength»). - Perform
ReadableStreamFulfillReadRequest (stream, transferredView,false ).
- If
- Otherwise,
- If
ReadableStreamHasBYOBReader (stream) istrue ,- Transfer buffer and let transferredBuffer be the result.
- Perform
ReadableByteStreamControllerEnqueueChunkToQueue (controller, transferredBuffer, byteOffset, byteLength). - Perform
ReadableByteStreamControllerProcessPullIntoDescriptorsUsingQueue (controller).
- Otherwise,
- Assert:
IsReadableStreamLocked (stream) isfalse . - Transfer buffer and let transferredBuffer be the result.
- Perform
ReadableByteStreamControllerEnqueueChunkToQueue (controller, transferredBuffer, byteOffset, byteLength).
- Assert:
- If
3.12.9. ReadableByteStreamControllerEnqueueChunkToQueue ( controller, buffer, byteOffset, byteLength ) nothrow
- Append Record{[[buffer]]: buffer, [[byteOffset]]: byteOffset, [[byteLength]]: byteLength} as the last element of controller@[[queue]].
- Add byteLength to controller@[[totalQueuedBytes]].
3.12.10. ReadableByteStreamControllerError ( controller, e ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- Assert: stream@[[state]] is
"readable". - Perform
ReadableByteStreamControllerClearPendingPullIntos (controller). - Let controller@[[queue]] be a new empty
List . - Perform
ReadableStreamError (stream, e).
3.12.11. ReadableByteStreamControllerFillHeadPullIntoDescriptor ( controller, size, pullIntoDescriptor ) nothrow
- Assert: controller@[[pendingPullIntos]] is empty or the first element of controller@[[pendingPullIntos]] is pullIntoDescriptor.
- If controller@[[byobRequest]] is not
undefined ,- Perform
ReadableStreamBYOBRequestInvalidate (controller@[[byobRequest]]). - Set controller@[[byobRequest]] to
undefined .
- Perform
- Add size to pullIntoDescriptor.[[bytesFilled]].
3.12.12. ReadableByteStreamControllerFillPullIntoDescriptorFromQueue ( controller, pullIntoDescriptor ) nothrow
- Let elementSize be pullIntoDescriptor.[[elementSize]].
- Let currentAlignedBytes be pullIntoDescriptor.[[bytesFilled]] - pullIntoDescriptor.[[bytesFilled]] mod elementSize.
- Let maxBytesToCopy be the minimum of controller@[[totalQueuedBytes]] and pullIntoDescriptor.[[byteLength]] - pullIntoDescriptor.[[bytesFilled]].
- Let maxBytesFilled be pullIntoDescriptor.[[bytesFilled]] + maxBytesToCopy.
- Let maxAlignedBytes be maxBytesFilled - maxBytesFilled mod elementSize.
- Let totalBytesToCopyRemaining be maxBytesToCopy.
- Let ready be
false . - If maxAlignedBytes > currentAlignedBytes,
- Let totalBytesToCopyRemaining be maxAlignedBytes - pullIntoDescriptor.[[bytesFilled]].
- Let ready be
true .
- Let queue be controller@[[queue]].
- Repeat the following steps while totalBytesToCopyRemaining > 0,
- Let headOfQueue be the first element of queue.
- Let bytesToCopy be the minimum of totalBytesToCopyRemaining and headOfQueue.[[byteLength]].
- Let destStart be pullIntoDescriptor.[[byteOffset]] + pullIntoDescriptor.[[bytesFilled]].
- Set the bytesToCopy bytes of headOfQueue.[[buffer]] at offset headOfQueue.[[byteOffset]] to the bytesToCopy bytes of pullIntoDescriptor.[[buffer]] at offset destStart.
- If headOfQueue.[[byteLength]] is bytesToCopy,
- Remove the first element of queue, shifting all other elements downward (so that the second becomes the first, and so on).
- Otherwise,
- Add bytesToCopy to headOfQueue.[[byteOffset]].
- Subtract bytesToCopy from headOfQueue.[[byteLength]].
- Subtract bytesToCopy from controller@[[totalQueuedBytes]].
- Perform
ReadableByteStreamControllerFillHeadPullIntoDescriptor (controller, bytesToCopy, pullIntoDescriptor). - Subtract bytesToCopy from totalBytesToCopyRemaining.
- If ready is
false ,- Assert: controller@[[totalQueuedBytes]] is 0.
- Assert: pullIntoDescriptor@[[bytesFilled]] > 0.
- Assert: pullIntoDescriptor@[[bytesFilled]] < pullIntoDescriptor.[[elementSize]].
- Return ready.
3.12.13. ReadableByteStreamControllerGetDesiredSize ( controller ) nothrow
- Return controller@[[strategyHWM]] - controller@[[totalQueuedBytes]].
3.12.14. ReadableByteStreamControllerHandleQueueDrain ( controller ) nothrow
- Assert: controller@[[controlledReadableStream]]@[[state]] is
"readable". - If controller@[[totalQueuedBytes]] is 0 and controller@[[closeRequested]] is
true ,- Perform
ReadableStreamClose (controller@[[controlledReadableStream]]).
- Perform
- Otherwise,
- Perform
ReadableByteStreamControllerCallPullIfNeeded (controller).
- Perform
3.12.15. ReadableByteStreamControllerProcessPullIntoDescriptorsUsingQueue ( controller ) nothrow
- Assert: controller@[[closeRequested]] is
false . - Repeat the following steps while controller@[[pendingPullIntos]] is not empty,
- If controller@[[totalQueuedBytes]] is 0, return.
- Let pullIntoDescriptor be the first element of controller@[[pendingPullIntos]].
- If
ReadableByteStreamControllerFillPullIntoDescriptorFromQueue (controller, pullIntoDescriptor) istrue ,- Perform
ReadableByteStreamControllerShiftPendingPullInto (controller). - Perform
ReadableByteStreamControllerCommitPullIntoDescriptor (controller@[[controlledReadableStream]], pullIntoDescriptor).
- Perform
3.12.16. ReadableByteStreamControllerPullInto ( controller, view ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- Let elementSize be 1.
- If view has a [[TypedArrayName]] internal slot (i.e., it is not a
DataView), set elementSize to the element size specified in The TypedArray Constructors table for view@[[TypedArrayName]]. - Let ctor be %DataView%.
- If view has a [[TypedArrayName]] internal slot (i.e., it is not a
DataView), set ctor to the constructor specified in The TypedArray Constructors table for view@[[TypedArrayName]]. - Let pullIntoDescriptor be Record{[[buffer]]: view.[[buffer]], [[byteOffset]]: view.[[byteOffset]], [[byteLength]]: view.[[byteLength]], [[bytesFilled]]: 0, [[elementSize]]: elementSize, [[ctor]]: ctor, [[readerType]]:
"byob"}. - If controller@[[pendingPullIntos]] is not empty,
- Transfer pullIntoDescriptor.[[buffer]] and set pullIntoDescriptor.[[buffer]] to the result.
- Append pullIntoDescriptor as the last element of controller@[[pendingPullIntos]].
- Return
ReadableStreamAddReadIntoRequest (stream).
- If stream@[[state]] is
"closed",- Let emptyView be
Construct (ctor, «view.[[buffer]], view.[[byteOffset]], 0»). - Return a promise resolved with
CreateIterResultObject (emptyView,true ).
- Let emptyView be
- If controller@[[totalQueuedBytes]] > 0,
- If
ReadableByteStreamControllerFillPullIntoDescriptorFromQueue (controller, pullIntoDescriptor) istrue ,- Let filledView be
ReadableByteStreamControllerConvertPullIntoDescriptor (pullIntoDescriptor). - Perform
ReadableByteStreamControllerHandleQueueDrain (controller). - Return a promise resolved with
CreateIterResultObject (filledView,false ).
- Let filledView be
- If controller@[[closeRequested]] is
true ,- Let e be a
TypeError exception. - Perform
ReadableByteStreamControllerError (controller, e). - Return a promise rejected with e.
- Let e be a
- If
- Transfer pullIntoDescriptor.[[buffer]] and set pullIntoDescriptor.[[buffer]] to the result.
- Append pullIntoDescriptor as the last element of controller@[[pendingPullIntos]].
- Let promise be
ReadableStreamAddReadIntoRequest (stream). - Perform
ReadableByteStreamControllerCallPullIfNeeded (controller). - Return promise.
3.12.17. ReadableByteStreamControllerRespond ( controller, bytesWritten ) throws
- Let bytesWritten be
ToNumber (bytesWritten). - If
IsFiniteNonNegativeNumber (bytesWritten) isfalse ,- Throw a
RangeError exception.
- Throw a
- Assert: controller@[[pendingPullIntos]] is not empty.
- Return
ReadableByteStreamControllerRespondInternal (controller, bytesWritten).
3.12.18. ReadableByteStreamControllerRespondInClosedState ( controller, firstDescriptor ) nothrow
- Transfer firstDescriptor.[[buffer]] and set firstDescriptor.[[buffer]] to the result.
- Assert: firstDescriptor.[[bytesFilled]] is 0.
- Let stream be controller@[[controlledReadableStream]].
- Repeat the following steps while
ReadableStreamGetNumReadIntoRequests (stream) > 0,- Let pullIntoDescriptor be
ReadableByteStreamControllerShiftPendingPullInto (controller). - Perform
ReadableByteStreamControllerCommitPullIntoDescriptor (stream, pullIntoDescriptor).
- Let pullIntoDescriptor be
3.12.19. ReadableByteStreamControllerRespondInReadableState ( controller, bytesWritten, pullIntoDescriptor ) nothrow
- If pullIntoDescriptor.[[bytesFilled]] + bytesWritten > pullIntoDescriptor.[[byteLength]], throw a
RangeError exception. - Perform
ReadableByteStreamControllerFillHeadPullIntoDescriptor (controller, bytesWritten, pullIntoDescriptor). - If pullIntoDescriptor.[[bytesFilled]] < pullIntoDescriptor.[[elementSize]], return.
- Perform
ReadableByteStreamControllerShiftPendingPullInto (controller). - Let remainderSize be pullIntoDescriptor.[[bytesFilled]] mod pullIntoDescriptor.[[elementSize]].
- If remainderSize > 0,
- Let end be pullIntoDescriptor.[[byteOffset]] + pullIntoDescriptor.[[bytesFilled]].
- Let remainder be a new ArrayBuffer containing the remainderSize bytes of pullIntoDescriptor.[[buffer]] at offset end - remainderSize.
- Perform
ReadableByteStreamControllerEnqueueChunkToQueue (controller, remainder, 0, remainder@[[ByteLength]]).
- Transfer pullIntoDescriptor.[[buffer]] and set pullIntoDescriptor.[[buffer]] to the result.
- Let pullIntoDescriptor.[[bytesFilled]] be pullIntoDescriptor.[[bytesFilled]] - remainderSize.
- Perform
ReadableByteStreamControllerCommitPullIntoDescriptor (controller@[[controlledReadableStream]], pullIntoDescriptor). - Perform
ReadableByteStreamControllerProcessPullIntoDescriptorsUsingQueue (controller).
3.12.20. ReadableByteStreamControllerRespondInternal ( controller, bytesWritten ) throws
- Let firstDescriptor be the first element of controller@[[pendingPullIntos]].
- Let stream be controller@[[controlledReadableStream]].
- If stream@[[state]] is
"closed",- If bytesWritten is not 0,
- Throw a
TypeError exception.
- Throw a
- Perform
ReadableByteStreamControllerRespondInClosedState (controller, firstDescriptor).
- If bytesWritten is not 0,
- Otherwise,
- Assert: stream@[[state]] is
"readable". - Perform
ReadableByteStreamControllerRespondInReadableState (controller, bytesWritten, firstDescriptor).
- Assert: stream@[[state]] is
3.12.21. ReadableByteStreamControllerRespondWithNewView ( controller, view ) throws
- Assert: controller@[[pendingPullIntos]] is not empty.
- Let firstDescriptor be the first element of controller@[[pendingPullIntos]].
- If firstDescriptor.[[byteOffset]] + firstDescriptor.[[bytesFilled]] is not view@[[ByteOffset]],
- Throw a
RangeError exception.
- Throw a
- If firstDescriptor.[[byteLength]] is not view@[[ByteOffset]],
- Throw a
RangeError exception.
- Throw a
- Set firstDescriptor.[[buffer]] to view@[[ViewedArrayBuffer]].
- Return
ReadableByteStreamControllerRespondInternal (controller, view@[[ByteLength]]).
3.12.22. ReadableByteStreamControllerShiftPendingPullInto ( controller ) nothrow
- Let descriptor be the first element of controller@[[pendingPullIntos]].
- Remove descriptor from controller@[[pendingPullIntos]], shifting all other elements downward (so that the second becomes the first, and so on).
- If controller@[[byobRequest]] is not
undefined ,- Perform
ReadableStreamBYOBRequestInvalidate (controller@[[byobRequest]]). - Set controller@[[byobRequest]] to
undefined .
- Perform
- Return descriptor.
3.12.23. ReadableByteStreamControllerShouldCallPull ( controller ) nothrow
- Let stream be controller@[[controlledReadableStream]].
- If stream@[[state]] is not
"readable", returnfalse . - If controller@[[closeRequested]] is
true , returnfalse . - If controller@[[started]] is
false , returnfalse . - If
ReadableStreamHasReader (stream) istrue andReadableStreamGetNumReadRequests (stream) > 0, returntrue . - If
ReadableStreamHasBYOBReader (stream) istrue andReadableStreamGetNumReadIntoRequests (stream) > 0, returntrue . - Let desiredSize be
ReadableByteStreamControllerGetDesiredSize (controller). - If desiredSize > 0, return
true . - Return
false .
3.12.24. ReadableStreamBYOBRequestInvalidate ( request ) nothrow
- Set request@[[associatedReadableByteStreamController]] to
undefined . - Set request@[[view]] to
undefined .
4. Writable Streams
4.1. Using Writable Streams
readableStream.pipeTo(writableStream)
.then(() => console.log("All data successfully written!"))
.catch(e => console.error("Something went wrong!", e));
write() and close() methods. Since writable streams queue any incoming writes, and take care internally to forward them to the underlying sink in sequence, you can indiscriminately write to a writable stream without much ceremony:
function writeArrayToStream(array, writableStream) {
array.forEach(chunk => writableStream.write(chunk));
return writableStream.close();
}
writeArrayToStream([1, 2, 3, 4, 5], writableStream)
.then(() => console.log("All done!"))
.catch(e => console.error("Error with the stream: " + e));
close() method. That promise (which can also be accessed using the closed getter) will reject if anything goes wrong with the stream—initializing it, writing to it,
or closing it. And it will fulfill once the stream is successfully closed. Often this is all you care about.
However, if you care about the success of writing a specific chunk, you can use the promise returned by the
stream’s write() method:
writableStream.write("i am a chunk of data")
.then(() => console.log("chunk successfully written!"))
.catch(e => console.error(e));
What "success" means is up to a given stream instance (or more precisely, its underlying sink) to decide. For example, for a file stream it could simply mean that the OS has accepted the write, and not necessarily that the chunk has been flushed to disk.
4.2. Class WritableStream#ws-classReferenced in:3.2.4.4. pipeThrough({ writable, readable }, options)4.2.1. Class Definition4.2.2. Internal Slots4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {}) (2) (3)4.2.4. Properties of the WritableStream Prototype7. Global Properties8. Examples of Creating Streams
4.2.1. Class Definition
This section is non-normative.
If one were to write the WritableStream class in something close to the syntax of [ECMASCRIPT], it would look
like
class WritableStream {
constructor(underlyingSink = {}, { size, highWaterMark = 0 } = {})
get closed()
get ready()
get state()
abort(reason)
close()
write(chunk)
}
4.2.2. Internal Slots
Instances of WritableStream are created with the internal slots described in the following table:
| Internal Slot | Description (non-normative) |
|---|---|
| [[closedPromise]] | A promise that becomes fulfilled when the stream becomes "closed"; returned by the closed getter
|
| [[queue]] | A |
| [[started]] | A boolean flag indicating whether the underlying sink has finished starting |
| [[startedPromise]] | A promise storing the result of starting the underlying sink, used to delay actions until that is complete |
| [[state]] | A string containing the stream’s current state; returned by the state getter
|
| [[storedError]] | A value indicating how the stream failed, to be given as a failure reason or exception when trying to operate
on the stream while in the "errored" state
|
| [[strategySize]] | A function supplied to the constructor as part of the stream’s queuing strategy, designed to calculate
the size of chunks written; can be |
| [[strategyHWM]] | A number supplied to the constructor as part of the stream’s queuing strategy, indicating the point at which the stream will apply backpressure to any producers. |
| [[readyPromise]] | A promise returned by the ready getter
|
| [[underlyingSink]] | An object representation of the stream’s underlying sink; also used for the |
| [[writing]] | A boolean flag indicating whether the stream is currently writing to the underlying sink, used to prevent concurrent such writes |
4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {})
underlyingSink object passed to the constructor can implement any of the following methods to govern
how the constructed stream instance behaves:
-
start(error)is called immediately, and should perform any actions necessary to acquire access to the underlying sink. If this process is asynchronous, it can return a promise to signal success or failure. -
write(chunk)is called when a new chunk of data is ready to be written to the underlying sink. It can return a promise to signal success or failure of the write operation. The stream implementation guarantees that this method will be called only after previous writes have succeeded, and never aftercloseorabortis called. -
close()is called after the producer signals that they are done writing chunks to the stream, and all queued-up writes successfully complete. It should perform any actions necessary to finalize writes to the underlying sink, and release access to it. If this process is asynchronous, it can return a promise to signal success or failure. The stream implementation guarantees that this method will be called only after all queued-up writes have succeeded. -
abort(reason)is called when the producer signals they wish to abruptly close the stream and put it in an"errored"state. It should clean up any held resources, much likeclose, but perhaps with some custom handling. Unlikeclose,abortwill be called even if writes are queued up; those chunks will be thrown away. If this process is asynchronous, it can return a promise to signal success or failure. If no abort method is passed, by default theclosemethod will be called instead.
The constructor also accepts a second argument containing the queuing strategy object with
two properties: a non-negative number highWaterMark, and a function size(chunk). The
supplied strategy could be an instance of the built-in CountQueuingStrategy or ByteLengthQueuingStrategy classes, or it could be custom. If no strategy is supplied, the default
behavior will be the same as a CountQueuingStrategy with a high water mark of 0.
close and abort to be called, in cases where the producer aborts the stream while it is in the "closing" state. Notably, since a stream always spends at least one turn in the "closing" state, code like ws.close(); ws.abort(...); will cause both to be called, even if the close method itself has no asynchronous behavior. A well-designed underlying sink object should be able to deal with
this. - Set
this @[[underlyingSink]] to underlyingSink. - Set
this @[[closedPromise]] to a new promise. - Set
this @[[readyPromise]] to a new promise resolved withundefined . - Set
this @[[queue]] to a new emptyList . - Set
this @[[state]] to "writable". - Set
this @[[started]] andthis @[[writing]] tofalse . - Let normalizedStrategy be
ValidateAndNormalizeQueuingStrategy (size, highWaterMark). - Set
this @[[strategySize]] to normalizedStrategy.[[size]] andthis @[[strategyHWM]] to normalizedStrategy.[[highWaterMark]]. - Perform
SyncWritableStreamStateWithQueue (this ). - Let error be a new
WritableStreamerror function. - Set error@[[stream]] to
this . - Let startResult be
InvokeOrNoop (underlyingSink, "start", «error»). ReturnIfAbrupt (startResult).- Set
this @[[startedPromise]] to the result of resolving startResult as a promise.- Upon fulfillment,
- Set
this @[[started]] totrue . - Set
this @[[startedPromise]] toundefined .
- Set
- Upon rejection with reason r, perform
ErrorWritableStream (this , r).
- Upon fulfillment,
A WritableStream error function#writablestream-error-functionReferenced in:4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {}) is an anonymous built-in function that is used to allow underlying sinks to error their associated writable stream. Each WritableStream error function has
a [[stream]] internal slot. When a WritableStream error function F is called with argument e, it performs the following steps:
- Let stream be F@[[stream]].
- Perform
ErrorWritableStream (stream, e). - Return
undefined .
4.2.4. Properties of the WritableStream Prototype
4.2.4.1. get closed#ws-closedReferenced in:4.1. Using Writable Streams4.2.2. Internal Slots
closed getter returns a promise that will be fulfilled when the stream becomes closed, or rejected
if it ever errors. - If
IsWritableStream (this ) isfalse , return a promise rejected with aTypeError exception. - Return
this @[[closedPromise]].
4.2.4.2. get ready#ws-readyReferenced in:4.2.2. Internal Slots4.2.4.3. get state
ready getter returns a promise that will be fulfilled when the stream transitions away from the "waiting" state to any other state. Once the stream transitions back to "waiting", the
getter will return a new promise that stays pending until the next state transition.
In essence, this promise gives a signal as to when any backpressure has let up (or that the stream has been closed or errored).
- If
IsWritableStream (this ) isfalse , return a promise rejected with aTypeError exception. - Return
this @[[readyPromise]].
4.2.4.3. get state#ws-stateReferenced in:4.2.2. Internal Slots4.2.4.6. write(chunk)
state getter returns the state of the stream, which will be one of the following:
"waiting"- The stream’s internal queue is full; that is, the stream is
exerting backpressure. Use
readyto be notified of when the pressure subsides. "writable"- The stream’s internal queue is not full; call
write()until backpressure is exerted. "closing"- The stream’s
close()method has been called, and a command to close is in the queue or being processed by the underlying sink; attempts to write will now fail. "closed"- The underlying sink has been closed; writing is no longer possible.
"errored"- An error occurred interacting with the underlying sink or the stream has been aborted, so the stream is now dead.
- If
IsWritableStream (this ) isfalse , throw aTypeError exception. - Return
this @[[state]].
4.2.4.4. abort(reason)
abort method signals that the producer can no longer successfully write to the stream and it should
be immediately moved to an "errored" state, with any queued-up writes discarded. This will also execute
any abort mechanism of the underlying sink. - If
IsWritableStream (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[state]] is "closed", return a new promise resolved withundefined . - If
this @[[state]] is "errored", return a new promise rejected withthis @[[storedError]]. - Perform
ErrorWritableStream (this , reason). - Let sinkAbortPromise be
PromiseInvokeOrFallbackOrNoop (this @[[underlyingSink]], "abort", «reason», "close", «»). - Return the result of transforming sinkAbortPromise by a fulfillment handler that returns
undefined .
4.2.4.5. close()#ws-closeReferenced in:4.1. Using Writable Streams (2)4.2.4.3. get state
close method signals that the producer is done writing chunks to the stream and wishes to move the
stream to a "closed" state. This queues an action to close the stream, such that once any currently
queued-up writes complete, the close mechanism of the underlying sink will execute, releasing any held
resources. In the meantime, the stream will be in a "closing" state. - If
IsWritableStream (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[state]] is "closing" or "closed", return a promise rejected with aTypeError exception. - If
this @[[state]] is "errored", return a promise rejected withthis @[[storedError]]. - If
this @[[state]] is "waiting", resolvethis @[[readyPromise]] withundefined . - Set
this @[[state]] to "closing". - Perform
EnqueueValueWithSize (this @[[queue]], "close",0 ). - Perform
CallOrScheduleWritableStreamAdvanceQueue (this ). - Return
this @[[closedPromise]].
4.2.4.6. write(chunk)#ws-writeReferenced in:4.1. Using Writable Streams (2)4.2.4.3. get state
write method adds a write to the stream’s internal queue, instructing the stream to
write the given chunk of data to the underlying sink once all other pending writes have finished
successfully. It returns a promise that will be fulfilled or rejected depending on the success or failure of writing
the chunk to the underlying sink.
The impact of enqueuing this chunk will be immediately reflected in the stream’s state property; in
particular, if the internal queue is now full according to the stream’s queuing strategy, the stream will
exert backpressure by changing its state to "waiting".
- If
IsWritableStream (this ) isfalse , return a promise rejected with aTypeError exception. - If
this @[[state]] is "closing" or "closed", return a promise rejected with aTypeError exception. - If
this @[[state]] is "errored", return a promise rejected withthis @[[storedError]]. - Assert:
this @[[state]] is either "waiting" or "writable". - Let chunkSize be
1 . - If
this @[[strategySize]] is notundefined , then- Set chunkSize to
Call (this @[[strategySize]],undefined , «chunk»). - If chunkSize is an
abrupt completion ,- Perform
ErrorWritableStream (this , chunkSize.[[value]]). - Return a new promise rejected with chunkSize.[[value]].
- Perform
- Set chunkSize to chunkSize.[[value]].
- Set chunkSize to
- Let promise be a new promise.
- Let writeRecord be Record{[[promise]]: promise, [[chunk]]: chunk}.
- Let enqueueResult be
EnqueueValueWithSize (this @[[queue]], writeRecord, chunkSize). - If enqueueResult is an
abrupt completion ,- Perform
ErrorWritableStream (this , enqueueResult.[[value]]). - Return a new promise rejected with enqueueResult.[[value]].
- Perform
- Perform
SyncWritableStreamStateWithQueue (this ). - Perform
CallOrScheduleWritableStreamAdvanceQueue (this ). - Return promise.
4.3. Writable Stream Abstract Operations
4.3.1. CallOrScheduleWritableStreamAdvanceQueue ( stream ) nothrow
- If stream@[[started]] is
false , then- Upon fulfillment of stream@[[startedPromise]], perform
WritableStreamAdvanceQueue (stream).
- Upon fulfillment of stream@[[startedPromise]], perform
- Otherwise,
- Perform
WritableStreamAdvanceQueue (stream).
- Perform
- Return
undefined .
4.3.2. CloseWritableStream ( stream ) nothrow
- Assert: stream@[[state]] is "closing".
- Let sinkClosePromise be
PromiseInvokeOrNoop (stream@[[underlyingSink]], "close").- Upon fulfillment,
- If stream@[[state]] is "errored", return.
- Assert: stream@[[state]] is "closing".
- Resolve stream@[[closedPromise]] with
undefined . - Set stream@[[state]] to "closed".
- Upon rejection with reason r, perform
ErrorWritableStream (stream, r).
- Upon fulfillment,
- Return
undefined .
4.3.3. ErrorWritableStream ( stream, e ) nothrow
- If stream@[[state]] is "closed" or "errored", return
undefined . - Repeat while stream@[[queue]] is not empty:
- Let writeRecord be
DequeueValue (stream@[[queue]]). - If writeRecord is not "close", reject writeRecord.[[promise]] with e.
- Let writeRecord be
- Set stream@[[storedError]] to e.
- If stream@[[state]] is "waiting", resolve stream@[[readyPromise]] with
undefined . - Reject stream@[[closedPromise]] with e.
- Set stream@[[state]] to "errored".
- Return
undefined .
4.3.4. IsWritableStream ( x ) nothrow
- If
Type (x) is not Object, returnfalse . - If x does not have a [[underlyingSink]] internal slot, return
false . - Return
true .
4.3.5. SyncWritableStreamStateWithQueue ( stream ) nothrow
- If stream@[[state]] is "closing", return
undefined . - Assert: stream@[[state]] is either "writable" or "waiting".
- Let queueSize be
GetTotalQueueSize (stream@[[queue]]). - Let shouldApplyBackpressure be
true if queueSize > stream@[[strategyHWM]], andfalse otherwise. - If shouldApplyBackpressure is
true and stream@[[state]] is "writable", then- Set stream@[[state]] to "waiting".
- Set stream@[[readyPromise]] to a new promise.
- If shouldApplyBackpressure is
false and stream@[[state]] is "waiting", then- Set stream@[[state]] to "writable".
- Resolve stream@[[readyPromise]] with
undefined .
- Return
undefined .
4.3.6. WritableStreamAdvanceQueue ( stream ) nothrow
- If stream@[[queue]] is empty, or stream@[[writing]] is
true , returnundefined . - Let writeRecord be
PeekQueueValue (stream@[[queue]]). - If writeRecord is "close", then
- Assert: stream@[[state]] is "closing".
- Perform
DequeueValue (stream@[[queue]]). - Assert: stream@[[queue]] is now empty.
- Perform
CloseWritableStream (stream). - Return
undefined .
- Set stream@[[writing]] to
true . - Let writeResult be
PromiseInvokeOrNoop (stream@[[underlyingSink]], "write", «writeRecord.[[chunk]]»). - Upon fulfillment of writeResult,
- If stream@[[state]] is "errored", return.
- Set stream@[[writing]] to
false . - Resolve writeRecord.[[promise]] with
undefined . - Perform
DequeueValue (stream@[[queue]]). - Perform
SyncWritableStreamStateWithQueue (stream). - Perform
WritableStreamAdvanceQueue (stream).
- Upon rejection of writeResult with reason r, perform
ErrorWritableStream (stream, r). - Return
undefined .
5. Transform Streams
Transform streams have been developed in the testable implementation, but not yet re-encoded in spec language. We are waiting to validate their design before doing so. In the meantime, see reference-implementation/lib/transform-stream.js.
6. Other Stream APIs and Operations
6.1. Class ByteLengthQueuingStrategy#blqs-classReferenced in:3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {})4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {})6.1.1. Class Definition (2)6.1.3. Properties of the ByteLengthQueuingStrategy Prototype7. Global Properties
A common queuing strategy when dealing with bytes is to wait until the accumulated byteLength properties of the incoming chunks reaches a specified high-water mark. As such, this is provided as a built-in queuing strategy that can be used when constructing streams.
const stream = new ReadableStream(
{ ... },
new ByteLengthQueuingStrategy({ highWaterMark: 16 * 1024 })
);
In this case, 16 KiB worth of chunks can be enqueued by the readable stream’s underlying source before the readable stream implementation starts sending backpressure signals to the underlying source.
const stream = new WritableStream(
{ ... },
new ByteLengthQueuingStrategy({ highWaterMark: 32 * 1024 })
);
In this case, 32 KiB worth of chunks can be accumulated in the writable stream’s internal queue, waiting for previous writes to the underlying sink to finish, before the writable stream starts sending backpressure signals to any producers.
6.1.1. Class Definition
This section is non-normative.
If one were to write the ByteLengthQueuingStrategy class in something close to the syntax of [ECMASCRIPT], it
would look like
class ByteLengthQueuingStrategy {
constructor({ highWaterMark })
size(chunk)
}
Each ByteLengthQueuingStrategy instance will additionally have an own data property highWaterMark set by its constructor.
6.1.2. new ByteLengthQueuingStrategy({ highWaterMark })
CreateDataProperty (this , "highWaterMark", highWaterMark).
6.1.3. Properties of the ByteLengthQueuingStrategy Prototype
6.1.3.1. size(chunk)
size method returns the given chunk’s byteLength property. (If the chunk doesn’t have
one, it will return This method is intentionally generic; it does not require that its ByteLengthQueuingStrategy object.
- Return
GetV (chunk, "byteLength").
6.2. Class CountQueuingStrategy#cqs-classReferenced in:3.2.3. new ReadableStream(underlyingSource = {}, { size, highWaterMark = 1 } = {}) (2)4.2.3. new WritableStream(underlyingSink = {}, { size, highWaterMark = 0 } = {}) (2)6.2.1. Class Definition (2)6.2.3. Properties of the CountQueuingStrategy Prototype7. Global Properties
A common queuing strategy when dealing with streams of generic objects is to simply count the number of chunks that have been accumulated so far, waiting until this number reaches a specified high-water mark. As such, this strategy is also provided out of the box.
const stream = new ReadableStream(
{ ... },
new CountQueuingStrategy({ highWaterMark: 10 })
);
In this case, 10 chunks (of any kind) can be enqueued by the readable stream’s underlying source before the readable stream implementation starts sending backpressure signals to the underlying source.
const stream = new WritableStream(
{ ... },
new CountQueuingStrategy({ highWaterMark: 5 })
);
In this case, five chunks (of any kind) can be accumulated in the writable stream’s internal queue, waiting for previous writes to the underlying sink to finish, before the writable stream starts sending backpressure signals to any producers.
6.2.1. Class Definition
This section is non-normative.
If one were to write the CountQueuingStrategy class in something close to the syntax of [ECMASCRIPT], it would
look like
class CountQueuingStrategy {
constructor({ highWaterMark })
size()
}
Each CountQueuingStrategy instance will additionally have an own data property highWaterMark set by its constructor.
6.2.2. new CountQueuingStrategy({ highWaterMark })
CreateDataProperty (this , "highWaterMark", highWaterMark).
6.2.3. Properties of the CountQueuingStrategy Prototype
6.2.3.1. size()
size method returns one always, so that the total queue size is a count of the number of chunks in
the queue.
This method is intentionally generic; it does not require that its CountQueuingStrategy object.
- Return
1 .
6.3. Queue-with-Sizes Operations
The streams in this specification use a "queue-with-sizes" data structure to store queued up values, along with their
determined sizes. A queue-with-sizes is a
A number of abstract operations are specified here to make working with queues-with-sizes more pleasant, and used throughout the rest of this standard.
6.3.1. DequeueValue ( queue ) nothrow
- Assert: queue is not empty.
- Let pair be the first element of queue.
- Remove pair from queue, shifting all other elements downward (so that the second becomes the first, and so on).
- Return pair.[[value]].
6.3.2. EnqueueValueWithSize ( queue, value, size ) throws
- Let size be
ToNumber (size). ReturnIfAbrupt (size).- If size is
NaN ,+∞ , or negative, throw aRangeError exception. - Append Record{[[value]]: value, [[size]]: size} as the last element of queue.
- Return
undefined .
6.3.3. GetTotalQueueSize ( queue ) nothrow
- Let totalSize be
0 . - Repeat for each Record{[[value]], [[size]]} pair that is an element of queue,
- Assert: pair.[[size]] is a finite, non-
NaN number. - Add pair.[[size]] to totalSize.
- Assert: pair.[[size]] is a finite, non-
- Return totalSize.
6.3.4. PeekQueueValue ( queue ) nothrow
- Assert: queue is not empty.
- Let pair be the first element of queue.
- Return pair.[[value]].
6.4. Miscellaneous Operations
A few abstract operations are used in this specification for utility purposes. We define them here.
6.4.1. IsFiniteNonNegativeNumber ( v ) nothrow
- If v is
NaN , returnfalse . - If v is
+∞ , returnfalse . - If v < 0, return
false . - Return
true .
6.4.2. InvokeOrNoop ( O, P, args ) throws
- Assert: P is a valid property key.
- If args was not passed, let args be a new empty
List . - Let method be
GetV (O, P). ReturnIfAbrupt (method).- If method is
undefined , returnundefined . - Return
Call (method, O, args).
6.4.3. PromiseInvokeOrFallbackOrNoop ( O, P1, args1, P2, args2 ) nothrow
- Assert: P1 is a valid property key.
- Assert: P2 is a valid property key.
- Let method be
GetV (O, P1). - If method is an
abrupt completion , return a new promise rejected with method.[[value]]. - Let method be method.[[value]].
- If method is
undefined , returnPromiseInvokeOrNoop (O, P2, args2). - Let returnValue be
Call (method, O, args1). - If returnValue is an
abrupt completion , return a new promise rejected with returnValue.[[value]]. - Otherwise, return a new promise resolved with returnValue.[[value]].
6.4.4. PromiseInvokeOrNoop ( O, P, args ) nothrow
- Assert: P is a valid property key.
- If args was not passed, let args be a new empty
List . - Let method be
GetV (O, P). - If method is an
abrupt completion , return a new promise rejected with method.[[value]]. - Let method be method.[[value]].
- If method is
undefined , return a new promise resolved withundefined . - Let returnValue be
Call (method, O, args). - If returnValue is an
abrupt completion , return a new promise rejected with returnValue.[[value]]. - Otherwise, return a new promise resolved with returnValue.[[value]].
6.4.5. ValidateAndNormalizeHighWaterMark ( highWaterMark ) throws
- Set highWaterMark to
ToNumber (highWaterMark). ReturnIfAbrupt (highWaterMark).- If highWaterMark is
NaN , throw aTypeError exception. - If highWaterMark <
0 , throw aRangeError exception. - Return highWaterMark.
6.4.6. ValidateAndNormalizeQueuingStrategy ( size, highWaterMark ) throws
- If size is not
undefined andIsCallable (size) isfalse , throw aTypeError exception. - Let highWaterMark be
ValidateAndNormalizeHighWaterMark (highWaterMark). ReturnIfAbrupt (highWaterMark).- Return Record{[[size]]: size, [[highWaterMark]]: highWaterMark}.
7. Global Properties
The following constructors must be exposed on the global object as data properties of the same name:
The attributes of these properties must be { [[Writable]]:
ReadableStreamDefaultReader and ReadableStreamBYOBReader classes are specifically not exposed,
as while they do have a functioning constructor, instances should instead be created through the getReader() method of a ReadableStream instance.
Similarly, the supporting classes ReadableStreamDefaultController, ReadableByteStreamController, and ReadableStreamBYOBRequest are not exposed, since they are not independently useful outside of the ReadableStream implementation. 8. Examples of Creating Streams
This section, and all its subsections, are non-normative.
The previous examples throughout the standard have focused on how to use streams. Here we show how to create a stream,
using the ReadableStream or WritableStream constructors.
8.1. A readable stream with an underlying push source (no backpressure support)
The following function creates readable streams that wrap WebSocket instances [HTML], which are push sources that do not support backpressure signals. It illustrates how, when adapting a push source, usually most of the work
happens in the start function.
function makeReadableWebSocketStream(url, protocols) {
const ws = new WebSocket(url, protocols);
ws.binaryType = "arraybuffer";
return new ReadableStream({
start(controller) {
ws.onmessage = event => controller.enqueue(event.data);
ws.onend = () => controller.close();
ws.onerror = () => controller.error(new Error("The WebSocket errored!"));
},
cancel() {
ws.close();
}
});
}
We can then use this function to create readable streams for a web socket, and pipe that stream to an arbitrary writable stream:
const webSocketStream = makeReadableWebSocketStream("wss://example.com:443/", "protocol");
webSocketStream.pipeTo(writableStream)
.then(() => console.log("All data successfully written!"))
.catch(e => console.error("Something went wrong!", e));
8.2. A readable stream with an underlying push source and backpressure support
The following function returns readable streams that wrap "backpressure sockets," which are hypothetical objects
that have the same API as web sockets, but also provide the ability to pause and resume the flow of data with their readStop and readStart methods. In doing so, this example shows how to apply backpressure to underlying sources that support it.
function makeReadableBackpressureSocketStream(host, port) {
const socket = createBackpressureSocket(host, port);
return new ReadableStream({
start(controller) {
socket.ondata = event => {
controller.enqueue(event.data);
if (controller.desiredSize <= 0) {
// The internal queue is full, so propagate
// the backpressure signal to the underlying source.
socket.readStop();
}
};
socket.onend = () => controller.close();
socket.onerror = () => controller.error(new Error("The socket errored!"));
},
pull() {
// This is called if the internal queue has been emptied, but the
// stream’s consumer still wants more data. In that case, restart
// the flow of data if we have previously paused it.
socket.readStart();
},
cancel() {
socket.close();
}
});
}
We can then use this function to create readable streams for such "backpressure sockets" in the same way we do for web sockets. This time, however, when we pipe to a destination that cannot accept data as fast as the socket is producing it, or if we leave the stream alone without reading from it for some time, a backpressure signal will be sent to the socket.
8.3. A readable byte stream with an underlying push source and backpressure support
The following function returns readable byte streams that allow efficient direct reading of TCP sockets, based on
a hypothetical JavaScript translation of the POSIX socket API (the main innovation of which is translating select(2) into an EventTarget emitting a readable event). [DOM]
This setup allows zero-copy reading directly into developer-supplied buffers. Additionally, it ensures that when data is available from the socket but not yet requested by the developer, it is enqueued in the stream’s internal queue, to avoid overflowing the kernel-space queue. In this case, an additional copy will potentially be necessary when using a BYOB reader, to move the data from the stream’s internal queue to the developer-supplied buffer. If this occurs, backpressure will immediately be applied downstream on the socket, by adjusting the TCP window size.
const DEFAULT_WINDOW_SIZE = 65536;
function makeReadableBackpressureByteSocketStream(host, port) {
const socket = createHypotheticalSelect2Socket(host, port);
return new ReadableStream({
type: "bytes",
start(controller) {
socket.setTCPWindowSize(Math.max(0, controller.desiredSize));
socket.onreadable = () => {
// Since onreadable can happen even when there’s no pending BYOB
// requests, we need to handle both cases.
if (controller.byobRequest) {
const v = controller.byobRequest.view;
const bytesRead = socket.readInto(v.buffer, v.byteOffset, v.byteLength);
controller.byobRequest.respond(bytesRead);
} else {
const buffer = new ArrayBuffer(DEFAULT_WINDOW_SIZE);
const bytesRead = socket.readInto(buffer, 0, DEFAULT_WINDOW_SIZE);
controller.enqueue(new Uint8Array(buffer, 0, bytesRead));
}
// The internal queue size has changed, so propagate
// the backpressure signal to the underlying source.
socket.setTCPWindowSize(Math.max(0, controller.desiredSize));
};
socket.onend = () => controller.close();
socket.onerror = () => controller.error(new Error("The socket errored!"));
},
pull(controller) {
// This is called when the internal queue has been drained, and the
// stream’s consumer can accept more data. Reflect the up-to-date
// backpressure level by setting the TCP receive window of the socket
// to desiredSize.
socket.setTCPWindowSize(Math.max(0, controller.desiredSize));
},
cancel() {
socket.close();
}
}, {
highWaterMark: DEFAULT_WINDOW_SIZE
});
}
ReadableStream instances returned from this function can now vend BYOB readers, with all of the
aforementioned benefits and caveats.
8.4. A readable stream with an underlying pull source
The following function returns readable streams that wrap portions of the Node.js file system API (which themselves map fairly directly to C’s fopen, fread, and fclose trio). Files are a typical example of pull
sources. Note how in contrast to the examples with push sources, most of the work here happens on-demand in the pull function, and not at startup time in the start function.
const fs = require("pr/fs"); // https://github.com/jden/pr
const CHUNK_SIZE = 1024;
function makeReadableFileStream(filename) {
let fd;
let position = 0;
return new ReadableStream({
start() {
return fs.open(filename, "r").then(result => {
fd = result;
});
},
pull(controller) {
const buffer = new ArrayBuffer(CHUNK_SIZE);
return fs.read(fd, buffer, 0, CHUNK_SIZE, position).then(bytesRead => {
if (bytesRead === 0) {
return fs.close(fd).then(() => controller.close());
} else {
position += bytesRead;
controller.enqueue(new Uint8Array(buffer, 0, bytesRead));
}
});
},
cancel() {
return fs.close(fd);
}
});
}
We can then create and use readable streams for files just as we could before for sockets.
8.5. A readable byte stream with an underlying pull source
The following function returns readable byte streams that allow efficient zero-copy reading of files, again using the Node.js file system API. Instead of using a predetermined chunk size of 1024, it attempts to fill the developer-supplied buffer, allowing full control.
const fs = require("pr/fs"); // https://github.com/jden/pr
const DEFAULT_CHUNK_SIZE = 1024;
function makeReadableByteFileStream(filename) {
let fd;
let position = 0;
return new ReadableStream({
type: "bytes",
start() {
return fs.open(filename, "r").then(result => {
fd = result;
});
},
pull(controller) {
// Even when the consumer is using the default reader, the auto-allocation
// feature allocates a buffer and passes it to us via byobRequest.
const v = controller.byobRequest.view;
return fs.read(fd, v.buffer, v.byteOffset, v.byteLength, position).then(bytesRead => {
if (bytesRead === 0) {
return fs.close(fd).then(() => controller.close());
} else {
position += bytesRead;
controller.byobRequest.respond(bytesRead);
}
});
},
cancel() {
return fs.close(fd);
},
autoAllocateChunkSize: DEFAULT_CHUNK_SIZE
});
}
With this in hand, we can create and use BYOB readers for the returned ReadableStream. But we can
also create default readers, using them in the same simple and generic manner as usual. The adaptation between
the low-level byte tracking of the underlying byte source shown here, and the higher-level chunk-based
consumption of a default reader, is all taken care of automatically by the streams implementation. The
auto-allocation feature, via the autoAllocateChunkSize option, even allows us to write less code, compared
to the manual branching in §8.3 A readable byte stream with an underlying push source and backpressure support.
8.6. A writable stream with no backpressure or success signals
The following function returns a writable stream that wraps a WebSocket [HTML]. Web sockets do not provide
any way to tell when a given chunk of data has been successfully sent, so this writable stream has no ability to
communicate backpressure signals or write success/failure to its producers. That is, it will always be in
the "writable" state, and the promise returned by its write() method will always fulfill
immediately.
function makeWritableWebSocketStream(url, protocols) {
const ws = new WebSocket(url, protocols);
return new WritableStream({
start(error) {
ws.onerror = error;
return new Promise(resolve => ws.onopen = resolve);
},
write(chunk) {
ws.send(chunk);
// Return immediately, since the web socket gives us no way to tell
// when the write completes.
},
close() {
return new Promise((resolve, reject) => {
ws.onclose = resolve;
ws.close();
});
}
});
}
We can then use this function to create writable streams for a web socket, and pipe an arbitrary readable stream to it:
const webSocketStream = makeWritableWebSocketStream("wss://example.com:443/", "protocol");
readableStream.pipeTo(webSocketStream)
.then(() => console.log("All data successfully written!"))
.catch(e => console.error("Something went wrong!", e));
8.7. A writable stream with backpressure and success signals
The following function returns writable streams that wrap portions of the io.js file system API (which themselves map fairly directly to C’s fopen, fwrite, and fclose trio). Since the API we are wrapping provides
a way to tell when a given write succeeds, this stream will be able to communicate backpressure signals as well
as whether an individual write succeeded or failed.
const fs = require("pr/fs"); // https://github.com/jden/pr
function makeWritableFileStream(filename) {
let fd;
return new WritableStream({
start() {
return fs.open(filename, "w").then(result => {
fd = result;
});
},
write(chunk) {
return fs.write(fd, chunk, 0, chunk.length);
}
close() {
return fs.close(fd);
}
});
}
We can then use this function to create a writable stream for a file, and write individual chunks of data to it:
const fileStream = makeWritableFileStream("/example/path/on/fs.txt");
fileStream.write("To stream, or not to stream\n");
fileStream.write("That is the question\n");
fileStream.close()
.then(() => console.log("chunks written and stream closed successfully!"))
.catch(e => console.error(e));
Note that if a particular call to fs.write takes a longer time, the returned promise will fulfill later.
In the meantime, additional writes can be queued up, which are stored in the stream’s internal queue. The accumulation
of chunks in this queue can move the stream into a "waiting" state, which is a signal to producers that they should back off and stop writing if possible.
The way in which the writable stream queues up writes is especially important in this case, since as stated in the documentation for fs.write, "it is unsafe to use fs.write multiple times on the same file without waiting
for the [promise]." But we don’t have to worry about that when writing the makeWritableFileStream function, since the stream implementation guarantees that the underlying sink’s write method will
not be called until any promises returned by previous calls have fulfilled!
8.8. A { readable, writable } stream pair wrapping the same underlying resource
The following function returns an object of the form { readable, writable }, with the readable property containing a readable stream and the writable property containing a
writable stream, where both streams wrap the same underlying web socket resource. In essence, this combines §8.1 A readable stream with an underlying push source (no backpressure support) and §8.6 A writable stream with no backpressure or success signals.
While doing so, it illustrates how you can use JavaScript classes to create reusable underlying sink and underlying source abstractions.
function streamifyWebSocket(url, protocol) {
const ws = new WebSocket(url, protocols);
ws.binaryType = "arraybuffer";
return {
readable: new ReadableStream(new WebSocketSource(ws)),
writable: new WritableStream(new WebSocketSink(ws))
};
}
class WebSocketSource {
constructor(ws) {
this._ws = ws;
}
start(controller) {
this._ws.onmessage = event => controller.enqueue(event.data);
this._ws.onend = () => controller.close();
this._ws.addEventListener("error", () => {
controller.error(new Error("The WebSocket errored!"));
});
}
cancel() {
this._ws.close();
}
}
class WebSocketSink {
constructor(ws) {
this._ws = ws;
}
start(error) {
this._ws.addEventListener("error", () => {
error(new Error("The WebSocket errored!"));
});
return new Promise(resolve => this._ws.onopen = resolve);
}
write(chunk) {
this._ws.send(chunk);
}
close() {
return new Promise((resolve, reject) => {
this._ws.onclose = resolve;
this._ws.close();
});
}
});
We can then use the objects created by this function to communicate with a remote web socket, using the standard stream APIs:
const streamyWS = streamifyWebSocket("wss://example.com:443/", "protocol");
streamyWS.writable.write("Hello");
streamyWS.writable.write("web socket!");
streamyWS.readable.read().then(({ value, done }) => {
console.log("The web socket says: ", value);
});
Note how in this setup canceling the readable side will implicitly close the writable side,
and similarly, closing or aborting the writable side will implicitly close the readable side.
streamyWS.readable.cancel().then(() => {
assert(streamyWS.writable.state === "closed");
});
Conventions
This specification uses algorithm conventions very similar to those of [ECMASCRIPT]. However, it deviates in the following ways, mostly for brevity. It is hoped (and vaguely planned) that eventually the conventions of ECMAScript itself will evolve in these ways.
- We use destructuring notation in function and method declarations, and assume that the destructuring assignment procedure was performed before the algorithm starts.
- We similarly use the default argument notation
= {}in a couple of cases. - We use the notation x@[[y]] to refer to internal slots of an object, instead of saying "the [[y]] internal slot of x."
- We do not alias
this to a local variable in each algorithm, instead using it directly. - We use the phrase "call-with-rethrow AbstractOperation(x, y, z)" as a shorthand
for "Let opResult be AbstractOperation(x, y, z).
ReturnIfAbrupt (opResult)." - We use the phrase "perform AbstractOperation(x, y, z)" as a shorthand for "Let opResult be AbstractOperation(x, y, z). Assert: opResult is
not an
abrupt completion ." (The ECMAScript spec seems to use "perform" this way, but does not define it.) - We use the shorthand phrases from the W3C TAG promises guide to operate on promises at a higher level than the ECMAScript spec does.
Acknowledgments
The editor would like to thank Anne van Kesteren, Ben Kelly, Brian di Palma, Calvin Metcalf, Dominic Tarr, Ed Hager, Forbes Lindesay, 贺师俊 (hax), Jake Archibald, Jens Nockert, Mangala Sadhu Sangeet Singh Khalsa, Marcos Caceres, Michael Mior, Mihai Potra, Stephen Sugden, Tab Atkins, Thorsten Lorenz, Tim Caswell, Trevor Norris, tzik, Youenn Fablet, and Xabier Rodríguez for their contributions to this specification.
Special thanks to: Bert Belder for bringing up implementation concerns that led to crucial API changes; Forrest Norvell for his work on the initial reference implementation; Gorgi Kosev for his breakthrough idea of separating piping into two methods, thus resolving a major sticking point; Isaac Schlueter for his pioneering work on JavaScript streams in Node.js; Jake Verbaten for his early involvement and support; Janessa Det for the logo; Will Chan for his help ensuring that the API allows high-performance network streaming; and 平野裕 (Yutaka Hirano) for his help with the readable stream reader design.
This standard is written by Domenic Denicola (Google, [email protected]) with substantial help from 吉野剛史 (Takeshi Yoshino, Google, [email protected]).
Per CC0, to the extent possible under law, the editor has waived all copyright and related or neighboring rights to this work.