You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@chemistry.apache.org by fg...@apache.org on 2010/07/29 19:18:22 UTC

svn commit: r980514 [2/4] - in /incubator/chemistry/opencmis/trunk/chemistry-opencmis-test: chemistry-opencmis-test-fit/src/main/webapp/WEB-INF/ chemistry-opencmis-test-fit/src/main/webapp/WEB-INF/classes/ chemistry-opencmis-test-fit/src/test/java/org/...

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/AbstractWriteObjectVersionIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/AbstractWriteObjectVersionIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/AbstractWriteObjectVersionIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/AbstractWriteObjectVersionIT.java Thu Jul 29 17:18:20 2010
@@ -1,83 +1,83 @@
-/*
- * 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.chemistry.opencmis.fit.runtime;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-
-import org.apache.chemistry.opencmis.client.api.Document;
-import org.apache.chemistry.opencmis.client.api.DocumentType;
-import org.apache.chemistry.opencmis.client.api.Folder;
-import org.apache.chemistry.opencmis.client.api.ItemIterable;
-import org.apache.chemistry.opencmis.client.api.ObjectId;
-import org.junit.Before;
-import org.junit.Test;
-
-public abstract class AbstractWriteObjectVersionIT extends AbstractSessionTest {
-
-    private ObjectId checkdOutId = null;
-
-    @Before
-    public void checkOutVersionableDocument() {
-        /* check out one versionable document */
-        String path = "/" + Fixture.TEST_ROOT_FOLDER_NAME + "/" + FixtureData.DOCUMENT1_NAME;
-        Document document = (Document) this.session.getObjectByPath(path);
-        assertNotNull("Document not found: " + path, document);
-        DocumentType dt = (DocumentType) document.getType();
-        assertNotNull(dt);
-        if (dt.isVersionable() != null && dt.isVersionable().booleanValue()) {
-            this.checkdOutId = document.checkOut();
-        }
-    }
-
-    @Test
-    public void checkOutDocs() {
-
-        /* get all verchecked out docs which should be exactly one or zero */
-        Folder f = this.session.getRootFolder();
-        assertNotNull(f);
-        ItemIterable<Document> pi = f.getCheckedOutDocs();
-        assertNotNull(pi);
-
-        for (Document d : pi) {
-            assertNotNull(d);
-            assertEquals(this.checkdOutId, d.getId());
-            break; // check only first and only loop entry
-        }
-
-    }
-
-    @Test
-    public void checkOutDocsSkip() {
-
-        /* get all verchecked out docs which should be exactly one or zero */
-        Folder f = this.session.getRootFolder();
-        assertNotNull(f);
-        ItemIterable<Document> pi = f.getCheckedOutDocs();
-        assertNotNull(pi);
-        // test skipTo and getPage
-        ItemIterable<Document> pii = pi.skipTo(2).getPage(2);
-        for (Document d : pii) {
-            assertNotNull(d);
-            assertEquals(this.checkdOutId, d.getId());
-            break; // check only first and only loop entry
-        }
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertNotNull;
+
+import org.apache.chemistry.opencmis.client.api.Document;
+import org.apache.chemistry.opencmis.client.api.DocumentType;
+import org.apache.chemistry.opencmis.client.api.Folder;
+import org.apache.chemistry.opencmis.client.api.ItemIterable;
+import org.apache.chemistry.opencmis.client.api.ObjectId;
+import org.junit.Before;
+import org.junit.Test;
+
+public abstract class AbstractWriteObjectVersionIT extends AbstractSessionTest {
+
+    private ObjectId checkdOutId = null;
+
+    @Before
+    public void checkOutVersionableDocument() {
+        /* check out one versionable document */
+        String path = "/" + Fixture.TEST_ROOT_FOLDER_NAME + "/" + FixtureData.DOCUMENT1_NAME;
+        Document document = (Document) this.session.getObjectByPath(path);
+        assertNotNull("Document not found: " + path, document);
+        DocumentType dt = (DocumentType) document.getType();
+        assertNotNull(dt);
+        if (dt.isVersionable() != null && dt.isVersionable().booleanValue()) {
+            this.checkdOutId = document.checkOut();
+        }
+    }
+
+    @Test
+    public void checkOutDocs() {
+
+        /* get all verchecked out docs which should be exactly one or zero */
+        Folder f = this.session.getRootFolder();
+        assertNotNull(f);
+        ItemIterable<Document> pi = f.getCheckedOutDocs();
+        assertNotNull(pi);
+
+        for (Document d : pi) {
+            assertNotNull(d);
+            assertEquals(this.checkdOutId, d.getId());
+            break; // check only first and only loop entry
+        }
+
+    }
+
+    @Test
+    public void checkOutDocsSkip() {
+
+        /* get all verchecked out docs which should be exactly one or zero */
+        Folder f = this.session.getRootFolder();
+        assertNotNull(f);
+        ItemIterable<Document> pi = f.getCheckedOutDocs();
+        assertNotNull(pi);
+        // test skipTo and getPage
+        ItemIterable<Document> pii = pi.skipTo(2).getPage(2);
+        for (Document d : pii) {
+            assertNotNull(d);
+            assertEquals(this.checkdOutId, d.getId());
+            break; // check only first and only loop entry
+        }
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/AbstractWriteObjectVersionIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/Fixture.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureData.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureData.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureData.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureData.java Thu Jul 29 17:18:20 2010
@@ -1,81 +1,81 @@
-/*
- * 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.chemistry.opencmis.fit.runtime;
-
-import java.util.Map;
-
-public enum FixtureData {
-	FOLDER_TYPE_ID("org.apache.chemistry.opencmis.fit.runtime.folder.type.id",
-			"cmis:folder"), DOCUMENT_TYPE_ID(
-			"org.apache.chemistry.opencmis.fit.runtime.document.type.id",
-			"cmis:document"), QUERY(
-			"org.apache.chemistry.opencmis.fit.runtime.query",
-			"SELECT * FROM cmis:document"), PROPERTY_FILTER(
-			"org.apache.chemistry.opencmis.fit.runtime.property.filter", "*"), FOLDER1_NAME(
-			"org.apache.chemistry.opencmis.fit.runtime.folder1.name", "folder1"), FOLDER2_NAME(
-			"org.apache.chemistry.opencmis.fit.runtime.folder2.name", "folder2"), DOCUMENT1_NAME(
-			"org.apache.chemistry.opencmis.fit.runtime.document1.name",
-			"document1.txt"), DOCUMENT2_NAME(
-			"org.apache.chemistry.opencmis.fit.runtime.document2.name",
-			"document2.txt"), 
-			PROPERTY_NAME_STRING_MULTI_VALUED("org.apache.chemistry.opencmis.fit.runtime.multi.valued.property.name", null);
-			;
-
-	private String key;
-	private String value;
-
-	FixtureData(String key, String value) {
-		this.key = key;
-		this.value = value;
-	}
-
-	public String value() {
-		return this.value;
-	}
-
-	public static void changeValues(Map<String, String> map) {
-		for (FixtureData fd : FixtureData.values()) {
-			String v = map.get(fd.key);
-			if (v != null) {
-				fd.changeValue(v);
-			}
-		}
-	}
-
-	public static FixtureData get(String key) {
-		for (FixtureData fd : FixtureData.values()) {
-			if (fd.key.equals(key)) {
-				return fd;
-			}
-		}
-		throw new IllegalArgumentException(key);
-	}
-
-	void changeValue(String newValue) {
-		this.value = newValue;
-	}
-
-	public String toString() {
-		return this.value();
-	}
-
-	public String key() {
-		return this.key;
-	}
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime;
+
+import java.util.Map;
+
+public enum FixtureData {
+	FOLDER_TYPE_ID("org.apache.chemistry.opencmis.fit.runtime.folder.type.id",
+			"cmis:folder"), DOCUMENT_TYPE_ID(
+			"org.apache.chemistry.opencmis.fit.runtime.document.type.id",
+			"cmis:document"), QUERY(
+			"org.apache.chemistry.opencmis.fit.runtime.query",
+			"SELECT * FROM cmis:document"), PROPERTY_FILTER(
+			"org.apache.chemistry.opencmis.fit.runtime.property.filter", "*"), FOLDER1_NAME(
+			"org.apache.chemistry.opencmis.fit.runtime.folder1.name", "folder1"), FOLDER2_NAME(
+			"org.apache.chemistry.opencmis.fit.runtime.folder2.name", "folder2"), DOCUMENT1_NAME(
+			"org.apache.chemistry.opencmis.fit.runtime.document1.name",
+			"document1.txt"), DOCUMENT2_NAME(
+			"org.apache.chemistry.opencmis.fit.runtime.document2.name",
+			"document2.txt"), 
+			PROPERTY_NAME_STRING_MULTI_VALUED("org.apache.chemistry.opencmis.fit.runtime.multi.valued.property.name", null);
+			;
+
+	private String key;
+	private String value;
+
+	FixtureData(String key, String value) {
+		this.key = key;
+		this.value = value;
+	}
+
+	public String value() {
+		return this.value;
+	}
+
+	public static void changeValues(Map<String, String> map) {
+		for (FixtureData fd : FixtureData.values()) {
+			String v = map.get(fd.key);
+			if (v != null) {
+				fd.changeValue(v);
+			}
+		}
+	}
+
+	public static FixtureData get(String key) {
+		for (FixtureData fd : FixtureData.values()) {
+			if (fd.key.equals(key)) {
+				return fd;
+			}
+		}
+		throw new IllegalArgumentException(key);
+	}
+
+	void changeValue(String newValue) {
+		this.value = newValue;
+	}
+
+	public String toString() {
+		return this.value();
+	}
+
+	public String key() {
+		return this.key;
+	}
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureData.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureSetup.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureSetup.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureSetup.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureSetup.java Thu Jul 29 17:18:20 2010
@@ -1,109 +1,109 @@
-/*
- * 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.chemistry.opencmis.fit.runtime;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import org.apache.chemistry.opencmis.client.bindings.CmisBindingFactory;
-import org.apache.chemistry.opencmis.commons.PropertyIds;
-import org.apache.chemistry.opencmis.commons.SessionParameter;
-import org.apache.chemistry.opencmis.commons.data.Properties;
-import org.apache.chemistry.opencmis.commons.data.PropertyData;
-import org.apache.chemistry.opencmis.commons.data.RepositoryInfo;
-import org.apache.chemistry.opencmis.commons.enums.UnfileObject;
-import org.apache.chemistry.opencmis.commons.spi.CmisBinding;
-import org.apache.chemistry.opencmis.util.repository.ObjectGenerator;
-import org.junit.Assert;
-
-public class FixtureSetup {
-
-    private CmisBinding binding = null;
-    private String rootFolderId = null; // root
-    private String testRootFolderId = null; // test root
-    private String repositoryId = null;
-    private Fixture fixture = null;
-
-    public FixtureSetup(Fixture fixture) {
-        this.fixture = fixture;
-    }
-
-    public void teardown() {
-        this.binding.getObjectService().deleteTree(this.repositoryId, this.testRootFolderId, true, UnfileObject.DELETE,
-                true, null);
-    }
-
-    public void setup() {
-        this.repositoryId = this.fixture.getParamter().get(SessionParameter.REPOSITORY_ID);
-        Assert.assertNotNull(this.repositoryId);
-
-        this.binding = CmisBindingFactory.newInstance().createCmisBinding(this.fixture.getParamter());
-        Assert.assertNotNull(this.binding);
-
-        // root folder
-        if (this.fixture.getParamter().containsKey(Fixture.TEST_ROOT_FOLDER_ID)) {
-            // test root folder
-            this.rootFolderId = this.fixture.getParamter().get(Fixture.TEST_ROOT_FOLDER_ID);
-            Assert.assertNotNull(this.rootFolderId);
-        } else {
-            RepositoryInfo rid = this.binding.getRepositoryService().getRepositoryInfo(this.repositoryId, null);
-            Assert.assertNotNull(rid);
-            this.rootFolderId = rid.getRootFolderId();
-            Assert.assertNotNull(this.rootFolderId);
-        }
-
-        // object types
-        String documentTypeId = FixtureData.DOCUMENT_TYPE_ID.value();
-        Assert.assertNotNull(documentTypeId);
-        String folderTypeId = FixtureData.FOLDER_TYPE_ID.value();
-        Assert.assertNotNull(folderTypeId);
-
-        // create test root folder
-        List<PropertyData<?>> propList = new ArrayList<PropertyData<?>>();
-        propList.add(this.binding.getObjectFactory().createPropertyStringData(PropertyIds.NAME,
-                Fixture.TEST_ROOT_FOLDER_NAME));
-        propList.add(this.binding.getObjectFactory().createPropertyIdData(PropertyIds.OBJECT_TYPE_ID, folderTypeId));
-
-        Properties properties = this.binding.getObjectFactory().createPropertiesData(propList);
-
-        this.testRootFolderId = this.binding.getObjectService().createFolder(this.repositoryId, properties,
-                this.rootFolderId, null, null, null, null);
-        Assert.assertNotNull(this.testRootFolderId);
-
-        ObjectGenerator og = new ObjectGenerator(binding.getObjectFactory(), binding.getNavigationService(), binding
-                .getObjectService(), this.repositoryId);
-
-        og.setContentSizeInKB(10);
-        og.setDocumentTypeId(documentTypeId);
-        og.setFolderTypeId(folderTypeId);
-        og.setNumberOfDocumentsToCreatePerFolder(2);
-        og.setDocumentPropertiesToGenerate(new ArrayList<String>());
-        og.setFolderPropertiesToGenerate(new ArrayList<String>());
-
-        og.createFolderHierachy(2, 2, this.testRootFolderId);
-    }
-
-    public String getTestRootId() {
-        if (this.testRootFolderId == null) {
-            this.testRootFolderId = Fixture.TEST_ROOT_FOLDER_NAME;
-        }
-        return this.testRootFolderId;
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime;
+
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.chemistry.opencmis.client.bindings.CmisBindingFactory;
+import org.apache.chemistry.opencmis.commons.PropertyIds;
+import org.apache.chemistry.opencmis.commons.SessionParameter;
+import org.apache.chemistry.opencmis.commons.data.Properties;
+import org.apache.chemistry.opencmis.commons.data.PropertyData;
+import org.apache.chemistry.opencmis.commons.data.RepositoryInfo;
+import org.apache.chemistry.opencmis.commons.enums.UnfileObject;
+import org.apache.chemistry.opencmis.commons.spi.CmisBinding;
+import org.apache.chemistry.opencmis.util.repository.ObjectGenerator;
+import org.junit.Assert;
+
+public class FixtureSetup {
+
+    private CmisBinding binding = null;
+    private String rootFolderId = null; // root
+    private String testRootFolderId = null; // test root
+    private String repositoryId = null;
+    private Fixture fixture = null;
+
+    public FixtureSetup(Fixture fixture) {
+        this.fixture = fixture;
+    }
+
+    public void teardown() {
+        this.binding.getObjectService().deleteTree(this.repositoryId, this.testRootFolderId, true, UnfileObject.DELETE,
+                true, null);
+    }
+
+    public void setup() {
+        this.repositoryId = this.fixture.getParamter().get(SessionParameter.REPOSITORY_ID);
+        Assert.assertNotNull(this.repositoryId);
+
+        this.binding = CmisBindingFactory.newInstance().createCmisBinding(this.fixture.getParamter());
+        Assert.assertNotNull(this.binding);
+
+        // root folder
+        if (this.fixture.getParamter().containsKey(Fixture.TEST_ROOT_FOLDER_ID)) {
+            // test root folder
+            this.rootFolderId = this.fixture.getParamter().get(Fixture.TEST_ROOT_FOLDER_ID);
+            Assert.assertNotNull(this.rootFolderId);
+        } else {
+            RepositoryInfo rid = this.binding.getRepositoryService().getRepositoryInfo(this.repositoryId, null);
+            Assert.assertNotNull(rid);
+            this.rootFolderId = rid.getRootFolderId();
+            Assert.assertNotNull(this.rootFolderId);
+        }
+
+        // object types
+        String documentTypeId = FixtureData.DOCUMENT_TYPE_ID.value();
+        Assert.assertNotNull(documentTypeId);
+        String folderTypeId = FixtureData.FOLDER_TYPE_ID.value();
+        Assert.assertNotNull(folderTypeId);
+
+        // create test root folder
+        List<PropertyData<?>> propList = new ArrayList<PropertyData<?>>();
+        propList.add(this.binding.getObjectFactory().createPropertyStringData(PropertyIds.NAME,
+                Fixture.TEST_ROOT_FOLDER_NAME));
+        propList.add(this.binding.getObjectFactory().createPropertyIdData(PropertyIds.OBJECT_TYPE_ID, folderTypeId));
+
+        Properties properties = this.binding.getObjectFactory().createPropertiesData(propList);
+
+        this.testRootFolderId = this.binding.getObjectService().createFolder(this.repositoryId, properties,
+                this.rootFolderId, null, null, null, null);
+        Assert.assertNotNull(this.testRootFolderId);
+
+        ObjectGenerator og = new ObjectGenerator(binding.getObjectFactory(), binding.getNavigationService(), binding
+                .getObjectService(), this.repositoryId);
+
+        og.setContentSizeInKB(10);
+        og.setDocumentTypeId(documentTypeId);
+        og.setFolderTypeId(folderTypeId);
+        og.setNumberOfDocumentsToCreatePerFolder(2);
+        og.setDocumentPropertiesToGenerate(new ArrayList<String>());
+        og.setFolderPropertiesToGenerate(new ArrayList<String>());
+
+        og.createFolderHierachy(2, 2, this.testRootFolderId);
+    }
+
+    public String getTestRootId() {
+        if (this.testRootFolderId == null) {
+            this.testRootFolderId = Fixture.TEST_ROOT_FOLDER_NAME;
+        }
+        return this.testRootFolderId;
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureSetup.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyAclCapabilityAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyContentStreamAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyDiscoverAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyNavigationAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyObjectAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyRepositoryInfoAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlySessionAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/ReadOnlyTypeAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteAclAtomPubIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteAclAtomPubIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteAclAtomPubIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteAclAtomPubIT.java Thu Jul 29 17:18:20 2010
@@ -1,33 +1,33 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.atom;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteAclT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-import org.junit.Ignore;
-
-@Ignore
-public class WriteAclAtomPubIT extends AbstractWriteAclT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        this.fixture.enableAtomPub();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.atom;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteAclT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+import org.junit.Ignore;
+
+@Ignore
+public class WriteAclAtomPubIT extends AbstractWriteAclT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        this.fixture.enableAtomPub();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteAclAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectAtomPubIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectAtomPubIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectAtomPubIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectAtomPubIT.java Thu Jul 29 17:18:20 2010
@@ -1,31 +1,31 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.atom;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectIT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-
-public class WriteObjectAtomPubIT extends AbstractWriteObjectIT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        fixture.enableAtomPub();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.atom;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectIT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+
+public class WriteObjectAtomPubIT extends AbstractWriteObjectIT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        fixture.enableAtomPub();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectRelationAtomPubIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectRelationAtomPubIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectRelationAtomPubIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectRelationAtomPubIT.java Thu Jul 29 17:18:20 2010
@@ -1,34 +1,34 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.atom;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectRelationIT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-import org.junit.Ignore;
-
-// relations not yet supported
-@Ignore
-public class WriteObjectRelationAtomPubIT extends AbstractWriteObjectRelationIT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        fixture.enableAtomPub();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.atom;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectRelationIT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+import org.junit.Ignore;
+
+// relations not yet supported
+@Ignore
+public class WriteObjectRelationAtomPubIT extends AbstractWriteObjectRelationIT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        fixture.enableAtomPub();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectRelationAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectVersionAtomPubIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectVersionAtomPubIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectVersionAtomPubIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectVersionAtomPubIT.java Thu Jul 29 17:18:20 2010
@@ -1,30 +1,30 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.atom;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectVersionIT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-
-public class WriteObjectVersionAtomPubIT extends AbstractWriteObjectVersionIT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        fixture.enableAtomPub();
-    }
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.atom;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectVersionIT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+
+public class WriteObjectVersionAtomPubIT extends AbstractWriteObjectVersionIT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        fixture.enableAtomPub();
+    }
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/atom/WriteObjectVersionAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/misc/AbstractReadOnlyCreateSessionIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/misc/ReadOnlyCreateSessionAtomPubIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/misc/ReadOnlyCreateSessionWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyAclCapabilityWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyContentStreamWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyDiscoverWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyNavigationWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyObjectWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyRepositoryInfoWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlySessionWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/ReadOnlyTypeWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteAclWebServicesIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteAclWebServicesIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteAclWebServicesIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteAclWebServicesIT.java Thu Jul 29 17:18:20 2010
@@ -1,33 +1,33 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.webservices;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteAclT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-import org.junit.Ignore;
-
-@Ignore
-public class WriteAclWebServicesIT extends AbstractWriteAclT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        this.fixture.enableWebServices();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.webservices;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteAclT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+import org.junit.Ignore;
+
+@Ignore
+public class WriteAclWebServicesIT extends AbstractWriteAclT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        this.fixture.enableWebServices();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteAclWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectRelationWebServicesIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectRelationWebServicesIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectRelationWebServicesIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectRelationWebServicesIT.java Thu Jul 29 17:18:20 2010
@@ -1,34 +1,34 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.webservices;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectRelationIT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-import org.junit.Ignore;
-
-// relations not yet supported
-@Ignore
-public class WriteObjectRelationWebServicesIT extends AbstractWriteObjectRelationIT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        fixture.enableWebServices();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.webservices;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectRelationIT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+import org.junit.Ignore;
+
+// relations not yet supported
+@Ignore
+public class WriteObjectRelationWebServicesIT extends AbstractWriteObjectRelationIT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        fixture.enableWebServices();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectRelationWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectVersionWebServicesIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectVersionWebServicesIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectVersionWebServicesIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectVersionWebServicesIT.java Thu Jul 29 17:18:20 2010
@@ -1,30 +1,30 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.webservices;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectVersionIT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-
-public class WriteObjectVersionWebServicesIT extends AbstractWriteObjectVersionIT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        fixture.enableWebServices();
-    }
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.webservices;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectVersionIT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+
+public class WriteObjectVersionWebServicesIT extends AbstractWriteObjectVersionIT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        fixture.enableWebServices();
+    }
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectVersionWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectWebServicesIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectWebServicesIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectWebServicesIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectWebServicesIT.java Thu Jul 29 17:18:20 2010
@@ -1,31 +1,31 @@
-/*
- * 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.chemistry.opencmis.fit.runtime.webservices;
-
-import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectIT;
-import org.apache.chemistry.opencmis.fit.runtime.Fixture;
-
-public class WriteObjectWebServicesIT extends AbstractWriteObjectIT {
-
-    @Override
-    public void initFixture(Fixture fixture) {
-        fixture.enableWebServices();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.runtime.webservices;
+
+import org.apache.chemistry.opencmis.fit.runtime.AbstractWriteObjectIT;
+import org.apache.chemistry.opencmis.fit.runtime.Fixture;
+
+public class WriteObjectWebServicesIT extends AbstractWriteObjectIT {
+
+    @Override
+    public void initFixture(Fixture fixture) {
+        fixture.enableWebServices();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/webservices/WriteObjectWebServicesIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AbstractSampleIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AbstractSampleIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AbstractSampleIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AbstractSampleIT.java Thu Jul 29 17:18:20 2010
@@ -1,166 +1,166 @@
-/*
- * 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.chemistry.opencmis.fit.sample;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertTrue;
-
-import java.util.List;
-
-import org.apache.chemistry.opencmis.client.api.ItemIterable;
-import org.apache.chemistry.opencmis.client.api.ObjectType;
-import org.apache.chemistry.opencmis.client.api.Session;
-import org.apache.chemistry.opencmis.client.api.Tree;
-import org.apache.chemistry.opencmis.commons.data.RepositoryInfo;
-import org.apache.chemistry.opencmis.commons.enums.BaseTypeId;
-import org.apache.chemistry.opencmis.fit.SessionFactory;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Test;
-
-/**
- * Sample test case that demonstrates how to build integration tests.
- * 
- * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
- * 
- */
-public abstract class AbstractSampleIT {
-
-    private static Session fSession;
-
-    /**
-     * Returns the current Session object.
-     */
-    protected Session getSession() {
-        return fSession;
-    }
-
-    /**
-     * Returns a new Session object.
-     */
-    protected abstract Session createSession();
-
-    @BeforeClass
-    public static void setUpClass() {
-        fSession = null;
-    }
-
-    @Before
-    public void setUp() {
-        if (fSession == null) {
-            fSession = createSession();
-        }
-    }
-
-    /**
-     * Simple repository info test.
-     */
-    @Test
-    public void testRepositoryInfo() {
-        RepositoryInfo ri = getSession().getRepositoryInfo();
-        assertNotNull(ri);
-        assertEquals(SessionFactory.getRepositoryId(), ri.getId());
-        assertNotNull(ri.getName());
-        assertNotNull(ri.getRootFolderId());
-        assertNotNull(ri.getCmisVersionSupported());
-        assertNotNull(ri.getCapabilities());
-        // assertNotNull(ri.getAclCapabilities());
-    }
-
-    /**
-     * Simple types test.
-     */
-    @Test
-    public void testTypes() {
-        String documentBaseId = "cmis:document";
-        String folderBaseId = "cmis:folder";
-
-        // check document type definition
-        ObjectType documentType = getSession().getTypeDefinition(documentBaseId);
-        checkBaseType(documentBaseId, BaseTypeId.CMIS_DOCUMENT, documentType);
-
-        // check folder type definition
-        ObjectType folderType = getSession().getTypeDefinition(folderBaseId);
-        checkBaseType(folderBaseId, BaseTypeId.CMIS_FOLDER, folderType);
-
-        // get base types via getTypesChildren
-        ItemIterable<ObjectType> baseTypes = getSession().getTypeChildren(null, true);
-        assertNotNull(baseTypes);
-
-        boolean hasDocumentBaseType = false;
-        boolean hasFolderBaseType = false;
-        for (ObjectType ot : baseTypes) {
-            checkBaseType(null, null, ot);
-
-            if (ot.getId().equals(documentBaseId)) {
-                hasDocumentBaseType = true;
-            }
-
-            if (ot.getId().equals(folderBaseId)) {
-                hasFolderBaseType = true;
-            }
-        }
-
-        assertTrue(hasDocumentBaseType);
-        assertTrue(hasFolderBaseType);
-
-        // get base types via getTypeDescendants
-        List<Tree<ObjectType>> baseTypeDesc = getSession().getTypeDescendants(null, -1, true);
-        assertNotNull(baseTypeDesc);
-
-        hasDocumentBaseType = false;
-        hasFolderBaseType = false;
-        for (Tree<ObjectType> cot : baseTypeDesc) {
-            assertNotNull(cot);
-            // checkBaseType(null, null, cot.getItem());
-
-            if (cot.getItem().getId().equals(documentBaseId)) {
-                hasDocumentBaseType = true;
-            }
-
-            if (cot.getItem().getId().equals(folderBaseId)) {
-                hasFolderBaseType = true;
-            }
-        }
-
-        assertTrue(hasDocumentBaseType);
-        assertTrue(hasFolderBaseType);
-    }
-
-    /**
-     * Checks a base type.
-     */
-    private void checkBaseType(String id, BaseTypeId baseType, ObjectType objectType) {
-        assertNotNull(objectType);
-        if (id != null) {
-            assertEquals(id, objectType.getId());
-        }
-        if (baseType != null) {
-            assertEquals(baseType, objectType.getBaseTypeId());
-        }
-        assertTrue(objectType.isBaseType());
-        assertNull(objectType.getBaseType());
-        assertNull(objectType.getParentType());
-        assertNotNull(objectType.getPropertyDefinitions());
-        assertFalse(objectType.getPropertyDefinitions().isEmpty());
-    }
-}
+/*
+ * 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.chemistry.opencmis.fit.sample;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertNotNull;
+import static org.junit.Assert.assertNull;
+import static org.junit.Assert.assertTrue;
+
+import java.util.List;
+
+import org.apache.chemistry.opencmis.client.api.ItemIterable;
+import org.apache.chemistry.opencmis.client.api.ObjectType;
+import org.apache.chemistry.opencmis.client.api.Session;
+import org.apache.chemistry.opencmis.client.api.Tree;
+import org.apache.chemistry.opencmis.commons.data.RepositoryInfo;
+import org.apache.chemistry.opencmis.commons.enums.BaseTypeId;
+import org.apache.chemistry.opencmis.fit.SessionFactory;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Test;
+
+/**
+ * Sample test case that demonstrates how to build integration tests.
+ * 
+ * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
+ * 
+ */
+public abstract class AbstractSampleIT {
+
+    private static Session fSession;
+
+    /**
+     * Returns the current Session object.
+     */
+    protected Session getSession() {
+        return fSession;
+    }
+
+    /**
+     * Returns a new Session object.
+     */
+    protected abstract Session createSession();
+
+    @BeforeClass
+    public static void setUpClass() {
+        fSession = null;
+    }
+
+    @Before
+    public void setUp() {
+        if (fSession == null) {
+            fSession = createSession();
+        }
+    }
+
+    /**
+     * Simple repository info test.
+     */
+    @Test
+    public void testRepositoryInfo() {
+        RepositoryInfo ri = getSession().getRepositoryInfo();
+        assertNotNull(ri);
+        assertEquals(SessionFactory.getRepositoryId(), ri.getId());
+        assertNotNull(ri.getName());
+        assertNotNull(ri.getRootFolderId());
+        assertNotNull(ri.getCmisVersionSupported());
+        assertNotNull(ri.getCapabilities());
+        // assertNotNull(ri.getAclCapabilities());
+    }
+
+    /**
+     * Simple types test.
+     */
+    @Test
+    public void testTypes() {
+        String documentBaseId = "cmis:document";
+        String folderBaseId = "cmis:folder";
+
+        // check document type definition
+        ObjectType documentType = getSession().getTypeDefinition(documentBaseId);
+        checkBaseType(documentBaseId, BaseTypeId.CMIS_DOCUMENT, documentType);
+
+        // check folder type definition
+        ObjectType folderType = getSession().getTypeDefinition(folderBaseId);
+        checkBaseType(folderBaseId, BaseTypeId.CMIS_FOLDER, folderType);
+
+        // get base types via getTypesChildren
+        ItemIterable<ObjectType> baseTypes = getSession().getTypeChildren(null, true);
+        assertNotNull(baseTypes);
+
+        boolean hasDocumentBaseType = false;
+        boolean hasFolderBaseType = false;
+        for (ObjectType ot : baseTypes) {
+            checkBaseType(null, null, ot);
+
+            if (ot.getId().equals(documentBaseId)) {
+                hasDocumentBaseType = true;
+            }
+
+            if (ot.getId().equals(folderBaseId)) {
+                hasFolderBaseType = true;
+            }
+        }
+
+        assertTrue(hasDocumentBaseType);
+        assertTrue(hasFolderBaseType);
+
+        // get base types via getTypeDescendants
+        List<Tree<ObjectType>> baseTypeDesc = getSession().getTypeDescendants(null, -1, true);
+        assertNotNull(baseTypeDesc);
+
+        hasDocumentBaseType = false;
+        hasFolderBaseType = false;
+        for (Tree<ObjectType> cot : baseTypeDesc) {
+            assertNotNull(cot);
+            // checkBaseType(null, null, cot.getItem());
+
+            if (cot.getItem().getId().equals(documentBaseId)) {
+                hasDocumentBaseType = true;
+            }
+
+            if (cot.getItem().getId().equals(folderBaseId)) {
+                hasFolderBaseType = true;
+            }
+        }
+
+        assertTrue(hasDocumentBaseType);
+        assertTrue(hasFolderBaseType);
+    }
+
+    /**
+     * Checks a base type.
+     */
+    private void checkBaseType(String id, BaseTypeId baseType, ObjectType objectType) {
+        assertNotNull(objectType);
+        if (id != null) {
+            assertEquals(id, objectType.getId());
+        }
+        if (baseType != null) {
+            assertEquals(baseType, objectType.getBaseTypeId());
+        }
+        assertTrue(objectType.isBaseType());
+        assertNull(objectType.getBaseType());
+        assertNull(objectType.getParentType());
+        assertNotNull(objectType.getPropertyDefinitions());
+        assertFalse(objectType.getPropertyDefinitions().isEmpty());
+    }
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AbstractSampleIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AtomPubSampleIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AtomPubSampleIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AtomPubSampleIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AtomPubSampleIT.java Thu Jul 29 17:18:20 2010
@@ -1,37 +1,37 @@
-/*
- * 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.chemistry.opencmis.fit.sample;
-
-import org.apache.chemistry.opencmis.client.api.Session;
-import org.apache.chemistry.opencmis.fit.SessionFactory;
-
-/**
- * AtomPub sample test.
- * 
- * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
- * 
- */
-public class AtomPubSampleIT extends AbstractSampleIT {
-
-    @Override
-    protected Session createSession() {
-        return SessionFactory.createAtomPubSession();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.sample;
+
+import org.apache.chemistry.opencmis.client.api.Session;
+import org.apache.chemistry.opencmis.fit.SessionFactory;
+
+/**
+ * AtomPub sample test.
+ * 
+ * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
+ * 
+ */
+public class AtomPubSampleIT extends AbstractSampleIT {
+
+    @Override
+    protected Session createSession() {
+        return SessionFactory.createAtomPubSession();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/AtomPubSampleIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/WebServicesSampleIT.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/WebServicesSampleIT.java?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/WebServicesSampleIT.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/WebServicesSampleIT.java Thu Jul 29 17:18:20 2010
@@ -1,37 +1,37 @@
-/*
- * 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.chemistry.opencmis.fit.sample;
-
-import org.apache.chemistry.opencmis.client.api.Session;
-import org.apache.chemistry.opencmis.fit.SessionFactory;
-
-/**
- * Web Services sample test.
- * 
- * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
- * 
- */
-public class WebServicesSampleIT extends AbstractSampleIT {
-
-    @Override
-    protected Session createSession() {
-        return SessionFactory.createWebServicesSession();
-    }
-
-}
+/*
+ * 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.chemistry.opencmis.fit.sample;
+
+import org.apache.chemistry.opencmis.client.api.Session;
+import org.apache.chemistry.opencmis.fit.SessionFactory;
+
+/**
+ * Web Services sample test.
+ * 
+ * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
+ * 
+ */
+public class WebServicesSampleIT extends AbstractSampleIT {
+
+    @Override
+    protected Session createSession() {
+        return SessionFactory.createWebServicesSession();
+    }
+
+}

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/sample/WebServicesSampleIT.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/resources/inmemory.atom.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/resources/inmemory.ws.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/resources/log4j.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/runCreate.bat
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/runCreate.bat?rev=980514&r1=980513&r2=980514&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/runCreate.bat (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/runCreate.bat Thu Jul 29 17:18:20 2010
@@ -1,21 +1,21 @@
-rem
-rem
-rem Licensed to the Apache Software Foundation (ASF) under one
-rem or more contributor license agreements.  See the NOTICE file
-rem distributed with this work for additional information
-rem regarding copyright ownership.  The ASF licenses this file
-rem to you under the Apache License, Version 2.0 (the
-rem "License"); you may not use this file except in compliance
-rem with the License.  You may obtain a copy of the License at
-rem
-rem   http://www.apache.org/licenses/LICENSE-2.0
-rem
-rem Unless required by applicable law or agreed to in writing,
-rem software distributed under the License is distributed on an
-rem "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-rem KIND, either express or implied.  See the License for the
-rem specific language governing permissions and limitations
-rem under the License.
-rem
-rem
-call runcmd.bat --Binding=AtomPub --Command=CreateDocument --RepositoryId=A1 --ContentSizeInKB=25
+rem
+rem
+rem Licensed to the Apache Software Foundation (ASF) under one
+rem or more contributor license agreements.  See the NOTICE file
+rem distributed with this work for additional information
+rem regarding copyright ownership.  The ASF licenses this file
+rem to you under the Apache License, Version 2.0 (the
+rem "License"); you may not use this file except in compliance
+rem with the License.  You may obtain a copy of the License at
+rem
+rem   http://www.apache.org/licenses/LICENSE-2.0
+rem
+rem Unless required by applicable law or agreed to in writing,
+rem software distributed under the License is distributed on an
+rem "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+rem KIND, either express or implied.  See the License for the
+rem specific language governing permissions and limitations
+rem under the License.
+rem
+rem
+call runcmd.bat --Binding=AtomPub --Command=CreateDocument --RepositoryId=A1 --ContentSizeInKB=25

Propchange: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/runCreate.bat
------------------------------------------------------------------------------
    svn:eol-style = CRLF