You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@couchdb.apache.org by ga...@apache.org on 2015/10/14 12:09:25 UTC

[28/52] [partial] couchdb-nmo git commit: prepare for release

http://git-wip-us.apache.org/repos/asf/couchdb-nmo/blob/753f1767/node_modules/couchbulkimporter/node_modules/mongodb/node_modules/mongodb-core/node_modules/bson/browser_build/bson.js
----------------------------------------------------------------------
diff --git a/node_modules/couchbulkimporter/node_modules/mongodb/node_modules/mongodb-core/node_modules/bson/browser_build/bson.js b/node_modules/couchbulkimporter/node_modules/mongodb/node_modules/mongodb-core/node_modules/bson/browser_build/bson.js
new file mode 100644
index 0000000..8e942dd
--- /dev/null
+++ b/node_modules/couchbulkimporter/node_modules/mongodb/node_modules/mongodb-core/node_modules/bson/browser_build/bson.js
@@ -0,0 +1,4843 @@
+var bson = (function(){
+
+  var pkgmap        = {},
+      global        = {},
+      nativeRequire = typeof require != 'undefined' && require,
+      lib, ties, main, async;
+
+  function exports(){ return main(); };
+
+  exports.main     = exports;
+  exports.module   = module;
+  exports.packages = pkgmap;
+  exports.pkg      = pkg;
+  exports.require  = function require(uri){
+    return pkgmap.main.index.require(uri);
+  };
+
+
+  ties             = {};
+
+  aliases          = {};
+
+
+  return exports;
+
+function join() {
+  return normalize(Array.prototype.join.call(arguments, "/"));
+};
+
+function normalize(path) {
+  var ret = [], parts = path.split('/'), cur, prev;
+
+  var i = 0, l = parts.length-1;
+  for (; i <= l; i++) {
+    cur = parts[i];
+
+    if (cur === "." && prev !== undefined) continue;
+
+    if (cur === ".." && ret.length && prev !== ".." && prev !== "." && prev !== undefined) {
+      ret.pop();
+      prev = ret.slice(-1)[0];
+    } else {
+      if (prev === ".") ret.pop();
+      ret.push(cur);
+      prev = cur;
+    }
+  }
+
+  return ret.join("/");
+};
+
+function dirname(path) {
+  return path && path.substr(0, path.lastIndexOf("/")) || ".";
+};
+
+function findModule(workingModule, uri){
+  var moduleId      = join(dirname(workingModule.id), /\.\/$/.test(uri) ? (uri + 'index') : uri ).replace(/\.js$/, ''),
+      moduleIndexId = join(moduleId, 'index'),
+      pkg           = workingModule.pkg,
+      module;
+
+  var i = pkg.modules.length,
+      id;
+
+  while(i-->0){
+    id = pkg.modules[i].id;
+
+    if(id==moduleId || id == moduleIndexId){
+      module = pkg.modules[i];
+      break;
+    }
+  }
+
+  return module;
+}
+
+function newRequire(callingModule){
+  function require(uri){
+    var module, pkg;
+
+    if(/^\./.test(uri)){
+      module = findModule(callingModule, uri);
+    } else if ( ties && ties.hasOwnProperty( uri ) ) {
+      return ties[uri];
+    } else if ( aliases && aliases.hasOwnProperty( uri ) ) {
+      return require(aliases[uri]);
+    } else {
+      pkg = pkgmap[uri];
+
+      if(!pkg && nativeRequire){
+        try {
+          pkg = nativeRequire(uri);
+        } catch (nativeRequireError) {}
+
+        if(pkg) return pkg;
+      }
+
+      if(!pkg){
+        throw new Error('Cannot find module "'+uri+'" @[module: '+callingModule.id+' package: '+callingModule.pkg.name+']');
+      }
+
+      module = pkg.index;
+    }
+
+    if(!module){
+      throw new Error('Cannot find module "'+uri+'" @[module: '+callingModule.id+' package: '+callingModule.pkg.name+']');
+    }
+
+    module.parent = callingModule;
+    return module.call();
+  };
+
+
+  return require;
+}
+
+
+function module(parent, id, wrapper){
+  var mod    = { pkg: parent, id: id, wrapper: wrapper },
+      cached = false;
+
+  mod.exports = {};
+  mod.require = newRequire(mod);
+
+  mod.call = function(){
+    if(cached) {
+      return mod.exports;
+    }
+
+    cached = true;
+
+    global.require = mod.require;
+
+    mod.wrapper(mod, mod.exports, global, global.require);
+    return mod.exports;
+  };
+
+  if(parent.mainModuleId == mod.id){
+    parent.index = mod;
+    parent.parents.length === 0 && ( main = mod.call );
+  }
+
+  parent.modules.push(mod);
+}
+
+function pkg(/* [ parentId ...], wrapper */){
+  var wrapper = arguments[ arguments.length - 1 ],
+      parents = Array.prototype.slice.call(arguments, 0, arguments.length - 1),
+      ctx     = wrapper(parents);
+
+
+  pkgmap[ctx.name] = ctx;
+
+  arguments.length == 1 && ( pkgmap.main = ctx );
+
+  return function(modules){
+    var id;
+    for(id in modules){
+      module(ctx, id, modules[id]);
+    }
+  };
+}
+
+
+}(this));
+
+bson.pkg(function(parents){
+
+  return {
+    'name'         : 'bson',
+    'mainModuleId' : 'bson',
+    'modules'      : [],
+    'parents'      : parents
+  };
+
+})({ 'binary': function(module, exports, global, require, undefined){
+  /**
+ * Module dependencies.
+ */
+if(typeof window === 'undefined') { 
+  var Buffer = require('buffer').Buffer; // TODO just use global Buffer
+}
+
+// Binary default subtype
+var BSON_BINARY_SUBTYPE_DEFAULT = 0;
+
+/**
+ * @ignore
+ * @api private
+ */
+var writeStringToArray = function(data) {
+  // Create a buffer
+  var buffer = typeof Uint8Array != 'undefined' ? new Uint8Array(new ArrayBuffer(data.length)) : new Array(data.length);
+  // Write the content to the buffer
+  for(var i = 0; i < data.length; i++) {
+    buffer[i] = data.charCodeAt(i);
+  }  
+  // Write the string to the buffer
+  return buffer;
+}
+
+/**
+ * Convert Array ot Uint8Array to Binary String
+ *
+ * @ignore
+ * @api private
+ */
+var convertArraytoUtf8BinaryString = function(byteArray, startIndex, endIndex) {
+  var result = "";
+  for(var i = startIndex; i < endIndex; i++) {
+   result = result + String.fromCharCode(byteArray[i]);
+  }
+  return result;  
+};
+
+/**
+ * A class representation of the BSON Binary type.
+ * 
+ * Sub types
+ *  - **BSON.BSON_BINARY_SUBTYPE_DEFAULT**, default BSON type.
+ *  - **BSON.BSON_BINARY_SUBTYPE_FUNCTION**, BSON function type.
+ *  - **BSON.BSON_BINARY_SUBTYPE_BYTE_ARRAY**, BSON byte array type.
+ *  - **BSON.BSON_BINARY_SUBTYPE_UUID**, BSON uuid type.
+ *  - **BSON.BSON_BINARY_SUBTYPE_MD5**, BSON md5 type.
+ *  - **BSON.BSON_BINARY_SUBTYPE_USER_DEFINED**, BSON user defined type.
+ *
+ * @class Represents the Binary BSON type.
+ * @param {Buffer} buffer a buffer object containing the binary data.
+ * @param {Number} [subType] the option binary type.
+ * @return {Grid}
+ */
+function Binary(buffer, subType) {
+  if(!(this instanceof Binary)) return new Binary(buffer, subType);
+  
+  this._bsontype = 'Binary';
+
+  if(buffer instanceof Number) {
+    this.sub_type = buffer;
+    this.position = 0;
+  } else {    
+    this.sub_type = subType == null ? BSON_BINARY_SUBTYPE_DEFAULT : subType;
+    this.position = 0;
+  }
+
+  if(buffer != null && !(buffer instanceof Number)) {
+    // Only accept Buffer, Uint8Array or Arrays
+    if(typeof buffer == 'string') {
+      // Different ways of writing the length of the string for the different types
+      if(typeof Buffer != 'undefined') {
+        this.buffer = new Buffer(buffer);
+      } else if(typeof Uint8Array != 'undefined' || (Object.prototype.toString.call(buffer) == '[object Array]')) {
+        this.buffer = writeStringToArray(buffer);
+      } else {
+        throw new Error("only String, Buffer, Uint8Array or Array accepted");
+      }
+    } else {
+      this.buffer = buffer;      
+    }
+    this.position = buffer.length;
+  } else {
+    if(typeof Buffer != 'undefined') {
+      this.buffer =  new Buffer(Binary.BUFFER_SIZE);      
+    } else if(typeof Uint8Array != 'undefined'){
+      this.buffer = new Uint8Array(new ArrayBuffer(Binary.BUFFER_SIZE));
+    } else {
+      this.buffer = new Array(Binary.BUFFER_SIZE);
+    }
+    // Set position to start of buffer
+    this.position = 0;
+  }
+};
+
+/**
+ * Updates this binary with byte_value.
+ *
+ * @param {Character} byte_value a single byte we wish to write.
+ * @api public
+ */
+Binary.prototype.put = function put(byte_value) {
+  // If it's a string and a has more than one character throw an error
+  if(byte_value['length'] != null && typeof byte_value != 'number' && byte_value.length != 1) throw new Error("only accepts single character String, Uint8Array or Array");
+  if(typeof byte_value != 'number' && byte_value < 0 || byte_value > 255) throw new Error("only accepts number in a valid unsigned byte range 0-255");
+  
+  // Decode the byte value once
+  var decoded_byte = null;
+  if(typeof byte_value == 'string') {
+    decoded_byte = byte_value.charCodeAt(0);      
+  } else if(byte_value['length'] != null) {
+    decoded_byte = byte_value[0];
+  } else {
+    decoded_byte = byte_value;
+  }
+  
+  if(this.buffer.length > this.position) {
+    this.buffer[this.position++] = decoded_byte;
+  } else {
+    if(typeof Buffer != 'undefined' && Buffer.isBuffer(this.buffer)) {    
+      // Create additional overflow buffer
+      var buffer = new Buffer(Binary.BUFFER_SIZE + this.buffer.length);
+      // Combine the two buffers together
+      this.buffer.copy(buffer, 0, 0, this.buffer.length);
+      this.buffer = buffer;
+      this.buffer[this.position++] = decoded_byte;
+    } else {
+      var buffer = null;
+      // Create a new buffer (typed or normal array)
+      if(Object.prototype.toString.call(this.buffer) == '[object Uint8Array]') {
+        buffer = new Uint8Array(new ArrayBuffer(Binary.BUFFER_SIZE + this.buffer.length));
+      } else {
+        buffer = new Array(Binary.BUFFER_SIZE + this.buffer.length);
+      }      
+      
+      // We need to copy all the content to the new array
+      for(var i = 0; i < this.buffer.length; i++) {
+        buffer[i] = this.buffer[i];
+      }
+      
+      // Reassign the buffer
+      this.buffer = buffer;
+      // Write the byte
+      this.buffer[this.position++] = decoded_byte;
+    }
+  }
+};
+
+/**
+ * Writes a buffer or string to the binary.
+ *
+ * @param {Buffer|String} string a string or buffer to be written to the Binary BSON object.
+ * @param {Number} offset specify the binary of where to write the content.
+ * @api public
+ */
+Binary.prototype.write = function write(string, offset) {
+  offset = typeof offset == 'number' ? offset : this.position;
+
+  // If the buffer is to small let's extend the buffer
+  if(this.buffer.length < offset + string.length) {
+    var buffer = null;
+    // If we are in node.js
+    if(typeof Buffer != 'undefined' && Buffer.isBuffer(this.buffer)) {      
+      buffer = new Buffer(this.buffer.length + string.length);
+      this.buffer.copy(buffer, 0, 0, this.buffer.length);      
+    } else if(Object.prototype.toString.call(this.buffer) == '[object Uint8Array]') {
+      // Create a new buffer
+      buffer = new Uint8Array(new ArrayBuffer(this.buffer.length + string.length))
+      // Copy the content
+      for(var i = 0; i < this.position; i++) {
+        buffer[i] = this.buffer[i];
+      }
+    }
+    
+    // Assign the new buffer
+    this.buffer = buffer;
+  }
+
+  if(typeof Buffer != 'undefined' && Buffer.isBuffer(string) && Buffer.isBuffer(this.buffer)) {
+    string.copy(this.buffer, offset, 0, string.length);
+    this.position = (offset + string.length) > this.position ? (offset + string.length) : this.position;
+    // offset = string.length
+  } else if(typeof Buffer != 'undefined' && typeof string == 'string' && Buffer.isBuffer(this.buffer)) {
+    this.buffer.write(string, 'binary', offset);
+    this.position = (offset + string.length) > this.position ? (offset + string.length) : this.position;
+    // offset = string.length;
+  } else if(Object.prototype.toString.call(string) == '[object Uint8Array]' 
+    || Object.prototype.toString.call(string) == '[object Array]' && typeof string != 'string') {      
+    for(var i = 0; i < string.length; i++) {
+      this.buffer[offset++] = string[i];
+    }    
+
+    this.position = offset > this.position ? offset : this.position;
+  } else if(typeof string == 'string') {
+    for(var i = 0; i < string.length; i++) {
+      this.buffer[offset++] = string.charCodeAt(i);
+    }
+
+    this.position = offset > this.position ? offset : this.position;
+  }
+};
+
+/**
+ * Reads **length** bytes starting at **position**.
+ *
+ * @param {Number} position read from the given position in the Binary.
+ * @param {Number} length the number of bytes to read.
+ * @return {Buffer}
+ * @api public
+ */
+Binary.prototype.read = function read(position, length) {
+  length = length && length > 0
+    ? length
+    : this.position;
+  
+  // Let's return the data based on the type we have
+  if(this.buffer['slice']) {
+    return this.buffer.slice(position, position + length);
+  } else {
+    // Create a buffer to keep the result
+    var buffer = typeof Uint8Array != 'undefined' ? new Uint8Array(new ArrayBuffer(length)) : new Array(length);
+    for(var i = 0; i < length; i++) {
+      buffer[i] = this.buffer[position++];
+    }
+  }
+  // Return the buffer
+  return buffer;
+};
+
+/**
+ * Returns the value of this binary as a string.
+ *
+ * @return {String}
+ * @api public
+ */
+Binary.prototype.value = function value(asRaw) {
+  asRaw = asRaw == null ? false : asRaw;  
+  
+  // If it's a node.js buffer object
+  if(typeof Buffer != 'undefined' && Buffer.isBuffer(this.buffer)) {
+    return asRaw ? this.buffer.slice(0, this.position) : this.buffer.toString('binary', 0, this.position);
+  } else {
+    if(asRaw) {
+      // we support the slice command use it
+      if(this.buffer['slice'] != null) {
+        return this.buffer.slice(0, this.position);
+      } else {
+        // Create a new buffer to copy content to
+        var newBuffer = Object.prototype.toString.call(this.buffer) == '[object Uint8Array]' ? new Uint8Array(new ArrayBuffer(this.position)) : new Array(this.position);
+        // Copy content
+        for(var i = 0; i < this.position; i++) {
+          newBuffer[i] = this.buffer[i];
+        }
+        // Return the buffer
+        return newBuffer;
+      }
+    } else {
+      return convertArraytoUtf8BinaryString(this.buffer, 0, this.position);
+    }
+  }
+};
+
+/**
+ * Length.
+ *
+ * @return {Number} the length of the binary.
+ * @api public
+ */
+Binary.prototype.length = function length() {
+  return this.position;
+};
+
+/**
+ * @ignore
+ * @api private
+ */
+Binary.prototype.toJSON = function() {
+  return this.buffer != null ? this.buffer.toString('base64') : '';
+}
+
+/**
+ * @ignore
+ * @api private
+ */
+Binary.prototype.toString = function(format) {
+  return this.buffer != null ? this.buffer.slice(0, this.position).toString(format) : '';
+}
+
+Binary.BUFFER_SIZE = 256;
+
+/**
+ * Default BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_DEFAULT = 0;
+/**
+ * Function BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_FUNCTION = 1;
+/**
+ * Byte Array BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_BYTE_ARRAY = 2;
+/**
+ * OLD UUID BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_UUID_OLD = 3;
+/**
+ * UUID BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_UUID = 4;
+/**
+ * MD5 BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_MD5 = 5;
+/**
+ * User BSON type
+ *  
+ * @classconstant SUBTYPE_DEFAULT
+ **/
+Binary.SUBTYPE_USER_DEFINED = 128;
+
+/**
+ * Expose.
+ */
+exports.Binary = Binary;
+
+
+}, 
+
+
+
+'binary_parser': function(module, exports, global, require, undefined){
+  /**
+ * Binary Parser.
+ * Jonas Raoni Soares Silva
+ * http://jsfromhell.com/classes/binary-parser [v1.0]
+ */
+var chr = String.fromCharCode;
+
+var maxBits = [];
+for (var i = 0; i < 64; i++) {
+	maxBits[i] = Math.pow(2, i);
+}
+
+function BinaryParser (bigEndian, allowExceptions) {
+  if(!(this instanceof BinaryParser)) return new BinaryParser(bigEndian, allowExceptions);
+  
+	this.bigEndian = bigEndian;
+	this.allowExceptions = allowExceptions;
+};
+
+BinaryParser.warn = function warn (msg) {
+	if (this.allowExceptions) {
+		throw new Error(msg);
+  }
+
+	return 1;
+};
+
+BinaryParser.decodeFloat = function decodeFloat (data, precisionBits, exponentBits) {
+	var b = new this.Buffer(this.bigEndian, data);
+
+	b.checkBuffer(precisionBits + exponentBits + 1);
+
+	var bias = maxBits[exponentBits - 1] - 1
+    , signal = b.readBits(precisionBits + exponentBits, 1)
+    , exponent = b.readBits(precisionBits, exponentBits)
+    , significand = 0
+    , divisor = 2
+    , curByte = b.buffer.length + (-precisionBits >> 3) - 1;
+
+	do {
+		for (var byteValue = b.buffer[ ++curByte ], startBit = precisionBits % 8 || 8, mask = 1 << startBit; mask >>= 1; ( byteValue & mask ) && ( significand += 1 / divisor ), divisor *= 2 );
+	} while (precisionBits -= startBit);
+
+	return exponent == ( bias << 1 ) + 1 ? significand ? NaN : signal ? -Infinity : +Infinity : ( 1 + signal * -2 ) * ( exponent || significand ? !exponent ? Math.pow( 2, -bias + 1 ) * significand : Math.pow( 2, exponent - bias ) * ( 1 + significand ) : 0 );
+};
+
+BinaryParser.decodeInt = function decodeInt (data, bits, signed, forceBigEndian) {
+  var b = new this.Buffer(this.bigEndian || forceBigEndian, data)
+      , x = b.readBits(0, bits)
+      , max = maxBits[bits]; //max = Math.pow( 2, bits );
+  
+  return signed && x >= max / 2
+      ? x - max
+      : x;
+};
+
+BinaryParser.encodeFloat = function encodeFloat (data, precisionBits, exponentBits) {
+	var bias = maxBits[exponentBits - 1] - 1
+    , minExp = -bias + 1
+    , maxExp = bias
+    , minUnnormExp = minExp - precisionBits
+    , n = parseFloat(data)
+    , status = isNaN(n) || n == -Infinity || n == +Infinity ? n : 0
+    ,	exp = 0
+    , len = 2 * bias + 1 + precisionBits + 3
+    , bin = new Array(len)
+    , signal = (n = status !== 0 ? 0 : n) < 0
+    , intPart = Math.floor(n = Math.abs(n))
+    , floatPart = n - intPart
+    , lastBit
+    , rounded
+    , result
+    , i
+    , j;
+
+	for (i = len; i; bin[--i] = 0);
+
+	for (i = bias + 2; intPart && i; bin[--i] = intPart % 2, intPart = Math.floor(intPart / 2));
+
+	for (i = bias + 1; floatPart > 0 && i; (bin[++i] = ((floatPart *= 2) >= 1) - 0 ) && --floatPart);
+
+	for (i = -1; ++i < len && !bin[i];);
+
+	if (bin[(lastBit = precisionBits - 1 + (i = (exp = bias + 1 - i) >= minExp && exp <= maxExp ? i + 1 : bias + 1 - (exp = minExp - 1))) + 1]) {
+		if (!(rounded = bin[lastBit])) {
+			for (j = lastBit + 2; !rounded && j < len; rounded = bin[j++]);
+		}
+
+		for (j = lastBit + 1; rounded && --j >= 0; (bin[j] = !bin[j] - 0) && (rounded = 0));
+	}
+
+	for (i = i - 2 < 0 ? -1 : i - 3; ++i < len && !bin[i];);
+
+	if ((exp = bias + 1 - i) >= minExp && exp <= maxExp) {
+		++i;
+  } else if (exp < minExp) {
+		exp != bias + 1 - len && exp < minUnnormExp && this.warn("encodeFloat::float underflow");
+		i = bias + 1 - (exp = minExp - 1);
+	}
+
+	if (intPart || status !== 0) {
+		this.warn(intPart ? "encodeFloat::float overflow" : "encodeFloat::" + status);
+		exp = maxExp + 1;
+		i = bias + 2;
+
+		if (status == -Infinity) {
+			signal = 1;
+    } else if (isNaN(status)) {
+			bin[i] = 1;
+    }
+	}
+
+	for (n = Math.abs(exp + bias), j = exponentBits + 1, result = ""; --j; result = (n % 2) + result, n = n >>= 1);
+
+	for (n = 0, j = 0, i = (result = (signal ? "1" : "0") + result + bin.slice(i, i + precisionBits).join("")).length, r = []; i; j = (j + 1) % 8) {
+		n += (1 << j) * result.charAt(--i);
+		if (j == 7) {
+			r[r.length] = String.fromCharCode(n);
+			n = 0;
+		}
+	}
+
+	r[r.length] = n
+    ? String.fromCharCode(n)
+    : "";
+
+	return (this.bigEndian ? r.reverse() : r).join("");
+};
+
+BinaryParser.encodeInt = function encodeInt (data, bits, signed, forceBigEndian) {
+	var max = maxBits[bits];
+
+  if (data >= max || data < -(max / 2)) {
+    this.warn("encodeInt::overflow");
+    data = 0;
+  }
+
+	if (data < 0) {
+    data += max;
+  }
+
+	for (var r = []; data; r[r.length] = String.fromCharCode(data % 256), data = Math.floor(data / 256));
+
+	for (bits = -(-bits >> 3) - r.length; bits--; r[r.length] = "\0");
+
+  return ((this.bigEndian || forceBigEndian) ? r.reverse() : r).join("");
+};
+
+BinaryParser.toSmall    = function( data ){ return this.decodeInt( data,  8, true  ); };
+BinaryParser.fromSmall  = function( data ){ return this.encodeInt( data,  8, true  ); };
+BinaryParser.toByte     = function( data ){ return this.decodeInt( data,  8, false ); };
+BinaryParser.fromByte   = function( data ){ return this.encodeInt( data,  8, false ); };
+BinaryParser.toShort    = function( data ){ return this.decodeInt( data, 16, true  ); };
+BinaryParser.fromShort  = function( data ){ return this.encodeInt( data, 16, true  ); };
+BinaryParser.toWord     = function( data ){ return this.decodeInt( data, 16, false ); };
+BinaryParser.fromWord   = function( data ){ return this.encodeInt( data, 16, false ); };
+BinaryParser.toInt      = function( data ){ return this.decodeInt( data, 32, true  ); };
+BinaryParser.fromInt    = function( data ){ return this.encodeInt( data, 32, true  ); };
+BinaryParser.toLong     = function( data ){ return this.decodeInt( data, 64, true  ); };
+BinaryParser.fromLong   = function( data ){ return this.encodeInt( data, 64, true  ); };
+BinaryParser.toDWord    = function( data ){ return this.decodeInt( data, 32, false ); };
+BinaryParser.fromDWord  = function( data ){ return this.encodeInt( data, 32, false ); };
+BinaryParser.toQWord    = function( data ){ return this.decodeInt( data, 64, true ); };
+BinaryParser.fromQWord  = function( data ){ return this.encodeInt( data, 64, true ); };
+BinaryParser.toFloat    = function( data ){ return this.decodeFloat( data, 23, 8   ); };
+BinaryParser.fromFloat  = function( data ){ return this.encodeFloat( data, 23, 8   ); };
+BinaryParser.toDouble   = function( data ){ return this.decodeFloat( data, 52, 11  ); };
+BinaryParser.fromDouble = function( data ){ return this.encodeFloat( data, 52, 11  ); };
+
+// Factor out the encode so it can be shared by add_header and push_int32
+BinaryParser.encode_int32 = function encode_int32 (number, asArray) {
+  var a, b, c, d, unsigned;
+  unsigned = (number < 0) ? (number + 0x100000000) : number;
+  a = Math.floor(unsigned / 0xffffff);
+  unsigned &= 0xffffff;
+  b = Math.floor(unsigned / 0xffff);
+  unsigned &= 0xffff;
+  c = Math.floor(unsigned / 0xff);
+  unsigned &= 0xff;
+  d = Math.floor(unsigned);
+  return asArray ? [chr(a), chr(b), chr(c), chr(d)] : chr(a) + chr(b) + chr(c) + chr(d);
+};
+
+BinaryParser.encode_int64 = function encode_int64 (number) {
+  var a, b, c, d, e, f, g, h, unsigned;
+  unsigned = (number < 0) ? (number + 0x10000000000000000) : number;
+  a = Math.floor(unsigned / 0xffffffffffffff);
+  unsigned &= 0xffffffffffffff;
+  b = Math.floor(unsigned / 0xffffffffffff);
+  unsigned &= 0xffffffffffff;
+  c = Math.floor(unsigned / 0xffffffffff);
+  unsigned &= 0xffffffffff;
+  d = Math.floor(unsigned / 0xffffffff);
+  unsigned &= 0xffffffff;
+  e = Math.floor(unsigned / 0xffffff);
+  unsigned &= 0xffffff;
+  f = Math.floor(unsigned / 0xffff);
+  unsigned &= 0xffff;
+  g = Math.floor(unsigned / 0xff);
+  unsigned &= 0xff;
+  h = Math.floor(unsigned);
+  return chr(a) + chr(b) + chr(c) + chr(d) + chr(e) + chr(f) + chr(g) + chr(h);
+};
+
+/**
+ * UTF8 methods
+ */
+
+// Take a raw binary string and return a utf8 string
+BinaryParser.decode_utf8 = function decode_utf8 (binaryStr) {
+  var len = binaryStr.length
+    , decoded = ''
+    , i = 0
+    , c = 0
+    , c1 = 0
+    , c2 = 0
+    , c3;
+
+  while (i < len) {
+    c = binaryStr.charCodeAt(i);
+    if (c < 128) {
+      decoded += String.fromCharCode(c);
+      i++;
+    } else if ((c > 191) && (c < 224)) {
+	    c2 = binaryStr.charCodeAt(i+1);
+      decoded += String.fromCharCode(((c & 31) << 6) | (c2 & 63));
+      i += 2;
+    } else {
+	    c2 = binaryStr.charCodeAt(i+1);
+	    c3 = binaryStr.charCodeAt(i+2);
+      decoded += String.fromCharCode(((c & 15) << 12) | ((c2 & 63) << 6) | (c3 & 63));
+      i += 3;
+    }
+  }
+
+  return decoded;
+};
+
+// Encode a cstring
+BinaryParser.encode_cstring = function encode_cstring (s) {
+  return unescape(encodeURIComponent(s)) + BinaryParser.fromByte(0);
+};
+
+// Take a utf8 string and return a binary string
+BinaryParser.encode_utf8 = function encode_utf8 (s) {
+  var a = ""
+    , c;
+
+  for (var n = 0, len = s.length; n < len; n++) {
+    c = s.charCodeAt(n);
+
+    if (c < 128) {
+	    a += String.fromCharCode(c);
+    } else if ((c > 127) && (c < 2048)) {
+	    a += String.fromCharCode((c>>6) | 192) ;
+	    a += String.fromCharCode((c&63) | 128);
+    } else {
+      a += String.fromCharCode((c>>12) | 224);
+      a += String.fromCharCode(((c>>6) & 63) | 128);
+      a += String.fromCharCode((c&63) | 128);
+    }
+  }
+
+  return a;
+};
+
+BinaryParser.hprint = function hprint (s) {
+  var number;
+
+  for (var i = 0, len = s.length; i < len; i++) {
+    if (s.charCodeAt(i) < 32) {
+      number = s.charCodeAt(i) <= 15
+        ? "0" + s.charCodeAt(i).toString(16)
+        : s.charCodeAt(i).toString(16);        
+      process.stdout.write(number + " ")
+    } else {
+      number = s.charCodeAt(i) <= 15
+        ? "0" + s.charCodeAt(i).toString(16)
+        : s.charCodeAt(i).toString(16);
+        process.stdout.write(number + " ")
+    }
+  }
+  
+  process.stdout.write("\n\n");
+};
+
+BinaryParser.ilprint = function hprint (s) {
+  var number;
+
+  for (var i = 0, len = s.length; i < len; i++) {
+    if (s.charCodeAt(i) < 32) {
+      number = s.charCodeAt(i) <= 15
+        ? "0" + s.charCodeAt(i).toString(10)
+        : s.charCodeAt(i).toString(10);
+
+      require('util').debug(number+' : ');
+    } else {
+      number = s.charCodeAt(i) <= 15
+        ? "0" + s.charCodeAt(i).toString(10)
+        : s.charCodeAt(i).toString(10);
+      require('util').debug(number+' : '+ s.charAt(i));
+    }
+  }
+};
+
+BinaryParser.hlprint = function hprint (s) {
+  var number;
+
+  for (var i = 0, len = s.length; i < len; i++) {
+    if (s.charCodeAt(i) < 32) {
+      number = s.charCodeAt(i) <= 15
+        ? "0" + s.charCodeAt(i).toString(16)
+        : s.charCodeAt(i).toString(16);
+      require('util').debug(number+' : ');
+    } else {
+      number = s.charCodeAt(i) <= 15
+        ? "0" + s.charCodeAt(i).toString(16)
+        : s.charCodeAt(i).toString(16);
+      require('util').debug(number+' : '+ s.charAt(i));
+    }
+  }
+};
+
+/**
+ * BinaryParser buffer constructor.
+ */
+function BinaryParserBuffer (bigEndian, buffer) {
+  this.bigEndian = bigEndian || 0;
+  this.buffer = [];
+  this.setBuffer(buffer);
+};
+
+BinaryParserBuffer.prototype.setBuffer = function setBuffer (data) {
+  var l, i, b;
+
+	if (data) {
+    i = l = data.length;
+    b = this.buffer = new Array(l);
+		for (; i; b[l - i] = data.charCodeAt(--i));
+		this.bigEndian && b.reverse();
+	}
+};
+
+BinaryParserBuffer.prototype.hasNeededBits = function hasNeededBits (neededBits) {
+	return this.buffer.length >= -(-neededBits >> 3);
+};
+
+BinaryParserBuffer.prototype.checkBuffer = function checkBuffer (neededBits) {
+	if (!this.hasNeededBits(neededBits)) {
+		throw new Error("checkBuffer::missing bytes");
+  }
+};
+
+BinaryParserBuffer.prototype.readBits = function readBits (start, length) {
+	//shl fix: Henri Torgemane ~1996 (compressed by Jonas Raoni)
+
+	function shl (a, b) {
+		for (; b--; a = ((a %= 0x7fffffff + 1) & 0x40000000) == 0x40000000 ? a * 2 : (a - 0x40000000) * 2 + 0x7fffffff + 1);
+		return a;
+	}
+
+	if (start < 0 || length <= 0) {
+		return 0;
+  }
+
+	this.checkBuffer(start + length);
+
+  var offsetLeft
+    , offsetRight = start % 8
+    , curByte = this.buffer.length - ( start >> 3 ) - 1
+    , lastByte = this.buffer.length + ( -( start + length ) >> 3 )
+    , diff = curByte - lastByte
+    , sum = ((this.buffer[ curByte ] >> offsetRight) & ((1 << (diff ? 8 - offsetRight : length)) - 1)) + (diff && (offsetLeft = (start + length) % 8) ? (this.buffer[lastByte++] & ((1 << offsetLeft) - 1)) << (diff-- << 3) - offsetRight : 0);
+
+	for(; diff; sum += shl(this.buffer[lastByte++], (diff-- << 3) - offsetRight));
+
+	return sum;
+};
+
+/**
+ * Expose.
+ */
+BinaryParser.Buffer = BinaryParserBuffer;
+
+exports.BinaryParser = BinaryParser;
+
+}, 
+
+
+
+'bson': function(module, exports, global, require, undefined){
+  var Long = require('./long').Long
+  , Double = require('./double').Double
+  , Timestamp = require('./timestamp').Timestamp
+  , ObjectID = require('./objectid').ObjectID
+  , Symbol = require('./symbol').Symbol
+  , Code = require('./code').Code
+  , MinKey = require('./min_key').MinKey
+  , MaxKey = require('./max_key').MaxKey
+  , DBRef = require('./db_ref').DBRef
+  , Binary = require('./binary').Binary
+  , BinaryParser = require('./binary_parser').BinaryParser
+  , writeIEEE754 = require('./float_parser').writeIEEE754
+  , readIEEE754 = require('./float_parser').readIEEE754
+
+// To ensure that 0.4 of node works correctly
+var isDate = function isDate(d) {
+  return typeof d === 'object' && Object.prototype.toString.call(d) === '[object Date]';
+}
+
+/**
+ * Create a new BSON instance
+ *
+ * @class Represents the BSON Parser
+ * @return {BSON} instance of BSON Parser.
+ */
+function BSON () {};
+
+/**
+ * @ignore
+ * @api private
+ */
+// BSON MAX VALUES
+BSON.BSON_INT32_MAX = 0x7FFFFFFF;
+BSON.BSON_INT32_MIN = -0x80000000;
+
+BSON.BSON_INT64_MAX = Math.pow(2, 63) - 1;
+BSON.BSON_INT64_MIN = -Math.pow(2, 63);
+
+// JS MAX PRECISE VALUES
+BSON.JS_INT_MAX = 0x20000000000000;  // Any integer up to 2^53 can be precisely represented by a double.
+BSON.JS_INT_MIN = -0x20000000000000;  // Any integer down to -2^53 can be precisely represented by a double.
+
+// Internal long versions
+var JS_INT_MAX_LONG = Long.fromNumber(0x20000000000000);  // Any integer up to 2^53 can be precisely represented by a double.
+var JS_INT_MIN_LONG = Long.fromNumber(-0x20000000000000);  // Any integer down to -2^53 can be precisely represented by a double.
+
+/**
+ * Number BSON Type
+ *
+ * @classconstant BSON_DATA_NUMBER
+ **/
+BSON.BSON_DATA_NUMBER = 1;
+/**
+ * String BSON Type
+ *
+ * @classconstant BSON_DATA_STRING
+ **/
+BSON.BSON_DATA_STRING = 2;
+/**
+ * Object BSON Type
+ *
+ * @classconstant BSON_DATA_OBJECT
+ **/
+BSON.BSON_DATA_OBJECT = 3;
+/**
+ * Array BSON Type
+ *
+ * @classconstant BSON_DATA_ARRAY
+ **/
+BSON.BSON_DATA_ARRAY = 4;
+/**
+ * Binary BSON Type
+ *
+ * @classconstant BSON_DATA_BINARY
+ **/
+BSON.BSON_DATA_BINARY = 5;
+/**
+ * ObjectID BSON Type
+ *
+ * @classconstant BSON_DATA_OID
+ **/
+BSON.BSON_DATA_OID = 7;
+/**
+ * Boolean BSON Type
+ *
+ * @classconstant BSON_DATA_BOOLEAN
+ **/
+BSON.BSON_DATA_BOOLEAN = 8;
+/**
+ * Date BSON Type
+ *
+ * @classconstant BSON_DATA_DATE
+ **/
+BSON.BSON_DATA_DATE = 9;
+/**
+ * null BSON Type
+ *
+ * @classconstant BSON_DATA_NULL
+ **/
+BSON.BSON_DATA_NULL = 10;
+/**
+ * RegExp BSON Type
+ *
+ * @classconstant BSON_DATA_REGEXP
+ **/
+BSON.BSON_DATA_REGEXP = 11;
+/**
+ * Code BSON Type
+ *
+ * @classconstant BSON_DATA_CODE
+ **/
+BSON.BSON_DATA_CODE = 13;
+/**
+ * Symbol BSON Type
+ *
+ * @classconstant BSON_DATA_SYMBOL
+ **/
+BSON.BSON_DATA_SYMBOL = 14;
+/**
+ * Code with Scope BSON Type
+ *
+ * @classconstant BSON_DATA_CODE_W_SCOPE
+ **/
+BSON.BSON_DATA_CODE_W_SCOPE = 15;
+/**
+ * 32 bit Integer BSON Type
+ *
+ * @classconstant BSON_DATA_INT
+ **/
+BSON.BSON_DATA_INT = 16;
+/**
+ * Timestamp BSON Type
+ *
+ * @classconstant BSON_DATA_TIMESTAMP
+ **/
+BSON.BSON_DATA_TIMESTAMP = 17;
+/**
+ * Long BSON Type
+ *
+ * @classconstant BSON_DATA_LONG
+ **/
+BSON.BSON_DATA_LONG = 18;
+/**
+ * MinKey BSON Type
+ *
+ * @classconstant BSON_DATA_MIN_KEY
+ **/
+BSON.BSON_DATA_MIN_KEY = 0xff;
+/**
+ * MaxKey BSON Type
+ *
+ * @classconstant BSON_DATA_MAX_KEY
+ **/
+BSON.BSON_DATA_MAX_KEY = 0x7f;
+
+/**
+ * Binary Default Type
+ *
+ * @classconstant BSON_BINARY_SUBTYPE_DEFAULT
+ **/
+BSON.BSON_BINARY_SUBTYPE_DEFAULT = 0;
+/**
+ * Binary Function Type
+ *
+ * @classconstant BSON_BINARY_SUBTYPE_FUNCTION
+ **/
+BSON.BSON_BINARY_SUBTYPE_FUNCTION = 1;
+/**
+ * Binary Byte Array Type
+ *
+ * @classconstant BSON_BINARY_SUBTYPE_BYTE_ARRAY
+ **/
+BSON.BSON_BINARY_SUBTYPE_BYTE_ARRAY = 2;
+/**
+ * Binary UUID Type
+ *
+ * @classconstant BSON_BINARY_SUBTYPE_UUID
+ **/
+BSON.BSON_BINARY_SUBTYPE_UUID = 3;
+/**
+ * Binary MD5 Type
+ *
+ * @classconstant BSON_BINARY_SUBTYPE_MD5
+ **/
+BSON.BSON_BINARY_SUBTYPE_MD5 = 4;
+/**
+ * Binary User Defined Type
+ *
+ * @classconstant BSON_BINARY_SUBTYPE_USER_DEFINED
+ **/
+BSON.BSON_BINARY_SUBTYPE_USER_DEFINED = 128;
+
+/**
+ * Calculate the bson size for a passed in Javascript object.
+ *
+ * @param {Object} object the Javascript object to calculate the BSON byte size for.
+ * @param {Boolean} [serializeFunctions] serialize all functions in the object **(default:false)**.
+ * @return {Number} returns the number of bytes the BSON object will take up.
+ * @api public
+ */
+BSON.calculateObjectSize = function calculateObjectSize(object, serializeFunctions) {
+  var totalLength = (4 + 1);
+
+  if(Array.isArray(object)) {
+    for(var i = 0; i < object.length; i++) {
+      totalLength += calculateElement(i.toString(), object[i], serializeFunctions)
+    }
+  } else {
+		// If we have toBSON defined, override the current object
+		if(object.toBSON) {
+			object = object.toBSON();
+		}
+
+		// Calculate size
+    for(var key in object) {
+      totalLength += calculateElement(key, object[key], serializeFunctions)
+    }
+  }
+
+  return totalLength;
+}
+
+/**
+ * @ignore
+ * @api private
+ */
+function calculateElement(name, value, serializeFunctions) {
+  var isBuffer = typeof Buffer !== 'undefined';
+
+  switch(typeof value) {
+    case 'string':
+      return 1 + (!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1 + 4 + (!isBuffer ? numberOfBytes(value) : Buffer.byteLength(value, 'utf8')) + 1;
+    case 'number':
+      if(Math.floor(value) === value && value >= BSON.JS_INT_MIN && value <= BSON.JS_INT_MAX) {
+        if(value >= BSON.BSON_INT32_MIN && value <= BSON.BSON_INT32_MAX) { // 32 bit
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (4 + 1);
+        } else {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (8 + 1);
+        }
+      } else {  // 64 bit
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (8 + 1);
+      }
+    case 'undefined':
+      return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (1);
+    case 'boolean':
+      return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (1 + 1);
+    case 'object':
+      if(value == null || value instanceof MinKey || value instanceof MaxKey || value['_bsontype'] == 'MinKey' || value['_bsontype'] == 'MaxKey') {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (1);
+      } else if(value instanceof ObjectID || value['_bsontype'] == 'ObjectID') {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (12 + 1);
+      } else if(value instanceof Date || isDate(value)) {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (8 + 1);
+      } else if(typeof Buffer !== 'undefined' && Buffer.isBuffer(value)) {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (1 + 4 + 1) + value.length;
+      } else if(value instanceof Long || value instanceof Double || value instanceof Timestamp
+          || value['_bsontype'] == 'Long' || value['_bsontype'] == 'Double' || value['_bsontype'] == 'Timestamp') {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (8 + 1);
+      } else if(value instanceof Code || value['_bsontype'] == 'Code') {
+        // Calculate size depending on the availability of a scope
+        if(value.scope != null && Object.keys(value.scope).length > 0) {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + 4 + 4 + (!isBuffer ? numberOfBytes(value.code.toString()) : Buffer.byteLength(value.code.toString(), 'utf8')) + 1 + BSON.calculateObjectSize(value.scope, serializeFunctions);
+        } else {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + 4 + (!isBuffer ? numberOfBytes(value.code.toString()) : Buffer.byteLength(value.code.toString(), 'utf8')) + 1;
+        }
+      } else if(value instanceof Binary || value['_bsontype'] == 'Binary') {
+        // Check what kind of subtype we have
+        if(value.sub_type == Binary.SUBTYPE_BYTE_ARRAY) {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (value.position + 1 + 4 + 1 + 4);
+        } else {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + (value.position + 1 + 4 + 1);
+        }
+      } else if(value instanceof Symbol || value['_bsontype'] == 'Symbol') {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + ((!isBuffer ? numberOfBytes(value.value) : Buffer.byteLength(value.value, 'utf8')) + 4 + 1 + 1);
+      } else if(value instanceof DBRef || value['_bsontype'] == 'DBRef') {
+        // Set up correct object for serialization
+        var ordered_values = {
+            '$ref': value.namespace
+          , '$id' : value.oid
+        };
+
+        // Add db reference if it exists
+        if(null != value.db) {
+          ordered_values['$db'] = value.db;
+        }
+
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + BSON.calculateObjectSize(ordered_values, serializeFunctions);
+      } else if(value instanceof RegExp || Object.prototype.toString.call(value) === '[object RegExp]') {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + (!isBuffer ? numberOfBytes(value.source) : Buffer.byteLength(value.source, 'utf8')) + 1
+            + (value.global ? 1 : 0) + (value.ignoreCase ? 1 : 0) + (value.multiline ? 1 : 0) + 1
+      } else {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + BSON.calculateObjectSize(value, serializeFunctions) + 1;
+      }
+    case 'function':
+      // WTF for 0.4.X where typeof /someregexp/ === 'function'
+      if(value instanceof RegExp || Object.prototype.toString.call(value) === '[object RegExp]' || String.call(value) == '[object RegExp]') {
+        return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + (!isBuffer ? numberOfBytes(value.source) : Buffer.byteLength(value.source, 'utf8')) + 1
+          + (value.global ? 1 : 0) + (value.ignoreCase ? 1 : 0) + (value.multiline ? 1 : 0) + 1
+      } else {
+        if(serializeFunctions && value.scope != null && Object.keys(value.scope).length > 0) {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + 4 + 4 + (!isBuffer ? numberOfBytes(value.toString()) : Buffer.byteLength(value.toString(), 'utf8')) + 1 + BSON.calculateObjectSize(value.scope, serializeFunctions);
+        } else if(serializeFunctions) {
+          return (name != null ? ((!isBuffer ? numberOfBytes(name) : Buffer.byteLength(name, 'utf8')) + 1) : 0) + 1 + 4 + (!isBuffer ? numberOfBytes(value.toString()) : Buffer.byteLength(value.toString(), 'utf8')) + 1;
+        }
+      }
+  }
+
+  return 0;
+}
+
+/**
+ * Serialize a Javascript object using a predefined Buffer and index into the buffer, useful when pre-allocating the space for serialization.
+ *
+ * @param {Object} object the Javascript object to serialize.
+ * @param {Boolean} checkKeys the serializer will check if keys are valid.
+ * @param {Buffer} buffer the Buffer you pre-allocated to store the serialized BSON object.
+ * @param {Number} index the index in the buffer where we wish to start serializing into.
+ * @param {Boolean} serializeFunctions serialize the javascript functions **(default:false)**.
+ * @return {Number} returns the new write index in the Buffer.
+ * @api public
+ */
+BSON.serializeWithBufferAndIndex = function serializeWithBufferAndIndex(object, checkKeys, buffer, index, serializeFunctions) {
+  // Default setting false
+  serializeFunctions = serializeFunctions == null ? false : serializeFunctions;
+  // Write end information (length of the object)
+  var size = buffer.length;
+  // Write the size of the object
+  buffer[index++] = size & 0xff;
+  buffer[index++] = (size >> 8) & 0xff;
+  buffer[index++] = (size >> 16) & 0xff;
+  buffer[index++] = (size >> 24) & 0xff;
+  return serializeObject(object, checkKeys, buffer, index, serializeFunctions) - 1;
+}
+
+/**
+ * @ignore
+ * @api private
+ */
+var serializeObject = function(object, checkKeys, buffer, index, serializeFunctions) {
+  // Process the object
+  if(Array.isArray(object)) {
+    for(var i = 0; i < object.length; i++) {
+      index = packElement(i.toString(), object[i], checkKeys, buffer, index, serializeFunctions);
+    }
+  } else {
+		// If we have toBSON defined, override the current object
+		if(object.toBSON) {
+			object = object.toBSON();
+		}
+
+		// Serialize the object
+    for(var key in object) {
+      // Check the key and throw error if it's illegal
+      if (key != '$db' && key != '$ref' && key != '$id') {
+        // dollars and dots ok
+        BSON.checkKey(key, !checkKeys);
+      }
+
+      // Pack the element
+      index = packElement(key, object[key], checkKeys, buffer, index, serializeFunctions);
+    }
+  }
+
+  // Write zero
+  buffer[index++] = 0;
+  return index;
+}
+
+var stringToBytes = function(str) {
+  var ch, st, re = [];
+  for (var i = 0; i < str.length; i++ ) {
+    ch = str.charCodeAt(i);  // get char
+    st = [];                 // set up "stack"
+    do {
+      st.push( ch & 0xFF );  // push byte to stack
+      ch = ch >> 8;          // shift value down by 1 byte
+    }
+    while ( ch );
+    // add stack contents to result
+    // done because chars have "wrong" endianness
+    re = re.concat( st.reverse() );
+  }
+  // return an array of bytes
+  return re;
+}
+
+var numberOfBytes = function(str) {
+  var ch, st, re = 0;
+  for (var i = 0; i < str.length; i++ ) {
+    ch = str.charCodeAt(i);  // get char
+    st = [];                 // set up "stack"
+    do {
+      st.push( ch & 0xFF );  // push byte to stack
+      ch = ch >> 8;          // shift value down by 1 byte
+    }
+    while ( ch );
+    // add stack contents to result
+    // done because chars have "wrong" endianness
+    re = re + st.length;
+  }
+  // return an array of bytes
+  return re;
+}
+
+/**
+ * @ignore
+ * @api private
+ */
+var writeToTypedArray = function(buffer, string, index) {
+  var bytes = stringToBytes(string);
+  for(var i = 0; i < bytes.length; i++) {
+    buffer[index + i] = bytes[i];
+  }
+  return bytes.length;
+}
+
+/**
+ * @ignore
+ * @api private
+ */
+var supportsBuffer = typeof Buffer != 'undefined';
+
+/**
+ * @ignore
+ * @api private
+ */
+var packElement = function(name, value, checkKeys, buffer, index, serializeFunctions) {
+  var startIndex = index;
+
+  switch(typeof value) {
+    case 'string':
+      // Encode String type
+      buffer[index++] = BSON.BSON_DATA_STRING;
+      // Number of written bytes
+      var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+      // Encode the name
+      index = index + numberOfWrittenBytes + 1;
+      buffer[index - 1] = 0;
+
+      // Calculate size
+      var size = supportsBuffer ? Buffer.byteLength(value) + 1 : numberOfBytes(value) + 1;
+      // Write the size of the string to buffer
+      buffer[index + 3] = (size >> 24) & 0xff;
+      buffer[index + 2] = (size >> 16) & 0xff;
+      buffer[index + 1] = (size >> 8) & 0xff;
+      buffer[index] = size & 0xff;
+      // Ajust the index
+      index = index + 4;
+      // Write the string
+      supportsBuffer ? buffer.write(value, index, 'utf8') : writeToTypedArray(buffer, value, index);
+      // Update index
+      index = index + size - 1;
+      // Write zero
+      buffer[index++] = 0;
+      // Return index
+      return index;
+    case 'number':
+      // We have an integer value
+      if(Math.floor(value) === value && value >= BSON.JS_INT_MIN && value <= BSON.JS_INT_MAX) {
+        // If the value fits in 32 bits encode as int, if it fits in a double
+        // encode it as a double, otherwise long
+        if(value >= BSON.BSON_INT32_MIN && value <= BSON.BSON_INT32_MAX) {
+          // Set int type 32 bits or less
+          buffer[index++] = BSON.BSON_DATA_INT;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          // Write the int value
+          buffer[index++] = value & 0xff;
+          buffer[index++] = (value >> 8) & 0xff;
+          buffer[index++] = (value >> 16) & 0xff;
+          buffer[index++] = (value >> 24) & 0xff;
+        } else if(value >= BSON.JS_INT_MIN && value <= BSON.JS_INT_MAX) {
+          // Encode as double
+          buffer[index++] = BSON.BSON_DATA_NUMBER;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          // Write float
+          writeIEEE754(buffer, value, index, 'little', 52, 8);
+          // Ajust index
+          index = index + 8;
+        } else {
+          // Set long type
+          buffer[index++] = BSON.BSON_DATA_LONG;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          var longVal = Long.fromNumber(value);
+          var lowBits = longVal.getLowBits();
+          var highBits = longVal.getHighBits();
+          // Encode low bits
+          buffer[index++] = lowBits & 0xff;
+          buffer[index++] = (lowBits >> 8) & 0xff;
+          buffer[index++] = (lowBits >> 16) & 0xff;
+          buffer[index++] = (lowBits >> 24) & 0xff;
+          // Encode high bits
+          buffer[index++] = highBits & 0xff;
+          buffer[index++] = (highBits >> 8) & 0xff;
+          buffer[index++] = (highBits >> 16) & 0xff;
+          buffer[index++] = (highBits >> 24) & 0xff;
+        }
+      } else {
+        // Encode as double
+        buffer[index++] = BSON.BSON_DATA_NUMBER;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Write float
+        writeIEEE754(buffer, value, index, 'little', 52, 8);
+        // Ajust index
+        index = index + 8;
+      }
+
+      return index;
+    case 'undefined':
+      // Set long type
+      buffer[index++] = BSON.BSON_DATA_NULL;
+      // Number of written bytes
+      var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+      // Encode the name
+      index = index + numberOfWrittenBytes + 1;
+      buffer[index - 1] = 0;
+      return index;
+    case 'boolean':
+      // Write the type
+      buffer[index++] = BSON.BSON_DATA_BOOLEAN;
+      // Number of written bytes
+      var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+      // Encode the name
+      index = index + numberOfWrittenBytes + 1;
+      buffer[index - 1] = 0;
+      // Encode the boolean value
+      buffer[index++] = value ? 1 : 0;
+      return index;
+    case 'object':
+      if(value === null || value instanceof MinKey || value instanceof MaxKey
+          || value['_bsontype'] == 'MinKey' || value['_bsontype'] == 'MaxKey') {
+        // Write the type of either min or max key
+        if(value === null) {
+          buffer[index++] = BSON.BSON_DATA_NULL;
+        } else if(value instanceof MinKey) {
+          buffer[index++] = BSON.BSON_DATA_MIN_KEY;
+        } else {
+          buffer[index++] = BSON.BSON_DATA_MAX_KEY;
+        }
+
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        return index;
+      } else if(value instanceof ObjectID || value['_bsontype'] == 'ObjectID') {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_OID;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+
+        // Write objectid
+        supportsBuffer ? buffer.write(value.id, index, 'binary') : writeToTypedArray(buffer, value.id, index);
+        // Ajust index
+        index = index + 12;
+        return index;
+      } else if(value instanceof Date || isDate(value)) {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_DATE;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+
+        // Write the date
+        var dateInMilis = Long.fromNumber(value.getTime());
+        var lowBits = dateInMilis.getLowBits();
+        var highBits = dateInMilis.getHighBits();
+        // Encode low bits
+        buffer[index++] = lowBits & 0xff;
+        buffer[index++] = (lowBits >> 8) & 0xff;
+        buffer[index++] = (lowBits >> 16) & 0xff;
+        buffer[index++] = (lowBits >> 24) & 0xff;
+        // Encode high bits
+        buffer[index++] = highBits & 0xff;
+        buffer[index++] = (highBits >> 8) & 0xff;
+        buffer[index++] = (highBits >> 16) & 0xff;
+        buffer[index++] = (highBits >> 24) & 0xff;
+        return index;
+      } else if(typeof Buffer !== 'undefined' && Buffer.isBuffer(value)) {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_BINARY;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Get size of the buffer (current write point)
+        var size = value.length;
+        // Write the size of the string to buffer
+        buffer[index++] = size & 0xff;
+        buffer[index++] = (size >> 8) & 0xff;
+        buffer[index++] = (size >> 16) & 0xff;
+        buffer[index++] = (size >> 24) & 0xff;
+        // Write the default subtype
+        buffer[index++] = BSON.BSON_BINARY_SUBTYPE_DEFAULT;
+        // Copy the content form the binary field to the buffer
+        value.copy(buffer, index, 0, size);
+        // Adjust the index
+        index = index + size;
+        return index;
+      } else if(value instanceof Long || value instanceof Timestamp || value['_bsontype'] == 'Long' || value['_bsontype'] == 'Timestamp') {
+        // Write the type
+        buffer[index++] = value instanceof Long ? BSON.BSON_DATA_LONG : BSON.BSON_DATA_TIMESTAMP;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Write the date
+        var lowBits = value.getLowBits();
+        var highBits = value.getHighBits();
+        // Encode low bits
+        buffer[index++] = lowBits & 0xff;
+        buffer[index++] = (lowBits >> 8) & 0xff;
+        buffer[index++] = (lowBits >> 16) & 0xff;
+        buffer[index++] = (lowBits >> 24) & 0xff;
+        // Encode high bits
+        buffer[index++] = highBits & 0xff;
+        buffer[index++] = (highBits >> 8) & 0xff;
+        buffer[index++] = (highBits >> 16) & 0xff;
+        buffer[index++] = (highBits >> 24) & 0xff;
+        return index;
+      } else if(value instanceof Double || value['_bsontype'] == 'Double') {
+        // Encode as double
+        buffer[index++] = BSON.BSON_DATA_NUMBER;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Write float
+        writeIEEE754(buffer, value, index, 'little', 52, 8);
+        // Ajust index
+        index = index + 8;
+        return index;
+      } else if(value instanceof Code || value['_bsontype'] == 'Code') {
+        if(value.scope != null && Object.keys(value.scope).length > 0) {
+          // Write the type
+          buffer[index++] = BSON.BSON_DATA_CODE_W_SCOPE;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          // Calculate the scope size
+          var scopeSize = BSON.calculateObjectSize(value.scope, serializeFunctions);
+          // Function string
+          var functionString = value.code.toString();
+          // Function Size
+          var codeSize = supportsBuffer ? Buffer.byteLength(functionString) + 1 : numberOfBytes(functionString) + 1;
+
+          // Calculate full size of the object
+          var totalSize = 4 + codeSize + scopeSize + 4;
+
+          // Write the total size of the object
+          buffer[index++] = totalSize & 0xff;
+          buffer[index++] = (totalSize >> 8) & 0xff;
+          buffer[index++] = (totalSize >> 16) & 0xff;
+          buffer[index++] = (totalSize >> 24) & 0xff;
+
+          // Write the size of the string to buffer
+          buffer[index++] = codeSize & 0xff;
+          buffer[index++] = (codeSize >> 8) & 0xff;
+          buffer[index++] = (codeSize >> 16) & 0xff;
+          buffer[index++] = (codeSize >> 24) & 0xff;
+
+          // Write the string
+          supportsBuffer ? buffer.write(functionString, index, 'utf8') : writeToTypedArray(buffer, functionString, index);
+          // Update index
+          index = index + codeSize - 1;
+          // Write zero
+          buffer[index++] = 0;
+          // Serialize the scope object
+          var scopeObjectBuffer = supportsBuffer ? new Buffer(scopeSize) : new Uint8Array(new ArrayBuffer(scopeSize));
+          // Execute the serialization into a seperate buffer
+          serializeObject(value.scope, checkKeys, scopeObjectBuffer, 0, serializeFunctions);
+
+          // Adjusted scope Size (removing the header)
+          var scopeDocSize = scopeSize;
+          // Write scope object size
+          buffer[index++] = scopeDocSize & 0xff;
+          buffer[index++] = (scopeDocSize >> 8) & 0xff;
+          buffer[index++] = (scopeDocSize >> 16) & 0xff;
+          buffer[index++] = (scopeDocSize >> 24) & 0xff;
+
+          // Write the scopeObject into the buffer
+          supportsBuffer ? scopeObjectBuffer.copy(buffer, index, 0, scopeSize) : buffer.set(scopeObjectBuffer, index);
+          // Adjust index, removing the empty size of the doc (5 bytes 0000000005)
+          index = index + scopeDocSize - 5;
+          // Write trailing zero
+          buffer[index++] = 0;
+          return index
+        } else {
+          buffer[index++] = BSON.BSON_DATA_CODE;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          // Function string
+          var functionString = value.code.toString();
+          // Function Size
+          var size = supportsBuffer ? Buffer.byteLength(functionString) + 1 : numberOfBytes(functionString) + 1;
+          // Write the size of the string to buffer
+          buffer[index++] = size & 0xff;
+          buffer[index++] = (size >> 8) & 0xff;
+          buffer[index++] = (size >> 16) & 0xff;
+          buffer[index++] = (size >> 24) & 0xff;
+          // Write the string
+          supportsBuffer ? buffer.write(functionString, index, 'utf8') : writeToTypedArray(buffer, functionString, index);
+          // Update index
+          index = index + size - 1;
+          // Write zero
+          buffer[index++] = 0;
+          return index;
+        }
+      } else if(value instanceof Binary || value['_bsontype'] == 'Binary') {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_BINARY;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Extract the buffer
+        var data = value.value(true);
+        // Calculate size
+        var size = value.position;
+        // Write the size of the string to buffer
+        buffer[index++] = size & 0xff;
+        buffer[index++] = (size >> 8) & 0xff;
+        buffer[index++] = (size >> 16) & 0xff;
+        buffer[index++] = (size >> 24) & 0xff;
+        // Write the subtype to the buffer
+        buffer[index++] = value.sub_type;
+
+        // If we have binary type 2 the 4 first bytes are the size
+        if(value.sub_type == Binary.SUBTYPE_BYTE_ARRAY) {
+          buffer[index++] = size & 0xff;
+          buffer[index++] = (size >> 8) & 0xff;
+          buffer[index++] = (size >> 16) & 0xff;
+          buffer[index++] = (size >> 24) & 0xff;
+        }
+
+        // Write the data to the object
+        supportsBuffer ? data.copy(buffer, index, 0, value.position) : buffer.set(data, index);
+        // Ajust index
+        index = index + value.position;
+        return index;
+      } else if(value instanceof Symbol || value['_bsontype'] == 'Symbol') {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_SYMBOL;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Calculate size
+        var size = supportsBuffer ? Buffer.byteLength(value.value) + 1 : numberOfBytes(value.value) + 1;
+        // Write the size of the string to buffer
+        buffer[index++] = size & 0xff;
+        buffer[index++] = (size >> 8) & 0xff;
+        buffer[index++] = (size >> 16) & 0xff;
+        buffer[index++] = (size >> 24) & 0xff;
+        // Write the string
+        buffer.write(value.value, index, 'utf8');
+        // Update index
+        index = index + size - 1;
+        // Write zero
+        buffer[index++] = 0x00;
+        return index;
+      } else if(value instanceof DBRef || value['_bsontype'] == 'DBRef') {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_OBJECT;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+        // Set up correct object for serialization
+        var ordered_values = {
+            '$ref': value.namespace
+          , '$id' : value.oid
+        };
+
+        // Add db reference if it exists
+        if(null != value.db) {
+          ordered_values['$db'] = value.db;
+        }
+
+        // Message size
+        var size = BSON.calculateObjectSize(ordered_values, serializeFunctions);
+        // Serialize the object
+        var endIndex = BSON.serializeWithBufferAndIndex(ordered_values, checkKeys, buffer, index, serializeFunctions);
+        // Write the size of the string to buffer
+        buffer[index++] = size & 0xff;
+        buffer[index++] = (size >> 8) & 0xff;
+        buffer[index++] = (size >> 16) & 0xff;
+        buffer[index++] = (size >> 24) & 0xff;
+        // Write zero for object
+        buffer[endIndex++] = 0x00;
+        // Return the end index
+        return endIndex;
+      } else if(value instanceof RegExp || Object.prototype.toString.call(value) === '[object RegExp]') {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_REGEXP;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+
+        // Write the regular expression string
+        supportsBuffer ? buffer.write(value.source, index, 'utf8') : writeToTypedArray(buffer, value.source, index);
+        // Adjust the index
+        index = index + (supportsBuffer ? Buffer.byteLength(value.source) : numberOfBytes(value.source));
+        // Write zero
+        buffer[index++] = 0x00;
+        // Write the parameters
+        if(value.global) buffer[index++] = 0x73; // s
+        if(value.ignoreCase) buffer[index++] = 0x69; // i
+        if(value.multiline) buffer[index++] = 0x6d; // m
+        // Add ending zero
+        buffer[index++] = 0x00;
+        return index;
+      } else {
+        // Write the type
+        buffer[index++] = Array.isArray(value) ? BSON.BSON_DATA_ARRAY : BSON.BSON_DATA_OBJECT;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Adjust the index
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+	      var endIndex = serializeObject(value, checkKeys, buffer, index + 4, serializeFunctions);
+        // Write size
+        var size = endIndex - index;
+        // Write the size of the string to buffer
+        buffer[index++] = size & 0xff;
+        buffer[index++] = (size >> 8) & 0xff;
+        buffer[index++] = (size >> 16) & 0xff;
+        buffer[index++] = (size >> 24) & 0xff;
+        return endIndex;
+      }
+    case 'function':
+      // WTF for 0.4.X where typeof /someregexp/ === 'function'
+      if(value instanceof RegExp || Object.prototype.toString.call(value) === '[object RegExp]' || String.call(value) == '[object RegExp]') {
+        // Write the type
+        buffer[index++] = BSON.BSON_DATA_REGEXP;
+        // Number of written bytes
+        var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+        // Encode the name
+        index = index + numberOfWrittenBytes + 1;
+        buffer[index - 1] = 0;
+
+        // Write the regular expression string
+        buffer.write(value.source, index, 'utf8');
+        // Adjust the index
+        index = index + (supportsBuffer ? Buffer.byteLength(value.source) : numberOfBytes(value.source));
+        // Write zero
+        buffer[index++] = 0x00;
+        // Write the parameters
+        if(value.global) buffer[index++] = 0x73; // s
+        if(value.ignoreCase) buffer[index++] = 0x69; // i
+        if(value.multiline) buffer[index++] = 0x6d; // m
+        // Add ending zero
+        buffer[index++] = 0x00;
+        return index;
+      } else {
+        if(serializeFunctions && value.scope != null && Object.keys(value.scope).length > 0) {
+          // Write the type
+          buffer[index++] = BSON.BSON_DATA_CODE_W_SCOPE;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          // Calculate the scope size
+          var scopeSize = BSON.calculateObjectSize(value.scope, serializeFunctions);
+          // Function string
+          var functionString = value.toString();
+          // Function Size
+          var codeSize = supportsBuffer ? Buffer.byteLength(functionString) + 1 : numberOfBytes(functionString) + 1;
+
+          // Calculate full size of the object
+          var totalSize = 4 + codeSize + scopeSize;
+
+          // Write the total size of the object
+          buffer[index++] = totalSize & 0xff;
+          buffer[index++] = (totalSize >> 8) & 0xff;
+          buffer[index++] = (totalSize >> 16) & 0xff;
+          buffer[index++] = (totalSize >> 24) & 0xff;
+
+          // Write the size of the string to buffer
+          buffer[index++] = codeSize & 0xff;
+          buffer[index++] = (codeSize >> 8) & 0xff;
+          buffer[index++] = (codeSize >> 16) & 0xff;
+          buffer[index++] = (codeSize >> 24) & 0xff;
+
+          // Write the string
+          supportsBuffer ? buffer.write(functionString, index, 'utf8') : writeToTypedArray(buffer, functionString, index);
+          // Update index
+          index = index + codeSize - 1;
+          // Write zero
+          buffer[index++] = 0;
+          // Serialize the scope object
+          var scopeObjectBuffer = new Buffer(scopeSize);
+          // Execute the serialization into a seperate buffer
+          serializeObject(value.scope, checkKeys, scopeObjectBuffer, 0, serializeFunctions);
+
+          // Adjusted scope Size (removing the header)
+          var scopeDocSize = scopeSize - 4;
+          // Write scope object size
+          buffer[index++] = scopeDocSize & 0xff;
+          buffer[index++] = (scopeDocSize >> 8) & 0xff;
+          buffer[index++] = (scopeDocSize >> 16) & 0xff;
+          buffer[index++] = (scopeDocSize >> 24) & 0xff;
+
+          // Write the scopeObject into the buffer
+          scopeObjectBuffer.copy(buffer, index, 0, scopeSize);
+
+          // Adjust index, removing the empty size of the doc (5 bytes 0000000005)
+          index = index + scopeDocSize - 5;
+          // Write trailing zero
+          buffer[index++] = 0;
+          return index
+        } else if(serializeFunctions) {
+          buffer[index++] = BSON.BSON_DATA_CODE;
+          // Number of written bytes
+          var numberOfWrittenBytes = supportsBuffer ? buffer.write(name, index, 'utf8') : writeToTypedArray(buffer, name, index);
+          // Encode the name
+          index = index + numberOfWrittenBytes + 1;
+          buffer[index - 1] = 0;
+          // Function string
+          var functionString = value.toString();
+          // Function Size
+          var size = supportsBuffer ? Buffer.byteLength(functionString) + 1 : numberOfBytes(functionString) + 1;
+          // Write the size of the string to buffer
+          buffer[index++] = size & 0xff;
+          buffer[index++] = (size >> 8) & 0xff;
+          buffer[index++] = (size >> 16) & 0xff;
+          buffer[index++] = (size >> 24) & 0xff;
+          // Write the string
+          supportsBuffer ? buffer.write(functionString, index, 'utf8') : writeToTypedArray(buffer, functionString, index);
+          // Update index
+          index = index + size - 1;
+          // Write zero
+          buffer[index++] = 0;
+          return index;
+        }
+      }
+  }
+
+  // If no value to serialize
+  return index;
+}
+
+/**
+ * Serialize a Javascript object.
+ *
+ * @param {Object} object the Javascript object to serialize.
+ * @param {Boolean} checkKeys the serializer will check if keys are valid.
+ * @param {Boolean} asBuffer return the serialized object as a Buffer object **(ignore)**.
+ * @param {Boolean} serializeFunctions serialize the javascript functions **(default:false)**.
+ * @return {Buffer} returns the Buffer object containing the serialized object.
+ * @api public
+ */
+BSON.serialize = function(object, checkKeys, asBuffer, serializeFunctions) {
+  // Throw error if we are trying serialize an illegal type
+  if(object == null || typeof object != 'object' || Array.isArray(object)) 
+    throw new Error("Only javascript objects supported");
+  
+  // Emoty target buffer
+  var buffer = null;
+  // Calculate the size of the object
+  var size = BSON.calculateObjectSize(object, serializeFunctions);
+  // Fetch the best available type for storing the binary data
+  if(buffer = typeof Buffer != 'undefined') {
+    buffer = new Buffer(size);
+    asBuffer = true;
+  } else if(typeof Uint8Array != 'undefined') {
+    buffer = new Uint8Array(new ArrayBuffer(size));
+  } else {
+    buffer = new Array(size);
+  }
+
+  // If asBuffer is false use typed arrays
+  BSON.serializeWithBufferAndIndex(object, checkKeys, buffer, 0, serializeFunctions);
+  return buffer;
+}
+
+/**
+ * Contains the function cache if we have that enable to allow for avoiding the eval step on each deserialization, comparison is by md5
+ *
+ * @ignore
+ * @api private
+ */
+var functionCache = BSON.functionCache = {};
+
+/**
+ * Crc state variables shared by function
+ *
+ * @ignore
+ * @api private
+ */
+var table = [0x00000000, 0x77073096, 0xEE0E612C, 0x990951BA, 0x076DC419, 0x706AF48F, 0xE963A535, 0x9E6495A3, 0x0EDB8832, 0x79DCB8A4, 0xE0D5E91E, 0x97D2D988, 0x09B64C2B, 0x7EB17CBD, 0xE7B82D07, 0x90BF1D91, 0x1DB71064, 0x6AB020F2, 0xF3B97148, 0x84BE41DE, 0x1ADAD47D, 0x6DDDE4EB, 0xF4D4B551, 0x83D385C7, 0x136C9856, 0x646BA8C0, 0xFD62F97A, 0x8A65C9EC, 0x14015C4F, 0x63066CD9, 0xFA0F3D63, 0x8D080DF5, 0x3B6E20C8, 0x4C69105E, 0xD56041E4, 0xA2677172, 0x3C03E4D1, 0x4B04D447, 0xD20D85FD, 0xA50AB56B, 0x35B5A8FA, 0x42B2986C, 0xDBBBC9D6, 0xACBCF940, 0x32D86CE3, 0x45DF5C75, 0xDCD60DCF, 0xABD13D59, 0x26D930AC, 0x51DE003A, 0xC8D75180, 0xBFD06116, 0x21B4F4B5, 0x56B3C423, 0xCFBA9599, 0xB8BDA50F, 0x2802B89E, 0x5F058808, 0xC60CD9B2, 0xB10BE924, 0x2F6F7C87, 0x58684C11, 0xC1611DAB, 0xB6662D3D, 0x76DC4190, 0x01DB7106, 0x98D220BC, 0xEFD5102A, 0x71B18589, 0x06B6B51F, 0x9FBFE4A5, 0xE8B8D433, 0x7807C9A2, 0x0F00F934, 0x9609A88E, 0xE10E9818, 0x7F6A0DBB, 0x086D3D2D, 0x91646C97, 0xE6635C01, 0x6B6B51F4, 0x1C6C6162, 
 0x856530D8, 0xF262004E, 0x6C0695ED, 0x1B01A57B, 0x8208F4C1, 0xF50FC457, 0x65B0D9C6, 0x12B7E950, 0x8BBEB8EA, 0xFCB9887C, 0x62DD1DDF, 0x15DA2D49, 0x8CD37CF3, 0xFBD44C65, 0x4DB26158, 0x3AB551CE, 0xA3BC0074, 0xD4BB30E2, 0x4ADFA541, 0x3DD895D7, 0xA4D1C46D, 0xD3D6F4FB, 0x4369E96A, 0x346ED9FC, 0xAD678846, 0xDA60B8D0, 0x44042D73, 0x33031DE5, 0xAA0A4C5F, 0xDD0D7CC9, 0x5005713C, 0x270241AA, 0xBE0B1010, 0xC90C2086, 0x5768B525, 0x206F85B3, 0xB966D409, 0xCE61E49F, 0x5EDEF90E, 0x29D9C998, 0xB0D09822, 0xC7D7A8B4, 0x59B33D17, 0x2EB40D81, 0xB7BD5C3B, 0xC0BA6CAD, 0xEDB88320, 0x9ABFB3B6, 0x03B6E20C, 0x74B1D29A, 0xEAD54739, 0x9DD277AF, 0x04DB2615, 0x73DC1683, 0xE3630B12, 0x94643B84, 0x0D6D6A3E, 0x7A6A5AA8, 0xE40ECF0B, 0x9309FF9D, 0x0A00AE27, 0x7D079EB1, 0xF00F9344, 0x8708A3D2, 0x1E01F268, 0x6906C2FE, 0xF762575D, 0x806567CB, 0x196C3671, 0x6E6B06E7, 0xFED41B76, 0x89D32BE0, 0x10DA7A5A, 0x67DD4ACC, 0xF9B9DF6F, 0x8EBEEFF9, 0x17B7BE43, 0x60B08ED5, 0xD6D6A3E8, 0xA1D1937E, 0x38D8C2C4, 0x4FDFF252, 0xD1BB67F1, 0
 xA6BC5767, 0x3FB506DD, 0x48B2364B, 0xD80D2BDA, 0xAF0A1B4C, 0x36034AF6, 0x41047A60, 0xDF60EFC3, 0xA867DF55, 0x316E8EEF, 0x4669BE79, 0xCB61B38C, 0xBC66831A, 0x256FD2A0, 0x5268E236, 0xCC0C7795, 0xBB0B4703, 0x220216B9, 0x5505262F, 0xC5BA3BBE, 0xB2BD0B28, 0x2BB45A92, 0x5CB36A04, 0xC2D7FFA7, 0xB5D0CF31, 0x2CD99E8B, 0x5BDEAE1D, 0x9B64C2B0, 0xEC63F226, 0x756AA39C, 0x026D930A, 0x9C0906A9, 0xEB0E363F, 0x72076785, 0x05005713, 0x95BF4A82, 0xE2B87A14, 0x7BB12BAE, 0x0CB61B38, 0x92D28E9B, 0xE5D5BE0D, 0x7CDCEFB7, 0x0BDBDF21, 0x86D3D2D4, 0xF1D4E242, 0x68DDB3F8, 0x1FDA836E, 0x81BE16CD, 0xF6B9265B, 0x6FB077E1, 0x18B74777, 0x88085AE6, 0xFF0F6A70, 0x66063BCA, 0x11010B5C, 0x8F659EFF, 0xF862AE69, 0x616BFFD3, 0x166CCF45, 0xA00AE278, 0xD70DD2EE, 0x4E048354, 0x3903B3C2, 0xA7672661, 0xD06016F7, 0x4969474D, 0x3E6E77DB, 0xAED16A4A, 0xD9D65ADC, 0x40DF0B66, 0x37D83BF0, 0xA9BCAE53, 0xDEBB9EC5, 0x47B2CF7F, 0x30B5FFE9, 0xBDBDF21C, 0xCABAC28A, 0x53B39330, 0x24B4A3A6, 0xBAD03605, 0xCDD70693, 0x54DE5729, 0x23D967BF, 0x
 B3667A2E, 0xC4614AB8, 0x5D681B02, 0x2A6F2B94, 0xB40BBE37, 0xC30C8EA1, 0x5A05DF1B, 0x2D02EF8D];
+
+/**
+ * CRC32 hash method, Fast and enough versitility for our usage
+ *
+ * @ignore
+ * @api private
+ */
+var crc32 =  function(string, start, end) {
+  var crc = 0
+  var x = 0;
+  var y = 0;
+  crc = crc ^ (-1);
+
+  for(var i = start, iTop = end; i < iTop;i++) {
+  	y = (crc ^ string[i]) & 0xFF;
+    x = table[y];
+  	crc = (crc >>> 8) ^ x;
+  }
+
+  return crc ^ (-1);
+}
+
+/**
+ * Deserialize stream data as BSON documents.
+ *
+ * Options
+ *  - **evalFunctions** {Boolean, default:false}, evaluate functions in the BSON document scoped to the object deserialized.
+ *  - **cacheFunctions** {Boolean, default:false}, cache evaluated functions for reuse.
+ *  - **cacheFunctionsCrc32** {Boolean, default:false}, use a crc32 code for caching, otherwise use the string of the function.
+ *  - **promoteLongs** {Boolean, default:true}, when deserializing a Long will fit it into a Number if it's smaller than 53 bits
+ *
+ * @param {Buffer} data the buffer containing the serialized set of BSON documents.
+ * @param {Number} startIndex the start index in the data Buffer where the deserialization is to start.
+ * @param {Number} numberOfDocuments number of documents to deserialize.
+ * @param {Array} documents an array where to store the deserialized documents.
+ * @param {Number} docStartIndex the index in the documents array from where to start inserting documents.
+ * @param {Object} [options] additional options used for the deserialization.
+ * @return {Number} returns the next index in the buffer after deserialization **x** numbers of documents.
+ * @api public
+ */
+BSON.deserializeStream = function(data, startIndex, numberOfDocuments, documents, docStartIndex, options) {
+  // if(numberOfDocuments !== documents.length) throw new Error("Number of expected results back is less than the number of documents");
+  options = options != null ? options : {};
+  var index = startIndex;
+  // Loop over all documents
+  for(var i = 0; i < numberOfDocuments; i++) {
+    // Find size of the document
+    var size = data[index] | data[index + 1] << 8 | data[index + 2] << 16 | data[index + 3] << 24;
+    // Update options with index
+    options['index'] = index;
+    // Parse the document at this point
+    documents[docStartIndex + i] = BSON.deserialize(data, options);
+    // Adjust index by the document size
+    index = index + size;
+  }
+
+  // Return object containing end index of parsing and list of documents
+  return index;
+}
+
+/**
+ * Ensure eval is isolated.
+ *
+ * @ignore
+ * @api private
+ */
+var isolateEvalWithHash = function(functionCache, hash, functionString, object) {
+  // Contains the value we are going to set
+  var value = null;
+
+  // Check for cache hit, eval if missing and return cached function
+  if(functionCache[hash] == null) {
+    eval("value = " + functionString);
+    functionCache[hash] = value;
+  }
+  // Set the object
+  return functionCache[hash].bind(object);
+}
+
+/**
+ * Ensure eval is isolated.
+ *
+ * @ignore
+ * @api private
+ */
+var isolateEval = function(functionString) {
+  // Contains the value we are going to set
+  var value = null;
+  // Eval the function
+  eval("value = " + functionString);
+  return value;
+}
+
+/**
+ * Convert Uint8Array to String
+ *
+ * @ignore
+ * @api private
+ */
+var convertUint8ArrayToUtf8String = function(byteArray, startIndex, endIndex) {
+  return BinaryParser.decode_utf8(convertArraytoUtf8BinaryString(byteArray, startIndex, endIndex));
+}
+
+var convertArraytoUtf8BinaryString = function(byteArray, startIndex, endIndex) {
+  var result = "";
+  for(var i = startIndex; i < endIndex; i++) {
+    result = result + String.fromCharCode(byteArray[i]);
+  }
+
+  return result;
+};
+
+/**
+ * Deserialize data as BSON.
+ *
+ * Options
+ *  - **evalFunctions** {Boolean, default:false}, evaluate functions in the BSON document scoped to the object deserialized.
+ *  - **cacheFunctions** {Boolean, default:false}, cache evaluated functions for reuse.
+ *  - **cacheFunctionsCrc32** {Boolean, default:false}, use a crc32 code for caching, otherwise use the string of the function.
+ *  - **promoteLongs** {Boolean, default:true}, when deserializing a Long will fit it into a Number if it's smaller than 53 bits
+ *
+ * @param {Buffer} buffer the buffer containing the serialized set of BSON documents.
+ * @param {Object} [options] additional options used for the deserialization.
+ * @param {Boolean} [isArray] ignore used for recursive parsing.
+ * @return {Object} returns the deserialized Javascript Object.
+ * @api public
+ */
+BSON.deserialize = function(buffer, options, isArray) {
+  // Options
+  options = options == null ? {} : options;
+  var evalFunctions = options['evalFunctions'] == null ? false : options['evalFunctions'];
+  var cacheFunctions = options['cacheFunctions'] == null ? false : options['cacheFunctions'];
+  var cacheFunctionsCrc32 = options['cacheFunctionsCrc32'] == null ? false : options['cacheFunctionsCrc32'];
+  var promoteLongs = options['promoteLongs'] || true;
+
+  // Validate that we have at least 4 bytes of buffer
+  if(buffer.length < 5) throw new Error("corrupt bson message < 5 bytes long");
+
+  // Set up index
+  var index = typeof options['index'] == 'number' ? options['index'] : 0;
+  // Reads in a C style string
+  var readCStyleString = function() {
+    // Get the start search index
+    var i = index;
+    // Locate the end of the c string
+    while(buffer[i] !== 0x00) { i++ }
+    // Grab utf8 encoded string
+    var string = supportsBuffer && Buffer.isBuffer(buffer) ? buffer.toString('utf8', index, i) : convertUint8ArrayToUtf8String(buffer, index, i);
+    // Update index position
+    index = i + 1;
+    // Return string
+    return string;
+  }
+
+  // Create holding object
+  var object = isArray ? [] : {};
+
+  // Read the document size
+  var size = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+
+  // Ensure buffer is valid size
+  if(size < 5 || size > buffer.length) throw new Error("corrupt bson message");
+
+  // While we have more left data left keep parsing
+  while(true) {
+    // Read the type
+    var elementType = buffer[index++];
+    // If we get a zero it's the last byte, exit
+    if(elementType == 0) break;
+    // Read the name of the field
+    var name = readCStyleString();
+    // Switch on the type
+    switch(elementType) {
+      case BSON.BSON_DATA_OID:
+        var string = supportsBuffer && Buffer.isBuffer(buffer) ? buffer.toString('binary', index, index + 12) : convertArraytoUtf8BinaryString(buffer, index, index + 12);
+        // Decode the oid
+        object[name] = new ObjectID(string);
+        // Update index
+        index = index + 12;
+        break;
+      case BSON.BSON_DATA_STRING:
+        // Read the content of the field
+        var stringSize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Add string to object
+        object[name] = supportsBuffer && Buffer.isBuffer(buffer) ? buffer.toString('utf8', index, index + stringSize - 1) : convertUint8ArrayToUtf8String(buffer, index, index + stringSize - 1);
+        // Update parse index position
+        index = index + stringSize;
+        break;
+      case BSON.BSON_DATA_INT:
+        // Decode the 32bit value
+        object[name] = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        break;
+      case BSON.BSON_DATA_NUMBER:
+        // Decode the double value
+        object[name] = readIEEE754(buffer, index, 'little', 52, 8);
+        // Update the index
+        index = index + 8;
+        break;
+      case BSON.BSON_DATA_DATE:
+        // Unpack the low and high bits
+        var lowBits = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        var highBits = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Set date object
+        object[name] = new Date(new Long(lowBits, highBits).toNumber());
+        break;
+      case BSON.BSON_DATA_BOOLEAN:
+        // Parse the boolean value
+        object[name] = buffer[index++] == 1;
+        break;
+      case BSON.BSON_DATA_NULL:
+        // Parse the boolean value
+        object[name] = null;
+        break;
+      case BSON.BSON_DATA_BINARY:
+        // Decode the size of the binary blob
+        var binarySize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Decode the subtype
+        var subType = buffer[index++];
+        // Decode as raw Buffer object if options specifies it
+        if(buffer['slice'] != null) {
+          // If we have subtype 2 skip the 4 bytes for the size
+          if(subType == Binary.SUBTYPE_BYTE_ARRAY) {
+            binarySize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+          }
+          // Slice the data
+          object[name] = new Binary(buffer.slice(index, index + binarySize), subType);
+        } else {
+          var _buffer = typeof Uint8Array != 'undefined' ? new Uint8Array(new ArrayBuffer(binarySize)) : new Array(binarySize);
+          // If we have subtype 2 skip the 4 bytes for the size
+          if(subType == Binary.SUBTYPE_BYTE_ARRAY) {
+            binarySize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+          }
+          // Copy the data
+          for(var i = 0; i < binarySize; i++) {
+            _buffer[i] = buffer[index + i];
+          }
+          // Create the binary object
+          object[name] = new Binary(_buffer, subType);
+        }
+        // Update the index
+        index = index + binarySize;
+        break;
+      case BSON.BSON_DATA_ARRAY:
+        options['index'] = index;
+        // Decode the size of the array document
+        var objectSize = buffer[index] | buffer[index + 1] << 8 | buffer[index + 2] << 16 | buffer[index + 3] << 24;
+        // Set the array to the object
+        object[name] = BSON.deserialize(buffer, options, true);
+        // Adjust the index
+        index = index + objectSize;
+        break;
+      case BSON.BSON_DATA_OBJECT:
+        options['index'] = index;
+        // Decode the size of the object document
+        var objectSize = buffer[index] | buffer[index + 1] << 8 | buffer[index + 2] << 16 | buffer[index + 3] << 24;
+        // Set the array to the object
+        object[name] = BSON.deserialize(buffer, options, false);
+        // Adjust the index
+        index = index + objectSize;
+        break;
+      case BSON.BSON_DATA_REGEXP:
+        // Create the regexp
+        var source = readCStyleString();
+        var regExpOptions = readCStyleString();
+        // For each option add the corresponding one for javascript
+        var optionsArray = new Array(regExpOptions.length);
+
+        // Parse options
+        for(var i = 0; i < regExpOptions.length; i++) {
+          switch(regExpOptions[i]) {
+            case 'm':
+              optionsArray[i] = 'm';
+              break;
+            case 's':
+              optionsArray[i] = 'g';
+              break;
+            case 'i':
+              optionsArray[i] = 'i';
+              break;
+          }
+        }
+
+        object[name] = new RegExp(source, optionsArray.join(''));
+        break;
+      case BSON.BSON_DATA_LONG:
+        // Unpack the low and high bits
+        var lowBits = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        var highBits = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Create long object
+        var long = new Long(lowBits, highBits); 
+        // Promote the long if possible
+        if(promoteLongs) {
+          object[name] = long.lessThanOrEqual(JS_INT_MAX_LONG) && long.greaterThanOrEqual(JS_INT_MIN_LONG) ? long.toNumber() : long;
+        } else {
+          object[name] = long;
+        }
+        break;
+      case BSON.BSON_DATA_SYMBOL:
+        // Read the content of the field
+        var stringSize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Add string to object
+        object[name] = new Symbol(buffer.toString('utf8', index, index + stringSize - 1));
+        // Update parse index position
+        index = index + stringSize;
+        break;
+      case BSON.BSON_DATA_TIMESTAMP:
+        // Unpack the low and high bits
+        var lowBits = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        var highBits = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Set the object
+        object[name] = new Timestamp(lowBits, highBits);
+        break;
+      case BSON.BSON_DATA_MIN_KEY:
+        // Parse the object
+        object[name] = new MinKey();
+        break;
+      case BSON.BSON_DATA_MAX_KEY:
+        // Parse the object
+        object[name] = new MaxKey();
+        break;
+      case BSON.BSON_DATA_CODE:
+        // Read the content of the field
+        var stringSize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Function string
+        var functionString = supportsBuffer && Buffer.isBuffer(buffer) ? buffer.toString('utf8', index, index + stringSize - 1) : convertUint8ArrayToUtf8String(buffer, index, index + stringSize - 1);
+
+        // If we are evaluating the functions
+        if(evalFunctions) {
+          // Contains the value we are going to set
+          var value = null;
+          // If we have cache enabled let's look for the md5 of the function in the cache
+          if(cacheFunctions) {
+            var hash = cacheFunctionsCrc32 ? crc32(functionString) : functionString;
+            // Got to do this to avoid V8 deoptimizing the call due to finding eval
+            object[name] = isolateEvalWithHash(functionCache, hash, functionString, object);
+          } else {
+            // Set directly
+            object[name] = isolateEval(functionString);
+          }
+        } else {
+          object[name]  = new Code(functionString, {});
+        }
+
+        // Update parse index position
+        index = index + stringSize;
+        break;
+      case BSON.BSON_DATA_CODE_W_SCOPE:
+        // Read the content of the field
+        var totalSize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        var stringSize = buffer[index++] | buffer[index++] << 8 | buffer[index++] << 16 | buffer[index++] << 24;
+        // Javascript function
+        var functionString = supportsBuffer && Buffer.isBuffer(buffer) ? buffer.toString('utf8', index, index + stringSize - 1) : convertUint8ArrayToUtf8String(buffer, index, index + stringSize - 1);
+        // Update parse index position
+        index = index + stringSize;
+        // Parse the element
+        options['index'] = index;
+        // Decode the size of the object document
+        var objectSize = buffer[index] | buffer[index + 1] << 8 | buffer[index + 2] << 16 | buffer[index + 3] << 24;
+        // Decode the scope object
+        var scopeObject = BSON.deserialize(buffer, options, false);
+        // Adjust the index
+        index = index + objectSize;
+
+        // If we are evaluating the functions
+        if(evalFunctions) {
+          // Contains the value we are going to set
+          var value = null;
+          // If we have cache enabled let's look for the md5 of the function in the cache
+          if(cacheFunctions) {
+            var hash = cacheFunctionsCrc32 ? crc32(functionString) : functionString;
+            // Got to do this to avoid V8 deoptimizing the call due to finding eval
+            object[name] = isolateEvalWithHash(functionCache, hash, functionString, object);
+       

<TRUNCATED>