/*--------------------------------------------------------------------------------------------- * Copyright (c) Microsoft Corporation. All rights reserved. * Licensed under the MIT License. See License.txt in the project root for license information. *--------------------------------------------------------------------------------------------*/ import { CancellationToken, CancellationTokenSource } from 'vs/base/common/cancellation'; import * as errors from 'vs/base/common/errors'; import { Emitter, Event } from 'vs/base/common/event'; import { IDisposable, toDisposable } from 'vs/base/common/lifecycle'; import { URI } from 'vs/base/common/uri'; export function isThenable(obj: any): obj is Promise { return obj && typeof (>obj).then === 'function'; } export interface CancelablePromise extends Promise { cancel(): void; } export function createCancelablePromise(callback: (token: CancellationToken) => Promise): CancelablePromise { const source = new CancellationTokenSource(); const thenable = callback(source.token); const promise = new Promise((resolve, reject) => { source.token.onCancellationRequested(() => { reject(errors.canceled()); }); Promise.resolve(thenable).then(value => { source.dispose(); resolve(value); }, err => { source.dispose(); reject(err); }); }); return >new class { cancel() { source.cancel(); } then(resolve?: ((value: T) => TResult1 | Promise) | undefined | null, reject?: ((reason: any) => TResult2 | Promise) | undefined | null): Promise { return promise.then(resolve, reject); } catch(reject?: ((reason: any) => TResult | Promise) | undefined | null): Promise { return this.then(undefined, reject); } finally(onfinally?: (() => void) | undefined | null): Promise { return promise.finally(onfinally); } }; } export function raceCancellation(promise: Promise, token: CancellationToken): Promise; export function raceCancellation(promise: Promise, token: CancellationToken, defaultValue: T): Promise; export function raceCancellation(promise: Promise, token: CancellationToken, defaultValue?: T): Promise { return Promise.race([promise, new Promise(resolve => token.onCancellationRequested(() => resolve(defaultValue)))]); } /** * Returns as soon as one of the promises is resolved and cancels remaining promises */ export async function raceCancellablePromises(cancellablePromises: CancelablePromise[]): Promise { let resolvedPromiseIndex = -1; const promises = cancellablePromises.map((promise, index) => promise.then(result => { resolvedPromiseIndex = index; return result; })); const result = await Promise.race(promises); cancellablePromises.forEach((cancellablePromise, index) => { if (index !== resolvedPromiseIndex) { cancellablePromise.cancel(); } }); return result; } export function raceTimeout(promise: Promise, timeout: number, onTimeout?: () => void): Promise { let promiseResolve: ((value: T | undefined) => void) | undefined = undefined; const timer = setTimeout(() => { promiseResolve?.(undefined); onTimeout?.(); }, timeout); return Promise.race([ promise.finally(() => clearTimeout(timer)), new Promise(resolve => promiseResolve = resolve) ]); } export function asPromise(callback: () => T | Thenable): Promise { return new Promise((resolve, reject) => { const item = callback(); if (isThenable(item)) { item.then(resolve, reject); } else { resolve(item); } }); } export interface ITask { (): T; } /** * A helper to prevent accumulation of sequential async tasks. * * Imagine a mail man with the sole task of delivering letters. As soon as * a letter submitted for delivery, he drives to the destination, delivers it * and returns to his base. Imagine that during the trip, N more letters were submitted. * When the mail man returns, he picks those N letters and delivers them all in a * single trip. Even though N+1 submissions occurred, only 2 deliveries were made. * * The throttler implements this via the queue() method, by providing it a task * factory. Following the example: * * const throttler = new Throttler(); * const letters = []; * * function deliver() { * const lettersToDeliver = letters; * letters = []; * return makeTheTrip(lettersToDeliver); * } * * function onLetterReceived(l) { * letters.push(l); * throttler.queue(deliver); * } */ export class Throttler { private activePromise: Promise | null; private queuedPromise: Promise | null; private queuedPromiseFactory: ITask> | null; constructor() { this.activePromise = null; this.queuedPromise = null; this.queuedPromiseFactory = null; } queue(promiseFactory: ITask>): Promise { if (this.activePromise) { this.queuedPromiseFactory = promiseFactory; if (!this.queuedPromise) { const onComplete = () => { this.queuedPromise = null; const result = this.queue(this.queuedPromiseFactory!); this.queuedPromiseFactory = null; return result; }; this.queuedPromise = new Promise(resolve => { this.activePromise!.then(onComplete, onComplete).then(resolve); }); } return new Promise((resolve, reject) => { this.queuedPromise!.then(resolve, reject); }); } this.activePromise = promiseFactory(); return new Promise((resolve, reject) => { this.activePromise!.then((result: any) => { this.activePromise = null; resolve(result); }, (err: any) => { this.activePromise = null; reject(err); }); }); } } export class Sequencer { private current: Promise = Promise.resolve(null); queue(promiseTask: ITask>): Promise { return this.current = this.current.then(() => promiseTask(), () => promiseTask()); } } export class SequencerByKey { private promiseMap = new Map>(); queue(key: TKey, promiseTask: ITask>): Promise { const runningPromise = this.promiseMap.get(key) ?? Promise.resolve(); const newPromise = runningPromise .catch(() => { }) .then(promiseTask) .finally(() => { if (this.promiseMap.get(key) === newPromise) { this.promiseMap.delete(key); } }); this.promiseMap.set(key, newPromise); return newPromise; } } /** * A helper to delay (debounce) execution of a task that is being requested often. * * Following the throttler, now imagine the mail man wants to optimize the number of * trips proactively. The trip itself can be long, so he decides not to make the trip * as soon as a letter is submitted. Instead he waits a while, in case more * letters are submitted. After said waiting period, if no letters were submitted, he * decides to make the trip. Imagine that N more letters were submitted after the first * one, all within a short period of time between each other. Even though N+1 * submissions occurred, only 1 delivery was made. * * The delayer offers this behavior via the trigger() method, into which both the task * to be executed and the waiting period (delay) must be passed in as arguments. Following * the example: * * const delayer = new Delayer(WAITING_PERIOD); * const letters = []; * * function letterReceived(l) { * letters.push(l); * delayer.trigger(() => { return makeTheTrip(); }); * } */ export class Delayer implements IDisposable { private timeout: any; private completionPromise: Promise | null; private doResolve: ((value?: any | Promise) => void) | null; private doReject: ((err: any) => void) | null; private task: ITask> | null; constructor(public defaultDelay: number) { this.timeout = null; this.completionPromise = null; this.doResolve = null; this.doReject = null; this.task = null; } trigger(task: ITask>, delay: number = this.defaultDelay): Promise { this.task = task; this.cancelTimeout(); if (!this.completionPromise) { this.completionPromise = new Promise((resolve, reject) => { this.doResolve = resolve; this.doReject = reject; }).then(() => { this.completionPromise = null; this.doResolve = null; if (this.task) { const task = this.task; this.task = null; return task(); } return undefined; }); } this.timeout = setTimeout(() => { this.timeout = null; if (this.doResolve) { this.doResolve(null); } }, delay); return this.completionPromise; } isTriggered(): boolean { return this.timeout !== null; } cancel(): void { this.cancelTimeout(); if (this.completionPromise) { if (this.doReject) { this.doReject(errors.canceled()); } this.completionPromise = null; } } private cancelTimeout(): void { if (this.timeout !== null) { clearTimeout(this.timeout); this.timeout = null; } } dispose(): void { this.cancelTimeout(); } } /** * A helper to delay execution of a task that is being requested often, while * preventing accumulation of consecutive executions, while the task runs. * * The mail man is clever and waits for a certain amount of time, before going * out to deliver letters. While the mail man is going out, more letters arrive * and can only be delivered once he is back. Once he is back the mail man will * do one more trip to deliver the letters that have accumulated while he was out. */ export class ThrottledDelayer { private delayer: Delayer>; private throttler: Throttler; constructor(defaultDelay: number) { this.delayer = new Delayer(defaultDelay); this.throttler = new Throttler(); } trigger(promiseFactory: ITask>, delay?: number): Promise { return this.delayer.trigger(() => this.throttler.queue(promiseFactory), delay) as any as Promise; } isTriggered(): boolean { return this.delayer.isTriggered(); } cancel(): void { this.delayer.cancel(); } dispose(): void { this.delayer.dispose(); } } /** * A barrier that is initially closed and then becomes opened permanently. */ export class Barrier { private _isOpen: boolean; private _promise: Promise; private _completePromise!: (v: boolean) => void; constructor() { this._isOpen = false; this._promise = new Promise((c, e) => { this._completePromise = c; }); } isOpen(): boolean { return this._isOpen; } open(): void { this._isOpen = true; this._completePromise(true); } wait(): Promise { return this._promise; } } export function timeout(millis: number): CancelablePromise; export function timeout(millis: number, token: CancellationToken): Promise; export function timeout(millis: number, token?: CancellationToken): CancelablePromise | Promise { if (!token) { return createCancelablePromise(token => timeout(millis, token)); } return new Promise((resolve, reject) => { const handle = setTimeout(resolve, millis); token.onCancellationRequested(() => { clearTimeout(handle); reject(errors.canceled()); }); }); } export function disposableTimeout(handler: () => void, timeout = 0): IDisposable { const timer = setTimeout(handler, timeout); return toDisposable(() => clearTimeout(timer)); } export function ignoreErrors(promise: Promise): Promise { return promise.then(undefined, _ => undefined); } /** * Runs the provided list of promise factories in sequential order. The returned * promise will complete to an array of results from each promise. */ export function sequence(promiseFactories: ITask>[]): Promise { const results: T[] = []; let index = 0; const len = promiseFactories.length; function next(): Promise | null { return index < len ? promiseFactories[index++]() : null; } function thenHandler(result: any): Promise { if (result !== undefined && result !== null) { results.push(result); } const n = next(); if (n) { return n.then(thenHandler); } return Promise.resolve(results); } return Promise.resolve(null).then(thenHandler); } export function first(promiseFactories: ITask>[], shouldStop: (t: T) => boolean = t => !!t, defaultValue: T | null = null): Promise { let index = 0; const len = promiseFactories.length; const loop: () => Promise = () => { if (index >= len) { return Promise.resolve(defaultValue); } const factory = promiseFactories[index++]; const promise = Promise.resolve(factory()); return promise.then(result => { if (shouldStop(result)) { return Promise.resolve(result); } return loop(); }); }; return loop(); } /** * Returns the result of the first promise that matches the "shouldStop", * running all promises in parallel. Supports cancelable promises. */ export function firstParallel(promiseList: Promise[], shouldStop?: (t: T) => boolean, defaultValue?: T | null): Promise; export function firstParallel(promiseList: Promise[], shouldStop: (t: T) => t is R, defaultValue?: R | null): Promise; export function firstParallel(promiseList: Promise[], shouldStop: (t: T) => boolean = t => !!t, defaultValue: T | null = null) { if (promiseList.length === 0) { return Promise.resolve(defaultValue); } let todo = promiseList.length; const finish = () => { todo = -1; for (const promise of promiseList) { (promise as Partial>).cancel?.(); } }; return new Promise((resolve, reject) => { for (const promise of promiseList) { promise.then(result => { if (--todo >= 0 && shouldStop(result)) { finish(); resolve(result); } else if (todo === 0) { resolve(defaultValue); } }) .catch(err => { if (--todo >= 0) { finish(); reject(err); } }); } }); } interface ILimitedTaskFactory { factory: ITask>; c: (value: T | Promise) => void; e: (error?: any) => void; } /** * A helper to queue N promises and run them all with a max degree of parallelism. The helper * ensures that at any time no more than M promises are running at the same time. */ export class Limiter { private _size = 0; private runningPromises: number; private maxDegreeOfParalellism: number; private outstandingPromises: ILimitedTaskFactory[]; private readonly _onFinished: Emitter; constructor(maxDegreeOfParalellism: number) { this.maxDegreeOfParalellism = maxDegreeOfParalellism; this.outstandingPromises = []; this.runningPromises = 0; this._onFinished = new Emitter(); } get onFinished(): Event { return this._onFinished.event; } get size(): number { return this._size; // return this.runningPromises + this.outstandingPromises.length; } queue(factory: ITask>): Promise { this._size++; return new Promise((c, e) => { this.outstandingPromises.push({ factory, c, e }); this.consume(); }); } private consume(): void { while (this.outstandingPromises.length && this.runningPromises < this.maxDegreeOfParalellism) { const iLimitedTask = this.outstandingPromises.shift()!; this.runningPromises++; const promise = iLimitedTask.factory(); promise.then(iLimitedTask.c, iLimitedTask.e); promise.then(() => this.consumed(), () => this.consumed()); } } private consumed(): void { this._size--; this.runningPromises--; if (this.outstandingPromises.length > 0) { this.consume(); } else { this._onFinished.fire(); } } dispose(): void { this._onFinished.dispose(); } } /** * A queue is handles one promise at a time and guarantees that at any time only one promise is executing. */ export class Queue extends Limiter { constructor() { super(1); } } /** * A helper to organize queues per resource. The ResourceQueue makes sure to manage queues per resource * by disposing them once the queue is empty. */ export class ResourceQueue implements IDisposable { private readonly queues = new Map>(); queueFor(resource: URI): Queue { const key = resource.toString(); if (!this.queues.has(key)) { const queue = new Queue(); queue.onFinished(() => { queue.dispose(); this.queues.delete(key); }); this.queues.set(key, queue); } return this.queues.get(key)!; } dispose(): void { this.queues.forEach(queue => queue.dispose()); this.queues.clear(); } } export class TimeoutTimer implements IDisposable { private _token: any; constructor(); constructor(runner: () => void, timeout: number); constructor(runner?: () => void, timeout?: number) { this._token = -1; if (typeof runner === 'function' && typeof timeout === 'number') { this.setIfNotSet(runner, timeout); } } dispose(): void { this.cancel(); } cancel(): void { if (this._token !== -1) { clearTimeout(this._token); this._token = -1; } } cancelAndSet(runner: () => void, timeout: number): void { this.cancel(); this._token = setTimeout(() => { this._token = -1; runner(); }, timeout); } setIfNotSet(runner: () => void, timeout: number): void { if (this._token !== -1) { // timer is already set return; } this._token = setTimeout(() => { this._token = -1; runner(); }, timeout); } } export class IntervalTimer implements IDisposable { private _token: any; constructor() { this._token = -1; } dispose(): void { this.cancel(); } cancel(): void { if (this._token !== -1) { clearInterval(this._token); this._token = -1; } } cancelAndSet(runner: () => void, interval: number): void { this.cancel(); this._token = setInterval(() => { runner(); }, interval); } } export class RunOnceScheduler { protected runner: ((...args: any[]) => void) | null; private timeoutToken: any; private timeout: number; private timeoutHandler: () => void; constructor(runner: (...args: any[]) => void, delay: number) { this.timeoutToken = -1; this.runner = runner; this.timeout = delay; this.timeoutHandler = this.onTimeout.bind(this); } /** * Dispose RunOnceScheduler */ dispose(): void { this.cancel(); this.runner = null; } /** * Cancel current scheduled runner (if any). */ cancel(): void { if (this.isScheduled()) { clearTimeout(this.timeoutToken); this.timeoutToken = -1; } } /** * Cancel previous runner (if any) & schedule a new runner. */ schedule(delay = this.timeout): void { this.cancel(); this.timeoutToken = setTimeout(this.timeoutHandler, delay); } get delay(): number { return this.timeout; } set delay(value: number) { this.timeout = value; } /** * Returns true if scheduled. */ isScheduled(): boolean { return this.timeoutToken !== -1; } private onTimeout() { this.timeoutToken = -1; if (this.runner) { this.doRun(); } } protected doRun(): void { if (this.runner) { this.runner(); } } } export class RunOnceWorker extends RunOnceScheduler { private units: T[] = []; constructor(runner: (units: T[]) => void, timeout: number) { super(runner, timeout); } work(unit: T): void { this.units.push(unit); if (!this.isScheduled()) { this.schedule(); } } protected doRun(): void { const units = this.units; this.units = []; if (this.runner) { this.runner(units); } } dispose(): void { this.units = []; super.dispose(); } } //#region -- run on idle tricks ------------ export interface IdleDeadline { readonly didTimeout: boolean; timeRemaining(): number; } /** * Execute the callback the next time the browser is idle */ export let runWhenIdle: (callback: (idle: IdleDeadline) => void, timeout?: number) => IDisposable; declare function requestIdleCallback(callback: (args: IdleDeadline) => void, options?: { timeout: number }): number; declare function cancelIdleCallback(handle: number): void; (function () { if (typeof requestIdleCallback !== 'function' || typeof cancelIdleCallback !== 'function') { const dummyIdle: IdleDeadline = Object.freeze({ didTimeout: true, timeRemaining() { return 15; } }); runWhenIdle = (runner) => { const handle = setTimeout(() => runner(dummyIdle)); let disposed = false; return { dispose() { if (disposed) { return; } disposed = true; clearTimeout(handle); } }; }; } else { runWhenIdle = (runner, timeout?) => { const handle: number = requestIdleCallback(runner, typeof timeout === 'number' ? { timeout } : undefined); let disposed = false; return { dispose() { if (disposed) { return; } disposed = true; cancelIdleCallback(handle); } }; }; } })(); /** * An implementation of the "idle-until-urgent"-strategy as introduced * here: https://philipwalton.com/articles/idle-until-urgent/ */ export class IdleValue { private readonly _executor: () => void; private readonly _handle: IDisposable; private _didRun: boolean = false; private _value?: T; private _error: any; constructor(executor: () => T) { this._executor = () => { try { this._value = executor(); } catch (err) { this._error = err; } finally { this._didRun = true; } }; this._handle = runWhenIdle(() => this._executor()); } dispose(): void { this._handle.dispose(); } get value(): T { if (!this._didRun) { this._handle.dispose(); this._executor(); } if (this._error) { throw this._error; } return this._value!; } } //#endregion export async function retry(task: ITask>, delay: number, retries: number): Promise { let lastError: Error | undefined; for (let i = 0; i < retries; i++) { try { return await task(); } catch (error) { lastError = error; await timeout(delay); } } throw lastError; } //#region Task Sequentializer interface IPendingTask { taskId: number; cancel: () => void; promise: Promise; } interface ISequentialTask { promise: Promise; promiseResolve: () => void; promiseReject: (error: Error) => void; run: () => Promise; } export interface ITaskSequentializerWithPendingTask { readonly pending: Promise; } export class TaskSequentializer { private _pending?: IPendingTask; private _next?: ISequentialTask; hasPending(taskId?: number): this is ITaskSequentializerWithPendingTask { if (!this._pending) { return false; } if (typeof taskId === 'number') { return this._pending.taskId === taskId; } return !!this._pending; } get pending(): Promise | undefined { return this._pending ? this._pending.promise : undefined; } cancelPending(): void { this._pending?.cancel(); } setPending(taskId: number, promise: Promise, onCancel?: () => void,): Promise { this._pending = { taskId: taskId, cancel: () => onCancel?.(), promise }; promise.then(() => this.donePending(taskId), () => this.donePending(taskId)); return promise; } private donePending(taskId: number): void { if (this._pending && taskId === this._pending.taskId) { // only set pending to done if the promise finished that is associated with that taskId this._pending = undefined; // schedule the next task now that we are free if we have any this.triggerNext(); } } private triggerNext(): void { if (this._next) { const next = this._next; this._next = undefined; // Run next task and complete on the associated promise next.run().then(next.promiseResolve, next.promiseReject); } } setNext(run: () => Promise): Promise { // this is our first next task, so we create associated promise with it // so that we can return a promise that completes when the task has // completed. if (!this._next) { let promiseResolve: () => void; let promiseReject: (error: Error) => void; const promise = new Promise((resolve, reject) => { promiseResolve = resolve; promiseReject = reject; }); this._next = { run, promise, promiseResolve: promiseResolve!, promiseReject: promiseReject! }; } // we have a previous next task, just overwrite it else { this._next.run = run; } return this._next.promise; } } //#endregion //#region /** * The `IntervalCounter` allows to count the number * of calls to `increment()` over a duration of * `interval`. This utility can be used to conditionally * throttle a frequent task when a certain threshold * is reached. */ export class IntervalCounter { private lastIncrementTime = 0; private value = 0; constructor(private readonly interval: number) { } increment(): number { const now = Date.now(); // We are outside of the range of `interval` and as such // start counting from 0 and remember the time if (now - this.lastIncrementTime > this.interval) { this.lastIncrementTime = now; this.value = 0; } this.value++; return this.value; } } //#endregion export type ValueCallback = (value: T | Promise) => void; /** * Creates a promise whose resolution or rejection can be controlled imperatively. */ export class DeferredPromise { private completeCallback!: ValueCallback; private errorCallback!: (err: any) => void; private rejected = false; private resolved = false; public get isRejected() { return this.rejected; } public get isResolved() { return this.resolved; } public get isSettled() { return this.rejected || this.resolved; } public p: Promise; constructor() { this.p = new Promise((c, e) => { this.completeCallback = c; this.errorCallback = e; }); } public complete(value: T) { return new Promise(resolve => { this.completeCallback(value); this.resolved = true; resolve(); }); } public error(err: any) { return new Promise(resolve => { this.errorCallback(err); this.rejected = true; resolve(); }); } public cancel() { new Promise(resolve => { this.errorCallback(errors.canceled()); this.rejected = true; resolve(); }); } }