You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@griffin.apache.org by gu...@apache.org on 2018/09/12 08:58:00 UTC

[11/51] [partial] incubator-griffin-site git commit: remove legacy code

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/co/index.js
----------------------------------------------------------------------
diff --git a/node_modules/co/index.js b/node_modules/co/index.js
deleted file mode 100644
index 87ba8ba..0000000
--- a/node_modules/co/index.js
+++ /dev/null
@@ -1,237 +0,0 @@
-
-/**
- * slice() reference.
- */
-
-var slice = Array.prototype.slice;
-
-/**
- * Expose `co`.
- */
-
-module.exports = co['default'] = co.co = co;
-
-/**
- * Wrap the given generator `fn` into a
- * function that returns a promise.
- * This is a separate function so that
- * every `co()` call doesn't create a new,
- * unnecessary closure.
- *
- * @param {GeneratorFunction} fn
- * @return {Function}
- * @api public
- */
-
-co.wrap = function (fn) {
-  createPromise.__generatorFunction__ = fn;
-  return createPromise;
-  function createPromise() {
-    return co.call(this, fn.apply(this, arguments));
-  }
-};
-
-/**
- * Execute the generator function or a generator
- * and return a promise.
- *
- * @param {Function} fn
- * @return {Promise}
- * @api public
- */
-
-function co(gen) {
-  var ctx = this;
-  var args = slice.call(arguments, 1)
-
-  // we wrap everything in a promise to avoid promise chaining,
-  // which leads to memory leak errors.
-  // see https://github.com/tj/co/issues/180
-  return new Promise(function(resolve, reject) {
-    if (typeof gen === 'function') gen = gen.apply(ctx, args);
-    if (!gen || typeof gen.next !== 'function') return resolve(gen);
-
-    onFulfilled();
-
-    /**
-     * @param {Mixed} res
-     * @return {Promise}
-     * @api private
-     */
-
-    function onFulfilled(res) {
-      var ret;
-      try {
-        ret = gen.next(res);
-      } catch (e) {
-        return reject(e);
-      }
-      next(ret);
-    }
-
-    /**
-     * @param {Error} err
-     * @return {Promise}
-     * @api private
-     */
-
-    function onRejected(err) {
-      var ret;
-      try {
-        ret = gen.throw(err);
-      } catch (e) {
-        return reject(e);
-      }
-      next(ret);
-    }
-
-    /**
-     * Get the next value in the generator,
-     * return a promise.
-     *
-     * @param {Object} ret
-     * @return {Promise}
-     * @api private
-     */
-
-    function next(ret) {
-      if (ret.done) return resolve(ret.value);
-      var value = toPromise.call(ctx, ret.value);
-      if (value && isPromise(value)) return value.then(onFulfilled, onRejected);
-      return onRejected(new TypeError('You may only yield a function, promise, generator, array, or object, '
-        + 'but the following object was passed: "' + String(ret.value) + '"'));
-    }
-  });
-}
-
-/**
- * Convert a `yield`ed value into a promise.
- *
- * @param {Mixed} obj
- * @return {Promise}
- * @api private
- */
-
-function toPromise(obj) {
-  if (!obj) return obj;
-  if (isPromise(obj)) return obj;
-  if (isGeneratorFunction(obj) || isGenerator(obj)) return co.call(this, obj);
-  if ('function' == typeof obj) return thunkToPromise.call(this, obj);
-  if (Array.isArray(obj)) return arrayToPromise.call(this, obj);
-  if (isObject(obj)) return objectToPromise.call(this, obj);
-  return obj;
-}
-
-/**
- * Convert a thunk to a promise.
- *
- * @param {Function}
- * @return {Promise}
- * @api private
- */
-
-function thunkToPromise(fn) {
-  var ctx = this;
-  return new Promise(function (resolve, reject) {
-    fn.call(ctx, function (err, res) {
-      if (err) return reject(err);
-      if (arguments.length > 2) res = slice.call(arguments, 1);
-      resolve(res);
-    });
-  });
-}
-
-/**
- * Convert an array of "yieldables" to a promise.
- * Uses `Promise.all()` internally.
- *
- * @param {Array} obj
- * @return {Promise}
- * @api private
- */
-
-function arrayToPromise(obj) {
-  return Promise.all(obj.map(toPromise, this));
-}
-
-/**
- * Convert an object of "yieldables" to a promise.
- * Uses `Promise.all()` internally.
- *
- * @param {Object} obj
- * @return {Promise}
- * @api private
- */
-
-function objectToPromise(obj){
-  var results = new obj.constructor();
-  var keys = Object.keys(obj);
-  var promises = [];
-  for (var i = 0; i < keys.length; i++) {
-    var key = keys[i];
-    var promise = toPromise.call(this, obj[key]);
-    if (promise && isPromise(promise)) defer(promise, key);
-    else results[key] = obj[key];
-  }
-  return Promise.all(promises).then(function () {
-    return results;
-  });
-
-  function defer(promise, key) {
-    // predefine the key in the result
-    results[key] = undefined;
-    promises.push(promise.then(function (res) {
-      results[key] = res;
-    }));
-  }
-}
-
-/**
- * Check if `obj` is a promise.
- *
- * @param {Object} obj
- * @return {Boolean}
- * @api private
- */
-
-function isPromise(obj) {
-  return 'function' == typeof obj.then;
-}
-
-/**
- * Check if `obj` is a generator.
- *
- * @param {Mixed} obj
- * @return {Boolean}
- * @api private
- */
-
-function isGenerator(obj) {
-  return 'function' == typeof obj.next && 'function' == typeof obj.throw;
-}
-
-/**
- * Check if `obj` is a generator function.
- *
- * @param {Mixed} obj
- * @return {Boolean}
- * @api private
- */
-function isGeneratorFunction(obj) {
-  var constructor = obj.constructor;
-  if (!constructor) return false;
-  if ('GeneratorFunction' === constructor.name || 'GeneratorFunction' === constructor.displayName) return true;
-  return isGenerator(constructor.prototype);
-}
-
-/**
- * Check for plain object.
- *
- * @param {Mixed} val
- * @return {Boolean}
- * @api private
- */
-
-function isObject(val) {
-  return Object == val.constructor;
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/co/package.json
----------------------------------------------------------------------
diff --git a/node_modules/co/package.json b/node_modules/co/package.json
deleted file mode 100644
index f02994d..0000000
--- a/node_modules/co/package.json
+++ /dev/null
@@ -1,107 +0,0 @@
-{
-  "_args": [
-    [
-      {
-        "raw": "co@^4.6.0",
-        "scope": null,
-        "escapedName": "co",
-        "name": "co",
-        "rawSpec": "^4.6.0",
-        "spec": ">=4.6.0 <5.0.0",
-        "type": "range"
-      },
-      "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/ajv"
-    ]
-  ],
-  "_from": "co@>=4.6.0 <5.0.0",
-  "_id": "co@4.6.0",
-  "_inCache": true,
-  "_installable": true,
-  "_location": "/co",
-  "_nodeVersion": "2.3.3",
-  "_npmUser": {
-    "name": "jongleberry",
-    "email": "jonathanrichardong@gmail.com"
-  },
-  "_npmVersion": "2.11.3",
-  "_phantomChildren": {},
-  "_requested": {
-    "raw": "co@^4.6.0",
-    "scope": null,
-    "escapedName": "co",
-    "name": "co",
-    "rawSpec": "^4.6.0",
-    "spec": ">=4.6.0 <5.0.0",
-    "type": "range"
-  },
-  "_requiredBy": [
-    "/ajv"
-  ],
-  "_resolved": "https://registry.npmjs.org/co/-/co-4.6.0.tgz",
-  "_shasum": "6ea6bdf3d853ae54ccb8e47bfa0bf3f9031fb184",
-  "_shrinkwrap": null,
-  "_spec": "co@^4.6.0",
-  "_where": "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/ajv",
-  "bugs": {
-    "url": "https://github.com/tj/co/issues"
-  },
-  "dependencies": {},
-  "description": "generator async control flow goodness",
-  "devDependencies": {
-    "browserify": "^10.0.0",
-    "istanbul-harmony": "0",
-    "mocha": "^2.0.0",
-    "mz": "^1.0.2"
-  },
-  "directories": {},
-  "dist": {
-    "shasum": "6ea6bdf3d853ae54ccb8e47bfa0bf3f9031fb184",
-    "tarball": "https://registry.npmjs.org/co/-/co-4.6.0.tgz"
-  },
-  "engines": {
-    "iojs": ">= 1.0.0",
-    "node": ">= 0.12.0"
-  },
-  "files": [
-    "index.js"
-  ],
-  "gitHead": "b54d18f8f472ad1314800e786993c4169a5ff9f8",
-  "homepage": "https://github.com/tj/co#readme",
-  "keywords": [
-    "async",
-    "flow",
-    "generator",
-    "coro",
-    "coroutine"
-  ],
-  "license": "MIT",
-  "maintainers": [
-    {
-      "name": "tjholowaychuk",
-      "email": "tj@vision-media.ca"
-    },
-    {
-      "name": "jonathanong",
-      "email": "jonathanrichardong@gmail.com"
-    },
-    {
-      "name": "jongleberry",
-      "email": "jonathanrichardong@gmail.com"
-    }
-  ],
-  "name": "co",
-  "optionalDependencies": {},
-  "readme": "ERROR: No README data found!",
-  "repository": {
-    "type": "git",
-    "url": "git+https://github.com/tj/co.git"
-  },
-  "scripts": {
-    "browserify": "browserify index.js -o ./co-browser.js -s co",
-    "prepublish": "npm run browserify",
-    "test": "mocha --harmony",
-    "test-cov": "node --harmony node_modules/.bin/istanbul cover ./node_modules/.bin/_mocha -- --reporter dot",
-    "test-travis": "node --harmony node_modules/.bin/istanbul cover ./node_modules/.bin/_mocha --report lcovonly -- --reporter dot"
-  },
-  "version": "4.6.0"
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/code-point-at/index.js
----------------------------------------------------------------------
diff --git a/node_modules/code-point-at/index.js b/node_modules/code-point-at/index.js
deleted file mode 100644
index 0432fe6..0000000
--- a/node_modules/code-point-at/index.js
+++ /dev/null
@@ -1,32 +0,0 @@
-/* eslint-disable babel/new-cap, xo/throw-new-error */
-'use strict';
-module.exports = function (str, pos) {
-	if (str === null || str === undefined) {
-		throw TypeError();
-	}
-
-	str = String(str);
-
-	var size = str.length;
-	var i = pos ? Number(pos) : 0;
-
-	if (Number.isNaN(i)) {
-		i = 0;
-	}
-
-	if (i < 0 || i >= size) {
-		return undefined;
-	}
-
-	var first = str.charCodeAt(i);
-
-	if (first >= 0xD800 && first <= 0xDBFF && size > i + 1) {
-		var second = str.charCodeAt(i + 1);
-
-		if (second >= 0xDC00 && second <= 0xDFFF) {
-			return ((first - 0xD800) * 0x400) + second - 0xDC00 + 0x10000;
-		}
-	}
-
-	return first;
-};

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/code-point-at/license
----------------------------------------------------------------------
diff --git a/node_modules/code-point-at/license b/node_modules/code-point-at/license
deleted file mode 100644
index 654d0bf..0000000
--- a/node_modules/code-point-at/license
+++ /dev/null
@@ -1,21 +0,0 @@
-The MIT License (MIT)
-
-Copyright (c) Sindre Sorhus <si...@gmail.com> (sindresorhus.com)
-
-Permission is hereby granted, free of charge, to any person obtaining a copy
-of this software and associated documentation files (the "Software"), to deal
-in the Software without restriction, including without limitation the rights
-to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-copies of the Software, and to permit persons to whom the Software is
-furnished to do so, subject to the following conditions:
-
-The above copyright notice and this permission notice shall be included in
-all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/code-point-at/package.json
----------------------------------------------------------------------
diff --git a/node_modules/code-point-at/package.json b/node_modules/code-point-at/package.json
deleted file mode 100644
index 5508429..0000000
--- a/node_modules/code-point-at/package.json
+++ /dev/null
@@ -1,107 +0,0 @@
-{
-  "_args": [
-    [
-      {
-        "raw": "code-point-at@^1.0.0",
-        "scope": null,
-        "escapedName": "code-point-at",
-        "name": "code-point-at",
-        "rawSpec": "^1.0.0",
-        "spec": ">=1.0.0 <2.0.0",
-        "type": "range"
-      },
-      "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/string-width"
-    ]
-  ],
-  "_from": "code-point-at@>=1.0.0 <2.0.0",
-  "_id": "code-point-at@1.1.0",
-  "_inCache": true,
-  "_installable": true,
-  "_location": "/code-point-at",
-  "_nodeVersion": "4.6.1",
-  "_npmOperationalInternal": {
-    "host": "packages-12-west.internal.npmjs.com",
-    "tmp": "tmp/code-point-at-1.1.0.tgz_1478169780337_0.8445875702891499"
-  },
-  "_npmUser": {
-    "name": "sindresorhus",
-    "email": "sindresorhus@gmail.com"
-  },
-  "_npmVersion": "2.15.9",
-  "_phantomChildren": {},
-  "_requested": {
-    "raw": "code-point-at@^1.0.0",
-    "scope": null,
-    "escapedName": "code-point-at",
-    "name": "code-point-at",
-    "rawSpec": "^1.0.0",
-    "spec": ">=1.0.0 <2.0.0",
-    "type": "range"
-  },
-  "_requiredBy": [
-    "/string-width"
-  ],
-  "_resolved": "https://registry.npmjs.org/code-point-at/-/code-point-at-1.1.0.tgz",
-  "_shasum": "0d070b4d043a5bea33a2f1a40e2edb3d9a4ccf77",
-  "_shrinkwrap": null,
-  "_spec": "code-point-at@^1.0.0",
-  "_where": "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/string-width",
-  "author": {
-    "name": "Sindre Sorhus",
-    "email": "sindresorhus@gmail.com",
-    "url": "sindresorhus.com"
-  },
-  "bugs": {
-    "url": "https://github.com/sindresorhus/code-point-at/issues"
-  },
-  "dependencies": {},
-  "description": "ES2015 `String#codePointAt()` ponyfill",
-  "devDependencies": {
-    "ava": "*",
-    "xo": "^0.16.0"
-  },
-  "directories": {},
-  "dist": {
-    "shasum": "0d070b4d043a5bea33a2f1a40e2edb3d9a4ccf77",
-    "tarball": "https://registry.npmjs.org/code-point-at/-/code-point-at-1.1.0.tgz"
-  },
-  "engines": {
-    "node": ">=0.10.0"
-  },
-  "files": [
-    "index.js"
-  ],
-  "gitHead": "f8f21c8df2d40248fef1b36ca9076e59c0c34791",
-  "homepage": "https://github.com/sindresorhus/code-point-at#readme",
-  "keywords": [
-    "es2015",
-    "ponyfill",
-    "polyfill",
-    "shim",
-    "string",
-    "str",
-    "code",
-    "point",
-    "at",
-    "codepoint",
-    "unicode"
-  ],
-  "license": "MIT",
-  "maintainers": [
-    {
-      "name": "sindresorhus",
-      "email": "sindresorhus@gmail.com"
-    }
-  ],
-  "name": "code-point-at",
-  "optionalDependencies": {},
-  "readme": "ERROR: No README data found!",
-  "repository": {
-    "type": "git",
-    "url": "git+https://github.com/sindresorhus/code-point-at.git"
-  },
-  "scripts": {
-    "test": "xo && ava"
-  },
-  "version": "1.1.0"
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/code-point-at/readme.md
----------------------------------------------------------------------
diff --git a/node_modules/code-point-at/readme.md b/node_modules/code-point-at/readme.md
deleted file mode 100644
index 4c97730..0000000
--- a/node_modules/code-point-at/readme.md
+++ /dev/null
@@ -1,32 +0,0 @@
-# code-point-at [![Build Status](https://travis-ci.org/sindresorhus/code-point-at.svg?branch=master)](https://travis-ci.org/sindresorhus/code-point-at)
-
-> ES2015 [`String#codePointAt()`](https://developer.mozilla.org/en-US/docs/Web/JavaScript/Reference/Global_Objects/String/codePointAt) [ponyfill](https://ponyfill.com)
-
-
-## Install
-
-```
-$ npm install --save code-point-at
-```
-
-
-## Usage
-
-```js
-var codePointAt = require('code-point-at');
-
-codePointAt('🐴');
-//=> 128052
-
-codePointAt('abc', 2);
-//=> 99
-```
-
-## API
-
-### codePointAt(input, [position])
-
-
-## License
-
-MIT © [Sindre Sorhus](https://sindresorhus.com)

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/combined-stream/License
----------------------------------------------------------------------
diff --git a/node_modules/combined-stream/License b/node_modules/combined-stream/License
deleted file mode 100644
index 4804b7a..0000000
--- a/node_modules/combined-stream/License
+++ /dev/null
@@ -1,19 +0,0 @@
-Copyright (c) 2011 Debuggable Limited <fe...@debuggable.com>
-
-Permission is hereby granted, free of charge, to any person obtaining a copy
-of this software and associated documentation files (the "Software"), to deal
-in the Software without restriction, including without limitation the rights
-to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-copies of the Software, and to permit persons to whom the Software is
-furnished to do so, subject to the following conditions:
-
-The above copyright notice and this permission notice shall be included in
-all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/combined-stream/Readme.md
----------------------------------------------------------------------
diff --git a/node_modules/combined-stream/Readme.md b/node_modules/combined-stream/Readme.md
deleted file mode 100644
index 3a9e025..0000000
--- a/node_modules/combined-stream/Readme.md
+++ /dev/null
@@ -1,138 +0,0 @@
-# combined-stream
-
-A stream that emits multiple other streams one after another.
-
-**NB** Currently `combined-stream` works with streams vesrion 1 only. There is ongoing effort to switch this library to streams version 2. Any help is welcome. :) Meanwhile you can explore other libraries that provide streams2 support with more or less compatability with `combined-stream`.
-
-- [combined-stream2](https://www.npmjs.com/package/combined-stream2): A drop-in streams2-compatible replacement for the combined-stream module.
-
-- [multistream](https://www.npmjs.com/package/multistream): A stream that emits multiple other streams one after another.
-
-## Installation
-
-``` bash
-npm install combined-stream
-```
-
-## Usage
-
-Here is a simple example that shows how you can use combined-stream to combine
-two files into one:
-
-``` javascript
-var CombinedStream = require('combined-stream');
-var fs = require('fs');
-
-var combinedStream = CombinedStream.create();
-combinedStream.append(fs.createReadStream('file1.txt'));
-combinedStream.append(fs.createReadStream('file2.txt'));
-
-combinedStream.pipe(fs.createWriteStream('combined.txt'));
-```
-
-While the example above works great, it will pause all source streams until
-they are needed. If you don't want that to happen, you can set `pauseStreams`
-to `false`:
-
-``` javascript
-var CombinedStream = require('combined-stream');
-var fs = require('fs');
-
-var combinedStream = CombinedStream.create({pauseStreams: false});
-combinedStream.append(fs.createReadStream('file1.txt'));
-combinedStream.append(fs.createReadStream('file2.txt'));
-
-combinedStream.pipe(fs.createWriteStream('combined.txt'));
-```
-
-However, what if you don't have all the source streams yet, or you don't want
-to allocate the resources (file descriptors, memory, etc.) for them right away?
-Well, in that case you can simply provide a callback that supplies the stream
-by calling a `next()` function:
-
-``` javascript
-var CombinedStream = require('combined-stream');
-var fs = require('fs');
-
-var combinedStream = CombinedStream.create();
-combinedStream.append(function(next) {
-  next(fs.createReadStream('file1.txt'));
-});
-combinedStream.append(function(next) {
-  next(fs.createReadStream('file2.txt'));
-});
-
-combinedStream.pipe(fs.createWriteStream('combined.txt'));
-```
-
-## API
-
-### CombinedStream.create([options])
-
-Returns a new combined stream object. Available options are:
-
-* `maxDataSize`
-* `pauseStreams`
-
-The effect of those options is described below.
-
-### combinedStream.pauseStreams = `true`
-
-Whether to apply back pressure to the underlaying streams. If set to `false`,
-the underlaying streams will never be paused. If set to `true`, the
-underlaying streams will be paused right after being appended, as well as when
-`delayedStream.pipe()` wants to throttle.
-
-### combinedStream.maxDataSize = `2 * 1024 * 1024`
-
-The maximum amount of bytes (or characters) to buffer for all source streams.
-If this value is exceeded, `combinedStream` emits an `'error'` event.
-
-### combinedStream.dataSize = `0`
-
-The amount of bytes (or characters) currently buffered by `combinedStream`.
-
-### combinedStream.append(stream)
-
-Appends the given `stream` to the combinedStream object. If `pauseStreams` is
-set to `true, this stream will also be paused right away.
-
-`streams` can also be a function that takes one parameter called `next`. `next`
-is a function that must be invoked in order to provide the `next` stream, see
-example above.
-
-Regardless of how the `stream` is appended, combined-stream always attaches an
-`'error'` listener to it, so you don't have to do that manually.
-
-Special case: `stream` can also be a String or Buffer.
-
-### combinedStream.write(data)
-
-You should not call this, `combinedStream` takes care of piping the appended
-streams into itself for you.
-
-### combinedStream.resume()
-
-Causes `combinedStream` to start drain the streams it manages. The function is
-idempotent, and also emits a `'resume'` event each time which usually goes to
-the stream that is currently being drained.
-
-### combinedStream.pause();
-
-If `combinedStream.pauseStreams` is set to `false`, this does nothing.
-Otherwise a `'pause'` event is emitted, this goes to the stream that is
-currently being drained, so you can use it to apply back pressure.
-
-### combinedStream.end();
-
-Sets `combinedStream.writable` to false, emits an `'end'` event, and removes
-all streams from the queue.
-
-### combinedStream.destroy();
-
-Same as `combinedStream.end()`, except it emits a `'close'` event instead of
-`'end'`.
-
-## License
-
-combined-stream is licensed under the MIT license.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/combined-stream/lib/combined_stream.js
----------------------------------------------------------------------
diff --git a/node_modules/combined-stream/lib/combined_stream.js b/node_modules/combined-stream/lib/combined_stream.js
deleted file mode 100644
index 6b5c21b..0000000
--- a/node_modules/combined-stream/lib/combined_stream.js
+++ /dev/null
@@ -1,188 +0,0 @@
-var util = require('util');
-var Stream = require('stream').Stream;
-var DelayedStream = require('delayed-stream');
-
-module.exports = CombinedStream;
-function CombinedStream() {
-  this.writable = false;
-  this.readable = true;
-  this.dataSize = 0;
-  this.maxDataSize = 2 * 1024 * 1024;
-  this.pauseStreams = true;
-
-  this._released = false;
-  this._streams = [];
-  this._currentStream = null;
-}
-util.inherits(CombinedStream, Stream);
-
-CombinedStream.create = function(options) {
-  var combinedStream = new this();
-
-  options = options || {};
-  for (var option in options) {
-    combinedStream[option] = options[option];
-  }
-
-  return combinedStream;
-};
-
-CombinedStream.isStreamLike = function(stream) {
-  return (typeof stream !== 'function')
-    && (typeof stream !== 'string')
-    && (typeof stream !== 'boolean')
-    && (typeof stream !== 'number')
-    && (!Buffer.isBuffer(stream));
-};
-
-CombinedStream.prototype.append = function(stream) {
-  var isStreamLike = CombinedStream.isStreamLike(stream);
-
-  if (isStreamLike) {
-    if (!(stream instanceof DelayedStream)) {
-      var newStream = DelayedStream.create(stream, {
-        maxDataSize: Infinity,
-        pauseStream: this.pauseStreams,
-      });
-      stream.on('data', this._checkDataSize.bind(this));
-      stream = newStream;
-    }
-
-    this._handleErrors(stream);
-
-    if (this.pauseStreams) {
-      stream.pause();
-    }
-  }
-
-  this._streams.push(stream);
-  return this;
-};
-
-CombinedStream.prototype.pipe = function(dest, options) {
-  Stream.prototype.pipe.call(this, dest, options);
-  this.resume();
-  return dest;
-};
-
-CombinedStream.prototype._getNext = function() {
-  this._currentStream = null;
-  var stream = this._streams.shift();
-
-
-  if (typeof stream == 'undefined') {
-    this.end();
-    return;
-  }
-
-  if (typeof stream !== 'function') {
-    this._pipeNext(stream);
-    return;
-  }
-
-  var getStream = stream;
-  getStream(function(stream) {
-    var isStreamLike = CombinedStream.isStreamLike(stream);
-    if (isStreamLike) {
-      stream.on('data', this._checkDataSize.bind(this));
-      this._handleErrors(stream);
-    }
-
-    this._pipeNext(stream);
-  }.bind(this));
-};
-
-CombinedStream.prototype._pipeNext = function(stream) {
-  this._currentStream = stream;
-
-  var isStreamLike = CombinedStream.isStreamLike(stream);
-  if (isStreamLike) {
-    stream.on('end', this._getNext.bind(this));
-    stream.pipe(this, {end: false});
-    return;
-  }
-
-  var value = stream;
-  this.write(value);
-  this._getNext();
-};
-
-CombinedStream.prototype._handleErrors = function(stream) {
-  var self = this;
-  stream.on('error', function(err) {
-    self._emitError(err);
-  });
-};
-
-CombinedStream.prototype.write = function(data) {
-  this.emit('data', data);
-};
-
-CombinedStream.prototype.pause = function() {
-  if (!this.pauseStreams) {
-    return;
-  }
-
-  if(this.pauseStreams && this._currentStream && typeof(this._currentStream.pause) == 'function') this._currentStream.pause();
-  this.emit('pause');
-};
-
-CombinedStream.prototype.resume = function() {
-  if (!this._released) {
-    this._released = true;
-    this.writable = true;
-    this._getNext();
-  }
-
-  if(this.pauseStreams && this._currentStream && typeof(this._currentStream.resume) == 'function') this._currentStream.resume();
-  this.emit('resume');
-};
-
-CombinedStream.prototype.end = function() {
-  this._reset();
-  this.emit('end');
-};
-
-CombinedStream.prototype.destroy = function() {
-  this._reset();
-  this.emit('close');
-};
-
-CombinedStream.prototype._reset = function() {
-  this.writable = false;
-  this._streams = [];
-  this._currentStream = null;
-};
-
-CombinedStream.prototype._checkDataSize = function() {
-  this._updateDataSize();
-  if (this.dataSize <= this.maxDataSize) {
-    return;
-  }
-
-  var message =
-    'DelayedStream#maxDataSize of ' + this.maxDataSize + ' bytes exceeded.';
-  this._emitError(new Error(message));
-};
-
-CombinedStream.prototype._updateDataSize = function() {
-  this.dataSize = 0;
-
-  var self = this;
-  this._streams.forEach(function(stream) {
-    if (!stream.dataSize) {
-      return;
-    }
-
-    self.dataSize += stream.dataSize;
-  });
-
-  if (this._currentStream && this._currentStream.dataSize) {
-    this.dataSize += this._currentStream.dataSize;
-  }
-};
-
-CombinedStream.prototype._emitError = function(err) {
-  this._reset();
-  this.emit('error', err);
-};

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/combined-stream/package.json
----------------------------------------------------------------------
diff --git a/node_modules/combined-stream/package.json b/node_modules/combined-stream/package.json
deleted file mode 100644
index 68dcf80..0000000
--- a/node_modules/combined-stream/package.json
+++ /dev/null
@@ -1,102 +0,0 @@
-{
-  "_args": [
-    [
-      {
-        "raw": "combined-stream@~1.0.5",
-        "scope": null,
-        "escapedName": "combined-stream",
-        "name": "combined-stream",
-        "rawSpec": "~1.0.5",
-        "spec": ">=1.0.5 <1.1.0",
-        "type": "range"
-      },
-      "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/request"
-    ]
-  ],
-  "_from": "combined-stream@>=1.0.5 <1.1.0",
-  "_id": "combined-stream@1.0.5",
-  "_inCache": true,
-  "_installable": true,
-  "_location": "/combined-stream",
-  "_nodeVersion": "0.12.4",
-  "_npmUser": {
-    "name": "alexindigo",
-    "email": "iam@alexindigo.com"
-  },
-  "_npmVersion": "2.10.1",
-  "_phantomChildren": {},
-  "_requested": {
-    "raw": "combined-stream@~1.0.5",
-    "scope": null,
-    "escapedName": "combined-stream",
-    "name": "combined-stream",
-    "rawSpec": "~1.0.5",
-    "spec": ">=1.0.5 <1.1.0",
-    "type": "range"
-  },
-  "_requiredBy": [
-    "/form-data",
-    "/request"
-  ],
-  "_resolved": "https://registry.npmjs.org/combined-stream/-/combined-stream-1.0.5.tgz",
-  "_shasum": "938370a57b4a51dea2c77c15d5c5fdf895164009",
-  "_shrinkwrap": null,
-  "_spec": "combined-stream@~1.0.5",
-  "_where": "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/request",
-  "author": {
-    "name": "Felix Geisendörfer",
-    "email": "felix@debuggable.com",
-    "url": "http://debuggable.com/"
-  },
-  "bugs": {
-    "url": "https://github.com/felixge/node-combined-stream/issues"
-  },
-  "dependencies": {
-    "delayed-stream": "~1.0.0"
-  },
-  "description": "A stream that emits multiple other streams one after another.",
-  "devDependencies": {
-    "far": "~0.0.7"
-  },
-  "directories": {},
-  "dist": {
-    "shasum": "938370a57b4a51dea2c77c15d5c5fdf895164009",
-    "tarball": "https://registry.npmjs.org/combined-stream/-/combined-stream-1.0.5.tgz"
-  },
-  "engines": {
-    "node": ">= 0.8"
-  },
-  "gitHead": "cfc7b815d090a109bcedb5bb0f6713148d55a6b7",
-  "homepage": "https://github.com/felixge/node-combined-stream",
-  "license": "MIT",
-  "main": "./lib/combined_stream",
-  "maintainers": [
-    {
-      "name": "felixge",
-      "email": "felix@debuggable.com"
-    },
-    {
-      "name": "celer",
-      "email": "dtyree77@gmail.com"
-    },
-    {
-      "name": "alexindigo",
-      "email": "iam@alexindigo.com"
-    },
-    {
-      "name": "apechimp",
-      "email": "apeherder@gmail.com"
-    }
-  ],
-  "name": "combined-stream",
-  "optionalDependencies": {},
-  "readme": "ERROR: No README data found!",
-  "repository": {
-    "type": "git",
-    "url": "git://github.com/felixge/node-combined-stream.git"
-  },
-  "scripts": {
-    "test": "node test/run.js"
-  },
-  "version": "1.0.5"
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compressible/HISTORY.md
----------------------------------------------------------------------
diff --git a/node_modules/compressible/HISTORY.md b/node_modules/compressible/HISTORY.md
deleted file mode 100644
index 6896784..0000000
--- a/node_modules/compressible/HISTORY.md
+++ /dev/null
@@ -1,62 +0,0 @@
-2.0.9 / 2016-10-31
-==================
-
-  * Fix regex fallback to not override `compressible: false` in db
-  * deps: mime-db@'>= 1.24.0 < 2'
-
-2.0.8 / 2016-05-12
-==================
-
-  * deps: mime-db@'>= 1.23.0 < 2'
-
-2.0.7 / 2016-01-18
-==================
-
-  * deps: mime-db@'>= 1.21.0 < 2'
-
-2.0.6 / 2015-09-29
-==================
-
-  * deps: mime-db@'>= 1.19.0 < 2'
-
-2.0.5 / 2015-07-30
-==================
-
-  * deps: mime-db@'>= 1.16.0 < 2'
-
-2.0.4 / 2015-07-01
-==================
-
-  * deps: mime-db@'>= 1.14.0 < 2'
-  * perf: enable strict mode
-
-2.0.3 / 2015-06-08
-==================
-
-  * Fix regex fallback to work if type exists, but is undefined
-  * perf: hoist regex declaration
-  * perf: use regex to extract mime
-  * deps: mime-db@'>= 1.13.0 < 2'
-
-2.0.2 / 2015-01-31
-==================
-
-  * deps: mime-db@'>= 1.1.2 < 2'
-
-2.0.1 / 2014-09-28
-==================
-
-  * deps: mime-db@1.x
-    - Add new mime types
-    - Add additional compressible
-    - Update charsets
-
-
-2.0.0 / 2014-09-02
-==================
-
-  * use mime-db
-  * remove .get()
-  * specifications are now private
-  * regex is now private
-  * stricter regex

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compressible/LICENSE
----------------------------------------------------------------------
diff --git a/node_modules/compressible/LICENSE b/node_modules/compressible/LICENSE
deleted file mode 100644
index ce00b3f..0000000
--- a/node_modules/compressible/LICENSE
+++ /dev/null
@@ -1,24 +0,0 @@
-(The MIT License)
-
-Copyright (c) 2013 Jonathan Ong <me...@jongleberry.com>
-Copyright (c) 2014 Jeremiah Senkpiel <fi...@rocketmail.com>
-Copyright (c) 2015 Douglas Christopher Wilson <do...@somethingdoug.com>
-
-Permission is hereby granted, free of charge, to any person obtaining
-a copy of this software and associated documentation files (the
-'Software'), to deal in the Software without restriction, including
-without limitation the rights to use, copy, modify, merge, publish,
-distribute, sublicense, and/or sell copies of the Software, and to
-permit persons to whom the Software is furnished to do so, subject to
-the following conditions:
-
-The above copyright notice and this permission notice shall be
-included in all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED 'AS IS', WITHOUT WARRANTY OF ANY KIND,
-EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF
-MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT.
-IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY
-CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT,
-TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE
-SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compressible/README.md
----------------------------------------------------------------------
diff --git a/node_modules/compressible/README.md b/node_modules/compressible/README.md
deleted file mode 100644
index 6d8699d..0000000
--- a/node_modules/compressible/README.md
+++ /dev/null
@@ -1,58 +0,0 @@
-# compressible
-
-[![NPM Version][npm-image]][npm-url]
-[![NPM Downloads][downloads-image]][downloads-url]
-[![Node.js Version][node-version-image]][node-version-url]
-[![Build Status][travis-image]][travis-url]
-[![Test Coverage][coveralls-image]][coveralls-url]
-
-Compressible `Content-Type` / `mime` checking.
-
-## Installation
-
-```bash
-$ npm install compressible
-```
-
-## API
-
-```js
-var compressible = require('compressible')
-```
-
-### compressible(type)
-
-Checks if the given `Content-Type` is compressible. The `type` argument is expected
-to be a value MIME type or `Content-Type` string, though no validation is performed.
-
-The MIME is looked up in the [`mime-db`](https://www.npmjs.com/package/mime-db) and
-if there is compressible information in the database entry, that is returned. Otherwise,
-this module will fallback to `true` for the following types:
-
-  * `text/*`
-  * `*/*+json`
-  * `*/*+text`
-  * `*/*+xml`
-
-If this module is not sure if a type is specifically compressible or specifically
-uncompressible, `undefined` is returned.
-
-```js
-compressible('text/html') // => true
-compressible('image/png') // => false
-```
-
-## License
-
-[MIT](LICENSE)
-
-[npm-image]: https://img.shields.io/npm/v/compressible.svg
-[npm-url]: https://npmjs.org/package/compressible
-[node-version-image]: https://img.shields.io/node/v/compressible.svg
-[node-version-url]: https://nodejs.org/en/download/
-[travis-image]: https://img.shields.io/travis/jshttp/compressible/master.svg
-[travis-url]: https://travis-ci.org/jshttp/compressible
-[coveralls-image]: https://img.shields.io/coveralls/jshttp/compressible/master.svg
-[coveralls-url]: https://coveralls.io/r/jshttp/compressible?branch=master
-[downloads-image]: https://img.shields.io/npm/dm/compressible.svg
-[downloads-url]: https://npmjs.org/package/compressible

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compressible/index.js
----------------------------------------------------------------------
diff --git a/node_modules/compressible/index.js b/node_modules/compressible/index.js
deleted file mode 100644
index bf14ad7..0000000
--- a/node_modules/compressible/index.js
+++ /dev/null
@@ -1,58 +0,0 @@
-/*!
- * compressible
- * Copyright(c) 2013 Jonathan Ong
- * Copyright(c) 2014 Jeremiah Senkpiel
- * Copyright(c) 2015 Douglas Christopher Wilson
- * MIT Licensed
- */
-
-'use strict'
-
-/**
- * Module dependencies.
- * @private
- */
-
-var db = require('mime-db')
-
-/**
- * Module variables.
- * @private
- */
-
-var compressibleTypeRegExp = /^text\/|\+json$|\+text$|\+xml$/i
-var extractTypeRegExp = /^\s*([^;\s]*)(?:;|\s|$)/
-
-/**
- * Module exports.
- * @public
- */
-
-module.exports = compressible
-
-/**
- * Checks if a type is compressible.
- *
- * @param {string} type
- * @return {Boolean} compressible
- * @public
- */
-
-function compressible (type) {
-  if (!type || typeof type !== 'string') {
-    return false
-  }
-
-  // strip parameters
-  var match = extractTypeRegExp.exec(type)
-  var mime = match && match[1].toLowerCase()
-  var data = db[mime]
-
-  // return database information
-  if (data && data.compressible !== undefined) {
-    return data.compressible
-  }
-
-  // fallback to regexp or unknown
-  return compressibleTypeRegExp.test(mime) || undefined
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compressible/package.json
----------------------------------------------------------------------
diff --git a/node_modules/compressible/package.json b/node_modules/compressible/package.json
deleted file mode 100644
index c00304c..0000000
--- a/node_modules/compressible/package.json
+++ /dev/null
@@ -1,146 +0,0 @@
-{
-  "_args": [
-    [
-      {
-        "raw": "compressible@~2.0.8",
-        "scope": null,
-        "escapedName": "compressible",
-        "name": "compressible",
-        "rawSpec": "~2.0.8",
-        "spec": ">=2.0.8 <2.1.0",
-        "type": "range"
-      },
-      "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/compression"
-    ]
-  ],
-  "_from": "compressible@>=2.0.8 <2.1.0",
-  "_id": "compressible@2.0.9",
-  "_inCache": true,
-  "_installable": true,
-  "_location": "/compressible",
-  "_npmOperationalInternal": {
-    "host": "packages-18-east.internal.npmjs.com",
-    "tmp": "tmp/compressible-2.0.9.tgz_1477956262136_0.9366124230436981"
-  },
-  "_npmUser": {
-    "name": "dougwilson",
-    "email": "doug@somethingdoug.com"
-  },
-  "_npmVersion": "1.4.28",
-  "_phantomChildren": {},
-  "_requested": {
-    "raw": "compressible@~2.0.8",
-    "scope": null,
-    "escapedName": "compressible",
-    "name": "compressible",
-    "rawSpec": "~2.0.8",
-    "spec": ">=2.0.8 <2.1.0",
-    "type": "range"
-  },
-  "_requiredBy": [
-    "/compression"
-  ],
-  "_resolved": "https://registry.npmjs.org/compressible/-/compressible-2.0.9.tgz",
-  "_shasum": "6daab4e2b599c2770dd9e21e7a891b1c5a755425",
-  "_shrinkwrap": null,
-  "_spec": "compressible@~2.0.8",
-  "_where": "/Users/yueguo/repo.site/incubator-griffin-site/node_modules/compression",
-  "bugs": {
-    "url": "https://github.com/jshttp/compressible/issues"
-  },
-  "contributors": [
-    {
-      "name": "Douglas Christopher Wilson",
-      "email": "doug@somethingdoug.com"
-    },
-    {
-      "name": "Jonathan Ong",
-      "email": "me@jongleberry.com",
-      "url": "http://jongleberry.com"
-    },
-    {
-      "name": "Jeremiah Senkpiel",
-      "email": "fishrock123@rocketmail.com",
-      "url": "https://searchbeam.jit.su"
-    }
-  ],
-  "dependencies": {
-    "mime-db": ">= 1.24.0 < 2"
-  },
-  "description": "Compressible Content-Type / mime checking",
-  "devDependencies": {
-    "eslint": "3.9.1",
-    "eslint-config-standard": "6.2.1",
-    "eslint-plugin-promise": "3.3.0",
-    "eslint-plugin-standard": "2.0.1",
-    "istanbul": "0.4.5",
-    "mocha": "~1.21.5"
-  },
-  "directories": {},
-  "dist": {
-    "shasum": "6daab4e2b599c2770dd9e21e7a891b1c5a755425",
-    "tarball": "https://registry.npmjs.org/compressible/-/compressible-2.0.9.tgz"
-  },
-  "engines": {
-    "node": ">= 0.6"
-  },
-  "files": [
-    "HISTORY.md",
-    "LICENSE",
-    "README.md",
-    "index.js"
-  ],
-  "gitHead": "9e750e00d459f01b9a16df504f87ad829bf2a518",
-  "homepage": "https://github.com/jshttp/compressible",
-  "keywords": [
-    "compress",
-    "gzip",
-    "mime",
-    "content-type"
-  ],
-  "license": "MIT",
-  "maintainers": [
-    {
-      "name": "defunctzombie",
-      "email": "shtylman@gmail.com"
-    },
-    {
-      "name": "dougwilson",
-      "email": "doug@somethingdoug.com"
-    },
-    {
-      "name": "federomero",
-      "email": "federomero@gmail.com"
-    },
-    {
-      "name": "fishrock123",
-      "email": "fishrock123@rocketmail.com"
-    },
-    {
-      "name": "jongleberry",
-      "email": "jonathanrichardong@gmail.com"
-    },
-    {
-      "name": "mscdex",
-      "email": "mscdex@mscdex.net"
-    },
-    {
-      "name": "tjholowaychuk",
-      "email": "tj@vision-media.ca"
-    }
-  ],
-  "name": "compressible",
-  "optionalDependencies": {},
-  "readme": "ERROR: No README data found!",
-  "repository": {
-    "type": "git",
-    "url": "git+https://github.com/jshttp/compressible.git"
-  },
-  "scripts": {
-    "lint": "eslint .",
-    "test": "mocha --reporter spec --bail --check-leaks test/",
-    "test-cov": "istanbul cover node_modules/mocha/bin/_mocha -- --reporter dot --check-leaks",
-    "test-travis": "istanbul cover node_modules/mocha/bin/_mocha --report lcovonly -- --reporter dot --check-leaks"
-  },
-  "version": "2.0.9"
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/HISTORY.md
----------------------------------------------------------------------
diff --git a/node_modules/compression/HISTORY.md b/node_modules/compression/HISTORY.md
deleted file mode 100644
index 663f0de..0000000
--- a/node_modules/compression/HISTORY.md
+++ /dev/null
@@ -1,251 +0,0 @@
-1.6.2 / 2016-05-12
-==================
-
-  * deps: accepts@~1.3.3
-    - deps: mime-types@~2.1.11
-    - deps: negotiator@0.6.1
-  * deps: bytes@2.3.0
-    - Drop partial bytes on all parsed units
-    - Fix parsing byte string that looks like hex
-    - perf: hoist regular expressions
-  * deps: compressible@~2.0.8
-    - deps: mime-db@'>= 1.23.0 < 2'
-
-1.6.1 / 2016-01-19
-==================
-
-  * deps: bytes@2.2.0
-  * deps: compressible@~2.0.7
-    - deps: mime-db@'>= 1.21.0 < 2'
-  * deps: accepts@~1.3.1
-    - deps: mime-types@~2.1.9
-
-1.6.0 / 2015-09-29
-==================
-
-  * Skip compression when response has `Cache-Control: no-transform`
-  * deps: accepts@~1.3.0
-    - deps: mime-types@~2.1.7
-    - deps: negotiator@0.6.0
-  * deps: compressible@~2.0.6
-    - deps: mime-db@'>= 1.19.0 < 2'
-  * deps: on-headers@~1.0.1
-    - perf: enable strict mode
-  * deps: vary@~1.1.0
-    - Only accept valid field names in the `field` argument
-
-1.5.2 / 2015-07-30
-==================
-
-  * deps: accepts@~1.2.12
-    - deps: mime-types@~2.1.4
-  * deps: compressible@~2.0.5
-    - deps: mime-db@'>= 1.16.0 < 2'
-  * deps: vary@~1.0.1
-    - Fix setting empty header from empty `field`
-    - perf: enable strict mode
-    - perf: remove argument reassignments
-
-1.5.1 / 2015-07-05
-==================
-
-  * deps: accepts@~1.2.10
-    - deps: mime-types@~2.1.2
-  * deps: compressible@~2.0.4
-    - deps: mime-db@'>= 1.14.0 < 2'
-    - perf: enable strict mode
-
-1.5.0 / 2015-06-09
-==================
-
-  * Fix return value from `.end` and `.write` after end
-  * Improve detection of zero-length body without `Content-Length`
-  * deps: accepts@~1.2.9
-    - deps: mime-types@~2.1.1
-    - perf: avoid argument reassignment & argument slice
-    - perf: avoid negotiator recursive construction
-    - perf: enable strict mode
-    - perf: remove unnecessary bitwise operator
-  * deps: bytes@2.1.0
-    - Slight optimizations
-    - Units no longer case sensitive when parsing
-  * deps: compressible@~2.0.3
-    - Fix regex fallback to work if type exists, but is undefined
-    - deps: mime-db@'>= 1.13.0 < 2'
-    - perf: hoist regex declaration
-    - perf: use regex to extract mime
-  * perf: enable strict mode
-  * perf: remove flush reassignment
-  * perf: simplify threshold detection
-
-1.4.4 / 2015-05-11
-==================
-
-  * deps: accepts@~1.2.7
-    - deps: mime-types@~2.0.11
-    - deps: negotiator@0.5.3
-  * deps: debug@~2.2.0
-    - deps: ms@0.7.1
-
-1.4.3 / 2015-03-14
-==================
-
-  * deps: accepts@~1.2.5
-    - deps: mime-types@~2.0.10
-  * deps: debug@~2.1.3
-    - Fix high intensity foreground color for bold
-    - deps: ms@0.7.0
-
-1.4.2 / 2015-03-11
-==================
-
-  * Fix error when code calls `res.end(str, encoding)`
-    - Specific to Node.js 0.8
-  * deps: debug@~2.1.2
-    - deps: ms@0.7.0
-
-1.4.1 / 2015-02-15
-==================
-
-  * deps: accepts@~1.2.4
-    - deps: mime-types@~2.0.9
-    - deps: negotiator@0.5.1
-
-1.4.0 / 2015-02-01
-==================
-
-  * Prefer `gzip` over `deflate` on the server
-    - Not all clients agree on what "deflate" coding means
-
-1.3.1 / 2015-01-31
-==================
-
-  * deps: accepts@~1.2.3
-    - deps: mime-types@~2.0.8
-  * deps: compressible@~2.0.2
-    - deps: mime-db@'>= 1.1.2 < 2'
-
-1.3.0 / 2014-12-30
-==================
-
-  * Export the default `filter` function for wrapping
-  * deps: accepts@~1.2.2
-    - deps: mime-types@~2.0.7
-    - deps: negotiator@0.5.0
-  * deps: debug@~2.1.1
-
-1.2.2 / 2014-12-10
-==================
-
-  * Fix `.end` to only proxy to `.end`
-    - Fixes an issue with Node.js 0.11.14
-  * deps: accepts@~1.1.4
-    - deps: mime-types@~2.0.4
-
-1.2.1 / 2014-11-23
-==================
-
-  * deps: accepts@~1.1.3
-    - deps: mime-types@~2.0.3
-
-1.2.0 / 2014-10-16
-==================
-
-  * deps: debug@~2.1.0
-    - Implement `DEBUG_FD` env variable support
-
-1.1.2 / 2014-10-15
-==================
-
-  * deps: accepts@~1.1.2
-    - Fix error when media type has invalid parameter
-    - deps: negotiator@0.4.9
-
-1.1.1 / 2014-10-12
-==================
-
-  * deps: accepts@~1.1.1
-    - deps: mime-types@~2.0.2
-    - deps: negotiator@0.4.8
-  * deps: compressible@~2.0.1
-    - deps: mime-db@1.x
-
-1.1.0 / 2014-09-07
-==================
-
-  * deps: accepts@~1.1.0
-  * deps: compressible@~2.0.0
-  * deps: debug@~2.0.0
-
-1.0.11 / 2014-08-10
-===================
-
-  * deps: on-headers@~1.0.0
-  * deps: vary@~1.0.0
-
-1.0.10 / 2014-08-05
-===================
-
-  * deps: compressible@~1.1.1
-    - Fix upper-case Content-Type characters prevent compression
-
-1.0.9 / 2014-07-20
-==================
-
-  * Add `debug` messages
-  * deps: accepts@~1.0.7
-    - deps: negotiator@0.4.7
-
-1.0.8 / 2014-06-20
-==================
-
-  * deps: accepts@~1.0.5
-    - use `mime-types`
-
-1.0.7 / 2014-06-11
-==================
-
- * use vary module for better `Vary` behavior
- * deps: accepts@1.0.3
- * deps: compressible@1.1.0
-
-1.0.6 / 2014-06-03
-==================
-
- * fix regression when negotiation fails
-
-1.0.5 / 2014-06-03
-==================
-
- * fix listeners for delayed stream creation
-   - fixes regression for certain `stream.pipe(res)` situations
-
-1.0.4 / 2014-06-03
-==================
-
- * fix adding `Vary` when value stored as array
- * fix back-pressure behavior
- * fix length check for `res.end`
-
-1.0.3 / 2014-05-29
-==================
-
- * use `accepts` for negotiation
- * use `on-headers` to handle header checking
- * deps: bytes@1.0.0
-
-1.0.2 / 2014-04-29
-==================
-
- * only version compatible with node.js 0.8
- * support headers given to `res.writeHead`
- * deps: bytes@0.3.0
- * deps: negotiator@0.4.3
-
-1.0.1 / 2014-03-08
-==================
-
- * bump negotiator
- * use compressible
- * use .headersSent (drops 0.8 support)
- * handle identity;q=0 case

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/LICENSE
----------------------------------------------------------------------
diff --git a/node_modules/compression/LICENSE b/node_modules/compression/LICENSE
deleted file mode 100644
index 386b7b6..0000000
--- a/node_modules/compression/LICENSE
+++ /dev/null
@@ -1,23 +0,0 @@
-(The MIT License)
-
-Copyright (c) 2014 Jonathan Ong <me...@jongleberry.com>
-Copyright (c) 2014-2015 Douglas Christopher Wilson <do...@somethingdoug.com>
-
-Permission is hereby granted, free of charge, to any person obtaining
-a copy of this software and associated documentation files (the
-'Software'), to deal in the Software without restriction, including
-without limitation the rights to use, copy, modify, merge, publish,
-distribute, sublicense, and/or sell copies of the Software, and to
-permit persons to whom the Software is furnished to do so, subject to
-the following conditions:
-
-The above copyright notice and this permission notice shall be
-included in all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED 'AS IS', WITHOUT WARRANTY OF ANY KIND,
-EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF
-MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT.
-IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY
-CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT,
-TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE
-SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/README.md
----------------------------------------------------------------------
diff --git a/node_modules/compression/README.md b/node_modules/compression/README.md
deleted file mode 100644
index a5d599d..0000000
--- a/node_modules/compression/README.md
+++ /dev/null
@@ -1,233 +0,0 @@
-# compression
-
-[![NPM Version][npm-image]][npm-url]
-[![NPM Downloads][downloads-image]][downloads-url]
-[![Build Status][travis-image]][travis-url]
-[![Test Coverage][coveralls-image]][coveralls-url]
-[![Gratipay][gratipay-image]][gratipay-url]
-
-Node.js compression middleware.
-
-The following compression codings are supported:
-
-  - deflate
-  - gzip
-
-## Install
-
-```bash
-$ npm install compression
-```
-
-## API
-
-```js
-var compression = require('compression')
-```
-
-### compression([options])
-
-Returns the compression middleware using the given `options`. The middleware
-will attempt to compress response bodies for all request that traverse through
-the middleware, based on the given `options`.
-
-This middleware will never compress responses that include a `Cache-Control`
-header with the [`no-transform` directive](https://tools.ietf.org/html/rfc7234#section-5.2.2.4),
-as compressing will transform the body.
-
-#### Options
-
-`compression()` accepts these properties in the options object. In addition to
-those listed below, [zlib](http://nodejs.org/api/zlib.html) options may be
-passed in to the options object.
-
-##### chunkSize
-
-The default value is `zlib.Z_DEFAULT_CHUNK`, or `16384`.
-
-See [Node.js documentation](http://nodejs.org/api/zlib.html#zlib_memory_usage_tuning)
-regarding the usage.
-
-##### filter
-
-A function to decide if the response should be considered for compression.
-This function is called as `filter(req, res)` and is expected to return
-`true` to consider the response for compression, or `false` to not compress
-the response.
-
-The default filter function uses the [compressible](https://www.npmjs.com/package/compressible)
-module to determine if `res.getHeader('Content-Type')` is compressible.
-
-##### level
-
-The level of zlib compression to apply to responses. A higher level will result
-in better compression, but will take longer to complete. A lower level will
-result in less compression, but will be much faster.
-
-This is an integer in the range of `0` (no compression) to `9` (maximum
-compression). The special value `-1` can be used to mean the "default
-compression level", which is a default compromise between speed and
-compression (currently equivalent to level 6).
-
-  - `-1` Default compression level (also `zlib.Z_DEFAULT_COMPRESSION`).
-  - `0` No compression (also `zlib.Z_NO_COMPRESSION`).
-  - `1` Fastest compression (also `zlib.Z_BEST_SPEED`).
-  - `2`
-  - `3`
-  - `4`
-  - `5`
-  - `6` (currently what `zlib.Z_DEFAULT_COMPRESSION` points to).
-  - `7`
-  - `8`
-  - `9` Best compression (also `zlib.Z_BEST_COMPRESSION`).
-
-The default value is `zlib.Z_DEFAULT_COMPRESSION`, or `-1`.
-
-**Note** in the list above, `zlib` is from `zlib = require('zlib')`.
-
-##### memLevel
-
-This specifies how much memory should be allocated for the internal compression
-state and is an integer in the range of `1` (minimum level) and `9` (maximum
-level).
-
-The default value is `zlib.Z_DEFAULT_MEMLEVEL`, or `8`.
-
-See [Node.js documentation](http://nodejs.org/api/zlib.html#zlib_memory_usage_tuning)
-regarding the usage.
-
-##### strategy
-
-This is used to tune the compression algorithm. This value only affects the
-compression ratio, not the correctness of the compressed output, even if it
-is not set appropriately.
-
-  - `zlib.Z_DEFAULT_STRATEGY` Use for normal data.
-  - `zlib.Z_FILTERED` Use for data produced by a filter (or predictor).
-    Filtered data consists mostly of small values with a somewhat random
-    distribution. In this case, the compression algorithm is tuned to
-    compress them better. The effect is to force more Huffman coding and less
-    string matching; it is somewhat intermediate between `zlib.Z_DEFAULT_STRATEGY`
-    and `zlib.Z_HUFFMAN_ONLY`.
-  - `zlib.Z_FIXED` Use to prevent the use of dynamic Huffman codes, allowing
-    for a simpler decoder for special applications.
-  - `zlib.Z_HUFFMAN_ONLY` Use to force Huffman encoding only (no string match).
-  - `zlib.Z_RLE` Use to limit match distances to one (run-length encoding).
-    This is designed to be almost as fast as `zlib.Z_HUFFMAN_ONLY`, but give
-    better compression for PNG image data.
-
-**Note** in the list above, `zlib` is from `zlib = require('zlib')`.
-
-##### threshold
-
-The byte threshold for the response body size before compression is considered
-for the response, defaults to `1kb`. This is a number of bytes, any string
-accepted by the [bytes](https://www.npmjs.com/package/bytes) module, or `false`.
-
-**Note** this is only an advisory setting; if the response size cannot be determined
-at the time the response headers are written, then it is assumed the response is
-_over_ the threshold. To guarantee the response size can be determined, be sure
-set a `Content-Length` response header.
-
-##### windowBits
-
-The default value is `zlib.Z_DEFAULT_WINDOWBITS`, or `15`.
-
-See [Node.js documentation](http://nodejs.org/api/zlib.html#zlib_memory_usage_tuning)
-regarding the usage.
-
-#### .filter
-
-The default `filter` function. This is used to construct a custom filter
-function that is an extension of the default function.
-
-```js
-app.use(compression({filter: shouldCompress}))
-
-function shouldCompress(req, res) {
-  if (req.headers['x-no-compression']) {
-    // don't compress responses with this request header
-    return false
-  }
-
-  // fallback to standard filter function
-  return compression.filter(req, res)
-}
-```
-
-### res.flush
-
-This module adds a `res.flush()` method to force the partially-compressed
-response to be flushed to the client.
-
-## Examples
-
-### express/connect
-
-When using this module with express or connect, simply `app.use` the module as
-high as you like. Requests that pass through the middleware will be compressed.
-
-```js
-var compression = require('compression')
-var express = require('express')
-
-var app = express()
-
-// compress all requests
-app.use(compression())
-
-// add all routes
-```
-
-### Server-Sent Events
-
-Because of the nature of compression this module does not work out of the box
-with server-sent events. To compress content, a window of the output needs to
-be buffered up in order to get good compression. Typically when using server-sent
-events, there are certain block of data that need to reach the client.
-
-You can achieve this by calling `res.flush()` when you need the data written to
-actually make it to the client.
-
-```js
-var compression = require('compression')
-var express     = require('express')
-
-var app = express()
-
-// compress responses
-app.use(compression())
-
-// server-sent event stream
-app.get('/events', function (req, res) {
-  res.setHeader('Content-Type', 'text/event-stream')
-  res.setHeader('Cache-Control', 'no-cache')
-
-  // send a ping approx every 2 seconds
-  var timer = setInterval(function () {
-    res.write('data: ping\n\n')
-
-    // !!! this is the important part
-    res.flush()
-  }, 2000)
-
-  res.on('close', function () {
-    clearInterval(timer)
-  })
-})
-```
-
-## License
-
-[MIT](LICENSE)
-
-[npm-image]: https://img.shields.io/npm/v/compression.svg
-[npm-url]: https://npmjs.org/package/compression
-[travis-image]: https://img.shields.io/travis/expressjs/compression/master.svg
-[travis-url]: https://travis-ci.org/expressjs/compression
-[coveralls-image]: https://img.shields.io/coveralls/expressjs/compression/master.svg
-[coveralls-url]: https://coveralls.io/r/expressjs/compression?branch=master
-[downloads-image]: https://img.shields.io/npm/dm/compression.svg
-[downloads-url]: https://npmjs.org/package/compression
-[gratipay-image]: https://img.shields.io/gratipay/dougwilson.svg
-[gratipay-url]: https://www.gratipay.com/dougwilson/

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/index.js
----------------------------------------------------------------------
diff --git a/node_modules/compression/index.js b/node_modules/compression/index.js
deleted file mode 100644
index c0e801e..0000000
--- a/node_modules/compression/index.js
+++ /dev/null
@@ -1,276 +0,0 @@
-/*!
- * compression
- * Copyright(c) 2010 Sencha Inc.
- * Copyright(c) 2011 TJ Holowaychuk
- * Copyright(c) 2014 Jonathan Ong
- * Copyright(c) 2014-2015 Douglas Christopher Wilson
- * MIT Licensed
- */
-
-'use strict'
-
-/**
- * Module dependencies.
- * @private
- */
-
-var accepts = require('accepts')
-var bytes = require('bytes')
-var compressible = require('compressible')
-var debug = require('debug')('compression')
-var onHeaders = require('on-headers')
-var vary = require('vary')
-var zlib = require('zlib')
-
-/**
- * Module exports.
- */
-
-module.exports = compression
-module.exports.filter = shouldCompress
-
-/**
- * Module variables.
- * @private
- */
-
-var cacheControlNoTransformRegExp = /(?:^|,)\s*?no-transform\s*?(?:,|$)/
-
-/**
- * Compress response data with gzip / deflate.
- *
- * @param {Object} [options]
- * @return {Function} middleware
- * @public
- */
-
-function compression (options) {
-  var opts = options || {}
-
-  // options
-  var filter = opts.filter || shouldCompress
-  var threshold = bytes.parse(opts.threshold)
-
-  if (threshold == null) {
-    threshold = 1024
-  }
-
-  return function compression (req, res, next) {
-    var ended = false
-    var length
-    var listeners = []
-    var stream
-
-    var _end = res.end
-    var _on = res.on
-    var _write = res.write
-
-    // flush
-    res.flush = function flush () {
-      if (stream) {
-        stream.flush()
-      }
-    }
-
-    // proxy
-
-    res.write = function write (chunk, encoding) {
-      if (ended) {
-        return false
-      }
-
-      if (!this._header) {
-        this._implicitHeader()
-      }
-
-      return stream
-        ? stream.write(new Buffer(chunk, encoding))
-        : _write.call(this, chunk, encoding)
-    }
-
-    res.end = function end (chunk, encoding) {
-      if (ended) {
-        return false
-      }
-
-      if (!this._header) {
-        // estimate the length
-        if (!this.getHeader('Content-Length')) {
-          length = chunkLength(chunk, encoding)
-        }
-
-        this._implicitHeader()
-      }
-
-      if (!stream) {
-        return _end.call(this, chunk, encoding)
-      }
-
-      // mark ended
-      ended = true
-
-      // write Buffer for Node.js 0.8
-      return chunk
-        ? stream.end(new Buffer(chunk, encoding))
-        : stream.end()
-    }
-
-    res.on = function on (type, listener) {
-      if (!listeners || type !== 'drain') {
-        return _on.call(this, type, listener)
-      }
-
-      if (stream) {
-        return stream.on(type, listener)
-      }
-
-      // buffer listeners for future stream
-      listeners.push([type, listener])
-
-      return this
-    }
-
-    function nocompress (msg) {
-      debug('no compression: %s', msg)
-      addListeners(res, _on, listeners)
-      listeners = null
-    }
-
-    onHeaders(res, function onResponseHeaders () {
-      // determine if request is filtered
-      if (!filter(req, res)) {
-        nocompress('filtered')
-        return
-      }
-
-      // determine if the entity should be transformed
-      if (!shouldTransform(req, res)) {
-        nocompress('no transform')
-        return
-      }
-
-      // vary
-      vary(res, 'Accept-Encoding')
-
-      // content-length below threshold
-      if (Number(res.getHeader('Content-Length')) < threshold || length < threshold) {
-        nocompress('size below threshold')
-        return
-      }
-
-      var encoding = res.getHeader('Content-Encoding') || 'identity'
-
-      // already encoded
-      if (encoding !== 'identity') {
-        nocompress('already encoded')
-        return
-      }
-
-      // head
-      if (req.method === 'HEAD') {
-        nocompress('HEAD request')
-        return
-      }
-
-      // compression method
-      var accept = accepts(req)
-      var method = accept.encoding(['gzip', 'deflate', 'identity'])
-
-      // we really don't prefer deflate
-      if (method === 'deflate' && accept.encoding(['gzip'])) {
-        method = accept.encoding(['gzip', 'identity'])
-      }
-
-      // negotiation failed
-      if (!method || method === 'identity') {
-        nocompress('not acceptable')
-        return
-      }
-
-      // compression stream
-      debug('%s compression', method)
-      stream = method === 'gzip'
-        ? zlib.createGzip(opts)
-        : zlib.createDeflate(opts)
-
-      // add buffered listeners to stream
-      addListeners(stream, stream.on, listeners)
-
-      // header fields
-      res.setHeader('Content-Encoding', method)
-      res.removeHeader('Content-Length')
-
-      // compression
-      stream.on('data', function onStreamData (chunk) {
-        if (_write.call(res, chunk) === false) {
-          stream.pause()
-        }
-      })
-
-      stream.on('end', function onStreamEnd () {
-        _end.call(res)
-      })
-
-      _on.call(res, 'drain', function onResponseDrain () {
-        stream.resume()
-      })
-    })
-
-    next()
-  }
-}
-
-/**
- * Add bufferred listeners to stream
- * @private
- */
-
-function addListeners (stream, on, listeners) {
-  for (var i = 0; i < listeners.length; i++) {
-    on.apply(stream, listeners[i])
-  }
-}
-
-/**
- * Get the length of a given chunk
- */
-
-function chunkLength (chunk, encoding) {
-  if (!chunk) {
-    return 0
-  }
-
-  return !Buffer.isBuffer(chunk)
-    ? Buffer.byteLength(chunk, encoding)
-    : chunk.length
-}
-
-/**
- * Default filter function.
- * @private
- */
-
-function shouldCompress (req, res) {
-  var type = res.getHeader('Content-Type')
-
-  if (type === undefined || !compressible(type)) {
-    debug('%s not compressible', type)
-    return false
-  }
-
-  return true
-}
-
-/**
- * Determine if the entity should be transformed.
- * @private
- */
-
-function shouldTransform (req, res) {
-  var cacheControl = res.getHeader('Cache-Control')
-
-  // Don't compress for Cache-Control: no-transform
-  // https://tools.ietf.org/html/rfc7234#section-5.2.2.4
-  return !cacheControl ||
-    !cacheControlNoTransformRegExp.test(cacheControl)
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/.jshintrc
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/.jshintrc b/node_modules/compression/node_modules/debug/.jshintrc
deleted file mode 100644
index 299877f..0000000
--- a/node_modules/compression/node_modules/debug/.jshintrc
+++ /dev/null
@@ -1,3 +0,0 @@
-{
-  "laxbreak": true
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/.npmignore
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/.npmignore b/node_modules/compression/node_modules/debug/.npmignore
deleted file mode 100644
index 7e6163d..0000000
--- a/node_modules/compression/node_modules/debug/.npmignore
+++ /dev/null
@@ -1,6 +0,0 @@
-support
-test
-examples
-example
-*.sock
-dist

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/History.md
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/History.md b/node_modules/compression/node_modules/debug/History.md
deleted file mode 100644
index 854c971..0000000
--- a/node_modules/compression/node_modules/debug/History.md
+++ /dev/null
@@ -1,195 +0,0 @@
-
-2.2.0 / 2015-05-09
-==================
-
-  * package: update "ms" to v0.7.1 (#202, @dougwilson)
-  * README: add logging to file example (#193, @DanielOchoa)
-  * README: fixed a typo (#191, @amir-s)
-  * browser: expose `storage` (#190, @stephenmathieson)
-  * Makefile: add a `distclean` target (#189, @stephenmathieson)
-
-2.1.3 / 2015-03-13
-==================
-
-  * Updated stdout/stderr example (#186)
-  * Updated example/stdout.js to match debug current behaviour
-  * Renamed example/stderr.js to stdout.js
-  * Update Readme.md (#184)
-  * replace high intensity foreground color for bold (#182, #183)
-
-2.1.2 / 2015-03-01
-==================
-
-  * dist: recompile
-  * update "ms" to v0.7.0
-  * package: update "browserify" to v9.0.3
-  * component: fix "ms.js" repo location
-  * changed bower package name
-  * updated documentation about using debug in a browser
-  * fix: security error on safari (#167, #168, @yields)
-
-2.1.1 / 2014-12-29
-==================
-
-  * browser: use `typeof` to check for `console` existence
-  * browser: check for `console.log` truthiness (fix IE 8/9)
-  * browser: add support for Chrome apps
-  * Readme: added Windows usage remarks
-  * Add `bower.json` to properly support bower install
-
-2.1.0 / 2014-10-15
-==================
-
-  * node: implement `DEBUG_FD` env variable support
-  * package: update "browserify" to v6.1.0
-  * package: add "license" field to package.json (#135, @panuhorsmalahti)
-
-2.0.0 / 2014-09-01
-==================
-
-  * package: update "browserify" to v5.11.0
-  * node: use stderr rather than stdout for logging (#29, @stephenmathieson)
-
-1.0.4 / 2014-07-15
-==================
-
-  * dist: recompile
-  * example: remove `console.info()` log usage
-  * example: add "Content-Type" UTF-8 header to browser example
-  * browser: place %c marker after the space character
-  * browser: reset the "content" color via `color: inherit`
-  * browser: add colors support for Firefox >= v31
-  * debug: prefer an instance `log()` function over the global one (#119)
-  * Readme: update documentation about styled console logs for FF v31 (#116, @wryk)
-
-1.0.3 / 2014-07-09
-==================
-
-  * Add support for multiple wildcards in namespaces (#122, @seegno)
-  * browser: fix lint
-
-1.0.2 / 2014-06-10
-==================
-
-  * browser: update color palette (#113, @gscottolson)
-  * common: make console logging function configurable (#108, @timoxley)
-  * node: fix %o colors on old node <= 0.8.x
-  * Makefile: find node path using shell/which (#109, @timoxley)
-
-1.0.1 / 2014-06-06
-==================
-
-  * browser: use `removeItem()` to clear localStorage
-  * browser, node: don't set DEBUG if namespaces is undefined (#107, @leedm777)
-  * package: add "contributors" section
-  * node: fix comment typo
-  * README: list authors
-
-1.0.0 / 2014-06-04
-==================
-
-  * make ms diff be global, not be scope
-  * debug: ignore empty strings in enable()
-  * node: make DEBUG_COLORS able to disable coloring
-  * *: export the `colors` array
-  * npmignore: don't publish the `dist` dir
-  * Makefile: refactor to use browserify
-  * package: add "browserify" as a dev dependency
-  * Readme: add Web Inspector Colors section
-  * node: reset terminal color for the debug content
-  * node: map "%o" to `util.inspect()`
-  * browser: map "%j" to `JSON.stringify()`
-  * debug: add custom "formatters"
-  * debug: use "ms" module for humanizing the diff
-  * Readme: add "bash" syntax highlighting
-  * browser: add Firebug color support
-  * browser: add colors for WebKit browsers
-  * node: apply log to `console`
-  * rewrite: abstract common logic for Node & browsers
-  * add .jshintrc file
-
-0.8.1 / 2014-04-14
-==================
-
-  * package: re-add the "component" section
-
-0.8.0 / 2014-03-30
-==================
-
-  * add `enable()` method for nodejs. Closes #27
-  * change from stderr to stdout
-  * remove unnecessary index.js file
-
-0.7.4 / 2013-11-13
-==================
-
-  * remove "browserify" key from package.json (fixes something in browserify)
-
-0.7.3 / 2013-10-30
-==================
-
-  * fix: catch localStorage security error when cookies are blocked (Chrome)
-  * add debug(err) support. Closes #46
-  * add .browser prop to package.json. Closes #42
-
-0.7.2 / 2013-02-06
-==================
-
-  * fix package.json
-  * fix: Mobile Safari (private mode) is broken with debug
-  * fix: Use unicode to send escape character to shell instead of octal to work with strict mode javascript
-
-0.7.1 / 2013-02-05
-==================
-
-  * add repository URL to package.json
-  * add DEBUG_COLORED to force colored output
-  * add browserify support
-  * fix component. Closes #24
-
-0.7.0 / 2012-05-04
-==================
-
-  * Added .component to package.json
-  * Added debug.component.js build
-
-0.6.0 / 2012-03-16
-==================
-
-  * Added support for "-" prefix in DEBUG [Vinay Pulim]
-  * Added `.enabled` flag to the node version [TooTallNate]
-
-0.5.0 / 2012-02-02
-==================
-
-  * Added: humanize diffs. Closes #8
-  * Added `debug.disable()` to the CS variant
-  * Removed padding. Closes #10
-  * Fixed: persist client-side variant again. Closes #9
-
-0.4.0 / 2012-02-01
-==================
-
-  * Added browser variant support for older browsers [TooTallNate]
-  * Added `debug.enable('project:*')` to browser variant [TooTallNate]
-  * Added padding to diff (moved it to the right)
-
-0.3.0 / 2012-01-26
-==================
-
-  * Added millisecond diff when isatty, otherwise UTC string
-
-0.2.0 / 2012-01-22
-==================
-
-  * Added wildcard support
-
-0.1.0 / 2011-12-02
-==================
-
-  * Added: remove colors unless stderr isatty [TooTallNate]
-
-0.0.1 / 2010-01-03
-==================
-
-  * Initial release

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/Makefile
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/Makefile b/node_modules/compression/node_modules/debug/Makefile
deleted file mode 100644
index 5cf4a59..0000000
--- a/node_modules/compression/node_modules/debug/Makefile
+++ /dev/null
@@ -1,36 +0,0 @@
-
-# get Makefile directory name: http://stackoverflow.com/a/5982798/376773
-THIS_MAKEFILE_PATH:=$(word $(words $(MAKEFILE_LIST)),$(MAKEFILE_LIST))
-THIS_DIR:=$(shell cd $(dir $(THIS_MAKEFILE_PATH));pwd)
-
-# BIN directory
-BIN := $(THIS_DIR)/node_modules/.bin
-
-# applications
-NODE ?= $(shell which node)
-NPM ?= $(NODE) $(shell which npm)
-BROWSERIFY ?= $(NODE) $(BIN)/browserify
-
-all: dist/debug.js
-
-install: node_modules
-
-clean:
-	@rm -rf dist
-
-dist:
-	@mkdir -p $@
-
-dist/debug.js: node_modules browser.js debug.js dist
-	@$(BROWSERIFY) \
-		--standalone debug \
-		. > $@
-
-distclean: clean
-	@rm -rf node_modules
-
-node_modules: package.json
-	@NODE_ENV= $(NPM) install
-	@touch node_modules
-
-.PHONY: all install clean distclean

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/Readme.md
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/Readme.md b/node_modules/compression/node_modules/debug/Readme.md
deleted file mode 100644
index b4f45e3..0000000
--- a/node_modules/compression/node_modules/debug/Readme.md
+++ /dev/null
@@ -1,188 +0,0 @@
-# debug
-
-  tiny node.js debugging utility modelled after node core's debugging technique.
-
-## Installation
-
-```bash
-$ npm install debug
-```
-
-## Usage
-
- With `debug` you simply invoke the exported function to generate your debug function, passing it a name which will determine if a noop function is returned, or a decorated `console.error`, so all of the `console` format string goodies you're used to work fine. A unique color is selected per-function for visibility.
-
-Example _app.js_:
-
-```js
-var debug = require('debug')('http')
-  , http = require('http')
-  , name = 'My App';
-
-// fake app
-
-debug('booting %s', name);
-
-http.createServer(function(req, res){
-  debug(req.method + ' ' + req.url);
-  res.end('hello\n');
-}).listen(3000, function(){
-  debug('listening');
-});
-
-// fake worker of some kind
-
-require('./worker');
-```
-
-Example _worker.js_:
-
-```js
-var debug = require('debug')('worker');
-
-setInterval(function(){
-  debug('doing some work');
-}, 1000);
-```
-
- The __DEBUG__ environment variable is then used to enable these based on space or comma-delimited names. Here are some examples:
-
-  ![debug http and worker](http://f.cl.ly/items/18471z1H402O24072r1J/Screenshot.png)
-
-  ![debug worker](http://f.cl.ly/items/1X413v1a3M0d3C2c1E0i/Screenshot.png)
-
-#### Windows note
-
- On Windows the environment variable is set using the `set` command.
-
- ```cmd
- set DEBUG=*,-not_this
- ```
-
-Then, run the program to be debugged as usual.
-
-## Millisecond diff
-
-  When actively developing an application it can be useful to see when the time spent between one `debug()` call and the next. Suppose for example you invoke `debug()` before requesting a resource, and after as well, the "+NNNms" will show you how much time was spent between calls.
-
-  ![](http://f.cl.ly/items/2i3h1d3t121M2Z1A3Q0N/Screenshot.png)
-
-  When stdout is not a TTY, `Date#toUTCString()` is used, making it more useful for logging the debug information as shown below:
-
-  ![](http://f.cl.ly/items/112H3i0e0o0P0a2Q2r11/Screenshot.png)
-
-## Conventions
-
- If you're using this in one or more of your libraries, you _should_ use the name of your library so that developers may toggle debugging as desired without guessing names. If you have more than one debuggers you _should_ prefix them with your library name and use ":" to separate features. For example "bodyParser" from Connect would then be "connect:bodyParser".
-
-## Wildcards
-
-  The `*` character may be used as a wildcard. Suppose for example your library has debuggers named "connect:bodyParser", "connect:compress", "connect:session", instead of listing all three with `DEBUG=connect:bodyParser,connect:compress,connect:session`, you may simply do `DEBUG=connect:*`, or to run everything using this module simply use `DEBUG=*`.
-
-  You can also exclude specific debuggers by prefixing them with a "-" character.  For example, `DEBUG=*,-connect:*` would include all debuggers except those starting with "connect:".
-
-## Browser support
-
-  Debug works in the browser as well, currently persisted by `localStorage`. Consider the situation shown below where you have `worker:a` and `worker:b`, and wish to debug both. Somewhere in the code on your page, include:
-
-```js
-window.myDebug = require("debug");
-```
-
-  ("debug" is a global object in the browser so we give this object a different name.) When your page is open in the browser, type the following in the console:
-
-```js
-myDebug.enable("worker:*")
-```
-
-  Refresh the page. Debug output will continue to be sent to the console until it is disabled by typing `myDebug.disable()` in the console.
-
-```js
-a = debug('worker:a');
-b = debug('worker:b');
-
-setInterval(function(){
-  a('doing some work');
-}, 1000);
-
-setInterval(function(){
-  b('doing some work');
-}, 1200);
-```
-
-#### Web Inspector Colors
-
-  Colors are also enabled on "Web Inspectors" that understand the `%c` formatting
-  option. These are WebKit web inspectors, Firefox ([since version
-  31](https://hacks.mozilla.org/2014/05/editable-box-model-multiple-selection-sublime-text-keys-much-more-firefox-developer-tools-episode-31/))
-  and the Firebug plugin for Firefox (any version).
-
-  Colored output looks something like:
-
-  ![](https://cloud.githubusercontent.com/assets/71256/3139768/b98c5fd8-e8ef-11e3-862a-f7253b6f47c6.png)
-
-### stderr vs stdout
-
-You can set an alternative logging method per-namespace by overriding the `log` method on a per-namespace or globally:
-
-Example _stdout.js_:
-
-```js
-var debug = require('debug');
-var error = debug('app:error');
-
-// by default stderr is used
-error('goes to stderr!');
-
-var log = debug('app:log');
-// set this namespace to log via console.log
-log.log = console.log.bind(console); // don't forget to bind to console!
-log('goes to stdout');
-error('still goes to stderr!');
-
-// set all output to go via console.info
-// overrides all per-namespace log settings
-debug.log = console.info.bind(console);
-error('now goes to stdout via console.info');
-log('still goes to stdout, but via console.info now');
-```
-
-### Save debug output to a file
-
-You can save all debug statements to a file by piping them.
-
-Example:
-
-```bash
-$ DEBUG_FD=3 node your-app.js 3> whatever.log
-```
-
-## Authors
-
- - TJ Holowaychuk
- - Nathan Rajlich
-
-## License
-
-(The MIT License)
-
-Copyright (c) 2014 TJ Holowaychuk &lt;tj@vision-media.ca&gt;
-
-Permission is hereby granted, free of charge, to any person obtaining
-a copy of this software and associated documentation files (the
-'Software'), to deal in the Software without restriction, including
-without limitation the rights to use, copy, modify, merge, publish,
-distribute, sublicense, and/or sell copies of the Software, and to
-permit persons to whom the Software is furnished to do so, subject to
-the following conditions:
-
-The above copyright notice and this permission notice shall be
-included in all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED 'AS IS', WITHOUT WARRANTY OF ANY KIND,
-EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF
-MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT.
-IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY
-CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT,
-TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE
-SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/bower.json
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/bower.json b/node_modules/compression/node_modules/debug/bower.json
deleted file mode 100644
index 6af573f..0000000
--- a/node_modules/compression/node_modules/debug/bower.json
+++ /dev/null
@@ -1,28 +0,0 @@
-{
-  "name": "visionmedia-debug",
-  "main": "dist/debug.js",
-  "version": "2.2.0",
-  "homepage": "https://github.com/visionmedia/debug",
-  "authors": [
-    "TJ Holowaychuk <tj...@vision-media.ca>"
-  ],
-  "description": "visionmedia-debug",
-  "moduleType": [
-    "amd",
-    "es6",
-    "globals",
-    "node"
-  ],
-  "keywords": [
-    "visionmedia",
-    "debug"
-  ],
-  "license": "MIT",
-  "ignore": [
-    "**/.*",
-    "node_modules",
-    "bower_components",
-    "test",
-    "tests"
-  ]
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/browser.js
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/browser.js b/node_modules/compression/node_modules/debug/browser.js
deleted file mode 100644
index 7c76452..0000000
--- a/node_modules/compression/node_modules/debug/browser.js
+++ /dev/null
@@ -1,168 +0,0 @@
-
-/**
- * This is the web browser implementation of `debug()`.
- *
- * Expose `debug()` as the module.
- */
-
-exports = module.exports = require('./debug');
-exports.log = log;
-exports.formatArgs = formatArgs;
-exports.save = save;
-exports.load = load;
-exports.useColors = useColors;
-exports.storage = 'undefined' != typeof chrome
-               && 'undefined' != typeof chrome.storage
-                  ? chrome.storage.local
-                  : localstorage();
-
-/**
- * Colors.
- */
-
-exports.colors = [
-  'lightseagreen',
-  'forestgreen',
-  'goldenrod',
-  'dodgerblue',
-  'darkorchid',
-  'crimson'
-];
-
-/**
- * Currently only WebKit-based Web Inspectors, Firefox >= v31,
- * and the Firebug extension (any Firefox version) are known
- * to support "%c" CSS customizations.
- *
- * TODO: add a `localStorage` variable to explicitly enable/disable colors
- */
-
-function useColors() {
-  // is webkit? http://stackoverflow.com/a/16459606/376773
-  return ('WebkitAppearance' in document.documentElement.style) ||
-    // is firebug? http://stackoverflow.com/a/398120/376773
-    (window.console && (console.firebug || (console.exception && console.table))) ||
-    // is firefox >= v31?
-    // https://developer.mozilla.org/en-US/docs/Tools/Web_Console#Styling_messages
-    (navigator.userAgent.toLowerCase().match(/firefox\/(\d+)/) && parseInt(RegExp.$1, 10) >= 31);
-}
-
-/**
- * Map %j to `JSON.stringify()`, since no Web Inspectors do that by default.
- */
-
-exports.formatters.j = function(v) {
-  return JSON.stringify(v);
-};
-
-
-/**
- * Colorize log arguments if enabled.
- *
- * @api public
- */
-
-function formatArgs() {
-  var args = arguments;
-  var useColors = this.useColors;
-
-  args[0] = (useColors ? '%c' : '')
-    + this.namespace
-    + (useColors ? ' %c' : ' ')
-    + args[0]
-    + (useColors ? '%c ' : ' ')
-    + '+' + exports.humanize(this.diff);
-
-  if (!useColors) return args;
-
-  var c = 'color: ' + this.color;
-  args = [args[0], c, 'color: inherit'].concat(Array.prototype.slice.call(args, 1));
-
-  // the final "%c" is somewhat tricky, because there could be other
-  // arguments passed either before or after the %c, so we need to
-  // figure out the correct index to insert the CSS into
-  var index = 0;
-  var lastC = 0;
-  args[0].replace(/%[a-z%]/g, function(match) {
-    if ('%%' === match) return;
-    index++;
-    if ('%c' === match) {
-      // we only are interested in the *last* %c
-      // (the user may have provided their own)
-      lastC = index;
-    }
-  });
-
-  args.splice(lastC, 0, c);
-  return args;
-}
-
-/**
- * Invokes `console.log()` when available.
- * No-op when `console.log` is not a "function".
- *
- * @api public
- */
-
-function log() {
-  // this hackery is required for IE8/9, where
-  // the `console.log` function doesn't have 'apply'
-  return 'object' === typeof console
-    && console.log
-    && Function.prototype.apply.call(console.log, console, arguments);
-}
-
-/**
- * Save `namespaces`.
- *
- * @param {String} namespaces
- * @api private
- */
-
-function save(namespaces) {
-  try {
-    if (null == namespaces) {
-      exports.storage.removeItem('debug');
-    } else {
-      exports.storage.debug = namespaces;
-    }
-  } catch(e) {}
-}
-
-/**
- * Load `namespaces`.
- *
- * @return {String} returns the previously persisted debug modes
- * @api private
- */
-
-function load() {
-  var r;
-  try {
-    r = exports.storage.debug;
-  } catch(e) {}
-  return r;
-}
-
-/**
- * Enable namespaces listed in `localStorage.debug` initially.
- */
-
-exports.enable(load());
-
-/**
- * Localstorage attempts to return the localstorage.
- *
- * This is necessary because safari throws
- * when a user disables cookies/localstorage
- * and you attempt to access it.
- *
- * @return {LocalStorage}
- * @api private
- */
-
-function localstorage(){
-  try {
-    return window.localStorage;
-  } catch (e) {}
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/compression/node_modules/debug/component.json
----------------------------------------------------------------------
diff --git a/node_modules/compression/node_modules/debug/component.json b/node_modules/compression/node_modules/debug/component.json
deleted file mode 100644
index ca10637..0000000
--- a/node_modules/compression/node_modules/debug/component.json
+++ /dev/null
@@ -1,19 +0,0 @@
-{
-  "name": "debug",
-  "repo": "visionmedia/debug",
-  "description": "small debugging utility",
-  "version": "2.2.0",
-  "keywords": [
-    "debug",
-    "log",
-    "debugger"
-  ],
-  "main": "browser.js",
-  "scripts": [
-    "browser.js",
-    "debug.js"
-  ],
-  "dependencies": {
-    "rauchg/ms.js": "0.7.1"
-  }
-}