You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cordova.apache.org by st...@apache.org on 2016/08/01 22:22:47 UTC

[28/61] [abbrv] [partial] cordova-create git commit: gitignore node modules

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/head.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/head.js b/node_modules/cordova-fetch/node_modules/shelljs/src/head.js
deleted file mode 100644
index 29474b5..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/head.js
+++ /dev/null
@@ -1,96 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-// This reads n or more lines, or the entire file, whichever is less.
-function readSomeLines(file, numLines) {
-  var BUF_LENGTH = 64*1024,
-      buf = new Buffer(BUF_LENGTH),
-      bytesRead = BUF_LENGTH,
-      pos = 0,
-      fdr = null;
-
-  try {
-    fdr = fs.openSync(file, 'r');
-  } catch(e) {
-    common.error('cannot read file: ' + file);
-  }
-
-  var numLinesRead = 0;
-  var ret = '';
-  while (bytesRead === BUF_LENGTH && numLinesRead < numLines) {
-    bytesRead = fs.readSync(fdr, buf, 0, BUF_LENGTH, pos);
-    var bufStr = buf.toString('utf8', 0, bytesRead);
-    numLinesRead += bufStr.split('\n').length - 1;
-    ret += bufStr;
-    pos += bytesRead;
-  }
-
-  fs.closeSync(fdr);
-  return ret;
-}
-//@
-//@ ### head([{'-n', \<num\>},] file [, file ...])
-//@ ### head([{'-n', \<num\>},] file_array)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ var str = head({'-n', 1}, 'file*.txt');
-//@ var str = head('file1', 'file2');
-//@ var str = head(['file1', 'file2']); // same as above
-//@ ```
-//@
-//@ Output the first 10 lines of a file (or the first `<num>` if `-n` is
-//@ specified)
-function _head(options, files) {
-  options = common.parseOptions(options, {
-    'n': 'numLines'
-  });
-  var head = [];
-  var pipe = common.readFromPipe(this);
-
-  if (!files && !pipe)
-    common.error('no paths given');
-
-  var idx = 1;
-  if (options.numLines === true) {
-    idx = 2;
-    options.numLines = Number(arguments[1]);
-  } else if (options.numLines === false) {
-    options.numLines = 10;
-  }
-  files = [].slice.call(arguments, idx);
-
-  if (pipe)
-    files.unshift('-');
-
-  var shouldAppendNewline = false;
-  files.forEach(function(file) {
-    if (!fs.existsSync(file) && file !== '-') {
-      common.error('no such file or directory: ' + file, true);
-      return;
-    }
-
-    var contents;
-    if (file === '-')
-      contents = pipe;
-    else if (options.numLines < 0) {
-      contents = fs.readFileSync(file, 'utf8');
-    } else {
-      contents = readSomeLines(file, options.numLines);
-    }
-
-    var lines = contents.split('\n');
-    var hasTrailingNewline = (lines[lines.length-1] === '');
-    if (hasTrailingNewline)
-      lines.pop();
-    shouldAppendNewline = (hasTrailingNewline || options.numLines < lines.length);
-
-    head = head.concat(lines.slice(0, options.numLines));
-  });
-
-  if (shouldAppendNewline)
-    head.push(''); // to add a trailing newline once we join
-  return new common.ShellString(head.join('\n'), common.state.error, common.state.errorCode);
-}
-module.exports = _head;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/ln.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/ln.js b/node_modules/cordova-fetch/node_modules/shelljs/src/ln.js
deleted file mode 100644
index 32aea44..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/ln.js
+++ /dev/null
@@ -1,70 +0,0 @@
-var fs = require('fs');
-var path = require('path');
-var common = require('./common');
-
-//@
-//@ ### ln([options,] source, dest)
-//@ Available options:
-//@
-//@ + `-s`: symlink
-//@ + `-f`: force
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ ln('file', 'newlink');
-//@ ln('-sf', 'file', 'existing');
-//@ ```
-//@
-//@ Links source to dest. Use -f to force the link, should dest already exist.
-function _ln(options, source, dest) {
-  options = common.parseOptions(options, {
-    's': 'symlink',
-    'f': 'force'
-  });
-
-  if (!source || !dest) {
-    common.error('Missing <source> and/or <dest>');
-  }
-
-  source = String(source);
-  var sourcePath = path.normalize(source).replace(RegExp(path.sep + '$'), '');
-  var isAbsolute = (path.resolve(source) === sourcePath);
-  dest = path.resolve(process.cwd(), String(dest));
-
-  if (fs.existsSync(dest)) {
-    if (!options.force) {
-      common.error('Destination file exists', true);
-    }
-
-    fs.unlinkSync(dest);
-  }
-
-  if (options.symlink) {
-    var isWindows = common.platform === 'win';
-    var linkType = isWindows ? 'file' : null;
-    var resolvedSourcePath = isAbsolute ? sourcePath : path.resolve(process.cwd(), path.dirname(dest), source);
-    if (!fs.existsSync(resolvedSourcePath)) {
-      common.error('Source file does not exist', true);
-    } else if (isWindows && fs.statSync(resolvedSourcePath).isDirectory()) {
-      linkType =  'junction';
-    }
-
-    try {
-      fs.symlinkSync(linkType === 'junction' ? resolvedSourcePath: source, dest, linkType);
-    } catch (err) {
-      common.error(err.message);
-    }
-  } else {
-    if (!fs.existsSync(source)) {
-      common.error('Source file does not exist', true);
-    }
-    try {
-      fs.linkSync(source, dest);
-    } catch (err) {
-      common.error(err.message);
-    }
-  }
-  return new common.ShellString('', common.state.error, common.state.errorCode);
-}
-module.exports = _ln;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/ls.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/ls.js b/node_modules/cordova-fetch/node_modules/shelljs/src/ls.js
deleted file mode 100644
index da40b7e..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/ls.js
+++ /dev/null
@@ -1,116 +0,0 @@
-var path = require('path');
-var fs = require('fs');
-var common = require('./common');
-var glob = require('glob');
-
-var globPatternRecursive = path.sep + '**' + path.sep + '*';
-
-//@
-//@ ### ls([options,] [path, ...])
-//@ ### ls([options,] path_array)
-//@ Available options:
-//@
-//@ + `-R`: recursive
-//@ + `-A`: all files (include files beginning with `.`, except for `.` and `..`)
-//@ + `-d`: list directories themselves, not their contents
-//@ + `-l`: list objects representing each file, each with fields containing `ls
-//@         -l` output fields. See
-//@         [fs.Stats](https://nodejs.org/api/fs.html#fs_class_fs_stats)
-//@         for more info
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ ls('projs/*.js');
-//@ ls('-R', '/users/me', '/tmp');
-//@ ls('-R', ['/users/me', '/tmp']); // same as above
-//@ ls('-l', 'file.txt'); // { name: 'file.txt', mode: 33188, nlink: 1, ...}
-//@ ```
-//@
-//@ Returns array of files in the given path, or in current directory if no path provided.
-function _ls(options, paths) {
-  options = common.parseOptions(options, {
-    'R': 'recursive',
-    'A': 'all',
-    'a': 'all_deprecated',
-    'd': 'directory',
-    'l': 'long'
-  });
-
-  if (options.all_deprecated) {
-    // We won't support the -a option as it's hard to image why it's useful
-    // (it includes '.' and '..' in addition to '.*' files)
-    // For backwards compatibility we'll dump a deprecated message and proceed as before
-    common.log('ls: Option -a is deprecated. Use -A instead');
-    options.all = true;
-  }
-
-  if (!paths)
-    paths = ['.'];
-  else
-    paths = [].slice.call(arguments, 1);
-
-  var list = [];
-
-  function pushFile(abs, relName, stat) {
-    if (process.platform === 'win32')
-      relName = relName.replace(/\\/g, '/');
-    if (options.long) {
-      stat = stat || fs.lstatSync(abs);
-      list.push(addLsAttributes(relName, stat));
-    } else {
-      // list.push(path.relative(rel || '.', file));
-      list.push(relName);
-    }
-  }
-
-  paths.forEach(function(p) {
-    var stat;
-
-    try {
-      stat = fs.lstatSync(p);
-    } catch (e) {
-      common.error('no such file or directory: ' + p, 2, true);
-      return;
-    }
-
-    // If the stat succeeded
-    if (stat.isDirectory() && !options.directory) {
-      if (options.recursive) {
-        // use glob, because it's simple
-        glob.sync(p + globPatternRecursive, { dot: options.all })
-          .forEach(function (item) {
-          pushFile(item, path.relative(p, item));
-        });
-      } else if (options.all) {
-        // use fs.readdirSync, because it's fast
-        fs.readdirSync(p).forEach(function (item) {
-          pushFile(path.join(p, item), item);
-        });
-      } else {
-        // use fs.readdirSync and then filter out secret files
-        fs.readdirSync(p).forEach(function (item) {
-          if (item[0] !== '.')
-            pushFile(path.join(p, item), item);
-        });
-      }
-    } else {
-      pushFile(p, p, stat);
-    }
-  });
-
-  // Add methods, to make this more compatible with ShellStrings
-  return new common.ShellString(list, common.state.error, common.state.errorCode);
-}
-
-function addLsAttributes(path, stats) {
-  // Note: this object will contain more information than .toString() returns
-  stats.name = path;
-  stats.toString = function() {
-    // Return a string resembling unix's `ls -l` format
-    return [this.mode, this.nlink, this.uid, this.gid, this.size, this.mtime, this.name].join(' ');
-  };
-  return stats;
-}
-
-module.exports = _ls;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/mkdir.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/mkdir.js b/node_modules/cordova-fetch/node_modules/shelljs/src/mkdir.js
deleted file mode 100644
index 48c341f..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/mkdir.js
+++ /dev/null
@@ -1,72 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-var path = require('path');
-
-// Recursively creates 'dir'
-function mkdirSyncRecursive(dir) {
-  var baseDir = path.dirname(dir);
-
-  // Base dir exists, no recursion necessary
-  if (fs.existsSync(baseDir)) {
-    fs.mkdirSync(dir, parseInt('0777', 8));
-    return;
-  }
-
-  // Base dir does not exist, go recursive
-  mkdirSyncRecursive(baseDir);
-
-  // Base dir created, can create dir
-  fs.mkdirSync(dir, parseInt('0777', 8));
-}
-
-//@
-//@ ### mkdir([options,] dir [, dir ...])
-//@ ### mkdir([options,] dir_array)
-//@ Available options:
-//@
-//@ + `-p`: full path (will create intermediate dirs if necessary)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ mkdir('-p', '/tmp/a/b/c/d', '/tmp/e/f/g');
-//@ mkdir('-p', ['/tmp/a/b/c/d', '/tmp/e/f/g']); // same as above
-//@ ```
-//@
-//@ Creates directories.
-function _mkdir(options, dirs) {
-  options = common.parseOptions(options, {
-    'p': 'fullpath'
-  });
-  if (!dirs)
-    common.error('no paths given');
-
-  if (typeof dirs === 'string')
-    dirs = [].slice.call(arguments, 1);
-  // if it's array leave it as it is
-
-  dirs.forEach(function(dir) {
-    try {
-      fs.lstatSync(dir);
-      if (!options.fullpath)
-        common.error('path already exists: ' + dir, true);
-      return; // skip dir
-    } catch (e) {
-      // do nothing
-    }
-
-    // Base dir does not exist, and no -p option given
-    var baseDir = path.dirname(dir);
-    if (!fs.existsSync(baseDir) && !options.fullpath) {
-      common.error('no such file or directory: ' + baseDir, true);
-      return; // skip dir
-    }
-
-    if (options.fullpath)
-      mkdirSyncRecursive(dir);
-    else
-      fs.mkdirSync(dir, parseInt('0777', 8));
-  });
-  return new common.ShellString('', common.state.error, common.state.errorCode);
-} // mkdir
-module.exports = _mkdir;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/mv.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/mv.js b/node_modules/cordova-fetch/node_modules/shelljs/src/mv.js
deleted file mode 100644
index 495dc43..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/mv.js
+++ /dev/null
@@ -1,79 +0,0 @@
-var fs = require('fs');
-var path = require('path');
-var common = require('./common');
-
-//@
-//@ ### mv([options ,] source [, source ...], dest')
-//@ ### mv([options ,] source_array, dest')
-//@ Available options:
-//@
-//@ + `-f`: force (default behavior)
-//@ + `-n`: no-clobber
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ mv('-n', 'file', 'dir/');
-//@ mv('file1', 'file2', 'dir/');
-//@ mv(['file1', 'file2'], 'dir/'); // same as above
-//@ ```
-//@
-//@ Moves files.
-function _mv(options, sources, dest) {
-  options = common.parseOptions(options, {
-    'f': '!no_force',
-    'n': 'no_force'
-  });
-
-  // Get sources, dest
-  if (arguments.length < 3) {
-    common.error('missing <source> and/or <dest>');
-  } else if (arguments.length > 3) {
-    sources = [].slice.call(arguments, 1, arguments.length - 1);
-    dest = arguments[arguments.length - 1];
-  } else if (typeof sources === 'string') {
-    sources = [sources];
-  } else {
-    common.error('invalid arguments');
-  }
-
-  var exists = fs.existsSync(dest),
-      stats = exists && fs.statSync(dest);
-
-  // Dest is not existing dir, but multiple sources given
-  if ((!exists || !stats.isDirectory()) && sources.length > 1)
-    common.error('dest is not a directory (too many sources)');
-
-  // Dest is an existing file, but no -f given
-  if (exists && stats.isFile() && options.no_force)
-    common.error('dest file already exists: ' + dest);
-
-  sources.forEach(function(src) {
-    if (!fs.existsSync(src)) {
-      common.error('no such file or directory: '+src, true);
-      return; // skip file
-    }
-
-    // If here, src exists
-
-    // When copying to '/path/dir':
-    //    thisDest = '/path/dir/file1'
-    var thisDest = dest;
-    if (fs.existsSync(dest) && fs.statSync(dest).isDirectory())
-      thisDest = path.normalize(dest + '/' + path.basename(src));
-
-    if (fs.existsSync(thisDest) && options.no_force) {
-      common.error('dest file already exists: ' + thisDest, true);
-      return; // skip file
-    }
-
-    if (path.resolve(src) === path.dirname(path.resolve(thisDest))) {
-      common.error('cannot move to self: '+src, true);
-      return; // skip file
-    }
-
-    fs.renameSync(src, thisDest);
-  }); // forEach(src)
-  return new common.ShellString('', common.state.error, common.state.errorCode);
-} // mv
-module.exports = _mv;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/popd.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/popd.js b/node_modules/cordova-fetch/node_modules/shelljs/src/popd.js
deleted file mode 100644
index 11ea24f..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/popd.js
+++ /dev/null
@@ -1 +0,0 @@
-// see dirs.js
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/pushd.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/pushd.js b/node_modules/cordova-fetch/node_modules/shelljs/src/pushd.js
deleted file mode 100644
index 11ea24f..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/pushd.js
+++ /dev/null
@@ -1 +0,0 @@
-// see dirs.js
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/pwd.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/pwd.js b/node_modules/cordova-fetch/node_modules/shelljs/src/pwd.js
deleted file mode 100644
index 3bc310d..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/pwd.js
+++ /dev/null
@@ -1,11 +0,0 @@
-var path = require('path');
-var common = require('./common');
-
-//@
-//@ ### pwd()
-//@ Returns the current directory.
-function _pwd() {
-  var pwd = path.resolve(process.cwd());
-  return new common.ShellString(pwd, '', common.state.errorCode);
-}
-module.exports = _pwd;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/rm.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/rm.js b/node_modules/cordova-fetch/node_modules/shelljs/src/rm.js
deleted file mode 100644
index 2780285..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/rm.js
+++ /dev/null
@@ -1,150 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-// Recursively removes 'dir'
-// Adapted from https://github.com/ryanmcgrath/wrench-js
-//
-// Copyright (c) 2010 Ryan McGrath
-// Copyright (c) 2012 Artur Adib
-//
-// Licensed under the MIT License
-// http://www.opensource.org/licenses/mit-license.php
-function rmdirSyncRecursive(dir, force) {
-  var files;
-
-  files = fs.readdirSync(dir);
-
-  // Loop through and delete everything in the sub-tree after checking it
-  for(var i = 0; i < files.length; i++) {
-    var file = dir + "/" + files[i],
-        currFile = fs.lstatSync(file);
-
-    if(currFile.isDirectory()) { // Recursive function back to the beginning
-      rmdirSyncRecursive(file, force);
-    } else { // Assume it's a file - perhaps a try/catch belongs here?
-      if (force || isWriteable(file)) {
-        try {
-          common.unlinkSync(file);
-        } catch (e) {
-          common.error('could not remove file (code '+e.code+'): ' + file, true);
-        }
-      }
-    }
-  }
-
-  // Now that we know everything in the sub-tree has been deleted, we can delete the main directory.
-  // Huzzah for the shopkeep.
-
-  var result;
-  try {
-    // Retry on windows, sometimes it takes a little time before all the files in the directory are gone
-    var start = Date.now();
-    while (true) {
-      try {
-        result = fs.rmdirSync(dir);
-        if (fs.existsSync(dir)) throw { code: "EAGAIN" };
-        break;
-      } catch(er) {
-        // In addition to error codes, also check if the directory still exists and loop again if true
-        if (process.platform === "win32" && (er.code === "ENOTEMPTY" || er.code === "EBUSY" || er.code === "EPERM" || er.code === "EAGAIN")) {
-          if (Date.now() - start > 1000) throw er;
-        } else if (er.code === "ENOENT") {
-          // Directory did not exist, deletion was successful
-          break;
-        } else {
-          throw er;
-        }
-      }
-    }
-  } catch(e) {
-    common.error('could not remove directory (code '+e.code+'): ' + dir, true);
-  }
-
-  return result;
-} // rmdirSyncRecursive
-
-// Hack to determine if file has write permissions for current user
-// Avoids having to check user, group, etc, but it's probably slow
-function isWriteable(file) {
-  var writePermission = true;
-  try {
-    var __fd = fs.openSync(file, 'a');
-    fs.closeSync(__fd);
-  } catch(e) {
-    writePermission = false;
-  }
-
-  return writePermission;
-}
-
-//@
-//@ ### rm([options,] file [, file ...])
-//@ ### rm([options,] file_array)
-//@ Available options:
-//@
-//@ + `-f`: force
-//@ + `-r, -R`: recursive
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ rm('-rf', '/tmp/*');
-//@ rm('some_file.txt', 'another_file.txt');
-//@ rm(['some_file.txt', 'another_file.txt']); // same as above
-//@ ```
-//@
-//@ Removes files.
-function _rm(options, files) {
-  options = common.parseOptions(options, {
-    'f': 'force',
-    'r': 'recursive',
-    'R': 'recursive'
-  });
-  if (!files)
-    common.error('no paths given');
-
-  // Convert to array
-  files = [].slice.call(arguments, 1);
-
-  files.forEach(function(file) {
-    var stats;
-    try {
-      stats = fs.lstatSync(file); // test for existence
-    } catch (e) {
-      // Path does not exist, no force flag given
-      if (!options.force)
-        common.error('no such file or directory: '+file, true);
-      return; // skip file
-    }
-
-    // If here, path exists
-    if (stats.isFile() || stats.isSymbolicLink()) {
-
-      // Do not check for file writing permissions
-      if (options.force) {
-        common.unlinkSync(file);
-        return;
-      }
-
-      if (isWriteable(file))
-        common.unlinkSync(file);
-      else
-        common.error('permission denied: '+file, true);
-
-      return;
-    } // simple file
-
-    // Path is an existing directory, but no -r flag given
-    if (stats.isDirectory() && !options.recursive) {
-      common.error('path is a directory', true);
-      return; // skip path
-    }
-
-    // Recursively remove existing directory
-    if (stats.isDirectory() && options.recursive) {
-      rmdirSyncRecursive(file, options.force);
-    }
-  }); // forEach(file)
-  return new common.ShellString('', common.state.error, common.state.errorCode);
-} // rm
-module.exports = _rm;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/sed.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/sed.js b/node_modules/cordova-fetch/node_modules/shelljs/src/sed.js
deleted file mode 100644
index 0a9c0f5..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/sed.js
+++ /dev/null
@@ -1,68 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-//@
-//@ ### sed([options,] search_regex, replacement, file [, file ...])
-//@ ### sed([options,] search_regex, replacement, file_array)
-//@ Available options:
-//@
-//@ + `-i`: Replace contents of 'file' in-place. _Note that no backups will be created!_
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ sed('-i', 'PROGRAM_VERSION', 'v0.1.3', 'source.js');
-//@ sed(/.*DELETE_THIS_LINE.*\n/, '', 'source.js');
-//@ ```
-//@
-//@ Reads an input string from `files` and performs a JavaScript `replace()` on the input
-//@ using the given search regex and replacement string or function. Returns the new string after replacement.
-function _sed(options, regex, replacement, files) {
-  options = common.parseOptions(options, {
-    'i': 'inplace'
-  });
-
-  // Check if this is coming from a pipe
-  var pipe = common.readFromPipe(this);
-
-  if (typeof replacement === 'string' || typeof replacement === 'function')
-    replacement = replacement; // no-op
-  else if (typeof replacement === 'number')
-    replacement = replacement.toString(); // fallback
-  else
-    common.error('invalid replacement string');
-
-  // Convert all search strings to RegExp
-  if (typeof regex === 'string')
-    regex = RegExp(regex);
-
-  if (!files && !pipe)
-    common.error('no files given');
-
-  files = [].slice.call(arguments, 3);
-
-  if (pipe)
-    files.unshift('-');
-
-  var sed = [];
-  files.forEach(function(file) {
-    if (!fs.existsSync(file) && file !== '-') {
-      common.error('no such file or directory: ' + file, 2, true);
-      return;
-    }
-
-    var contents = file === '-' ? pipe : fs.readFileSync(file, 'utf8');
-    var lines = contents.split(/\r*\n/);
-    var result = lines.map(function (line) {
-      return line.replace(regex, replacement);
-    }).join('\n');
-
-    sed.push(result);
-
-    if (options.inplace)
-      fs.writeFileSync(file, result, 'utf8');
-  });
-
-  return new common.ShellString(sed.join('\n'), common.state.error, common.state.errorCode);
-}
-module.exports = _sed;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/set.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/set.js b/node_modules/cordova-fetch/node_modules/shelljs/src/set.js
deleted file mode 100644
index 701637e..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/set.js
+++ /dev/null
@@ -1,51 +0,0 @@
-var common = require('./common');
-
-//@
-//@ ### set(options)
-//@ Available options:
-//@
-//@ + `+/-e`: exit upon error (`config.fatal`)
-//@ + `+/-v`: verbose: show all commands (`config.verbose`)
-//@ + `+/-f`: disable filename expansion (globbing)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ set('-e'); // exit upon first error
-//@ set('+e'); // this undoes a "set('-e')"
-//@ ```
-//@
-//@ Sets global configuration variables
-function _set(options) {
-  if (!options) {
-    var args = [].slice.call(arguments, 0);
-    if (args.length < 2)
-      common.error('must provide an argument');
-    options = args[1];
-  }
-  var negate = (options[0] === '+');
-  if (negate) {
-    options = '-' + options.slice(1); // parseOptions needs a '-' prefix
-  }
-  options = common.parseOptions(options, {
-    'e': 'fatal',
-    'v': 'verbose',
-    'f': 'noglob'
-  });
-
-  var key;
-  if (negate) {
-    for (key in options)
-      options[key] = !options[key];
-  }
-
-  for (key in options) {
-    // Only change the global config if `negate` is false and the option is true
-    // or if `negate` is true and the option is false (aka negate !== option)
-    if (negate !== options[key]) {
-      common.config[key] = options[key];
-    }
-  }
-  return;
-}
-module.exports = _set;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/sort.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/sort.js b/node_modules/cordova-fetch/node_modules/shelljs/src/sort.js
deleted file mode 100644
index 514a90f..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/sort.js
+++ /dev/null
@@ -1,87 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-// parse out the number prefix of a line
-function parseNumber (str) {
-  var match = str.match(/^\s*(\d*)\s*(.*)$/);
-  return {num: Number(match[1]), value: match[2]};
-}
-
-// compare two strings case-insensitively, but examine case for strings that are
-// case-insensitive equivalent
-function unixCmp(a, b) {
-  var aLower = a.toLowerCase();
-  var bLower = b.toLowerCase();
-  return (aLower === bLower ?
-      -1 * a.localeCompare(b) : // unix sort treats case opposite how javascript does
-      aLower.localeCompare(bLower));
-}
-
-// compare two strings in the fashion that unix sort's -n option works
-function numericalCmp(a, b) {
-  var objA = parseNumber(a);
-  var objB = parseNumber(b);
-  if (objA.hasOwnProperty('num') && objB.hasOwnProperty('num')) {
-    return ((objA.num !== objB.num) ?
-        (objA.num - objB.num) :
-        unixCmp(objA.value, objB.value));
-  } else {
-    return unixCmp(objA.value, objB.value);
-  }
-}
-
-//@
-//@ ### sort([options,] file [, file ...])
-//@ ### sort([options,] file_array)
-//@ Available options:
-//@
-//@ + `-r`: Reverse the result of comparisons
-//@ + `-n`: Compare according to numerical value
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ sort('foo.txt', 'bar.txt');
-//@ sort('-r', 'foo.txt');
-//@ ```
-//@
-//@ Return the contents of the files, sorted line-by-line. Sorting multiple
-//@ files mixes their content, just like unix sort does.
-function _sort(options, files) {
-  options = common.parseOptions(options, {
-    'r': 'reverse',
-    'n': 'numerical'
-  });
-
-  // Check if this is coming from a pipe
-  var pipe = common.readFromPipe(this);
-
-  if (!files && !pipe)
-    common.error('no files given');
-
-  files = [].slice.call(arguments, 1);
-
-  if (pipe)
-    files.unshift('-');
-
-  var lines = [];
-  files.forEach(function(file) {
-    if (!fs.existsSync(file) && file !== '-') {
-      // exit upon any sort of error
-      common.error('no such file or directory: ' + file);
-    }
-
-    var contents = file === '-' ? pipe : fs.readFileSync(file, 'utf8');
-    lines = lines.concat(contents.trimRight().split(/\r*\n/));
-  });
-
-  var sorted;
-  sorted = lines.sort(options.numerical ? numericalCmp : unixCmp);
-
-  if (options.reverse)
-    sorted = sorted.reverse();
-
-  return new common.ShellString(sorted.join('\n')+'\n', common.state.error, common.state.errorCode);
-}
-
-module.exports = _sort;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/tail.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/tail.js b/node_modules/cordova-fetch/node_modules/shelljs/src/tail.js
deleted file mode 100644
index c54daea..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/tail.js
+++ /dev/null
@@ -1,65 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-//@
-//@ ### tail([{'-n', \<num\>},] file [, file ...])
-//@ ### tail([{'-n', \<num\>},] file_array)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ var str = tail({'-n', 1}, 'file*.txt');
-//@ var str = tail('file1', 'file2');
-//@ var str = tail(['file1', 'file2']); // same as above
-//@ ```
-//@
-//@ Output the last 10 lines of a file (or the last `<num>` if `-n` is
-//@ specified)
-function _tail(options, files) {
-  options = common.parseOptions(options, {
-    'n': 'numLines'
-  });
-  var tail = [];
-  var pipe = common.readFromPipe(this);
-
-  if (!files && !pipe)
-    common.error('no paths given');
-
-  var idx = 1;
-  if (options.numLines === true) {
-    idx = 2;
-    options.numLines = Number(arguments[1]);
-  } else if (options.numLines === false) {
-    options.numLines = 10;
-  }
-  options.numLines = -1 * Math.abs(options.numLines);
-  files = [].slice.call(arguments, idx);
-
-  if (pipe)
-    files.unshift('-');
-
-  var shouldAppendNewline = false;
-  files.forEach(function(file) {
-    if (!fs.existsSync(file) && file !== '-') {
-      common.error('no such file or directory: ' + file, true);
-      return;
-    }
-
-    var contents = file === '-' ? pipe : fs.readFileSync(file, 'utf8');
-
-    var lines = contents.split('\n');
-    if (lines[lines.length-1] === '') {
-      lines.pop();
-      shouldAppendNewline = true;
-    } else {
-      shouldAppendNewline = false;
-    }
-
-    tail = tail.concat(lines.slice(options.numLines));
-  });
-
-  if (shouldAppendNewline)
-    tail.push(''); // to add a trailing newline once we join
-  return new common.ShellString(tail.join('\n'), common.state.error, common.state.errorCode);
-}
-module.exports = _tail;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/tempdir.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/tempdir.js b/node_modules/cordova-fetch/node_modules/shelljs/src/tempdir.js
deleted file mode 100644
index 79b949f..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/tempdir.js
+++ /dev/null
@@ -1,57 +0,0 @@
-var common = require('./common');
-var os = require('os');
-var fs = require('fs');
-
-// Returns false if 'dir' is not a writeable directory, 'dir' otherwise
-function writeableDir(dir) {
-  if (!dir || !fs.existsSync(dir))
-    return false;
-
-  if (!fs.statSync(dir).isDirectory())
-    return false;
-
-  var testFile = dir+'/'+common.randomFileName();
-  try {
-    fs.writeFileSync(testFile, ' ');
-    common.unlinkSync(testFile);
-    return dir;
-  } catch (e) {
-    return false;
-  }
-}
-
-
-//@
-//@ ### tempdir()
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ var tmp = tempdir(); // "/tmp" for most *nix platforms
-//@ ```
-//@
-//@ Searches and returns string containing a writeable, platform-dependent temporary directory.
-//@ Follows Python's [tempfile algorithm](http://docs.python.org/library/tempfile.html#tempfile.tempdir).
-function _tempDir() {
-  var state = common.state;
-  if (state.tempDir)
-    return state.tempDir; // from cache
-
-  state.tempDir = writeableDir(os.tmpdir && os.tmpdir()) || // node 0.10+
-                  writeableDir(os.tmpDir && os.tmpDir()) || // node 0.8+
-                  writeableDir(process.env['TMPDIR']) ||
-                  writeableDir(process.env['TEMP']) ||
-                  writeableDir(process.env['TMP']) ||
-                  writeableDir(process.env['Wimp$ScrapDir']) || // RiscOS
-                  writeableDir('C:\\TEMP') || // Windows
-                  writeableDir('C:\\TMP') || // Windows
-                  writeableDir('\\TEMP') || // Windows
-                  writeableDir('\\TMP') || // Windows
-                  writeableDir('/tmp') ||
-                  writeableDir('/var/tmp') ||
-                  writeableDir('/usr/tmp') ||
-                  writeableDir('.'); // last resort
-
-  return state.tempDir;
-}
-module.exports = _tempDir;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/test.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/test.js b/node_modules/cordova-fetch/node_modules/shelljs/src/test.js
deleted file mode 100644
index 068a1ce..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/test.js
+++ /dev/null
@@ -1,85 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-//@
-//@ ### test(expression)
-//@ Available expression primaries:
-//@
-//@ + `'-b', 'path'`: true if path is a block device
-//@ + `'-c', 'path'`: true if path is a character device
-//@ + `'-d', 'path'`: true if path is a directory
-//@ + `'-e', 'path'`: true if path exists
-//@ + `'-f', 'path'`: true if path is a regular file
-//@ + `'-L', 'path'`: true if path is a symbolic link
-//@ + `'-p', 'path'`: true if path is a pipe (FIFO)
-//@ + `'-S', 'path'`: true if path is a socket
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ if (test('-d', path)) { /* do something with dir */ };
-//@ if (!test('-f', path)) continue; // skip if it's a regular file
-//@ ```
-//@
-//@ Evaluates expression using the available primaries and returns corresponding value.
-function _test(options, path) {
-  if (!path)
-    common.error('no path given');
-
-  // hack - only works with unary primaries
-  options = common.parseOptions(options, {
-    'b': 'block',
-    'c': 'character',
-    'd': 'directory',
-    'e': 'exists',
-    'f': 'file',
-    'L': 'link',
-    'p': 'pipe',
-    'S': 'socket'
-  });
-
-  var canInterpret = false;
-  for (var key in options)
-    if (options[key] === true) {
-      canInterpret = true;
-      break;
-    }
-
-  if (!canInterpret)
-    common.error('could not interpret expression');
-
-  if (options.link) {
-    try {
-      return fs.lstatSync(path).isSymbolicLink();
-    } catch(e) {
-      return false;
-    }
-  }
-
-  if (!fs.existsSync(path))
-    return false;
-
-  if (options.exists)
-    return true;
-
-  var stats = fs.statSync(path);
-
-  if (options.block)
-    return stats.isBlockDevice();
-
-  if (options.character)
-    return stats.isCharacterDevice();
-
-  if (options.directory)
-    return stats.isDirectory();
-
-  if (options.file)
-    return stats.isFile();
-
-  if (options.pipe)
-    return stats.isFIFO();
-
-  if (options.socket)
-    return stats.isSocket();
-} // test
-module.exports = _test;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/to.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/to.js b/node_modules/cordova-fetch/node_modules/shelljs/src/to.js
deleted file mode 100644
index 80d15cb..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/to.js
+++ /dev/null
@@ -1,31 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-var path = require('path');
-
-//@
-//@ ### ShellString.prototype.to(file)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ cat('input.txt').to('output.txt');
-//@ ```
-//@
-//@ Analogous to the redirection operator `>` in Unix, but works with
-//@ ShellStrings (such as those returned by `cat`, `grep`, etc). _Like Unix
-//@ redirections, `to()` will overwrite any existing file!_
-function _to(options, file) {
-  if (!file)
-    common.error('wrong arguments');
-
-  if (!fs.existsSync( path.dirname(file) ))
-      common.error('no such file or directory: ' + path.dirname(file));
-
-  try {
-    fs.writeFileSync(file, this.toString(), 'utf8');
-    return this;
-  } catch(e) {
-    common.error('could not write to file (code '+e.code+'): '+file, true);
-  }
-}
-module.exports = _to;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/toEnd.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/toEnd.js b/node_modules/cordova-fetch/node_modules/shelljs/src/toEnd.js
deleted file mode 100644
index 01058ab..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/toEnd.js
+++ /dev/null
@@ -1,30 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-var path = require('path');
-
-//@
-//@ ### ShellString.prototype.toEnd(file)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ cat('input.txt').toEnd('output.txt');
-//@ ```
-//@
-//@ Analogous to the redirect-and-append operator `>>` in Unix, but works with
-//@ ShellStrings (such as those returned by `cat`, `grep`, etc).
-function _toEnd(options, file) {
-  if (!file)
-    common.error('wrong arguments');
-
-  if (!fs.existsSync( path.dirname(file) ))
-      common.error('no such file or directory: ' + path.dirname(file));
-
-  try {
-    fs.appendFileSync(file, this.toString(), 'utf8');
-    return this;
-  } catch(e) {
-    common.error('could not append to file (code '+e.code+'): '+file, true);
-  }
-}
-module.exports = _toEnd;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/touch.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/touch.js b/node_modules/cordova-fetch/node_modules/shelljs/src/touch.js
deleted file mode 100644
index 4a4b017..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/touch.js
+++ /dev/null
@@ -1,107 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-
-//@
-//@ ### touch([options,] file [, file ...])
-//@ ### touch([options,] file_array)
-//@ Available options:
-//@
-//@ + `-a`: Change only the access time
-//@ + `-c`: Do not create any files
-//@ + `-m`: Change only the modification time
-//@ + `-d DATE`: Parse DATE and use it instead of current time
-//@ + `-r FILE`: Use FILE's times instead of current time
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ touch('source.js');
-//@ touch('-c', '/path/to/some/dir/source.js');
-//@ touch({ '-r': FILE }, '/path/to/some/dir/source.js');
-//@ ```
-//@
-//@ Update the access and modification times of each FILE to the current time.
-//@ A FILE argument that does not exist is created empty, unless -c is supplied.
-//@ This is a partial implementation of *[touch(1)](http://linux.die.net/man/1/touch)*.
-function _touch(opts, files) {
-  opts = common.parseOptions(opts, {
-    'a': 'atime_only',
-    'c': 'no_create',
-    'd': 'date',
-    'm': 'mtime_only',
-    'r': 'reference',
-  });
-
-  if (!files)
-    common.error('no files given');
-  else if (typeof files === 'string')
-    files = [].slice.call(arguments, 1);
-  else
-    common.error('file arg should be a string file path or an Array of string file paths');
-
-  files.forEach(function(f) {
-    touchFile(opts, f);
-  });
-  return new common.ShellString('', common.state.error, common.state.errorCode);
-}
-
-function touchFile(opts, file) {
-  var stat = tryStatFile(file);
-
-  if (stat && stat.isDirectory()) {
-    // don't error just exit
-    return;
-  }
-
-  // if the file doesn't already exist and the user has specified --no-create then
-  // this script is finished
-  if (!stat && opts.no_create) {
-    return;
-  }
-
-  // open the file and then close it. this will create it if it doesn't exist but will
-  // not truncate the file
-  fs.closeSync(fs.openSync(file, 'a'));
-
-  //
-  // Set timestamps
-  //
-
-  // setup some defaults
-  var now = new Date();
-  var mtime = opts.date || now;
-  var atime = opts.date || now;
-
-  // use reference file
-  if (opts.reference) {
-    var refStat = tryStatFile(opts.reference);
-    if (!refStat) {
-      common.error('failed to get attributess of ' + opts.reference);
-    }
-    mtime = refStat.mtime;
-    atime = refStat.atime;
-  } else if (opts.date) {
-    mtime = opts.date;
-    atime = opts.date;
-  }
-
-  if (opts.atime_only && opts.mtime_only) {
-    // keep the new values of mtime and atime like GNU
-  } else if (opts.atime_only) {
-    mtime = stat.mtime;
-  } else if (opts.mtime_only) {
-    atime = stat.atime;
-  }
-
-  fs.utimesSync(file, atime, mtime);
-}
-
-module.exports = _touch;
-
-function tryStatFile(filePath) {
-  try {
-    return fs.statSync(filePath);
-  } catch (e) {
-    return null;
-  }
-}

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/node_modules/shelljs/src/which.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/node_modules/shelljs/src/which.js b/node_modules/cordova-fetch/node_modules/shelljs/src/which.js
deleted file mode 100644
index 86952d3..0000000
--- a/node_modules/cordova-fetch/node_modules/shelljs/src/which.js
+++ /dev/null
@@ -1,98 +0,0 @@
-var common = require('./common');
-var fs = require('fs');
-var path = require('path');
-
-// XP's system default value for PATHEXT system variable, just in case it's not
-// set on Windows.
-var XP_DEFAULT_PATHEXT = '.com;.exe;.bat;.cmd;.vbs;.vbe;.js;.jse;.wsf;.wsh';
-
-// Cross-platform method for splitting environment PATH variables
-function splitPath(p) {
-  if (!p)
-    return [];
-
-  if (common.platform === 'win')
-    return p.split(';');
-  else
-    return p.split(':');
-}
-
-function checkPath(path) {
-  return fs.existsSync(path) && !fs.statSync(path).isDirectory();
-}
-
-//@
-//@ ### which(command)
-//@
-//@ Examples:
-//@
-//@ ```javascript
-//@ var nodeExec = which('node');
-//@ ```
-//@
-//@ Searches for `command` in the system's PATH. On Windows, this uses the
-//@ `PATHEXT` variable to append the extension if it's not already executable.
-//@ Returns string containing the absolute path to the command.
-function _which(options, cmd) {
-  if (!cmd)
-    common.error('must specify command');
-
-  var pathEnv = process.env.path || process.env.Path || process.env.PATH,
-      pathArray = splitPath(pathEnv),
-      where = null;
-
-  // No relative/absolute paths provided?
-  if (cmd.search(/\//) === -1) {
-    // Search for command in PATH
-    pathArray.forEach(function(dir) {
-      if (where)
-        return; // already found it
-
-      var attempt = path.resolve(dir, cmd);
-
-      if (common.platform === 'win') {
-        attempt = attempt.toUpperCase();
-
-        // In case the PATHEXT variable is somehow not set (e.g.
-        // child_process.spawn with an empty environment), use the XP default.
-        var pathExtEnv = process.env.PATHEXT || XP_DEFAULT_PATHEXT;
-        var pathExtArray = splitPath(pathExtEnv.toUpperCase());
-        var i;
-
-        // If the extension is already in PATHEXT, just return that.
-        for (i = 0; i < pathExtArray.length; i++) {
-          var ext = pathExtArray[i];
-          if (attempt.slice(-ext.length) === ext && checkPath(attempt)) {
-            where = attempt;
-            return;
-          }
-        }
-
-        // Cycle through the PATHEXT variable
-        var baseAttempt = attempt;
-        for (i = 0; i < pathExtArray.length; i++) {
-          attempt = baseAttempt + pathExtArray[i];
-          if (checkPath(attempt)) {
-            where = attempt;
-            return;
-          }
-        }
-      } else {
-        // Assume it's Unix-like
-        if (checkPath(attempt)) {
-          where = attempt;
-          return;
-        }
-      }
-    });
-  }
-
-  // Command not found anywhere?
-  if (!checkPath(cmd) && !where)
-    return null;
-
-  where = where || path.resolve(cmd);
-
-  return new common.ShellString(where, '', common.state.errorCode);
-}
-module.exports = _which;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/package.json
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/package.json b/node_modules/cordova-fetch/package.json
deleted file mode 100644
index 84c9f9a..0000000
--- a/node_modules/cordova-fetch/package.json
+++ /dev/null
@@ -1,112 +0,0 @@
-{
-  "_args": [
-    [
-      {
-        "name": "cordova-fetch",
-        "raw": "cordova-fetch@1.0.0",
-        "rawSpec": "1.0.0",
-        "scope": null,
-        "spec": "1.0.0",
-        "type": "version"
-      },
-      "/Users/ctran/cordova/cordova-lib/cordova-create"
-    ]
-  ],
-  "_from": "cordova-fetch@1.0.0",
-  "_id": "cordova-fetch@1.0.0",
-  "_inCache": true,
-  "_installable": true,
-  "_location": "/cordova-fetch",
-  "_nodeVersion": "5.4.1",
-  "_npmOperationalInternal": {
-    "host": "packages-12-west.internal.npmjs.com",
-    "tmp": "tmp/cordova-fetch-1.0.0.tgz_1464130124678_0.8607046958059072"
-  },
-  "_npmUser": {
-    "email": "stevengill97@gmail.com",
-    "name": "stevegill"
-  },
-  "_npmVersion": "3.9.0",
-  "_phantomChildren": {
-    "brace-expansion": "1.1.5",
-    "fs.realpath": "1.0.0",
-    "inflight": "1.0.5",
-    "inherits": "2.0.1",
-    "interpret": "1.0.1",
-    "once": "1.3.3",
-    "path-is-absolute": "1.0.0",
-    "rechoir": "0.6.2"
-  },
-  "_requested": {
-    "name": "cordova-fetch",
-    "raw": "cordova-fetch@1.0.0",
-    "rawSpec": "1.0.0",
-    "scope": null,
-    "spec": "1.0.0",
-    "type": "version"
-  },
-  "_requiredBy": [
-    "/"
-  ],
-  "_resolved": "https://registry.npmjs.org/cordova-fetch/-/cordova-fetch-1.0.0.tgz",
-  "_shasum": "54b1044f2ccc39169131b50f35e7ce24159264e6",
-  "_shrinkwrap": null,
-  "_spec": "cordova-fetch@1.0.0",
-  "_where": "/Users/ctran/cordova/cordova-lib/cordova-create",
-  "author": {
-    "name": "Apache Software Foundation"
-  },
-  "bugs": {
-    "email": "dev@cordova.apache.org",
-    "url": "https://issues.apache.org/jira/browse/CB"
-  },
-  "dependencies": {
-    "cordova-common": "^1.3.0",
-    "dependency-ls": "^1.0.0",
-    "is-url": "^1.2.1",
-    "q": "^1.4.1",
-    "shelljs": "^0.7.0"
-  },
-  "description": "Apache Cordova fetch module. Fetches from git and npm.",
-  "devDependencies": {
-    "jasmine": "^2.4.1",
-    "jshint": "^2.8.0"
-  },
-  "directories": {},
-  "dist": {
-    "shasum": "54b1044f2ccc39169131b50f35e7ce24159264e6",
-    "tarball": "https://registry.npmjs.org/cordova-fetch/-/cordova-fetch-1.0.0.tgz"
-  },
-  "engines": {
-    "node": ">= 0.12.0",
-    "npm": ">= 2.5.1"
-  },
-  "keywords": [
-    "cordova",
-    "fetch",
-    "apache",
-    "ecosystem:cordova",
-    "cordova:tool"
-  ],
-  "license": "Apache-2.0",
-  "main": "index.js",
-  "maintainers": [
-    {
-      "email": "stevengill97@gmail.com",
-      "name": "stevegill"
-    }
-  ],
-  "name": "cordova-fetch",
-  "optionalDependencies": {},
-  "readme": "ERROR: No README data found!",
-  "repository": {
-    "type": "git",
-    "url": "git://git-wip-us.apache.org/repos/asf/cordova-lib.git"
-  },
-  "scripts": {
-    "jasmine": "jasmine spec/fetch.spec.js",
-    "jshint": "jshint index.js spec/fetch.spec.js",
-    "test": "npm run jshint && npm run jasmine"
-  },
-  "version": "1.0.0"
-}

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/spec/fetch.spec.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/spec/fetch.spec.js b/node_modules/cordova-fetch/spec/fetch.spec.js
deleted file mode 100644
index 2f6513a..0000000
--- a/node_modules/cordova-fetch/spec/fetch.spec.js
+++ /dev/null
@@ -1,300 +0,0 @@
-/**
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-*/
-
-var fetch = require('../index.js');
-var uninstall = require('../index.js').uninstall;
-var shell = require('shelljs');
-var path = require('path');
-var fs = require('fs');
-var helpers = require('./helpers.js');
-
-describe('platform fetch/uninstall tests via npm & git', function () {
-
-    var tmpDir = helpers.tmpDir('plat_fetch');
-    var opts = {};
-
-    beforeEach(function() {
-        process.chdir(tmpDir);
-    });
-    
-    afterEach(function() {
-        process.chdir(path.join(__dirname, '..'));  // Needed to rm the dir on Windows.
-        shell.rm('-rf', tmpDir);
-    });
-
-    it('should fetch and uninstall a cordova platform via npm & git', function(done) {
-        
-        fetch('cordova-android', tmpDir, opts)
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-android');
-            
-            return uninstall('cordova-android', tmpDir, opts);
-        })
-        .then(function() {
-            expect(fs.existsSync(path.join(tmpDir,'node_modules', 'cordova-android'))).toBe(false);
-            
-            return fetch('https://github.com/apache/cordova-ios.git', tmpDir, opts);       
-        })
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-ios');
-            
-            return uninstall('cordova-ios', tmpDir, opts);
-        })
-        .then(function() {
-            expect(fs.existsSync(path.join(tmpDir,'node_modules', 'cordova-ios'))).toBe(false);    
-        })
-        .fail(function(err) {
-            console.error(err);
-            expect(err).toBeUndefined();
-        })
-        .fin(done);
-    }, 60000);
-});
-
-describe('platform fetch/uninstall test via npm & git tags with --save', function () {
-
-    var tmpDir = helpers.tmpDir('plat_fetch_save');
-    var opts = {'save':true};
-    
-    beforeEach(function() {
-        //copy package.json from spec directory to tmpDir
-        shell.cp('spec/testpkg.json', path.join(tmpDir,'package.json'));
-        process.chdir(tmpDir);
-    });
-    
-    afterEach(function() {
-        process.chdir(path.join(__dirname, '..'));  // Needed to rm the dir on Windows.
-        shell.rm('-rf', tmpDir);
-    });
-
-    it('should fetch and uninstall a cordova platform via npm & git tags/branches', function(done) {
-        fetch('cordova-android@5.1.1', tmpDir, opts)
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-android');
-            expect(pkgJSON.version).toBe('5.1.1');
-
-            var rootPJ = require(path.join(tmpDir,'package.json'));
-            expect(rootPJ.dependencies['cordova-android']).toBe('^5.1.1');
-
-            return uninstall('cordova-android', tmpDir, opts);
-        })
-        .then(function() {
-            var rootPJ = JSON.parse(fs.readFileSync(path.join(tmpDir,'package.json'), 'utf8'));
-            expect(Object.keys(rootPJ.dependencies).length).toBe(0);
-            expect(fs.existsSync(path.join(tmpDir,'node_modules', 'cordova-android'))).toBe(false);
-
-            return fetch('https://github.com/apache/cordova-ios.git#rel/4.1.1', tmpDir, opts);       
-        })
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-ios');
-            expect(pkgJSON.version).toBe('4.1.1');
-
-            var rootPJ = JSON.parse(fs.readFileSync(path.join(tmpDir,'package.json'), 'utf8'));
-            expect(rootPJ.dependencies['cordova-ios']).toBe('git+https://github.com/apache/cordova-ios.git#rel/4.1.1');
-
-            return uninstall('cordova-ios', tmpDir, opts);
-        })
-        .then(function() {
-            var rootPJ = JSON.parse(fs.readFileSync(path.join(tmpDir,'package.json'), 'utf8'));
-            expect(Object.keys(rootPJ.dependencies).length).toBe(0);
-            expect(fs.existsSync(path.join(tmpDir,'node_modules', 'cordova-ios'))).toBe(false);
-
-            return fetch('https://github.com/apache/cordova-android.git#4.1.x', tmpDir, opts);
-        })
-        .then(function(result) {
-            var pkgJSON = JSON.parse(fs.readFileSync(path.join(result,'package.json'), 'utf8'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-android');
-            expect(pkgJSON.version).toBe('4.1.1');
-
-            var rootPJ = JSON.parse(fs.readFileSync(path.join(tmpDir,'package.json'), 'utf8'));
-            expect(rootPJ.dependencies['cordova-android']).toBe('git+https://github.com/apache/cordova-android.git#4.1.x');
-
-            return uninstall('cordova-android', tmpDir, opts);
-        })
-        .fail(function(err) {
-            console.error(err);
-            expect(err).toBeUndefined();
-        })
-        .fin(done);
-    }, 60000);
-});
-
-describe('plugin fetch/uninstall test with --save', function () {
-
-    var tmpDir = helpers.tmpDir('plug_fetch_save');
-    var opts = {'save':true};
-    
-    beforeEach(function() {
-        //copy package.json from spec directory to tmpDir
-        shell.cp('spec/testpkg.json', path.join(tmpDir,'package.json'));
-        process.chdir(tmpDir);
-    });
-    
-    afterEach(function() {
-        process.chdir(path.join(__dirname, '..'));  // Needed to rm the dir on Windows.
-        shell.rm('-rf', tmpDir);
-    });
-
-    it('should fetch and uninstall a cordova plugin via git commit sha', function(done) {
-        fetch('https://github.com/apache/cordova-plugin-contacts.git#7db612115755c2be73a98dda76ff4c5fd9d8a575', tmpDir, opts)
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-plugin-contacts');
-            expect(pkgJSON.version).toBe('2.0.2-dev');
-
-            var rootPJ = require(path.join(tmpDir,'package.json'));
-            expect(rootPJ.dependencies['cordova-plugin-contacts']).toBe('git+https://github.com/apache/cordova-plugin-contacts.git#7db612115755c2be73a98dda76ff4c5fd9d8a575');
-
-            return uninstall('cordova-plugin-contacts', tmpDir, opts);
-        })
-        .then(function() {
-            var rootPJ = JSON.parse(fs.readFileSync(path.join(tmpDir,'package.json'), 'utf8'));
-            expect(Object.keys(rootPJ.dependencies).length).toBe(0);
-            expect(fs.existsSync(path.join(tmpDir,'node_modules', 'cordova-plugin-contacts'))).toBe(false);
-        })
-        .fail(function(err) {
-            console.error(err);
-            expect(err).toBeUndefined();
-        })
-        .fin(done);
-    }, 30000);
-});
-
-describe('test trimID method for npm and git', function () {
-
-    var tmpDir = helpers.tmpDir('plug_trimID');
-    var opts = {};
-    
-    beforeEach(function() {
-        process.chdir(tmpDir);
-    });
-    
-    afterEach(function() {
-        process.chdir(path.join(__dirname, '..'));  // Needed to rm the dir on Windows.
-        shell.rm('-rf', tmpDir);
-    });
-
-    it('should fetch the same cordova plugin twice in a row', function(done) {
-        fetch('cordova-plugin-device', tmpDir, opts)
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-plugin-device');
-            
-            return fetch('https://github.com/apache/cordova-plugin-media.git', tmpDir, opts);
-        })
-        .then(function(result) {
-            var pkgJSON = require(path.join(result,'package.json'));
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-            expect(pkgJSON.name).toBe('cordova-plugin-media');
-
-            //refetch to trigger trimID
-            return fetch('cordova-plugin-device', tmpDir, opts);
-            
-        })
-        .then(function(result) {
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-
-            //refetch to trigger trimID
-            return fetch('https://github.com/apache/cordova-plugin-media.git', tmpDir, opts);
-        })
-        .then(function(result) {
-            expect(result).toBeDefined();
-            expect(fs.existsSync(result)).toBe(true);
-        })
-        .fail(function(err) {
-            console.error(err);
-            expect(err).toBeUndefined();
-        })
-        .fin(done);
-    }, 30000);
-});
-
-describe('fetch failure with unknown module', function () {
-
-    var tmpDir = helpers.tmpDir('fetch_fails_npm');
-    var opts = {};
-    
-    beforeEach(function() {
-        process.chdir(tmpDir);
-    });
-    
-    afterEach(function() {
-        process.chdir(path.join(__dirname, '..'));  // Needed to rm the dir on Windows.
-        shell.rm('-rf', tmpDir);
-    });
-
-    it('should fail fetching a module that does not exist on npm', function(done) {
-        fetch('NOTAMODULE', tmpDir, opts)
-        .then(function(result) {
-            console.log('This should fail and it should not be seen');
-        })
-        .fail(function(err) {
-            expect(err.message.code).toBe(1);
-            expect(err).toBeDefined();
-        })
-        .fin(done);
-    }, 30000);
-});
-
-describe('fetch failure with git subdirectory', function () {
-
-    var tmpDir = helpers.tmpDir('fetch_fails_subdirectory');
-    var opts = {};
-
-    beforeEach(function() {
-        process.chdir(tmpDir);
-    });
-    
-    afterEach(function() {
-        process.chdir(path.join(__dirname, '..'));  // Needed to rm the dir on Windows.
-        shell.rm('-rf', tmpDir);
-    });
-
-    it('should fail fetching a giturl which contains a subdirectory', function(done) {
-        fetch('https://github.com/apache/cordova-plugins.git#:keyboard', tmpDir, opts)
-        .then(function(result) {
-            console.log('This should fail and it should not be seen');
-        })
-        .fail(function(err) {
-            expect(err.message.code).toBe(1);
-            expect(err).toBeDefined();
-        })
-        .fin(done);
-    }, 30000);
-});

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/spec/helpers.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/spec/helpers.js b/node_modules/cordova-fetch/spec/helpers.js
deleted file mode 100644
index 8fd325b..0000000
--- a/node_modules/cordova-fetch/spec/helpers.js
+++ /dev/null
@@ -1,35 +0,0 @@
-/*
- Licensed to the Apache Software Foundation (ASF) under one
- or more contributor license agreements.  See the NOTICE file
- distributed with this work for additional information
- regarding copyright ownership.  The ASF licenses this file
- to you under the Apache License, Version 2.0 (the
- "License"); you may not use this file except in compliance
- with the License.  You may obtain a copy of the License at
-
- http://www.apache.org/licenses/LICENSE-2.0
-
- Unless required by applicable law or agreed to in writing,
- software distributed under the License is distributed on an
- "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- KIND, either express or implied.  See the License for the
- specific language governing permissions and limitations
- under the License.
- */
-
-var path    = require('path'),
-    fs      = require('fs'),
-    shell   = require('shelljs'),
-    os      = require('os');
-
-module.exports.tmpDir = function (subdir) {
-    var dir = path.join(os.tmpdir(), 'e2e-test');
-    if (subdir) {
-        dir = path.join(dir, subdir);
-    }
-    if(fs.existsSync(dir)) {
-        shell.rm('-rf', dir);
-    }
-    shell.mkdir('-p', dir);
-    return dir;
-};

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/spec/support/jasmine.json
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/spec/support/jasmine.json b/node_modules/cordova-fetch/spec/support/jasmine.json
deleted file mode 100644
index 3ea3166..0000000
--- a/node_modules/cordova-fetch/spec/support/jasmine.json
+++ /dev/null
@@ -1,11 +0,0 @@
-{
-  "spec_dir": "spec",
-  "spec_files": [
-    "**/*[sS]pec.js"
-  ],
-  "helpers": [
-    "helpers/**/*.js"
-  ],
-  "stopSpecOnExpectationFailure": false,
-  "random": false
-}

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-fetch/spec/testpkg.json
----------------------------------------------------------------------
diff --git a/node_modules/cordova-fetch/spec/testpkg.json b/node_modules/cordova-fetch/spec/testpkg.json
deleted file mode 100644
index 94e7f64..0000000
--- a/node_modules/cordova-fetch/spec/testpkg.json
+++ /dev/null
@@ -1,11 +0,0 @@
-{
-  "name": "test",
-  "version": "1.0.0",
-  "description": "",
-  "main": "fetch.spec.js",
-  "scripts": {
-    "test": "echo \"Error: no test specified\" && exit 1"
-  },
-  "author": "",
-  "license": "ISC"
-}

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-registry-mapper/.npmignore
----------------------------------------------------------------------
diff --git a/node_modules/cordova-registry-mapper/.npmignore b/node_modules/cordova-registry-mapper/.npmignore
deleted file mode 100644
index 3c3629e..0000000
--- a/node_modules/cordova-registry-mapper/.npmignore
+++ /dev/null
@@ -1 +0,0 @@
-node_modules

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-registry-mapper/.travis.yml
----------------------------------------------------------------------
diff --git a/node_modules/cordova-registry-mapper/.travis.yml b/node_modules/cordova-registry-mapper/.travis.yml
deleted file mode 100644
index ae381fc..0000000
--- a/node_modules/cordova-registry-mapper/.travis.yml
+++ /dev/null
@@ -1,7 +0,0 @@
-language: node_js
-sudo: false 
-node_js:
-  - "0.10"
-install: npm install
-script:
-  - npm test

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-registry-mapper/README.md
----------------------------------------------------------------------
diff --git a/node_modules/cordova-registry-mapper/README.md b/node_modules/cordova-registry-mapper/README.md
deleted file mode 100644
index 3b93e5f..0000000
--- a/node_modules/cordova-registry-mapper/README.md
+++ /dev/null
@@ -1,14 +0,0 @@
-[![Build Status](https://travis-ci.org/stevengill/cordova-registry-mapper.svg?branch=master)](https://travis-ci.org/stevengill/cordova-registry-mapper)
-
-#Cordova Registry Mapper
-
-This module is used to map Cordova plugin ids to package names and vice versa.
-
-When Cordova users add plugins to their projects using ids
-(e.g. `cordova plugin add org.apache.cordova.device`),
-this module will map that id to the corresponding package name so `cordova-lib` knows what to fetch from **npm**.
-
-This module was created so the Apache Cordova project could migrate its plugins from
-the [Cordova Registry](http://registry.cordova.io/)
-to [npm](https://registry.npmjs.com/)
-instead of having to maintain a registry.

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-registry-mapper/index.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-registry-mapper/index.js b/node_modules/cordova-registry-mapper/index.js
deleted file mode 100644
index 4550774..0000000
--- a/node_modules/cordova-registry-mapper/index.js
+++ /dev/null
@@ -1,204 +0,0 @@
-var map = {
-    'org.apache.cordova.battery-status':'cordova-plugin-battery-status',
-    'org.apache.cordova.camera':'cordova-plugin-camera',
-    'org.apache.cordova.console':'cordova-plugin-console',
-    'org.apache.cordova.contacts':'cordova-plugin-contacts',
-    'org.apache.cordova.device':'cordova-plugin-device',
-    'org.apache.cordova.device-motion':'cordova-plugin-device-motion',
-    'org.apache.cordova.device-orientation':'cordova-plugin-device-orientation',
-    'org.apache.cordova.dialogs':'cordova-plugin-dialogs',
-    'org.apache.cordova.file':'cordova-plugin-file',
-    'org.apache.cordova.file-transfer':'cordova-plugin-file-transfer',
-    'org.apache.cordova.geolocation':'cordova-plugin-geolocation',
-    'org.apache.cordova.globalization':'cordova-plugin-globalization',
-    'org.apache.cordova.inappbrowser':'cordova-plugin-inappbrowser',
-    'org.apache.cordova.media':'cordova-plugin-media',
-    'org.apache.cordova.media-capture':'cordova-plugin-media-capture',
-    'org.apache.cordova.network-information':'cordova-plugin-network-information',
-    'org.apache.cordova.splashscreen':'cordova-plugin-splashscreen',
-    'org.apache.cordova.statusbar':'cordova-plugin-statusbar',
-    'org.apache.cordova.vibration':'cordova-plugin-vibration',
-    'org.apache.cordova.test-framework':'cordova-plugin-test-framework',
-    'com.msopentech.websql' : 'cordova-plugin-websql',
-    'com.msopentech.indexeddb' : 'cordova-plugin-indexeddb',
-    'com.microsoft.aad.adal' : 'cordova-plugin-ms-adal',
-    'com.microsoft.capptain' : 'capptain-cordova',
-    'com.microsoft.services.aadgraph' : 'cordova-plugin-ms-aad-graph',
-    'com.microsoft.services.files' : 'cordova-plugin-ms-files',
-    'om.microsoft.services.outlook' : 'cordova-plugin-ms-outlook',
-    'com.pbakondy.sim' : 'cordova-plugin-sim',
-    'android.support.v4' : 'cordova-plugin-android-support-v4',
-    'android.support.v7-appcompat' : 'cordova-plugin-android-support-v7-appcompat',
-    'com.google.playservices' : 'cordova-plugin-googleplayservices',
-    'com.google.cordova.admob' : 'cordova-plugin-admobpro',
-    'com.rjfun.cordova.extension' : 'cordova-plugin-extension',
-    'com.rjfun.cordova.plugin.admob' : 'cordova-plugin-admob',
-    'com.rjfun.cordova.flurryads' : 'cordova-plugin-flurry',
-    'com.rjfun.cordova.facebookads' : 'cordova-plugin-facebookads',
-    'com.rjfun.cordova.httpd' : 'cordova-plugin-httpd',
-    'com.rjfun.cordova.iad' : 'cordova-plugin-iad',
-    'com.rjfun.cordova.iflyspeech' : 'cordova-plugin-iflyspeech',
-    'com.rjfun.cordova.lianlianpay' : 'cordova-plugin-lianlianpay',
-    'com.rjfun.cordova.mobfox' : 'cordova-plugin-mobfox',
-    'com.rjfun.cordova.mopub' : 'cordova-plugin-mopub',
-    'com.rjfun.cordova.mmedia' : 'cordova-plugin-mmedia',
-    'com.rjfun.cordova.nativeaudio' : 'cordova-plugin-nativeaudio',
-    'com.rjfun.cordova.plugin.paypalmpl' : 'cordova-plugin-paypalmpl',
-    'com.rjfun.cordova.smartadserver' : 'cordova-plugin-smartadserver',
-    'com.rjfun.cordova.sms' : 'cordova-plugin-sms',
-    'com.rjfun.cordova.wifi' : 'cordova-plugin-wifi',
-    'com.ohh2ahh.plugins.appavailability' : 'cordova-plugin-appavailability',
-    'org.adapt-it.cordova.fonts' : 'cordova-plugin-fonts',
-    'de.martinreinhardt.cordova.plugins.barcodeScanner' : 'cordova-plugin-barcodescanner',
-    'de.martinreinhardt.cordova.plugins.urlhandler' : 'cordova-plugin-urlhandler',
-    'de.martinreinhardt.cordova.plugins.email' : 'cordova-plugin-email',
-    'de.martinreinhardt.cordova.plugins.certificates' : 'cordova-plugin-certificates',
-    'de.martinreinhardt.cordova.plugins.sqlite' : 'cordova-plugin-sqlite',
-    'fr.smile.cordova.fileopener' : 'cordova-plugin-fileopener',
-    'org.smile.websqldatabase.initializer' : 'cordova-plugin-websqldatabase-initializer',
-    'org.smile.websqldatabase.wpdb' : 'cordova-plugin-websqldatabase',
-    'org.jboss.aerogear.cordova.push' : 'aerogear-cordova-push',
-    'org.jboss.aerogear.cordova.oauth2' : 'aerogear-cordova-oauth2',
-    'org.jboss.aerogear.cordova.geo' : 'aerogear-cordova-geo',
-    'org.jboss.aerogear.cordova.crypto' : 'aerogear-cordova-crypto',
-    'org.jboss.aerogaer.cordova.otp' : 'aerogear-cordova-otp',
-    'uk.co.ilee.applewatch' : 'cordova-plugin-apple-watch',
-    'uk.co.ilee.directions' : 'cordova-plugin-directions',
-    'uk.co.ilee.gamecenter' : 'cordova-plugin-game-center',
-    'uk.co.ilee.jailbreakdetection' : 'cordova-plugin-jailbreak-detection',
-    'uk.co.ilee.nativetransitions' : 'cordova-plugin-native-transitions',
-    'uk.co.ilee.pedometer' : 'cordova-plugin-pedometer',
-    'uk.co.ilee.shake' : 'cordova-plugin-shake',
-    'uk.co.ilee.touchid' : 'cordova-plugin-touchid',
-    'com.knowledgecode.cordova.websocket' : 'cordova-plugin-websocket',
-    'com.elixel.plugins.settings' : 'cordova-plugin-settings',
-    'com.cowbell.cordova.geofence' : 'cordova-plugin-geofence',
-    'com.blackberry.community.preventsleep' : 'cordova-plugin-preventsleep',
-    'com.blackberry.community.gamepad' : 'cordova-plugin-gamepad',
-    'com.blackberry.community.led' : 'cordova-plugin-led',
-    'com.blackberry.community.thumbnail' : 'cordova-plugin-thumbnail',
-    'com.blackberry.community.mediakeys' : 'cordova-plugin-mediakeys',
-    'com.blackberry.community.simplebtlehrplugin' : 'cordova-plugin-bluetoothheartmonitor',
-    'com.blackberry.community.simplebeaconplugin' : 'cordova-plugin-bluetoothibeacon',
-    'com.blackberry.community.simplebtsppplugin' : 'cordova-plugin-bluetoothspp',
-    'com.blackberry.community.clipboard' : 'cordova-plugin-clipboard',
-    'com.blackberry.community.curl' : 'cordova-plugin-curl',
-    'com.blackberry.community.qt' : 'cordova-plugin-qtbridge',
-    'com.blackberry.community.upnp' : 'cordova-plugin-upnp',
-    'com.blackberry.community.PasswordCrypto' : 'cordova-plugin-password-crypto',
-    'com.blackberry.community.deviceinfoplugin' : 'cordova-plugin-deviceinfo',
-    'com.blackberry.community.gsecrypto' : 'cordova-plugin-bb-crypto',
-    'com.blackberry.community.mongoose' : 'cordova-plugin-mongoose',
-    'com.blackberry.community.sysdialog' : 'cordova-plugin-bb-sysdialog',
-    'com.blackberry.community.screendisplay' : 'cordova-plugin-screendisplay',
-    'com.blackberry.community.messageplugin' : 'cordova-plugin-bb-messageretrieve',
-    'com.blackberry.community.emailsenderplugin' : 'cordova-plugin-emailsender',
-    'com.blackberry.community.audiometadata' : 'cordova-plugin-audiometadata',
-    'com.blackberry.community.deviceemails' : 'cordova-plugin-deviceemails',
-    'com.blackberry.community.audiorecorder' : 'cordova-plugin-audiorecorder',
-    'com.blackberry.community.vibration' : 'cordova-plugin-vibrate-intense',
-    'com.blackberry.community.SMSPlugin' : 'cordova-plugin-bb-sms',
-    'com.blackberry.community.extractZipFile' : 'cordova-plugin-bb-zip',
-    'com.blackberry.community.lowlatencyaudio' : 'cordova-plugin-bb-nativeaudio',
-    'com.blackberry.community.barcodescanner' : 'phonegap-plugin-barcodescanner',
-    'com.blackberry.app' : 'cordova-plugin-bb-app',
-    'com.blackberry.bbm.platform' : 'cordova-plugin-bbm',
-    'com.blackberry.connection' : 'cordova-plugin-bb-connection',
-    'com.blackberry.identity' : 'cordova-plugin-bb-identity',
-    'com.blackberry.invoke.card' : 'cordova-plugin-bb-card',
-    'com.blackberry.invoke' : 'cordova-plugin-bb-invoke',
-    'com.blackberry.invoked' : 'cordova-plugin-bb-invoked',
-    'com.blackberry.io.filetransfer' : 'cordova-plugin-bb-filetransfer',
-    'com.blackberry.io' : 'cordova-plugin-bb-io',
-    'com.blackberry.notification' : 'cordova-plugin-bb-notification',
-    'com.blackberry.payment' : 'cordova-plugin-bb-payment',
-    'com.blackberry.pim.calendar' : 'cordova-plugin-bb-calendar',
-    'com.blackberry.pim.contacts' : 'cordova-plugin-bb-contacts',
-    'com.blackberry.pim.lib' : 'cordova-plugin-bb-pimlib',
-    'com.blackberry.push' : 'cordova-plugin-bb-push',
-    'com.blackberry.screenshot' : 'cordova-plugin-screenshot',
-    'com.blackberry.sensors' : 'cordova-plugin-bb-sensors',
-    'com.blackberry.system' : 'cordova-plugin-bb-system',
-    'com.blackberry.ui.contextmenu' : 'cordova-plugin-bb-ctxmenu',
-    'com.blackberry.ui.cover' : 'cordova-plugin-bb-cover',
-    'com.blackberry.ui.dialog' : 'cordova-plugin-bb-dialog',
-    'com.blackberry.ui.input' : 'cordova-plugin-touch-keyboard',
-    'com.blackberry.ui.toast' : 'cordova-plugin-toast',
-    'com.blackberry.user.identity' : 'cordova-plugin-bb-idservice',
-    'com.blackberry.utils' : 'cordova-plugin-bb-utils',
-    'net.yoik.cordova.plugins.screenorientation' : 'cordova-plugin-screen-orientation',
-    'com.phonegap.plugins.barcodescanner' : 'phonegap-plugin-barcodescanner',
-    'com.manifoldjs.hostedwebapp' : 'cordova-plugin-hostedwebapp',
-    'com.initialxy.cordova.themeablebrowser' : 'cordova-plugin-themeablebrowser',
-    'gr.denton.photosphere' : 'cordova-plugin-panoramaviewer',
-    'nl.x-services.plugins.actionsheet' : 'cordova-plugin-actionsheet',
-    'nl.x-services.plugins.socialsharing' : 'cordova-plugin-x-socialsharing',
-    'nl.x-services.plugins.googleplus' : 'cordova-plugin-googleplus',
-    'nl.x-services.plugins.insomnia' : 'cordova-plugin-insomnia',
-    'nl.x-services.plugins.toast' : 'cordova-plugin-x-toast',
-    'nl.x-services.plugins.calendar' : 'cordova-plugin-calendar',
-    'nl.x-services.plugins.launchmyapp' : 'cordova-plugin-customurlscheme',
-    'nl.x-services.plugins.flashlight' : 'cordova-plugin-flashlight',
-    'nl.x-services.plugins.sslcertificatechecker' : 'cordova-plugin-sslcertificatechecker',
-    'com.bridge.open' : 'cordova-open',
-    'com.bridge.safe' : 'cordova-safe',
-    'com.disusered.open' : 'cordova-open',
-    'com.disusered.safe' : 'cordova-safe',
-    'me.apla.cordova.app-preferences' : 'cordova-plugin-app-preferences',
-    'com.konotor.cordova' : 'cordova-plugin-konotor',
-    'io.intercom.cordova' : 'cordova-plugin-intercom',
-    'com.onesignal.plugins.onesignal' : 'onesignal-cordova-plugin',
-    'com.danjarvis.document-contract': 'cordova-plugin-document-contract',
-    'com.eface2face.iosrtc' : 'cordova-plugin-iosrtc',
-    'com.mobileapptracking.matplugin' : 'cordova-plugin-tune',
-    'com.marianhello.cordova.background-geolocation' : 'cordova-plugin-mauron85-background-geolocation',
-    'fr.louisbl.cordova.locationservices' : 'cordova-plugin-locationservices',
-    'fr.louisbl.cordova.gpslocation' : 'cordova-plugin-gpslocation',
-    'com.hiliaox.weibo' : 'cordova-plugin-weibo',
-    'com.uxcam.cordova.plugin' : 'cordova-uxcam',
-    'de.fastr.phonegap.plugins.downloader' : 'cordova-plugin-fastrde-downloader',
-    'de.fastr.phonegap.plugins.injectView' : 'cordova-plugin-fastrde-injectview',
-    'de.fastr.phonegap.plugins.CheckGPS' : 'cordova-plugin-fastrde-checkgps',
-    'de.fastr.phonegap.plugins.md5chksum' : 'cordova-plugin-fastrde-md5',
-    'io.repro.cordova' : 'cordova-plugin-repro',
-    're.notifica.cordova': 'cordova-plugin-notificare-push',
-    'com.megster.cordova.ble': 'cordova-plugin-ble-central',
-    'com.megster.cordova.bluetoothserial': 'cordova-plugin-bluetooth-serial',
-    'com.megster.cordova.rfduino': 'cordova-plugin-rfduino',
-    'cz.velda.cordova.plugin.devicefeedback': 'cordova-plugin-velda-devicefeedback',
-    'cz.Velda.cordova.plugin.devicefeedback': 'cordova-plugin-velda-devicefeedback',
-    'org.scriptotek.appinfo': 'cordova-plugin-appinfo',
-    'com.yezhiming.cordova.appinfo': 'cordova-plugin-appinfo',
-    'pl.makingwaves.estimotebeacons': 'cordova-plugin-estimote',
-    'com.evothings.ble': 'cordova-plugin-ble',
-    'com.appsee.plugin' : 'cordova-plugin-appsee',
-    'am.armsoft.plugins.listpicker': 'cordova-plugin-listpicker',
-    'com.pushbots.push': 'pushbots-cordova-plugin',
-    'com.admob.google': 'cordova-admob',
-    'admob.ads.google': 'cordova-admob-ads',
-    'admob.google.plugin': 'admob-google',
-    'com.admob.admobads': 'admob-ads',
-    'com.connectivity.monitor': 'cordova-connectivity-monitor',
-    'com.ios.libgoogleadmobads': 'cordova-libgoogleadmobads',
-    'com.google.play.services': 'cordova-google-play-services',
-    'android.support.v13': 'cordova-android-support-v13',
-    'android.support.v4': 'cordova-android-support-v4', // Duplicated key ;)
-    'com.analytics.google': 'cordova-plugin-analytics',
-    'com.analytics.adid.google': 'cordova-plugin-analytics-adid',
-    'com.chariotsolutions.nfc.plugin': 'phonegap-nfc',
-    'com.samz.mixpanel': 'cordova-plugin-mixpanel',
-    'de.appplant.cordova.common.RegisterUserNotificationSettings': 'cordova-plugin-registerusernotificationsettings',
-    'plugin.google.maps': 'cordova-plugin-googlemaps',
-    'xu.li.cordova.wechat': 'cordova-plugin-wechat',
-    'es.keensoft.fullscreenimage': 'cordova-plugin-fullscreenimage',
-    'com.arcoirislabs.plugin.mqtt' : 'cordova-plugin-mqtt'
-};
-
-module.exports.oldToNew = map;
-
-var reverseMap = {};
-Object.keys(map).forEach(function(elem){
-    reverseMap[map[elem]] = elem;
-});
-
-module.exports.newToOld = reverseMap;

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-registry-mapper/package.json
----------------------------------------------------------------------
diff --git a/node_modules/cordova-registry-mapper/package.json b/node_modules/cordova-registry-mapper/package.json
deleted file mode 100644
index 6025e7a..0000000
--- a/node_modules/cordova-registry-mapper/package.json
+++ /dev/null
@@ -1,84 +0,0 @@
-{
-  "_args": [
-    [
-      {
-        "name": "cordova-registry-mapper",
-        "raw": "cordova-registry-mapper@^1.1.8",
-        "rawSpec": "^1.1.8",
-        "scope": null,
-        "spec": ">=1.1.8 <2.0.0",
-        "type": "range"
-      },
-      "/Users/ctran/cordova/cordova-lib/cordova-create/node_modules/cordova-common"
-    ]
-  ],
-  "_from": "cordova-registry-mapper@>=1.1.8 <2.0.0",
-  "_id": "cordova-registry-mapper@1.1.15",
-  "_inCache": true,
-  "_installable": true,
-  "_location": "/cordova-registry-mapper",
-  "_nodeVersion": "5.4.1",
-  "_npmUser": {
-    "email": "stevengill97@gmail.com",
-    "name": "stevegill"
-  },
-  "_npmVersion": "3.5.3",
-  "_phantomChildren": {},
-  "_requested": {
-    "name": "cordova-registry-mapper",
-    "raw": "cordova-registry-mapper@^1.1.8",
-    "rawSpec": "^1.1.8",
-    "scope": null,
-    "spec": ">=1.1.8 <2.0.0",
-    "type": "range"
-  },
-  "_requiredBy": [
-    "/cordova-common"
-  ],
-  "_resolved": "https://registry.npmjs.org/cordova-registry-mapper/-/cordova-registry-mapper-1.1.15.tgz",
-  "_shasum": "e244b9185b8175473bff6079324905115f83dc7c",
-  "_shrinkwrap": null,
-  "_spec": "cordova-registry-mapper@^1.1.8",
-  "_where": "/Users/ctran/cordova/cordova-lib/cordova-create/node_modules/cordova-common",
-  "author": {
-    "name": "Steve Gill"
-  },
-  "bugs": {
-    "url": "https://github.com/stevengill/cordova-registry-mapper/issues"
-  },
-  "dependencies": {},
-  "description": "Maps old plugin ids to new plugin names for fetching from npm",
-  "devDependencies": {
-    "tape": "^3.5.0"
-  },
-  "directories": {},
-  "dist": {
-    "shasum": "e244b9185b8175473bff6079324905115f83dc7c",
-    "tarball": "https://registry.npmjs.org/cordova-registry-mapper/-/cordova-registry-mapper-1.1.15.tgz"
-  },
-  "gitHead": "00af0f028ec94154a364eeabe38b8e22320647bd",
-  "homepage": "https://github.com/stevengill/cordova-registry-mapper#readme",
-  "keywords": [
-    "cordova",
-    "plugins"
-  ],
-  "license": "Apache version 2.0",
-  "main": "index.js",
-  "maintainers": [
-    {
-      "email": "stevengill97@gmail.com",
-      "name": "stevegill"
-    }
-  ],
-  "name": "cordova-registry-mapper",
-  "optionalDependencies": {},
-  "readme": "ERROR: No README data found!",
-  "repository": {
-    "type": "git",
-    "url": "git+https://github.com/stevengill/cordova-registry-mapper.git"
-  },
-  "scripts": {
-    "test": "node tests/test.js"
-  },
-  "version": "1.1.15"
-}

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/cordova-registry-mapper/tests/test.js
----------------------------------------------------------------------
diff --git a/node_modules/cordova-registry-mapper/tests/test.js b/node_modules/cordova-registry-mapper/tests/test.js
deleted file mode 100644
index 35343be..0000000
--- a/node_modules/cordova-registry-mapper/tests/test.js
+++ /dev/null
@@ -1,11 +0,0 @@
-var test = require('tape');
-var oldToNew = require('../index').oldToNew;
-var newToOld = require('../index').newToOld;
-
-test('plugin mappings exist', function(t) {
-    t.plan(2);
-
-    t.equal('cordova-plugin-device', oldToNew['org.apache.cordova.device']);
-
-    t.equal('org.apache.cordova.device', newToOld['cordova-plugin-device']);
-})

http://git-wip-us.apache.org/repos/asf/cordova-create/blob/9fb2883e/node_modules/core-util-is/LICENSE
----------------------------------------------------------------------
diff --git a/node_modules/core-util-is/LICENSE b/node_modules/core-util-is/LICENSE
deleted file mode 100644
index d8d7f94..0000000
--- a/node_modules/core-util-is/LICENSE
+++ /dev/null
@@ -1,19 +0,0 @@
-Copyright Node.js contributors. All rights reserved.
-
-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/cordova-create/blob/9fb2883e/node_modules/core-util-is/README.md
----------------------------------------------------------------------
diff --git a/node_modules/core-util-is/README.md b/node_modules/core-util-is/README.md
deleted file mode 100644
index 5a76b41..0000000
--- a/node_modules/core-util-is/README.md
+++ /dev/null
@@ -1,3 +0,0 @@
-# core-util-is
-
-The `util.is*` functions introduced in Node v0.12.


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@cordova.apache.org
For additional commands, e-mail: commits-help@cordova.apache.org