Exploring ES2018 and ES2019
Please support this book: buy it or donate
(Ad, please don’t block.)

5. Asynchronous iteration



This chapter explains the ECMAScript proposal “Asynchronous Iteration” by Domenic Denicola and Kevin Smith.

5.1. Asynchronous iteration

With ECMAScript 6, JavaScript got built-in support for synchronously iterating over data. But what about data that is delivered asynchronously? For example, lines of text, read asynchronously from a file or an HTTP connection.

This proposal brings support for that kind of data. Before we go into it, let’s first recap synchronous iteration.

5.1.1. Synchronous iteration

Synchronous iteration was introduced with ES6 and works as follows:

I’ll demonstrate via an Array:

> const iterable = ['a', 'b'];
> const iterator = iterable[Symbol.iterator]();
> iterator.next()
{ value: 'a', done: false }
> iterator.next()
{ value: 'b', done: false }
> iterator.next()
{ value: undefined, done: true }

5.1.2. Asynchronous iteration

The problem is that the previously explained way of iterating is synchronous, it doesn’t work for asynchronous sources of data. For example, in the following code, readLinesFromFile() cannot deliver its asynchronous data via synchronous iteration:

for (const line of readLinesFromFile(fileName)) {
    console.log(line);
}

The proposal specifies a new protocol for iteration that works asynchronously:

You may wonder whether it would be possible to instead use a synchronous iterator that returns one Promise for each iterated element. But that is not enough – whether or not iteration is done is generally determined asynchronously.

Using an asynchronous iterable looks as follows. Function createAsyncIterable() is explained later. It converts its synchronously iterable parameter into an async iterable.

const asyncIterable = createAsyncIterable(['a', 'b']);
const asyncIterator = asyncIterable[Symbol.asyncIterator]();
asyncIterator.next()
.then(iterResult1 => {
    console.log(iterResult1); // { value: 'a', done: false }
    return asyncIterator.next();
})
.then(iterResult2 => {
    console.log(iterResult2); // { value: 'b', done: false }
    return asyncIterator.next();
})
.then(iterResult3 => {
    console.log(iterResult3); // { value: undefined, done: true }
});

Within an asynchronous function, you can process the results of the Promises via await and the code becomes simpler:

async function f() {
    const asyncIterable = createAsyncIterable(['a', 'b']);
    const asyncIterator = asyncIterable[Symbol.asyncIterator]();
    console.log(await asyncIterator.next());
        // { value: 'a', done: false }
    console.log(await asyncIterator.next());
        // { value: 'b', done: false }
    console.log(await asyncIterator.next());
        // { value: undefined, done: true }
}

5.1.3. The interfaces for async iteration

In TypeScript notation, the interfaces look as follows.

interface AsyncIterable {
    [Symbol.asyncIterator]() : AsyncIterator;
}
interface AsyncIterator {
    next() : Promise<IteratorResult>;
}
interface IteratorResult {
    value: any;
    done: boolean;
}

5.2. for-await-of

The proposal also specifies an asynchronous version of the for-of loop: for-await-of:

async function f() {
    for await (const x of createAsyncIterable(['a', 'b'])) {
        console.log(x);
    }
}
// Output:
// a
// b

5.2.1. for-await-of and rejections

Similarly to how await works in async functions, the loop throws an exception if next() returns a rejection:

function createRejectingIterable() {
    return {
        [Symbol.asyncIterator]() {
            return this;
        },
        next() {
            return Promise.reject(new Error('Problem!'));
        },
    };
}
(async function () { // (A)
    try {
        for await (const x of createRejectingIterable()) {
            console.log(x);
        }
    } catch (e) {
        console.error(e);
            // Error: Problem!
    }
})(); // (B)

Note that we have just used an Immediately Invoked Async Function Expression (IIAFE, pronounced “yaffee”). It starts in line (A) and ends in line (B). We need to do that because for-of-await doesn’t work at the top level of modules and scripts. It does work everywhere where await can be used. Namely, in async functions and async generators (which are explained later).

5.2.2. for-await-of and synchronous iterables

Synchronous iterables return synchronous iterators, whose method next() returns {value, done} objects. for-await-of handles synchronous iterables by converting them to asynchronous iterables. Each iterated value is converted to a Promise (or left unchanged if it already is a Promise) via Promise.resolve(). That is, for-await-of works for iterables over Promises and over normal values. The conversion looks like this:

const nextResult = Promise.resolve(valueOrPromise)
    .then(x => ({ value: x, done: false }));

Two more ways of looking at the conversion are:

Therefore, the following two statements are roughly similar.

for (const x of await Promise.all(syncIterableOverPromises));
for await (const x of syncIterableOverPromises);

The second statement is faster, because Promise.all() only creates the Promise for the Array after all Promises in syncIterableOverPromises are fulfilled. And for-of has to await that Promise. In contrast, for-await-of starts processing as soon as the first Promise is fulfilled.

5.2.3. Example: for-await-of with a sync iterable

Iterating over a sync iterable over Promises:

async function main() {
    const syncIterable = [
        Promise.resolve('a'),
        Promise.resolve('b'),
    ];
    for await (const x of syncIterable) {
        console.log(x);
    }
}
main();

// Output:
// a
// b

Iterating over a sync iterable over normal values:

async function main() {
    for await (const x of ['c', 'd']) {
        console.log(x);
    }
}
main();

// Output:
// c
// d

5.3. Asynchronous generators

Normal (synchronous) generators help with implementing synchronous iterables. Asynchronous generators do the same for asynchronous iterables.

For example, we have previously used the function createAsyncIterable(syncIterable) which converts a syncIterable into an asynchronous iterable. This is how you would implement this function via an async generator:

async function* createAsyncIterable(syncIterable) {
    for (const elem of syncIterable) {
        yield elem;
    }
}

Note the asterisk after function:

How do async generators work?

5.3.1. Queuing next() invocations

The JavaScript engine internally queues invocations of next() and feeds them to an async generator once it is ready. That is, after calling next(), you can call again, right away; you don’t have to wait for the Promise it returns to be settled. In most cases, though, you do want to wait for the settlement, because you need the value of done in order to decide whether to call next() again or not. That’s how the for-await-of loop works.

Use cases for calling next() several times without waiting for settlements include:

Use case: Retrieving Promises to be processed via Promise.all(). If you know how many elements there are in an async iterable, you don’t need to check done.

const asyncGenObj = createAsyncIterable(['a', 'b']);
const [{value:v1},{value:v2}] = await Promise.all([
    asyncGenObj.next(), asyncGenObj.next()
]);
console.log(v1, v2); // a b

Use case: Async generators as sinks for data, where you don’t always need to know when they are done.

const writer = openFile('someFile.txt');
writer.next('hello'); // don’t wait
writer.next('world'); // don’t wait
await writer.return(); // wait for file to close

Acknowledgement: Thanks to [@domenic] and [@zenparsing] for these use cases.

5.3.2. await in async generators

You can use await and for-await-of inside async generators. For example:

async function* prefixLines(asyncIterable) {
    for await (const line of asyncIterable) {
        yield '> ' + line;
    }
}

One interesting aspect of combining await and yield is that await can’t stop yield from returning a Promise, but it can stop that Promise from being settled:

async function* asyncGenerator() {
    console.log('Start');
    const result = await doSomethingAsync(); // (A)
    yield 'Result: '+result; // (B)
    console.log('Done');
}

This is the context in which this code is executed:

What does this mean for asyncGenerator()?

That means that line A and B correspond (roughly) to this code:

doSomethingAsync()
.then(result => {
    const {resolve} = promiseQueue.dequeue();
    resolve({
        value: 'Result: '+result,
        done: false,
    });
});

If you want to dig deeper – this is a rough approximation of how async generators work:

const BUSY = Symbol('BUSY');
const COMPLETED = Symbol('COMPLETED');
function asyncGenerator() {
  const settlers = [];
  let step = 0;
  return {
    [Symbol.asyncIterator]() {
      return this;
    },
    next() {
      return new Promise((resolve, reject) => {
        settlers.push({resolve, reject});
        this._run();
      });
    }
    _run() {
      setTimeout(() => {
        if (step === BUSY || settlers.length === 0) {
          return;
        }
        const currentSettler = settlers.shift();
        try {
          switch (step) {
            case 0:
              step = BUSY;
              console.log('Start');
              doSomethingAsync()
              .then(result => {
                currentSettler.resolve({
                  value: 'Result: '+result,
                  done: false,
                });
                // We are not busy, anymore
                step = 1;
                this._run();
              })
              .catch(e => currentSettler.reject(e));
              break;
            case 1:
              console.log('Done');
              currentSettler.resolve({
                value: undefined,
                done: true,
              });
              step = COMPLETED;
              this._run();
              break;
            case COMPLETED:
              currentSettler.resolve({
                value: undefined,
                done: true,
              });
              this._run();
              break;
          }
        }
        catch (e) {
          currentSettler.reject(e);
        }
      }, 0);
    }
  }
}

This code assumes that next() is always called without arguments. A complete implementation would have to queue arguments, too.

5.3.3. yield* in async generators

yield* in async generators works analogously to how it works in normal generators – like a recursive invocation:

async function* gen1() {
    yield 'a';
    yield 'b';
    return 2;
}
async function* gen2() {
    const result = yield* gen1(); // (A)
        // result === 2
}

In line (A), gen2() calls gen1(), which means that all elements yielded by gen1() are yielded by gen2():

(async function () {
    for await (const x of gen2()) {
        console.log(x);
    }
})();
// Output:
// a
// b

The operand of yield* can be any async iterable. Sync iterables are automatically converted to async iterables, just like with for-await-of.

5.3.4. Errors

In normal generators, next() can throw exceptions. In async generators, next() can reject the Promise it returns:

async function* asyncGenerator() {
    // The following exception is converted to a rejection
    throw new Error('Problem!');
}
asyncGenerator().next()
.catch(err => console.log(err)); // Error: Problem!

Converting exceptions to rejections is similar to how async functions work.

5.3.5. Async function vs. async generator function

Async function:

(async function () {
    return 'hello';
})()
.then(x => console.log(x)); // hello

(async function () {
    throw new Error('Problem!');
})()
.catch(x => console.error(x)); // Error: Problem!

Async generator function:

async function* gen() {
    yield 'hello';
}
const genObj = gen();
genObj.next().then(x => console.log(x));
    // { value: 'hello', done: false }

5.4. Examples

The source code for the examples is available via the repository async-iter-demo on GitHub.

5.4.1. Using asynchronous iteration via Babel

The example repo uses babel-node to run its code. This is how it configures Babel in its package.json:

{
  "dependencies": {
    "babel-preset-env": "···",
    "babel-plugin-transform-async-generator-functions": "···",
    ···
  },
  "babel": {
    "presets": [
      [
        "env",
        {
          "targets": {
            "node": "current"
          }
        }
      ]
    ],
    "plugins": [
      "transform-async-generator-functions"
    ]
  },
  ···
}

5.4.2. Example: turning an async iterable into an Array

Function takeAsync() collects all elements of asyncIterable in an Array. I don’t use for-await-of in this case, I invoke the async iteration protocol manually. I also don’t close asyncIterable if I’m finished before the iterable is done.

/**
 * @returns a Promise for an Array with the elements
 * in `asyncIterable`
 */
async function takeAsync(asyncIterable, count=Infinity) {
    const result = [];
    const iterator = asyncIterable[Symbol.asyncIterator]();
    while (result.length < count) {
        const {value,done} = await iterator.next();
        if (done) break;
        result.push(value);
    }
    return result;
}

This is the test for takeAsync():

test('Collect values yielded by an async generator', async function() {
    async function* gen() {
        yield 'a';
        yield 'b';
        yield 'c';
    }

    assert.deepStrictEqual(await takeAsync(gen()), ['a', 'b', 'c']);
    assert.deepStrictEqual(await takeAsync(gen(), 3), ['a', 'b', 'c']);
    assert.deepStrictEqual(await takeAsync(gen(), 2), ['a', 'b']);
    assert.deepStrictEqual(await takeAsync(gen(), 1), ['a']);
    assert.deepStrictEqual(await takeAsync(gen(), 0), []);
});

Note how nicely async functions work together with the mocha test framework: for asynchronous tests, the second parameter of test() can return a Promise.

5.4.3. Example: a queue as an async iterable

The example repo also has an implementation for an asynchronous queue, called AsyncQueue. Its implementation is relatively complex, which is why I don’t show it here. This is the test for AsyncQueue:

test('Enqueue before dequeue', async function() {
    const queue = new AsyncQueue();
    queue.enqueue('a');
    queue.enqueue('b');
    queue.close();
    assert.deepStrictEqual(await takeAsync(queue), ['a', 'b']);
});
test('Dequeue before enqueue', async function() {
    const queue = new AsyncQueue();
    const promise = Promise.all([queue.next(), queue.next()]);
    queue.enqueue('a');
    queue.enqueue('b');
    return promise.then(arr => {
        const values = arr.map(x => x.value);
        assert.deepStrictEqual(values, ['a', 'b']);
    });
});

5.4.4. Example: reading text lines asynchronously

Let’s implement code that reads text lines asynchronously. We’ll do it in three steps.

Step 1: read text data in chunks via the Node.js ReadStream API (which is based on callbacks) and push it into an AsyncQueue (which was introduced in the previous section).

/**
 * Creates an asynchronous ReadStream for the file whose name
 * is `fileName` and feeds it into an AsyncQueue that it returns.
 *
 * @returns an async iterable
 */
function readFile(fileName) {
    const queue = new AsyncQueue();
    const readStream = createReadStream(fileName,
        { encoding: 'utf8', bufferSize: 1024 });
    readStream.on('data', buffer => {
        const str = buffer.toString('utf8');
        queue.enqueue(str);
    });
    readStream.on('end', () => {
        // Signal end of output sequence
        queue.close();
    });
    return queue;
}

Step 2: Use for-await-of to iterate over the chunks of text and yield lines of text.

/**
 * Turns a sequence of text chunks into a sequence of lines
 * (where lines are separated by newlines)
 *
 * @returns an async iterable
 */
async function* splitLines(chunksAsync) {
    let previous = '';
    for await (const chunk of chunksAsync) {
        previous += chunk;
        let eolIndex;
        while ((eolIndex = previous.indexOf('\n')) >= 0) {
            const line = previous.slice(0, eolIndex);
            yield line;
            previous = previous.slice(eolIndex+1);
        }
    }
    if (previous.length > 0) {
        yield previous;
    }
}

Step 3: combine the two previous functions. We first feed chunks of text into a queue via readFile() and then convert that queue into an async iterable over lines of text via splitLines().

/**
 * @returns an async iterable
 */
function readLines(fileName) {
    // `queue` is an async iterable
    const queue = readFile(fileName);
    return splitLines(queue);
}

Lastly, this is how you’d use readLines() from within a Node.js script:

(async function () {
    const fileName = process.argv[2];
    for await (const line of readLines(fileName)) {
        console.log('>', line);
    }
})();

5.5. WHATWG Streams are async iterables

WHATWG streams are async iterables, meaning that you can use for-await-of to process them:

const rs = openReadableStream();
for await (const chunk of rs) {
    ···
}

5.6. The specification of asynchronous iteration

The spec introduces several new concepts and entities:

No new global variables are introduced by this feature.

5.6.1. Async generators

If you want to understand how async generators work, it’s best to start with Sect. “AsyncGenerator Abstract Operations”. The key to understanding async generators is understanding how queuing works.

Two internal properties of async generator objects play important roles w.r.t. queuing:

The queue is managed mainly via two operations:

5.6.2. Async-from-Sync Iterator Objects

To get an async iterator from an object iterable, you call GetIterator(iterable, async) (async is a symbol). If iterable doesn’t have a method [Symbol.asyncIterator](), GetIterator() retrieves a sync iterator via method iterable[Symbol.iterator]() and converts it to an async iterator via CreateAsyncFromSyncIterator().

5.6.3. The for-await-of loop

for-await-of works almost exactly like for-of, but there is an await whenever the contents of an IteratorResult are accessed. You can see that by looking at Sect. “Runtime Semantics: ForIn/OfBodyEvaluation”. Notably, iterators are closed similarly, via IteratorClose(), towards the end of this section.

5.7. Alternatives to async iteration

Let’s look at two alternatives to async iteration for processing async data.

5.7.1. Alternative 1: Communicating Sequential Processes (CSP)

The following code demonstrates the CSP library js-csp:

var csp = require('js-csp');

function* player(name, table) {
  while (true) {
    var ball = yield csp.take(table); // dequeue
    if (ball === csp.CLOSED) {
      console.log(name + ": table's gone");
      return;
    }
    ball.hits += 1;
    console.log(name + " " + ball.hits);
    yield csp.timeout(100); // wait
    yield csp.put(table, ball); // enqueue
  }
}

csp.go(function* () {
  var table = csp.chan(); // (A)

  csp.go(player, ["ping", table]); // (B)
  csp.go(player, ["pong", table]); // (C)

  yield csp.put(table, {hits: 0}); // enqueue
  yield csp.timeout(1000); // wait
  table.close();
});

player defines a “process” that is instantiated twice (in line (B) and in line (C), via csp.go()). The processes are connected via the “channel” table, which is created in line (A) and passed to player via its second parameter. A channel is basically a queue.

How does CSP compare to async iteration?

5.7.2. Alternative 2: Reactive Programming

The following code demonstrates Reactive Programming via the JavaScript library RxJS:

const button = document.querySelector('button');
Rx.Observable.fromEvent(button, 'click') // (A)
  .throttle(1000) // at most one event per second
  .scan(count => count + 1, 0)
  .subscribe(count => console.log(`Clicked ${count} times`));

In line (A), we create a stream of click events via fromEvent(). These events are then filtered so that there is at most one event per second. Every time there is an event, scan() counts how many events there have been, so far. In the last line, we log all counts.

How does Reactive Programming compare to async iteration?

There is an ECMAScript proposal for Reactive Programming, called “Observable” (by Jafar Husain).

5.8. Further reading

Background: