You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pivot.apache.org by tv...@apache.org on 2009/11/03 16:02:39 UTC

svn commit: r832445 [4/4] - in /incubator/pivot/trunk: core/src/org/apache/pivot/beans/ core/src/org/apache/pivot/util/ demos/ demos/src/org/apache/pivot/demos/clock/ demos/src/org/apache/pivot/demos/decorator/ demos/src/org/apache/pivot/demos/dnd/ dem...

Modified: incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.java
URL: http://svn.apache.org/viewvc/incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.java?rev=832445&r1=832444&r2=832445&view=diff
==============================================================================
--- incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.java (original)
+++ incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.java Tue Nov  3 15:02:31 2009
@@ -1,331 +1,331 @@
-/*
- * 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.
- */
-package org.apache.pivot.web.test;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertNull;
-
-import java.io.IOException;
-
-import org.apache.pivot.serialization.ByteArraySerializer;
-import org.apache.pivot.serialization.SerializationException;
-import org.apache.pivot.util.Resources;
-import org.apache.pivot.web.Authentication;
-import org.apache.pivot.web.DigestAuthentication;
-import org.apache.pivot.web.GetQuery;
-import org.apache.pivot.web.QueryException;
-import org.junit.After;
-import org.junit.AfterClass;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Test;
-
-/**
- * Integration Test of Client-side Authentication with the Digest method.
- * <br/>
- * This is a JUnit 4 Test, but should be excluded from usual (Unit) Test Suite.
- * <br/>
- * To Run these tests, a local instance of Apache must be started and configured with
- * the required resources (by default folders /public , and /dir and /protected_digest
- * protected with digest authentication) and files.
- * Before to run these tests, ensure digest authentication has been successfully setup
- * asking the same URLs from a Web Browser.
- * Note that now this class loads (in a standard Pivot way) some test parameters
- * from a json file that must be in the same folder of this class.
- * For example, to run this Class on another Server (for example on a local Tomcat instance),
- * some parameters have to be changed  inside the json file, then rerun the test.
- *
- * TODO:
- *   - test other HTTP methods ...
- *   - test also many queries after the first, to see if/how to handle the nonce count ...
- *   - test also with URL parameters ...
- *   - test also with long query:
- *     -- test the timeout (of query, and not of the test method)
- *     -- test the cancel (of query) , like downloading an iso file
- *   - test also with Tomcat ...
- *
- */
-public class WebQueryTestClientDigest {
-    static Resources resources = null; // parametric resources, using the
-                                       // Pivot-way
-
-    String host = null;
-    int port = 0;
-    String path = null;
-    boolean secure = false;
-
-    Authentication authentication = null;
-
-    Object result = null;
-
-    public static void log(String msg) {
-        System.out.println(msg);
-    }
-
-    @BeforeClass
-    public static void runBeforeClass() {
-        // run for one time before all test cases
-
-        // load Test Case parametric values
-        try {
-            resources = new Resources(WebQueryTestClientDigest.class.getName());
-        } catch (IOException e) {
-            e.printStackTrace();
-        } catch (SerializationException e) {
-            e.printStackTrace();
-        }
-
-        log("Loaded " + resources + " resources");
-    }
-
-    @AfterClass
-    public static void runAfterClass() {
-        // run for one time after all test cases
-    }
-
-    @Before
-    public void runBeforeEveryTest() {
-        // run before any single test case
-    }
-
-    @After
-    public void runAfterEveryTest() {
-        // run after any single test case
-        host = null;
-        port = 0;
-        path = null;
-
-        authentication = null;
-
-        result = null;
-    }
-
-    // @Ignore
-    @Test(timeout = 10000, expected = QueryException.class)
-    public void public_noauth_NotExistingHost() throws QueryException {
-        log("public_noauth_NotExistingHost()");
-
-        host = "non_existing_host";
-        port = resources.getInteger("port");
-        path = resources.getString("folder_public");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        result = query.execute();
-        assertNull(result);
-
-        log("Query result: \n" + result);
-    }
-
-    @Test(timeout = 10000, expected = QueryException.class)
-    public void public_noauth_localhost_NotExistingResource() throws QueryException {
-        log("public_noauth_localhost_NotExistingResource()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        path = resources.getString("folder_public") + "non_existing_resource";
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        result = query.execute();
-        assertNull(result);
-
-        log("Query result: \n" + result);
-    }
-
-    @Test(timeout = 10000)
-    public void public_noauth_localhost_testFile() throws QueryException {
-        log("public_noauth_localhost_testFile()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        path = resources.getString("folder_public") + resources.getString("file_text");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-
-        // attention, don't use BinarySerializer here, but instead use the
-        // generic ByteArraySerializer
-        query.setSerializer(new ByteArraySerializer());
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        result = query.execute();
-        assertNotNull(result);
-
-        // dump content, but useful only for text resources ...
-        String dump = // result.toString()
-        // Arrays.toString((byte []) result);
-        new String((byte[]) result);
-        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
-    }
-
-    @Test(timeout = 10000)
-    public void public_digest_localhost_forceUnnecessaryAuthentication() throws QueryException {
-        log("public_digest_localhost_forceUnnecessaryAuthentication()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        path = resources.getString("folder_public") + resources.getString("file_text");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-
-        // attention, don't use BinarySerializer here, but instead use the
-        // generic ByteArraySerializer
-        query.setSerializer(new ByteArraySerializer());
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        authentication = new DigestAuthentication(resources.getString("user_name"),
-            resources.getString("user_pass"));
-        authentication.authenticate(query);
-
-        result = query.execute();
-        assertNotNull(result);
-
-        // dump content, but useful only for text resources ...
-        String dump = // result.toString()
-        // Arrays.toString((byte []) result);
-        new String((byte[]) result);
-        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
-    }
-
-    // @Test(timeout = 10000, expected = QueryException.class)
-    @Test(timeout = 1000000, expected = QueryException.class)  // for debugging the execution
-    public void protected_digest_localhostWithoutAuthenticate() throws QueryException {
-        log("protected_digest_localhostWithoutAuthenticate()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        path = resources.getString("folder_protected") + resources.getString("file_text");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-        query.setSerializer(new ByteArraySerializer());
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        result = query.execute();
-        log("Query result: \n" + result);
-        assertNull(result);
-
-        int status = query.getStatus();
-        log("Query: status = " + status + ", result: \n" + result);
-        assertEquals(401, status);
-    }
-
-    @Test(timeout = 10000, expected = QueryException.class)
-    public void protected_digest_localhostWithWrongCredentials() throws QueryException {
-        log("protected_digest_localhostWithWrongCredentials()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        path = resources.getString("folder_protected") + resources.getString("file_text");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-        query.setSerializer(new ByteArraySerializer());
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        authentication = new DigestAuthentication("wrongUsername", "wrongPassword");
-        authentication.authenticate(query);
-
-        result = query.execute();
-        log("Query result: \n" + result);
-        assertNull(result);
-
-        int status = query.getStatus();
-        log("Query: status = " + status + ", result: \n" + result);
-        assertEquals(401, status);
-   }
-
-    // @Test(timeout = 10000)
-    @Test(timeout = 1000000)  // for debugging the execution
-    public void protected_digest_localhost() throws QueryException {
-        log("protected_digest_localhost()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        // path = resources.getString("folder_protected") + resources.getString("file_text");
-        // path = resources.getString("folder_protected") + resources.getString("file_binary");
-        path = resources.getString("folder_protected") + resources.getString("file_text");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-
-        // attention, don't use BinarySerializer here, but instead use the
-        // generic ByteArraySerializer
-        query.setSerializer(new ByteArraySerializer());
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        authentication = new DigestAuthentication(resources.getString("user_name"),
-            resources.getString("user_pass"));
-        authentication.authenticate(query);
-
-        result = query.execute();
-        assertNotNull(result);
-
-        int status = query.getStatus();
-        log("Query: status = " + status + ", result: \n" + result);
-        assertEquals(200, status);
-
-        // dump content, but useful only for text resources ...
-        String dump = // result.toString()
-        // Arrays.toString((byte []) result);
-        new String((byte[]) result);
-        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
-    }
-
-    // @Test(timeout = 10000)
-    @Test(timeout = 1000000)  // for debugging the execution
-    public void protected_digest_localhostByRFC() throws QueryException {
-        log("protected_digest_localhostByRFC()");
-
-        host = resources.getString("hostname");
-        port = resources.getInteger("port");
-        path = resources.getString("rfc_uri_protected");
-
-        GetQuery query = new GetQuery(host, port, path, secure);
-
-        // attention, don't use BinarySerializer here, but instead use the
-        // generic ByteArraySerializer
-        query.setSerializer(new ByteArraySerializer());
-        query.setTimeout(resources.getLong("timeout"));
-        log("GET Query to " + query.getLocation());
-
-        authentication = new DigestAuthentication(resources.getString("rfc_user_name"),
-            resources.getString("rfc_user_pass"));
-        authentication.authenticate(query);
-
-        result = query.execute();
-        assertNotNull(result);
-
-        int status = query.getStatus();
-        log("Query: status = " + status + ", result: \n" + result);
-        assertEquals(200, status);
-
-        // dump content, but useful only for text resources ...
-        String dump = // result.toString()
-        // Arrays.toString((byte []) result);
-        new String((byte[]) result);
-        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
-    }
-
-}
+/*
+ * 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.
+ */
+package org.apache.pivot.web.test;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertNotNull;
+import static org.junit.Assert.assertNull;
+
+import java.io.IOException;
+
+import org.apache.pivot.serialization.ByteArraySerializer;
+import org.apache.pivot.serialization.SerializationException;
+import org.apache.pivot.util.Resources;
+import org.apache.pivot.web.Authentication;
+import org.apache.pivot.web.DigestAuthentication;
+import org.apache.pivot.web.GetQuery;
+import org.apache.pivot.web.QueryException;
+import org.junit.After;
+import org.junit.AfterClass;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Test;
+
+/**
+ * Integration Test of Client-side Authentication with the Digest method.
+ * <br/>
+ * This is a JUnit 4 Test, but should be excluded from usual (Unit) Test Suite.
+ * <br/>
+ * To Run these tests, a local instance of Apache must be started and configured with
+ * the required resources (by default folders /public , and /dir and /protected_digest
+ * protected with digest authentication) and files.
+ * Before to run these tests, ensure digest authentication has been successfully setup
+ * asking the same URLs from a Web Browser.
+ * Note that now this class loads (in a standard Pivot way) some test parameters
+ * from a json file that must be in the same folder of this class.
+ * For example, to run this Class on another Server (for example on a local Tomcat instance),
+ * some parameters have to be changed  inside the json file, then rerun the test.
+ *
+ * TODO:
+ *   - test other HTTP methods ...
+ *   - test also many queries after the first, to see if/how to handle the nonce count ...
+ *   - test also with URL parameters ...
+ *   - test also with long query:
+ *     -- test the timeout (of query, and not of the test method)
+ *     -- test the cancel (of query) , like downloading an iso file
+ *   - test also with Tomcat ...
+ *
+ */
+public class WebQueryTestClientDigest {
+    static Resources resources = null; // parametric resources, using the
+                                       // Pivot-way
+
+    String host = null;
+    int port = 0;
+    String path = null;
+    boolean secure = false;
+
+    Authentication authentication = null;
+
+    Object result = null;
+
+    public static void log(String msg) {
+        System.out.println(msg);
+    }
+
+    @BeforeClass
+    public static void runBeforeClass() {
+        // run for one time before all test cases
+
+        // load Test Case parametric values
+        try {
+            resources = new Resources(WebQueryTestClientDigest.class.getName());
+        } catch (IOException e) {
+            e.printStackTrace();
+        } catch (SerializationException e) {
+            e.printStackTrace();
+        }
+
+        log("Loaded " + resources + " resources");
+    }
+
+    @AfterClass
+    public static void runAfterClass() {
+        // run for one time after all test cases
+    }
+
+    @Before
+    public void runBeforeEveryTest() {
+        // run before any single test case
+    }
+
+    @After
+    public void runAfterEveryTest() {
+        // run after any single test case
+        host = null;
+        port = 0;
+        path = null;
+
+        authentication = null;
+
+        result = null;
+    }
+
+    // @Ignore
+    @Test(timeout = 10000, expected = QueryException.class)
+    public void public_noauth_NotExistingHost() throws QueryException {
+        log("public_noauth_NotExistingHost()");
+
+        host = "non_existing_host";
+        port = resources.getInteger("port");
+        path = resources.getString("folder_public");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        result = query.execute();
+        assertNull(result);
+
+        log("Query result: \n" + result);
+    }
+
+    @Test(timeout = 10000, expected = QueryException.class)
+    public void public_noauth_localhost_NotExistingResource() throws QueryException {
+        log("public_noauth_localhost_NotExistingResource()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        path = resources.getString("folder_public") + "non_existing_resource";
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        result = query.execute();
+        assertNull(result);
+
+        log("Query result: \n" + result);
+    }
+
+    @Test(timeout = 10000)
+    public void public_noauth_localhost_testFile() throws QueryException {
+        log("public_noauth_localhost_testFile()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        path = resources.getString("folder_public") + resources.getString("file_text");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+
+        // attention, don't use BinarySerializer here, but instead use the
+        // generic ByteArraySerializer
+        query.setSerializer(new ByteArraySerializer());
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        result = query.execute();
+        assertNotNull(result);
+
+        // dump content, but useful only for text resources ...
+        String dump = // result.toString()
+        // Arrays.toString((byte []) result);
+        new String((byte[]) result);
+        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
+    }
+
+    @Test(timeout = 10000)
+    public void public_digest_localhost_forceUnnecessaryAuthentication() throws QueryException {
+        log("public_digest_localhost_forceUnnecessaryAuthentication()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        path = resources.getString("folder_public") + resources.getString("file_text");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+
+        // attention, don't use BinarySerializer here, but instead use the
+        // generic ByteArraySerializer
+        query.setSerializer(new ByteArraySerializer());
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        authentication = new DigestAuthentication(resources.getString("user_name"),
+            resources.getString("user_pass"));
+        authentication.authenticate(query);
+
+        result = query.execute();
+        assertNotNull(result);
+
+        // dump content, but useful only for text resources ...
+        String dump = // result.toString()
+        // Arrays.toString((byte []) result);
+        new String((byte[]) result);
+        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
+    }
+
+    // @Test(timeout = 10000, expected = QueryException.class)
+    @Test(timeout = 1000000, expected = QueryException.class)  // for debugging the execution
+    public void protected_digest_localhostWithoutAuthenticate() throws QueryException {
+        log("protected_digest_localhostWithoutAuthenticate()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        path = resources.getString("folder_protected") + resources.getString("file_text");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+        query.setSerializer(new ByteArraySerializer());
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        result = query.execute();
+        log("Query result: \n" + result);
+        assertNull(result);
+
+        int status = query.getStatus();
+        log("Query: status = " + status + ", result: \n" + result);
+        assertEquals(401, status);
+    }
+
+    @Test(timeout = 10000, expected = QueryException.class)
+    public void protected_digest_localhostWithWrongCredentials() throws QueryException {
+        log("protected_digest_localhostWithWrongCredentials()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        path = resources.getString("folder_protected") + resources.getString("file_text");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+        query.setSerializer(new ByteArraySerializer());
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        authentication = new DigestAuthentication("wrongUsername", "wrongPassword");
+        authentication.authenticate(query);
+
+        result = query.execute();
+        log("Query result: \n" + result);
+        assertNull(result);
+
+        int status = query.getStatus();
+        log("Query: status = " + status + ", result: \n" + result);
+        assertEquals(401, status);
+   }
+
+    // @Test(timeout = 10000)
+    @Test(timeout = 1000000)  // for debugging the execution
+    public void protected_digest_localhost() throws QueryException {
+        log("protected_digest_localhost()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        // path = resources.getString("folder_protected") + resources.getString("file_text");
+        // path = resources.getString("folder_protected") + resources.getString("file_binary");
+        path = resources.getString("folder_protected") + resources.getString("file_text");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+
+        // attention, don't use BinarySerializer here, but instead use the
+        // generic ByteArraySerializer
+        query.setSerializer(new ByteArraySerializer());
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        authentication = new DigestAuthentication(resources.getString("user_name"),
+            resources.getString("user_pass"));
+        authentication.authenticate(query);
+
+        result = query.execute();
+        assertNotNull(result);
+
+        int status = query.getStatus();
+        log("Query: status = " + status + ", result: \n" + result);
+        assertEquals(200, status);
+
+        // dump content, but useful only for text resources ...
+        String dump = // result.toString()
+        // Arrays.toString((byte []) result);
+        new String((byte[]) result);
+        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
+    }
+
+    // @Test(timeout = 10000)
+    @Test(timeout = 1000000)  // for debugging the execution
+    public void protected_digest_localhostByRFC() throws QueryException {
+        log("protected_digest_localhostByRFC()");
+
+        host = resources.getString("hostname");
+        port = resources.getInteger("port");
+        path = resources.getString("rfc_uri_protected");
+
+        GetQuery query = new GetQuery(host, port, path, secure);
+
+        // attention, don't use BinarySerializer here, but instead use the
+        // generic ByteArraySerializer
+        query.setSerializer(new ByteArraySerializer());
+        query.setTimeout(resources.getLong("timeout"));
+        log("GET Query to " + query.getLocation());
+
+        authentication = new DigestAuthentication(resources.getString("rfc_user_name"),
+            resources.getString("rfc_user_pass"));
+        authentication.authenticate(query);
+
+        result = query.execute();
+        assertNotNull(result);
+
+        int status = query.getStatus();
+        log("Query: status = " + status + ", result: \n" + result);
+        assertEquals(200, status);
+
+        // dump content, but useful only for text resources ...
+        String dump = // result.toString()
+        // Arrays.toString((byte []) result);
+        new String((byte[]) result);
+        log("Query result: " + (dump.getBytes().length) + " bytes \n" + dump);
+    }
+
+}

Propchange: incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.json
URL: http://svn.apache.org/viewvc/incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.json?rev=832445&r1=832444&r2=832445&view=diff
==============================================================================
--- incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.json (original)
+++ incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.json Tue Nov  3 15:02:31 2009
@@ -1,27 +1,27 @@
-{
-    secure: false,
-    hostname: "localhost",
-
-    // enable this for Test on Apache
-    port: 80,  // for apache keep this on 80
-    webapp: "",  // for apache keep this empty
-    //
-    // or enable this for Test on Tomcat
-    // port: 8080,  // for tomcat enable this (default on 8080)
-    // webapp: "/pivot-test",  // for tomcat keep this to the test webapp name
-    // end customizations
-
-    folder_public: "/public/",
-    folder_protected: "/protected_digest/",
-    file_binary: "test.jpg",
-    file_text: "test.txt",
-    user_name: "test",
-    user_pass: "test0",
-
-    rfc_uri_protected: "/dir/index.html",
-    rfc_user_name: "Mufasa",
-    rfc_user_pass: "Circle Of Life",
-
-    timeout: 5000
-
-}
+{
+    secure: false,
+    hostname: "localhost",
+
+    // enable this for Test on Apache
+    port: 80,  // for apache keep this on 80
+    webapp: "",  // for apache keep this empty
+    //
+    // or enable this for Test on Tomcat
+    // port: 8080,  // for tomcat enable this (default on 8080)
+    // webapp: "/pivot-test",  // for tomcat keep this to the test webapp name
+    // end customizations
+
+    folder_public: "/public/",
+    folder_protected: "/protected_digest/",
+    file_binary: "test.jpg",
+    file_text: "test.txt",
+    user_name: "test",
+    user_pass: "test0",
+
+    rfc_uri_protected: "/dir/index.html",
+    rfc_user_name: "Mufasa",
+    rfc_user_pass: "Circle Of Life",
+
+    timeout: 5000
+
+}

Propchange: incubator/pivot/trunk/web/test/org/apache/pivot/web/test/WebQueryTestClientDigest.json
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/pivot/trunk/web/test/org/apache/pivot/web/test/package.html
URL: http://svn.apache.org/viewvc/incubator/pivot/trunk/web/test/org/apache/pivot/web/test/package.html?rev=832445&r1=832444&r2=832445&view=diff
==============================================================================
--- incubator/pivot/trunk/web/test/org/apache/pivot/web/test/package.html (original)
+++ incubator/pivot/trunk/web/test/org/apache/pivot/web/test/package.html Tue Nov  3 15:02:31 2009
@@ -1,202 +1,202 @@
-<!--
-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>
-</head>
-<body>
-<p>Provides classes for Testing HTTP communication classes.</p>
-
-<p>
-Note that the classes <b>WebQueryTestClientBasic</b> and <b>WebQueryTestClientDigest</b> works under JUnit 4,
-but more than Unit Tests they are <u>Integration Tests</u>, because they require a working HTTP Server
-setup in the right way for their test to be successfully run.<br/>
-So they should be <u>excluded</u> from usual (Unit) Test Suite (run for example during Release builds).
-</p>
-
-<p>
-The following instructions explains the setup required for the right execution of
-WebQueryTestClientBasic and WebQueryTestClientDigest Integration Tests with JUnit 4.
-</p>
-<br/>
-
-<p><b>Requirements:</b><br/></p>
-<ul>
-<li>Apache 2.2.x Web Server installed and working on localhost</li>
-<li>JUnit 4.x Test Runner, like that inside Eclipse</li>
-<li>(optional) Apache Tomcat 6.0.x installed and working on localhost</li>
-</ul>
-
-
-<p><b>Test Setup for Apache:</b></p>
-<ul>
-<li>
-in the main Apache configuration file (APACHE_HOME/conf/httpd.conf) make some modify:<br/>
-enable the digest authentication module, removing the comment on it, for example:
-<pre>
-# LoadModule auth_digest_module modules/mod_auth_digest.so
-LoadModule auth_digest_module modules/mod_auth_digest.so
-</pre>
-Note that the module for the Basic Authentication (needed by the other class WebQueryTestClientBasic), by default is already enabled in Apache.<br/>
-<br/>
-Then, enable the usage of .htaccess files on the root folder (by default htdocs), for a simpler per-directory authentication and authorization setup:
-<pre>
-#     AllowOverride None
-    AllowOverride All
-or
-    AllowOverride AuthConfig
-</pre>
-Note that this is only a convenience setting, targeted at these tests.
-<br/>
-</li>
-<li>test that Apache works, starting/restarting it, to ensure the configuration is right
-<br/>
-</li>
-<li>go into the published directory (htdocs, or public_html, depending on the environment) and create the following empty directories:
-public (optional), protected (for testing basic authentication), protected_digest (for testing digest authentication), dir (for testing digest authentication, using the same values from the RFC)
-<br/>
-Copy some files (for example one binary like test.jpg, and one of text like test.txt) inside any of the previously-created directories.
-In the dir directory, put a index.html file (required by the test, because all tests as explained in the RFC use it).
-<br/>
-</li>
-<li>in the "dir" directory, create a (text) file named .htaccess , and put inside this:
-<pre>
-AuthType Digest
-
-# Note that with Digest Authentication, the value of AuthName must be the same as the realm
-AuthName "testrealm@host.com"
-
-AuthDigestDomain /dir/
-AuthUserFile  "htdocs/dir/.htpasswd"
-Require valid-user
-
-# Hack for enabling pre IE 7 to work good with Digest Authentication
-BrowserMatch "MSIE" AuthDigestEnableQueryStringHack=On
-</pre>
-<br/>
-</li>
-<li>in the "protected" dir (required by Basic Test), create a (text) file named .htaccess , and put inside this:
-<pre>
-AuthType Basic
-AuthName "Password Required"
-
-AuthUserFile  "htdocs/protected/.htpasswd"
-Require valid-user
-</pre>
-<br/>
-</li>
-<li>in the "protected_digest" dir, create a (text) file named .htaccess , and put inside this:
-<pre>
-AuthType Digest
-
-# Note that with Digest Authentication, the value of AuthName must be the same as the realm
-AuthName "Password Required (Digest)"
-
-AuthDigestDomain /protected_digest/
-AuthUserFile  "htdocs/protected_digest/.htpasswd"
-Require valid-user
-
-# Hack for enabling pre IE 7 to work good with Digest Authentication
-BrowserMatch "MSIE" AuthDigestEnableQueryStringHack=On
-</pre>
-<br/>
-</li>
-<li>from the prompt, use some standard Apache commands to create the digested passwords.
-If Apache commands are available in PATH, go directly in the target directory,
-otherwise for example you'll have to go to the main apache directory and launch them using for example bin\ht*.exe (for Windows),
-and then move the generated file into the right directory.
-<pre>
-Optional, for the "protected" (Basic Authentication) for example use:
-htpasswd -c .htpasswd test
-htpasswd will ask you for the password (in this case "test0", but without quotes), and then ask you to type it again to confirm it
-
-For the "protected_digest" (Digest Authentication) for example use:
-htdigest -c .htpasswd "Password Required (Digest)" test
-htdigest will ask you for the password (in this case "test0", but without quotes), and then ask you to type it again to confirm it
-<br/>
-For the "dir" (Digest Authentication) for example use:
-htdigest -c .htpasswd "testrealm@host.com" Mufasa
-htdigest will ask you for the password (in this case "Circle Of Life", but without quotes), and then ask you to type it again to confirm it
-</pre>
-<br/>
-</li>
-<li>manual test using a browser (to ensure the directories has been protected in the right way):
-point to the URL http://localhost/ , and then add (by hand) the subdirectory names, and try to access.
-Note that all protected directories are not visible from here.
-Any time required, the browser will open an Authentication popup, where to put username/password data (always without quotes).
-<br/>
-<pre>
-"protected/" needs username "test" and password "test0"
-"protected_digest/" needs username "test" and password "test0"
-"dir/" needs username "Mufasa" and password "Circle Of Life"
-</pre>
-<br/>
-</li>
-<li>execute the Test class, for example by running it from Eclipse (or by prompt), using JUnit 4, and see results.
-<br/>
-</li>
-</ul>
-
-<br/>
-
-
-<p><b>Test Setup for Tomcat:</b><p/>
-<ul>
-<li>under Tomcat things are different: first is needed a webapp, for example pivot-test
-</li>
-<li>
-then, configure the security (but of the full webapp) as BASIC or DIGEST, so it will be possible only one type of Integration Tests per run
-(or two different webapps could be used, like pivot-test-basic and pivot-test-digest)
-</li>
-<li>
-under the Tomcat Users file define the following (in the right XML format, inside the file):
-<pre>
-role rolename="test"
-user username="test" password="test0" roles="test"
-user username="Mufasa" password="Circle Of Life" roles="test"
-</pre>
-and then Restart Tomcat (important)
-<br/>
-Note that this is enough for BASIC authentication, while for DIGEST passwords must be written here in encoded format (digest),
-see the Tomcat docs for more detail on this.
-<br/>
-</li>
-<li>
-as with Apache, do a
-manual test using a browser (to ensure the directories has been protected in the right way and are accessible):
-point to the URL http://localhost:8080/pivot-test/ , and then add (by hand) the subdirectory names, and try to access.
-Note that all protected directories are not visible from here.
-Any time required, the browser will open an Authentication popup, where to put username/password data (always without quotes).
-</li>
-<li>
-change json data inside config files for Tests (any test has its own config) file that by default here works with Apache,
-so to make it work with Tomcat at least you'll have to comment the two lines defining the port and the webapp,
-and uncomment the two for Tomcat.
-</li>
-<li>
-suggestion: start running the BASIC authentication test, and only after the DIGEST.
-</li>
-<li>execute the Test class, for example by running it from Eclipse (or by prompt), using JUnit 4, and see results.
-<br/>
-</li>
-</ul>
-
-
-<br/>
-
-</body>
-</html>
+<!--
+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>
+</head>
+<body>
+<p>Provides classes for Testing HTTP communication classes.</p>
+
+<p>
+Note that the classes <b>WebQueryTestClientBasic</b> and <b>WebQueryTestClientDigest</b> works under JUnit 4,
+but more than Unit Tests they are <u>Integration Tests</u>, because they require a working HTTP Server
+setup in the right way for their test to be successfully run.<br/>
+So they should be <u>excluded</u> from usual (Unit) Test Suite (run for example during Release builds).
+</p>
+
+<p>
+The following instructions explains the setup required for the right execution of
+WebQueryTestClientBasic and WebQueryTestClientDigest Integration Tests with JUnit 4.
+</p>
+<br/>
+
+<p><b>Requirements:</b><br/></p>
+<ul>
+<li>Apache 2.2.x Web Server installed and working on localhost</li>
+<li>JUnit 4.x Test Runner, like that inside Eclipse</li>
+<li>(optional) Apache Tomcat 6.0.x installed and working on localhost</li>
+</ul>
+
+
+<p><b>Test Setup for Apache:</b></p>
+<ul>
+<li>
+in the main Apache configuration file (APACHE_HOME/conf/httpd.conf) make some modify:<br/>
+enable the digest authentication module, removing the comment on it, for example:
+<pre>
+# LoadModule auth_digest_module modules/mod_auth_digest.so
+LoadModule auth_digest_module modules/mod_auth_digest.so
+</pre>
+Note that the module for the Basic Authentication (needed by the other class WebQueryTestClientBasic), by default is already enabled in Apache.<br/>
+<br/>
+Then, enable the usage of .htaccess files on the root folder (by default htdocs), for a simpler per-directory authentication and authorization setup:
+<pre>
+#     AllowOverride None
+    AllowOverride All
+or
+    AllowOverride AuthConfig
+</pre>
+Note that this is only a convenience setting, targeted at these tests.
+<br/>
+</li>
+<li>test that Apache works, starting/restarting it, to ensure the configuration is right
+<br/>
+</li>
+<li>go into the published directory (htdocs, or public_html, depending on the environment) and create the following empty directories:
+public (optional), protected (for testing basic authentication), protected_digest (for testing digest authentication), dir (for testing digest authentication, using the same values from the RFC)
+<br/>
+Copy some files (for example one binary like test.jpg, and one of text like test.txt) inside any of the previously-created directories.
+In the dir directory, put a index.html file (required by the test, because all tests as explained in the RFC use it).
+<br/>
+</li>
+<li>in the "dir" directory, create a (text) file named .htaccess , and put inside this:
+<pre>
+AuthType Digest
+
+# Note that with Digest Authentication, the value of AuthName must be the same as the realm
+AuthName "testrealm@host.com"
+
+AuthDigestDomain /dir/
+AuthUserFile  "htdocs/dir/.htpasswd"
+Require valid-user
+
+# Hack for enabling pre IE 7 to work good with Digest Authentication
+BrowserMatch "MSIE" AuthDigestEnableQueryStringHack=On
+</pre>
+<br/>
+</li>
+<li>in the "protected" dir (required by Basic Test), create a (text) file named .htaccess , and put inside this:
+<pre>
+AuthType Basic
+AuthName "Password Required"
+
+AuthUserFile  "htdocs/protected/.htpasswd"
+Require valid-user
+</pre>
+<br/>
+</li>
+<li>in the "protected_digest" dir, create a (text) file named .htaccess , and put inside this:
+<pre>
+AuthType Digest
+
+# Note that with Digest Authentication, the value of AuthName must be the same as the realm
+AuthName "Password Required (Digest)"
+
+AuthDigestDomain /protected_digest/
+AuthUserFile  "htdocs/protected_digest/.htpasswd"
+Require valid-user
+
+# Hack for enabling pre IE 7 to work good with Digest Authentication
+BrowserMatch "MSIE" AuthDigestEnableQueryStringHack=On
+</pre>
+<br/>
+</li>
+<li>from the prompt, use some standard Apache commands to create the digested passwords.
+If Apache commands are available in PATH, go directly in the target directory,
+otherwise for example you'll have to go to the main apache directory and launch them using for example bin\ht*.exe (for Windows),
+and then move the generated file into the right directory.
+<pre>
+Optional, for the "protected" (Basic Authentication) for example use:
+htpasswd -c .htpasswd test
+htpasswd will ask you for the password (in this case "test0", but without quotes), and then ask you to type it again to confirm it
+
+For the "protected_digest" (Digest Authentication) for example use:
+htdigest -c .htpasswd "Password Required (Digest)" test
+htdigest will ask you for the password (in this case "test0", but without quotes), and then ask you to type it again to confirm it
+<br/>
+For the "dir" (Digest Authentication) for example use:
+htdigest -c .htpasswd "testrealm@host.com" Mufasa
+htdigest will ask you for the password (in this case "Circle Of Life", but without quotes), and then ask you to type it again to confirm it
+</pre>
+<br/>
+</li>
+<li>manual test using a browser (to ensure the directories has been protected in the right way):
+point to the URL http://localhost/ , and then add (by hand) the subdirectory names, and try to access.
+Note that all protected directories are not visible from here.
+Any time required, the browser will open an Authentication popup, where to put username/password data (always without quotes).
+<br/>
+<pre>
+"protected/" needs username "test" and password "test0"
+"protected_digest/" needs username "test" and password "test0"
+"dir/" needs username "Mufasa" and password "Circle Of Life"
+</pre>
+<br/>
+</li>
+<li>execute the Test class, for example by running it from Eclipse (or by prompt), using JUnit 4, and see results.
+<br/>
+</li>
+</ul>
+
+<br/>
+
+
+<p><b>Test Setup for Tomcat:</b><p/>
+<ul>
+<li>under Tomcat things are different: first is needed a webapp, for example pivot-test
+</li>
+<li>
+then, configure the security (but of the full webapp) as BASIC or DIGEST, so it will be possible only one type of Integration Tests per run
+(or two different webapps could be used, like pivot-test-basic and pivot-test-digest)
+</li>
+<li>
+under the Tomcat Users file define the following (in the right XML format, inside the file):
+<pre>
+role rolename="test"
+user username="test" password="test0" roles="test"
+user username="Mufasa" password="Circle Of Life" roles="test"
+</pre>
+and then Restart Tomcat (important)
+<br/>
+Note that this is enough for BASIC authentication, while for DIGEST passwords must be written here in encoded format (digest),
+see the Tomcat docs for more detail on this.
+<br/>
+</li>
+<li>
+as with Apache, do a
+manual test using a browser (to ensure the directories has been protected in the right way and are accessible):
+point to the URL http://localhost:8080/pivot-test/ , and then add (by hand) the subdirectory names, and try to access.
+Note that all protected directories are not visible from here.
+Any time required, the browser will open an Authentication popup, where to put username/password data (always without quotes).
+</li>
+<li>
+change json data inside config files for Tests (any test has its own config) file that by default here works with Apache,
+so to make it work with Tomcat at least you'll have to comment the two lines defining the port and the webapp,
+and uncomment the two for Tomcat.
+</li>
+<li>
+suggestion: start running the BASIC authentication test, and only after the DIGEST.
+</li>
+<li>execute the Test class, for example by running it from Eclipse (or by prompt), using JUnit 4, and see results.
+<br/>
+</li>
+</ul>
+
+
+<br/>
+
+</body>
+</html>

Propchange: incubator/pivot/trunk/web/test/org/apache/pivot/web/test/package.html
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/ColorChooser.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/ColorChooserButton.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/ColorChooserButtonListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/ColorChooserButtonSelectionListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/ColorChooserListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/ColorChooserSelectionListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/skin/ColorChooserButtonSkin.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/skin/ColorChooserSkin.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/skin/terra/TerraColorChooserButtonSkin.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/skin/terra/TerraColorChooserSkin.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/skin/terra/TerraTextAreaSkin.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/src/org/apache/pivot/wtk/skin/terra/drive.png
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/octet-stream
+image/png

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/accordion_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/action_mapping_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/activity.wtkd
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/activity_indicator_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/application_handler_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/baseline_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/border_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/calendar_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/card_pane_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/chinese_characters_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/color_chooser_test.wtkx
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/color_chooser_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/color_list_button_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/context_menu_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/drawing_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/expander_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/flow_pane_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/font_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/form_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/image_view_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/include_test.content.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/include_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/label_test.wtkx
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/label_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/layout_cache_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/menu_bar_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/paint_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/panel_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/panorama_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/preferred_aspect_ratio_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/resolve_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/sample_drawing.wtkd
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/sample_drawing.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/script_application_test.frame.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/script_application_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/slider_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/spinner_focus_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/table_pane_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/table_view_test.wtkx
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/table_view_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/textInputValidator_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/text_input_test.wtkx
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/text_input_test.wtkx
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/test/watermark_decorator_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/text/test/document.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml

Propchange: incubator/pivot/trunk/wtk/test/org/apache/pivot/wtk/text/test/text_area_test.wtkx
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Nov  3 15:02:31 2009
@@ -1 +1 @@
-application/xml
+text/xml