You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@olingo.apache.org by ko...@apache.org on 2014/07/31 14:30:34 UTC

git commit: [OLINGO-324] rename jsonlight to json, and license headers

Repository: olingo-odata4-js
Updated Branches:
  refs/heads/master e1e69790f -> 88c0592e6


[OLINGO-324] rename jsonlight to json, and license headers


Project: http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/repo
Commit: http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/commit/88c0592e
Tree: http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/tree/88c0592e
Diff: http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/diff/88c0592e

Branch: refs/heads/master
Commit: 88c0592e6257bd6c812b9b69807f139f67926500
Parents: e1e6979
Author: Sven Kobler <sv...@sap.com>
Authored: Mon Jul 28 16:04:33 2014 +0200
Committer: Sven Kobler <sv...@sap.com>
Committed: Thu Jul 31 14:29:02 2014 +0200

----------------------------------------------------------------------
 .../grunt-config/custom-tasks/rat/tasks/rat.js  | 32 +++++----
 datajs/grunt-config/rat-config.js               |  8 +--
 datajs/packages.config                          |  1 -
 datajs/src/lib/odata/json.js                    | 68 +++++++++++---------
 datajs/tests/cache-tests.js                     | 37 ++++++-----
 datajs/tests/common/Instrument.svc              | 34 ++++++----
 datajs/tests/common/ODataReadOracle.svc         | 34 ++++++----
 datajs/tests/common/TestLogger.svc              | 32 +++++----
 datajs/tests/common/common.js                   | 20 +++++-
 ...cache-large-collection-functional-tests.html | 21 +++++-
 datajs/tests/datajs-cache-long-haul-tests.html  | 22 ++++++-
 datajs/tests/datajs-startup-perf-test.html      | 20 ++++++
 datajs/tests/endpoints/BasicAuthDataService.svc |  8 +--
 datajs/tests/endpoints/CustomAnnotations.xml    | 21 +++++-
 datajs/tests/endpoints/web.config               | 20 ++++++
 datajs/tests/node-test-setup.js                 | 18 ++++++
 datajs/tests/odata-batch-functional-tests.html  | 22 ++++++-
 .../odata-cache-filter-functional-tests.html    | 22 ++++++-
 datajs/tests/odata-cache-fperf-tests.html       | 22 ++++++-
 datajs/tests/odata-cache-functional-tests.html  | 22 ++++++-
 .../tests/odata-cache-rx-functional-tests.html  | 22 ++++++-
 datajs/tests/odata-fuzz.html                    | 22 ++++++-
 datajs/tests/odata-json-parse-tests.html        | 20 ++++++
 datajs/tests/odata-links-functional-tests.html  | 22 ++++++-
 ...ata-metadata-awareness-functional-tests.html | 22 ++++++-
 datajs/tests/odata-perf-tests.html              | 22 ++++++-
 datajs/tests/odata-qunit-tests.htm              | 38 +++++------
 ...odata-read-crossdomain-functional-tests.html | 22 ++++++-
 datajs/tests/odata-read-functional-tests.html   | 22 ++++++-
 .../tests/odata-request-functional-tests.html   | 22 ++++++-
 datajs/tests/run-tests.wsf                      | 28 +++++---
 datajs/tests/test-manager.html                  | 22 ++++++-
 32 files changed, 608 insertions(+), 160 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/grunt-config/custom-tasks/rat/tasks/rat.js
----------------------------------------------------------------------
diff --git a/datajs/grunt-config/custom-tasks/rat/tasks/rat.js b/datajs/grunt-config/custom-tasks/rat/tasks/rat.js
index a8c61eb..8c6e8b0 100644
--- a/datajs/grunt-config/custom-tasks/rat/tasks/rat.js
+++ b/datajs/grunt-config/custom-tasks/rat/tasks/rat.js
@@ -1,50 +1,56 @@
 'use strict';
+
 module.exports = function (grunt) {
   grunt.registerMultiTask('rat', 'Run Apache Rat', function () {
     var path = require('path');
     var chalk = require('chalk');
     var childProcess = require('child_process');
     var xml2js = require('xml2js');
+    var fs = require('fs');
 
     var cb = this.async();
 
-    var options = this.options({ xml : true, tmpdir : './build/tmp'});
+    var options = this.options({ xml : true, tmpDir : './build/tmp'});
     var dir = this.data.dir;
-    var out = options.tmpdir + '/' + (options.xml ? 'rat.xml' : 'rat.txt');
+    var out = options.tmpDir + '/' + (options.xml ? 'rat.xml' : 'rat.txt');
 
-    
     var pathToRat =  path.resolve(__dirname,'./../tools/apache-rat-0.10/apache-rat-0.10.jar');
     
     //sample command java -jar apache-rat-0.10.jar -x -d ./src > ./build/tmp/rat.txt
-    var cmd = 'java -jar ' + pathToRat;
+    var cmd = 'java -jar ' + pathToRat+ ' ';
     cmd += options.xml ? ' -x' : '';
+    cmd += ' --force -d ' + dir + ' > ' + out;
 
-    cmd += ' -d ' + dir;
-    cmd += ' > ' + out;
+    grunt.verbose.writeln('Directory: '+dir);
 
     var cp = childProcess.exec(cmd, options.execOptions, function (err, stdout, stderr) {
       if (err) {
-        grunt.fail.warn('rat --> ' + err, 1); //abort Grunt immediately with error code 1
+        grunt.fail.warn('rat --> ' + err, 1); //exit grunt with error code 1
       }
-      grunt.verbose.writeln('Rat['+dir+']:');
+      
+      
+      
       if (!options.xml) {
-        grunt.fail.warn('rat --> ' + 'No XML output: checkRatLogFile skipped!', 1); //abort Grunt immediately with error code 1
+        grunt.fail.warn('rat --> ' + 'No XML output: checkRatLogFile skipped!', 1); 
       }
+
       var xml = grunt.file.read(out);
       var parser = new xml2js.Parser();
+
       parser.parseString(xml, function (err, result) {
+
           if (err) {
-            grunt.fail.warn('rat --> ' + err, 1); //abort Grunt immediately with error code 1
+            grunt.fail.warn('rat --> ' + err, 1); 
           }
           
-          //
           if (checkRatLogFile(result)) {
             grunt.fail.warn('rat --> ' + 'Missing or Invalied license header detected ( see "'+out+'")', 1);
           }
 
-          //
-          cb();
+          
       });
+      cb(); 
+      
     }.bind(this));
 
     var checkRatLogFile = function(result) {

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/grunt-config/rat-config.js
----------------------------------------------------------------------
diff --git a/datajs/grunt-config/rat-config.js b/datajs/grunt-config/rat-config.js
index c5ab665..019192b 100644
--- a/datajs/grunt-config/rat-config.js
+++ b/datajs/grunt-config/rat-config.js
@@ -7,13 +7,9 @@ module.exports = function(grunt) {
     test: {                      
       dir: './tests'
     },
-    all: {
-      all: ['./src','./tests']
-    }
   });
 
-  
-  //grunt.loadNpmTasks('custom-tasks/rat');
+ 
   grunt.loadTasks('grunt-config/custom-tasks/rat/tasks');
-  grunt.registerTask('license',['rat:src']);
+  grunt.registerTask('license',['rat:src','rat:test']);
 };
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/packages.config
----------------------------------------------------------------------
diff --git a/datajs/packages.config b/datajs/packages.config
index 8d5126f..9e7480b 100644
--- a/datajs/packages.config
+++ b/datajs/packages.config
@@ -3,6 +3,5 @@
   <package id="Microsoft.OData.Client" version="6.5.0" targetFramework="net40" />
   <package id="Microsoft.OData.Core" version="6.5.0" targetFramework="net40" />
   <package id="Microsoft.OData.Edm" version="6.5.0" targetFramework="net40" />
-  <package id="Microsoft.OData.Service" version="6.5.0" targetFramework="net40" />
   <package id="Microsoft.Spatial" version="6.5.0" targetFramework="net40" />
 </packages>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/src/lib/odata/json.js
----------------------------------------------------------------------
diff --git a/datajs/src/lib/odata/json.js b/datajs/src/lib/odata/json.js
index 89c759c..edb0b0b 100644
--- a/datajs/src/lib/odata/json.js
+++ b/datajs/src/lib/odata/json.js
@@ -36,7 +36,6 @@ var getFormatKind = utils.getFormatKind;
 
 var formatDateTimeOffset = oDataUtils.formatDateTimeOffset;
 var formatDuration = oDataUtils.formatDuration;
-var formatJsonLight = oDataUtils.formatJsonLight;
 var formatNumberWidth = oDataUtils.formatNumberWidth;
 var getCanonicalTimezone = oDataUtils.getCanonicalTimezone;
 var handler = oDataUtils.handler;
@@ -52,6 +51,10 @@ var lookupProperty = oDataUtils.lookupProperty;
 var MAX_DATA_SERVICE_VERSION = oDataUtils.MAX_DATA_SERVICE_VERSION;
 var maxVersion = oDataUtils.maxVersion;
 var parseDateTime = oDataUtils.parseDateTime;
+
+var isPrimitiveEdmType = oDataUtils.isPrimitiveEdmType;
+var isGeographyEdmType = oDataUtils.isGeographyEdmType;
+var isGeometryEdmType = oDataUtils.isGeometryEdmType;
 //var parseDuration = oDataUtils.parseDuration;
 //var parseTimezone = oDataUtils.parseTimezone;
 //var payloadTypeOf = oDataUtils.payloadTypeOf;
@@ -155,9 +158,9 @@ var jsonParser = function (handler, text, context) {
     var recognizeDates = defined(context.recognizeDates, handler.recognizeDates);
     var model = context.metadata;
     var json = (typeof text === "string") ? JSON.parse(text) : text;
-
+    var metadataContentType;
     if (assigned(context.contentType) && assigned(context.contentType.properties)) {
-        var metadataContentType = context.contentType.properties["odata.metadata"]; //TODO convert to lower before comparism
+        metadataContentType = context.contentType.properties["odata.metadata"]; //TODO convert to lower before comparism
     }
 
     var payloadFormat = getFormatKind(metadataContentType, 1); // none: 0, minimal: 1, full: 2
@@ -263,7 +266,7 @@ var jsonSerializer = function (handler, data, context) {
 
     if (cType && cType.mediaType === jsonContentType.mediaType) {
         context.dataServiceVersion = maxVersion(dataServiceVersion, "4.0");
-        var newdata = formatJsonLightRequestPayload(data);
+        var newdata = formatJsonRequestPayload(data);
         if (newdata) {
             return JSON.stringify(newdata);
         }
@@ -272,7 +275,7 @@ var jsonSerializer = function (handler, data, context) {
     return undefined;
 };
 
-var formatJsonLightRequestPayload = function (data) {
+var formatJsonRequestPayload = function (data) {
     if (!data) {
         return data;
     }
@@ -285,7 +288,7 @@ var formatJsonLightRequestPayload = function (data) {
         var newArrayData = [];
         var i, len;
         for (i = 0, len = data.length; i < len; i++) {
-            newArrayData[i] = formatJsonLightRequestPayload(data[i]);
+            newArrayData[i] = formatJsonRequestPayload(data[i]);
         }
 
         return newArrayData;
@@ -293,8 +296,8 @@ var formatJsonLightRequestPayload = function (data) {
 
     var newdata = {};
     for (var property in data) {
-        if (isJsonLightSerializableProperty(property)) {
-            newdata[property] = formatJsonLightRequestPayload(data[property]);
+        if (isJsonSerializableProperty(property)) {
+            newdata[property] = formatJsonRequestPayload(data[property]);
         }
     }
 
@@ -317,14 +320,14 @@ var jsonReplacer = function (_, value) {
 };
 
 
-var jsonLightMakePayloadInfo = function (kind, type) {
-    /// <summary>Creates an object containing information for the json light payload.</summary>
-    /// <param name="kind" type="String">JSON light payload kind, one of the PAYLOADTYPE_XXX constant values.</param>
-    /// <param name="typeName" type="String">Type name of the JSON light payload.</param>
+var jsonMakePayloadInfo = function (kind, type) {
+    /// <summary>Creates an object containing information for the json payload.</summary>
+    /// <param name="kind" type="String">JSON payload kind, one of the PAYLOADTYPE_XXX constant values.</param>
+    /// <param name="typeName" type="String">Type name of the JSON payload.</param>
     /// <returns type="Object">Object with kind and type fields.</returns>
 
-    /// <field name="kind" type="String">Kind of the JSON light payload. One of the PAYLOADTYPE_XXX constant values.</field>
-    /// <field name="type" type="String">Data type of the JSON light payload.</field>
+    /// <field name="kind" type="String">Kind of the JSON payload. One of the PAYLOADTYPE_XXX constant values.</field>
+    /// <field name="type" type="String">Data type of the JSON payload.</field>
 
     return { kind: kind, type: type || null };
 };
@@ -440,7 +443,7 @@ var parseContextUriFragment = function( fragments, model ) {
                 continue;
             }
 
-            if (jsonLightIsPrimitiveType(fragment)) {
+            if (jsonIsPrimitiveType(fragment)) {
                 ret.typeName = fragment;
                 ret.type = null;
                 ret.detectedPayloadKind = PAYLOADTYPE_VALUE;
@@ -521,14 +524,14 @@ var parseContextUriFragment = function( fragments, model ) {
 };
 
 var createPayloadInfo = function (data, model) {
-    /// <summary>Infers the information describing the JSON light payload from its metadata annotation, structure, and data model.</summary>
-    /// <param name="data" type="Object">Json light response payload object.</param>
+    /// <summary>Infers the information describing the JSON payload from its metadata annotation, structure, and data model.</summary>
+    /// <param name="data" type="Object">Json response payload object.</param>
     /// <param name="model" type="Object">Object describing an OData conceptual schema.</param>
     /// <remarks>
     ///     If the arguments passed to the function don't convey enough information about the payload to determine without doubt that the payload is a feed then it
     ///     will try to use the payload object structure instead.  If the payload looks like a feed (has value property that is an array or non-primitive values) then
     ///     the function will report its kind as PAYLOADTYPE_FEED unless the inferFeedAsComplexType flag is set to true. This flag comes from the user request
-    ///     and allows the user to control how the library behaves with an ambigous JSON light payload.
+    ///     and allows the user to control how the library behaves with an ambigous JSON payload.
     /// </remarks>
     /// <returns type="Object">
     ///     Object with kind and type fields. Null if there is no metadata annotation or the payload info cannot be obtained..
@@ -541,7 +544,7 @@ var createPayloadInfo = function (data, model) {
 
     var fragmentStart = metadataUri.lastIndexOf("#");
     if (fragmentStart === -1) {
-        return jsonLightMakePayloadInfo(PAYLOADTYPE_SVCDOC);
+        return jsonMakePayloadInfo(PAYLOADTYPE_SVCDOC);
     }
 
     var fragment = metadataUri.substring(fragmentStart + 1);
@@ -580,9 +583,9 @@ var readPayloadMinimal = function (data, model, recognizeDates) {
     return data;
 };
 
-var jsonLightGetEntryKey = function (data, entityModel) {
+var jsonGetEntryKey = function (data, entityModel) {
     /// <summary>Gets the key of an entry.</summary>
-    /// <param name="data" type="Object">JSON light entry.</param>
+    /// <param name="data" type="Object">JSON entry.</param>
     /// <paraFrom   Subject Received    Size    Categories  
     /// <returns type="string">Entry instance key.</returns>
 
@@ -779,33 +782,33 @@ var readPayloadMinimalObject = function (data, objectInfo, baseURI, model, recog
 
     //if ((keyType !== undefined) && (keyType.key !== undefined)) { 
     if (keyType.key !== undefined) { 
-        var lastIdSegment = objectInfo.name + jsonLightGetEntryKey(data, keyType);
+        var lastIdSegment = objectInfo.name + jsonGetEntryKey(data, keyType);
         data['@odata.id'] = baseURI.substring(0, baseURI.lastIndexOf("$metadata")) + lastIdSegment;
         data['@odata.editLink'] = lastIdSegment;
     }
 
     var serviceURI = baseURI.substring(0, baseURI.lastIndexOf("$metadata"));
-    //jsonLightComputeUrisIfMissing(data, entryInfo, actualType, serviceURI, dataModel, baseTypeModel);
+    //json ComputeUrisIfMissing(data, entryInfo, actualType, serviceURI, dataModel, baseTypeModel);
 
     checkProperties(data, objectInfo.type, baseURI, model, recognizeDates);
     
     return data;
 };
 
-var jsonLightSerializableMetadata = ["@odata.id", "@odata.type"];
+var jsonSerializableMetadata = ["@odata.id", "@odata.type"];
 
-var isJsonLightSerializableProperty = function (property) {
+var isJsonSerializableProperty = function (property) {
     if (!property) {
         return false;
     }
 
     if (property.indexOf("@odata.") == -1) {
         return true;
-    }
+    } 
 
     var i, len;
-    for (i = 0, len = jsonLightSerializableMetadata.length; i < len; i++) {
-        var name = jsonLightSerializableMetadata[i];
+    for (i = 0, len = jsonSerializableMetadata.length; i < len; i++) {
+        var name = jsonSerializableMetadata[i];
         if (property.indexOf(name) != -1) {
             return true;
         }
@@ -814,10 +817,17 @@ var isJsonLightSerializableProperty = function (property) {
     return false;
 };
 
+var jsonIsPrimitiveType = function (typeName) {
+    /// <summary>Determines whether a type name is a primitive type in a JSON payload.</summary>
+    /// <param name="typeName" type="String">Type name to test.</param>
+    /// <returns type="Boolean">True if the type name an EDM primitive type or an OData spatial type; false otherwise.</returns>
+
+    return isPrimitiveEdmType(typeName) || isGeographyEdmType(typeName) || isGeometryEdmType(typeName);
+};
+
 
 var jsonHandler = oDataHandler.handler(jsonParser, jsonSerializer, jsonMediaType, MAX_DATA_SERVICE_VERSION);
 jsonHandler.recognizeDates = false;
-jsonHandler.useJsonLight = true;
 
 exports.jsonHandler = jsonHandler;
 exports.jsonParser = jsonParser;

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/cache-tests.js
----------------------------------------------------------------------
diff --git a/datajs/tests/cache-tests.js b/datajs/tests/cache-tests.js
index 91ab3ca..d4c345c 100644
--- a/datajs/tests/cache-tests.js
+++ b/datajs/tests/cache-tests.js
@@ -1,22 +1,21 @@
-/// <reference path="../src/datajs.js" />
-/// <reference path="../src/odata-utils.js" />
-/// <reference path="../src/cache.js" />
-/// <reference path="common/djstest.js" />
-
-// Copyright (c) Microsoft Open Technologies, Inc.  All rights reserved.
-// Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation
-// files (the "Software"), to deal  in the Software without restriction, including without limitation the rights  to use, copy,
-// modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the
-// Software is furnished to do so, subject to the following conditions:
-//
-// The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-//
-// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR  IMPLIED, INCLUDING BUT NOT LIMITED TO THE
-// WARRANTIES OF MERCHANTABILITY,  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
-// COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE,
-// ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
-
-// cache-tests.js
+/*
+ * 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.
+*/
 
 (function (window, undefined) {
 

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/common/Instrument.svc
----------------------------------------------------------------------
diff --git a/datajs/tests/common/Instrument.svc b/datajs/tests/common/Instrument.svc
index 3d14b16..111020f 100644
--- a/datajs/tests/common/Instrument.svc
+++ b/datajs/tests/common/Instrument.svc
@@ -1,18 +1,24 @@
-<%@ ServiceHost Language="C#" Debug="true" Factory="System.ServiceModel.Activation.WebScriptServiceHostFactory"
-    Service="DataJS.Tests.Instrument" %>
+/*
+ * 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.
+*/
 
-// Copyright (c) Microsoft Open Technologies, Inc.  All rights reserved.
-// Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation 
-// files (the "Software"), to deal  in the Software without restriction, including without limitation the rights  to use, copy,
-// modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the 
-// Software is furnished to do so, subject to the following conditions:
-//
-// The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-//
-// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR  IMPLIED, INCLUDING BUT NOT LIMITED TO THE
-// WARRANTIES OF MERCHANTABILITY,  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
-// COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, 
-// ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
+<%@ ServiceHost Language="C#" Debug="true" Factory="System.ServiceModel.Activation.WebScriptServiceHostFactory"
+    Service="DataJS.Tests.Instrument" %>
 
 namespace DataJS.Tests
 {

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/common/ODataReadOracle.svc
----------------------------------------------------------------------
diff --git a/datajs/tests/common/ODataReadOracle.svc b/datajs/tests/common/ODataReadOracle.svc
index 7536de4..339666c 100644
--- a/datajs/tests/common/ODataReadOracle.svc
+++ b/datajs/tests/common/ODataReadOracle.svc
@@ -1,18 +1,24 @@
-<%@ ServiceHost Language="C#" Debug="true" Factory="System.ServiceModel.Activation.WebScriptServiceHostFactory"
-    Service="DataJS.Tests.ODataReadOracle" %>
+/*
+ * 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.
+*/
 
-// Copyright (c) Microsoft Open Technologies, Inc.  All rights reserved.
-// Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation 
-// files (the "Software"), to deal  in the Software without restriction, including without limitation the rights  to use, copy,
-// modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the 
-// Software is furnished to do so, subject to the following conditions:
-//
-// The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-//
-// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR  IMPLIED, INCLUDING BUT NOT LIMITED TO THE
-// WARRANTIES OF MERCHANTABILITY,  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
-// COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, 
-// ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
+<%@ ServiceHost Language="C#" Debug="true" Factory="System.ServiceModel.Activation.WebScriptServiceHostFactory"
+    Service="DataJS.Tests.ODataReadOracle" %>
 
 //uncomment this line to debug JSON serialization.
 //#define DEBUG_SERIALIZATION

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/common/TestLogger.svc
----------------------------------------------------------------------
diff --git a/datajs/tests/common/TestLogger.svc b/datajs/tests/common/TestLogger.svc
index d236b24..164d207 100644
--- a/datajs/tests/common/TestLogger.svc
+++ b/datajs/tests/common/TestLogger.svc
@@ -1,17 +1,23 @@
-<%@ ServiceHost Language="C#" Debug="true" Factory="DataJS.Tests.TestSynchronizerFactory" Service="DataJS.Tests.TestSynchronizer" %>
+/*
+ * 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.
+*/
 
-// Copyright (c) Microsoft Open Technologies, Inc.  All rights reserved.
-// Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation 
-// files (the "Software"), to deal  in the Software without restriction, including without limitation the rights  to use, copy,
-// modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the 
-// Software is furnished to do so, subject to the following conditions:
-//
-// The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-//
-// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR  IMPLIED, INCLUDING BUT NOT LIMITED TO THE
-// WARRANTIES OF MERCHANTABILITY,  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
-// COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, 
-// ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
+<%@ ServiceHost Language="C#" Debug="true" Factory="DataJS.Tests.TestSynchronizerFactory" Service="DataJS.Tests.TestSynchronizer" %>
 
 namespace DataJS.Tests
 {

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/common/common.js
----------------------------------------------------------------------
diff --git a/datajs/tests/common/common.js b/datajs/tests/common/common.js
index 876b052..cd764a9 100644
--- a/datajs/tests/common/common.js
+++ b/datajs/tests/common/common.js
@@ -1,4 +1,22 @@
-(function (window, undefined) {
+/*
+ * 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.
+*/
+(function (window, undefined) {
         window.OData = window.datajs.V4.oData;
         window.temp = window.datajs.V4;
         window.temp.store = window.datajs.V4.store;

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/datajs-cache-large-collection-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/datajs-cache-large-collection-functional-tests.html b/datajs/tests/datajs-cache-large-collection-functional-tests.html
index 357998a..d0a298d 100644
--- a/datajs/tests/datajs-cache-large-collection-functional-tests.html
+++ b/datajs/tests/datajs-cache-large-collection-functional-tests.html
@@ -1,4 +1,23 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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.
+ */
+ -->
 <html>
 <head>
     <title>datajs.cache and datajs.store full local store tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/datajs-cache-long-haul-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/datajs-cache-long-haul-tests.html b/datajs/tests/datajs-cache-long-haul-tests.html
index a5f00c4..5455a89 100644
--- a/datajs/tests/datajs-cache-long-haul-tests.html
+++ b/datajs/tests/datajs-cache-long-haul-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData Long Haul Tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/datajs-startup-perf-test.html
----------------------------------------------------------------------
diff --git a/datajs/tests/datajs-startup-perf-test.html b/datajs/tests/datajs-startup-perf-test.html
index d717db4..1cbe321 100644
--- a/datajs/tests/datajs-startup-perf-test.html
+++ b/datajs/tests/datajs-startup-perf-test.html
@@ -1,3 +1,23 @@
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.0//EN">
 <html>
 <!--

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/endpoints/BasicAuthDataService.svc
----------------------------------------------------------------------
diff --git a/datajs/tests/endpoints/BasicAuthDataService.svc b/datajs/tests/endpoints/BasicAuthDataService.svc
index df448dc..e059314 100644
--- a/datajs/tests/endpoints/BasicAuthDataService.svc
+++ b/datajs/tests/endpoints/BasicAuthDataService.svc
@@ -1,4 +1,5 @@
-<!--
+<%@ ServiceHost Language="C#" Factory="Microsoft.OData.Service.DataServiceHostFactory, Microsoft.OData.Service, Version=6.5.0.0, Culture=neutral, PublicKeyToken=31bf3856ad364e35"
+    Service="DataJS.Tests.BasicAuthDataService" %>
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -17,11 +18,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
--->
-
-<%@ ServiceHost Language="C#" Factory="Microsoft.OData.Service.DataServiceHostFactory, Microsoft.OData.Service, Version=6.5.0.0, Culture=neutral, PublicKeyToken=31bf3856ad364e35"
-    Service="DataJS.Tests.BasicAuthDataService" %>
-
 namespace DataJS.Tests
 {
     using System;

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/endpoints/CustomAnnotations.xml
----------------------------------------------------------------------
diff --git a/datajs/tests/endpoints/CustomAnnotations.xml b/datajs/tests/endpoints/CustomAnnotations.xml
index 622769f..ebf4e26 100644
--- a/datajs/tests/endpoints/CustomAnnotations.xml
+++ b/datajs/tests/endpoints/CustomAnnotations.xml
@@ -1,4 +1,23 @@
-<?xml version="1.0" encoding="utf-8"?>
+<!--/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+*/
+-->
+<?xml version="1.0" encoding="utf-8"?>
 <edmx:Edmx xmlns:edmx="http://schemas.microsoft.com/ado/2007/06/edmx" Version="1.0">
   <edmx:DataServices m:DataServiceVersion="2.0" xmlns:m="http://schemas.microsoft.com/ado/2007/08/dataservices/metadata">
     <Schema xmlns="http://schemas.microsoft.com/ado/2007/05/edm" xmlns:m="http://schemas.microsoft.com/ado/2007/08/dataservices/metadata" xmlns:d="http://schemas.microsoft.com/ado/2007/08/dataservices" xmlns:mcns="http://MyCustomNamespace.com"

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/endpoints/web.config
----------------------------------------------------------------------
diff --git a/datajs/tests/endpoints/web.config b/datajs/tests/endpoints/web.config
index 11c6696..116a567 100644
--- a/datajs/tests/endpoints/web.config
+++ b/datajs/tests/endpoints/web.config
@@ -1,4 +1,24 @@
 <?xml version='1.0'?>
+<!--
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+-->
 <configuration>
   <system.web>
     <compilation debug='true'>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/node-test-setup.js
----------------------------------------------------------------------
diff --git a/datajs/tests/node-test-setup.js b/datajs/tests/node-test-setup.js
index 2a94b81..68c03b9 100644
--- a/datajs/tests/node-test-setup.js
+++ b/datajs/tests/node-test-setup.js
@@ -1,3 +1,21 @@
+/*
+ * 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.
+*/
 //Creates the global objects
 
 //tools

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-batch-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-batch-functional-tests.html b/datajs/tests/odata-batch-functional-tests.html
index 1c8d8dd..e6cc61a 100644
--- a/datajs/tests/odata-batch-functional-tests.html
+++ b/datajs/tests/odata-batch-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>batch tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-cache-filter-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-cache-filter-functional-tests.html b/datajs/tests/odata-cache-filter-functional-tests.html
index 3c72a81..aa22293 100644
--- a/datajs/tests/odata-cache-filter-functional-tests.html
+++ b/datajs/tests/odata-cache-filter-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>datajs.cache  filter functional tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-cache-fperf-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-cache-fperf-tests.html b/datajs/tests/odata-cache-fperf-tests.html
index 9a0632a..85d49c1 100644
--- a/datajs/tests/odata-cache-fperf-tests.html
+++ b/datajs/tests/odata-cache-fperf-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>datajs.cache functional perf tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-cache-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-cache-functional-tests.html b/datajs/tests/odata-cache-functional-tests.html
index 0390b18..301854e 100644
--- a/datajs/tests/odata-cache-functional-tests.html
+++ b/datajs/tests/odata-cache-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData tests against local service</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-cache-rx-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-cache-rx-functional-tests.html b/datajs/tests/odata-cache-rx-functional-tests.html
index ce0c4af..a80b59d 100644
--- a/datajs/tests/odata-cache-rx-functional-tests.html
+++ b/datajs/tests/odata-cache-rx-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>>datajs.cache toObservable() tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-fuzz.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-fuzz.html b/datajs/tests/odata-fuzz.html
index 93009b9..0a02ef5 100644
--- a/datajs/tests/odata-fuzz.html
+++ b/datajs/tests/odata-fuzz.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData Fuzzing Tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-json-parse-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-json-parse-tests.html b/datajs/tests/odata-json-parse-tests.html
index 8aa847b..83dd9fc 100644
--- a/datajs/tests/odata-json-parse-tests.html
+++ b/datajs/tests/odata-json-parse-tests.html
@@ -1,3 +1,23 @@
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.0//EN">
 <html>
 <!--

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-links-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-links-functional-tests.html b/datajs/tests/odata-links-functional-tests.html
index f820266..ced1988 100644
--- a/datajs/tests/odata-links-functional-tests.html
+++ b/datajs/tests/odata-links-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData tests against local service</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-metadata-awareness-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-metadata-awareness-functional-tests.html b/datajs/tests/odata-metadata-awareness-functional-tests.html
index cb903bb..60d379b 100644
--- a/datajs/tests/odata-metadata-awareness-functional-tests.html
+++ b/datajs/tests/odata-metadata-awareness-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>metadata awareness tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-perf-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-perf-tests.html b/datajs/tests/odata-perf-tests.html
index 1aea5de..54ccf54 100644
--- a/datajs/tests/odata-perf-tests.html
+++ b/datajs/tests/odata-perf-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData perf tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-qunit-tests.htm
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-qunit-tests.htm b/datajs/tests/odata-qunit-tests.htm
index e22bc51..696b7bb 100644
--- a/datajs/tests/odata-qunit-tests.htm
+++ b/datajs/tests/odata-qunit-tests.htm
@@ -1,19 +1,25 @@
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.0//EN">
 <html>
-<!--
-Copyright (c) Microsoft Open Technologies, Inc.  All rights reserved.
-Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation 
-files (the "Software"), to deal  in the Software without restriction, including without limitation the rights  to use, copy,
-modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the 
-Software is furnished to do so, subject to the following conditions:
-
-The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR  IMPLIED, INCLUDING BUT NOT LIMITED TO THE
-WARRANTIES OF MERCHANTABILITY,  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
-COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, 
-ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
--->
   <head>
     <meta http-equiv="X-UA-Compatible" content="IE=Edge" />
     <meta http-equiv="cache-control" content="no-cache" />
@@ -24,10 +30,6 @@ ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEAL
     <link rel="stylesheet" href="http://code.jquery.com/qunit/qunit-1.10.0.css" type="text/css" />
     
     <script type="text/javascript" src="http://code.jquery.com/jquery-1.4.4.min.js" ></script>
-    
-<!--    <script type="text/javascript" src="http://code.jquery.com/jquery-1.4.4.js">
-    <script type="text/javascript" src="http://ajax.aspnetcdn.com/ajax/jQuery/jquery-1.5.2.js"></script>-->
-    
 
     <script type="text/javascript" src="http://code.jquery.com/qunit/qunit-1.10.0.js"></script>
     <script type="text/javascript" src="http://cdnjs.cloudflare.com/ajax/libs/json2/20110223/json2.js"></script>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-read-crossdomain-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-read-crossdomain-functional-tests.html b/datajs/tests/odata-read-crossdomain-functional-tests.html
index 0d2ba44..a2bee9e 100644
--- a/datajs/tests/odata-read-crossdomain-functional-tests.html
+++ b/datajs/tests/odata-read-crossdomain-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData tests against local service</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-read-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-read-functional-tests.html b/datajs/tests/odata-read-functional-tests.html
index 4ed5b29..54120c6 100644
--- a/datajs/tests/odata-read-functional-tests.html
+++ b/datajs/tests/odata-read-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>OData tests against local service</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/odata-request-functional-tests.html
----------------------------------------------------------------------
diff --git a/datajs/tests/odata-request-functional-tests.html b/datajs/tests/odata-request-functional-tests.html
index 888887b..7faf792 100644
--- a/datajs/tests/odata-request-functional-tests.html
+++ b/datajs/tests/odata-request-functional-tests.html
@@ -1,4 +1,24 @@
-<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
 <html>
 <head>
     <title>odata.request tests</title>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/run-tests.wsf
----------------------------------------------------------------------
diff --git a/datajs/tests/run-tests.wsf b/datajs/tests/run-tests.wsf
index 26d954d..263bae0 100644
--- a/datajs/tests/run-tests.wsf
+++ b/datajs/tests/run-tests.wsf
@@ -1,14 +1,22 @@
 <!--
-Copyright (c) Microsoft Open Technologies, Inc.  All rights reserved.
-Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation
-files (the "Software"), to deal  in the Software without restriction, including without limitation the rights  to use, copy,
-modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the
-Software is furnished to do so, subject to the following conditions:
-The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software.
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR  IMPLIED, INCLUDING BUT NOT LIMITED TO THE
-WARRANTIES OF MERCHANTABILITY,  FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR
-COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE,
-ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE.
+/*
+ * 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.
+*/
 -->
 <job>
     <runtime>

http://git-wip-us.apache.org/repos/asf/olingo-odata4-js/blob/88c0592e/datajs/tests/test-manager.html
----------------------------------------------------------------------
diff --git a/datajs/tests/test-manager.html b/datajs/tests/test-manager.html
index fa4911a..290f161 100644
--- a/datajs/tests/test-manager.html
+++ b/datajs/tests/test-manager.html
@@ -1,4 +1,24 @@
-<!DOCTYPE html PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
+<!--
+/*
+ * 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 PUBLIC "-//W3C//DTD XHTML 1.0 Transitional//EN" "http://www.w3.org/TR/xhtml1/DTD/xhtml1-transitional.dtd">
 <html xmlns="http://www.w3.org/1999/xhtml">
 <head>
     <title>datajs test manager</title>