You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by al...@apache.org on 2014/12/11 21:26:30 UTC

[2/5] ambari git commit: AMBARI-8533. Views: Pig View Usability (alexantonenko)

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/qunit.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/qunit.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/qunit.js
new file mode 100644
index 0000000..dfe4294
--- /dev/null
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/qunit.js
@@ -0,0 +1,2495 @@
+/*!
+ * QUnit 1.15.0
+ * http://qunitjs.com/
+ *
+ * Copyright 2014 jQuery Foundation and other contributors
+ * Released under the MIT license
+ * http://jquery.org/license
+ *
+ * Date: 2014-08-08T16:00Z
+ */
+
+(function( window ) {
+
+var QUnit,
+  config,
+  onErrorFnPrev,
+  fileName = ( sourceFromStacktrace( 0 ) || "" ).replace( /(:\d+)+\)?/, "" ).replace( /.+\//, "" ),
+  toString = Object.prototype.toString,
+  hasOwn = Object.prototype.hasOwnProperty,
+  // Keep a local reference to Date (GH-283)
+  Date = window.Date,
+  now = Date.now || function() {
+    return new Date().getTime();
+  },
+  setTimeout = window.setTimeout,
+  clearTimeout = window.clearTimeout,
+  defined = {
+    document: typeof window.document !== "undefined",
+    setTimeout: typeof window.setTimeout !== "undefined",
+    sessionStorage: (function() {
+      var x = "qunit-test-string";
+      try {
+        sessionStorage.setItem( x, x );
+        sessionStorage.removeItem( x );
+        return true;
+      } catch ( e ) {
+        return false;
+      }
+    }())
+  },
+  /**
+   * Provides a normalized error string, correcting an issue
+   * with IE 7 (and prior) where Error.prototype.toString is
+   * not properly implemented
+   *
+   * Based on http://es5.github.com/#x15.11.4.4
+   *
+   * @param {String|Error} error
+   * @return {String} error message
+   */
+  errorString = function( error ) {
+    var name, message,
+      errorString = error.toString();
+    if ( errorString.substring( 0, 7 ) === "[object" ) {
+      name = error.name ? error.name.toString() : "Error";
+      message = error.message ? error.message.toString() : "";
+      if ( name && message ) {
+        return name + ": " + message;
+      } else if ( name ) {
+        return name;
+      } else if ( message ) {
+        return message;
+      } else {
+        return "Error";
+      }
+    } else {
+      return errorString;
+    }
+  },
+  /**
+   * Makes a clone of an object using only Array or Object as base,
+   * and copies over the own enumerable properties.
+   *
+   * @param {Object} obj
+   * @return {Object} New object with only the own properties (recursively).
+   */
+  objectValues = function( obj ) {
+    var key, val,
+      vals = QUnit.is( "array", obj ) ? [] : {};
+    for ( key in obj ) {
+      if ( hasOwn.call( obj, key ) ) {
+        val = obj[ key ];
+        vals[ key ] = val === Object( val ) ? objectValues( val ) : val;
+      }
+    }
+    return vals;
+  };
+
+// Root QUnit object.
+// `QUnit` initialized at top of scope
+QUnit = {
+
+  // call on start of module test to prepend name to all tests
+  module: function( name, testEnvironment ) {
+    config.currentModule = name;
+    config.currentModuleTestEnvironment = testEnvironment;
+    config.modules[ name ] = true;
+  },
+
+  asyncTest: function( testName, expected, callback ) {
+    if ( arguments.length === 2 ) {
+      callback = expected;
+      expected = null;
+    }
+
+    QUnit.test( testName, expected, callback, true );
+  },
+
+  test: function( testName, expected, callback, async ) {
+    var test;
+
+    if ( arguments.length === 2 ) {
+      callback = expected;
+      expected = null;
+    }
+
+    test = new Test({
+      testName: testName,
+      expected: expected,
+      async: async,
+      callback: callback,
+      module: config.currentModule,
+      moduleTestEnvironment: config.currentModuleTestEnvironment,
+      stack: sourceFromStacktrace( 2 )
+    });
+
+    if ( !validTest( test ) ) {
+      return;
+    }
+
+    test.queue();
+  },
+
+  start: function( count ) {
+    var message;
+
+    // QUnit hasn't been initialized yet.
+    // Note: RequireJS (et al) may delay onLoad
+    if ( config.semaphore === undefined ) {
+      QUnit.begin(function() {
+        // This is triggered at the top of QUnit.load, push start() to the event loop, to allow QUnit.load to finish first
+        setTimeout(function() {
+          QUnit.start( count );
+        });
+      });
+      return;
+    }
+
+    config.semaphore -= count || 1;
+    // don't start until equal number of stop-calls
+    if ( config.semaphore > 0 ) {
+      return;
+    }
+
+    // Set the starting time when the first test is run
+    QUnit.config.started = QUnit.config.started || now();
+    // ignore if start is called more often then stop
+    if ( config.semaphore < 0 ) {
+      config.semaphore = 0;
+
+      message = "Called start() while already started (QUnit.config.semaphore was 0 already)";
+
+      if ( config.current ) {
+        QUnit.pushFailure( message, sourceFromStacktrace( 2 ) );
+      } else {
+        throw new Error( message );
+      }
+
+      return;
+    }
+    // A slight delay, to avoid any current callbacks
+    if ( defined.setTimeout ) {
+      setTimeout(function() {
+        if ( config.semaphore > 0 ) {
+          return;
+        }
+        if ( config.timeout ) {
+          clearTimeout( config.timeout );
+        }
+
+        config.blocking = false;
+        process( true );
+      }, 13 );
+    } else {
+      config.blocking = false;
+      process( true );
+    }
+  },
+
+  stop: function( count ) {
+    config.semaphore += count || 1;
+    config.blocking = true;
+
+    if ( config.testTimeout && defined.setTimeout ) {
+      clearTimeout( config.timeout );
+      config.timeout = setTimeout(function() {
+        QUnit.ok( false, "Test timed out" );
+        config.semaphore = 1;
+        QUnit.start();
+      }, config.testTimeout );
+    }
+  }
+};
+
+// We use the prototype to distinguish between properties that should
+// be exposed as globals (and in exports) and those that shouldn't
+(function() {
+  function F() {}
+  F.prototype = QUnit;
+  QUnit = new F();
+
+  // Make F QUnit's constructor so that we can add to the prototype later
+  QUnit.constructor = F;
+}());
+
+/**
+ * Config object: Maintain internal state
+ * Later exposed as QUnit.config
+ * `config` initialized at top of scope
+ */
+config = {
+  // The queue of tests to run
+  queue: [],
+
+  // block until document ready
+  blocking: true,
+
+  // when enabled, show only failing tests
+  // gets persisted through sessionStorage and can be changed in UI via checkbox
+  hidepassed: false,
+
+  // by default, run previously failed tests first
+  // very useful in combination with "Hide passed tests" checked
+  reorder: true,
+
+  // by default, modify document.title when suite is done
+  altertitle: true,
+
+  // by default, scroll to top of the page when suite is done
+  scrolltop: true,
+
+  // when enabled, all tests must call expect()
+  requireExpects: false,
+
+  // add checkboxes that are persisted in the query-string
+  // when enabled, the id is set to `true` as a `QUnit.config` property
+  urlConfig: [
+    {
+      id: "noglobals",
+      label: "Check for Globals",
+      tooltip: "Enabling this will test if any test introduces new properties on the `window` object. Stored as query-strings."
+    },
+    {
+      id: "notrycatch",
+      label: "No try-catch",
+      tooltip: "Enabling this will run tests outside of a try-catch block. Makes debugging exceptions in IE reasonable. Stored as query-strings."
+    }
+  ],
+
+  // Set of all modules.
+  modules: {},
+
+  callbacks: {}
+};
+
+// Initialize more QUnit.config and QUnit.urlParams
+(function() {
+  var i, current,
+    location = window.location || { search: "", protocol: "file:" },
+    params = location.search.slice( 1 ).split( "&" ),
+    length = params.length,
+    urlParams = {};
+
+  if ( params[ 0 ] ) {
+    for ( i = 0; i < length; i++ ) {
+      current = params[ i ].split( "=" );
+      current[ 0 ] = decodeURIComponent( current[ 0 ] );
+
+      // allow just a key to turn on a flag, e.g., test.html?noglobals
+      current[ 1 ] = current[ 1 ] ? decodeURIComponent( current[ 1 ] ) : true;
+      if ( urlParams[ current[ 0 ] ] ) {
+        urlParams[ current[ 0 ] ] = [].concat( urlParams[ current[ 0 ] ], current[ 1 ] );
+      } else {
+        urlParams[ current[ 0 ] ] = current[ 1 ];
+      }
+    }
+  }
+
+  QUnit.urlParams = urlParams;
+
+  // String search anywhere in moduleName+testName
+  config.filter = urlParams.filter;
+
+  // Exact match of the module name
+  config.module = urlParams.module;
+
+  config.testNumber = [];
+  if ( urlParams.testNumber ) {
+
+    // Ensure that urlParams.testNumber is an array
+    urlParams.testNumber = [].concat( urlParams.testNumber );
+    for ( i = 0; i < urlParams.testNumber.length; i++ ) {
+      current = urlParams.testNumber[ i ];
+      config.testNumber.push( parseInt( current, 10 ) );
+    }
+  }
+
+  // Figure out if we're running the tests from a server or not
+  QUnit.isLocal = location.protocol === "file:";
+}());
+
+extend( QUnit, {
+
+  config: config,
+
+  // Safe object type checking
+  is: function( type, obj ) {
+    return QUnit.objectType( obj ) === type;
+  },
+
+  objectType: function( obj ) {
+    if ( typeof obj === "undefined" ) {
+      return "undefined";
+    }
+
+    // Consider: typeof null === object
+    if ( obj === null ) {
+      return "null";
+    }
+
+    var match = toString.call( obj ).match( /^\[object\s(.*)\]$/ ),
+      type = match && match[ 1 ] || "";
+
+    switch ( type ) {
+      case "Number":
+        if ( isNaN( obj ) ) {
+          return "nan";
+        }
+        return "number";
+      case "String":
+      case "Boolean":
+      case "Array":
+      case "Date":
+      case "RegExp":
+      case "Function":
+        return type.toLowerCase();
+    }
+    if ( typeof obj === "object" ) {
+      return "object";
+    }
+    return undefined;
+  },
+
+  url: function( params ) {
+    params = extend( extend( {}, QUnit.urlParams ), params );
+    var key,
+      querystring = "?";
+
+    for ( key in params ) {
+      if ( hasOwn.call( params, key ) ) {
+        querystring += encodeURIComponent( key ) + "=" +
+          encodeURIComponent( params[ key ] ) + "&";
+      }
+    }
+    return window.location.protocol + "//" + window.location.host +
+      window.location.pathname + querystring.slice( 0, -1 );
+  },
+
+  extend: extend
+});
+
+/**
+ * @deprecated: Created for backwards compatibility with test runner that set the hook function
+ * into QUnit.{hook}, instead of invoking it and passing the hook function.
+ * QUnit.constructor is set to the empty F() above so that we can add to it's prototype here.
+ * Doing this allows us to tell if the following methods have been overwritten on the actual
+ * QUnit object.
+ */
+extend( QUnit.constructor.prototype, {
+
+  // Logging callbacks; all receive a single argument with the listed properties
+  // run test/logs.html for any related changes
+  begin: registerLoggingCallback( "begin" ),
+
+  // done: { failed, passed, total, runtime }
+  done: registerLoggingCallback( "done" ),
+
+  // log: { result, actual, expected, message }
+  log: registerLoggingCallback( "log" ),
+
+  // testStart: { name }
+  testStart: registerLoggingCallback( "testStart" ),
+
+  // testDone: { name, failed, passed, total, runtime }
+  testDone: registerLoggingCallback( "testDone" ),
+
+  // moduleStart: { name }
+  moduleStart: registerLoggingCallback( "moduleStart" ),
+
+  // moduleDone: { name, failed, passed, total }
+  moduleDone: registerLoggingCallback( "moduleDone" )
+});
+
+QUnit.load = function() {
+  runLoggingCallbacks( "begin", {
+    totalTests: Test.count
+  });
+
+  // Initialize the configuration options
+  extend( config, {
+    stats: { all: 0, bad: 0 },
+    moduleStats: { all: 0, bad: 0 },
+    started: 0,
+    updateRate: 1000,
+    autostart: true,
+    filter: "",
+    semaphore: 1
+  }, true );
+
+  config.blocking = false;
+
+  if ( config.autostart ) {
+    QUnit.start();
+  }
+};
+
+// `onErrorFnPrev` initialized at top of scope
+// Preserve other handlers
+onErrorFnPrev = window.onerror;
+
+// Cover uncaught exceptions
+// Returning true will suppress the default browser handler,
+// returning false will let it run.
+window.onerror = function( error, filePath, linerNr ) {
+  var ret = false;
+  if ( onErrorFnPrev ) {
+    ret = onErrorFnPrev( error, filePath, linerNr );
+  }
+
+  // Treat return value as window.onerror itself does,
+  // Only do our handling if not suppressed.
+  if ( ret !== true ) {
+    if ( QUnit.config.current ) {
+      if ( QUnit.config.current.ignoreGlobalErrors ) {
+        return true;
+      }
+      QUnit.pushFailure( error, filePath + ":" + linerNr );
+    } else {
+      QUnit.test( "global failure", extend(function() {
+        QUnit.pushFailure( error, filePath + ":" + linerNr );
+      }, { validTest: validTest } ) );
+    }
+    return false;
+  }
+
+  return ret;
+};
+
+function done() {
+  config.autorun = true;
+
+  // Log the last module results
+  if ( config.previousModule ) {
+    runLoggingCallbacks( "moduleDone", {
+      name: config.previousModule,
+      failed: config.moduleStats.bad,
+      passed: config.moduleStats.all - config.moduleStats.bad,
+      total: config.moduleStats.all
+    });
+  }
+  delete config.previousModule;
+
+  var runtime = now() - config.started,
+    passed = config.stats.all - config.stats.bad;
+
+  runLoggingCallbacks( "done", {
+    failed: config.stats.bad,
+    passed: passed,
+    total: config.stats.all,
+    runtime: runtime
+  });
+}
+
+/** @return Boolean: true if this test should be ran */
+function validTest( test ) {
+  var include,
+    filter = config.filter && config.filter.toLowerCase(),
+    module = config.module && config.module.toLowerCase(),
+    fullName = ( test.module + ": " + test.testName ).toLowerCase();
+
+  // Internally-generated tests are always valid
+  if ( test.callback && test.callback.validTest === validTest ) {
+    delete test.callback.validTest;
+    return true;
+  }
+
+  if ( config.testNumber.length > 0 ) {
+    if ( inArray( test.testNumber, config.testNumber ) < 0 ) {
+      return false;
+    }
+  }
+
+  if ( module && ( !test.module || test.module.toLowerCase() !== module ) ) {
+    return false;
+  }
+
+  if ( !filter ) {
+    return true;
+  }
+
+  include = filter.charAt( 0 ) !== "!";
+  if ( !include ) {
+    filter = filter.slice( 1 );
+  }
+
+  // If the filter matches, we need to honour include
+  if ( fullName.indexOf( filter ) !== -1 ) {
+    return include;
+  }
+
+  // Otherwise, do the opposite
+  return !include;
+}
+
+// Doesn't support IE6 to IE9
+// See also https://developer.mozilla.org/en/JavaScript/Reference/Global_Objects/Error/Stack
+function extractStacktrace( e, offset ) {
+  offset = offset === undefined ? 4 : offset;
+
+  var stack, include, i;
+
+  if ( e.stacktrace ) {
+
+    // Opera 12.x
+    return e.stacktrace.split( "\n" )[ offset + 3 ];
+  } else if ( e.stack ) {
+
+    // Firefox, Chrome, Safari 6+, IE10+, PhantomJS and Node
+    stack = e.stack.split( "\n" );
+    if ( /^error$/i.test( stack[ 0 ] ) ) {
+      stack.shift();
+    }
+    if ( fileName ) {
+      include = [];
+      for ( i = offset; i < stack.length; i++ ) {
+        if ( stack[ i ].indexOf( fileName ) !== -1 ) {
+          break;
+        }
+        include.push( stack[ i ] );
+      }
+      if ( include.length ) {
+        return include.join( "\n" );
+      }
+    }
+    return stack[ offset ];
+  } else if ( e.sourceURL ) {
+
+    // Safari < 6
+    // exclude useless self-reference for generated Error objects
+    if ( /qunit.js$/.test( e.sourceURL ) ) {
+      return;
+    }
+
+    // for actual exceptions, this is useful
+    return e.sourceURL + ":" + e.line;
+  }
+}
+function sourceFromStacktrace( offset ) {
+  try {
+    throw new Error();
+  } catch ( e ) {
+    return extractStacktrace( e, offset );
+  }
+}
+
+function synchronize( callback, last ) {
+  config.queue.push( callback );
+
+  if ( config.autorun && !config.blocking ) {
+    process( last );
+  }
+}
+
+function process( last ) {
+  function next() {
+    process( last );
+  }
+  var start = now();
+  config.depth = config.depth ? config.depth + 1 : 1;
+
+  while ( config.queue.length && !config.blocking ) {
+    if ( !defined.setTimeout || config.updateRate <= 0 || ( ( now() - start ) < config.updateRate ) ) {
+      config.queue.shift()();
+    } else {
+      setTimeout( next, 13 );
+      break;
+    }
+  }
+  config.depth--;
+  if ( last && !config.blocking && !config.queue.length && config.depth === 0 ) {
+    done();
+  }
+}
+
+function saveGlobal() {
+  config.pollution = [];
+
+  if ( config.noglobals ) {
+    for ( var key in window ) {
+      if ( hasOwn.call( window, key ) ) {
+        // in Opera sometimes DOM element ids show up here, ignore them
+        if ( /^qunit-test-output/.test( key ) ) {
+          continue;
+        }
+        config.pollution.push( key );
+      }
+    }
+  }
+}
+
+function checkPollution() {
+  var newGlobals,
+    deletedGlobals,
+    old = config.pollution;
+
+  saveGlobal();
+
+  newGlobals = diff( config.pollution, old );
+  if ( newGlobals.length > 0 ) {
+    QUnit.pushFailure( "Introduced global variable(s): " + newGlobals.join( ", " ) );
+  }
+
+  deletedGlobals = diff( old, config.pollution );
+  if ( deletedGlobals.length > 0 ) {
+    QUnit.pushFailure( "Deleted global variable(s): " + deletedGlobals.join( ", " ) );
+  }
+}
+
+// returns a new Array with the elements that are in a but not in b
+function diff( a, b ) {
+  var i, j,
+    result = a.slice();
+
+  for ( i = 0; i < result.length; i++ ) {
+    for ( j = 0; j < b.length; j++ ) {
+      if ( result[ i ] === b[ j ] ) {
+        result.splice( i, 1 );
+        i--;
+        break;
+      }
+    }
+  }
+  return result;
+}
+
+function extend( a, b, undefOnly ) {
+  for ( var prop in b ) {
+    if ( hasOwn.call( b, prop ) ) {
+
+      // Avoid "Member not found" error in IE8 caused by messing with window.constructor
+      if ( !( prop === "constructor" && a === window ) ) {
+        if ( b[ prop ] === undefined ) {
+          delete a[ prop ];
+        } else if ( !( undefOnly && typeof a[ prop ] !== "undefined" ) ) {
+          a[ prop ] = b[ prop ];
+        }
+      }
+    }
+  }
+
+  return a;
+}
+
+function registerLoggingCallback( key ) {
+
+  // Initialize key collection of logging callback
+  if ( QUnit.objectType( config.callbacks[ key ] ) === "undefined" ) {
+    config.callbacks[ key ] = [];
+  }
+
+  return function( callback ) {
+    config.callbacks[ key ].push( callback );
+  };
+}
+
+function runLoggingCallbacks( key, args ) {
+  var i, l, callbacks;
+
+  callbacks = config.callbacks[ key ];
+  for ( i = 0, l = callbacks.length; i < l; i++ ) {
+    callbacks[ i ]( args );
+  }
+}
+
+// from jquery.js
+function inArray( elem, array ) {
+  if ( array.indexOf ) {
+    return array.indexOf( elem );
+  }
+
+  for ( var i = 0, length = array.length; i < length; i++ ) {
+    if ( array[ i ] === elem ) {
+      return i;
+    }
+  }
+
+  return -1;
+}
+
+function Test( settings ) {
+  extend( this, settings );
+  this.assert = new Assert( this );
+  this.assertions = [];
+  this.testNumber = ++Test.count;
+}
+
+Test.count = 0;
+
+Test.prototype = {
+  setup: function() {
+    if (
+
+      // Emit moduleStart when we're switching from one module to another
+      this.module !== config.previousModule ||
+
+        // They could be equal (both undefined) but if the previousModule property doesn't
+        // yet exist it means this is the first test in a suite that isn't wrapped in a
+        // module, in which case we'll just emit a moduleStart event for 'undefined'.
+        // Without this, reporters can get testStart before moduleStart  which is a problem.
+        !hasOwn.call( config, "previousModule" )
+    ) {
+      if ( hasOwn.call( config, "previousModule" ) ) {
+        runLoggingCallbacks( "moduleDone", {
+          name: config.previousModule,
+          failed: config.moduleStats.bad,
+          passed: config.moduleStats.all - config.moduleStats.bad,
+          total: config.moduleStats.all
+        });
+      }
+      config.previousModule = this.module;
+      config.moduleStats = { all: 0, bad: 0 };
+      runLoggingCallbacks( "moduleStart", {
+        name: this.module
+      });
+    }
+
+    config.current = this;
+
+    this.testEnvironment = extend({
+      setup: function() {},
+      teardown: function() {}
+    }, this.moduleTestEnvironment );
+
+    this.started = now();
+    runLoggingCallbacks( "testStart", {
+      name: this.testName,
+      module: this.module,
+      testNumber: this.testNumber
+    });
+
+    if ( !config.pollution ) {
+      saveGlobal();
+    }
+    if ( config.notrycatch ) {
+      this.testEnvironment.setup.call( this.testEnvironment, this.assert );
+      return;
+    }
+    try {
+      this.testEnvironment.setup.call( this.testEnvironment, this.assert );
+    } catch ( e ) {
+      this.pushFailure( "Setup failed on " + this.testName + ": " + ( e.message || e ), extractStacktrace( e, 0 ) );
+    }
+  },
+  run: function() {
+    config.current = this;
+
+    if ( this.async ) {
+      QUnit.stop();
+    }
+
+    this.callbackStarted = now();
+
+    if ( config.notrycatch ) {
+      this.callback.call( this.testEnvironment, this.assert );
+      this.callbackRuntime = now() - this.callbackStarted;
+      return;
+    }
+
+    try {
+      this.callback.call( this.testEnvironment, this.assert );
+      this.callbackRuntime = now() - this.callbackStarted;
+    } catch ( e ) {
+      this.callbackRuntime = now() - this.callbackStarted;
+
+      this.pushFailure( "Died on test #" + ( this.assertions.length + 1 ) + " " + this.stack + ": " + ( e.message || e ), extractStacktrace( e, 0 ) );
+
+      // else next test will carry the responsibility
+      saveGlobal();
+
+      // Restart the tests if they're blocking
+      if ( config.blocking ) {
+        QUnit.start();
+      }
+    }
+  },
+  teardown: function() {
+    config.current = this;
+    if ( config.notrycatch ) {
+      if ( typeof this.callbackRuntime === "undefined" ) {
+        this.callbackRuntime = now() - this.callbackStarted;
+      }
+      this.testEnvironment.teardown.call( this.testEnvironment, this.assert );
+      return;
+    } else {
+      try {
+        this.testEnvironment.teardown.call( this.testEnvironment, this.assert );
+      } catch ( e ) {
+        this.pushFailure( "Teardown failed on " + this.testName + ": " + ( e.message || e ), extractStacktrace( e, 0 ) );
+      }
+    }
+    checkPollution();
+  },
+  finish: function() {
+    config.current = this;
+    if ( config.requireExpects && this.expected === null ) {
+      this.pushFailure( "Expected number of assertions to be defined, but expect() was not called.", this.stack );
+    } else if ( this.expected !== null && this.expected !== this.assertions.length ) {
+      this.pushFailure( "Expected " + this.expected + " assertions, but " + this.assertions.length + " were run", this.stack );
+    } else if ( this.expected === null && !this.assertions.length ) {
+      this.pushFailure( "Expected at least one assertion, but none were run - call expect(0) to accept zero assertions.", this.stack );
+    }
+
+    var i,
+      bad = 0;
+
+    this.runtime = now() - this.started;
+    config.stats.all += this.assertions.length;
+    config.moduleStats.all += this.assertions.length;
+
+    for ( i = 0; i < this.assertions.length; i++ ) {
+      if ( !this.assertions[ i ].result ) {
+        bad++;
+        config.stats.bad++;
+        config.moduleStats.bad++;
+      }
+    }
+
+    runLoggingCallbacks( "testDone", {
+      name: this.testName,
+      module: this.module,
+      failed: bad,
+      passed: this.assertions.length - bad,
+      total: this.assertions.length,
+      runtime: this.runtime,
+
+      // HTML Reporter use
+      assertions: this.assertions,
+      testNumber: this.testNumber,
+
+      // DEPRECATED: this property will be removed in 2.0.0, use runtime instead
+      duration: this.runtime
+    });
+
+    config.current = undefined;
+  },
+
+  queue: function() {
+    var bad,
+      test = this;
+
+    function run() {
+      // each of these can by async
+      synchronize(function() {
+        test.setup();
+      });
+      synchronize(function() {
+        test.run();
+      });
+      synchronize(function() {
+        test.teardown();
+      });
+      synchronize(function() {
+        test.finish();
+      });
+    }
+
+    // `bad` initialized at top of scope
+    // defer when previous test run passed, if storage is available
+    bad = QUnit.config.reorder && defined.sessionStorage &&
+        +sessionStorage.getItem( "qunit-test-" + this.module + "-" + this.testName );
+
+    if ( bad ) {
+      run();
+    } else {
+      synchronize( run, true );
+    }
+  },
+
+  push: function( result, actual, expected, message ) {
+    var source,
+      details = {
+        module: this.module,
+        name: this.testName,
+        result: result,
+        message: message,
+        actual: actual,
+        expected: expected,
+        testNumber: this.testNumber
+      };
+
+    if ( !result ) {
+      source = sourceFromStacktrace();
+
+      if ( source ) {
+        details.source = source;
+      }
+    }
+
+    runLoggingCallbacks( "log", details );
+
+    this.assertions.push({
+      result: !!result,
+      message: message
+    });
+  },
+
+  pushFailure: function( message, source, actual ) {
+    if ( !this instanceof Test ) {
+      throw new Error( "pushFailure() assertion outside test context, was " + sourceFromStacktrace( 2 ) );
+    }
+
+    var details = {
+        module: this.module,
+        name: this.testName,
+        result: false,
+        message: message || "error",
+        actual: actual || null,
+        testNumber: this.testNumber
+      };
+
+    if ( source ) {
+      details.source = source;
+    }
+
+    runLoggingCallbacks( "log", details );
+
+    this.assertions.push({
+      result: false,
+      message: message
+    });
+  }
+};
+
+QUnit.pushFailure = function() {
+  if ( !QUnit.config.current ) {
+    throw new Error( "pushFailure() assertion outside test context, in " + sourceFromStacktrace( 2 ) );
+  }
+
+  // Gets current test obj
+  var currentTest = QUnit.config.current.assert.test;
+
+  return currentTest.pushFailure.apply( currentTest, arguments );
+};
+
+function Assert( testContext ) {
+  this.test = testContext;
+}
+
+// Assert helpers
+QUnit.assert = Assert.prototype = {
+
+  // Specify the number of expected assertions to guarantee that failed test (no assertions are run at all) don't slip through.
+  expect: function( asserts ) {
+    if ( arguments.length === 1 ) {
+      this.test.expected = asserts;
+    } else {
+      return this.test.expected;
+    }
+  },
+
+  // Exports test.push() to the user API
+  push: function() {
+    var assert = this;
+
+    // Backwards compatibility fix.
+    // Allows the direct use of global exported assertions and QUnit.assert.*
+    // Although, it's use is not recommended as it can leak assertions
+    // to other tests from async tests, because we only get a reference to the current test,
+    // not exactly the test where assertion were intended to be called.
+    if ( !QUnit.config.current ) {
+      throw new Error( "assertion outside test context, in " + sourceFromStacktrace( 2 ) );
+    }
+    if ( !( assert instanceof Assert ) ) {
+      assert = QUnit.config.current.assert;
+    }
+    return assert.test.push.apply( assert.test, arguments );
+  },
+
+  /**
+   * Asserts rough true-ish result.
+   * @name ok
+   * @function
+   * @example ok( "asdfasdf".length > 5, "There must be at least 5 chars" );
+   */
+  ok: function( result, message ) {
+    message = message || ( result ? "okay" : "failed, expected argument to be truthy, was: " +
+      QUnit.dump.parse( result ) );
+    if ( !!result ) {
+      this.push( true, result, true, message );
+    } else {
+      this.test.pushFailure( message, null, result );
+    }
+  },
+
+  /**
+   * Assert that the first two arguments are equal, with an optional message.
+   * Prints out both actual and expected values.
+   * @name equal
+   * @function
+   * @example equal( format( "Received {0} bytes.", 2), "Received 2 bytes.", "format() replaces {0} with next argument" );
+   */
+  equal: function( actual, expected, message ) {
+    /*jshint eqeqeq:false */
+    this.push( expected == actual, actual, expected, message );
+  },
+
+  /**
+   * @name notEqual
+   * @function
+   */
+  notEqual: function( actual, expected, message ) {
+    /*jshint eqeqeq:false */
+    this.push( expected != actual, actual, expected, message );
+  },
+
+  /**
+   * @name propEqual
+   * @function
+   */
+  propEqual: function( actual, expected, message ) {
+    actual = objectValues( actual );
+    expected = objectValues( expected );
+    this.push( QUnit.equiv( actual, expected ), actual, expected, message );
+  },
+
+  /**
+   * @name notPropEqual
+   * @function
+   */
+  notPropEqual: function( actual, expected, message ) {
+    actual = objectValues( actual );
+    expected = objectValues( expected );
+    this.push( !QUnit.equiv( actual, expected ), actual, expected, message );
+  },
+
+  /**
+   * @name deepEqual
+   * @function
+   */
+  deepEqual: function( actual, expected, message ) {
+    this.push( QUnit.equiv( actual, expected ), actual, expected, message );
+  },
+
+  /**
+   * @name notDeepEqual
+   * @function
+   */
+  notDeepEqual: function( actual, expected, message ) {
+    this.push( !QUnit.equiv( actual, expected ), actual, expected, message );
+  },
+
+  /**
+   * @name strictEqual
+   * @function
+   */
+  strictEqual: function( actual, expected, message ) {
+    this.push( expected === actual, actual, expected, message );
+  },
+
+  /**
+   * @name notStrictEqual
+   * @function
+   */
+  notStrictEqual: function( actual, expected, message ) {
+    this.push( expected !== actual, actual, expected, message );
+  },
+
+  "throws": function( block, expected, message ) {
+    var actual, expectedType,
+      expectedOutput = expected,
+      ok = false;
+
+    // 'expected' is optional unless doing string comparison
+    if ( message == null && typeof expected === "string" ) {
+      message = expected;
+      expected = null;
+    }
+
+    this.test.ignoreGlobalErrors = true;
+    try {
+      block.call( this.test.testEnvironment );
+    } catch (e) {
+      actual = e;
+    }
+    this.test.ignoreGlobalErrors = false;
+
+    if ( actual ) {
+      expectedType = QUnit.objectType( expected );
+
+      // we don't want to validate thrown error
+      if ( !expected ) {
+        ok = true;
+        expectedOutput = null;
+
+      // expected is a regexp
+      } else if ( expectedType === "regexp" ) {
+        ok = expected.test( errorString( actual ) );
+
+      // expected is a string
+      } else if ( expectedType === "string" ) {
+        ok = expected === errorString( actual );
+
+      // expected is a constructor, maybe an Error constructor
+      } else if ( expectedType === "function" && actual instanceof expected ) {
+        ok = true;
+
+      // expected is an Error object
+      } else if ( expectedType === "object" ) {
+        ok = actual instanceof expected.constructor &&
+          actual.name === expected.name &&
+          actual.message === expected.message;
+
+      // expected is a validation function which returns true if validation passed
+      } else if ( expectedType === "function" && expected.call( {}, actual ) === true ) {
+        expectedOutput = null;
+        ok = true;
+      }
+
+      this.push( ok, actual, expectedOutput, message );
+    } else {
+      this.test.pushFailure( message, null, "No exception was thrown." );
+    }
+  }
+};
+
+// Test for equality any JavaScript type.
+// Author: Philippe Rathé <pr...@gmail.com>
+QUnit.equiv = (function() {
+
+  // Call the o related callback with the given arguments.
+  function bindCallbacks( o, callbacks, args ) {
+    var prop = QUnit.objectType( o );
+    if ( prop ) {
+      if ( QUnit.objectType( callbacks[ prop ] ) === "function" ) {
+        return callbacks[ prop ].apply( callbacks, args );
+      } else {
+        return callbacks[ prop ]; // or undefined
+      }
+    }
+  }
+
+  // the real equiv function
+  var innerEquiv,
+
+    // stack to decide between skip/abort functions
+    callers = [],
+
+    // stack to avoiding loops from circular referencing
+    parents = [],
+    parentsB = [],
+
+    getProto = Object.getPrototypeOf || function( obj ) {
+      /* jshint camelcase: false, proto: true */
+      return obj.__proto__;
+    },
+    callbacks = (function() {
+
+      // for string, boolean, number and null
+      function useStrictEquality( b, a ) {
+
+        /*jshint eqeqeq:false */
+        if ( b instanceof a.constructor || a instanceof b.constructor ) {
+
+          // to catch short annotation VS 'new' annotation of a
+          // declaration
+          // e.g. var i = 1;
+          // var j = new Number(1);
+          return a == b;
+        } else {
+          return a === b;
+        }
+      }
+
+      return {
+        "string": useStrictEquality,
+        "boolean": useStrictEquality,
+        "number": useStrictEquality,
+        "null": useStrictEquality,
+        "undefined": useStrictEquality,
+
+        "nan": function( b ) {
+          return isNaN( b );
+        },
+
+        "date": function( b, a ) {
+          return QUnit.objectType( b ) === "date" && a.valueOf() === b.valueOf();
+        },
+
+        "regexp": function( b, a ) {
+          return QUnit.objectType( b ) === "regexp" &&
+
+            // the regex itself
+            a.source === b.source &&
+
+            // and its modifiers
+            a.global === b.global &&
+
+            // (gmi) ...
+            a.ignoreCase === b.ignoreCase &&
+            a.multiline === b.multiline &&
+            a.sticky === b.sticky;
+        },
+
+        // - skip when the property is a method of an instance (OOP)
+        // - abort otherwise,
+        // initial === would have catch identical references anyway
+        "function": function() {
+          var caller = callers[ callers.length - 1 ];
+          return caller !== Object && typeof caller !== "undefined";
+        },
+
+        "array": function( b, a ) {
+          var i, j, len, loop, aCircular, bCircular;
+
+          // b could be an object literal here
+          if ( QUnit.objectType( b ) !== "array" ) {
+            return false;
+          }
+
+          len = a.length;
+          if ( len !== b.length ) {
+            // safe and faster
+            return false;
+          }
+
+          // track reference to avoid circular references
+          parents.push( a );
+          parentsB.push( b );
+          for ( i = 0; i < len; i++ ) {
+            loop = false;
+            for ( j = 0; j < parents.length; j++ ) {
+              aCircular = parents[ j ] === a[ i ];
+              bCircular = parentsB[ j ] === b[ i ];
+              if ( aCircular || bCircular ) {
+                if ( a[ i ] === b[ i ] || aCircular && bCircular ) {
+                  loop = true;
+                } else {
+                  parents.pop();
+                  parentsB.pop();
+                  return false;
+                }
+              }
+            }
+            if ( !loop && !innerEquiv( a[ i ], b[ i ] ) ) {
+              parents.pop();
+              parentsB.pop();
+              return false;
+            }
+          }
+          parents.pop();
+          parentsB.pop();
+          return true;
+        },
+
+        "object": function( b, a ) {
+
+          /*jshint forin:false */
+          var i, j, loop, aCircular, bCircular,
+            // Default to true
+            eq = true,
+            aProperties = [],
+            bProperties = [];
+
+          // comparing constructors is more strict than using
+          // instanceof
+          if ( a.constructor !== b.constructor ) {
+
+            // Allow objects with no prototype to be equivalent to
+            // objects with Object as their constructor.
+            if ( !( ( getProto( a ) === null && getProto( b ) === Object.prototype ) ||
+              ( getProto( b ) === null && getProto( a ) === Object.prototype ) ) ) {
+              return false;
+            }
+          }
+
+          // stack constructor before traversing properties
+          callers.push( a.constructor );
+
+          // track reference to avoid circular references
+          parents.push( a );
+          parentsB.push( b );
+
+          // be strict: don't ensure hasOwnProperty and go deep
+          for ( i in a ) {
+            loop = false;
+            for ( j = 0; j < parents.length; j++ ) {
+              aCircular = parents[ j ] === a[ i ];
+              bCircular = parentsB[ j ] === b[ i ];
+              if ( aCircular || bCircular ) {
+                if ( a[ i ] === b[ i ] || aCircular && bCircular ) {
+                  loop = true;
+                } else {
+                  eq = false;
+                  break;
+                }
+              }
+            }
+            aProperties.push( i );
+            if ( !loop && !innerEquiv( a[ i ], b[ i ] ) ) {
+              eq = false;
+              break;
+            }
+          }
+
+          parents.pop();
+          parentsB.pop();
+          callers.pop(); // unstack, we are done
+
+          for ( i in b ) {
+            bProperties.push( i ); // collect b's properties
+          }
+
+          // Ensures identical properties name
+          return eq && innerEquiv( aProperties.sort(), bProperties.sort() );
+        }
+      };
+    }());
+
+  innerEquiv = function() { // can take multiple arguments
+    var args = [].slice.apply( arguments );
+    if ( args.length < 2 ) {
+      return true; // end transition
+    }
+
+    return ( (function( a, b ) {
+      if ( a === b ) {
+        return true; // catch the most you can
+      } else if ( a === null || b === null || typeof a === "undefined" ||
+          typeof b === "undefined" ||
+          QUnit.objectType( a ) !== QUnit.objectType( b ) ) {
+
+        // don't lose time with error prone cases
+        return false;
+      } else {
+        return bindCallbacks( a, callbacks, [ b, a ] );
+      }
+
+      // apply transition with (1..n) arguments
+    }( args[ 0 ], args[ 1 ] ) ) && innerEquiv.apply( this, args.splice( 1, args.length - 1 ) ) );
+  };
+
+  return innerEquiv;
+}());
+
+// Based on jsDump by Ariel Flesler
+// http://flesler.blogspot.com/2008/05/jsdump-pretty-dump-of-any-javascript.html
+QUnit.dump = (function() {
+  function quote( str ) {
+    return "\"" + str.toString().replace( /"/g, "\\\"" ) + "\"";
+  }
+  function literal( o ) {
+    return o + "";
+  }
+  function join( pre, arr, post ) {
+    var s = dump.separator(),
+      base = dump.indent(),
+      inner = dump.indent( 1 );
+    if ( arr.join ) {
+      arr = arr.join( "," + s + inner );
+    }
+    if ( !arr ) {
+      return pre + post;
+    }
+    return [ pre, inner + arr, base + post ].join( s );
+  }
+  function array( arr, stack ) {
+    var i = arr.length,
+      ret = new Array( i );
+    this.up();
+    while ( i-- ) {
+      ret[ i ] = this.parse( arr[ i ], undefined, stack );
+    }
+    this.down();
+    return join( "[", ret, "]" );
+  }
+
+  var reName = /^function (\w+)/,
+    dump = {
+      // type is used mostly internally, you can fix a (custom)type in advance
+      parse: function( obj, type, stack ) {
+        stack = stack || [];
+        var inStack, res,
+          parser = this.parsers[ type || this.typeOf( obj ) ];
+
+        type = typeof parser;
+        inStack = inArray( obj, stack );
+
+        if ( inStack !== -1 ) {
+          return "recursion(" + ( inStack - stack.length ) + ")";
+        }
+        if ( type === "function" ) {
+          stack.push( obj );
+          res = parser.call( this, obj, stack );
+          stack.pop();
+          return res;
+        }
+        return ( type === "string" ) ? parser : this.parsers.error;
+      },
+      typeOf: function( obj ) {
+        var type;
+        if ( obj === null ) {
+          type = "null";
+        } else if ( typeof obj === "undefined" ) {
+          type = "undefined";
+        } else if ( QUnit.is( "regexp", obj ) ) {
+          type = "regexp";
+        } else if ( QUnit.is( "date", obj ) ) {
+          type = "date";
+        } else if ( QUnit.is( "function", obj ) ) {
+          type = "function";
+        } else if ( typeof obj.setInterval !== undefined && typeof obj.document !== "undefined" && typeof obj.nodeType === "undefined" ) {
+          type = "window";
+        } else if ( obj.nodeType === 9 ) {
+          type = "document";
+        } else if ( obj.nodeType ) {
+          type = "node";
+        } else if (
+
+          // native arrays
+          toString.call( obj ) === "[object Array]" ||
+
+          // NodeList objects
+          ( typeof obj.length === "number" && typeof obj.item !== "undefined" && ( obj.length ? obj.item( 0 ) === obj[ 0 ] : ( obj.item( 0 ) === null && typeof obj[ 0 ] === "undefined" ) ) )
+        ) {
+          type = "array";
+        } else if ( obj.constructor === Error.prototype.constructor ) {
+          type = "error";
+        } else {
+          type = typeof obj;
+        }
+        return type;
+      },
+      separator: function() {
+        return this.multiline ? this.HTML ? "<br />" : "\n" : this.HTML ? "&nbsp;" : " ";
+      },
+      // extra can be a number, shortcut for increasing-calling-decreasing
+      indent: function( extra ) {
+        if ( !this.multiline ) {
+          return "";
+        }
+        var chr = this.indentChar;
+        if ( this.HTML ) {
+          chr = chr.replace( /\t/g, "   " ).replace( / /g, "&nbsp;" );
+        }
+        return new Array( this.depth + ( extra || 0 ) ).join( chr );
+      },
+      up: function( a ) {
+        this.depth += a || 1;
+      },
+      down: function( a ) {
+        this.depth -= a || 1;
+      },
+      setParser: function( name, parser ) {
+        this.parsers[ name ] = parser;
+      },
+      // The next 3 are exposed so you can use them
+      quote: quote,
+      literal: literal,
+      join: join,
+      //
+      depth: 1,
+      // This is the list of parsers, to modify them, use dump.setParser
+      parsers: {
+        window: "[Window]",
+        document: "[Document]",
+        error: function( error ) {
+          return "Error(\"" + error.message + "\")";
+        },
+        unknown: "[Unknown]",
+        "null": "null",
+        "undefined": "undefined",
+        "function": function( fn ) {
+          var ret = "function",
+            // functions never have name in IE
+            name = "name" in fn ? fn.name : ( reName.exec( fn ) || [] )[ 1 ];
+
+          if ( name ) {
+            ret += " " + name;
+          }
+          ret += "( ";
+
+          ret = [ ret, dump.parse( fn, "functionArgs" ), "){" ].join( "" );
+          return join( ret, dump.parse( fn, "functionCode" ), "}" );
+        },
+        array: array,
+        nodelist: array,
+        "arguments": array,
+        object: function( map, stack ) {
+          /*jshint forin:false */
+          var ret = [], keys, key, val, i, nonEnumerableProperties;
+          dump.up();
+          keys = [];
+          for ( key in map ) {
+            keys.push( key );
+          }
+
+          // Some properties are not always enumerable on Error objects.
+          nonEnumerableProperties = [ "message", "name" ];
+          for ( i in nonEnumerableProperties ) {
+            key = nonEnumerableProperties[ i ];
+            if ( key in map && !( key in keys ) ) {
+              keys.push( key );
+            }
+          }
+          keys.sort();
+          for ( i = 0; i < keys.length; i++ ) {
+            key = keys[ i ];
+            val = map[ key ];
+            ret.push( dump.parse( key, "key" ) + ": " + dump.parse( val, undefined, stack ) );
+          }
+          dump.down();
+          return join( "{", ret, "}" );
+        },
+        node: function( node ) {
+          var len, i, val,
+            open = dump.HTML ? "&lt;" : "<",
+            close = dump.HTML ? "&gt;" : ">",
+            tag = node.nodeName.toLowerCase(),
+            ret = open + tag,
+            attrs = node.attributes;
+
+          if ( attrs ) {
+            for ( i = 0, len = attrs.length; i < len; i++ ) {
+              val = attrs[ i ].nodeValue;
+
+              // IE6 includes all attributes in .attributes, even ones not explicitly set.
+              // Those have values like undefined, null, 0, false, "" or "inherit".
+              if ( val && val !== "inherit" ) {
+                ret += " " + attrs[ i ].nodeName + "=" + dump.parse( val, "attribute" );
+              }
+            }
+          }
+          ret += close;
+
+          // Show content of TextNode or CDATASection
+          if ( node.nodeType === 3 || node.nodeType === 4 ) {
+            ret += node.nodeValue;
+          }
+
+          return ret + open + "/" + tag + close;
+        },
+
+        // function calls it internally, it's the arguments part of the function
+        functionArgs: function( fn ) {
+          var args,
+            l = fn.length;
+
+          if ( !l ) {
+            return "";
+          }
+
+          args = new Array( l );
+          while ( l-- ) {
+
+            // 97 is 'a'
+            args[ l ] = String.fromCharCode( 97 + l );
+          }
+          return " " + args.join( ", " ) + " ";
+        },
+        // object calls it internally, the key part of an item in a map
+        key: quote,
+        // function calls it internally, it's the content of the function
+        functionCode: "[code]",
+        // node calls it internally, it's an html attribute value
+        attribute: quote,
+        string: quote,
+        date: quote,
+        regexp: literal,
+        number: literal,
+        "boolean": literal
+      },
+      // if true, entities are escaped ( <, >, \t, space and \n )
+      HTML: false,
+      // indentation unit
+      indentChar: "  ",
+      // if true, items in a collection, are separated by a \n, else just a space.
+      multiline: true
+    };
+
+  return dump;
+}());
+
+// back compat
+QUnit.jsDump = QUnit.dump;
+
+// For browser, export only select globals
+if ( typeof window !== "undefined" ) {
+
+  // Deprecated
+  // Extend assert methods to QUnit and Global scope through Backwards compatibility
+  (function() {
+    var i,
+      assertions = Assert.prototype;
+
+    function applyCurrent( current ) {
+      return function() {
+        var assert = new Assert( QUnit.config.current );
+        current.apply( assert, arguments );
+      };
+    }
+
+    for ( i in assertions ) {
+      QUnit[ i ] = applyCurrent( assertions[ i ] );
+    }
+  })();
+
+  (function() {
+    var i, l,
+      keys = [
+        "test",
+        "module",
+        "expect",
+        "asyncTest",
+        "start",
+        "stop",
+        "ok",
+        "equal",
+        "notEqual",
+        "propEqual",
+        "notPropEqual",
+        "deepEqual",
+        "notDeepEqual",
+        "strictEqual",
+        "notStrictEqual",
+        "throws"
+      ];
+
+    for ( i = 0, l = keys.length; i < l; i++ ) {
+      window[ keys[ i ] ] = QUnit[ keys[ i ] ];
+    }
+  })();
+
+  window.QUnit = QUnit;
+}
+
+// For CommonJS environments, export everything
+if ( typeof module !== "undefined" && module.exports ) {
+  module.exports = QUnit;
+}
+
+// Get a reference to the global object, like window in browsers
+}( (function() {
+  return this;
+})() ));
+
+/*istanbul ignore next */
+/*
+ * Javascript Diff Algorithm
+ *  By John Resig (http://ejohn.org/)
+ *  Modified by Chu Alan "sprite"
+ *
+ * Released under the MIT license.
+ *
+ * More Info:
+ *  http://ejohn.org/projects/javascript-diff-algorithm/
+ *
+ * Usage: QUnit.diff(expected, actual)
+ *
+ * QUnit.diff( "the quick brown fox jumped over", "the quick fox jumps over" ) == "the  quick <del>brown </del> fox <del>jumped </del><ins>jumps </ins> over"
+ */
+QUnit.diff = (function() {
+  var hasOwn = Object.prototype.hasOwnProperty;
+
+  /*jshint eqeqeq:false, eqnull:true */
+  function diff( o, n ) {
+    var i,
+      ns = {},
+      os = {};
+
+    for ( i = 0; i < n.length; i++ ) {
+      if ( !hasOwn.call( ns, n[ i ] ) ) {
+        ns[ n[ i ] ] = {
+          rows: [],
+          o: null
+        };
+      }
+      ns[ n[ i ] ].rows.push( i );
+    }
+
+    for ( i = 0; i < o.length; i++ ) {
+      if ( !hasOwn.call( os, o[ i ] ) ) {
+        os[ o[ i ] ] = {
+          rows: [],
+          n: null
+        };
+      }
+      os[ o[ i ] ].rows.push( i );
+    }
+
+    for ( i in ns ) {
+      if ( hasOwn.call( ns, i ) ) {
+        if ( ns[ i ].rows.length === 1 && hasOwn.call( os, i ) && os[ i ].rows.length === 1 ) {
+          n[ ns[ i ].rows[ 0 ] ] = {
+            text: n[ ns[ i ].rows[ 0 ] ],
+            row: os[ i ].rows[ 0 ]
+          };
+          o[ os[ i ].rows[ 0 ] ] = {
+            text: o[ os[ i ].rows[ 0 ] ],
+            row: ns[ i ].rows[ 0 ]
+          };
+        }
+      }
+    }
+
+    for ( i = 0; i < n.length - 1; i++ ) {
+      if ( n[ i ].text != null && n[ i + 1 ].text == null && n[ i ].row + 1 < o.length && o[ n[ i ].row + 1 ].text == null &&
+        n[ i + 1 ] == o[ n[ i ].row + 1 ] ) {
+
+        n[ i + 1 ] = {
+          text: n[ i + 1 ],
+          row: n[ i ].row + 1
+        };
+        o[ n[ i ].row + 1 ] = {
+          text: o[ n[ i ].row + 1 ],
+          row: i + 1
+        };
+      }
+    }
+
+    for ( i = n.length - 1; i > 0; i-- ) {
+      if ( n[ i ].text != null && n[ i - 1 ].text == null && n[ i ].row > 0 && o[ n[ i ].row - 1 ].text == null &&
+        n[ i - 1 ] == o[ n[ i ].row - 1 ] ) {
+
+        n[ i - 1 ] = {
+          text: n[ i - 1 ],
+          row: n[ i ].row - 1
+        };
+        o[ n[ i ].row - 1 ] = {
+          text: o[ n[ i ].row - 1 ],
+          row: i - 1
+        };
+      }
+    }
+
+    return {
+      o: o,
+      n: n
+    };
+  }
+
+  return function( o, n ) {
+    o = o.replace( /\s+$/, "" );
+    n = n.replace( /\s+$/, "" );
+
+    var i, pre,
+      str = "",
+      out = diff( o === "" ? [] : o.split( /\s+/ ), n === "" ? [] : n.split( /\s+/ ) ),
+      oSpace = o.match( /\s+/g ),
+      nSpace = n.match( /\s+/g );
+
+    if ( oSpace == null ) {
+      oSpace = [ " " ];
+    } else {
+      oSpace.push( " " );
+    }
+
+    if ( nSpace == null ) {
+      nSpace = [ " " ];
+    } else {
+      nSpace.push( " " );
+    }
+
+    if ( out.n.length === 0 ) {
+      for ( i = 0; i < out.o.length; i++ ) {
+        str += "<del>" + out.o[ i ] + oSpace[ i ] + "</del>";
+      }
+    } else {
+      if ( out.n[ 0 ].text == null ) {
+        for ( n = 0; n < out.o.length && out.o[ n ].text == null; n++ ) {
+          str += "<del>" + out.o[ n ] + oSpace[ n ] + "</del>";
+        }
+      }
+
+      for ( i = 0; i < out.n.length; i++ ) {
+        if ( out.n[ i ].text == null ) {
+          str += "<ins>" + out.n[ i ] + nSpace[ i ] + "</ins>";
+        } else {
+
+          // `pre` initialized at top of scope
+          pre = "";
+
+          for ( n = out.n[ i ].row + 1; n < out.o.length && out.o[ n ].text == null; n++ ) {
+            pre += "<del>" + out.o[ n ] + oSpace[ n ] + "</del>";
+          }
+          str += " " + out.n[ i ].text + nSpace[ i ] + pre;
+        }
+      }
+    }
+
+    return str;
+  };
+}());
+
+(function() {
+
+// Deprecated QUnit.init - Ref #530
+// Re-initialize the configuration options
+QUnit.init = function() {
+  var tests, banner, result, qunit,
+    config = QUnit.config;
+
+  config.stats = { all: 0, bad: 0 };
+  config.moduleStats = { all: 0, bad: 0 };
+  config.started = 0;
+  config.updateRate = 1000;
+  config.blocking = false;
+  config.autostart = true;
+  config.autorun = false;
+  config.filter = "";
+  config.queue = [];
+  config.semaphore = 1;
+
+  // Return on non-browser environments
+  // This is necessary to not break on node tests
+  if ( typeof window === "undefined" ) {
+    return;
+  }
+
+  qunit = id( "qunit" );
+  if ( qunit ) {
+    qunit.innerHTML =
+      "<h1 id='qunit-header'>" + escapeText( document.title ) + "</h1>" +
+      "<h2 id='qunit-banner'></h2>" +
+      "<div id='qunit-testrunner-toolbar'></div>" +
+      "<h2 id='qunit-userAgent'></h2>" +
+      "<ol id='qunit-tests'></ol>";
+  }
+
+  tests = id( "qunit-tests" );
+  banner = id( "qunit-banner" );
+  result = id( "qunit-testresult" );
+
+  if ( tests ) {
+    tests.innerHTML = "";
+  }
+
+  if ( banner ) {
+    banner.className = "";
+  }
+
+  if ( result ) {
+    result.parentNode.removeChild( result );
+  }
+
+  if ( tests ) {
+    result = document.createElement( "p" );
+    result.id = "qunit-testresult";
+    result.className = "result";
+    tests.parentNode.insertBefore( result, tests );
+    result.innerHTML = "Running...<br/>&nbsp;";
+  }
+};
+
+// Resets the test setup. Useful for tests that modify the DOM.
+/*
+DEPRECATED: Use multiple tests instead of resetting inside a test.
+Use testStart or testDone for custom cleanup.
+This method will throw an error in 2.0, and will be removed in 2.1
+*/
+QUnit.reset = function() {
+
+  // Return on non-browser environments
+  // This is necessary to not break on node tests
+  if ( typeof window === "undefined" ) {
+    return;
+  }
+
+  var fixture = id( "qunit-fixture" );
+  if ( fixture ) {
+    fixture.innerHTML = config.fixture;
+  }
+};
+
+// Don't load the HTML Reporter on non-Browser environments
+if ( typeof window === "undefined" ) {
+  return;
+}
+
+var config = QUnit.config,
+  hasOwn = Object.prototype.hasOwnProperty,
+  defined = {
+    document: typeof window.document !== "undefined",
+    sessionStorage: (function() {
+      var x = "qunit-test-string";
+      try {
+        sessionStorage.setItem( x, x );
+        sessionStorage.removeItem( x );
+        return true;
+      } catch ( e ) {
+        return false;
+      }
+    }())
+  };
+
+/**
+* Escape text for attribute or text content.
+*/
+function escapeText( s ) {
+  if ( !s ) {
+    return "";
+  }
+  s = s + "";
+
+  // Both single quotes and double quotes (for attributes)
+  return s.replace( /['"<>&]/g, function( s ) {
+    switch ( s ) {
+    case "'":
+      return "&#039;";
+    case "\"":
+      return "&quot;";
+    case "<":
+      return "&lt;";
+    case ">":
+      return "&gt;";
+    case "&":
+      return "&amp;";
+    }
+  });
+}
+
+/**
+ * @param {HTMLElement} elem
+ * @param {string} type
+ * @param {Function} fn
+ */
+function addEvent( elem, type, fn ) {
+  if ( elem.addEventListener ) {
+
+    // Standards-based browsers
+    elem.addEventListener( type, fn, false );
+  } else if ( elem.attachEvent ) {
+
+    // support: IE <9
+    elem.attachEvent( "on" + type, fn );
+  }
+}
+
+/**
+ * @param {Array|NodeList} elems
+ * @param {string} type
+ * @param {Function} fn
+ */
+function addEvents( elems, type, fn ) {
+  var i = elems.length;
+  while ( i-- ) {
+    addEvent( elems[ i ], type, fn );
+  }
+}
+
+function hasClass( elem, name ) {
+  return ( " " + elem.className + " " ).indexOf( " " + name + " " ) >= 0;
+}
+
+function addClass( elem, name ) {
+  if ( !hasClass( elem, name ) ) {
+    elem.className += ( elem.className ? " " : "" ) + name;
+  }
+}
+
+function toggleClass( elem, name ) {
+  if ( hasClass( elem, name ) ) {
+    removeClass( elem, name );
+  } else {
+    addClass( elem, name );
+  }
+}
+
+function removeClass( elem, name ) {
+  var set = " " + elem.className + " ";
+
+  // Class name may appear multiple times
+  while ( set.indexOf( " " + name + " " ) >= 0 ) {
+    set = set.replace( " " + name + " ", " " );
+  }
+
+  // trim for prettiness
+  elem.className = typeof set.trim === "function" ? set.trim() : set.replace( /^\s+|\s+$/g, "" );
+}
+
+function id( name ) {
+  return defined.document && document.getElementById && document.getElementById( name );
+}
+
+function getUrlConfigHtml() {
+  var i, j, val,
+    escaped, escapedTooltip,
+    selection = false,
+    len = config.urlConfig.length,
+    urlConfigHtml = "";
+
+  for ( i = 0; i < len; i++ ) {
+    val = config.urlConfig[ i ];
+    if ( typeof val === "string" ) {
+      val = {
+        id: val,
+        label: val
+      };
+    }
+
+    escaped = escapeText( val.id );
+    escapedTooltip = escapeText( val.tooltip );
+
+    config[ val.id ] = QUnit.urlParams[ val.id ];
+    if ( !val.value || typeof val.value === "string" ) {
+      urlConfigHtml += "<input id='qunit-urlconfig-" + escaped +
+        "' name='" + escaped + "' type='checkbox'" +
+        ( val.value ? " value='" + escapeText( val.value ) + "'" : "" ) +
+        ( config[ val.id ] ? " checked='checked'" : "" ) +
+        " title='" + escapedTooltip + "'><label for='qunit-urlconfig-" + escaped +
+        "' title='" + escapedTooltip + "'>" + val.label + "</label>";
+    } else {
+      urlConfigHtml += "<label for='qunit-urlconfig-" + escaped +
+        "' title='" + escapedTooltip + "'>" + val.label +
+        ": </label><select id='qunit-urlconfig-" + escaped +
+        "' name='" + escaped + "' title='" + escapedTooltip + "'><option></option>";
+
+      if ( QUnit.is( "array", val.value ) ) {
+        for ( j = 0; j < val.value.length; j++ ) {
+          escaped = escapeText( val.value[ j ] );
+          urlConfigHtml += "<option value='" + escaped + "'" +
+            ( config[ val.id ] === val.value[ j ] ?
+              ( selection = true ) && " selected='selected'" : "" ) +
+            ">" + escaped + "</option>";
+        }
+      } else {
+        for ( j in val.value ) {
+          if ( hasOwn.call( val.value, j ) ) {
+            urlConfigHtml += "<option value='" + escapeText( j ) + "'" +
+              ( config[ val.id ] === j ?
+                ( selection = true ) && " selected='selected'" : "" ) +
+              ">" + escapeText( val.value[ j ] ) + "</option>";
+          }
+        }
+      }
+      if ( config[ val.id ] && !selection ) {
+        escaped = escapeText( config[ val.id ] );
+        urlConfigHtml += "<option value='" + escaped +
+          "' selected='selected' disabled='disabled'>" + escaped + "</option>";
+      }
+      urlConfigHtml += "</select>";
+    }
+  }
+
+  return urlConfigHtml;
+}
+
+function toolbarUrlConfigContainer() {
+  var urlConfigContainer = document.createElement( "span" );
+
+  urlConfigContainer.innerHTML = getUrlConfigHtml();
+
+  // For oldIE support:
+  // * Add handlers to the individual elements instead of the container
+  // * Use "click" instead of "change" for checkboxes
+  // * Fallback from event.target to event.srcElement
+  addEvents( urlConfigContainer.getElementsByTagName( "input" ), "click", function( event ) {
+    var params = {},
+      target = event.target || event.srcElement;
+    params[ target.name ] = target.checked ?
+      target.defaultValue || true :
+      undefined;
+    window.location = QUnit.url( params );
+  });
+  addEvents( urlConfigContainer.getElementsByTagName( "select" ), "change", function( event ) {
+    var params = {},
+      target = event.target || event.srcElement;
+    params[ target.name ] = target.options[ target.selectedIndex ].value || undefined;
+    window.location = QUnit.url( params );
+  });
+
+  return urlConfigContainer;
+}
+
+function getModuleNames() {
+  var i,
+    moduleNames = [];
+
+  for ( i in config.modules ) {
+    if ( config.modules.hasOwnProperty( i ) ) {
+      moduleNames.push( i );
+    }
+  }
+
+  moduleNames.sort(function( a, b ) {
+    return a.localeCompare( b );
+  });
+
+  return moduleNames;
+}
+
+function toolbarModuleFilterHtml() {
+  var i,
+    moduleFilterHtml = "",
+    moduleNames = getModuleNames();
+
+  if ( moduleNames.length <= 1 ) {
+    return false;
+  }
+
+  moduleFilterHtml += "<label for='qunit-modulefilter'>Module: </label>" +
+    "<select id='qunit-modulefilter' name='modulefilter'><option value='' " +
+    ( config.module === undefined ? "selected='selected'" : "" ) +
+    ">< All Modules ></option>";
+
+  for ( i = 0; i < moduleNames.length; i++ ) {
+    moduleFilterHtml += "<option value='" +
+      escapeText( encodeURIComponent( moduleNames[ i ] ) ) + "' " +
+      ( config.module === moduleNames[ i ] ? "selected='selected'" : "" ) +
+      ">" + escapeText( moduleNames[ i ] ) + "</option>";
+  }
+  moduleFilterHtml += "</select>";
+
+  return moduleFilterHtml;
+}
+
+function toolbarModuleFilter() {
+  var moduleFilter = document.createElement( "span" ),
+    moduleFilterHtml = toolbarModuleFilterHtml();
+
+  if ( !moduleFilterHtml ) {
+    return false;
+  }
+
+  moduleFilter.setAttribute( "id", "qunit-modulefilter-container" );
+  moduleFilter.innerHTML = moduleFilterHtml;
+
+  addEvent( moduleFilter.lastChild, "change", function() {
+    var selectBox = moduleFilter.getElementsByTagName( "select" )[ 0 ],
+      selectedModule = decodeURIComponent( selectBox.options[ selectBox.selectedIndex ].value );
+
+    window.location = QUnit.url({
+      module: ( selectedModule === "" ) ? undefined : selectedModule,
+
+      // Remove any existing filters
+      filter: undefined,
+      testNumber: undefined
+    });
+  });
+
+  return moduleFilter;
+}
+
+function toolbarFilter() {
+  var testList = id( "qunit-tests" ),
+    filter = document.createElement( "input" );
+
+  filter.type = "checkbox";
+  filter.id = "qunit-filter-pass";
+
+  addEvent( filter, "click", function() {
+    if ( filter.checked ) {
+      addClass( testList, "hidepass" );
+      if ( defined.sessionStorage ) {
+        sessionStorage.setItem( "qunit-filter-passed-tests", "true" );
+      }
+    } else {
+      removeClass( testList, "hidepass" );
+      if ( defined.sessionStorage ) {
+        sessionStorage.removeItem( "qunit-filter-passed-tests" );
+      }
+    }
+  });
+
+  if ( config.hidepassed || defined.sessionStorage &&
+      sessionStorage.getItem( "qunit-filter-passed-tests" ) ) {
+    filter.checked = true;
+
+    addClass( testList, "hidepass" );
+  }
+
+  return filter;
+}
+
+function toolbarLabel() {
+  var label = document.createElement( "label" );
+  label.setAttribute( "for", "qunit-filter-pass" );
+  label.setAttribute( "title", "Only show tests and assertions that fail. Stored in sessionStorage." );
+  label.innerHTML = "Hide passed tests";
+
+  return label;
+}
+
+function appendToolbar() {
+  var moduleFilter,
+    toolbar = id( "qunit-testrunner-toolbar" );
+
+  if ( toolbar ) {
+    toolbar.appendChild( toolbarFilter() );
+    toolbar.appendChild( toolbarLabel() );
+    toolbar.appendChild( toolbarUrlConfigContainer() );
+
+    moduleFilter = toolbarModuleFilter();
+    if ( moduleFilter ) {
+      toolbar.appendChild( moduleFilter );
+    }
+  }
+}
+
+function appendBanner() {
+  var banner = id( "qunit-banner" );
+
+  if ( banner ) {
+    banner.className = "";
+    banner.innerHTML = "<a href='" +
+      QUnit.url({ filter: undefined, module: undefined, testNumber: undefined }) +
+      "'>" + banner.innerHTML + "</a> ";
+  }
+}
+
+function appendTestResults() {
+  var tests = id( "qunit-tests" ),
+    result = id( "qunit-testresult" );
+
+  if ( result ) {
+    result.parentNode.removeChild( result );
+  }
+
+  if ( tests ) {
+    tests.innerHTML = "";
+    result = document.createElement( "p" );
+    result.id = "qunit-testresult";
+    result.className = "result";
+    tests.parentNode.insertBefore( result, tests );
+    result.innerHTML = "Running...<br>&nbsp;";
+  }
+}
+
+function storeFixture() {
+  var fixture = id( "qunit-fixture" );
+  if ( fixture ) {
+    config.fixture = fixture.innerHTML;
+  }
+}
+
+function appendUserAgent() {
+  var userAgent = id( "qunit-userAgent" );
+  if ( userAgent ) {
+    userAgent.innerHTML = navigator.userAgent;
+  }
+}
+
+// HTML Reporter initialization and load
+QUnit.begin(function() {
+  var qunit = id( "qunit" );
+
+  if ( qunit ) {
+    qunit.innerHTML =
+    "<h1 id='qunit-header'>" + escapeText( document.title ) + "</h1>" +
+    "<h2 id='qunit-banner'></h2>" +
+    "<div id='qunit-testrunner-toolbar'></div>" +
+    "<h2 id='qunit-userAgent'></h2>" +
+    "<ol id='qunit-tests'></ol>";
+  }
+
+  appendBanner();
+  appendTestResults();
+  appendUserAgent();
+  appendToolbar();
+  storeFixture();
+});
+
+QUnit.done(function( details ) {
+  var i, key,
+    banner = id( "qunit-banner" ),
+    tests = id( "qunit-tests" ),
+    html = [
+      "Tests completed in ",
+      details.runtime,
+      " milliseconds.<br>",
+      "<span class='passed'>",
+      details.passed,
+      "</span> assertions of <span class='total'>",
+      details.total,
+      "</span> passed, <span class='failed'>",
+      details.failed,
+      "</span> failed."
+    ].join( "" );
+
+  if ( banner ) {
+    banner.className = details.failed ? "qunit-fail" : "qunit-pass";
+  }
+
+  if ( tests ) {
+    id( "qunit-testresult" ).innerHTML = html;
+  }
+
+  if ( config.altertitle && defined.document && document.title ) {
+
+    // show ✖ for good, ✔ for bad suite result in title
+    // use escape sequences in case file gets loaded with non-utf-8-charset
+    document.title = [
+      ( details.failed ? "\u2716" : "\u2714" ),
+      document.title.replace( /^[\u2714\u2716] /i, "" )
+    ].join( " " );
+  }
+
+  // clear own sessionStorage items if all tests passed
+  if ( config.reorder && defined.sessionStorage && details.failed === 0 ) {
+    for ( i = 0; i < sessionStorage.length; i++ ) {
+      key = sessionStorage.key( i++ );
+      if ( key.indexOf( "qunit-test-" ) === 0 ) {
+        sessionStorage.removeItem( key );
+      }
+    }
+  }
+
+  // scroll back to top to show results
+  if ( config.scrolltop && window.scrollTo ) {
+    window.scrollTo( 0, 0 );
+  }
+});
+
+function getNameHtml( name, module ) {
+  var nameHtml = "";
+
+  if ( module ) {
+    nameHtml = "<span class='module-name'>" + escapeText( module ) + "</span>: ";
+  }
+
+  nameHtml += "<span class='test-name'>" + escapeText( name ) + "</span>";
+
+  return nameHtml;
+}
+
+QUnit.testStart(function( details ) {
+  var a, b, li, running, assertList,
+    name = getNameHtml( details.name, details.module ),
+    tests = id( "qunit-tests" );
+
+  if ( tests ) {
+    b = document.createElement( "strong" );
+    b.innerHTML = name;
+
+    a = document.createElement( "a" );
+    a.innerHTML = "Rerun";
+    a.href = QUnit.url({ testNumber: details.testNumber });
+
+    li = document.createElement( "li" );
+    li.appendChild( b );
+    li.appendChild( a );
+    li.className = "running";
+    li.id = "qunit-test-output" + details.testNumber;
+
+    assertList = document.createElement( "ol" );
+    assertList.className = "qunit-assert-list";
+
+    li.appendChild( assertList );
+
+    tests.appendChild( li );
+  }
+
+  running = id( "qunit-testresult" );
+  if ( running ) {
+    running.innerHTML = "Running: <br>" + name;
+  }
+
+});
+
+QUnit.log(function( details ) {
+  var assertList, assertLi,
+    message, expected, actual,
+    testItem = id( "qunit-test-output" + details.testNumber );
+
+  if ( !testItem ) {
+    return;
+  }
+
+  message = escapeText( details.message ) || ( details.result ? "okay" : "failed" );
+  message = "<span class='test-message'>" + message + "</span>";
+
+  // pushFailure doesn't provide details.expected
+  // when it calls, it's implicit to also not show expected and diff stuff
+  // Also, we need to check details.expected existence, as it can exist and be undefined
+  if ( !details.result && hasOwn.call( details, "expected" ) ) {
+    expected = escapeText( QUnit.dump.parse( details.expected ) );
+    actual = escapeText( QUnit.dump.parse( details.actual ) );
+    message += "<table><tr class='test-expected'><th>Expected: </th><td><pre>" +
+      expected +
+      "</pre></td></tr>";
+
+    if ( actual !== expected ) {
+      message += "<tr class='test-actual'><th>Result: </th><td><pre>" +
+        actual + "</pre></td></tr>" +
+        "<tr class='test-diff'><th>Diff: </th><td><pre>" +
+        QUnit.diff( expected, actual ) + "</pre></td></tr>";
+    }
+
+    if ( details.source ) {
+      message += "<tr class='test-source'><th>Source: </th><td><pre>" +
+        escapeText( details.source ) + "</pre></td></tr>";
+    }
+
+    message += "</table>";
+
+  // this occours when pushFailure is set and we have an extracted stack trace
+  } else if ( !details.result && details.source ) {
+    message += "<table>" +
+      "<tr class='test-source'><th>Source: </th><td><pre>" +
+      escapeText( details.source ) + "</pre></td></tr>" +
+      "</table>";
+  }
+
+  assertList = testItem.getElementsByTagName( "ol" )[ 0 ];
+
+  assertLi = document.createElement( "li" );
+  assertLi.className = details.result ? "pass" : "fail";
+  assertLi.innerHTML = message;
+  assertList.appendChild( assertLi );
+});
+
+QUnit.testDone(function( details ) {
+  var testTitle, time, testItem, assertList,
+    good, bad, testCounts,
+    tests = id( "qunit-tests" );
+
+  // QUnit.reset() is deprecated and will be replaced for a new
+  // fixture reset function on QUnit 2.0/2.1.
+  // It's still called here for backwards compatibility handling
+  QUnit.reset();
+
+  if ( !tests ) {
+    return;
+  }
+
+  testItem = id( "qunit-test-output" + details.testNumber );
+  assertList = testItem.getElementsByTagName( "ol" )[ 0 ];
+
+  good = details.passed;
+  bad = details.failed;
+
+  // store result when possible
+  if ( config.reorder && defined.sessionStorage ) {
+    if ( bad ) {
+      sessionStorage.setItem( "qunit-test-" + details.module + "-" + details.name, bad );
+    } else {
+      sessionStorage.removeItem( "qunit-test-" + details.module + "-" + details.name );
+    }
+  }
+
+  if ( bad === 0 ) {
+    addClass( assertList, "qunit-collapsed" );
+  }
+
+  // testItem.firstChild is the test name
+  testTitle = testItem.firstChild;
+
+  testCounts = bad ?
+    "<b class='failed'>" + bad + "</b>, " + "<b class='passed'>" + good + "</b>, " :
+    "";
+
+  testTitle.innerHTML += " <b class='counts'>(" + testCounts +
+    details.assertions.length + ")</b>";
+
+  addEvent( testTitle, "click", function() {
+    toggleClass( assertList, "qunit-collapsed" );
+  });
+
+  time = document.createElement( "span" );
+  time.className = "runtime";
+  time.innerHTML = details.runtime + " ms";
+
+  testItem.className = bad ? "fail" : "pass";
+
+  testItem.insertBefore( time, assertList );
+});
+
+if ( !defined.document || document.readyState === "complete" ) {
+  config.autorun = true;
+}
+
+if ( defined.document ) {
+  addEvent( window, "load", QUnit.load );
+}
+
+})();

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/tests.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/tests.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/tests.js
new file mode 100644
index 0000000..b830f0f
--- /dev/null
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/javascripts/tests.js
@@ -0,0 +1,29 @@
+/**
+ * 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 folderOrder = [
+  'test'
+];
+
+folderOrder.forEach(function(folder) {
+  window.require.list().filter(function(module) {
+    return new RegExp('^' + folder + '/').test(module);
+  }).forEach(function(module) {
+      require(module);
+    });
+});
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/stylesheets/qunit.css
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/stylesheets/qunit.css b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/stylesheets/qunit.css
new file mode 100644
index 0000000..9437b4b
--- /dev/null
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/static/stylesheets/qunit.css
@@ -0,0 +1,237 @@
+/*!
+ * QUnit 1.15.0
+ * http://qunitjs.com/
+ *
+ * Copyright 2014 jQuery Foundation and other contributors
+ * Released under the MIT license
+ * http://jquery.org/license
+ *
+ * Date: 2014-08-08T16:00Z
+ */
+
+/** Font Family and Sizes */
+
+#qunit-tests, #qunit-header, #qunit-banner, #qunit-testrunner-toolbar, #qunit-userAgent, #qunit-testresult {
+	font-family: "Helvetica Neue Light", "HelveticaNeue-Light", "Helvetica Neue", Calibri, Helvetica, Arial, sans-serif;
+}
+
+#qunit-testrunner-toolbar, #qunit-userAgent, #qunit-testresult, #qunit-tests li { font-size: small; }
+#qunit-tests { font-size: smaller; }
+
+
+/** Resets */
+
+#qunit-tests, #qunit-header, #qunit-banner, #qunit-userAgent, #qunit-testresult, #qunit-modulefilter {
+	margin: 0;
+	padding: 0;
+}
+
+
+/** Header */
+
+#qunit-header {
+	padding: 0.5em 0 0.5em 1em;
+
+	color: #8699A4;
+	background-color: #0D3349;
+
+	font-size: 1.5em;
+	line-height: 1em;
+	font-weight: 400;
+
+	border-radius: 5px 5px 0 0;
+}
+
+#qunit-header a {
+	text-decoration: none;
+	color: #C2CCD1;
+}
+
+#qunit-header a:hover,
+#qunit-header a:focus {
+	color: #FFF;
+}
+
+#qunit-testrunner-toolbar label {
+	display: inline-block;
+	padding: 0 0.5em 0 0.1em;
+}
+
+#qunit-banner {
+	height: 5px;
+}
+
+#qunit-testrunner-toolbar {
+	padding: 0.5em 1em 0.5em 1em;
+	color: #5E740B;
+	background-color: #EEE;
+	overflow: hidden;
+}
+
+#qunit-userAgent {
+	padding: 0.5em 1em 0.5em 1em;
+	background-color: #2B81AF;
+	color: #FFF;
+	text-shadow: rgba(0, 0, 0, 0.5) 2px 2px 1px;
+}
+
+#qunit-modulefilter-container {
+	float: right;
+}
+
+/** Tests: Pass/Fail */
+
+#qunit-tests {
+	list-style-position: inside;
+}
+
+#qunit-tests li {
+	padding: 0.4em 1em 0.4em 1em;
+	border-bottom: 1px solid #FFF;
+	list-style-position: inside;
+}
+
+#qunit-tests.hidepass li.pass, #qunit-tests.hidepass li.running  {
+	display: none;
+}
+
+#qunit-tests li strong {
+	cursor: pointer;
+}
+
+#qunit-tests li a {
+	padding: 0.5em;
+	color: #C2CCD1;
+	text-decoration: none;
+}
+#qunit-tests li a:hover,
+#qunit-tests li a:focus {
+	color: #000;
+}
+
+#qunit-tests li .runtime {
+	float: right;
+	font-size: smaller;
+}
+
+.qunit-assert-list {
+	margin-top: 0.5em;
+	padding: 0.5em;
+
+	background-color: #FFF;
+
+	border-radius: 5px;
+}
+
+.qunit-collapsed {
+	display: none;
+}
+
+#qunit-tests table {
+	border-collapse: collapse;
+	margin-top: 0.2em;
+}
+
+#qunit-tests th {
+	text-align: right;
+	vertical-align: top;
+	padding: 0 0.5em 0 0;
+}
+
+#qunit-tests td {
+	vertical-align: top;
+}
+
+#qunit-tests pre {
+	margin: 0;
+	white-space: pre-wrap;
+	word-wrap: break-word;
+}
+
+#qunit-tests del {
+	background-color: #E0F2BE;
+	color: #374E0C;
+	text-decoration: none;
+}
+
+#qunit-tests ins {
+	background-color: #FFCACA;
+	color: #500;
+	text-decoration: none;
+}
+
+/*** Test Counts */
+
+#qunit-tests b.counts                       { color: #000; }
+#qunit-tests b.passed                       { color: #5E740B; }
+#qunit-tests b.failed                       { color: #710909; }
+
+#qunit-tests li li {
+	padding: 5px;
+	background-color: #FFF;
+	border-bottom: none;
+	list-style-position: inside;
+}
+
+/*** Passing Styles */
+
+#qunit-tests li li.pass {
+	color: #3C510C;
+	background-color: #FFF;
+	border-left: 10px solid #C6E746;
+}
+
+#qunit-tests .pass                          { color: #528CE0; background-color: #D2E0E6; }
+#qunit-tests .pass .test-name               { color: #366097; }
+
+#qunit-tests .pass .test-actual,
+#qunit-tests .pass .test-expected           { color: #999; }
+
+#qunit-banner.qunit-pass                    { background-color: #C6E746; }
+
+/*** Failing Styles */
+
+#qunit-tests li li.fail {
+	color: #710909;
+	background-color: #FFF;
+	border-left: 10px solid #EE5757;
+	white-space: pre;
+}
+
+#qunit-tests > li:last-child {
+	border-radius: 0 0 5px 5px;
+}
+
+#qunit-tests .fail                          { color: #000; background-color: #EE5757; }
+#qunit-tests .fail .test-name,
+#qunit-tests .fail .module-name             { color: #000; }
+
+#qunit-tests .fail .test-actual             { color: #EE5757; }
+#qunit-tests .fail .test-expected           { color: #008000; }
+
+#qunit-banner.qunit-fail                    { background-color: #EE5757; }
+
+
+/** Result */
+
+#qunit-testresult {
+	padding: 0.5em 1em 0.5em 1em;
+
+	color: #2B81AF;
+	background-color: #D2E0E6;
+
+	border-bottom: 1px solid #FFF;
+}
+#qunit-testresult .module-name {
+	font-weight: 700;
+}
+
+/** Fixture */
+
+#qunit-fixture {
+	position: absolute;
+	top: -10000px;
+	left: -10000px;
+	width: 1000px;
+	height: 1000px;
+}

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/tests.html
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/tests.html b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/tests.html
new file mode 100644
index 0000000..5ec9f0b
--- /dev/null
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/assets/tests.html
@@ -0,0 +1,46 @@
+<!--
+* 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.
+-->
+
+<!DOCTYPE html>
+<html>
+<head>
+  <meta charset="utf-8">
+  <title>Pig tests</title>
+  <link rel="stylesheet" href="static/stylesheets/qunit.css">
+</head>
+<body>
+  <div id="qunit"></div>
+  <div id="qunit-fixture"></div>
+  <div id="ember-testing"></div>
+  <script src="static/javascripts/qunit.js"></script>
+  <script src="static/javascripts/vendor.js"></script>
+  <script src="static/javascripts/jquery.mockjax.js"></script>
+  <script src="static/javascripts/ember-qunit.js"></script>
+  <script src="static/javascripts/app.js"></script>
+  <script>
+    emq.globalize();
+    require('initialize');
+    App.setupForTesting();
+    App.injectTestHelpers();
+    setResolver(Em.DefaultResolver.create({ namespace: App }));
+    App.rootElement = '#ember-testing';
+  </script>
+  <script src="static/javascripts/test.js"></script>
+  <script src="static/javascripts/tests.js"></script>
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/components/codeMirror.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/components/codeMirror.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/components/codeMirror.js
index dbbac8a..a77fcf6 100644
--- a/contrib/views/pig/src/main/resources/ui/pig-web/app/components/codeMirror.js
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/components/codeMirror.js
@@ -22,6 +22,7 @@ App.CodeMirrorComponent = Ember.Component.extend({
   tagName: "textarea",
   readOnly:false,
   codeMirror:null,
+  fullscreen:false,
   updateCM:function () {
     var cm = this.get('codeMirror');
     if (this.get('readOnly')) {
@@ -39,28 +40,62 @@ App.CodeMirrorComponent = Ember.Component.extend({
       cmElement.addClass('inactive');
     }
   }.observes('codeMirror', 'content.didLoad'),
+  toggleFullScreen:function () {
+    Em.run.next(this,function () {
+      this.get('codeMirror').setOption("fullScreen", this.get('fullscreen'));
+    });
+  }.observes('fullscreen'),
   didInsertElement: function() {
     var cm = CodeMirror.fromTextArea(this.get('element'),{
       lineNumbers: true,
       matchBrackets: true,
       indentUnit: 4,
-      keyMap: "emacs"
+      keyMap: "emacs",
+      mode: "text/x-pig",
+      extraKeys: {
+        "Ctrl-Space": function (cm) {
+          if (!cm.getOption('readOnly')) {
+            cm.showHint({completeSingle:false});
+          }
+        },
+        "F11": function(cm) {
+          this.set('fullscreen',!this.get("fullscreen"));
+        }.bind(this),
+        "Esc": function(cm) {
+          if (this.get("fullscreen")) this.set("fullscreen", false);
+        }.bind(this)
+      }
     });
 
+    var updateToggle = function () {
+      var addMargin = $('.CodeMirror-vscrollbar').css('display') === "block";
+      var margin = $('.CodeMirror-vscrollbar').width();
+      $('.fullscreen-toggle').css('right',((addMargin)?3+margin:3));
+    }
+
+    cm.on('viewportChange',updateToggle);
+
     $('.editor-container').resizable({
       stop:function () {
         cm.setSize(null, this.style.height);
+        updateToggle();
       },
       resize: function() {
         this.getElementsByClassName('CodeMirror')[0].style.height = this.style.height;
         this.getElementsByClassName('CodeMirror-gutters')[0].style.height = this.style.height;
       },
-      minHeight:215,
+      minHeight:218,
       handles: {'s': '#sgrip' }
     });
 
     this.set('codeMirror',cm);
     if (!this.get('readOnly')) {
+      cm.on('keyup',function (cm, e) {
+        var inp = String.fromCharCode(e.keyCode);
+        if (e.type == "keyup" && /[a-zA-Z0-9-_ ]/.test(inp)) {
+          cm.showHint({completeSingle:false});
+        }
+      });
       cm.focus();
       cm.on('change', Em.run.bind(this,this.editorDidChange));
     }
@@ -78,6 +113,7 @@ App.CodeMirrorComponent = Ember.Component.extend({
     }
   }.observes('content.fileContent'),
   willClearRender:function () {
+    this.set('fullscreen', false);
     this.get('codeMirror').toTextArea();
   }
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/components/jobProgress.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/components/jobProgress.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/components/jobProgress.js
index 24618ac..81ea2c9 100644
--- a/contrib/views/pig/src/main/resources/ui/pig-web/app/components/jobProgress.js
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/components/jobProgress.js
@@ -26,7 +26,7 @@ App.JobProgressComponent = Em.Component.extend({
   },
   update:function () {
     var progress = (!this.get('job.isTerminated'))?this.get('job.percentStatus'):100;
-    $(this.get('element')).find('.progress-bar').css('width',progress+'%');
+    this.$().find('.progress-bar').css('width',progress+'%');
   }.observes('job.percentStatus'),
   layout:Em.Handlebars.compile('<div {{bind-attr class=":progress-bar job.isTerminated:progress-bar-danger:progress-bar-success" }}role="progressbar"></div>')
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/components/pigHelper.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/components/pigHelper.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/components/pigHelper.js
index 9e2f874..16b0812 100644
--- a/contrib/views/pig/src/main/resources/ui/pig-web/app/components/pigHelper.js
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/components/pigHelper.js
@@ -43,8 +43,8 @@ App.PigHelperComponent = Em.Component.extend({
     }
   },
   findPosition: function (curLine){
-    var pos= curLine.indexOf("%");
-    var posArr=[];
+    var pos = curLine.indexOf("%");
+    var posArr = [];
     while(pos > -1) {
       posArr.push(pos);
       pos = curLine.indexOf("%", pos+1);

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/confirmAway.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/confirmAway.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/confirmAway.js
index c231948..58a9fa1 100644
--- a/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/confirmAway.js
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/confirmAway.js
@@ -37,7 +37,7 @@ App.ConfirmAwayController = Ember.ObjectController.extend({
         script.rollback();
         file.rollback();
         this.get('waitingTransition').retry();
-      }.bind(this))
+      }.bind(this));
     }
   },
   saveCallback:function(response){

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createScript.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createScript.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createScript.js
index f0781d9..5bb6008 100644
--- a/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createScript.js
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createScript.js
@@ -22,31 +22,30 @@ App.CreateScriptController = Ember.ObjectController.extend({
   needs:['pigScripts'],
   filePath:'',
   clearFilePath:function () {
-    this.set('didInsertTtle',false);
     this.set('filePath','');
+    this.set('titleErrorMessage','');
   }.observes('content'),
   actions:{
     confirm:function () {
-      var title = this.get('content.title');
-      if (!title) {
-        this.set('error', Em.I18n.t('scripts.modal.error_empty_title'));
-        return;
-      }
       this.get('controllers.pigScripts').send('confirmcreate',this.get('content'),this.get('filePath'));
     },
     cancel:function (script) {
       this.get('content').deleteRecord();
     }
   },
-  didInsertTtle:false,
-  titleError:function () {
-    var title = this.get('content.title');
-
-    if (!title && this.get('didInsertTtle')) {
-      return Em.I18n.t('scripts.modal.error_empty_title');
-    } else {
-      this.set('didInsertTtle',true);
+  titleErrorMessage:'',
+  clearAlert:function () {
+    if (!this.get('content.isBlankTitle')) {
+      this.set('titleErrorMessage','');
     }
-    return '';
-  }.property('content.title')
+  }.observes('content.title'),
+  titleChange:function () {
+    var target = this.get('targetObject');
+    var message = (Ember.isBlank(target.get('content.title')))?Em.I18n.t('scripts.modal.error_empty_title'):'';
+
+    target.set('titleErrorMessage',message);
+  },
+  isValid:function () {
+    return !this.get('content.isBlankTitle');
+  }.property('content.isBlankTitle')
 });

http://git-wip-us.apache.org/repos/asf/ambari/blob/f7414a76/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createUdf.js
----------------------------------------------------------------------
diff --git a/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createUdf.js b/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createUdf.js
index 3982ec7..e878a48 100644
--- a/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createUdf.js
+++ b/contrib/views/pig/src/main/resources/ui/pig-web/app/controllers/modal/createUdf.js
@@ -28,7 +28,7 @@ App.CreateUdfController = Ember.ObjectController.extend({
       this.get('content').deleteRecord();
     }
   },
-  udfInvalid:function (argument) {
-    return !this.get('content.name') || !this.get('content.path');
+  isValid:function () {
+    return !Em.isBlank(this.get('content.name')) && !Em.isBlank(this.get('content.path'));
   }.property('content.name','content.path')
 });