You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cordova.apache.org by js...@apache.org on 2014/07/07 23:43:25 UTC

[19/51] [partial] CB-7087 Retire blackberry10/ directory

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/lib/prompt.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/lib/prompt.js b/blackberry10/node_modules/prompt/lib/prompt.js
deleted file mode 100644
index 250b047..0000000
--- a/blackberry10/node_modules/prompt/lib/prompt.js
+++ /dev/null
@@ -1,756 +0,0 @@
-/*
- * prompt.js: Simple prompt for prompting information from the command line
- *
- * (C) 2010, Nodejitsu Inc.
- *
- */
-
-var events = require('events'),
-    readline = require('readline'),
-    utile = require('utile'),
-    async = utile.async,
-    read = require('read'),
-    validate = require('revalidator').validate,
-    winston = require('winston');
-
-//
-// Monkey-punch readline.Interface to work-around
-// https://github.com/joyent/node/issues/3860
-//
-readline.Interface.prototype.setPrompt = function(prompt, length) {
-  this._prompt = prompt;
-  if (length) {
-    this._promptLength = length;
-  } else {
-    var lines = prompt.split(/[\r\n]/);
-    var lastLine = lines[lines.length - 1];
-    this._promptLength = lastLine.replace(/\u001b\[(\d+(;\d+)*)?m/g, '').length;
-  }
-};
-
-//
-// Expose version using `pkginfo`
-//
-require('pkginfo')(module, 'version');
-
-var stdin, stdout, history = [];
-var prompt = module.exports = Object.create(events.EventEmitter.prototype);
-var logger = prompt.logger = new winston.Logger({
-  transports: [new (winston.transports.Console)()]
-});
-
-prompt.started    = false;
-prompt.paused     = false;
-prompt.allowEmpty = false;
-prompt.message    = 'prompt';
-prompt.delimiter  = ': ';
-prompt.colors     = true;
-
-//
-// Create an empty object for the properties
-// known to `prompt`
-//
-prompt.properties = {};
-
-//
-// Setup the default winston logger to use
-// the `cli` levels and colors.
-//
-logger.cli();
-
-//
-// ### function start (options)
-// #### @options {Object} **Optional** Options to consume by prompt
-// Starts the prompt by listening to the appropriate events on `options.stdin`
-// and `options.stdout`. If no streams are supplied, then `process.stdin`
-// and `process.stdout` are used, respectively.
-//
-prompt.start = function (options) {
-  if (prompt.started) {
-    return;
-  }
-
-  options = options        || {};
-  stdin   = options.stdin  || process.stdin;
-  stdout  = options.stdout || process.stdout;
-
-  //
-  // By default: Remember the last `10` prompt property /
-  // answer pairs and don't allow empty responses globally.
-  //
-  prompt.memory     = options.memory     || 10;
-  prompt.allowEmpty = options.allowEmpty || false;
-  prompt.message    = options.message    || prompt.message;
-  prompt.delimiter  = options.delimiter  || prompt.delimiter;
-  prompt.colors     = options.colors     || prompt.colors;
-
-  if (process.platform !== 'win32') {
-    // windows falls apart trying to deal with SIGINT
-    process.on('SIGINT', function () {
-      stdout.write('\n');
-      process.exit(1);
-    });
-  }
-
-  prompt.emit('start');
-  prompt.started = true;
-  return prompt;
-};
-
-//
-// ### function pause ()
-// Pauses input coming in from stdin
-//
-prompt.pause = function () {
-  if (!prompt.started || prompt.paused) {
-    return;
-  }
-
-  stdin.pause();
-  prompt.emit('pause');
-  prompt.paused = true;
-  return prompt;
-};
-
-//
-// ### function resume ()
-// Resumes input coming in from stdin
-//
-prompt.resume = function () {
-  if (!prompt.started || !prompt.paused) {
-    return;
-  }
-
-  stdin.resume();
-  prompt.emit('resume');
-  prompt.paused = false;
-  return prompt;
-};
-
-//
-// ### function history (search)
-// #### @search {Number|string} Index or property name to find.
-// Returns the `property:value` pair from within the prompts
-// `history` array.
-//
-prompt.history = function (search) {
-  if (typeof search === 'number') {
-    return history[search] || {};
-  }
-
-  var names = history.map(function (pair) {
-    return typeof pair.property === 'string'
-      ? pair.property
-      : pair.property.name;
-  });
-
-  if (~names.indexOf(search)) {
-    return null;
-  }
-
-  return history.filter(function (pair) {
-    return typeof pair.property === 'string'
-      ? pair.property === search
-      : pair.property.name === search;
-  })[0];
-};
-
-//
-// ### function get (schema, callback)
-// #### @schema {Array|Object|string} Set of variables to get input for.
-// #### @callback {function} Continuation to pass control to when complete.
-// Gets input from the user via stdin for the specified message(s) `msg`.
-//
-prompt.get = function (schema, callback) {
-  //
-  // Transforms a full JSON-schema into an array describing path and sub-schemas.
-  // Used for iteration purposes.
-  //
-  function untangle(schema, path) {
-    var results = [];
-    path = path || [];
-
-    if (schema.properties) {
-      //
-      // Iterate over the properties in the schema and use recursion
-      // to process sub-properties.
-      //
-      Object.keys(schema.properties).forEach(function (key) {
-        var obj = {};
-        obj[key] = schema.properties[key];
-
-        //
-        // Concat a sub-untangling to the results.
-        //
-        results = results.concat(untangle(obj[key], path.concat(key)));
-      });
-
-      // Return the results.
-      return results;
-    }
-
-    //
-    // This is a schema "leaf".
-    //
-    return {
-      path: path,
-      schema: schema
-    };
-  }
-
-  //
-  // Iterate over the values in the schema, represented as
-  // a legit single-property object subschemas. Accepts `schema`
-  // of the forms:
-  //
-  //    'prop-name'
-  //
-  //    ['string-name', { path: ['or-well-formed-subschema'], properties: ... }]
-  //
-  //    { path: ['or-well-formed-subschema'], properties: ... ] }
-  //
-  //    { properties: { 'schema-with-no-path' } }
-  //
-  // And transforms them all into
-  //
-  //    { path: ['path', 'to', 'property'], properties: { path: { to: ...} } }
-  //
-  function iterate(schema, get, done) {
-    var iterator = [],
-        result = {};
-
-    if (typeof schema === 'string') {
-      //
-      // We can iterate over a single string.
-      //
-      iterator.push({
-        path: [schema],
-        schema: prompt.properties[schema.toLowerCase()] || {}
-      });
-    }
-    else if (Array.isArray(schema)) {
-      //
-      // An array of strings and/or single-prop schema and/or no-prop schema.
-      //
-      iterator = schema.map(function (element) {
-        if (typeof element === 'string') {
-          return {
-            path: [element],
-            schema: prompt.properties[element.toLowerCase()] || {}
-          };
-        }
-        else if (element.properties) {
-          return {
-            path: [Object.keys(element.properties)[0]],
-            schema: element.properties[Object.keys(element.properties)[0]]
-          };
-        }
-        else if (element.path && element.schema) {
-          return element;
-        }
-        else {
-          return {
-            path: [element.name || 'question'],
-            schema: element
-          };
-        }
-      });
-    }
-    else if (schema.properties) {
-      //
-      // Or a complete schema `untangle` it for use.
-      //
-      iterator = untangle(schema);
-    }
-    else {
-      //
-      // Or a partial schema and path.
-      // TODO: Evaluate need for this option.
-      //
-      iterator = [{
-        schema: schema.schema ? schema.schema : schema,
-        path: schema.path || [schema.name || 'question']
-      }];
-    }
-
-    //
-    // Now, iterate and assemble the result.
-    //
-    async.forEachSeries(iterator, function (branch, next) {
-      get(branch, function assembler(err, line) {
-        if (err) {
-          return next(err);
-        }
-
-        function build(path, line) {
-          var obj = {};
-          if (path.length) {
-            obj[path[0]] = build(path.slice(1), line);
-            return obj;
-          }
-
-          return line;
-        }
-
-        function attach(obj, attr) {
-          var keys;
-          if (typeof attr !== 'object' || attr instanceof Array) {
-            return attr;
-          }
-
-          keys = Object.keys(attr);
-          if (keys.length) {
-            if (!obj[keys[0]]) {
-              obj[keys[0]] = {};
-            }
-            obj[keys[0]] = attach(obj[keys[0]], attr[keys[0]]);
-          }
-
-          return obj;
-        }
-
-        result = attach(result, build(branch.path, line));
-        next();
-      });
-    }, function (err) {
-      return err ? done(err) : done(null, result);
-    });
-  }
-
-  iterate(schema, function get(target, next) {
-    prompt.getInput(target, function (err, line) {
-      return err ? next(err) : next(null, line);
-    });
-  }, callback);
-
-  return prompt;
-};
-
-//
-// ### function confirm (msg, callback)
-// #### @msg {Array|Object|string} set of message to confirm
-// #### @callback {function} Continuation to pass control to when complete.
-// Confirms a single or series of messages by prompting the user for a Y/N response.
-// Returns `true` if ALL messages are answered in the affirmative, otherwise `false`
-//
-// `msg` can be a string, or object (or array of strings/objects).
-// An object may have the following properties:
-//
-//    {
-//      description: 'yes/no' // message to prompt user
-//      pattern: /^[yntf]{1}/i // optional - regex defining acceptable responses
-//      yes: /^[yt]{1}/i // optional - regex defining `affirmative` responses
-//      message: 'yes/no' // optional - message to display for invalid responses
-//    }
-//
-prompt.confirm = function (/* msg, options, callback */) {
-  var args     = Array.prototype.slice.call(arguments),
-      msg      = args.shift(),
-      callback = args.pop(),
-      opts     = args.shift(),
-      vars     = !Array.isArray(msg) ? [msg] : msg,
-      RX_Y     = /^[yt]{1}/i,
-      RX_YN    = /^[yntf]{1}/i;
-
-  function confirm(target, next) {
-    var yes = target.yes || RX_Y,
-      options = utile.mixin({
-        description: typeof target === 'string' ? target : target.description||'yes/no',
-        pattern: target.pattern || RX_YN,
-        name: 'confirm',
-        message: target.message || 'yes/no'
-      }, opts || {});
-
-
-    prompt.get([options], function (err, result) {
-      next(err ? false : yes.test(result[options.name]));
-    });
-  }
-
-  async.rejectSeries(vars, confirm, function(result) {
-    callback(null, result.length===0);
-  });
-};
-
-
-// Variables needed outside of getInput for multiline arrays.
-var tmp = [];
-
-
-// ### function getInput (prop, callback)
-// #### @prop {Object|string} Variable to get input for.
-// #### @callback {function} Continuation to pass control to when complete.
-// Gets input from the user via stdin for the specified message `msg`.
-//
-prompt.getInput = function (prop, callback) {
-  var schema = prop.schema || prop,
-      propName = prop.path && prop.path.join(':') || prop,
-      storedSchema = prompt.properties[propName.toLowerCase()],
-      delim = prompt.delimiter,
-      defaultLine,
-      against,
-      hidden,
-      length,
-      valid,
-      name,
-      raw,
-      msg;
-
-  //
-  // If there is a stored schema for `propName` in `propmpt.properties`
-  // then use it.
-  //
-  if (schema instanceof Object && !Object.keys(schema).length &&
-    typeof storedSchema !== 'undefined') {
-    schema = storedSchema;
-  }
-
-  //
-  // Build a proper validation schema if we just have a string
-  // and no `storedSchema`.
-  //
-  if (typeof prop === 'string' && !storedSchema) {
-    schema = {};
-  }
-
-  schema = convert(schema);
-  defaultLine = schema.default;
-  name = prop.description || schema.description || propName;
-  raw = prompt.colors
-    ? [prompt.message, delim + name.grey, delim.grey]
-    : [prompt.message, delim + name, delim];
-
-  prop = {
-    schema: schema,
-    path: propName.split(':')
-  };
-
-  //
-  // If the schema has no `properties` value then set
-  // it to an object containing the current schema
-  // for `propName`.
-  //
-  if (!schema.properties) {
-    schema = (function () {
-      var obj = { properties: {} };
-      obj.properties[propName] = schema;
-      return obj;
-    })();
-  }
-
-  //
-  // Handle overrides here.
-  // TODO: Make overrides nestable
-  //
-  if (prompt.override && prompt.override[propName]) {
-    if (prompt._performValidation(name, prop, prompt.override, schema, -1, callback)) {
-      return callback(null, prompt.override[propName]);
-    }
-
-    delete prompt.override[propName];
-  }
-
-  var type = (schema.properties && schema.properties[name] &&
-              schema.properties[name].type || '').toLowerCase().trim(),
-      wait = type === 'array';
-
-  if (type === 'array') {
-    length = prop.schema.maxItems;
-    if (length) {
-      msg = (tmp.length + 1).toString() + '/' + length.toString();
-    }
-    else {
-      msg = (tmp.length + 1).toString();
-    }
-    msg += delim;
-    raw.push(prompt.colors ? msg.grey : msg);
-  }
-
-  //
-  // Calculate the raw length and colorize the prompt
-  //
-  length = raw.join('').length;
-  raw[0] = raw[0];
-  msg = raw.join('');
-
-  if (schema.help) {
-    schema.help.forEach(function (line) {
-      logger.help(line);
-    });
-  }
-
-  //
-  // Emit a "prompting" event
-  //
-  prompt.emit('prompt', prop);
-
-  //
-  // If there is no default line, set it to an empty string
-  //
-  if(typeof defaultLine === 'undefined') {
-    defaultLine = '';
-  }
-
-  //
-  // set to string for readline ( will not accept Numbers )
-  //
-  defaultLine = defaultLine.toString();
-
-  //
-  // Make the actual read
-  //
-  read({
-    prompt: msg,
-    silent: prop.schema && prop.schema.hidden,
-    default: defaultLine,
-    input: stdin,
-    output: stdout
-  }, function (err, line) {
-    if (err && wait === false) {
-      return callback(err);
-    }
-
-    var against = {},
-        numericInput,
-        isValid;
-
-    if (line !== '') {
-
-      if (schema.properties[name]) {
-        var type = (schema.properties[name].type || '').toLowerCase().trim() || undefined;
-
-        //
-        // Attempt to parse input as a float if the schema expects a number.
-        //
-        if (type == 'number') {
-          numericInput = parseFloat(line, 10);
-          if (!isNaN(numericInput)) {
-            line = numericInput;
-          }
-        }
-
-        //
-        // Attempt to parse input as a boolean if the schema expects a boolean
-        //
-        if (type == 'boolean') {
-          if(line === "true") {
-            line = true;
-          }
-          if(line === "false") {
-            line = false;
-          }
-        }
-
-        //
-        // If the type is an array, wait for the end. Fixes #54
-        //
-        if (type == 'array') {
-          var length = prop.schema.maxItems;
-          if (err) {
-            if (err.message == 'canceled') {
-              wait = false;
-              stdout.write('\n');
-            }
-          }
-          else {
-            if (length) {
-              if (tmp.length + 1 < length) {
-                isValid = false;
-                wait = true;
-              }
-              else {
-                isValid = true;
-                wait = false;
-              }
-            }
-            else {
-              isValid = false;
-              wait = true;
-            }
-            tmp.push(line);
-          }
-          line = tmp;
-        }
-      }
-
-      against[propName] = line;
-    }
-
-    if (prop && prop.schema.before) {
-      line = prop.schema.before(line);
-    }
-
-    // Validate
-    if (isValid === undefined) isValid = prompt._performValidation(name, prop, against, schema, line, callback);
-
-    if (!isValid) {
-      return prompt.getInput(prop, callback);
-    }
-
-    //
-    // Log the resulting line, append this `property:value`
-    // pair to the history for `prompt` and respond to
-    // the callback.
-    //
-    logger.input(line.yellow);
-    prompt._remember(propName, line);
-    callback(null, line);
-
-    // Make sure `tmp` is emptied
-    tmp = [];
-  });
-};
-
-//
-// ### function performValidation (name, prop, against, schema, line, callback)
-// #### @name {Object} Variable name
-// #### @prop {Object|string} Variable to get input for.
-// #### @against {Object} Input
-// #### @schema {Object} Validation schema
-// #### @line {String|Boolean} Input line
-// #### @callback {function} Continuation to pass control to when complete.
-// Perfoms user input validation, print errors if needed and returns value according to validation
-//
-prompt._performValidation = function (name, prop, against, schema, line, callback) {
-  var numericInput, valid, msg;
-
-  try {
-    valid = validate(against, schema);
-  }
-  catch (err) {
-    return (line !== -1) ? callback(err) : false;
-  }
-
-  if (!valid.valid) {
-    msg = line !== -1 ? 'Invalid input for ' : 'Invalid command-line input for ';
-
-    if (prompt.colors) {
-      logger.error(msg + name.grey);
-    }
-    else {
-      logger.error(msg + name);
-    }
-
-    if (prop.schema.message) {
-      logger.error(prop.schema.message);
-    }
-
-    prompt.emit('invalid', prop, line);
-  }
-
-  return valid.valid;
-};
-
-//
-// ### function addProperties (obj, properties, callback)
-// #### @obj {Object} Object to add properties to
-// #### @properties {Array} List of properties to get values for
-// #### @callback {function} Continuation to pass control to when complete.
-// Prompts the user for values each of the `properties` if `obj` does not already
-// have a value for the property. Responds with the modified object.
-//
-prompt.addProperties = function (obj, properties, callback) {
-  properties = properties.filter(function (prop) {
-    return typeof obj[prop] === 'undefined';
-  });
-
-  if (properties.length === 0) {
-    return callback(obj);
-  }
-
-  prompt.get(properties, function (err, results) {
-    if (err) {
-      return callback(err);
-    }
-    else if (!results) {
-      return callback(null, obj);
-    }
-
-    function putNested (obj, path, value) {
-      var last = obj, key;
-
-      while (path.length > 1) {
-        key = path.shift();
-        if (!last[key]) {
-          last[key] = {};
-        }
-
-        last = last[key];
-      }
-
-      last[path.shift()] = value;
-    }
-
-    Object.keys(results).forEach(function (key) {
-      putNested(obj, key.split('.'), results[key]);
-    });
-
-    callback(null, obj);
-  });
-
-  return prompt;
-};
-
-//
-// ### @private function _remember (property, value)
-// #### @property {Object|string} Property that the value is in response to.
-// #### @value {string} User input captured by `prompt`.
-// Prepends the `property:value` pair into the private `history` Array
-// for `prompt` so that it can be accessed later.
-//
-prompt._remember = function (property, value) {
-  history.unshift({
-    property: property,
-    value: value
-  });
-
-  //
-  // If the length of the `history` Array
-  // has exceeded the specified length to remember,
-  // `prompt.memory`, truncate it.
-  //
-  if (history.length > prompt.memory) {
-    history.splice(prompt.memory, history.length - prompt.memory);
-  }
-};
-
-//
-// ### @private function convert (schema)
-// #### @schema {Object} Schema for a property
-// Converts the schema into new format if it is in old format
-//
-function convert(schema) {
-  var newProps = Object.keys(validate.messages),
-      newSchema = false,
-      key;
-
-  newProps = newProps.concat(['description', 'dependencies']);
-
-  for (key in schema) {
-    if (newProps.indexOf(key) > 0) {
-      newSchema = true;
-      break;
-    }
-  }
-
-  if (!newSchema || schema.validator || schema.warning || typeof schema.empty !== 'undefined') {
-    schema.description = schema.message;
-    schema.message = schema.warning;
-
-    if (typeof schema.validator === 'function') {
-      schema.conform = schema.validator;
-    } else {
-      schema.pattern = schema.validator;
-    }
-
-    if (typeof schema.empty !== 'undefined') {
-      schema.required = !(schema.empty);
-    }
-
-    delete schema.warning;
-    delete schema.validator;
-    delete schema.empty;
-  }
-
-  return schema;
-}

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/.npmignore
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/.npmignore b/blackberry10/node_modules/prompt/node_modules/pkginfo/.npmignore
deleted file mode 100644
index 9303c34..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/.npmignore
+++ /dev/null
@@ -1,2 +0,0 @@
-node_modules/
-npm-debug.log
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/LICENSE
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/LICENSE b/blackberry10/node_modules/prompt/node_modules/pkginfo/LICENSE
deleted file mode 100644
index ed4a4e7..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/LICENSE
+++ /dev/null
@@ -1,19 +0,0 @@
-Copyright (c) 2010 Charlie Robbins.
-
-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.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/README.md
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/README.md b/blackberry10/node_modules/prompt/node_modules/pkginfo/README.md
deleted file mode 100644
index 332704e..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/README.md
+++ /dev/null
@@ -1,86 +0,0 @@
-# node-pkginfo
-
-An easy way to expose properties on a module from a package.json
-
-## Installation
-
-### Installing npm (node package manager)
-```
-  curl http://npmjs.org/install.sh | sh
-```
-
-### Installing pkginfo
-```
-  [sudo] npm install pkginfo
-```
-
-## Motivation
-How often when writing node.js modules have you written the following line(s) of code? 
-
-* Hard code your version string into your code
-
-``` js
-  exports.version = '0.1.0';
-```
-
-* Programmatically expose the version from the package.json
-
-``` js
-  exports.version = JSON.parse(fs.readFileSync('/path/to/package.json', 'utf8')).version;
-```
-
-In other words, how often have you wanted to expose basic information from your package.json onto your module programmatically? **WELL NOW YOU CAN!**
-
-## Usage
-
-Using `pkginfo` is idiot-proof, just require and invoke it. 
-
-``` js
-  var pkginfo = require('pkginfo')(module);
-  
-  console.dir(module.exports);
-```
-
-By invoking the `pkginfo` module all of the properties in your `package.json` file will be automatically exposed on the callee module (i.e. the parent module of `pkginfo`). 
-
-Here's a sample of the output:
-
-```
-  { name: 'simple-app',
-    description: 'A test fixture for pkginfo',
-    version: '0.1.0',
-    author: 'Charlie Robbins <ch...@gmail.com>',
-    keywords: [ 'test', 'fixture' ],
-    main: './index.js',
-    scripts: { test: 'vows test/*-test.js --spec' },
-    engines: { node: '>= 0.4.0' } }
-```
-
-### Expose specific properties
-If you don't want to expose **all** properties on from your `package.json` on your module then simple pass those properties to the `pkginfo` function:
-
-``` js
-  var pkginfo = require('pkginfo')(module, 'version', 'author');
-  
-  console.dir(module.exports);
-```
-
-```
-  { version: '0.1.0',
-    author: 'Charlie Robbins <ch...@gmail.com>' }
-```
-
-If you're looking for further usage see the [examples][0] included in this repository. 
-
-## Run Tests
-Tests are written in [vows][1] and give complete coverage of all APIs.
-
-```
-  vows test/*-test.js --spec
-```
-
-[0]: https://github.com/indexzero/node-pkginfo/tree/master/examples
-[1]: http://vowsjs.org
-
-#### Author: [Charlie Robbins](http://nodejitsu.com)
-#### License: MIT
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/docco.css
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/docco.css b/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/docco.css
deleted file mode 100644
index bd54134..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/docco.css
+++ /dev/null
@@ -1,194 +0,0 @@
-/*--------------------- Layout and Typography ----------------------------*/
-body {
-  font-family: 'Palatino Linotype', 'Book Antiqua', Palatino, FreeSerif, serif;
-  font-size: 15px;
-  line-height: 22px;
-  color: #252519;
-  margin: 0; padding: 0;
-}
-a {
-  color: #261a3b;
-}
-  a:visited {
-    color: #261a3b;
-  }
-p {
-  margin: 0 0 15px 0;
-}
-h4, h5, h6 {
-  color: #333;
-  margin: 6px 0 6px 0;
-  font-size: 13px;
-}
-  h2, h3 {
-    margin-bottom: 0;
-    color: #000;
-  }
-    h1 {
-      margin-top: 40px;
-      margin-bottom: 15px;
-      color: #000;
-    }
-#container {
-  position: relative;
-}
-#background {
-  position: fixed;
-  top: 0; left: 525px; right: 0; bottom: 0;
-  background: #f5f5ff;
-  border-left: 1px solid #e5e5ee;
-  z-index: -1;
-}
-#jump_to, #jump_page {
-  background: white;
-  -webkit-box-shadow: 0 0 25px #777; -moz-box-shadow: 0 0 25px #777;
-  -webkit-border-bottom-left-radius: 5px; -moz-border-radius-bottomleft: 5px;
-  font: 10px Arial;
-  text-transform: uppercase;
-  cursor: pointer;
-  text-align: right;
-}
-#jump_to, #jump_wrapper {
-  position: fixed;
-  right: 0; top: 0;
-  padding: 5px 10px;
-}
-  #jump_wrapper {
-    padding: 0;
-    display: none;
-  }
-    #jump_to:hover #jump_wrapper {
-      display: block;
-    }
-    #jump_page {
-      padding: 5px 0 3px;
-      margin: 0 0 25px 25px;
-    }
-      #jump_page .source {
-        display: block;
-        padding: 5px 10px;
-        text-decoration: none;
-        border-top: 1px solid #eee;
-      }
-        #jump_page .source:hover {
-          background: #f5f5ff;
-        }
-        #jump_page .source:first-child {
-        }
-table td {
-  border: 0;
-  outline: 0;
-}
-  td.docs, th.docs {
-    max-width: 450px;
-    min-width: 450px;
-    min-height: 5px;
-    padding: 10px 25px 1px 50px;
-    overflow-x: hidden;
-    vertical-align: top;
-    text-align: left;
-  }
-    .docs pre {
-      margin: 15px 0 15px;
-      padding-left: 15px;
-    }
-    .docs p tt, .docs p code {
-      background: #f8f8ff;
-      border: 1px solid #dedede;
-      font-size: 12px;
-      padding: 0 0.2em;
-    }
-    .pilwrap {
-      position: relative;
-    }
-      .pilcrow {
-        font: 12px Arial;
-        text-decoration: none;
-        color: #454545;
-        position: absolute;
-        top: 3px; left: -20px;
-        padding: 1px 2px;
-        opacity: 0;
-        -webkit-transition: opacity 0.2s linear;
-      }
-        td.docs:hover .pilcrow {
-          opacity: 1;
-        }
-  td.code, th.code {
-    padding: 14px 15px 16px 25px;
-    width: 100%;
-    vertical-align: top;
-    background: #f5f5ff;
-    border-left: 1px solid #e5e5ee;
-  }
-    pre, tt, code {
-      font-size: 12px; line-height: 18px;
-      font-family: Menlo, Monaco, Consolas, "Lucida Console", monospace;
-      margin: 0; padding: 0;
-    }
-
-
-/*---------------------- Syntax Highlighting -----------------------------*/
-td.linenos { background-color: #f0f0f0; padding-right: 10px; }
-span.lineno { background-color: #f0f0f0; padding: 0 5px 0 5px; }
-body .hll { background-color: #ffffcc }
-body .c { color: #408080; font-style: italic }  /* Comment */
-body .err { border: 1px solid #FF0000 }         /* Error */
-body .k { color: #954121 }                      /* Keyword */
-body .o { color: #666666 }                      /* Operator */
-body .cm { color: #408080; font-style: italic } /* Comment.Multiline */
-body .cp { color: #BC7A00 }                     /* Comment.Preproc */
-body .c1 { color: #408080; font-style: italic } /* Comment.Single */
-body .cs { color: #408080; font-style: italic } /* Comment.Special */
-body .gd { color: #A00000 }                     /* Generic.Deleted */
-body .ge { font-style: italic }                 /* Generic.Emph */
-body .gr { color: #FF0000 }                     /* Generic.Error */
-body .gh { color: #000080; font-weight: bold }  /* Generic.Heading */
-body .gi { color: #00A000 }                     /* Generic.Inserted */
-body .go { color: #808080 }                     /* Generic.Output */
-body .gp { color: #000080; font-weight: bold }  /* Generic.Prompt */
-body .gs { font-weight: bold }                  /* Generic.Strong */
-body .gu { color: #800080; font-weight: bold }  /* Generic.Subheading */
-body .gt { color: #0040D0 }                     /* Generic.Traceback */
-body .kc { color: #954121 }                     /* Keyword.Constant */
-body .kd { color: #954121; font-weight: bold }  /* Keyword.Declaration */
-body .kn { color: #954121; font-weight: bold }  /* Keyword.Namespace */
-body .kp { color: #954121 }                     /* Keyword.Pseudo */
-body .kr { color: #954121; font-weight: bold }  /* Keyword.Reserved */
-body .kt { color: #B00040 }                     /* Keyword.Type */
-body .m { color: #666666 }                      /* Literal.Number */
-body .s { color: #219161 }                      /* Literal.String */
-body .na { color: #7D9029 }                     /* Name.Attribute */
-body .nb { color: #954121 }                     /* Name.Builtin */
-body .nc { color: #0000FF; font-weight: bold }  /* Name.Class */
-body .no { color: #880000 }                     /* Name.Constant */
-body .nd { color: #AA22FF }                     /* Name.Decorator */
-body .ni { color: #999999; font-weight: bold }  /* Name.Entity */
-body .ne { color: #D2413A; font-weight: bold }  /* Name.Exception */
-body .nf { color: #0000FF }                     /* Name.Function */
-body .nl { color: #A0A000 }                     /* Name.Label */
-body .nn { color: #0000FF; font-weight: bold }  /* Name.Namespace */
-body .nt { color: #954121; font-weight: bold }  /* Name.Tag */
-body .nv { color: #19469D }                     /* Name.Variable */
-body .ow { color: #AA22FF; font-weight: bold }  /* Operator.Word */
-body .w { color: #bbbbbb }                      /* Text.Whitespace */
-body .mf { color: #666666 }                     /* Literal.Number.Float */
-body .mh { color: #666666 }                     /* Literal.Number.Hex */
-body .mi { color: #666666 }                     /* Literal.Number.Integer */
-body .mo { color: #666666 }                     /* Literal.Number.Oct */
-body .sb { color: #219161 }                     /* Literal.String.Backtick */
-body .sc { color: #219161 }                     /* Literal.String.Char */
-body .sd { color: #219161; font-style: italic } /* Literal.String.Doc */
-body .s2 { color: #219161 }                     /* Literal.String.Double */
-body .se { color: #BB6622; font-weight: bold }  /* Literal.String.Escape */
-body .sh { color: #219161 }                     /* Literal.String.Heredoc */
-body .si { color: #BB6688; font-weight: bold }  /* Literal.String.Interpol */
-body .sx { color: #954121 }                     /* Literal.String.Other */
-body .sr { color: #BB6688 }                     /* Literal.String.Regex */
-body .s1 { color: #219161 }                     /* Literal.String.Single */
-body .ss { color: #19469D }                     /* Literal.String.Symbol */
-body .bp { color: #954121 }                     /* Name.Builtin.Pseudo */
-body .vc { color: #19469D }                     /* Name.Variable.Class */
-body .vg { color: #19469D }                     /* Name.Variable.Global */
-body .vi { color: #19469D }                     /* Name.Variable.Instance */
-body .il { color: #666666 }                     /* Literal.Number.Integer.Long */
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/pkginfo.html
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/pkginfo.html b/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/pkginfo.html
deleted file mode 100644
index bf615fa..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/docs/pkginfo.html
+++ /dev/null
@@ -1,101 +0,0 @@
-<!DOCTYPE html>  <html> <head>   <title>pkginfo.js</title>   <meta http-equiv="content-type" content="text/html; charset=UTF-8">   <link rel="stylesheet" media="all" href="docco.css" /> </head> <body>   <div id="container">     <div id="background"></div>          <table cellpadding="0" cellspacing="0">       <thead>         <tr>           <th class="docs">             <h1>               pkginfo.js             </h1>           </th>           <th class="code">           </th>         </tr>       </thead>       <tbody>                               <tr id="section-1">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-1">&#182;</a>               </div>                            </td>             <td class="code">               <div class="highlight"><pre><span class="cm">/*</span>
-<span class="cm"> * pkginfo.js: Top-level include for the pkginfo module</span>
-<span class="cm"> *</span>
-<span class="cm"> * (C) 2011, Charlie Robbins</span>
-<span class="cm"> *</span>
-<span class="cm"> */</span>
- 
-<span class="kd">var</span> <span class="nx">fs</span> <span class="o">=</span> <span class="nx">require</span><span class="p">(</span><span class="s1">&#39;fs&#39;</span><span class="p">),</span>
-    <span class="nx">path</span> <span class="o">=</span> <span class="nx">require</span><span class="p">(</span><span class="s1">&#39;path&#39;</span><span class="p">);</span></pre></div>             </td>           </tr>                               <tr id="section-2">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-2">&#182;</a>               </div>               <h3>function pkginfo ([options, 'property', 'property' ..])</h3>
-
-<h4>@pmodule {Module} Parent module to read from.</h4>
-
-<h4>@options {Object|Array|string} <strong>Optional</strong> Options used when exposing properties.</h4>
-
-<h4>@arguments {string...} <strong>Optional</strong> Specified properties to expose.</h4>
-
-<p>Exposes properties from the package.json file for the parent module on 
-it's exports. Valid usage:</p>
-
-<p><code>require('pkginfo')()</code></p>
-
-<p><code>require('pkginfo')('version', 'author');</code></p>
-
-<p><code>require('pkginfo')(['version', 'author']);</code></p>
-
-<p><code>require('pkginfo')({ include: ['version', 'author'] });</code></p>             </td>             <td class="code">               <div class="highlight"><pre><span class="kd">var</span> <span class="nx">pkginfo</span> <span class="o">=</span> <span class="nx">module</span><span class="p">.</span><span class="nx">exports</span> <span class="o">=</span> <span class="kd">function</span> <span class="p">(</span><span class="nx">pmodule</span><span class="p">,</span> <span class="nx">options</span><span class="p">)</span> <span class="p">{</span>
-  <span class="kd">var</span> <span class="nx">args</span> <span class="o">=</span> <span class="p">[].</span><span class="nx">slice</span><span class="p">.</span><span class="nx">call</span><span class="p">(</span><span class="nx">arguments</span><span class="p">,</span> <span class="mi">2</span><span class="p">).</span><span class="nx">filter</span><span class="p">(</span><span class="kd">function</span> <span class="p">(</span><span class="nx">arg</span><span class="p">)</span> <span class="p">{</span>
-    <span class="k">return</span> <span class="k">typeof</span> <span class="nx">arg</span> <span class="o">===</span> <span class="s1">&#39;string&#39;</span><span class="p">;</span>
-  <span class="p">});</span>
-  </pre></div>             </td>           </tr>                               <tr id="section-3">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-3">&#182;</a>               </div>               <p><strong>Parse variable arguments</strong></p>             </td>             <td class="code">               <div class="highlight"><pre>  <span class="k">if</span> <span class="p">(</span><span class="nb">Array</span><span class="p">.</span><span class="nx">isArray</span><span class="p">(</span><span class="nx">options</span><span class="p">))</span> <span class="p">{</span></pre></div>             </td>           </tr>                               <tr id="section-4">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-4">&#182;</a>               </div>               <p>If the options passed in is an Array assume that
-it is the Array of properties to expose from the
-on the package.json file on the parent module.</p>             </td>             <td class="code">               <div class="highlight"><pre>    <span class="nx">options</span> <span class="o">=</span> <span class="p">{</span> <span class="nx">include</span><span class="o">:</span> <span class="nx">options</span> <span class="p">};</span>
-  <span class="p">}</span>
-  <span class="k">else</span> <span class="k">if</span> <span class="p">(</span><span class="k">typeof</span> <span class="nx">options</span> <span class="o">===</span> <span class="s1">&#39;string&#39;</span><span class="p">)</span> <span class="p">{</span></pre></div>             </td>           </tr>                               <tr id="section-5">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-5">&#182;</a>               </div>               <p>Otherwise if the first argument is a string, then
-assume that it is the first property to expose from
-the package.json file on the parent module.</p>             </td>             <td class="code">               <div class="highlight"><pre>    <span class="nx">options</span> <span class="o">=</span> <span class="p">{</span> <span class="nx">include</span><span class="o">:</span> <span class="p">[</span><span class="nx">options</span><span class="p">]</span> <span class="p">};</span>
-  <span class="p">}</span>
-  </pre></div>             </td>           </tr>                               <tr id="section-6">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-6">&#182;</a>               </div>               <p><strong>Setup default options</strong></p>             </td>             <td class="code">               <div class="highlight"><pre>  <span class="nx">options</span> <span class="o">=</span> <span class="nx">options</span> <span class="o">||</span> <span class="p">{</span> <span class="nx">include</span><span class="o">:</span> <span class="p">[]</span> <span class="p">};</span>
-  
-  <span class="k">if</span> <span class="p">(</span><span class="nx">args</span><span class="p">.</span><span class="nx">length</span> <span class="o">&gt;</span> <span class="mi">0</span><span class="p">)</span> <span class="p">{</span></pre></div>             </td>           </tr>                               <tr id="section-7">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-7">&#182;</a>               </div>               <p>If additional string arguments have been passed in
-then add them to the properties to expose on the 
-parent module. </p>             </td>             <td class="code">               <div class="highlight"><pre>    <span class="nx">options</span><span class="p">.</span><span class="nx">include</span> <span class="o">=</span> <span class="nx">options</span><span class="p">.</span><span class="nx">include</span><span class="p">.</span><span class="nx">concat</span><span class="p">(</span><span class="nx">args</span><span class="p">);</span>
-  <span class="p">}</span>
-  
-  <span class="kd">var</span> <span class="nx">pkg</span> <span class="o">=</span> <span class="nx">pkginfo</span><span class="p">.</span><span class="nx">read</span><span class="p">(</span><span class="nx">pmodule</span><span class="p">,</span> <span class="nx">options</span><span class="p">.</span><span class="nx">dir</span><span class="p">).</span><span class="kr">package</span><span class="p">;</span>
-  <span class="nb">Object</span><span class="p">.</span><span class="nx">keys</span><span class="p">(</span><span class="nx">pkg</span><span class="p">).</span><span class="nx">forEach</span><span class="p">(</span><span class="kd">function</span> <span class="p">(</span><span class="nx">key</span><span class="p">)</span> <span class="p">{</span>
-    <span class="k">if</span> <span class="p">(</span><span class="nx">options</span><span class="p">.</span><span class="nx">include</span><span class="p">.</span><span class="nx">length</span> <span class="o">&gt;</span> <span class="mi">0</span> <span class="o">&amp;&amp;</span> <span class="o">!~</span><span class="nx">options</span><span class="p">.</span><span class="nx">include</span><span class="p">.</span><span class="nx">indexOf</span><span class="p">(</span><span class="nx">key</span><span class="p">))</span> <span class="p">{</span>
-      <span class="k">return</span><span class="p">;</span>
-    <span class="p">}</span>
-    
-    <span class="k">if</span> <span class="p">(</span><span class="o">!</span><span class="nx">pmodule</span><span class="p">.</span><span class="nx">exports</span><span class="p">[</span><span class="nx">key</span><span class="p">])</span> <span class="p">{</span>
-      <span class="nx">pmodule</span><span class="p">.</span><span class="nx">exports</span><span class="p">[</span><span class="nx">key</span><span class="p">]</span> <span class="o">=</span> <span class="nx">pkg</span><span class="p">[</span><span class="nx">key</span><span class="p">];</span>
-    <span class="p">}</span>
-  <span class="p">});</span>
-  
-  <span class="k">return</span> <span class="nx">pkginfo</span><span class="p">;</span>
-<span class="p">};</span></pre></div>             </td>           </tr>                               <tr id="section-8">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-8">&#182;</a>               </div>               <h3>function find (dir)</h3>
-
-<h4>@pmodule {Module} Parent module to read from.</h4>
-
-<h4>@dir {string} <strong>Optional</strong> Directory to start search from.</h4>
-
-<p>Searches up the directory tree from <code>dir</code> until it finds a directory
-which contains a <code>package.json</code> file. </p>             </td>             <td class="code">               <div class="highlight"><pre><span class="nx">pkginfo</span><span class="p">.</span><span class="nx">find</span> <span class="o">=</span> <span class="kd">function</span> <span class="p">(</span><span class="nx">pmodule</span><span class="p">,</span> <span class="nx">dir</span><span class="p">)</span> <span class="p">{</span>
-  <span class="nx">dir</span> <span class="o">=</span> <span class="nx">dir</span> <span class="o">||</span> <span class="nx">pmodule</span><span class="p">.</span><span class="nx">filename</span><span class="p">;</span>
-  <span class="nx">dir</span> <span class="o">=</span> <span class="nx">path</span><span class="p">.</span><span class="nx">dirname</span><span class="p">(</span><span class="nx">dir</span><span class="p">);</span> 
-  
-  <span class="kd">var</span> <span class="nx">files</span> <span class="o">=</span> <span class="nx">fs</span><span class="p">.</span><span class="nx">readdirSync</span><span class="p">(</span><span class="nx">dir</span><span class="p">);</span>
-  
-  <span class="k">if</span> <span class="p">(</span><span class="o">~</span><span class="nx">files</span><span class="p">.</span><span class="nx">indexOf</span><span class="p">(</span><span class="s1">&#39;package.json&#39;</span><span class="p">))</span> <span class="p">{</span>
-    <span class="k">return</span> <span class="nx">path</span><span class="p">.</span><span class="nx">join</span><span class="p">(</span><span class="nx">dir</span><span class="p">,</span> <span class="s1">&#39;package.json&#39;</span><span class="p">);</span>
-  <span class="p">}</span>
-  
-  <span class="k">if</span> <span class="p">(</span><span class="nx">dir</span> <span class="o">===</span> <span class="s1">&#39;/&#39;</span><span class="p">)</span> <span class="p">{</span>
-    <span class="k">throw</span> <span class="k">new</span> <span class="nb">Error</span><span class="p">(</span><span class="s1">&#39;Could not find package.json up from: &#39;</span> <span class="o">+</span> <span class="nx">dir</span><span class="p">);</span>
-  <span class="p">}</span>
-  
-  <span class="k">return</span> <span class="nx">pkginfo</span><span class="p">.</span><span class="nx">find</span><span class="p">(</span><span class="nx">dir</span><span class="p">);</span>
-<span class="p">};</span></pre></div>             </td>           </tr>                               <tr id="section-9">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-9">&#182;</a>               </div>               <h3>function read (pmodule, dir)</h3>
-
-<h4>@pmodule {Module} Parent module to read from.</h4>
-
-<h4>@dir {string} <strong>Optional</strong> Directory to start search from.</h4>
-
-<p>Searches up the directory tree from <code>dir</code> until it finds a directory
-which contains a <code>package.json</code> file and returns the package information.</p>             </td>             <td class="code">               <div class="highlight"><pre><span class="nx">pkginfo</span><span class="p">.</span><span class="nx">read</span> <span class="o">=</span> <span class="kd">function</span> <span class="p">(</span><span class="nx">pmodule</span><span class="p">,</span> <span class="nx">dir</span><span class="p">)</span> <span class="p">{</span> 
-  <span class="nx">dir</span> <span class="o">=</span> <span class="nx">pkginfo</span><span class="p">.</span><span class="nx">find</span><span class="p">(</span><span class="nx">pmodule</span><span class="p">,</span> <span class="nx">dir</span><span class="p">);</span>
-  
-  <span class="kd">var</span> <span class="nx">data</span> <span class="o">=</span> <span class="nx">fs</span><span class="p">.</span><span class="nx">readFileSync</span><span class="p">(</span><span class="nx">dir</span><span class="p">).</span><span class="nx">toString</span><span class="p">();</span>
-      
-  <span class="k">return</span> <span class="p">{</span>
-    <span class="nx">dir</span><span class="o">:</span> <span class="nx">dir</span><span class="p">,</span> 
-    <span class="kr">package</span><span class="o">:</span> <span class="nx">JSON</span><span class="p">.</span><span class="nx">parse</span><span class="p">(</span><span class="nx">data</span><span class="p">)</span>
-  <span class="p">};</span>
-<span class="p">};</span></pre></div>             </td>           </tr>                               <tr id="section-10">             <td class="docs">               <div class="pilwrap">                 <a class="pilcrow" href="#section-10">&#182;</a>               </div>               <p>Call <code>pkginfo</code> on this module and expose version.</p>             </td>             <td class="code">               <div class="highlight"><pre><span class="nx">pkginfo</span><span class="p">(</span><span class="nx">module</span><span class="p">,</span> <span class="p">{</span>
-  <span class="nx">dir</span><span class="o">:</span> <span class="nx">__dirname</span><span class="p">,</span>
-  <span class="nx">include</span><span class="o">:</span> <span class="p">[</span><span class="s1">&#39;version&#39;</span><span class="p">],</span>
-  <span class="nx">target</span><span class="o">:</span> <span class="nx">pkginfo</span>
-<span class="p">});</span>
-
-</pre></div>             </td>           </tr>                </tbody>     </table>   </div> </body> </html> 
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/all-properties.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/all-properties.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/all-properties.js
deleted file mode 100644
index fd1d831..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/all-properties.js
+++ /dev/null
@@ -1,19 +0,0 @@
-/*
- * all-properties.js: Sample of including all properties from a package.json file
- *
- * (C) 2011, Charlie Robbins
- *
- */
-
-var util = require('util'),
-    pkginfo = require('../lib/pkginfo')(module);
-
-exports.someFunction = function () {
-  console.log('some of your custom logic here');
-};
-
-console.log('Inspecting module:');
-console.dir(module.exports);
-
-console.log('\nAll exports exposed:');
-console.error(Object.keys(module.exports));
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/array-argument.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/array-argument.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/array-argument.js
deleted file mode 100644
index b1b6848..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/array-argument.js
+++ /dev/null
@@ -1,20 +0,0 @@
-/*
- * array-argument.js: Sample of including specific properties from a package.json file
- *                    using Array argument syntax.
- *
- * (C) 2011, Charlie Robbins
- *
- */
- 
-var util = require('util'),
-    pkginfo = require('../lib/pkginfo')(module, ['version', 'author']);
-
-exports.someFunction = function () {
-  console.log('some of your custom logic here');
-};
-
-console.log('Inspecting module:');
-console.dir(module.exports);
-
-console.log('\nAll exports exposed:');
-console.error(Object.keys(module.exports));
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/multiple-properties.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/multiple-properties.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/multiple-properties.js
deleted file mode 100644
index b4b5fd6..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/multiple-properties.js
+++ /dev/null
@@ -1,19 +0,0 @@
-/*
- * multiple-properties.js: Sample of including multiple properties from a package.json file
- *
- * (C) 2011, Charlie Robbins
- *
- */
- 
-var util = require('util'),
-    pkginfo = require('../lib/pkginfo')(module, 'version', 'author');
-
-exports.someFunction = function () {
-  console.log('some of your custom logic here');
-};
-
-console.log('Inspecting module:');
-console.dir(module.exports);
-
-console.log('\nAll exports exposed:');
-console.error(Object.keys(module.exports));
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/object-argument.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/object-argument.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/object-argument.js
deleted file mode 100644
index 28420c8..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/object-argument.js
+++ /dev/null
@@ -1,22 +0,0 @@
-/*
- * object-argument.js: Sample of including specific properties from a package.json file
- *                     using Object argument syntax.
- *
- * (C) 2011, Charlie Robbins
- *
- */
- 
-var util = require('util'),
-    pkginfo = require('../lib/pkginfo')(module, {
-      include: ['version', 'author']
-    });
-
-exports.someFunction = function () {
-  console.log('some of your custom logic here');
-};
-
-console.log('Inspecting module:');
-console.dir(module.exports);
-
-console.log('\nAll exports exposed:');
-console.error(Object.keys(module.exports));
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/package.json
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/package.json b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/package.json
deleted file mode 100644
index 1f2f01c..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/package.json
+++ /dev/null
@@ -1,10 +0,0 @@
-{
-  "name": "simple-app",
-  "description": "A test fixture for pkginfo",
-  "version": "0.1.0",
-  "author": "Charlie Robbins <ch...@gmail.com>",
-  "keywords": ["test", "fixture"],
-  "main": "./index.js",
-  "scripts": { "test": "vows test/*-test.js --spec" },
-  "engines": { "node": ">= 0.4.0" }
-}

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/single-property.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/single-property.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/single-property.js
deleted file mode 100644
index 4f44561..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/single-property.js
+++ /dev/null
@@ -1,19 +0,0 @@
-/*
- * single-property.js: Sample of including a single specific properties from a package.json file
- *
- * (C) 2011, Charlie Robbins
- *
- */
- 
-var util = require('util'),
-    pkginfo = require('../lib/pkginfo')(module, 'version');
-
-exports.someFunction = function () {
-  console.log('some of your custom logic here');
-};
-
-console.log('Inspecting module:');
-console.dir(module.exports);
-
-console.log('\nAll exports exposed:');
-console.error(Object.keys(module.exports));
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/subdir/package.json
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/subdir/package.json b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/subdir/package.json
deleted file mode 100644
index aa85410..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/subdir/package.json
+++ /dev/null
@@ -1,11 +0,0 @@
-{
-  "name": "simple-app-subdir",
-  "description": "A test fixture for pkginfo",
-  "version": "0.1.0",
-  "author": "Charlie Robbins <ch...@gmail.com>",
-  "keywords": ["test", "fixture"],
-  "main": "./index.js",
-  "scripts": { "test": "vows test/*-test.js --spec" },
-  "engines": { "node": ">= 0.4.0" },
-  "subdironly": "true"
-}

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/target-dir.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/target-dir.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/target-dir.js
deleted file mode 100644
index 88770e6..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/examples/target-dir.js
+++ /dev/null
@@ -1,20 +0,0 @@
-/*
- * multiple-properties.js: Sample of including multiple properties from a package.json file
- *
- * (C) 2011, Charlie Robbins
- *
- */
- 
-var util = require('util'),
-    path = require('path'),
-    pkginfo = require('../lib/pkginfo')(module, { dir: path.resolve(__dirname, 'subdir' )});
-
-exports.someFunction = function () {
-  console.log('some of your custom logic here');
-};
-
-console.log('Inspecting module:');
-console.dir(module.exports);
-
-console.log('\nAll exports exposed:');
-console.error(Object.keys(module.exports));
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/lib/pkginfo.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/lib/pkginfo.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/lib/pkginfo.js
deleted file mode 100644
index c5dc020..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/lib/pkginfo.js
+++ /dev/null
@@ -1,136 +0,0 @@
-/*
- * pkginfo.js: Top-level include for the pkginfo module
- *
- * (C) 2011, Charlie Robbins
- *
- */
- 
-var fs = require('fs'),
-    path = require('path');
-
-//
-// ### function pkginfo ([options, 'property', 'property' ..])
-// #### @pmodule {Module} Parent module to read from.
-// #### @options {Object|Array|string} **Optional** Options used when exposing properties.
-// #### @arguments {string...} **Optional** Specified properties to expose.
-// Exposes properties from the package.json file for the parent module on 
-// it's exports. Valid usage:
-//
-// `require('pkginfo')()`
-//
-// `require('pkginfo')('version', 'author');`
-//
-// `require('pkginfo')(['version', 'author']);`
-//
-// `require('pkginfo')({ include: ['version', 'author'] });`
-//
-var pkginfo = module.exports = function (pmodule, options) {
-  var args = [].slice.call(arguments, 2).filter(function (arg) {
-    return typeof arg === 'string';
-  });
-  
-  //
-  // **Parse variable arguments**
-  //
-  if (Array.isArray(options)) {
-    //
-    // If the options passed in is an Array assume that
-    // it is the Array of properties to expose from the
-    // on the package.json file on the parent module.
-    //
-    options = { include: options };
-  }
-  else if (typeof options === 'string') {
-    //
-    // Otherwise if the first argument is a string, then
-    // assume that it is the first property to expose from
-    // the package.json file on the parent module.
-    //
-    options = { include: [options] };
-  }
-  
-  //
-  // **Setup default options**
-  //
-  options = options || {};
-  
-  // ensure that includes have been defined
-  options.include = options.include || [];
-  
-  if (args.length > 0) {
-    //
-    // If additional string arguments have been passed in
-    // then add them to the properties to expose on the 
-    // parent module. 
-    //
-    options.include = options.include.concat(args);
-  }
-  
-  var pkg = pkginfo.read(pmodule, options.dir).package;
-  Object.keys(pkg).forEach(function (key) {
-    if (options.include.length > 0 && !~options.include.indexOf(key)) {
-      return;
-    }
-    
-    if (!pmodule.exports[key]) {
-      pmodule.exports[key] = pkg[key];
-    }
-  });
-  
-  return pkginfo;
-};
-
-//
-// ### function find (dir)
-// #### @pmodule {Module} Parent module to read from.
-// #### @dir {string} **Optional** Directory to start search from.
-// Searches up the directory tree from `dir` until it finds a directory
-// which contains a `package.json` file. 
-//
-pkginfo.find = function (pmodule, dir) {
-  if (! dir) {
-    dir = path.dirname(pmodule.filename);
-  }
-  
-  var files = fs.readdirSync(dir);
-  
-  if (~files.indexOf('package.json')) {
-    return path.join(dir, 'package.json');
-  }
-  
-  if (dir === '/') {
-    throw new Error('Could not find package.json up from: ' + dir);
-  }
-  else if (!dir || dir === '.') {
-    throw new Error('Cannot find package.json from unspecified directory');
-  }
-  
-  return pkginfo.find(pmodule, path.dirname(dir));
-};
-
-//
-// ### function read (pmodule, dir)
-// #### @pmodule {Module} Parent module to read from.
-// #### @dir {string} **Optional** Directory to start search from.
-// Searches up the directory tree from `dir` until it finds a directory
-// which contains a `package.json` file and returns the package information.
-//
-pkginfo.read = function (pmodule, dir) { 
-  dir = pkginfo.find(pmodule, dir);
-  
-  var data = fs.readFileSync(dir).toString();
-      
-  return {
-    dir: dir, 
-    package: JSON.parse(data)
-  };
-};
-
-//
-// Call `pkginfo` on this module and expose version.
-//
-pkginfo(module, {
-  dir: __dirname,
-  include: ['version'],
-  target: pkginfo
-});
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/package.json
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/package.json b/blackberry10/node_modules/prompt/node_modules/pkginfo/package.json
deleted file mode 100644
index 173f799..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/package.json
+++ /dev/null
@@ -1,35 +0,0 @@
-{
-  "name": "pkginfo",
-  "version": "0.3.0",
-  "description": "An easy way to expose properties on a module from a package.json",
-  "author": {
-    "name": "Charlie Robbins",
-    "email": "charlie.robbins@gmail.com"
-  },
-  "repository": {
-    "type": "git",
-    "url": "http://github.com/indexzero/node-pkginfo.git"
-  },
-  "keywords": [
-    "info",
-    "tools",
-    "package.json"
-  ],
-  "devDependencies": {
-    "vows": "0.7.x"
-  },
-  "main": "./lib/pkginfo",
-  "scripts": {
-    "test": "vows test/*-test.js --spec"
-  },
-  "engines": {
-    "node": ">= 0.4.0"
-  },
-  "readme": "# node-pkginfo\n\nAn easy way to expose properties on a module from a package.json\n\n## Installation\n\n### Installing npm (node package manager)\n```\n  curl http://npmjs.org/install.sh | sh\n```\n\n### Installing pkginfo\n```\n  [sudo] npm install pkginfo\n```\n\n## Motivation\nHow often when writing node.js modules have you written the following line(s) of code? \n\n* Hard code your version string into your code\n\n``` js\n  exports.version = '0.1.0';\n```\n\n* Programmatically expose the version from the package.json\n\n``` js\n  exports.version = JSON.parse(fs.readFileSync('/path/to/package.json', 'utf8')).version;\n```\n\nIn other words, how often have you wanted to expose basic information from your package.json onto your module programmatically? **WELL NOW YOU CAN!**\n\n## Usage\n\nUsing `pkginfo` is idiot-proof, just require and invoke it. \n\n``` js\n  var pkginfo = require('pkginfo')(module);\n  \n  console.dir(module.exports);\n```\n\nBy invoking the `pkgin
 fo` module all of the properties in your `package.json` file will be automatically exposed on the callee module (i.e. the parent module of `pkginfo`). \n\nHere's a sample of the output:\n\n```\n  { name: 'simple-app',\n    description: 'A test fixture for pkginfo',\n    version: '0.1.0',\n    author: 'Charlie Robbins <ch...@gmail.com>',\n    keywords: [ 'test', 'fixture' ],\n    main: './index.js',\n    scripts: { test: 'vows test/*-test.js --spec' },\n    engines: { node: '>= 0.4.0' } }\n```\n\n### Expose specific properties\nIf you don't want to expose **all** properties on from your `package.json` on your module then simple pass those properties to the `pkginfo` function:\n\n``` js\n  var pkginfo = require('pkginfo')(module, 'version', 'author');\n  \n  console.dir(module.exports);\n```\n\n```\n  { version: '0.1.0',\n    author: 'Charlie Robbins <ch...@gmail.com>' }\n```\n\nIf you're looking for further usage see the [examples][0] included in this repository. 
 \n\n## Run Tests\nTests are written in [vows][1] and give complete coverage of all APIs.\n\n```\n  vows test/*-test.js --spec\n```\n\n[0]: https://github.com/indexzero/node-pkginfo/tree/master/examples\n[1]: http://vowsjs.org\n\n#### Author: [Charlie Robbins](http://nodejitsu.com)\n#### License: MIT",
-  "readmeFilename": "README.md",
-  "bugs": {
-    "url": "https://github.com/indexzero/node-pkginfo/issues"
-  },
-  "_id": "pkginfo@0.3.0",
-  "_from": "pkginfo@0.x.x"
-}

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/pkginfo/test/pkginfo-test.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/pkginfo/test/pkginfo-test.js b/blackberry10/node_modules/prompt/node_modules/pkginfo/test/pkginfo-test.js
deleted file mode 100644
index a59f077..0000000
--- a/blackberry10/node_modules/prompt/node_modules/pkginfo/test/pkginfo-test.js
+++ /dev/null
@@ -1,83 +0,0 @@
-/*
- * pkginfo-test.js: Tests for the pkginfo module.
- *
- * (C) 2011, Charlie Robbins
- *
- */
-
-var assert = require('assert'),
-    exec = require('child_process').exec,
-    fs = require('fs'),
-    path = require('path'),
-    vows = require('vows'),
-    pkginfo = require('../lib/pkginfo');
-
-function assertProperties (source, target) {
-  assert.lengthOf(source, target.length + 1);
-  target.forEach(function (prop) {
-    assert.isTrue(!!~source.indexOf(prop));
-  });
-}
-
-function compareWithExample(targetPath) {
-  var examplePaths = ['package.json'];
-  
-  if (targetPath) {
-    examplePaths.unshift(targetPath);
-  }
-  
-  return function(exposed) {
-    var pkg = fs.readFileSync(path.join.apply(null, [__dirname, '..', 'examples'].concat(examplePaths))).toString(),
-        keys = Object.keys(JSON.parse(pkg));
-    
-    assertProperties(exposed, keys);
-  };
-}
-
-function testExposes (options) {
-  return {
-    topic: function () {
-      exec('node ' + path.join(__dirname, '..', 'examples', options.script), this.callback);
-    },
-    "should expose that property correctly": function (err, stdout, stderr) {
-      assert.isNull(err);
-      
-      var exposed = stderr.match(/'(\w+)'/ig).map(function (p) { 
-        return p.substring(1, p.length - 1);
-      });
-      
-      return !options.assert 
-        ? assertProperties(exposed, options.properties)
-        : options.assert(exposed);
-    }
-  }
-}
-
-vows.describe('pkginfo').addBatch({
-  "When using the pkginfo module": {
-    "and passed a single `string` argument": testExposes({
-      script: 'single-property.js',
-      properties: ['version']
-    }),
-    "and passed multiple `string` arguments": testExposes({
-      script: 'multiple-properties.js',
-      properties: ['version', 'author']
-    }),
-    "and passed an `object` argument": testExposes({
-      script: 'object-argument.js',
-      properties: ['version', 'author']
-    }),
-    "and passed an `array` argument": testExposes({
-      script: 'array-argument.js',
-      properties: ['version', 'author']
-    }),
-    "and read from a specified directory": testExposes({
-      script: 'target-dir.js',
-      assert: compareWithExample('subdir')
-    }),
-    "and passed no arguments": testExposes({
-      script: 'all-properties.js',
-      assert: compareWithExample()
-    })
-  }
-}).export(module);

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/.npmignore
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/.npmignore b/blackberry10/node_modules/prompt/node_modules/read/.npmignore
deleted file mode 100644
index 0db216b..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/.npmignore
+++ /dev/null
@@ -1,2 +0,0 @@
-npm-debug.log
-node_modules

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/LICENCE
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/LICENCE b/blackberry10/node_modules/prompt/node_modules/read/LICENCE
deleted file mode 100644
index 74489e2..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/LICENCE
+++ /dev/null
@@ -1,25 +0,0 @@
-Copyright (c) Isaac Z. Schlueter
-All rights reserved.
-
-The BSD License
-
-Redistribution and use in source and binary forms, with or without
-modification, are permitted provided that the following conditions
-are met:
-1. Redistributions of source code must retain the above copyright
-   notice, this list of conditions and the following disclaimer.
-2. Redistributions in binary form must reproduce the above copyright
-   notice, this list of conditions and the following disclaimer in the
-   documentation and/or other materials provided with the distribution.
-
-THIS SOFTWARE IS PROVIDED BY THE NETBSD FOUNDATION, INC. AND CONTRIBUTORS
-``AS IS'' AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED
-TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
-PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL THE FOUNDATION OR CONTRIBUTORS
-BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
-CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF
-SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS
-INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN
-CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE)
-ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE
-POSSIBILITY OF SUCH DAMAGE.

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/README.md
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/README.md b/blackberry10/node_modules/prompt/node_modules/read/README.md
deleted file mode 100644
index 5967fad..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/README.md
+++ /dev/null
@@ -1,53 +0,0 @@
-## read
-
-For reading user input from stdin.
-
-Similar to the `readline` builtin's `question()` method, but with a
-few more features.
-
-## USAGE
-
-```javascript
-var read = require("read")
-read(options, callback)
-```
-
-The callback gets called with either the user input, or the default
-specified, or an error, as `callback(error, result, isDefault)`
-node style.
-
-## OPTIONS
-
-Every option is optional.
-
-* `prompt` What to write to stdout before reading input.
-* `silent` Don't echo the output as the user types it.
-* `replace` Replace silenced characters with the supplied character value.
-* `timeout` Number of ms to wait for user input before giving up.
-* `default` The default value if the user enters nothing.
-* `edit` Allow the user to edit the default value.
-* `terminal` Treat the output as a TTY, whether it is or not.
-* `input` Readable stream to get input data from. (default `process.stdin`)
-* `output` Writeable stream to write prompts to. (default: `process.stdout`)
-
-If silent is true, and the input is a TTY, then read will set raw
-mode, and read character by character.
-
-## COMPATIBILITY
-
-This module works sort of with node 0.6.  It does not work with node
-versions less than 0.6.  It is best on node 0.8.
-
-On node version 0.6, it will remove all listeners on the input
-stream's `data` and `keypress` events, because the readline module did
-not fully clean up after itself in that version of node, and did not
-make it possible to clean up after it in a way that has no potential
-for side effects.
-
-Additionally, some of the readline options (like `terminal`) will not
-function in versions of node before 0.8, because they were not
-implemented in the builtin readline module.
-
-## CONTRIBUTING
-
-Patches welcome.

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/lib/read.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/lib/read.js b/blackberry10/node_modules/prompt/node_modules/read/lib/read.js
deleted file mode 100644
index a93d1b3..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/lib/read.js
+++ /dev/null
@@ -1,113 +0,0 @@
-
-module.exports = read
-
-var readline = require('readline')
-var Mute = require('mute-stream')
-
-function read (opts, cb) {
-  if (opts.num) {
-    throw new Error('read() no longer accepts a char number limit')
-  }
-
-  if (typeof opts.default !== 'undefined' &&
-      typeof opts.default !== 'string' &&
-      typeof opts.default !== 'number') {
-    throw new Error('default value must be string or number')
-  }
-
-  var input = opts.input || process.stdin
-  var output = opts.output || process.stdout
-  var prompt = (opts.prompt || '').trim() + ' '
-  var silent = opts.silent
-  var editDef = false
-  var timeout = opts.timeout
-
-  var def = opts.default || ''
-  if (def) {
-    if (silent) {
-      prompt += '(<default hidden>) '
-    } else if (opts.edit) {
-      editDef = true
-    } else {
-      prompt += '(' + def + ') '
-    }
-  }
-  var terminal = !!(opts.terminal || output.isTTY)
-
-  var m = new Mute({ replace: opts.replace, prompt: prompt })
-  m.pipe(output, {end: false})
-  output = m
-  var rlOpts = { input: input, output: output, terminal: terminal }
-
-  if (process.version.match(/^v0\.6/)) {
-    var rl = readline.createInterface(rlOpts.input, rlOpts.output)
-  } else {
-    var rl = readline.createInterface(rlOpts)
-  }
-
-
-  output.unmute()
-  rl.setPrompt(prompt)
-  rl.prompt()
-  if (silent) {
-    output.mute()
-  } else if (editDef) {
-    rl.line = def
-    rl.cursor = def.length
-    rl._refreshLine()
-  }
-
-  var called = false
-  rl.on('line', onLine)
-  rl.on('error', onError)
-
-  rl.on('SIGINT', function () {
-    rl.close()
-    onError(new Error('canceled'))
-  })
-
-  var timer
-  if (timeout) {
-    timer = setTimeout(function () {
-      onError(new Error('timed out'))
-    }, timeout)
-  }
-
-  function done () {
-    called = true
-    rl.close()
-
-    if (process.version.match(/^v0\.6/)) {
-      rl.input.removeAllListeners('data')
-      rl.input.removeAllListeners('keypress')
-      rl.input.pause()
-    }
-
-    clearTimeout(timer)
-    output.mute()
-    output.end()
-  }
-
-  function onError (er) {
-    if (called) return
-    done()
-    return cb(er)
-  }
-
-  function onLine (line) {
-    if (called) return
-    if (silent && terminal) {
-      output.unmute()
-      output.write('\r\n')
-    }
-    done()
-    // truncate the \n at the end.
-    line = line.replace(/\r?\n$/, '')
-    var isDefault = !!(editDef && line === def)
-    if (def && !line) {
-      isDefault = true
-      line = def
-    }
-    cb(null, line, isDefault)
-  }
-}

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/LICENSE
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/LICENSE b/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/LICENSE
deleted file mode 100644
index 0c44ae7..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/LICENSE
+++ /dev/null
@@ -1,27 +0,0 @@
-Copyright (c) Isaac Z. Schlueter ("Author")
-All rights reserved.
-
-The BSD License
-
-Redistribution and use in source and binary forms, with or without
-modification, are permitted provided that the following conditions
-are met:
-
-1. Redistributions of source code must retain the above copyright
-   notice, this list of conditions and the following disclaimer.
-
-2. Redistributions in binary form must reproduce the above copyright
-   notice, this list of conditions and the following disclaimer in the
-   documentation and/or other materials provided with the distribution.
-
-THIS SOFTWARE IS PROVIDED BY THE AUTHOR AND CONTRIBUTORS ``AS IS'' AND
-ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE
-IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR
-PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL THE AUTHOR OR CONTRIBUTORS
-BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR
-CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF
-SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR
-BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY,
-WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE
-OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN
-IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/README.md
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/README.md b/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/README.md
deleted file mode 100644
index 8ab1238..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/README.md
+++ /dev/null
@@ -1,68 +0,0 @@
-# mute-stream
-
-Bytes go in, but they don't come out (when muted).
-
-This is a basic pass-through stream, but when muted, the bytes are
-silently dropped, rather than being passed through.
-
-## Usage
-
-```javascript
-var MuteStream = require('mute-stream')
-
-var ms = new MuteStream(options)
-
-ms.pipe(process.stdout)
-ms.write('foo') // writes 'foo' to stdout
-ms.mute()
-ms.write('bar') // does not write 'bar'
-ms.unmute()
-ms.write('baz') // writes 'baz' to stdout
-
-// can also be used to mute incoming data
-var ms = new MuteStream
-input.pipe(ms)
-
-ms.on('data', function (c) {
-  console.log('data: ' + c)
-})
-
-input.emit('data', 'foo') // logs 'foo'
-ms.mute()
-input.emit('data', 'bar') // does not log 'bar'
-ms.unmute()
-input.emit('data', 'baz') // logs 'baz'
-```
-
-## Options
-
-All options are optional.
-
-* `replace` Set to a string to replace each character with the
-  specified string when muted.  (So you can show `****` instead of the
-  password, for example.)
-
-* `prompt` If you are using a replacement char, and also using a
-  prompt with a readline stream (as for a `Password: *****` input),
-  then specify what the prompt is so that backspace will work
-  properly.  Otherwise, pressing backspace will overwrite the prompt
-  with the replacement character, which is weird.
-
-## ms.mute()
-
-Set `muted` to `true`.  Turns `.write()` into a no-op.
-
-## ms.unmute()
-
-Set `muted` to `false`
-
-## ms.isTTY
-
-True if the pipe destination is a TTY, or if the incoming pipe source is
-a TTY.
-
-## Other stream methods...
-
-The other standard readable and writable stream methods are all
-available.  The MuteStream object acts as a facade to its pipe source
-and destination.

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/mute.js
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/mute.js b/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/mute.js
deleted file mode 100644
index 42eac31..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/mute.js
+++ /dev/null
@@ -1,140 +0,0 @@
-var Stream = require('stream')
-
-module.exports = MuteStream
-
-// var out = new MuteStream(process.stdout)
-// argument auto-pipes
-function MuteStream (opts) {
-  Stream.apply(this)
-  opts = opts || {}
-  this.writable = this.readable = true
-  this.muted = false
-  this.on('pipe', this._onpipe)
-  this.replace = opts.replace
-
-  // For readline-type situations
-  // This much at the start of a line being redrawn after a ctrl char
-  // is seen (such as backspace) won't be redrawn as the replacement
-  this._prompt = opts.prompt || null
-  this._hadControl = false
-}
-
-MuteStream.prototype = Object.create(Stream.prototype)
-
-Object.defineProperty(MuteStream.prototype, 'constructor', {
-  value: MuteStream,
-  enumerable: false
-})
-
-MuteStream.prototype.mute = function () {
-  this.muted = true
-}
-
-MuteStream.prototype.unmute = function () {
-  this.muted = false
-}
-
-Object.defineProperty(MuteStream.prototype, '_onpipe', {
-  value: onPipe,
-  enumerable: false,
-  writable: true,
-  configurable: true
-})
-
-function onPipe (src) {
-  this._src = src
-}
-
-Object.defineProperty(MuteStream.prototype, 'isTTY', {
-  get: getIsTTY,
-  set: setIsTTY,
-  enumerable: true,
-  configurable: true
-})
-
-function getIsTTY () {
-  return( (this._dest) ? this._dest.isTTY
-        : (this._src) ? this._src.isTTY
-        : false
-        )
-}
-
-// basically just get replace the getter/setter with a regular value
-function setIsTTY (isTTY) {
-  Object.defineProperty(this, 'isTTY', {
-    value: isTTY,
-    enumerable: true,
-    writable: true,
-    configurable: true
-  })
-}
-
-Object.defineProperty(MuteStream.prototype, 'rows', {
-  get: function () {
-    return( this._dest ? this._dest.rows
-          : this._src ? this._src.rows
-          : undefined )
-  }, enumerable: true, configurable: true })
-
-Object.defineProperty(MuteStream.prototype, 'columns', {
-  get: function () {
-    return( this._dest ? this._dest.columns
-          : this._src ? this._src.columns
-          : undefined )
-  }, enumerable: true, configurable: true })
-
-
-MuteStream.prototype.pipe = function (dest) {
-  this._dest = dest
-  return Stream.prototype.pipe.call(this, dest)
-}
-
-MuteStream.prototype.pause = function () {
-  if (this._src) return this._src.pause()
-}
-
-MuteStream.prototype.resume = function () {
-  if (this._src) return this._src.resume()
-}
-
-MuteStream.prototype.write = function (c) {
-  if (this.muted) {
-    if (!this.replace) return true
-    if (c.match(/^\u001b/)) {
-      this._hadControl = true
-      return this.emit('data', c)
-    } else {
-      if (this._prompt && this._hadControl &&
-          c.indexOf(this._prompt) === 0) {
-        this._hadControl = false
-        this.emit('data', this._prompt)
-        c = c.substr(this._prompt.length)
-      }
-      c = c.toString().replace(/./g, this.replace)
-    }
-  }
-  this.emit('data', c)
-}
-
-MuteStream.prototype.end = function (c) {
-  if (this.muted) {
-    if (c && this.replace) {
-      c = c.toString().replace(/./g, this.replace)
-    } else {
-      c = null
-    }
-  }
-  if (c) this.emit('data', c)
-  this.emit('end')
-}
-
-function proxy (fn) { return function () {
-  var d = this._dest
-  var s = this._src
-  if (d && d[fn]) d[fn].apply(d, arguments)
-  if (s && s[fn]) s[fn].apply(s, arguments)
-}}
-
-MuteStream.prototype.destroy = proxy('destroy')
-MuteStream.prototype.destroySoon = proxy('destroySoon')
-MuteStream.prototype.close = proxy('close')

http://git-wip-us.apache.org/repos/asf/cordova-blackberry/blob/a6733a83/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/package.json
----------------------------------------------------------------------
diff --git a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/package.json b/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/package.json
deleted file mode 100644
index 5e69980..0000000
--- a/blackberry10/node_modules/prompt/node_modules/read/node_modules/mute-stream/package.json
+++ /dev/null
@@ -1,37 +0,0 @@
-{
-  "name": "mute-stream",
-  "version": "0.0.4",
-  "main": "mute.js",
-  "directories": {
-    "test": "test"
-  },
-  "devDependencies": {
-    "tap": "~0.2.5"
-  },
-  "scripts": {
-    "test": "tap test/*.js"
-  },
-  "repository": {
-    "type": "git",
-    "url": "git://github.com/isaacs/mute-stream"
-  },
-  "keywords": [
-    "mute",
-    "stream",
-    "pipe"
-  ],
-  "author": {
-    "name": "Isaac Z. Schlueter",
-    "email": "i@izs.me",
-    "url": "http://blog.izs.me/"
-  },
-  "license": "BSD",
-  "description": "Bytes go in, but they don't come out (when muted).",
-  "readme": "# mute-stream\n\nBytes go in, but they don't come out (when muted).\n\nThis is a basic pass-through stream, but when muted, the bytes are\nsilently dropped, rather than being passed through.\n\n## Usage\n\n```javascript\nvar MuteStream = require('mute-stream')\n\nvar ms = new MuteStream(options)\n\nms.pipe(process.stdout)\nms.write('foo') // writes 'foo' to stdout\nms.mute()\nms.write('bar') // does not write 'bar'\nms.unmute()\nms.write('baz') // writes 'baz' to stdout\n\n// can also be used to mute incoming data\nvar ms = new MuteStream\ninput.pipe(ms)\n\nms.on('data', function (c) {\n  console.log('data: ' + c)\n})\n\ninput.emit('data', 'foo') // logs 'foo'\nms.mute()\ninput.emit('data', 'bar') // does not log 'bar'\nms.unmute()\ninput.emit('data', 'baz') // logs 'baz'\n```\n\n## Options\n\nAll options are optional.\n\n* `replace` Set to a string to replace each character with the\n  specified string when muted.  (So you can show `****` instead of the\n  password, fo
 r example.)\n\n* `prompt` If you are using a replacement char, and also using a\n  prompt with a readline stream (as for a `Password: *****` input),\n  then specify what the prompt is so that backspace will work\n  properly.  Otherwise, pressing backspace will overwrite the prompt\n  with the replacement character, which is weird.\n\n## ms.mute()\n\nSet `muted` to `true`.  Turns `.write()` into a no-op.\n\n## ms.unmute()\n\nSet `muted` to `false`\n\n## ms.isTTY\n\nTrue if the pipe destination is a TTY, or if the incoming pipe source is\na TTY.\n\n## Other stream methods...\n\nThe other standard readable and writable stream methods are all\navailable.  The MuteStream object acts as a facade to its pipe source\nand destination.\n",
-  "readmeFilename": "README.md",
-  "bugs": {
-    "url": "https://github.com/isaacs/mute-stream/issues"
-  },
-  "_id": "mute-stream@0.0.4",
-  "_from": "mute-stream@~0.0.4"
-}