You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cordova.apache.org by fi...@apache.org on 2013/06/12 19:15:41 UTC

[25/56] [abbrv] [partial] start of lazy loading: axe all vendored-in libs

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager-validator.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager-validator.js b/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager-validator.js
deleted file mode 100644
index d85c0db..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager-validator.js
+++ /dev/null
@@ -1,107 +0,0 @@
-/*
- *  Copyright 2012 Research In Motion Limited.
- *
- * Licensed 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 check = require('validator').check,
-    sanitize = require('validator').sanitize,
-    localize = require("./localize"),
-    logger = require("./logger"),
-    signingHelper = require("./signing-helper"),
-    path = require("path"),
-    fs = require("fs"),
-    packagerUtils = require("./packager-utils"),
-    CORDOVA_JS_REGEX = /(cordova-.+js)|cordova\.js/,
-    _self;
-
-//NOTE this class is unfinished and is a work in progress
-
-_self = {
-    //TODO create one global validate method that will validate
-    //both the session and configObj?
-    validateSession: function (session, widgetConfig) {
-        //The string checks below is to get around a really weird issue in commander
-        //where sometimes unspecified arguments come in as a function...
-        var keysFound = session.keystore,
-            cskFound = session.keystoreCsk,//barsigner.csk
-            dbFound = session.keystoreDb,//barsigner.db
-            keysPassword = session.storepass && typeof session.storepass === "string",
-            commandLinebuildId = session.buildId && typeof session.buildId === "string",//--buildId
-            buildId = widgetConfig.buildId && typeof widgetConfig.buildId === "string",//Finalized Build ID
-
-            //Constants
-            AUTHOR_P12 = "author.p12",
-            BARSIGNER_CSK = "barsigner.csk",
-            BARSIGNER_DB = "barsigner.db",
-
-            //Logging function
-            signingFileWarn = function (file) {
-                logger.warn(localize.translate("WARNING_MISSING_SIGNING_KEY_FILE", file));
-            },
-            signingFileError = function (file) {
-                throw localize.translate("EXCEPTION_MISSING_SIGNING_KEY_FILE", file);
-            };
-
-        //If -g <password> or --buildId is set, but signing key files are missing, throw an error
-        if (keysPassword || commandLinebuildId) {
-            if (!keysFound) {
-                signingFileError(AUTHOR_P12);
-            } else if (!cskFound) {
-                signingFileError(BARSIGNER_CSK);
-            } else if (!dbFound) {
-                signingFileError(BARSIGNER_DB);
-            }
-
-        //If a buildId exists in config, but no keys were found, throw a warning
-        } else if (buildId) {
-            if (!keysFound) {
-                signingFileWarn(AUTHOR_P12);
-            } else if (!cskFound) {
-                signingFileWarn(BARSIGNER_CSK);
-            } else if (!dbFound) {
-                signingFileWarn(BARSIGNER_DB);
-            }
-        }
-
-        //if -g was provided with NO build id, throw error
-        if (keysPassword && !buildId) {
-            throw localize.translate("EXCEPTION_MISSING_SIGNING_BUILDID");
-        }
-
-        if (commandLinebuildId && !keysPassword) {
-            //if --buildId was provided with NO password, throw error
-            throw localize.translate("EXCEPTION_MISSING_SIGNING_PASSWORD");
-        }
-
-        //if --appdesc was provided, but the file is not existing, throw an error
-        if (session.appdesc && !fs.existsSync(session.appdesc)) {
-            throw localize.translate("EXCEPTION_APPDESC_NOT_FOUND", session.appdesc);
-        }
-    },
-
-    //Validation for configObj, iterates through whitelisted features in configObj to remove any non-existing APIs
-    validateConfig: function (session, configObj) {
-        //if packageCordovaJs was set, test for existing cordova.js files
-        if (configObj.packageCordovaJs) {
-            cordovaJsFiles = packagerUtils.listFiles(session.sourceDir, function (file) {
-                return CORDOVA_JS_REGEX.test(file);
-            });
-            if (cordovaJsFiles.length > 0) {
-                logger.warn(localize.translate("WARN_CORDOVA_JS_PACKAGED"));
-            }
-        }
-
-    }
-};
-
-module.exports = _self;

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager.js b/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager.js
deleted file mode 100644
index 01541ac..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/packager.js
+++ /dev/null
@@ -1,73 +0,0 @@
-/*
- *  Copyright 2012 Research In Motion Limited.
- *
- * Licensed 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.
- */
-
-require('./../third_party/wrench/wrench');
-
-var path = require("path"),
-    wrench = require("wrench"),
-    cmdline = require("./cmdline"),
-    logger = require("./logger"),
-    fileManager = require("./file-manager"),
-    localize = require("./localize"),
-    configParser = require("./config-parser"),
-    packagerUtils = require("./packager-utils"),
-    packagerValidator = require("./packager-validator"),
-    barBuilder = require("./bar-builder"),
-    session;
-
-module.exports = {
-    start: function(callback) {
-        try {
-            cmdline.parse(process.argv);
-            session = require("./session").initialize(cmdline.commander);
-
-            //prepare files for webworks archiving
-            logger.log(localize.translate("PROGRESS_FILE_POPULATING_SOURCE"));
-            fileManager.prepareOutputFiles(session);
-
-            //parse config.xml
-            logger.log(localize.translate("PROGRESS_SESSION_CONFIGXML"));
-            configParser.parse(path.join(session.sourceDir, "config.xml"), session, function (configObj) {
-                //validate session Object
-                packagerValidator.validateSession(session, configObj);
-                //validage configuration object
-                packagerValidator.validateConfig(session, configObj);
-
-                //generate user.js
-                logger.log(localize.translate("PROGRESS_GEN_OUTPUT"));
-                //Adding debuEnabled property to user.js. Framework will enable/disable WebInspector based on that variable.
-                configObj.debugEnabled = session.debug;
-
-                barBuilder.build(session, configObj, function (code) {
-                    fileManager.cleanSource(session);
-
-                    if (code === 0) {
-                        logger.log(localize.translate("PROGRESS_COMPLETE"));
-
-                        //call packager callback
-                        callback();
-                    }
-                });
-            });
-        } catch (e) {
-            try {
-                fileManager.cleanSource(session);
-            } catch (ex) {}
-
-            logger.error(e);
-        }
-    }
-};

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/plugin.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/plugin.js b/lib/cordova-blackberry/bin/templates/project/cordova/lib/plugin.js
deleted file mode 100644
index 7e1412c..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/plugin.js
+++ /dev/null
@@ -1,200 +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"),
-    shell = require('shelljs'),
-    wrench = require("wrench"),
-    fs = require('fs'),
-    et   = require('elementtree'),
-    escapeStringForShell = require("./packager-utils").escapeStringForShell,
-    PROJECT_ROOT = path.join(__dirname, "..", ".."),
-    PLUGMAN = escapeStringForShell(path.join(PROJECT_ROOT, "cordova", "node_modules", "plugman", "main.js")),
-    GLOBAL_PLUGIN_PATH = require(path.join(PROJECT_ROOT, "project.json")).globalFetchDir,
-    LOCAL_PLUGIN_PATH = path.join(PROJECT_ROOT, "plugins"),
-    argumentor = {
-        action : process.argv[2],
-        plugin: process.argv[3],
-        args: [],
-        reset: function () {
-            this.args = [];
-            return argumentor;
-        },
-        setAction: function () {
-            this.args.push("--" + this.action);
-            return argumentor;
-        },
-        setPlatform: function () {
-            this.args.push("--platform");
-            this.args.push("blackberry10");
-            return argumentor;
-        },
-        setProject: function () {
-            this.args.push("--project");
-            this.args.push(escapeStringForShell(PROJECT_ROOT));
-            return argumentor;
-        },
-        setPlugin: function () {
-            var pluginWithoutTrailingSlash = this.plugin.charAt(this.plugin.length - 1) === "/" ? this.plugin.slice(0, -1) : this.plugin;
-            this.args.push("--plugin");
-            this.args.push(escapeStringForShell(pluginWithoutTrailingSlash));
-            return argumentor;
-        },
-        setPluginsDir: function (isGlobal) {
-            this.args.push("--plugins_dir");
-            if (isGlobal) {
-                this.args.push(escapeStringForShell(GLOBAL_PLUGIN_PATH));
-            } else {
-                this.args.push(escapeStringForShell(LOCAL_PLUGIN_PATH));
-            }
-            return argumentor;
-        },
-        run: function () {
-            var cmd = "";
-            if (require('os').type().toLowerCase().indexOf("windows") >= 0) {
-                cmd += "@node.exe ";
-            }
-            cmd += PLUGMAN + " " + this.args.join(" ");
-            return shell.exec(cmd, {silent: false});
-        }
-    },
-    plugmanInterface= {
-        "uninstall": function (plugin) {
-                if (plugin) {
-                    argumentor.plugin = plugin;
-                }
-                argumentor.action = "uninstall";
-                argumentor.reset().setAction().setPlatform().setProject().setPlugin().setPluginsDir().run();
-            },
-        "install": function (plugin) {
-                if (plugin) {
-                    argumentor.plugin = plugin;
-                }
-                argumentor.reset().setPlatform().setProject().setPlugin().setPluginsDir().run();
-            }
-    };
-
-function getPluginId(pluginXMLPath) {
-    var pluginEt = new et.ElementTree(et.XML(fs.readFileSync(pluginXMLPath, "utf-8")));
-    return pluginEt._root.attrib.id;
-}
-
-function addPlugin (pluginPath) {
-    var plugin = pluginPath || argumentor.plugin,
-        pluginDirs = [],
-        allFiles;
-
-    //Check if the path they sent in exists
-    if (!fs.existsSync(plugin) ) {
-        //Check if the plugin has been fetched globally
-        plugin = path.resolve(GLOBAL_PLUGIN_PATH, plugin);
-        if (!fs.existsSync(plugin)) {
-            console.log("Input ", pluginPath || argumentor.plugin, " cannot be resolved as a plugin");
-            listHelp();
-            process.exit(1);
-        }
-    }
-
-    allFiles = wrench.readdirSyncRecursive(plugin);
-    allFiles.forEach(function (file) {
-        var fullPath = path.resolve(plugin, file);
-
-        if (path.basename(file) === "plugin.xml") {
-            pluginDirs.push(path.dirname(fullPath));
-        }
-    });
-
-    if (!pluginDirs.length) {
-        console.log("No plugins could be found given the input " + pluginPath || argumentor.plugin);
-        listHelp();
-        process.exit(1);
-    } else {
-        pluginDirs.forEach(function (pluginDir) {
-            plugmanInterface.install(pluginDir);
-        });
-    }
-}
-
-function removePlugin (pluginPath) {
-    var plugin = pluginPath || argumentor.plugin,
-        pluginIds = [],
-        allFiles;
-
-    //Check if the path they send in exists
-    if (!fs.existsSync(plugin) ) {
-        //Check if it is the folder name of an installed plugin
-        plugin = path.resolve(LOCAL_PLUGIN_PATH, plugin);
-        if (!fs.existsSync(plugin)) {
-            //Assume that this is a plugin id and continue
-            plugin = pluginPath || argumentor.plugin;
-        }
-    }
-
-    allFiles = wrench.readdirSyncRecursive(plugin);
-    allFiles.forEach(function (file) {
-        var fullPath = path.resolve(plugin, file),
-            pluginEt;
-
-        if (path.basename(file) === "plugin.xml") {
-            pluginIds.push(getPluginId(fullPath));
-        }
-    });
-
-    pluginIds.forEach(function (pluginId) {
-        plugmanInterface.uninstall(pluginId);
-    });
-
-}
-
-function listPlugins () {
-    fs.readdirSync(LOCAL_PLUGIN_PATH).forEach(function (pluginName) {
-        //TODO: Parse the plugin.xml and get any extra information ie description
-        console.log(pluginName);
-    });
-}
-
-function listHelp () {
-    console.log("\nUsage:");
-    console.log("add <plugin_dir> Adds all plugins contained in the given directory");
-    console.log("rm <plugin_name> [<plugin_name>] Removes all of the listed plugins");
-    console.log("ls Lists all of the currently installed plugins");
-}
-
-function cliEntry () {
-    switch (argumentor.action) {
-        case "add":
-            addPlugin();
-            break;
-        case "rm":
-            removePlugin();
-            break;
-        case "ls":
-            listPlugins();
-            break;
-        default:
-            listHelp();
-    }
-}
-
-module.exports = {
-    add: addPlugin,
-    rm: removePlugin,
-    ls: listPlugins,
-    help: listHelp,
-    cli: cliEntry
-};

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/run
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/run b/lib/cordova-blackberry/bin/templates/project/cordova/lib/run
deleted file mode 100755
index d4430f9..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/run
+++ /dev/null
@@ -1,295 +0,0 @@
-#!/usr/bin/env node
-
-/*
- *  Copyright 2012 Research In Motion Limited.
- *
- * Licensed 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 childProcess = require("child_process"),
-    fs = require("fs"),
-    path = require("path"),
-    util = require("util"),
-    wrench = require("wrench"),
-    conf = require("./conf"),
-    localize = require("./localize"),
-    pkgrUtils = require("./packager-utils"),
-    debugTokenHelper = require("./debugtoken-helper"),
-    properties = require('../../project.json'),
-    program = require('commander'),
-    xml2js = require('xml2js'),
-    jWorkflow = require("jWorkflow"),
-    logger = require("./logger"),
-    pin,
-    needCreateDebugToken = false,
-    needDeployDebugToken = false,
-    commandStr,
-    target,
-    ip,
-    password,
-    workingdir = path.normalize(__dirname + "/..");
-
-function generateOptions(uninstall) {
-    var options = [];
-        barPath = pkgrUtils.escapeStringForShell(path.normalize(__dirname + "/../../build/" + properties.targets[target].type + "/" + properties.barName + ".bar"));
-
-    options.push("-device");
-    options.push(ip);
-
-    if (password) {
-        options.push("-password");
-        options.push(password);
-    }
-
-    options.push("-package");
-    options.push(barPath);
-
-    if (uninstall) {
-        options.push("-uninstallApp");
-        return options;
-    } else {
-
-        options.push("-installApp");
-
-        if (program.launch) {
-            options.push("-launchApp");
-        }
-
-        return options;
-    }
-}
-
-function execNativeDeploy(optionsArray, callback) {
-    var script = "/bin/blackberry-deploy",
-        nativeDeploy;
-        options = optionsArray.join(" ");
-
-    if (pkgrUtils.isWindows()) {
-        script += ".bat";
-    }
-
-    if (fs.existsSync(conf.DEPENDENCIES_TOOLS)) {
-        nativeDeploy = childProcess.exec(path.normalize(conf.DEPENDENCIES_TOOLS + script +" "+ options), {
-            "cwd": workingdir,
-            "env": process.env
-        });
-
-        nativeDeploy.stdout.on("data", pkgrUtils.handleProcessOutput);
-
-        nativeDeploy.stderr.on("data", pkgrUtils.handleProcessOutput);
-
-        nativeDeploy.on("exit", function (code) {
-            if (callback && typeof callback === "function") {
-                callback(code);
-            }
-        });
-    } else {
-        throw localize.translate("EXCEPTION_MISSING_TOOLS");
-    }
-}
-
-function checkTarget() {
-    if (!target) {
-        console.log("No target exists, to add that target please run target add <name> <ip> [-t | --type <device | simulator>] [-p <password>] [--pin <devicepin>]");
-        console.log(program.helpInformation());
-        return false;
-    }
-    if (!properties.targets[target]) {
-        console.log("The target \""+target+"\" does not exist, to add that target please run target add "+target+" <ip> [-t | --type <device | simulator>] [-p <password>] [--pin <devicepin>]");
-        console.log(program.helpInformation());
-        return false;
-    }
-    if (properties.targets[target].ip) {
-       ip = properties.targets[target].ip;
-    } else {
-        console.log("IP is not defined in target \""+target+"\"");
-        console.log(program.helpInformation());
-        return false;
-    }
-    if (properties.targets[target].password) {
-       password = properties.targets[target].password;
-    }
-    return true;
-}
-
-function uninstall() {
-    var script = "/bin/blackberry-deploy",
-        nativeDeploy;
-
-    if (pkgrUtils.isWindows()) {
-        script += ".bat";
-    }
-
-    if (fs.existsSync(conf.DEPENDENCIES_TOOLS)) {
-        nativeDeploy = childProcess.exec(path.normalize(conf.DEPENDENCIES_TOOLS + script +" -listInstalledApps -device " +ip+ " -password " +password), {
-            "cwd": workingdir,
-            "env": process.env
-        }, function (error, stdout, stderr) {
-            var parser = new xml2js.Parser();
-            fs.readFile(path.join(__dirname + "/../../www/", "config.xml"), function(err, data) {
-                parser.parseString(data, function (err, result) {
-                    if (stdout.indexOf(result['@'].id) != -1) {
-                        var options = generateOptions(true);
-                        execNativeDeploy(options,
-                            function(){
-                                deploy();
-                        });
-                    } else {
-                        deploy();
-                    }
-                });
-            });
-        });
-    }
-}
-
-function deploy() {
-    options = generateOptions(false);
-    execNativeDeploy(options, function (code) {
-        if (code) {
-            process.exit(2);
-        } else {
-            process.exit(0);
-        }
-    });
-}
-
-function checkDebugtoken(previous, baton) {
-    baton.take();
-
-    // if target has no pin, skip the debug token feature
-    if (properties.targets[target].pin) {
-        debugTokenHelper.checkDebugToken(properties.targets[target].pin, function (valid) {
-            // If the debug token is not valid, we need create new debug token
-            if (valid) {
-                // No need to create the debug token
-                logger.info(localize.translate("PROGRESS_DEBUG_TOKEN_IS_VALID"));
-                needDeployDebugToken = true;
-            } else {
-                needCreateDebugToken = true;
-            }
-            baton.pass();
-        });
-    } else {
-        baton.pass();
-    }
-}
-
-function createDebugToken(previous, baton) {
-    var keystorepass = program["keystorepass"] ? program["keystorepass"] : properties.keystorepass;
-
-    baton.take();
-
-    if (needCreateDebugToken) {
-        debugTokenHelper.createToken(properties, "all", keystorepass, function (code) {
-            if (code === 0) {
-                // Deploy the debug token if created
-                needDeployDebugToken = true;
-            }
-
-            baton.pass();
-        });
-    } else {
-            baton.pass();
-    }
-}
-
-function deployDebugToken(previous, baton) {
-    baton.take();
-
-    // If in debug build and debug token was created, deploy the debug token and wait until the deployment is finished
-    if (needDeployDebugToken) {
-        debugTokenHelper.deployToken(properties, target, function () {
-            baton.pass();
-        });
-    } else {
-        baton.pass();
-    }
-}
-
-function handleBuildOutput(data) {
-    var msg = data.toString().replace(/[\n\r]/g, '');
-    console.log(msg);
-}
-
-function build(previous, baton) {
-    var nativeDeploy,
-        execName = "./build";
-
-    baton.take();
-
-    if (pkgrUtils.isWindows()) {
-        execName = "build";
-    } 
-
-    nativeDeploy = childProcess.exec(execName, {
-        "cwd": path.normalize(__dirname + "/.."),
-        "env": process.env
-    });
-
-    nativeDeploy.stdout.on("data", handleBuildOutput);
-
-    nativeDeploy.stderr.on("data", handleBuildOutput);
-
-    nativeDeploy.on("exit", function (code) {
-        // If error happened during building the bar, exit
-        if (code === 2) {
-            process.exit(2);
-        }
-
-        baton.pass();
-    });
-}
-
-function postBuild() {
-    if (program.uninstall) {
-        uninstall();
-    } else {
-        deploy();
-    }
-}
-
-function exec() {
-    program
-        .usage('[--target=<id>] [-k | --keystorepass] [--no-launch] [--no-uninstall] [--no-build]')
-        .option('-k, --keystorepass <password>', 'the password of signing key; needed for creating debug token')
-        .option('--target', 'specifies the target to run the application')
-        .option('--no-uninstall', 'does not uninstall application from device')
-        .option('--no-launch', 'do not launch the application on device')
-        .option('--no-build', 'deploy the pre-built bar file and skip building');
-
-    commandStr = typeof process.argv[2] === "string" ? process.argv[2] : undefined;
-    if (commandStr && commandStr.indexOf("--target=") === 0) {
-        // Convert "--target=<id>" into "--target id"
-        process.argv[2] = "--target";
-        process.argv.splice(3, 0, commandStr.substring("--target=".length));
-    }
-
-    program.parse(process.argv);
-    target = program.args[0] ? program.args[0] : properties.defaultTarget;
-
-    if (checkTarget()) {
-        if (program.build) {
-            jWorkflow.order(checkDebugtoken)
-                     .andThen(createDebugToken)
-                     .andThen(deployDebugToken)
-                     .andThen(build)
-                     .andThen(postBuild)
-                     .start();
-        } else {
-            postBuild();
-        }
-    }
-}
-
-exec();

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/session.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/session.js b/lib/cordova-blackberry/bin/templates/project/cordova/lib/session.js
deleted file mode 100644
index bb9fa06..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/session.js
+++ /dev/null
@@ -1,120 +0,0 @@
-/*
- *  Copyright 2012 Research In Motion Limited.
- *
- * Licensed 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"),
-    wrench = require("wrench"),
-    logger = require("./logger"),
-    signingHelper = require("./signing-helper"),
-    barConf = require("./bar-conf"),
-    localize = require("./localize"),
-    params;
-
-function getParams(cmdline, toolName) {
-    if (cmdline.params) {
-        if (!params) {
-            var paramsPath = path.resolve(cmdline.params);
-
-            if (fs.existsSync(paramsPath)) {
-                try {
-                    params = require(paramsPath);
-                } catch (e) {
-                    throw localize.translate("EXCEPTION_PARAMS_FILE_ERROR", paramsPath);
-                }
-            } else {
-                throw localize.translate("EXCEPTION_PARAMS_FILE_NOT_FOUND", paramsPath);
-            }
-        }
-
-        if (params) {
-            return params[toolName];
-        }
-    }
-
-    return null;
-}
-
-
-module.exports = {
-    initialize: function (cmdline) {
-        var sourceDir,
-            signingPassword,
-            outputDir = cmdline.output,
-            properties = require("../../project.json"),
-            archivePath = path.resolve(cmdline.args[0]),
-            archiveName = properties.barName ? properties.barName : path.basename(archivePath, '.zip'),
-            appdesc,
-            buildId = cmdline.buildId;
-
-        //If -o option was not provided, default output location is the same as .zip
-        outputDir = outputDir || path.dirname(archivePath);
-
-        //Only set signingPassword if it contains a value
-        if (cmdline.password && "string" === typeof cmdline.password) {
-            signingPassword = cmdline.password;
-        }
-
-        if (cmdline.appdesc && "string" === typeof cmdline.appdesc) {
-            appdesc = path.resolve(cmdline.appdesc);
-        }
-
-        //If -s [dir] is provided
-        if (cmdline.source && "string" === typeof cmdline.source) {
-            sourceDir = cmdline.source + "/src";
-        } else {
-            sourceDir = outputDir + "/src";
-        }
-
-        if (!fs.existsSync(sourceDir)) {
-            wrench.mkdirSyncRecursive(sourceDir, "0755");
-        }
-
-        logger.level(cmdline.loglevel || 'verbose');
-
-        return {
-            "conf": require("./conf"),
-            "keepSource": !!cmdline.source,
-            "sourceDir": path.resolve(sourceDir),
-            "sourcePaths": {
-                "ROOT": path.resolve(sourceDir),
-                "CHROME": path.normalize(path.resolve(sourceDir) + barConf.CHROME),
-                "LIB": path.normalize(path.resolve(sourceDir) + barConf.LIB),
-                "EXT": path.normalize(path.resolve(sourceDir) + barConf.EXT),
-                "UI": path.normalize(path.resolve(sourceDir) + barConf.UI),
-                "PLUGINS": path.normalize(path.resolve(sourceDir) + barConf.PLUGINS),
-                "JNEXT_PLUGINS": path.normalize(path.resolve(sourceDir) + barConf.JNEXT_PLUGINS)
-            },
-            "outputDir": path.resolve(outputDir),
-            "archivePath": archivePath,
-            "archiveName": archiveName,
-            "barPath": outputDir + "/%s/" + archiveName + ".bar",
-            "debug": !!cmdline.debug,
-            "keystore": signingHelper.getKeyStorePath(),
-            "keystoreCsk": signingHelper.getCskPath(),
-            "keystoreDb": signingHelper.getDbPath(),
-            "storepass": signingPassword,
-            "buildId": buildId,
-            "appdesc" : appdesc,
-            getParams: function (toolName) {
-                return getParams(cmdline, toolName);
-            },
-            isSigningRequired: function (config) {
-                return signingHelper.getKeyStorePath() && signingPassword && config.buildId;
-            },
-            "targets": ["simulator", "device"]
-        };
-    }
-};

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/signing-helper.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/signing-helper.js b/lib/cordova-blackberry/bin/templates/project/cordova/lib/signing-helper.js
deleted file mode 100644
index d0daafd..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/signing-helper.js
+++ /dev/null
@@ -1,127 +0,0 @@
-/*
- *  Copyright 2012 Research In Motion Limited.
- *
- * Licensed 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"),
-    os = require('os'),
-    childProcess = require("child_process"),
-    util = require("util"),
-    conf = require("./conf"),
-    pkgrUtils = require("./packager-utils"),
-    logger = require("./logger"),
-    AUTHOR_P12 = "author.p12",
-    CSK = "barsigner.csk",
-    DB = "barsigner.db",
-    _self;
-
-function getDefaultPath(file) {
-    // The default location where signing key files are stored will vary based on the OS:
-    // Windows XP: %HOMEPATH%\Local Settings\Application Data\Research In Motion
-    // Windows Vista and Windows 7: %HOMEPATH%\AppData\Local\Research In Motion
-    // Mac OS: ~/Library/Research In Motion
-    // UNIX or Linux: ~/.rim
-    var p = "";
-    if (os.type().toLowerCase().indexOf("windows") >= 0) {
-        // Try Windows XP location
-        p = process.env.HOMEDRIVE + process.env.HOMEPATH + "\\Local Settings\\Application Data\\Research In Motion\\" + file;
-        if (fs.existsSync(p)) {
-            return p;
-        }
-
-        // Try Windows Vista and Windows 7 location
-        p = process.env.HOMEDRIVE + process.env.HOMEPATH + "\\AppData\\Local\\Research In Motion\\" + file;
-        if (fs.existsSync(p)) {
-            return p;
-        }
-    } else if (os.type().toLowerCase().indexOf("darwin") >= 0) {
-        // Try Mac OS location
-        p = process.env.HOME + "/Library/Research In Motion/" + file;
-        if (fs.existsSync(p)) {
-            return p;
-        }
-    } else if (os.type().toLowerCase().indexOf("linux") >= 0) {
-        // Try Linux location
-        p = process.env.HOME + "/.rim/" + file;
-        if (fs.existsSync(p)) {
-            return p;
-        }
-    }
-}
-
-function execSigner(session, target, callback) {
-    var script = "blackberry-signer",
-        cwd = path.normalize(conf.DEPENDENCIES_TOOLS + "/bin/"),
-        signer,
-        params = session.getParams("blackberry-signer"),
-        args = [];
-
-    if (pkgrUtils.isWindows()) {
-        script += ".bat";
-    } else {
-        // add path to executable to work around issue with node
-        script = cwd + script;
-    }
-
-    args.push("-keystore");
-    args.push(session.keystore);
-    args.push("-storepass");
-    args.push(session.storepass);
-
-    if (params) {
-        Object.getOwnPropertyNames(params).forEach(function (p) {
-            args.push(p);
-
-            if (params[p]) {
-                args.push(params[p]);
-            }
-        });
-    }
-
-    args.push(path.resolve(util.format(session.barPath, target)));
-
-    signer = childProcess.spawn(script, args, {
-        "cwd": cwd,
-        "env": process.env
-    });
-
-    signer.stdout.on("data", pkgrUtils.handleProcessOutput);
-
-    signer.stderr.on("data", pkgrUtils.handleProcessOutput);
-
-    signer.on("exit", function (code) {
-        if (callback && typeof callback === "function") {
-            callback(code);
-        }
-    });
-}
-
-_self = {
-    getKeyStorePath : function () {
-        // Todo: decide where to put sigtool.p12 which is genereated and used in WebWorks SDK for Tablet OS
-        return getDefaultPath(AUTHOR_P12);
-    },
-
-    getCskPath : function () {
-        return getDefaultPath(CSK);
-    },
-
-    getDbPath : function () {
-        return getDefaultPath(DB);
-    },
-
-    execSigner: execSigner
-};
-
-module.exports = _self;

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator b/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator
deleted file mode 100755
index cfb96a8..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator
+++ /dev/null
@@ -1,54 +0,0 @@
-#!/usr/bin/env bash
-#
-# 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.
-#
-
-# support for this script on BB10 is dependent on vmware tools being on the path, or in the default install directory
-# Valid values for "--target": path to 'vmwarevm' file
-
-VMWARE_DEFAULT_PATH=/Applications/VMware\ Fusion.app/Contents/Library
-VMWARE_TOOL=vmrun
-OS_NAME=`uname`
-
-if [ "$1" = "" -o ! -e "$1" ]
-then
-    echo "BlackBerry10: must provide path to valid vmwarevm image"
-    exit 2
-fi
-
-if [ "$OS_NAME" = "Darwin" ]; then
-    if [ "`which vmrun`" = "" ]; then
-        echo "BlackBerry10: VMware Fusion 'vmrun' tool not found on path, trying default install path"
-        runpath=$VMWARE_DEFAULT_PATH/$VMWARE_TOOL
-    else
-        runpath=`which vmrun`
-    fi
-    
-    if [ -x "$runpath" ]; then
-        echo $runpath start $1
-        `$"$runpath" start "$1" > /dev/null`
-
-        exit 0 
-    else
-        echo "BlackBerry10: could not find VMware Fusion 'vmrun' tool"
-        exit 1 
-    fi
-else
-    echo "BlackBerry10: currently only supports installing to emulator on OS X"
-    exit 1
-fi

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator.bat
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator.bat b/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator.bat
deleted file mode 100644
index 6671abb..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/start-emulator.bat
+++ /dev/null
@@ -1,21 +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.
-
-@ECHO OFF
-
-ECHO echo 'BlackBerry10: Not able to start emulator images on windows command-line at this time.'
-EXIT /B 1

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/lib/target
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/lib/target b/lib/cordova-blackberry/bin/templates/project/cordova/lib/target
deleted file mode 100644
index 0a5746b..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/lib/target
+++ /dev/null
@@ -1,209 +0,0 @@
-#!/usr/bin/env node
-/*
- *  Copyright 2013 Research In Motion Limited.
- *
- * Licensed 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'),
-    propertiesFile = path.resolve(path.join(__dirname, '..', '..', 'project.json')),
-    properties = require(propertiesFile),
-    fs = require('fs'),
-    commander = require('commander'),
-    command,
-    name,
-    ip,
-    type,
-    password,
-    pin,
-    pinRegex = new RegExp("[0-9A-Fa-f]{8}");
-
-function writeProjectFile(contents, file) {
-    fs.writeFile(file, contents, 'utf-8', function (err) {
-        if (err) console.log("Error updating project.json :(\n" + err);
-        process.exit();
-    });
-}
-
-function isValidIp(ip) {
-    var num,
-        result = true,
-        ipArray;
-
-    if (typeof ip !== 'string') {
-        console.log("IP is required");
-        console.log(commander.helpInformation());
-        process.exit(2); 
-    } else {
-        ipArray = ip.split('.');
-        if (ipArray.length !== 4) {
-            result = false;
-        }
-        ipArray.forEach(function (quadrant) {
-            num = Number(quadrant);
-            if (isNaN(num) || (num < 0) || (num > 255)) {
-                result = false;
-            }
-        });
-    }
-    return result;
-}
-
-function isValidType(type) {
-    var result = true;
-
-    if (typeof type !== 'string') {
-        console.log("target type is required");
-        console.log(commander.helpInformation());
-        process.exit(2); 
-    }
-    else if (!(type === 'device' || type === 'simulator')) {
-        result = false;
-    }
-    return result;
-}
-
-function isValidPin(pin) {
-    var result = true;
-    if (typeof pin !== 'undefined' && !pinRegex.test(pin)) {
-        result = false;
-    }
-    return result;
-}
-
-commander
-    .usage('[command] [params]')
-    .option('-p, --password <password>', 'Specifies password for this target')
-    .option('--pin <devicepin>', 'Specifies PIN for this device')
-    .option('-t, --type <device | simulator>', 'Specifies the target type');
-
-commander
-    .on('--help', function () {
-        console.log('   Synopsis:');
-        console.log('   $ target');
-        console.log('   $ target add <name> <ip> [-t | --type <device | simulator>] [-p | --password <password>] [--pin <devicepin>]');
-        console.log('   $ target remove <name>');
-        console.log('   $ target default [name]');
-        console.log(' ');
-    });
-
-commander
-    .command('add')
-    .description("Add specified target")
-    .action(function () {
-        if (commander.args.length === 1) {
-            console.log("Target details not specified");
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-        name = commander.args[0];
-        ip = commander.args[1];
-        type = commander.type ? commander.type : "device";
-        if (commander.password && typeof commander.password === 'string') {
-            password = commander.password;
-        }
-        if (commander.pin && typeof commander.pin === 'string') {
-            pin = commander.pin;
-        }
-        if (!isValidIp(ip)) {
-            console.log("Invalid IP: " + ip);
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-        if (!isValidType(type)) {
-            console.log("Invalid target type: " + type);
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-        if (!isValidPin(pin)) {
-            console.log("Invalid PIN: " + pin);
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-        if (properties.targets.hasOwnProperty(name)) {
-            console.log("Overwriting target: " + name);
-        }
-        properties.targets[name] = {"ip": ip, "type": type, "password": password, "pin": pin};
-    });
-
-commander
-    .command('remove')
-    .description("Remove specified target")
-    .action(function () {
-        if (commander.args.length === 1) {
-            console.log('No target specified');
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-        name = commander.args[0];
-        if (!properties.targets.hasOwnProperty(name)) {
-            console.log("Target: '" + name + "' not found");
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-        if (name === properties.defaultTarget) {
-            console.log("Deleting default target, please set a new default target");
-            properties.defaultTarget = "";
-        }
-        delete properties.targets[name];
-    });
-
-commander
-    .command('default')
-    .description("Get or set default target")
-    .action(function () {
-        if (commander.args.length === 1) {
-            console.log(properties.defaultTarget);
-            process.exit();
-        }
-        name = commander.args[0];
-        if (properties.targets.hasOwnProperty(name)) {
-            properties.defaultTarget = name;
-        } else {
-            console.log("Target '" + name + "' not found");
-            console.log(commander.helpInformation());
-            process.exit(2); 
-        }
-    });
-
-commander
-    .command('*')
-    .action(function () {
-        console.log('Unrecognized command');
-        console.log(commander.helpInformation());
-        process.exit(2);
-    });
-
-
-try {
-    commander.parse(process.argv);
-
-    if (commander.args.length === 0) {
-        Object.keys(properties.targets).forEach(function (target) {
-            if (target === properties.defaultTarget) {
-                console.log('* ' + target);
-            } else {
-                console.log('  ' + target);
-            }
-        });
-        process.exit();
-    }
-    if (Object.keys(properties.targets).length === 1) {
-        properties.defaultTarget = Object.keys(properties.targets)[0];
-    }
-
-    writeProjectFile(JSON.stringify(properties, null, 4) + "\n", propertiesFile);
-} catch (e) {
-    console.log(e);
-    process.exit();
-}

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/plugin
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/plugin b/lib/cordova-blackberry/bin/templates/project/cordova/plugin
deleted file mode 100755
index 010649b..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/plugin
+++ /dev/null
@@ -1,23 +0,0 @@
-#!/usr/bin/env node
-
-/**
- * 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.
- */
-
-require(require("path").join(__dirname, "lib", "plugin.js")).cli();
-

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/plugin.bat
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/plugin.bat b/lib/cordova-blackberry/bin/templates/project/cordova/plugin.bat
deleted file mode 100755
index 8a53da1..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/plugin.bat
+++ /dev/null
@@ -1,21 +0,0 @@
-@ECHO OFF
-goto comment
-       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.
-:comment
-
-@node.exe %~dps0\plugin %*

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/run
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/run b/lib/cordova-blackberry/bin/templates/project/cordova/run
deleted file mode 100755
index c6ccacf..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/run
+++ /dev/null
@@ -1,3 +0,0 @@
-#!/bin/sh
-
-node "$( dirname "$0")/lib/run" "$@"

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/run.bat
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/run.bat b/lib/cordova-blackberry/bin/templates/project/cordova/run.bat
deleted file mode 100755
index 32b6cc3..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/run.bat
+++ /dev/null
@@ -1,21 +0,0 @@
-@ECHO OFF
-goto comment
-       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.
-:comment
-
-@node.exe %~dps0\lib\run %*

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/target
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/target b/lib/cordova-blackberry/bin/templates/project/cordova/target
deleted file mode 100755
index 4e676d2..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/target
+++ /dev/null
@@ -1,3 +0,0 @@
-#!/bin/sh
-
-node "$( dirname "$0")/lib/target" "$@"

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/target.bat
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/target.bat b/lib/cordova-blackberry/bin/templates/project/cordova/target.bat
deleted file mode 100755
index 3c05c97..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/target.bat
+++ /dev/null
@@ -1,21 +0,0 @@
-@ECHO OFF
-goto comment
-       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.
-:comment
-
-@node.exe %~dps0\lib\target %*

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/third_party/data2xml/data2xml.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/third_party/data2xml/data2xml.js b/lib/cordova-blackberry/bin/templates/project/cordova/third_party/data2xml/data2xml.js
deleted file mode 100644
index 8223d12..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/third_party/data2xml/data2xml.js
+++ /dev/null
@@ -1,86 +0,0 @@
-// --------------------------------------------------------------------------------------------------------------------
-//
-// data2xml.js - A data to XML converter with a nice interface (for NodeJS).
-//
-// Copyright (c) 2011 AppsAttic Ltd - http://www.appsattic.com/
-// Written by Andrew Chilton <ch...@appsattic.com>
-//
-// License: http://opensource.org/licenses/MIT
-//
-// --------------------------------------------------------------------------------------------------------------------
-
-var xmlHeader = '<?xml version="1.0" encoding="utf-8"?>\n';
-
-function entitify(str) {
-    str = '' + str;
-    str = str
-        .replace(/&/g, '&amp;')
-        .replace(/</g,'&lt;')
-        .replace(/>/g,'&gt;')
-        .replace(/'/g, '&apos;')
-        .replace(/"/g, '&quot;');
-    return str;
-}
-
-function makeStartTag(name, attr) {
-    attr = attr || {};
-    var tag = '<' + name;
-    for(var a in attr) {
-        tag += ' ' + a + '="' + entitify(attr[a]) + '"';
-    }
-    tag += '>';
-    return tag;
-}
-
-function makeEndTag(name) {
-    return '</' + name + '>';
-}
-
-function makeElement(name, data) {
-    var element = '';
-    if ( Array.isArray(data) ) {
-        data.forEach(function(v) {
-            element += makeElement(name, v);
-        });
-        return element;
-    }
-    else if ( typeof data === 'object' ) {
-        element += makeStartTag(name, data._attr);
-        if ( data._value ) {
-            element += entitify(data._value);
-        }
-/************** MODIFICATION [always execute else condition] ***************/
-        for (var el in data) {
-            /**************** MODIFICATION {if condition altered} **********************/
-            if ( el === '_attr'  || el === '_value') {
-                continue;
-            }
-            element += makeElement(el, data[el]);
-        }
-        element += makeEndTag(name);
-        return element;
-/***************************** END MODIFICATION ***************************/
-    }
-    else {
-        // a piece of data on it's own can't have attributes
-        return makeStartTag(name) + entitify(data) + makeEndTag(name);
-    }
-    throw "Unknown data " + data;
-}
-
-var data2xml = function(name, data) {
-    var xml = xmlHeader;
-    xml += makeElement(name, data);
-    return xml;
-};
-
-// --------------------------------------------------------------------------------------------------------------------
-
-data2xml.entitify = entitify;
-data2xml.makeStartTag = makeStartTag;
-data2xml.makeEndTag = makeEndTag;
-data2xml.makeElement = makeElement;
-
-module.exports = data2xml;
-
-// --------------------------------------------------------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/cordova/third_party/wrench/wrench.js
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/cordova/third_party/wrench/wrench.js b/lib/cordova-blackberry/bin/templates/project/cordova/third_party/wrench/wrench.js
deleted file mode 100644
index 8c3d746..0000000
--- a/lib/cordova-blackberry/bin/templates/project/cordova/third_party/wrench/wrench.js
+++ /dev/null
@@ -1,78 +0,0 @@
-/*  wrench.js
- *
- *  A collection of various utility functions I've found myself in need of
- *  for use with Node.js (http://nodejs.org/). This includes things like:
- *
- *  - Recursively deleting directories in Node.js (Sync, not Async)
- *  - Recursively copying directories in Node.js (Sync, not Async)
- *  - Recursively chmoding a directory structure from Node.js (Sync, not Async)
- *  - Other things that I'll add here as time goes on. Shhhh...
- *
- *  ~ Ryan McGrath (ryan [at] venodesigns.net)
- */
-
-/* This file is originally licensed under https://raw.github.com/ryanmcgrath/wrench-js/master/LICENSE
- * This code has been copied from https://raw.github.com/ryanmcgrath/wrench-js and modified
- * add the functionality for a callback to the copyDirSyncRecursive method.
- * Modifications have been clearly marked.
- * The callback acts like a filter and you must return true/false from it to include/exclude a file
- */
-
-var wrench = require('wrench'),
-    fs = require("fs"),
-    _path = require("path");
-/*  wrench.copyDirSyncRecursive("directory_to_copy", "new_directory_location", opts);
- *
- *  Recursively dives through a directory and moves all its files to a new location. This is a
- *  Synchronous function, which blocks things until it's done. If you need/want to do this in
- *  an Asynchronous manner, look at wrench.copyDirRecursively() below.
- *
- *  Note: Directories should be passed to this function without a trailing slash.
- */
-wrench.copyDirSyncRecursive = function(sourceDir, newDirLocation, opts, callback) {
-
-    /**************************Modification*****************************************/
-    if (typeof opts === "function") {
-        callback = opts;
-        opts = {};
-    }
-    /**************************Modification End*****************************************/
-
-    if (!opts || !opts.preserve) {
-        try {
-            if(fs.statSync(newDirLocation).isDirectory()) wrench.rmdirSyncRecursive(newDirLocation);
-        } catch(e) { }
-    }
-
-    /*  Create the directory where all our junk is moving to; read the mode of the source directory and mirror it */
-    var checkDir = fs.statSync(sourceDir);
-    try {
-        fs.mkdirSync(newDirLocation, checkDir.mode);
-    } catch (e) {
-        //if the directory already exists, that's okay
-        if (e.code !== 'EEXIST') throw e;
-    }
-
-    var files = fs.readdirSync(sourceDir);
-
-    for(var i = 0; i < files.length; i++) {
-        var currFile = fs.lstatSync(sourceDir + "/" + files[i]);
-        /**************************Modified to add if statement*****************************************/
-        if (callback && !callback(sourceDir + "/" + files[i], currFile)) {
-            continue;
-        }
-        if(currFile.isDirectory()) {
-            /*  recursion this thing right on back. */
-            wrench.copyDirSyncRecursive(sourceDir + "/" + files[i], newDirLocation + "/" + files[i], opts, callback);
-        } else if(currFile.isSymbolicLink()) {
-            var symlinkFull = fs.readlinkSync(sourceDir + "/" + files[i]);
-            fs.symlinkSync(symlinkFull, newDirLocation + "/" + files[i]);
-        } else {
-            /*  At this point, we've hit a file actually worth copying... so copy it on over. */
-            var contents = fs.readFileSync(sourceDir + "/" + files[i]);
-            fs.writeFileSync(newDirLocation + "/" + files[i], contents);
-        }
-    }
-};
-
-

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/native/device/plugins/jnext/auth.txt
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/native/device/plugins/jnext/auth.txt b/lib/cordova-blackberry/bin/templates/project/native/device/plugins/jnext/auth.txt
deleted file mode 100644
index 0983f4f..0000000
--- a/lib/cordova-blackberry/bin/templates/project/native/device/plugins/jnext/auth.txt
+++ /dev/null
@@ -1,3 +0,0 @@
-local:/// *
-file:// *
-http:// *
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/native/device/wwe
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/native/device/wwe b/lib/cordova-blackberry/bin/templates/project/native/device/wwe
deleted file mode 100644
index 0e48b92..0000000
--- a/lib/cordova-blackberry/bin/templates/project/native/device/wwe
+++ /dev/null
@@ -1,2 +0,0 @@
-#!/bin/sh
-exec weblauncher "$@"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/native/simulator/plugins/jnext/auth.txt
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/native/simulator/plugins/jnext/auth.txt b/lib/cordova-blackberry/bin/templates/project/native/simulator/plugins/jnext/auth.txt
deleted file mode 100644
index 0983f4f..0000000
--- a/lib/cordova-blackberry/bin/templates/project/native/simulator/plugins/jnext/auth.txt
+++ /dev/null
@@ -1,3 +0,0 @@
-local:/// *
-file:// *
-http:// *
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/native/simulator/wwe
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/native/simulator/wwe b/lib/cordova-blackberry/bin/templates/project/native/simulator/wwe
deleted file mode 100644
index 0e48b92..0000000
--- a/lib/cordova-blackberry/bin/templates/project/native/simulator/wwe
+++ /dev/null
@@ -1,2 +0,0 @@
-#!/bin/sh
-exec weblauncher "$@"
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/project.json
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/project.json b/lib/cordova-blackberry/bin/templates/project/project.json
deleted file mode 100644
index 97390ae..0000000
--- a/lib/cordova-blackberry/bin/templates/project/project.json
+++ /dev/null
@@ -1,5 +0,0 @@
-{
-    "barName": "cordova-BB10-app",
-    "defaultTarget": "",
-    "targets": {}
-}

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/LICENSE
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/LICENSE b/lib/cordova-blackberry/bin/templates/project/www/LICENSE
deleted file mode 100644
index 9f761f1..0000000
--- a/lib/cordova-blackberry/bin/templates/project/www/LICENSE
+++ /dev/null
@@ -1,296 +0,0 @@
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed 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.
-
-==============================================================
-This product also include the following software:
-==============================================================
-
---------------------------------------------------------------
-jasmine from GitHub
-
-   https://github.com/pivotal/jasmine
-
-MIT-style license
-
-license available from:
-
-   https://github.com/pivotal/jasmine/blob/master/MIT.LICENSE
-   
------------------------------
-
-Copyright (c) 2008-2011 Pivotal Labs
-
-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.
-
-
---------------------------------------------------------------
-commonjs tests from the commonjs organization at GitHub
-
-   https://github.com/commonjs/commonjs
-
-MIT-style license
-
-license available from:
-
-   https://github.com/commonjs/commonjs/blob/master/docs/license.html.markdown
-
-contributor list available from:
-
-   https://github.com/commonjs/commonjs/blob/master/docs/contributors.html.markdown
-
------------------------------
-
-Copyright 2009 Kevin Dangoor
-Copyright 2009 Ihab Awad
-Copyright 2009 Ash Berlin
-Copyright 2009 Aristid Breitkreuz
-Copyright 2009 Kevin Dangoor
-Copyright 2009 Daniel Friesen
-Copyright 2009 Wes Garland
-Copyright 2009 Kris Kowal
-Copyright 2009 Dean Landolt
-Copyright 2009 Peter Michaux
-Copyright 2009 George Moschovitis
-Copyright 2009 Michael O'Brien
-Copyright 2009 Tom Robinson
-Copyright 2009 Hannes Wallnoefer
-Copyright 2009 Mike Wilson
-Copyright 2009 Ondrej Zara
-Copyright 2009 Chris Zumbrunn
-Copyright 2009 Kris Zyp
-
-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-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/NOTICE
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/NOTICE b/lib/cordova-blackberry/bin/templates/project/www/NOTICE
deleted file mode 100644
index 4e02ca4..0000000
--- a/lib/cordova-blackberry/bin/templates/project/www/NOTICE
+++ /dev/null
@@ -1,8 +0,0 @@
-Apache Cordova
-Copyright 2012 The Apache Software Foundation
-
-This product includes software developed by
-The Apache Software Foundation (http://www.apache.org)
-
-This product includes software developed by
-Jasmine (https://github.com/pivotal/jasmine)

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/README.md
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/README.md b/lib/cordova-blackberry/bin/templates/project/www/README.md
deleted file mode 100644
index 61256fe..0000000
--- a/lib/cordova-blackberry/bin/templates/project/www/README.md
+++ /dev/null
@@ -1,30 +0,0 @@
-# Apache Cordova Hello World Application
-
-> Simple Hello World application and test suite.
-
-## Run Application
-
-    /www/index.html
-
-## Run Tests
-
-    /www/spec.html
-
-## Versions and Tags
-
-The Hello World's version is directly tied to an Apache Cordova release.
-
-For example, Hello World `2.0.0` is compatible with Apache Cordova `2.0.0`.
-
-## How to Update
-
-Update to Apache Cordova x.x.x by:
-
-1. `www/index.html`
-    - Update `<script type="text/javascript" src="cordova-x.x.x.js"></script>`
-2. `VERSION`
-    - Update the version
-3. Commit and Tag
-    - `git commit -am "[app] Version x.x.x"`
-    - `git tag x.x.x`
-

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/VERSION
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/VERSION b/lib/cordova-blackberry/bin/templates/project/www/VERSION
deleted file mode 100644
index 834f262..0000000
--- a/lib/cordova-blackberry/bin/templates/project/www/VERSION
+++ /dev/null
@@ -1 +0,0 @@
-2.8.0

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/config.xml
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/config.xml b/lib/cordova-blackberry/bin/templates/project/www/config.xml
deleted file mode 100644
index a645139..0000000
--- a/lib/cordova-blackberry/bin/templates/project/www/config.xml
+++ /dev/null
@@ -1,61 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-       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.
--->
-<!--
-  Widget Configuration Reference:
-    http://docs.blackberry.com/en/developers/deliverables/15274/
--->
-
-<widget xmlns="http://www.w3.org/ns/widgets"
-        xmlns:rim="http://www.blackberry.com/ns/widgets"
-	version="1.0.0.1" id="default.app.id">
-
-  <name>Webworks Application</name>
-
-  <author>Your Name Here</author>
-
-  <description>
-       A sample Apache Cordova application that responds to the deviceready event.
-  </description>
-
-  <license href="http://opensource.org/licenses/alphabetical">
-  </license>
-
-  <!-- Expose access to all URIs, including the file and http protocols -->
-  <access subdomains="true" uri="file:///store/home" />
-  <access subdomains="true" uri="file:///SDCard" />
-  <access subdomains="true" uri="*" />
-
-  <icon src="res/icon/blackberry/icon-80.png" />
-  <rim:splash src="res/screen/blackberry/splash-1280x768.png" />
-  <rim:splash src="res/screen/blackberry/splash-720x720.png" />
-  <rim:splash src="res/screen/blackberry/splash-768x1280.png" />
-
-  <content src="index.html" />
-
-  <rim:permissions>
-    <rim:permit>use_camera</rim:permit>
-    <rim:permit>read_device_identifying_information</rim:permit>
-    <rim:permit>access_shared</rim:permit>
-    <rim:permit>read_geolocation</rim:permit>
-    <rim:permit>record_audio</rim:permit>
-    <rim:permit>access_pimdomain_contacts</rim:permit>
-  </rim:permissions>
-
-</widget>

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/css/index.css
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/css/index.css b/lib/cordova-blackberry/bin/templates/project/www/css/index.css
deleted file mode 100644
index 51daa79..0000000
--- a/lib/cordova-blackberry/bin/templates/project/www/css/index.css
+++ /dev/null
@@ -1,115 +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.
- */
-* {
-    -webkit-tap-highlight-color: rgba(0,0,0,0); /* make transparent link selection, adjust last value opacity 0 to 1.0 */
-}
-
-body {
-    -webkit-touch-callout: none;                /* prevent callout to copy image, etc when tap to hold */
-    -webkit-text-size-adjust: none;             /* prevent webkit from resizing text to fit */
-    -webkit-user-select: none;                  /* prevent copy paste, to allow, change 'none' to 'text' */
-    background-color:#E4E4E4;
-    background-image:linear-gradient(top, #A7A7A7 0%, #E4E4E4 51%);
-    background-image:-webkit-linear-gradient(top, #A7A7A7 0%, #E4E4E4 51%);
-    background-image:-ms-linear-gradient(top, #A7A7A7 0%, #E4E4E4 51%);
-    background-image:-webkit-gradient(
-        linear,
-        left top,
-        left bottom,
-        color-stop(0, #A7A7A7),
-        color-stop(0.51, #E4E4E4)
-    );
-    background-attachment:fixed;
-    font-family:'HelveticaNeue-Light', 'HelveticaNeue', Helvetica, Arial, sans-serif;
-    font-size:12px;
-    height:100%;
-    margin:0px;
-    padding:0px;
-    text-transform:uppercase;
-    width:100%;
-}
-
-/* Portrait layout (default) */
-.app {
-    background:url(../img/logo.png) no-repeat center top; /* 170px x 200px */
-    position:absolute;             /* position in the center of the screen */
-    left:50%;
-    top:50%;
-    height:50px;                   /* text area height */
-    width:225px;                   /* text area width */
-    text-align:center;
-    padding:180px 0px 0px 0px;     /* image height is 200px (bottom 20px are overlapped with text) */
-    margin:-115px 0px 0px -112px;  /* offset vertical: half of image height and text area height */
-                                   /* offset horizontal: half of text area width */
-}
-
-/* Landscape layout (with min-width) */
-@media screen and (min-aspect-ratio: 1/1) and (min-width:400px) {
-    .app {
-        background-position:left center;
-        padding:75px 0px 75px 170px;  /* padding-top + padding-bottom + text area = image height */
-        margin:-90px 0px 0px -198px;  /* offset vertical: half of image height */
-                                      /* offset horizontal: half of image width and text area width */
-    }
-}
-
-h1 {
-    font-size:24px;
-    font-weight:normal;
-    margin:0px;
-    overflow:visible;
-    padding:0px;
-    text-align:center;
-}
-
-.event {
-    border-radius:4px;
-    -webkit-border-radius:4px;
-    color:#FFFFFF;
-    font-size:12px;
-    margin:0px 30px;
-    padding:2px 0px;
-}
-
-.event.listening {
-    background-color:#333333;
-    display:block;
-}
-
-.event.received {
-    background-color:#4B946A;
-    display:none;
-}
-
-@keyframes fade {
-    from { opacity: 1.0; }
-    50% { opacity: 0.4; }
-    to { opacity: 1.0; }
-}
- 
-@-webkit-keyframes fade {
-    from { opacity: 1.0; }
-    50% { opacity: 0.4; }
-    to { opacity: 1.0; }
-}
- 
-.blink {
-    animation:fade 3000ms infinite;
-    -webkit-animation:fade 3000ms infinite;
-}

http://git-wip-us.apache.org/repos/asf/cordova-cli/blob/09ee1837/lib/cordova-blackberry/bin/templates/project/www/img/logo.png
----------------------------------------------------------------------
diff --git a/lib/cordova-blackberry/bin/templates/project/www/img/logo.png b/lib/cordova-blackberry/bin/templates/project/www/img/logo.png
deleted file mode 100644
index 9519e7d..0000000
Binary files a/lib/cordova-blackberry/bin/templates/project/www/img/logo.png and /dev/null differ