You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cordova.apache.org by bo...@apache.org on 2012/03/23 23:01:16 UTC

[5/17] Cleaning out the asssets/www directory. This should house mobile-spec

http://git-wip-us.apache.org/repos/asf/incubator-cordova-android/blob/8ecfcb12/test/assets/www/cordova-1.4.1.js
----------------------------------------------------------------------
diff --git a/test/assets/www/cordova-1.4.1.js b/test/assets/www/cordova-1.4.1.js
deleted file mode 100644
index edbbb47..0000000
--- a/test/assets/www/cordova-1.4.1.js
+++ /dev/null
@@ -1,5510 +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.
- */
-
-if (typeof Cordova === "undefined") {
-
-/**
- * The order of events during page load and Cordova startup is as follows:
- *
- * onDOMContentLoaded         Internal event that is received when the web page is loaded and parsed.
- * window.onload              Body onload event.
- * onNativeReady              Internal event that indicates the Cordova native side is ready.
- * onCordovaInit             Internal event that kicks off creation of all Cordova JavaScript objects (runs constructors).
- * onCordovaReady            Internal event fired when all Cordova JavaScript objects have been created
- * onCordovaInfoReady        Internal event fired when device properties are available
- * onDeviceReady              User event fired to indicate that Cordova is ready
- * onResume                   User event fired to indicate a start/resume lifecycle event
- * onPause                    User event fired to indicate a pause lifecycle event
- * onDestroy                  Internal event fired when app is being destroyed (User should use window.onunload event, not this one).
- *
- * The only Cordova events that user code should register for are:
- *      deviceready           Cordova native code is initialized and Cordova APIs can be called from JavaScript
- *      pause                 App has moved to background
- *      resume                App has returned to foreground
- *
- * Listeners can be registered as:
- *      document.addEventListener("deviceready", myDeviceReadyListener, false);
- *      document.addEventListener("resume", myResumeListener, false);
- *      document.addEventListener("pause", myPauseListener, false);
- *
- * The DOM lifecycle events should be used for saving and restoring state
- *      window.onload
- *      window.onunload
- */
-
-/**
- * This represents the Cordova API itself, and provides a global namespace for accessing
- * information about the state of Cordova.
- * @class
- */
-var Cordova = {
-    documentEventHandler: {},   // Collection of custom document event handlers
-    windowEventHandler: {}      // Collection of custom window event handlers
-};
-
-/**
- * List of resource files loaded by Cordova.
- * This is used to ensure JS and other files are loaded only once.
- */
-Cordova.resources = {base: true};
-
-/**
- * Determine if resource has been loaded by Cordova
- *
- * @param name
- * @return
- */
-Cordova.hasResource = function(name) {
-    return Cordova.resources[name];
-};
-
-/**
- * Add a resource to list of loaded resources by Cordova
- *
- * @param name
- */
-Cordova.addResource = function(name) {
-    Cordova.resources[name] = true;
-};
-
-/**
- * Custom pub-sub channel that can have functions subscribed to it
- * @constructor
- */
-Cordova.Channel = function (type)
-{
-    this.type = type;
-    this.handlers = {};
-    this.guid = 0;
-    this.fired = false;
-    this.enabled = true;
-};
-
-/**
- * Subscribes the given function to the channel. Any time that
- * Channel.fire is called so too will the function.
- * Optionally specify an execution context for the function
- * and a guid that can be used to stop subscribing to the channel.
- * Returns the guid.
- */
-Cordova.Channel.prototype.subscribe = function(f, c, g) {
-    // need a function to call
-    if (f === null) { return; }
-
-    var func = f;
-    if (typeof c === "object" && typeof f === "function") { func = Cordova.close(c, f); }
-
-    g = g || func.observer_guid || f.observer_guid || this.guid++;
-    func.observer_guid = g;
-    f.observer_guid = g;
-    this.handlers[g] = func;
-    return g;
-};
-
-/**
- * Like subscribe but the function is only called once and then it
- * auto-unsubscribes itself.
- */
-Cordova.Channel.prototype.subscribeOnce = function(f, c) {
-    var g = null;
-    var _this = this;
-    var m = function() {
-        f.apply(c || null, arguments);
-        _this.unsubscribe(g);
-    };
-    if (this.fired) {
-        if (typeof c === "object" && typeof f === "function") { f = Cordova.close(c, f); }
-        f.apply(this, this.fireArgs);
-    } else {
-        g = this.subscribe(m);
-    }
-    return g;
-};
-
-/**
- * Unsubscribes the function with the given guid from the channel.
- */
-Cordova.Channel.prototype.unsubscribe = function(g) {
-    if (typeof g === "function") { g = g.observer_guid; }
-    this.handlers[g] = null;
-    delete this.handlers[g];
-};
-
-/**
- * Calls all functions subscribed to this channel.
- */
-Cordova.Channel.prototype.fire = function(e) {
-    if (this.enabled) {
-        var fail = false;
-        var item, handler, rv;
-        for (item in this.handlers) {
-            if (this.handlers.hasOwnProperty(item)) {
-                handler = this.handlers[item];
-                if (typeof handler === "function") {
-                    rv = (handler.apply(this, arguments) === false);
-                    fail = fail || rv;
-                }
-            }
-        }
-        this.fired = true;
-        this.fireArgs = arguments;
-        return !fail;
-    }
-    return true;
-};
-
-/**
- * Calls the provided function only after all of the channels specified
- * have been fired.
- */
-Cordova.Channel.join = function(h, c) {
-    var i = c.length;
-    var f = function() {
-        if (!(--i)) {
-            h();
-        }
-    };
-    var len = i;
-    var j;
-    for (j=0; j<len; j++) {
-        if (!c[j].fired) {
-            c[j].subscribeOnce(f);
-        }
-        else {
-            i--;
-        }
-    }
-    if (!i) {
-        h();
-    }
-};
-
-/**
- * Add an initialization function to a queue that ensures it will run and initialize
- * application constructors only once Cordova has been initialized.
- * @param {Function} func The function callback you want run once Cordova is initialized
- */
-Cordova.addConstructor = function(func) {
-    Cordova.onCordovaInit.subscribeOnce(function() {
-        try {
-            func();
-        } catch(e) {
-            console.log("Failed to run constructor: " + e);
-        }
-    });
-};
-
-/**
- * Plugins object
- */
-if (!window.plugins) {
-    window.plugins = {};
-}
-
-/**
- * Adds a plugin object to window.plugins.
- * The plugin is accessed using window.plugins.<name>
- *
- * @param name          The plugin name
- * @param obj           The plugin object
- */
-Cordova.addPlugin = function(name, obj) {
-    if (!window.plugins[name]) {
-        window.plugins[name] = obj;
-    }
-    else {
-        console.log("Error: Plugin "+name+" already exists.");
-    }
-};
-
-/**
- * onDOMContentLoaded channel is fired when the DOM content
- * of the page has been parsed.
- */
-Cordova.onDOMContentLoaded = new Cordova.Channel('onDOMContentLoaded');
-
-/**
- * onNativeReady channel is fired when the Cordova native code
- * has been initialized.
- */
-Cordova.onNativeReady = new Cordova.Channel('onNativeReady');
-
-/**
- * onCordovaInit channel is fired when the web page is fully loaded and
- * Cordova native code has been initialized.
- */
-Cordova.onCordovaInit = new Cordova.Channel('onCordovaInit');
-
-/**
- * onCordovaReady channel is fired when the JS Cordova objects have been created.
- */
-Cordova.onCordovaReady = new Cordova.Channel('onCordovaReady');
-
-/**
- * onCordovaInfoReady channel is fired when the Cordova device properties
- * has been set.
- */
-Cordova.onCordovaInfoReady = new Cordova.Channel('onCordovaInfoReady');
-
-/**
- * onCordovaConnectionReady channel is fired when the Cordova connection properties
- * has been set.
- */
-Cordova.onCordovaConnectionReady = new Cordova.Channel('onCordovaConnectionReady');
-
-/**
- * onDestroy channel is fired when the Cordova native code
- * is destroyed.  It is used internally.
- * Window.onunload should be used by the user.
- */
-Cordova.onDestroy = new Cordova.Channel('onDestroy');
-Cordova.onDestroy.subscribeOnce(function() {
-    Cordova.shuttingDown = true;
-});
-Cordova.shuttingDown = false;
-
-// _nativeReady is global variable that the native side can set
-// to signify that the native code is ready. It is a global since
-// it may be called before any Cordova JS is ready.
-if (typeof _nativeReady !== 'undefined') { Cordova.onNativeReady.fire(); }
-
-/**
- * onDeviceReady is fired only after all Cordova objects are created and
- * the device properties are set.
- */
-Cordova.onDeviceReady = new Cordova.Channel('onDeviceReady');
-
-
-// Array of channels that must fire before "deviceready" is fired
-Cordova.deviceReadyChannelsArray = [ Cordova.onCordovaReady, Cordova.onCordovaInfoReady, Cordova.onCordovaConnectionReady];
-
-// Hashtable of user defined channels that must also fire before "deviceready" is fired
-Cordova.deviceReadyChannelsMap = {};
-
-/**
- * Indicate that a feature needs to be initialized before it is ready to be used.
- * This holds up Cordova's "deviceready" event until the feature has been initialized
- * and Cordova.initComplete(feature) is called.
- *
- * @param feature {String}     The unique feature name
- */
-Cordova.waitForInitialization = function(feature) {
-    if (feature) {
-        var channel = new Cordova.Channel(feature);
-        Cordova.deviceReadyChannelsMap[feature] = channel;
-        Cordova.deviceReadyChannelsArray.push(channel);
-    }
-};
-
-/**
- * Indicate that initialization code has completed and the feature is ready to be used.
- *
- * @param feature {String}     The unique feature name
- */
-Cordova.initializationComplete = function(feature) {
-    var channel = Cordova.deviceReadyChannelsMap[feature];
-    if (channel) {
-        channel.fire();
-    }
-};
-
-/**
- * Create all Cordova objects once page has fully loaded and native side is ready.
- */
-Cordova.Channel.join(function() {
-
-    // Start listening for XHR callbacks
-    setTimeout(function() {
-            if (Cordova.UsePolling) {
-                Cordova.JSCallbackPolling();
-            }
-            else {
-                var polling = prompt("usePolling", "gap_callbackServer:");
-                Cordova.UsePolling = polling;
-                if (polling == "true") {
-                    Cordova.UsePolling = true;
-                    Cordova.JSCallbackPolling();
-                }
-                else {
-                    Cordova.UsePolling = false;
-                    Cordova.JSCallback();
-                }
-            }
-        }, 1);
-
-    // Run Cordova constructors
-    Cordova.onCordovaInit.fire();
-
-    // Fire event to notify that all objects are created
-    Cordova.onCordovaReady.fire();
-
-    // Fire onDeviceReady event once all constructors have run and Cordova info has been
-    // received from native side, and any user defined initialization channels.
-    Cordova.Channel.join(function() {
-        // Let native code know we are inited on JS side
-        prompt("", "gap_init:");
-
-        Cordova.onDeviceReady.fire();
-    }, Cordova.deviceReadyChannelsArray);
-
-}, [ Cordova.onDOMContentLoaded, Cordova.onNativeReady ]);
-
-// Listen for DOMContentLoaded and notify our channel subscribers
-document.addEventListener('DOMContentLoaded', function() {
-    Cordova.onDOMContentLoaded.fire();
-}, false);
-
-// Intercept calls to document.addEventListener and watch for deviceready
-Cordova.m_document_addEventListener = document.addEventListener;
-
-// Intercept calls to window.addEventListener
-Cordova.m_window_addEventListener = window.addEventListener;
-
-/**
- * Add a custom window event handler.
- *
- * @param {String} event            The event name that callback handles
- * @param {Function} callback       The event handler
- */
-Cordova.addWindowEventHandler = function(event, callback) {
-    Cordova.windowEventHandler[event] = callback;
-};
-
-/**
- * Add a custom document event handler.
- *
- * @param {String} event            The event name that callback handles
- * @param {Function} callback       The event handler
- */
-Cordova.addDocumentEventHandler = function(event, callback) {
-    Cordova.documentEventHandler[event] = callback;
-};
-
-/**
- * Intercept adding document event listeners and handle our own
- *
- * @param {Object} evt
- * @param {Function} handler
- * @param capture
- */
-document.addEventListener = function(evt, handler, capture) {
-    var e = evt.toLowerCase();
-    if (e === 'deviceready') {
-        Cordova.onDeviceReady.subscribeOnce(handler);
-    }
-    else {
-        // If subscribing to Android backbutton
-        if (e === 'backbutton') {
-            Cordova.exec(null, null, "App", "overrideBackbutton", [true]);
-        }
-        
-        // If subscribing to an event that is handled by a plugin
-        else if (typeof Cordova.documentEventHandler[e] !== "undefined") {
-            if (Cordova.documentEventHandler[e](e, handler, true)) {
-                return; // Stop default behavior
-            }
-        }
-        
-        Cordova.m_document_addEventListener.call(document, evt, handler, capture);
-    }
-};
-
-/**
- * Intercept adding window event listeners and handle our own
- *
- * @param {Object} evt
- * @param {Function} handler
- * @param capture
- */
-window.addEventListener = function(evt, handler, capture) {
-    var e = evt.toLowerCase();
-        
-    // If subscribing to an event that is handled by a plugin
-    if (typeof Cordova.windowEventHandler[e] !== "undefined") {
-        if (Cordova.windowEventHandler[e](e, handler, true)) {
-            return; // Stop default behavior
-        }
-    }
-        
-    Cordova.m_window_addEventListener.call(window, evt, handler, capture);
-};
-
-// Intercept calls to document.removeEventListener and watch for events that
-// are generated by Cordova native code
-Cordova.m_document_removeEventListener = document.removeEventListener;
-
-// Intercept calls to window.removeEventListener
-Cordova.m_window_removeEventListener = window.removeEventListener;
-
-/**
- * Intercept removing document event listeners and handle our own
- *
- * @param {Object} evt
- * @param {Function} handler
- * @param capture
- */
-document.removeEventListener = function(evt, handler, capture) {
-    var e = evt.toLowerCase();
-
-    // If unsubscribing to Android backbutton
-    if (e === 'backbutton') {
-        Cordova.exec(null, null, "App", "overrideBackbutton", [false]);
-    }
-
-    // If unsubcribing from an event that is handled by a plugin
-    if (typeof Cordova.documentEventHandler[e] !== "undefined") {
-        if (Cordova.documentEventHandler[e](e, handler, false)) {
-            return; // Stop default behavior
-        }
-    }
-
-    Cordova.m_document_removeEventListener.call(document, evt, handler, capture);
-};
-
-/**
- * Intercept removing window event listeners and handle our own
- *
- * @param {Object} evt
- * @param {Function} handler
- * @param capture
- */
-window.removeEventListener = function(evt, handler, capture) {
-    var e = evt.toLowerCase();
-
-    // If unsubcribing from an event that is handled by a plugin
-    if (typeof Cordova.windowEventHandler[e] !== "undefined") {
-        if (Cordova.windowEventHandler[e](e, handler, false)) {
-            return; // Stop default behavior
-        }
-    }
-
-    Cordova.m_window_removeEventListener.call(window, evt, handler, capture);
-};
-
-/**
- * Method to fire document event
- *
- * @param {String} type             The event type to fire
- * @param {Object} data             Data to send with event
- */
-Cordova.fireDocumentEvent = function(type, data) {
-    var e = document.createEvent('Events');
-    e.initEvent(type);
-    if (data) {
-        for (var i in data) {
-            e[i] = data[i];
-        }
-    }
-    document.dispatchEvent(e);
-};
-
-/**
- * Method to fire window event
- *
- * @param {String} type             The event type to fire
- * @param {Object} data             Data to send with event
- */
-Cordova.fireWindowEvent = function(type, data) {
-    var e = document.createEvent('Events');
-    e.initEvent(type);
-    if (data) {
-        for (var i in data) {
-            e[i] = data[i];
-        }
-    }
-    window.dispatchEvent(e);
-};
-
-/**
- * Does a deep clone of the object.
- *
- * @param obj
- * @return {Object}
- */
-Cordova.clone = function(obj) {
-    var i, retVal;
-    if(!obj) { 
-        return obj;
-    }
-    
-    if(obj instanceof Array){
-        retVal = [];
-        for(i = 0; i < obj.length; ++i){
-            retVal.push(Cordova.clone(obj[i]));
-        }
-        return retVal;
-    }
-    
-    if (typeof obj === "function") {
-        return obj;
-    }
-    
-    if(!(obj instanceof Object)){
-        return obj;
-    }
-    
-    if (obj instanceof Date) {
-        return obj;
-    }
-    
-    retVal = {};
-    for(i in obj){
-        if(!(i in retVal) || retVal[i] !== obj[i]) {
-            retVal[i] = Cordova.clone(obj[i]);
-        }
-    }
-    return retVal;
-};
-
-Cordova.callbackId = 0;
-Cordova.callbacks = {};
-Cordova.callbackStatus = {
-    NO_RESULT: 0,
-    OK: 1,
-    CLASS_NOT_FOUND_EXCEPTION: 2,
-    ILLEGAL_ACCESS_EXCEPTION: 3,
-    INSTANTIATION_EXCEPTION: 4,
-    MALFORMED_URL_EXCEPTION: 5,
-    IO_EXCEPTION: 6,
-    INVALID_ACTION: 7,
-    JSON_EXCEPTION: 8,
-    ERROR: 9
-    };
-
-
-/**
- * Execute a Cordova command.  It is up to the native side whether this action is synch or async.
- * The native side can return:
- *      Synchronous: PluginResult object as a JSON string
- *      Asynchrounous: Empty string ""
- * If async, the native side will Cordova.callbackSuccess or Cordova.callbackError,
- * depending upon the result of the action.
- *
- * @param {Function} success    The success callback
- * @param {Function} fail       The fail callback
- * @param {String} service      The name of the service to use
- * @param {String} action       Action to be run in Cordova
- * @param {Array.<String>} [args]     Zero or more arguments to pass to the method
- */
-Cordova.exec = function(success, fail, service, action, args) {
-    try {
-        var callbackId = service + Cordova.callbackId++;
-        if (success || fail) {
-            Cordova.callbacks[callbackId] = {success:success, fail:fail};
-        }
-
-        var r = prompt(JSON.stringify(args), "gap:"+JSON.stringify([service, action, callbackId, true]));
-
-        // If a result was returned
-        if (r.length > 0) {
-            eval("var v="+r+";");
-
-            // If status is OK, then return value back to caller
-            if (v.status === Cordova.callbackStatus.OK) {
-
-                // If there is a success callback, then call it now with
-                // returned value
-                if (success) {
-                    try {
-                        success(v.message);
-                    } catch (e) {
-                        console.log("Error in success callback: " + callbackId  + " = " + e);
-                    }
-
-                    // Clear callback if not expecting any more results
-                    if (!v.keepCallback) {
-                        delete Cordova.callbacks[callbackId];
-                    }
-                }
-                return v.message;
-            }
-
-            // If no result
-            else if (v.status === Cordova.callbackStatus.NO_RESULT) {
-
-                // Clear callback if not expecting any more results
-                if (!v.keepCallback) {
-                    delete Cordova.callbacks[callbackId];
-                }
-            }
-
-            // If error, then display error
-            else {
-                console.log("Error: Status="+v.status+" Message="+v.message);
-
-                // If there is a fail callback, then call it now with returned value
-                if (fail) {
-                    try {
-                        fail(v.message);
-                    }
-                    catch (e1) {
-                        console.log("Error in error callback: "+callbackId+" = "+e1);
-                    }
-
-                    // Clear callback if not expecting any more results
-                    if (!v.keepCallback) {
-                        delete Cordova.callbacks[callbackId];
-                    }
-                }
-                return null;
-            }
-        }
-    } catch (e2) {
-        console.log("Error: "+e2);
-    }
-};
-
-/**
- * Called by native code when returning successful result from an action.
- *
- * @param callbackId
- * @param args
- */
-Cordova.callbackSuccess = function(callbackId, args) {
-    if (Cordova.callbacks[callbackId]) {
-
-        // If result is to be sent to callback
-        if (args.status === Cordova.callbackStatus.OK) {
-            try {
-                if (Cordova.callbacks[callbackId].success) {
-                    Cordova.callbacks[callbackId].success(args.message);
-                }
-            }
-            catch (e) {
-                console.log("Error in success callback: "+callbackId+" = "+e);
-            }
-        }
-
-        // Clear callback if not expecting any more results
-        if (!args.keepCallback) {
-            delete Cordova.callbacks[callbackId];
-        }
-    }
-};
-
-/**
- * Called by native code when returning error result from an action.
- *
- * @param callbackId
- * @param args
- */
-Cordova.callbackError = function(callbackId, args) {
-    if (Cordova.callbacks[callbackId]) {
-        try {
-            if (Cordova.callbacks[callbackId].fail) {
-                Cordova.callbacks[callbackId].fail(args.message);
-            }
-        }
-        catch (e) {
-            console.log("Error in error callback: "+callbackId+" = "+e);
-        }
-
-        // Clear callback if not expecting any more results
-        if (!args.keepCallback) {
-            delete Cordova.callbacks[callbackId];
-        }
-    }
-};
-
-Cordova.JSCallbackPort = null;
-Cordova.JSCallbackToken = null;
-
-/**
- * This is only for Android.
- *
- * Internal function that uses XHR to call into Cordova Java code and retrieve
- * any JavaScript code that needs to be run.  This is used for callbacks from
- * Java to JavaScript.
- */
-Cordova.JSCallback = function() {
-
-    // Exit if shutting down app
-    if (Cordova.shuttingDown) {
-        return;
-    }
-
-    // If polling flag was changed, start using polling from now on
-    if (Cordova.UsePolling) {
-        Cordova.JSCallbackPolling();
-        return;
-    }
-
-    var xmlhttp = new XMLHttpRequest();
-
-    // Callback function when XMLHttpRequest is ready
-    xmlhttp.onreadystatechange=function(){
-        if(xmlhttp.readyState === 4){
-
-            // Exit if shutting down app
-            if (Cordova.shuttingDown) {
-                return;
-            }
-
-            // If callback has JavaScript statement to execute
-            if (xmlhttp.status === 200) {
-
-                // Need to url decode the response
-                var msg = decodeURIComponent(xmlhttp.responseText);
-                setTimeout(function() {
-                    try {
-                        var t = eval(msg);
-                    }
-                    catch (e) {
-                        // If we're getting an error here, seeing the message will help in debugging
-                        console.log("JSCallback: Message from Server: " + msg);
-                        console.log("JSCallback Error: "+e);
-                    }
-                }, 1);
-                setTimeout(Cordova.JSCallback, 1);
-            }
-
-            // If callback ping (used to keep XHR request from timing out)
-            else if (xmlhttp.status === 404) {
-                setTimeout(Cordova.JSCallback, 10);
-            }
-
-            // If security error
-            else if (xmlhttp.status === 403) {
-                console.log("JSCallback Error: Invalid token.  Stopping callbacks.");
-            }
-
-            // If server is stopping
-            else if (xmlhttp.status === 503) {
-                console.log("JSCallback Server Closed: Stopping callbacks.");
-            }
-
-            // If request wasn't GET
-            else if (xmlhttp.status === 400) {
-                console.log("JSCallback Error: Bad request.  Stopping callbacks.");
-            }
-
-            // If error, revert to polling
-            else {
-                console.log("JSCallback Error: Request failed.");
-                Cordova.UsePolling = true;
-                Cordova.JSCallbackPolling();
-            }
-        }
-    };
-
-    if (Cordova.JSCallbackPort === null) {
-        Cordova.JSCallbackPort = prompt("getPort", "gap_callbackServer:");
-    }
-    if (Cordova.JSCallbackToken === null) {
-        Cordova.JSCallbackToken = prompt("getToken", "gap_callbackServer:");
-    }
-    xmlhttp.open("GET", "http://127.0.0.1:"+Cordova.JSCallbackPort+"/"+Cordova.JSCallbackToken , true);
-    xmlhttp.send();
-};
-
-/**
- * The polling period to use with JSCallbackPolling.
- * This can be changed by the application.  The default is 50ms.
- */
-Cordova.JSCallbackPollingPeriod = 50;
-
-/**
- * Flag that can be set by the user to force polling to be used or force XHR to be used.
- */
-Cordova.UsePolling = false;    // T=use polling, F=use XHR
-
-/**
- * This is only for Android.
- *
- * Internal function that uses polling to call into Cordova Java code and retrieve
- * any JavaScript code that needs to be run.  This is used for callbacks from
- * Java to JavaScript.
- */
-Cordova.JSCallbackPolling = function() {
-
-    // Exit if shutting down app
-    if (Cordova.shuttingDown) {
-        return;
-    }
-
-    // If polling flag was changed, stop using polling from now on
-    if (!Cordova.UsePolling) {
-        Cordova.JSCallback();
-        return;
-    }
-
-    var msg = prompt("", "gap_poll:");
-    if (msg) {
-        setTimeout(function() {
-            try {
-                var t = eval(""+msg);
-            }
-            catch (e) {
-                console.log("JSCallbackPolling: Message from Server: " + msg);
-                console.log("JSCallbackPolling Error: "+e);
-            }
-        }, 1);
-        setTimeout(Cordova.JSCallbackPolling, 1);
-    }
-    else {
-        setTimeout(Cordova.JSCallbackPolling, Cordova.JSCallbackPollingPeriod);
-    }
-};
-
-/**
- * Create a UUID
- *
- * @return {String}
- */
-Cordova.createUUID = function() {
-    return Cordova.UUIDcreatePart(4) + '-' +
-        Cordova.UUIDcreatePart(2) + '-' +
-        Cordova.UUIDcreatePart(2) + '-' +
-        Cordova.UUIDcreatePart(2) + '-' +
-        Cordova.UUIDcreatePart(6);
-};
-
-Cordova.UUIDcreatePart = function(length) {
-    var uuidpart = "";
-    var i, uuidchar;
-    for (i=0; i<length; i++) {
-        uuidchar = parseInt((Math.random() * 256),0).toString(16);
-        if (uuidchar.length === 1) {
-            uuidchar = "0" + uuidchar;
-        }
-        uuidpart += uuidchar;
-    }
-    return uuidpart;
-};
-
-Cordova.close = function(context, func, params) {
-    if (typeof params === 'undefined') {
-        return function() {
-            return func.apply(context, arguments);
-        };
-    } else {
-        return function() {
-            return func.apply(context, params);
-        };
-    }
-};
-
-/**
- * Load a JavaScript file after page has loaded.
- *
- * @param {String} jsfile               The url of the JavaScript file to load.
- * @param {Function} successCallback    The callback to call when the file has been loaded.
- */
-Cordova.includeJavascript = function(jsfile, successCallback) {
-    var id = document.getElementsByTagName("head")[0];
-    var el = document.createElement('script');
-    el.type = 'text/javascript';
-    if (typeof successCallback === 'function') {
-        el.onload = successCallback;
-    }
-    el.src = jsfile;
-    id.appendChild(el);
-};
-
-/** 
- * Legacy variable for old plugins.
- */
-var PhoneGap = Cordova;
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("device")) {
-Cordova.addResource("device");
-
-/**
- * This represents the mobile device, and provides properties for inspecting the model, version, UUID of the
- * phone, etc.
- * @constructor
- */
-var Device = function() {
-    this.available = Cordova.available;
-    this.platform = null;
-    this.version = null;
-    this.name = null;
-    this.uuid = null;
-    this.cordova = null;
-
-    var me = this;
-    this.getInfo(
-        function(info) {
-            me.available = true;
-            me.platform = info.platform;
-            me.version = info.version;
-            me.name = info.name;
-            me.uuid = info.uuid;
-            me.cordova = info.cordova;
-            Cordova.onCordovaInfoReady.fire();
-        },
-        function(e) {
-            me.available = false;
-            console.log("Error initializing Cordova: " + e);
-            alert("Error initializing Cordova: "+e);
-        });
-};
-
-/**
- * Get device info
- *
- * @param {Function} successCallback The function to call when the heading data is available
- * @param {Function} errorCallback The function to call when there is an error getting the heading data. (OPTIONAL)
- */
-Device.prototype.getInfo = function(successCallback, errorCallback) {
-
-    // successCallback required
-    if (typeof successCallback !== "function") {
-        console.log("Device Error: successCallback is not a function");
-        return;
-    }
-
-    // errorCallback optional
-    if (errorCallback && (typeof errorCallback !== "function")) {
-        console.log("Device Error: errorCallback is not a function");
-        return;
-    }
-
-    // Get info
-    Cordova.exec(successCallback, errorCallback, "Device", "getDeviceInfo", []);
-};
-
-Cordova.addConstructor(function() {
-    if (typeof navigator.device === "undefined") {
-        navigator.device = window.device = new Device();
-    }
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("accelerometer")) {
-Cordova.addResource("accelerometer");
-
-/** @constructor */
-var Acceleration = function(x, y, z) {
-  this.x = x;
-  this.y = y;
-  this.z = z;
-  this.timestamp = new Date().getTime();
-};
-
-/**
- * This class provides access to device accelerometer data.
- * @constructor
- */
-var Accelerometer = function() {
-
-    /**
-     * The last known acceleration.  type=Acceleration()
-     */
-    this.lastAcceleration = null;
-
-    /**
-     * List of accelerometer watch timers
-     */
-    this.timers = {};
-};
-
-Accelerometer.ERROR_MSG = ["Not running", "Starting", "", "Failed to start"];
-
-/**
- * Asynchronously aquires the current acceleration.
- *
- * @param {Function} successCallback    The function to call when the acceleration data is available
- * @param {Function} errorCallback      The function to call when there is an error getting the acceleration data. (OPTIONAL)
- * @param {AccelerationOptions} options The options for getting the accelerometer data such as timeout. (OPTIONAL)
- */
-Accelerometer.prototype.getCurrentAcceleration = function(successCallback, errorCallback, options) {
-
-    // successCallback required
-    if (typeof successCallback !== "function") {
-        console.log("Accelerometer Error: successCallback is not a function");
-        return;
-    }
-
-    // errorCallback optional
-    if (errorCallback && (typeof errorCallback !== "function")) {
-        console.log("Accelerometer Error: errorCallback is not a function");
-        return;
-    }
-
-    // Get acceleration
-    Cordova.exec(successCallback, errorCallback, "Accelerometer", "getAcceleration", []);
-};
-
-/**
- * Asynchronously aquires the acceleration repeatedly at a given interval.
- *
- * @param {Function} successCallback    The function to call each time the acceleration data is available
- * @param {Function} errorCallback      The function to call when there is an error getting the acceleration data. (OPTIONAL)
- * @param {AccelerationOptions} options The options for getting the accelerometer data such as timeout. (OPTIONAL)
- * @return String                       The watch id that must be passed to #clearWatch to stop watching.
- */
-Accelerometer.prototype.watchAcceleration = function(successCallback, errorCallback, options) {
-
-    // Default interval (10 sec)
-    var frequency = (options !== undefined)? options.frequency : 10000;
-
-    // successCallback required
-    if (typeof successCallback !== "function") {
-        console.log("Accelerometer Error: successCallback is not a function");
-        return;
-    }
-
-    // errorCallback optional
-    if (errorCallback && (typeof errorCallback !== "function")) {
-        console.log("Accelerometer Error: errorCallback is not a function");
-        return;
-    }
-
-    // Make sure accelerometer timeout > frequency + 10 sec
-    Cordova.exec(
-        function(timeout) {
-            if (timeout < (frequency + 10000)) {
-                Cordova.exec(null, null, "Accelerometer", "setTimeout", [frequency + 10000]);
-            }
-        },
-        function(e) { }, "Accelerometer", "getTimeout", []);
-
-    // Start watch timer
-    var id = Cordova.createUUID();
-    navigator.accelerometer.timers[id] = setInterval(function() {
-        Cordova.exec(successCallback, errorCallback, "Accelerometer", "getAcceleration", []);
-    }, (frequency ? frequency : 1));
-
-    return id;
-};
-
-/**
- * Clears the specified accelerometer watch.
- *
- * @param {String} id       The id of the watch returned from #watchAcceleration.
- */
-Accelerometer.prototype.clearWatch = function(id) {
-
-    // Stop javascript timer & remove from timer list
-    if (id && navigator.accelerometer.timers[id] !== undefined) {
-        clearInterval(navigator.accelerometer.timers[id]);
-        delete navigator.accelerometer.timers[id];
-    }
-};
-
-Cordova.addConstructor(function() {
-    if (typeof navigator.accelerometer === "undefined") {
-        navigator.accelerometer = new Accelerometer();
-    }
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("app")) {
-Cordova.addResource("app");
-(function() {
-
-/**
- * Constructor
- * @constructor
- */
-var App = function() {};
-
-/**
- * Clear the resource cache.
- */
-App.prototype.clearCache = function() {
-    Cordova.exec(null, null, "App", "clearCache", []);
-};
-
-/**
- * Load the url into the webview or into new browser instance.
- *
- * @param url           The URL to load
- * @param props         Properties that can be passed in to the activity:
- *      wait: int                           => wait msec before loading URL
- *      loadingDialog: "Title,Message"      => display a native loading dialog
- *      loadUrlTimeoutValue: int            => time in msec to wait before triggering a timeout error
- *      clearHistory: boolean              => clear webview history (default=false)
- *      openExternal: boolean              => open in a new browser (default=false)
- *
- * Example:
- *      navigator.app.loadUrl("http://server/myapp/index.html", {wait:2000, loadingDialog:"Wait,Loading App", loadUrlTimeoutValue: 60000});
- */
-App.prototype.loadUrl = function(url, props) {
-    Cordova.exec(null, null, "App", "loadUrl", [url, props]);
-};
-
-/**
- * Cancel loadUrl that is waiting to be loaded.
- */
-App.prototype.cancelLoadUrl = function() {
-    Cordova.exec(null, null, "App", "cancelLoadUrl", []);
-};
-
-/**
- * Clear web history in this web view.
- * Instead of BACK button loading the previous web page, it will exit the app.
- */
-App.prototype.clearHistory = function() {
-    Cordova.exec(null, null, "App", "clearHistory", []);
-};
-
-/**
- * Go to previous page displayed.
- * This is the same as pressing the backbutton on Android device.
- */
-App.prototype.backHistory = function() {
-    Cordova.exec(null, null, "App", "backHistory", []);
-};
-
-/**
- * Exit and terminate the application.
- */
-App.prototype.exitApp = function() {
-	return Cordova.exec(null, null, "App", "exitApp", []);
-};
-
-Cordova.addConstructor(function() {
-    navigator.app = new App();
-});
-}());
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("battery")) {
-Cordova.addResource("battery");
-
-/**
- * This class contains information about the current battery status.
- * @constructor
- */
-var Battery = function() {
-    this._level = null;
-    this._isPlugged = null;
-    this._batteryListener = [];
-    this._lowListener = [];
-    this._criticalListener = [];
-};
-
-/**
- * Registers as an event producer for battery events.
- * 
- * @param {Object} eventType
- * @param {Object} handler
- * @param {Object} add
- */
-Battery.prototype.eventHandler = function(eventType, handler, add) {
-    var me = navigator.battery;
-    if (add) {
-        // If there are no current registered event listeners start the battery listener on native side.
-        if (me._batteryListener.length === 0 && me._lowListener.length === 0 && me._criticalListener.length === 0) {
-            Cordova.exec(me._status, me._error, "Battery", "start", []);
-        }
-        
-        // Register the event listener in the proper array
-        if (eventType === "batterystatus") {
-            if (me._batteryListener.indexOf(handler) === -1) {
-                me._batteryListener.push(handler);
-            }
-        } else if (eventType === "batterylow") {
-            if (me._lowListener.indexOf(handler) === -1) {
-                me._lowListener.push(handler);
-            }
-        } else if (eventType === "batterycritical") {
-            if (me._criticalListener.indexOf(handler) === -1) {
-                me._criticalListener.push(handler);
-            }
-        }
-    } else {
-        var pos = -1;
-        // Remove the event listener from the proper array
-        if (eventType === "batterystatus") {
-            pos = me._batteryListener.indexOf(handler);
-            if (pos > -1) {
-                me._batteryListener.splice(pos, 1);        
-            }
-        } else if (eventType === "batterylow") {
-            pos = me._lowListener.indexOf(handler);
-            if (pos > -1) {
-                me._lowListener.splice(pos, 1);        
-            }
-        } else if (eventType === "batterycritical") {
-            pos = me._criticalListener.indexOf(handler);
-            if (pos > -1) {
-                me._criticalListener.splice(pos, 1);        
-            }
-        }
-        
-        // If there are no more registered event listeners stop the battery listener on native side.
-        if (me._batteryListener.length === 0 && me._lowListener.length === 0 && me._criticalListener.length === 0) {
-            Cordova.exec(null, null, "Battery", "stop", []);
-        }
-    }
-};
-
-/**
- * Callback for battery status
- * 
- * @param {Object} info			keys: level, isPlugged
- */
-Battery.prototype._status = function(info) {
-	if (info) {
-		var me = this;
-        var level = info.level;
-		if (me._level !== level || me._isPlugged !== info.isPlugged) {
-			// Fire batterystatus event
-			Cordova.fireWindowEvent("batterystatus", info);
-
-			// Fire low battery event
-			if (level === 20 || level === 5) {
-				if (level === 20) {
-					Cordova.fireWindowEvent("batterylow", info);
-				}
-				else {
-					Cordova.fireWindowEvent("batterycritical", info);
-				}
-			}
-		}
-		me._level = level;
-		me._isPlugged = info.isPlugged;	
-	}
-};
-
-/**
- * Error callback for battery start
- */
-Battery.prototype._error = function(e) {
-    console.log("Error initializing Battery: " + e);
-};
-
-Cordova.addConstructor(function() {
-    if (typeof navigator.battery === "undefined") {
-        navigator.battery = new Battery();
-        Cordova.addWindowEventHandler("batterystatus", navigator.battery.eventHandler);
-        Cordova.addWindowEventHandler("batterylow", navigator.battery.eventHandler);
-        Cordova.addWindowEventHandler("batterycritical", navigator.battery.eventHandler);
-    }
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("camera")) {
-Cordova.addResource("camera");
-
-/**
- * This class provides access to the device camera.
- *
- * @constructor
- */
-var Camera = function() {
-    this.successCallback = null;
-    this.errorCallback = null;
-    this.options = null;
-};
-
-/**
- * Format of image that returned from getPicture.
- *
- * Example: navigator.camera.getPicture(success, fail,
- *              { quality: 80,
- *                destinationType: Camera.DestinationType.DATA_URL,
- *                sourceType: Camera.PictureSourceType.PHOTOLIBRARY})
- */
-Camera.DestinationType = {
-    DATA_URL: 0,                // Return base64 encoded string
-    FILE_URI: 1                 // Return file uri (content://media/external/images/media/2 for Android)
-};
-Camera.prototype.DestinationType = Camera.DestinationType;
-
-/**
- * Encoding of image returned from getPicture.
- *
- * Example: navigator.camera.getPicture(success, fail,
- *              { quality: 80,
- *                destinationType: Camera.DestinationType.DATA_URL,
- *                sourceType: Camera.PictureSourceType.CAMERA,
- *                encodingType: Camera.EncodingType.PNG})
-*/
-Camera.EncodingType = {
-    JPEG: 0,                    // Return JPEG encoded image
-    PNG: 1                      // Return PNG encoded image
-};
-Camera.prototype.EncodingType = Camera.EncodingType;
-
-/**
- * Type of pictures to select from.  Only applicable when
- *      PictureSourceType is PHOTOLIBRARY or SAVEDPHOTOALBUM
- *
- * Example: navigator.camera.getPicture(success, fail,
- *              { quality: 80,
- *                destinationType: Camera.DestinationType.DATA_URL,
- *                sourceType: Camera.PictureSourceType.PHOTOLIBRARY,
- *                mediaType: Camera.MediaType.PICTURE})
- */
-Camera.MediaType = {
-       PICTURE: 0,      // allow selection of still pictures only. DEFAULT. Will return format specified via DestinationType
-       VIDEO: 1,        // allow selection of video only, ONLY RETURNS URL
-       ALLMEDIA : 2     // allow selection from all media types
-};
-Camera.prototype.MediaType = Camera.MediaType;
-
-
-/**
- * Source to getPicture from.
- *
- * Example: navigator.camera.getPicture(success, fail,
- *              { quality: 80,
- *                destinationType: Camera.DestinationType.DATA_URL,
- *                sourceType: Camera.PictureSourceType.PHOTOLIBRARY})
- */
-Camera.PictureSourceType = {
-    PHOTOLIBRARY : 0,           // Choose image from picture library (same as SAVEDPHOTOALBUM for Android)
-    CAMERA : 1,                 // Take picture from camera
-    SAVEDPHOTOALBUM : 2         // Choose image from picture library (same as PHOTOLIBRARY for Android)
-};
-Camera.prototype.PictureSourceType = Camera.PictureSourceType;
-
-/**
- * Gets a picture from source defined by "options.sourceType", and returns the
- * image as defined by the "options.destinationType" option.
-
- * The defaults are sourceType=CAMERA and destinationType=DATA_URL.
- *
- * @param {Function} successCallback
- * @param {Function} errorCallback
- * @param {Object} options
- */
-Camera.prototype.getPicture = function(successCallback, errorCallback, options) {
-
-    // successCallback required
-    if (typeof successCallback !== "function") {
-        console.log("Camera Error: successCallback is not a function");
-        return;
-    }
-
-    // errorCallback optional
-    if (errorCallback && (typeof errorCallback !== "function")) {
-        console.log("Camera Error: errorCallback is not a function");
-        return;
-    }
-    
-    if (options === null || typeof options === "undefined") {
-        options = {};
-    }
-    if (options.quality === null || typeof options.quality === "undefined") {
-        options.quality = 80;
-    }
-    if (options.maxResolution === null || typeof options.maxResolution === "undefined") {
-        options.maxResolution = 0;
-    }
-    if (options.destinationType === null || typeof options.destinationType === "undefined") {
-        options.destinationType = Camera.DestinationType.FILE_URI;
-    }
-    if (options.sourceType === null || typeof options.sourceType === "undefined") {
-        options.sourceType = Camera.PictureSourceType.CAMERA;
-    }
-    if (options.encodingType === null || typeof options.encodingType === "undefined") {
-        options.encodingType = Camera.EncodingType.JPEG;
-    }
-    if (options.mediaType === null || typeof options.mediaType === "undefined") {
-        options.mediaType = Camera.MediaType.PICTURE;
-    }
-    if (options.targetWidth === null || typeof options.targetWidth === "undefined") {
-        options.targetWidth = -1;
-    } 
-    else if (typeof options.targetWidth === "string") {
-        var width = new Number(options.targetWidth);
-        if (isNaN(width) === false) {
-            options.targetWidth = width.valueOf();
-        }
-    }
-    if (options.targetHeight === null || typeof options.targetHeight === "undefined") {
-        options.targetHeight = -1;
-    } 
-    else if (typeof options.targetHeight === "string") {
-        var height = new Number(options.targetHeight);
-        if (isNaN(height) === false) {
-            options.targetHeight = height.valueOf();
-        }
-    }
-    
-    Cordova.exec(successCallback, errorCallback, "Camera", "takePicture", [options]);
-};
-
-Cordova.addConstructor(function() {
-    if (typeof navigator.camera === "undefined") {
-        navigator.camera = new Camera();
-    }
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("capture")) {
-Cordova.addResource("capture");
-	
-/**
- * Represents a single file.
- *
- * name {DOMString} name of the file, without path information
- * fullPath {DOMString} the full path of the file, including the name
- * type {DOMString} mime type
- * lastModifiedDate {Date} last modified date
- * size {Number} size of the file in bytes
- */
-var MediaFile = function(name, fullPath, type, lastModifiedDate, size){
-	this.name = name || null;
-	this.fullPath = fullPath || null;
-	this.type = type || null;
-	this.lastModifiedDate = lastModifiedDate || null;
-	this.size = size || 0;
-};
-
-/**
- * Launch device camera application for recording video(s).
- *
- * @param {Function} successCB
- * @param {Function} errorCB
- */
-MediaFile.prototype.getFormatData = function(successCallback, errorCallback){
-	Cordova.exec(successCallback, errorCallback, "Capture", "getFormatData", [this.fullPath, this.type]);
-};
-
-/**
- * MediaFileData encapsulates format information of a media file.
- *
- * @param {DOMString} codecs
- * @param {long} bitrate
- * @param {long} height
- * @param {long} width
- * @param {float} duration
- */
-var MediaFileData = function(codecs, bitrate, height, width, duration){
-	this.codecs = codecs || null;
-	this.bitrate = bitrate || 0;
-	this.height = height || 0;
-	this.width = width || 0;
-	this.duration = duration || 0;
-};
-
-/**
- * The CaptureError interface encapsulates all errors in the Capture API.
- */
-var CaptureError = function(){
-	this.code = null;
-};
-
-// Capture error codes
-CaptureError.CAPTURE_INTERNAL_ERR = 0;
-CaptureError.CAPTURE_APPLICATION_BUSY = 1;
-CaptureError.CAPTURE_INVALID_ARGUMENT = 2;
-CaptureError.CAPTURE_NO_MEDIA_FILES = 3;
-CaptureError.CAPTURE_NOT_SUPPORTED = 20;
-
-/**
- * The Capture interface exposes an interface to the camera and microphone of the hosting device.
- */
-var Capture = function(){
-	this.supportedAudioModes = [];
-	this.supportedImageModes = [];
-	this.supportedVideoModes = [];
-};
-
-/**
- * Launch audio recorder application for recording audio clip(s).
- *
- * @param {Function} successCB
- * @param {Function} errorCB
- * @param {CaptureAudioOptions} options
- */
-Capture.prototype.captureAudio = function(successCallback, errorCallback, options){
-	Cordova.exec(successCallback, errorCallback, "Capture", "captureAudio", [options]);
-};
-
-/**
- * Launch camera application for taking image(s).
- *
- * @param {Function} successCB
- * @param {Function} errorCB
- * @param {CaptureImageOptions} options
- */
-Capture.prototype.captureImage = function(successCallback, errorCallback, options){
-	Cordova.exec(successCallback, errorCallback, "Capture", "captureImage", [options]);
-};
-
-/**
- * Launch camera application for taking image(s).
- *
- * @param {Function} successCB
- * @param {Function} errorCB
- * @param {CaptureImageOptions} options
- */
-Capture.prototype._castMediaFile = function(pluginResult){
-	var mediaFiles = [];
-	var i;
-	for (i = 0; i < pluginResult.message.length; i++) {
-		var mediaFile = new MediaFile();
-		mediaFile.name = pluginResult.message[i].name;
-		mediaFile.fullPath = pluginResult.message[i].fullPath;
-		mediaFile.type = pluginResult.message[i].type;
-		mediaFile.lastModifiedDate = pluginResult.message[i].lastModifiedDate;
-		mediaFile.size = pluginResult.message[i].size;
-		mediaFiles.push(mediaFile);
-	}
-	pluginResult.message = mediaFiles;
-	return pluginResult;
-};
-
-/**
- * Launch device camera application for recording video(s).
- *
- * @param {Function} successCB
- * @param {Function} errorCB
- * @param {CaptureVideoOptions} options
- */
-Capture.prototype.captureVideo = function(successCallback, errorCallback, options){
-	Cordova.exec(successCallback, errorCallback, "Capture", "captureVideo", [options]);
-};
-
-/**
- * Encapsulates a set of parameters that the capture device supports.
- */
-var ConfigurationData = function(){
-	// The ASCII-encoded string in lower case representing the media type. 
-	this.type = null;
-	// The height attribute represents height of the image or video in pixels. 
-	// In the case of a sound clip this attribute has value 0. 
-	this.height = 0;
-	// The width attribute represents width of the image or video in pixels. 
-	// In the case of a sound clip this attribute has value 0
-	this.width = 0;
-};
-
-/**
- * Encapsulates all image capture operation configuration options.
- */
-var CaptureImageOptions = function(){
-	// Upper limit of images user can take. Value must be equal or greater than 1.
-	this.limit = 1;
-	// The selected image mode. Must match with one of the elements in supportedImageModes array.
-	this.mode = null;
-};
-
-/**
- * Encapsulates all video capture operation configuration options.
- */
-var CaptureVideoOptions = function(){
-	// Upper limit of videos user can record. Value must be equal or greater than 1.
-	this.limit = 1;
-	// Maximum duration of a single video clip in seconds.
-	this.duration = 0;
-	// The selected video mode. Must match with one of the elements in supportedVideoModes array.
-	this.mode = null;
-};
-
-/**
- * Encapsulates all audio capture operation configuration options.
- */
-var CaptureAudioOptions = function(){
-	// Upper limit of sound clips user can record. Value must be equal or greater than 1.
-	this.limit = 1;
-	// Maximum duration of a single sound clip in seconds.
-	this.duration = 0;
-	// The selected audio mode. Must match with one of the elements in supportedAudioModes array.
-	this.mode = null;
-};
-
-Cordova.addConstructor(function(){
-	if (typeof navigator.device.capture === "undefined") {
-		navigator.device.capture = window.device.capture = new Capture();
-	}
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("compass")) {
-Cordova.addResource("compass");
-
-var CompassError = function(){
-    this.code = null;
-};
-
-// Capture error codes
-CompassError.COMPASS_INTERNAL_ERR = 0;
-CompassError.COMPASS_NOT_SUPPORTED = 20;
-
-var CompassHeading = function() {
-    this.magneticHeading = null;
-    this.trueHeading = null;
-    this.headingAccuracy = null;
-    this.timestamp = null;
-};
-
-/**
- * This class provides access to device Compass data.
- * @constructor
- */
-var Compass = function() {
-    /**
-     * The last known Compass position.
-     */
-    this.lastHeading = null;
-
-    /**
-     * List of compass watch timers
-     */
-    this.timers = {};
-};
-
-Compass.ERROR_MSG = ["Not running", "Starting", "", "Failed to start"];
-
-/**
- * Asynchronously aquires the current heading.
- *
- * @param {Function} successCallback The function to call when the heading data is available
- * @param {Function} errorCallback The function to call when there is an error getting the heading data. (OPTIONAL)
- * @param {PositionOptions} options The options for getting the heading data such as timeout. (OPTIONAL)
- */
-Compass.prototype.getCurrentHeading = function(successCallback, errorCallback, options) {
-
-    // successCallback required
-    if (typeof successCallback !== "function") {
-        console.log("Compass Error: successCallback is not a function");
-        return;
-    }
-
-    // errorCallback optional
-    if (errorCallback && (typeof errorCallback !== "function")) {
-        console.log("Compass Error: errorCallback is not a function");
-        return;
-    }
-
-    // Get heading
-    Cordova.exec(successCallback, errorCallback, "Compass", "getHeading", []);
-};
-
-/**
- * Asynchronously aquires the heading repeatedly at a given interval.
- *
- * @param {Function} successCallback    The function to call each time the heading data is available
- * @param {Function} errorCallback      The function to call when there is an error getting the heading data. (OPTIONAL)
- * @param {HeadingOptions} options      The options for getting the heading data such as timeout and the frequency of the watch. (OPTIONAL)
- * @return String                       The watch id that must be passed to #clearWatch to stop watching.
- */
-Compass.prototype.watchHeading= function(successCallback, errorCallback, options) {
-
-    // Default interval (100 msec)
-    var frequency = (options !== undefined) ? options.frequency : 100;
-
-    // successCallback required
-    if (typeof successCallback !== "function") {
-        console.log("Compass Error: successCallback is not a function");
-        return;
-    }
-
-    // errorCallback optional
-    if (errorCallback && (typeof errorCallback !== "function")) {
-        console.log("Compass Error: errorCallback is not a function");
-        return;
-    }
-
-    // Make sure compass timeout > frequency + 10 sec
-    Cordova.exec(
-        function(timeout) {
-            if (timeout < (frequency + 10000)) {
-                Cordova.exec(null, null, "Compass", "setTimeout", [frequency + 10000]);
-            }
-        },
-        function(e) { }, "Compass", "getTimeout", []);
-
-    // Start watch timer to get headings
-    var id = Cordova.createUUID();
-    navigator.compass.timers[id] = setInterval(
-        function() {
-            Cordova.exec(successCallback, errorCallback, "Compass", "getHeading", []);
-        }, (frequency ? frequency : 1));
-
-    return id;
-};
-
-
-/**
- * Clears the specified heading watch.
- *
- * @param {String} id       The ID of the watch returned from #watchHeading.
- */
-Compass.prototype.clearWatch = function(id) {
-
-    // Stop javascript timer & remove from timer list
-    if (id && navigator.compass.timers[id]) {
-        clearInterval(navigator.compass.timers[id]);
-        delete navigator.compass.timers[id];
-    }
-};
-
-Compass.prototype._castDate = function(pluginResult) {
-    if (pluginResult.message.timestamp) {
-        var timestamp = new Date(pluginResult.message.timestamp);
-        pluginResult.message.timestamp = timestamp;
-    }
-    return pluginResult;
-};
-
-Cordova.addConstructor(function() {
-    if (typeof navigator.compass === "undefined") {
-        navigator.compass = new Compass();
-    }
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("contact")) {
-Cordova.addResource("contact");
-
-/**
-* Contains information about a single contact.
-* @constructor
-* @param {DOMString} id unique identifier
-* @param {DOMString} displayName
-* @param {ContactName} name
-* @param {DOMString} nickname
-* @param {Array.<ContactField>} phoneNumbers array of phone numbers
-* @param {Array.<ContactField>} emails array of email addresses
-* @param {Array.<ContactAddress>} addresses array of addresses
-* @param {Array.<ContactField>} ims instant messaging user ids
-* @param {Array.<ContactOrganization>} organizations
-* @param {DOMString} birthday contact's birthday
-* @param {DOMString} note user notes about contact
-* @param {Array.<ContactField>} photos
-* @param {Array.<ContactField>} categories
-* @param {Array.<ContactField>} urls contact's web sites
-*/
-var Contact = function (id, displayName, name, nickname, phoneNumbers, emails, addresses,
-    ims, organizations, birthday, note, photos, categories, urls) {
-    this.id = id || null;
-    this.rawId = null;
-    this.displayName = displayName || null;
-    this.name = name || null; // ContactName
-    this.nickname = nickname || null;
-    this.phoneNumbers = phoneNumbers || null; // ContactField[]
-    this.emails = emails || null; // ContactField[]
-    this.addresses = addresses || null; // ContactAddress[]
-    this.ims = ims || null; // ContactField[]
-    this.organizations = organizations || null; // ContactOrganization[]
-    this.birthday = birthday || null;
-    this.note = note || null;
-    this.photos = photos || null; // ContactField[]
-    this.categories = categories || null; // ContactField[]
-    this.urls = urls || null; // ContactField[]
-};
-
-/**
- *  ContactError.
- *  An error code assigned by an implementation when an error has occurreds
- * @constructor
- */
-var ContactError = function() {
-    this.code=null;
-};
-
-/**
- * Error codes
- */
-ContactError.UNKNOWN_ERROR = 0;
-ContactError.INVALID_ARGUMENT_ERROR = 1;
-ContactError.TIMEOUT_ERROR = 2;
-ContactError.PENDING_OPERATION_ERROR = 3;
-ContactError.IO_ERROR = 4;
-ContactError.NOT_SUPPORTED_ERROR = 5;
-ContactError.PERMISSION_DENIED_ERROR = 20;
-
-/**
-* Removes contact from device storage.
-* @param successCB success callback
-* @param errorCB error callback
-*/
-Contact.prototype.remove = function(successCB, errorCB) {
-    if (this.id === null) {
-        var errorObj = new ContactError();
-        errorObj.code = ContactError.UNKNOWN_ERROR;
-        errorCB(errorObj);
-    }
-    else {
-        Cordova.exec(successCB, errorCB, "Contacts", "remove", [this.id]);
-    }
-};
-
-/**
-* Creates a deep copy of this Contact.
-* With the contact ID set to null.
-* @return copy of this Contact
-*/
-Contact.prototype.clone = function() {
-    var clonedContact = Cordova.clone(this);
-    var i;
-    clonedContact.id = null;
-    clonedContact.rawId = null;
-    // Loop through and clear out any id's in phones, emails, etc.
-    if (clonedContact.phoneNumbers) {
-        for (i = 0; i < clonedContact.phoneNumbers.length; i++) {
-            clonedContact.phoneNumbers[i].id = null;
-        }
-    }
-    if (clonedContact.emails) {
-        for (i = 0; i < clonedContact.emails.length; i++) {
-            clonedContact.emails[i].id = null;
-        }
-    }
-    if (clonedContact.addresses) {
-        for (i = 0; i < clonedContact.addresses.length; i++) {
-            clonedContact.addresses[i].id = null;
-        }
-    }
-    if (clonedContact.ims) {
-        for (i = 0; i < clonedContact.ims.length; i++) {
-            clonedContact.ims[i].id = null;
-        }
-    }
-    if (clonedContact.organizations) {
-        for (i = 0; i < clonedContact.organizations.length; i++) {
-            clonedContact.organizations[i].id = null;
-        }
-    }
-    if (clonedContact.tags) {
-        for (i = 0; i < clonedContact.tags.length; i++) {
-            clonedContact.tags[i].id = null;
-        }
-    }
-    if (clonedContact.photos) {
-        for (i = 0; i < clonedContact.photos.length; i++) {
-            clonedContact.photos[i].id = null;
-        }
-    }
-    if (clonedContact.urls) {
-        for (i = 0; i < clonedContact.urls.length; i++) {
-            clonedContact.urls[i].id = null;
-        }
-    }
-    return clonedContact;
-};
-
-/**
-* Persists contact to device storage.
-* @param successCB success callback
-* @param errorCB error callback
-*/
-Contact.prototype.save = function(successCB, errorCB) {
-    Cordova.exec(successCB, errorCB, "Contacts", "save", [this]);
-};
-
-/**
-* Contact name.
-* @constructor
-* @param formatted
-* @param familyName
-* @param givenName
-* @param middle
-* @param prefix
-* @param suffix
-*/
-var ContactName = function(formatted, familyName, givenName, middle, prefix, suffix) {
-    this.formatted = formatted || null;
-    this.familyName = familyName || null;
-    this.givenName = givenName || null;
-    this.middleName = middle || null;
-    this.honorificPrefix = prefix || null;
-    this.honorificSuffix = suffix || null;
-};
-
-/**
-* Generic contact field.
-* @constructor
-* @param {DOMString} id unique identifier, should only be set by native code
-* @param type
-* @param value
-* @param pref
-*/
-var ContactField = function(type, value, pref) {
-	this.id = null;
-    this.type = type || null;
-    this.value = value || null;
-    this.pref = pref || null;
-};
-
-/**
-* Contact address.
-* @constructor
-* @param {DOMString} id unique identifier, should only be set by native code
-* @param formatted
-* @param streetAddress
-* @param locality
-* @param region
-* @param postalCode
-* @param country
-*/
-var ContactAddress = function(pref, type, formatted, streetAddress, locality, region, postalCode, country) {
-	this.id = null;
-    this.pref = pref || null;
-    this.type = type || null;
-    this.formatted = formatted || null;
-    this.streetAddress = streetAddress || null;
-    this.locality = locality || null;
-    this.region = region || null;
-    this.postalCode = postalCode || null;
-    this.country = country || null;
-};
-
-/**
-* Contact organization.
-* @constructor
-* @param {DOMString} id unique identifier, should only be set by native code
-* @param name
-* @param dept
-* @param title
-* @param startDate
-* @param endDate
-* @param location
-* @param desc
-*/
-var ContactOrganization = function(pref, type, name, dept, title) {
-	this.id = null;
-    this.pref = pref || null;
-    this.type = type || null;
-    this.name = name || null;
-    this.department = dept || null;
-    this.title = title || null;
-};
-
-/**
-* Represents a group of Contacts.
-* @constructor
-*/
-var Contacts = function() {
-    this.inProgress = false;
-    this.records = [];
-};
-/**
-* Returns an array of Contacts matching the search criteria.
-* @param fields that should be searched
-* @param successCB success callback
-* @param errorCB error callback
-* @param {ContactFindOptions} options that can be applied to contact searching
-* @return array of Contacts matching search criteria
-*/
-Contacts.prototype.find = function(fields, successCB, errorCB, options) {
-    if (successCB === null) {
-        throw new TypeError("You must specify a success callback for the find command.");
-    }
-    if (fields === null || fields === "undefined" || fields.length === "undefined" || fields.length <= 0) {
-        if (typeof errorCB === "function") {
-            errorCB({"code": ContactError.INVALID_ARGUMENT_ERROR});
-        }
-    } else {
-        Cordova.exec(successCB, errorCB, "Contacts", "search", [fields, options]);        
-    }
-};
-
-/**
-* This function creates a new contact, but it does not persist the contact
-* to device storage. To persist the contact to device storage, invoke
-* contact.save().
-* @param properties an object who's properties will be examined to create a new Contact
-* @returns new Contact object
-*/
-Contacts.prototype.create = function(properties) {
-    var i;
-	var contact = new Contact();
-    for (i in properties) {
-        if (contact[i] !== 'undefined') {
-            contact[i] = properties[i];
-        }
-    }
-    return contact;
-};
-
-/**
-* This function returns and array of contacts.  It is required as we need to convert raw
-* JSON objects into concrete Contact objects.  Currently this method is called after
-* navigator.contacts.find but before the find methods success call back.
-*
-* @param jsonArray an array of JSON Objects that need to be converted to Contact objects.
-* @returns an array of Contact objects
-*/
-Contacts.prototype.cast = function(pluginResult) {
-	var contacts = [];
-	var i;
-	for (i=0; i<pluginResult.message.length; i++) {
-		contacts.push(navigator.contacts.create(pluginResult.message[i]));
-	}
-	pluginResult.message = contacts;
-	return pluginResult;
-};
-
-/**
- * ContactFindOptions.
- * @constructor
- * @param filter used to match contacts against
- * @param multiple boolean used to determine if more than one contact should be returned
- */
-var ContactFindOptions = function(filter, multiple) {
-    this.filter = filter || '';
-    this.multiple = multiple || false;
-};
-
-/**
- * Add the contact interface into the browser.
- */
-Cordova.addConstructor(function() {
-    if(typeof navigator.contacts === "undefined") {
-        navigator.contacts = new Contacts();
-    }
-});
-}
-/*
- *     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.
- */
-
-// TODO: Needs to be commented
-
-if (!Cordova.hasResource("crypto")) {
-Cordova.addResource("crypto");
-
-/**
-* @constructor
-*/
-var Crypto = function() {
-};
-
-Crypto.prototype.encrypt = function(seed, string, callback) {
-    this.encryptWin = callback;
-    Cordova.exec(null, null, "Crypto", "encrypt", [seed, string]);
-};
-
-Crypto.prototype.decrypt = function(seed, string, callback) {
-    this.decryptWin = callback;
-    Cordova.exec(null, null, "Crypto", "decrypt", [seed, string]);
-};
-
-Crypto.prototype.gotCryptedString = function(string) {
-    this.encryptWin(string);
-};
-
-Crypto.prototype.getPlainString = function(string) {
-    this.decryptWin(string);
-};
-
-Cordova.addConstructor(function() {
-    if (typeof navigator.Crypto === "undefined") {
-        navigator.Crypto = new Crypto();
-    }
-});
-}
-/*
- *     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.
- */
-
-if (!Cordova.hasResource("file")) {
-Cordova.addResource("file");
-
-/**
- * This class provides some useful information about a file.
- * @constructor
- */
-var FileProperties = function(filePath) {
-    this.filePath = filePath;
-    this.size = 0;
-    this.lastModifiedDate = null;
-};
-
-/**
- * Represents a single file.
- *
- * @constructor
- * @param name {DOMString} name of the file, without path information
- * @param fullPath {DOMString} the full path of the file, including the name
- * @param type {DOMString} mime type
- * @param lastModifiedDate {Date} last modified date
- * @param size {Number} size of the file in bytes
- */
-var File = function(name, fullPath, type, lastModifiedDate, size) {
-    this.name = name || null;
-    this.fullPath = fullPath || null;
-    this.type = type || null;
-    this.lastModifiedDate = lastModifiedDate || null;
-    this.size = size || 0;
-};
-
-/** @constructor */
-var FileError = function() {
-   this.code = null;
-};
-
-// File error codes
-// Found in DOMException
-FileError.NOT_FOUND_ERR = 1;
-FileError.SECURITY_ERR = 2;
-FileError.ABORT_ERR = 3;
-
-// Added by this specification
-FileError.NOT_READABLE_ERR = 4;
-FileError.ENCODING_ERR = 5;
-FileError.NO_MODIFICATION_ALLOWED_ERR = 6;
-FileError.INVALID_STATE_ERR = 7;
-FileError.SYNTAX_ERR = 8;
-FileError.INVALID_MODIFICATION_ERR = 9;
-FileError.QUOTA_EXCEEDED_ERR = 10;
-FileError.TYPE_MISMATCH_ERR = 11;
-FileError.PATH_EXISTS_ERR = 12;
-
-//-----------------------------------------------------------------------------
-// File Reader
-//-----------------------------------------------------------------------------
-
-/**
- * This class reads the mobile device file system.
- *
- * For Android:
- *      The root directory is the root of the file system.
- *      To read from the SD card, the file name is "sdcard/my_file.txt"
- * @constructor
- */
-var FileReader = function() {
-    this.fileName = "";
-
-    this.readyState = 0;
-
-    // File data
-    this.result = null;
-
-    // Error
-    this.error = null;
-
-    // Event handlers
-    this.onloadstart = null;    // When the read starts.
-    this.onprogress = null;     // While reading (and decoding) file or fileBlob data, and reporting partial file data (progess.loaded/progress.total)
-    this.onload = null;         // When the read has successfully completed.
-    this.onerror = null;        // When the read has failed (see errors).
-    this.onloadend = null;      // When the request has completed (either in success or failure).
-    this.onabort = null;        // When the read has been aborted. For instance, by invoking the abort() method.
-};
-
-// States
-FileReader.EMPTY = 0;
-FileReader.LOADING = 1;
-FileReader.DONE = 2;
-
-/**
- * Abort reading file.
- */
-FileReader.prototype.abort = function() {
-    var evt;
-    this.readyState = FileReader.DONE;
-    this.result = null;
-
-    // set error
-    var error = new FileError();
-    error.code = error.ABORT_ERR;
-    this.error = error;
-
-    // If error callback
-    if (typeof this.onerror === "function") {
-        this.onerror({"type":"error", "target":this});
-    }
-    // If abort callback
-    if (typeof this.onabort === "function") {
-        this.onabort({"type":"abort", "target":this});
-    }
-    // If load end callback
-    if (typeof this.onloadend === "function") {
-        this.onloadend({"type":"loadend", "target":this});
-    }
-};
-
-/**
- * Read text file.
- *
- * @param file          {File} File object containing file properties
- * @param encoding      [Optional] (see http://www.iana.org/assignments/character-sets)
- */
-FileReader.prototype.readAsText = function(file, encoding) {
-    this.fileName = "";
-    if (typeof file.fullPath === "undefined") {
-        this.fileName = file;
-    } else {
-        this.fileName = file.fullPath;
-    }
-
-    // LOADING state
-    this.readyState = FileReader.LOADING;
-
-    // If loadstart callback
-    if (typeof this.onloadstart === "function") {
-        this.onloadstart({"type":"loadstart", "target":this});
-    }
-
-    // Default encoding is UTF-8
-    var enc = encoding ? encoding : "UTF-8";
-
-    var me = this;
-
-    // Read file
-    Cordova.exec(
-        // Success callback
-        function(r) {
-            var evt;
-
-            // If DONE (cancelled), then don't do anything
-            if (me.readyState === FileReader.DONE) {
-                return;
-            }
-
-            // Save result
-            me.result = r;
-
-            // If onload callback
-            if (typeof me.onload === "function") {
-                me.onload({"type":"load", "target":me});
-            }
-
-            // DONE state
-            me.readyState = FileReader.DONE;
-
-            // If onloadend callback
-            if (typeof me.onloadend === "function") {
-                me.onloadend({"type":"loadend", "target":me});
-            }
-        },
-        // Error callback
-        function(e) {
-            var evt;
-            // If DONE (cancelled), then don't do anything
-            if (me.readyState === FileReader.DONE) {
-                return;
-            }
-
-            // Save error
-            me.error = e;
-
-            // If onerror callback
-            if (typeof me.onerror === "function") {
-                me.onerror({"type":"error", "target":me});
-            }
-
-            // DONE state
-            me.readyState = FileReader.DONE;
-
-            // If onloadend callback
-            if (typeof me.onloadend === "function") {
-                me.onloadend({"type":"loadend", "target":me});
-            }
-        }, "File", "readAsText", [this.fileName, enc]);
-};
-
-
-/**
- * Read file and return data as a base64 encoded data url.
- * A data url is of the form:
- *      data:[<mediatype>][;base64],<data>
- *
- * @param file          {File} File object containing file properties
- */
-FileReader.prototype.readAsDataURL = function(file) {
-    this.fileName = "";
-    if (typeof file.fullPath === "undefined") {
-        this.fileName = file;
-    } else {
-        this.fileName = file.fullPath;
-    }
-
-    // LOADING state
-    this.readyState = FileReader.LOADING;
-
-    // If loadstart callback
-    if (typeof this.onloadstart === "function") {
-        this.onloadstart({"type":"loadstart", "target":this});
-    }
-
-    var me = this;
-
-    // Read file
-    Cordova.exec(
-        // Success callback
-        function(r) {
-            var evt;
-
-            // If DONE (cancelled), then don't do anything
-            if (me.readyState === FileReader.DONE) {
-                return;
-            }
-
-            // Save result
-            me.result = r;
-
-            // If onload callback
-            if (typeof me.onload === "function") {
-                me.onload({"type":"load", "target":me});
-            }
-
-            // DONE state
-            me.readyState = FileReader.DONE;
-
-            // If onloadend callback
-            if (typeof me.onloadend === "function") {
-                me.onloadend({"type":"loadend", "target":me});
-            }
-        },
-        // Error callback
-        function(e) {
-            var evt;
-            // If DONE (cancelled), then don't do anything
-            if (me.readyState === FileReader.DONE) {
-                return;
-            }
-
-            // Save error
-            me.error = e;
-
-            // If onerror callback
-            if (typeof me.onerror === "function") {
-                me.onerror({"type":"error", "target":me});
-            }
-
-            // DONE state
-            me.readyState = FileReader.DONE;
-
-            // If onloadend callback
-            if (typeof me.onloadend === "function") {
-                me.onloadend({"type":"loadend", "target":me});
-            }
-        }, "File", "readAsDataURL", [this.fileName]);
-};
-
-/**
- * Read file and return data as a binary data.
- *
- * @param file          {File} File object containing file properties
- */
-FileReader.prototype.readAsBinaryString = function(file) {
-    // TODO - Can't return binary data to browser.
-    this.fileName = file;
-};
-
-/**
- * Read file and return data as a binary data.
- *
- * @param file          {File} File object containing file properties
- */
-FileReader.prototype.readAsArrayBuffer = function(file) {
-    // TODO - Can't return binary data to browser.
-    this.fileName = file;
-};
-
-//-----------------------------------------------------------------------------
-// File Writer
-//-----------------------------------------------------------------------------
-
-/**
- * This class writes to the mobile device file system.
- *
- * For Android:
- *      The root directory is the root of the file system.
- *      To write to the SD card, the file name is "sdcard/my_file.txt"
- *
- * @constructor
- * @param file {File} File object containing file properties
- * @param append if true write to the end of the file, otherwise overwrite the file
- */
-var FileWriter = function(file) {
-    this.fileName = "";
-    this.length = 0;
-    if (file) {
-        this.fileName = file.fullPath || file;
-        this.length = file.size || 0;
-    }
-    // default is to write at the beginning of the file
-    this.position = 0;
-
-    this.readyState = 0; // EMPTY
-
-    this.result = null;
-
-    // Error
-    this.error = null;
-
-    // Event handlers
-    this.onwritestart = null;   // When writing starts
-    this.onprogress = null;     // While writing the file, and reporting partial file data
-    this.onwrite = null;        // When the write has successfully completed.
-    this.onwriteend = null;     // When the request has completed (either in success or failure).
-    this.onabort = null;        // When the write has been aborted. For instance, by invoking the abort() method.
-    this.onerror = null;        // When the write has failed (see errors).
-};
-
-// States
-FileWriter.INIT = 0;
-FileWriter.WRITING = 1;
-FileWriter.DONE = 2;
-
-/**
- * Abort writing file.
- */
-FileWriter.prototype.abort = function() {
-    // check for invalid state
-    if (this.readyState === FileWriter.DONE || this.readyState === FileWriter.INIT) {
-        throw FileError.INVALID_STATE_ERR;
-    }
-
-    // set error
-    var error = new FileError(), evt;
-    error.code = error.ABORT_ERR;
-    this.error = error;
-
-    // If error callback
-    if (typeof this.onerror === "function") {
-        this.onerror({"type":"error", "target":this});
-    }
-    // If abort callback
-    if (typeof this.onabort === "function") {
-        this.onabort({"type":"abort", "target":this});
-    }
-
-    this.readyState = FileWriter.DONE;
-
-    // If write end callback
-    if (typeof this.onwriteend === "function") {
-        this.onwriteend({"type":"writeend", "target":this});
-    }
-};
-
-/**
- * Writes data to the file
- *
- * @param text to be written
- */
-FileWriter.prototype.write = function(text) {
-    // Throw an exception if we are already writing a file
-    if (this.readyState === FileWriter.WRITING) {
-        throw FileError.INVALID_STATE_ERR;
-    }
-
-    // WRITING state
-    this.readyState = FileWriter.WRITING;
-
-    var me = this;
-
-    // If onwritestart callback
-    if (typeof me.onwritestart === "function") {
-        me.onwritestart({"type":"writestart", "target":me});
-    }
-
-    // Write file
-    Cordova.exec(
-        // Success callback
-        function(r) {
-            var evt;
-            // If DONE (cancelled), then don't do anything
-            if (me.readyState === FileWriter.DONE) {
-                return;
-            }
-
-            // position always increases by bytes written because file would be extended
-            me.position += r;
-            // The length of the file is now where we are done writing.
-            me.length = me.position;
-
-            // If onwrite callback
-            if (typeof me.onwrite === "function") {
-                me.onwrite({"type":"write", "target":me});
-            }
-
-            // DONE state
-            me.readyState = FileWriter.DONE;
-
-            // If onwriteend callback
-            if (typeof me.onwriteend === "function") {
-                me.onwriteend({"type":"writeend", "target":me});
-            }
-        },
-        // Error callback
-        function(e) {
-            var evt;
-
-            // If DONE (cancelled), then don't do anything
-            if (me.readyState === FileWriter.DONE) {
-                return;
-            }
-
-            // Save error
-            me.error = e;
-
-            // If onerror callback
-            if (typeof me.onerror === "function") {
-                me.onerror({"type":"error", "target":me});
-            }
-
-            // DONE state
-            me.readyState = FileWriter.DONE;
-
-            // If onwriteend callback
-            if (typeof me.onwriteend === "function") {
-                me.onwriteend({"type":"writeend", "target":me});
-            }
-        }, "File", "write", [this.fileName, text, this.position]);
-};
-
-/**
- * Moves the file pointer to the location specified.
- *
- * If the offset is a negative number the position of the file
- * pointer is rewound.  If the offset is greater than the file
- * size the position is set to the end of the file.
- *
- * @param offset is the location to move the file pointer to.
- */
-FileWriter.prototype.seek = function(offset) {
-    // Throw an exception if we are already writing a file
-    if (this.readyState === FileWriter.WRITING) {
-        throw FileError.INVALID_STATE_ERR;
-    }
-
-    if (!offset) {
-        return;
-    }
-
-    // See back from end of file.
-    if (offset < 0) {
-        this.position = Math.max(offset + this.length, 0);
-    }
-    // Offset is bigger then file size so set position
-    // to the end of the file.
-    else if (offset > this.length) {
-        this.position = this.length;
-    }
-    // Offset is between 0 and file size so set the posit

<TRUNCATED>