| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376 | 
							- 'use strict';
 
- Object.defineProperty(exports, "__esModule", {
 
-   value: true
 
- });
 
- var _child_process = require('child_process');
 
- var _child_process2 = _interopRequireDefault(_child_process);
 
- var _queue = require('neo-async/queue');
 
- var _queue2 = _interopRequireDefault(_queue);
 
- var _mapSeries = require('neo-async/mapSeries');
 
- var _mapSeries2 = _interopRequireDefault(_mapSeries);
 
- var _readBuffer = require('./readBuffer');
 
- var _readBuffer2 = _interopRequireDefault(_readBuffer);
 
- var _WorkerError = require('./WorkerError');
 
- var _WorkerError2 = _interopRequireDefault(_WorkerError);
 
- function _interopRequireDefault(obj) { return obj && obj.__esModule ? obj : { default: obj }; }
 
- const workerPath = require.resolve('./worker'); /* eslint-disable no-console */
 
- let workerId = 0;
 
- class PoolWorker {
 
-   constructor(options, onJobDone) {
 
-     this.disposed = false;
 
-     this.nextJobId = 0;
 
-     this.jobs = Object.create(null);
 
-     this.activeJobs = 0;
 
-     this.onJobDone = onJobDone;
 
-     this.id = workerId;
 
-     workerId += 1;
 
-     // Empty or invalid node args would break the child process
 
-     const sanitizedNodeArgs = (options.nodeArgs || []).filter(opt => !!opt);
 
-     this.worker = _child_process2.default.spawn(process.execPath, [].concat(sanitizedNodeArgs).concat(workerPath, options.parallelJobs), {
 
-       detached: true,
 
-       stdio: ['ignore', 'pipe', 'pipe', 'pipe', 'pipe']
 
-     });
 
-     this.worker.unref();
 
-     // This prevents a problem where the worker stdio can be undefined
 
-     // when the kernel hits the limit of open files.
 
-     // More info can be found on: https://github.com/webpack-contrib/thread-loader/issues/2
 
-     if (!this.worker.stdio) {
 
-       throw new Error(`Failed to create the worker pool with workerId: ${workerId} and ${''}configuration: ${JSON.stringify(options)}. Please verify if you hit the OS open files limit.`);
 
-     }
 
-     const [,,, readPipe, writePipe] = this.worker.stdio;
 
-     this.readPipe = readPipe;
 
-     this.writePipe = writePipe;
 
-     this.listenStdOutAndErrFromWorker(this.worker.stdout, this.worker.stderr);
 
-     this.readNextMessage();
 
-   }
 
-   listenStdOutAndErrFromWorker(workerStdout, workerStderr) {
 
-     if (workerStdout) {
 
-       workerStdout.on('data', this.writeToStdout);
 
-     }
 
-     if (workerStderr) {
 
-       workerStderr.on('data', this.writeToStderr);
 
-     }
 
-   }
 
-   ignoreStdOutAndErrFromWorker(workerStdout, workerStderr) {
 
-     if (workerStdout) {
 
-       workerStdout.removeListener('data', this.writeToStdout);
 
-     }
 
-     if (workerStderr) {
 
-       workerStderr.removeListener('data', this.writeToStderr);
 
-     }
 
-   }
 
-   writeToStdout(data) {
 
-     if (!this.disposed) {
 
-       process.stdout.write(data);
 
-     }
 
-   }
 
-   writeToStderr(data) {
 
-     if (!this.disposed) {
 
-       process.stderr.write(data);
 
-     }
 
-   }
 
-   run(data, callback) {
 
-     const jobId = this.nextJobId;
 
-     this.nextJobId += 1;
 
-     this.jobs[jobId] = { data, callback };
 
-     this.activeJobs += 1;
 
-     this.writeJson({
 
-       type: 'job',
 
-       id: jobId,
 
-       data
 
-     });
 
-   }
 
-   warmup(requires) {
 
-     this.writeJson({
 
-       type: 'warmup',
 
-       requires
 
-     });
 
-   }
 
-   writeJson(data) {
 
-     const lengthBuffer = Buffer.alloc(4);
 
-     const messageBuffer = Buffer.from(JSON.stringify(data), 'utf-8');
 
-     lengthBuffer.writeInt32BE(messageBuffer.length, 0);
 
-     this.writePipe.write(lengthBuffer);
 
-     this.writePipe.write(messageBuffer);
 
-   }
 
-   writeEnd() {
 
-     const lengthBuffer = Buffer.alloc(4);
 
-     lengthBuffer.writeInt32BE(0, 0);
 
-     this.writePipe.write(lengthBuffer);
 
-   }
 
-   readNextMessage() {
 
-     this.state = 'read length';
 
-     this.readBuffer(4, (lengthReadError, lengthBuffer) => {
 
-       if (lengthReadError) {
 
-         console.error(`Failed to communicate with worker (read length) ${lengthReadError}`);
 
-         return;
 
-       }
 
-       this.state = 'length read';
 
-       const length = lengthBuffer.readInt32BE(0);
 
-       this.state = 'read message';
 
-       this.readBuffer(length, (messageError, messageBuffer) => {
 
-         if (messageError) {
 
-           console.error(`Failed to communicate with worker (read message) ${messageError}`);
 
-           return;
 
-         }
 
-         this.state = 'message read';
 
-         const messageString = messageBuffer.toString('utf-8');
 
-         const message = JSON.parse(messageString);
 
-         this.state = 'process message';
 
-         this.onWorkerMessage(message, err => {
 
-           if (err) {
 
-             console.error(`Failed to communicate with worker (process message) ${err}`);
 
-             return;
 
-           }
 
-           this.state = 'soon next';
 
-           setImmediate(() => this.readNextMessage());
 
-         });
 
-       });
 
-     });
 
-   }
 
-   onWorkerMessage(message, finalCallback) {
 
-     const { type, id } = message;
 
-     switch (type) {
 
-       case 'job':
 
-         {
 
-           const { data, error, result } = message;
 
-           (0, _mapSeries2.default)(data, (length, callback) => this.readBuffer(length, callback), (eachErr, buffers) => {
 
-             const { callback: jobCallback } = this.jobs[id];
 
-             const callback = (err, arg) => {
 
-               if (jobCallback) {
 
-                 delete this.jobs[id];
 
-                 this.activeJobs -= 1;
 
-                 this.onJobDone();
 
-                 if (err) {
 
-                   jobCallback(err instanceof Error ? err : new Error(err), arg);
 
-                 } else {
 
-                   jobCallback(null, arg);
 
-                 }
 
-               }
 
-               finalCallback();
 
-             };
 
-             if (eachErr) {
 
-               callback(eachErr);
 
-               return;
 
-             }
 
-             let bufferPosition = 0;
 
-             if (result.result) {
 
-               result.result = result.result.map(r => {
 
-                 if (r.buffer) {
 
-                   const buffer = buffers[bufferPosition];
 
-                   bufferPosition += 1;
 
-                   if (r.string) {
 
-                     return buffer.toString('utf-8');
 
-                   }
 
-                   return buffer;
 
-                 }
 
-                 return r.data;
 
-               });
 
-             }
 
-             if (error) {
 
-               callback(this.fromErrorObj(error), result);
 
-               return;
 
-             }
 
-             callback(null, result);
 
-           });
 
-           break;
 
-         }
 
-       case 'resolve':
 
-         {
 
-           const { context, request, questionId } = message;
 
-           const { data } = this.jobs[id];
 
-           data.resolve(context, request, (error, result) => {
 
-             this.writeJson({
 
-               type: 'result',
 
-               id: questionId,
 
-               error: error ? {
 
-                 message: error.message,
 
-                 details: error.details,
 
-                 missing: error.missing
 
-               } : null,
 
-               result
 
-             });
 
-           });
 
-           finalCallback();
 
-           break;
 
-         }
 
-       case 'emitWarning':
 
-         {
 
-           const { data } = message;
 
-           const { data: jobData } = this.jobs[id];
 
-           jobData.emitWarning(this.fromErrorObj(data));
 
-           finalCallback();
 
-           break;
 
-         }
 
-       case 'emitError':
 
-         {
 
-           const { data } = message;
 
-           const { data: jobData } = this.jobs[id];
 
-           jobData.emitError(this.fromErrorObj(data));
 
-           finalCallback();
 
-           break;
 
-         }
 
-       default:
 
-         {
 
-           console.error(`Unexpected worker message ${type} in WorkerPool.`);
 
-           finalCallback();
 
-           break;
 
-         }
 
-     }
 
-   }
 
-   fromErrorObj(arg) {
 
-     let obj;
 
-     if (typeof arg === 'string') {
 
-       obj = { message: arg };
 
-     } else {
 
-       obj = arg;
 
-     }
 
-     return new _WorkerError2.default(obj, this.id);
 
-   }
 
-   readBuffer(length, callback) {
 
-     (0, _readBuffer2.default)(this.readPipe, length, callback);
 
-   }
 
-   dispose() {
 
-     if (!this.disposed) {
 
-       this.disposed = true;
 
-       this.ignoreStdOutAndErrFromWorker(this.worker.stdout, this.worker.stderr);
 
-       this.writeEnd();
 
-     }
 
-   }
 
- }
 
- class WorkerPool {
 
-   constructor(options) {
 
-     this.options = options || {};
 
-     this.numberOfWorkers = options.numberOfWorkers;
 
-     this.poolTimeout = options.poolTimeout;
 
-     this.workerNodeArgs = options.workerNodeArgs;
 
-     this.workerParallelJobs = options.workerParallelJobs;
 
-     this.workers = new Set();
 
-     this.activeJobs = 0;
 
-     this.timeout = null;
 
-     this.poolQueue = (0, _queue2.default)(this.distributeJob.bind(this), options.poolParallelJobs);
 
-     this.terminated = false;
 
-     this.setupLifeCycle();
 
-   }
 
-   isAbleToRun() {
 
-     return !this.terminated;
 
-   }
 
-   terminate() {
 
-     if (this.terminated) {
 
-       return;
 
-     }
 
-     this.terminated = true;
 
-     this.poolQueue.kill();
 
-     this.disposeWorkers(true);
 
-   }
 
-   setupLifeCycle() {
 
-     process.on('exit', () => {
 
-       this.terminate();
 
-     });
 
-   }
 
-   run(data, callback) {
 
-     if (this.timeout) {
 
-       clearTimeout(this.timeout);
 
-       this.timeout = null;
 
-     }
 
-     this.activeJobs += 1;
 
-     this.poolQueue.push(data, callback);
 
-   }
 
-   distributeJob(data, callback) {
 
-     // use worker with the fewest jobs
 
-     let bestWorker;
 
-     for (const worker of this.workers) {
 
-       if (!bestWorker || worker.activeJobs < bestWorker.activeJobs) {
 
-         bestWorker = worker;
 
-       }
 
-     }
 
-     if (bestWorker && (bestWorker.activeJobs === 0 || this.workers.size >= this.numberOfWorkers)) {
 
-       bestWorker.run(data, callback);
 
-       return;
 
-     }
 
-     const newWorker = this.createWorker();
 
-     newWorker.run(data, callback);
 
-   }
 
-   createWorker() {
 
-     // spin up a new worker
 
-     const newWorker = new PoolWorker({
 
-       nodeArgs: this.workerNodeArgs,
 
-       parallelJobs: this.workerParallelJobs
 
-     }, () => this.onJobDone());
 
-     this.workers.add(newWorker);
 
-     return newWorker;
 
-   }
 
-   warmup(requires) {
 
-     while (this.workers.size < this.numberOfWorkers) {
 
-       this.createWorker().warmup(requires);
 
-     }
 
-   }
 
-   onJobDone() {
 
-     this.activeJobs -= 1;
 
-     if (this.activeJobs === 0 && isFinite(this.poolTimeout)) {
 
-       this.timeout = setTimeout(() => this.disposeWorkers(), this.poolTimeout);
 
-     }
 
-   }
 
-   disposeWorkers(fromTerminate) {
 
-     if (!this.options.poolRespawn && !fromTerminate) {
 
-       this.terminate();
 
-       return;
 
-     }
 
-     if (this.activeJobs === 0 || fromTerminate) {
 
-       for (const worker of this.workers) {
 
-         worker.dispose();
 
-       }
 
-       this.workers.clear();
 
-     }
 
-   }
 
- }
 
- exports.default = WorkerPool;
 
 
  |