You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@chemistry.apache.org by fm...@apache.org on 2010/04/15 11:03:51 UTC

svn commit: r934333 [1/2] - in /incubator/chemistry/opencmis/trunk: chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/ chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/main/ja...

Author: fmui
Date: Thu Apr 15 09:03:50 2010
New Revision: 934333

URL: http://svn.apache.org/viewvc?rev=934333&view=rev
Log:
- first step to remove the term "provider"

Added:
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/CmisBindingHelper.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/BindingsObjectFactory.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/CmisBinding.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-impl/src/main/java/org/apache/chemistry/opencmis/commons/impl/dataobjects/BindingsObjectFactoryImpl.java
Removed:
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/main/java/org/apache/chemistry/opencmis/client/provider/
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/test/java/org/apache/chemistry/opencmis/client/provider/
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/CmisProviderHelper.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/CmisProvider.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/ProviderObjectFactory.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-impl/src/main/java/org/apache/chemistry/opencmis/commons/impl/dataobjects/ProviderObjectFactoryImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/provider/
Modified:
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/Session.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/test/java/log4j.properties
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentCmisObject.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentFilableCmisObject.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentDocumentImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentFolderImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentSessionImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/RenditionImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/SessionFactoryImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/repository/PersistentObjectFactoryImpl.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/SessionFactory.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/runtime/FixtureSetup.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Command.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Commander.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/DeleteCommand.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/InfosCommand.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/ListCommand.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/MultiThreadedObjectGenerator.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/ObjGenApp.java
    incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/ObjectGenerator.java

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/Session.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/Session.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/Session.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/Session.java Thu Apr 15 09:03:50 2010
@@ -30,7 +30,7 @@ import org.apache.chemistry.opencmis.cli
 import org.apache.chemistry.opencmis.client.api.util.PagingList;
 import org.apache.chemistry.opencmis.commons.enums.IncludeRelationships;
 import org.apache.chemistry.opencmis.commons.enums.VersioningState;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 
 /**
  * A session is associated with a specific connection to a CMIS repository. A session belongs to one
@@ -47,9 +47,9 @@ public interface Session {
   // session context
 
   /**
-   * Gets the underlying provider object.
+   * Gets the underlying binding object.
    */
-  CmisProvider getProvider();
+  CmisBinding getBinding();
 
   /**
    * Get the current default operation parameters for filtering and paging.

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/test/java/log4j.properties
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/test/java/log4j.properties?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/test/java/log4j.properties (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/test/java/log4j.properties Thu Apr 15 09:03:50 2010
@@ -19,4 +19,4 @@ log4j.appender.O.layout=org.apache.log4j
 log4j.appender.R.layout.ConversionPattern=%d{ISO8601} %-5p [%t] %c: %m%n
 log4j.appender.O.layout.ConversionPattern=%d{ISO8601} %-5p [%t] %c: %m%n
 
-log4j.logger.org.apache.opencmis.client.provider.spi=O
\ No newline at end of file
+log4j.logger.org.apache.opencmis.client.bindings.spi=O
\ No newline at end of file

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentCmisObject.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentCmisObject.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentCmisObject.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentCmisObject.java Thu Apr 15 09:03:50 2010
@@ -50,7 +50,7 @@ import org.apache.chemistry.opencmis.com
 import org.apache.chemistry.opencmis.commons.enums.Cardinality;
 import org.apache.chemistry.opencmis.commons.enums.RelationshipDirection;
 import org.apache.chemistry.opencmis.commons.enums.Updatability;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.Holder;
 import org.apache.chemistry.opencmis.commons.provider.ObjectData;
 import org.apache.chemistry.opencmis.commons.provider.ObjectList;
@@ -207,10 +207,10 @@ public abstract class AbstractPersistent
   }
 
   /**
-   * Returns the provider object.
+   * Returns the binding object.
    */
-  protected CmisProvider getProvider() {
-    return getSession().getProvider();
+  protected CmisBinding getBinding() {
+    return getSession().getBinding();
   }
 
   /**
@@ -241,7 +241,7 @@ public abstract class AbstractPersistent
    */
   public void delete(boolean allVersions) {
     String objectId = getObjectId();
-    getProvider().getObjectService().deleteObject(getRepositoryId(), objectId, allVersions, null);
+    getBinding().getObjectService().deleteObject(getRepositoryId(), objectId, allVersions, null);
   }
 
   /*
@@ -268,7 +268,7 @@ public abstract class AbstractPersistent
       }
 
       // it's time to update
-      getProvider().getObjectService().updateProperties(getRepositoryId(), objectIdHolder,
+      getBinding().getObjectService().updateProperties(getRepositoryId(), objectIdHolder,
           changeTokenHolder,
           getObjectFactory().convertProperties(this.properties, this.objectType, updatebility),
           null);
@@ -312,7 +312,7 @@ public abstract class AbstractPersistent
       }
 
       // it's time to update
-      getProvider().getObjectService().updateProperties(getRepositoryId(), objectIdHolder,
+      getBinding().getObjectService().updateProperties(getRepositoryId(), objectIdHolder,
           changeTokenHolder,
           getObjectFactory().convertProperties(properties, this.objectType, updatebility), null);
 
@@ -606,7 +606,7 @@ public abstract class AbstractPersistent
 
     ObjectFactory of = getObjectFactory();
 
-    return of.convertAcl(getProvider().getAclService().getAcl(getRepositoryId(), objectId,
+    return of.convertAcl(getBinding().getAclService().getAcl(getRepositoryId(), objectId,
         onlyBasicPermissions, null));
   }
 
@@ -621,7 +621,7 @@ public abstract class AbstractPersistent
 
     ObjectFactory of = getObjectFactory();
 
-    return of.convertAcl(getProvider().getAclService().applyAcl(getRepositoryId(), objectId,
+    return of.convertAcl(getBinding().getAclService().applyAcl(getRepositoryId(), objectId,
         of.convertAces(addAces), of.convertAces(removeAces), aclPropagation, null));
   }
 
@@ -674,8 +674,8 @@ public abstract class AbstractPersistent
     }
 
     String objectId = getObjectId();
-    getProvider().getPolicyService().applyPolicy(getRepositoryId(), policyId.getId(), objectId,
-        null);
+    getBinding().getPolicyService()
+        .applyPolicy(getRepositoryId(), policyId.getId(), objectId, null);
   }
 
   /*
@@ -690,7 +690,7 @@ public abstract class AbstractPersistent
     }
 
     String objectId = getObjectId();
-    getProvider().getPolicyService().removePolicy(getRepositoryId(), policyId.getId(), objectId,
+    getBinding().getPolicyService().removePolicy(getRepositoryId(), policyId.getId(), objectId,
         null);
   }
 
@@ -743,7 +743,7 @@ public abstract class AbstractPersistent
 
     final String objectId = getObjectId();
     final String typeId = (type == null ? null : type.getId());
-    final RelationshipService relationshipService = getProvider().getRelationshipService();
+    final RelationshipService relationshipService = getBinding().getRelationshipService();
     final OperationContext ctxt = (context != null ? context : new OperationContextImpl(
         getSession().getDefaultContext()));
 
@@ -838,7 +838,7 @@ public abstract class AbstractPersistent
       String objectId = getObjectId();
 
       // get the latest data from the repository
-      ObjectData objectData = getSession().getProvider().getObjectService().getObject(
+      ObjectData objectData = getSession().getBinding().getObjectService().getObject(
           getRepositoryId(), objectId, creationContext.getFilterString(),
           creationContext.isIncludeAllowableActions(), creationContext.getIncludeRelationships(),
           creationContext.getRenditionFilterString(), creationContext.isIncludePolicies(),

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentFilableCmisObject.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentFilableCmisObject.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentFilableCmisObject.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/AbstractPersistentFilableCmisObject.java Thu Apr 15 09:03:50 2010
@@ -49,7 +49,7 @@ public abstract class AbstractPersistent
     String objectId = getObjectId();
 
     // get object ids of the parent folders
-    List<ObjectParentData> providerParents = getProvider().getNavigationService().getObjectParents(
+    List<ObjectParentData> providerParents = getBinding().getNavigationService().getObjectParents(
         getRepositoryId(), objectId, PropertyIds.CMIS_OBJECT_ID, false, IncludeRelationships.NONE,
         null, false, null);
 
@@ -92,7 +92,7 @@ public abstract class AbstractPersistent
     String objectId = getObjectId();
 
     // get object paths of the parent folders
-    List<ObjectParentData> providerParents = getProvider().getNavigationService().getObjectParents(
+    List<ObjectParentData> providerParents = getBinding().getNavigationService().getObjectParents(
         getRepositoryId(), objectId, PropertyIds.CMIS_PATH, false, IncludeRelationships.NONE, null,
         true, null);
 
@@ -143,7 +143,7 @@ public abstract class AbstractPersistent
       throw new IllegalArgumentException("Target folder id must be set!");
     }
 
-    getProvider().getObjectService().moveObject(getRepositoryId(), objectIdHolder,
+    getBinding().getObjectService().moveObject(getRepositoryId(), objectIdHolder,
         targetFolderId.getId(), sourceFolderId.getId(), null);
 
     if (objectIdHolder.getValue() == null) {
@@ -173,7 +173,7 @@ public abstract class AbstractPersistent
       throw new IllegalArgumentException("Folder Id must be set!");
     }
 
-    getProvider().getMultiFilingService().addObjectToFolder(getRepositoryId(), objectId,
+    getBinding().getMultiFilingService().addObjectToFolder(getRepositoryId(), objectId,
         folderId.getId(), allVersions, null);
   }
 
@@ -191,7 +191,7 @@ public abstract class AbstractPersistent
       throw new IllegalArgumentException("Folder Id must be set!");
     }
 
-    getProvider().getMultiFilingService().removeObjectFromFolder(getRepositoryId(), objectId,
+    getBinding().getMultiFilingService().removeObjectFromFolder(getRepositoryId(), objectId,
         folderId.getId(), null);
   }
 }

Added: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/CmisBindingHelper.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/CmisBindingHelper.java?rev=934333&view=auto
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/CmisBindingHelper.java (added)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/CmisBindingHelper.java Thu Apr 15 09:03:50 2010
@@ -0,0 +1,88 @@
+/*
+ * 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.client.runtime;
+
+import java.util.Map;
+
+import org.apache.chemistry.opencmis.client.bindings.factory.CmisBindingFactory;
+import org.apache.chemistry.opencmis.commons.SessionParameter;
+import org.apache.chemistry.opencmis.commons.enums.BindingType;
+import org.apache.chemistry.opencmis.commons.exceptions.CmisRuntimeException;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
+
+/**
+ * Helper methods for binding handling.
+ */
+public class CmisBindingHelper {
+  /**
+   * Creates a {@link CmisProvider} object.
+   */
+  public static CmisBinding createProvider(Map<String, String> parameters) {
+    if (parameters == null || parameters.isEmpty()) {
+      throw new CmisRuntimeException("Session parameter not set!");
+    }
+
+    if (!parameters.containsKey(SessionParameter.BINDING_TYPE)) {
+      parameters.put(SessionParameter.BINDING_TYPE, BindingType.CUSTOM.value());
+    }
+
+    BindingType bt = BindingType.fromValue(parameters.get(SessionParameter.BINDING_TYPE));
+
+    switch (bt) {
+    case ATOMPUB:
+      return createAtomPubBinding(parameters);
+    case WEBSERVICES:
+      return createWebServiceBinding(parameters);
+    case CUSTOM:
+      return createCustomBinding(parameters);
+    default:
+      throw new CmisRuntimeException("Ambiguous session parameter: " + parameters);
+    }
+  }
+
+  /**
+   * Creates a provider with custom parameters.
+   */
+  private static CmisBinding createCustomBinding(Map<String, String> parameters) {
+    CmisBindingFactory factory = CmisBindingFactory.newInstance();
+    CmisBinding binding = factory.createCmisBinding(parameters);
+
+    return binding;
+  }
+
+  /**
+   * Creates a Web Services provider.
+   */
+  private static CmisBinding createWebServiceBinding(Map<String, String> parameters) {
+    CmisBindingFactory factory = CmisBindingFactory.newInstance();
+    CmisBinding binding = factory.createCmisWebServicesBinding(parameters);
+
+    return binding;
+  }
+
+  /**
+   * Creates an AtomPub provider.
+   */
+  private static CmisBinding createAtomPubBinding(Map<String, String> parameters) {
+    CmisBindingFactory factory = CmisBindingFactory.newInstance();
+    CmisBinding binding = factory.createCmisAtomPubBinding(parameters);
+
+    return binding;
+  }
+}

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentDocumentImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentDocumentImpl.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentDocumentImpl.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentDocumentImpl.java Thu Apr 15 09:03:50 2010
@@ -139,7 +139,7 @@ public class PersistentDocumentImpl exte
     String objectId = getObjectId();
     Holder<String> objectIdHolder = new Holder<String>(objectId);
 
-    getProvider().getVersioningService().checkOut(getRepositoryId(), objectIdHolder, null, null);
+    getBinding().getVersioningService().checkOut(getRepositoryId(), objectIdHolder, null, null);
 
     if (objectIdHolder.getValue() == null) {
       return null;
@@ -156,7 +156,7 @@ public class PersistentDocumentImpl exte
   public void cancelCheckOut() {
     String objectId = getObjectId();
 
-    getProvider().getVersioningService().cancelCheckOut(getRepositoryId(), objectId, null);
+    getBinding().getVersioningService().cancelCheckOut(getRepositoryId(), objectId, null);
   }
 
   /*
@@ -187,7 +187,7 @@ public class PersistentDocumentImpl exte
     updatebility.add(Updatability.READWRITE);
     updatebility.add(Updatability.WHENCHECKEDOUT);
 
-    getProvider().getVersioningService().checkIn(getRepositoryId(), objectIdHolder, major,
+    getBinding().getVersioningService().checkIn(getRepositoryId(), objectIdHolder, major,
         of.convertProperties(properties, type, updatebility),
         of.convertContentStream(contentStream), checkinComment, of.convertPolicies(policies),
         of.convertAces(addAces), of.convertAces(removeAces), null);
@@ -228,7 +228,7 @@ public class PersistentDocumentImpl exte
       readUnlock();
     }
 
-    List<ObjectData> versions = getProvider().getVersioningService().getAllVersions(
+    List<ObjectData> versions = getBinding().getVersioningService().getAllVersions(
         getRepositoryId(), objectId, versionSeriesId, context.getFilterString(),
         context.isIncludeAllowableActions(), null);
 
@@ -272,7 +272,7 @@ public class PersistentDocumentImpl exte
       throw new CmisRuntimeException("Version series id is unknown!");
     }
 
-    ObjectData objectData = getProvider().getVersioningService().getObjectOfLatestVersion(
+    ObjectData objectData = getBinding().getVersioningService().getObjectOfLatestVersion(
         getRepositoryId(), versionSeriesId, major, context.getFilterString(),
         context.isIncludeAllowableActions(), context.getIncludeRelationships(),
         context.getRenditionFilterString(), context.isIncludePolicies(), context.isIncludeAcls(),
@@ -299,7 +299,7 @@ public class PersistentDocumentImpl exte
     String objectId = getObjectId();
 
     // get the stream
-    ContentStreamData contentStream = getProvider().getObjectService().getContentStream(
+    ContentStreamData contentStream = getBinding().getObjectService().getContentStream(
         getRepositoryId(), objectId, null, null, null, null);
 
     // TODO: what should happen if the length is not set?
@@ -332,7 +332,7 @@ public class PersistentDocumentImpl exte
     Holder<String> objectIdHolder = new Holder<String>(objectId);
     Holder<String> changeTokenHolder = new Holder<String>(changeToken);
 
-    getProvider().getObjectService().setContentStream(getRepositoryId(), objectIdHolder, overwrite,
+    getBinding().getObjectService().setContentStream(getRepositoryId(), objectIdHolder, overwrite,
         changeTokenHolder, getObjectFactory().convertContentStream(contentStream), null);
 
     if (objectIdHolder.getValue() == null) {
@@ -363,7 +363,7 @@ public class PersistentDocumentImpl exte
     Holder<String> objectIdHolder = new Holder<String>(objectId);
     Holder<String> changeTokenHolder = new Holder<String>(changeToken);
 
-    getProvider().getObjectService().deleteContentStream(getRepositoryId(), objectIdHolder,
+    getBinding().getObjectService().deleteContentStream(getRepositoryId(), objectIdHolder,
         changeTokenHolder, null);
 
     if (objectIdHolder.getValue() == null) {

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentFolderImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentFolderImpl.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentFolderImpl.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentFolderImpl.java Thu Apr 15 09:03:50 2010
@@ -89,7 +89,7 @@ public class PersistentFolderImpl extend
 
     ObjectFactory of = getObjectFactory();
 
-    String newId = getProvider().getObjectService().createDocument(getRepositoryId(),
+    String newId = getBinding().getObjectService().createDocument(getRepositoryId(),
         of.convertProperties(properties, null, CREATE_UPDATABILITY), objectId,
         of.convertContentStream(contentStream), versioningState, of.convertPolicies(policies),
         of.convertAces(addAces), of.convertAces(removeAces), null);
@@ -144,7 +144,7 @@ public class PersistentFolderImpl extend
     Set<Updatability> updatebility = new HashSet<Updatability>();
     updatebility.add(Updatability.READWRITE);
 
-    String newId = getProvider().getObjectService().createDocumentFromSource(getRepositoryId(),
+    String newId = getBinding().getObjectService().createDocumentFromSource(getRepositoryId(),
         source.getId(), of.convertProperties(properties, type, updatebility), objectId,
         versioningState, of.convertPolicies(policies), of.convertAces(addAces),
         of.convertAces(removeAces), null);
@@ -175,7 +175,7 @@ public class PersistentFolderImpl extend
 
     ObjectFactory of = getObjectFactory();
 
-    String newId = getProvider().getObjectService().createFolder(getRepositoryId(),
+    String newId = getBinding().getObjectService().createFolder(getRepositoryId(),
         of.convertProperties(properties, null, CREATE_UPDATABILITY), objectId,
         of.convertPolicies(policies), of.convertAces(addAces), of.convertAces(removeAces), null);
 
@@ -205,7 +205,7 @@ public class PersistentFolderImpl extend
 
     ObjectFactory of = getObjectFactory();
 
-    String newId = getProvider().getObjectService().createPolicy(getRepositoryId(),
+    String newId = getBinding().getObjectService().createPolicy(getRepositoryId(),
         of.convertProperties(properties, null, CREATE_UPDATABILITY), objectId,
         of.convertPolicies(policies), of.convertAces(addAces), of.convertAces(removeAces), null);
 
@@ -234,7 +234,7 @@ public class PersistentFolderImpl extend
     String repositoryId = getRepositoryId();
     String objectId = getObjectId();
 
-    FailedToDeleteData failed = getProvider().getObjectService().deleteTree(repositoryId, objectId,
+    FailedToDeleteData failed = getBinding().getObjectService().deleteTree(repositoryId, objectId,
         allVersions, unfile, continueOnFailure, null);
 
     return failed.getIds();
@@ -287,7 +287,7 @@ public class PersistentFolderImpl extend
     }
 
     final String objectId = getObjectId();
-    final NavigationService nagivationService = getProvider().getNavigationService();
+    final NavigationService nagivationService = getBinding().getNavigationService();
     final ObjectFactory objectFactory = getSession().getObjectFactory();
     final OperationContext ctxt = new OperationContextImpl(context);
 
@@ -349,7 +349,7 @@ public class PersistentFolderImpl extend
     }
 
     final String objectId = getObjectId();
-    final NavigationService navigationService = getProvider().getNavigationService();
+    final NavigationService navigationService = getBinding().getNavigationService();
     final ObjectFactory objectFactory = getSession().getObjectFactory();
     final OperationContext ctxt = new OperationContextImpl(context);
 
@@ -406,7 +406,7 @@ public class PersistentFolderImpl extend
     String objectId = getObjectId();
 
     // get the descendants
-    List<ObjectInFolderContainer> providerContainerList = getProvider().getNavigationService()
+    List<ObjectInFolderContainer> providerContainerList = getBinding().getNavigationService()
         .getDescendants(getRepositoryId(), objectId, BigInteger.valueOf(depth),
             context.getFilterString(), context.isIncludeAllowableActions(),
             context.getIncludeRelationships(), context.getRenditionFilterString(),
@@ -434,7 +434,7 @@ public class PersistentFolderImpl extend
     String objectId = getObjectId();
 
     // get the folder tree
-    List<ObjectInFolderContainer> providerContainerList = getProvider().getNavigationService()
+    List<ObjectInFolderContainer> providerContainerList = getBinding().getNavigationService()
         .getFolderTree(getRepositoryId(), objectId, BigInteger.valueOf(depth),
             context.getFilterString(), context.isIncludeAllowableActions(),
             context.getIncludeRelationships(), context.getRenditionFilterString(),
@@ -525,7 +525,7 @@ public class PersistentFolderImpl extend
       // if the path property isn't set, get it
       if (path == null) {
         String objectId = getObjectId();
-        ObjectData objectData = getProvider().getObjectService().getObject(getRepositoryId(),
+        ObjectData objectData = getBinding().getObjectService().getObject(getRepositoryId(),
             objectId, PropertyIds.CMIS_PATH, false, IncludeRelationships.NONE, "cmis:none", false,
             false, null);
 

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentSessionImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentSessionImpl.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentSessionImpl.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/PersistentSessionImpl.java Thu Apr 15 09:03:50 2010
@@ -60,7 +60,7 @@ import org.apache.chemistry.opencmis.com
 import org.apache.chemistry.opencmis.commons.enums.Updatability;
 import org.apache.chemistry.opencmis.commons.enums.VersioningState;
 import org.apache.chemistry.opencmis.commons.exceptions.CmisRuntimeException;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.DiscoveryService;
 import org.apache.chemistry.opencmis.commons.provider.NavigationService;
 import org.apache.chemistry.opencmis.commons.provider.ObjectData;
@@ -101,7 +101,7 @@ public class PersistentSessionImpl imple
   /*
    * CMIS provider (serializable)
    */
-  private CmisProvider provider = null;
+  private CmisBinding binding = null;
 
   /*
    * Session Locale, determined from session parameter (serializable)
@@ -212,7 +212,7 @@ public class PersistentSessionImpl imple
       /*
        * clear provider cache
        */
-      getProvider().clearAllCaches();
+      getBinding().clearAllCaches();
     }
     finally {
       fLock.writeLock().unlock();
@@ -248,7 +248,7 @@ public class PersistentSessionImpl imple
       throw new IllegalArgumentException("itemsPerPage must be > 0!");
     }
 
-    final NavigationService nagivationService = getProvider().getNavigationService();
+    final NavigationService nagivationService = getBinding().getNavigationService();
     final ObjectFactory objectFactory = getObjectFactory();
     final OperationContext ctxt = new OperationContextImpl(context);
 
@@ -390,7 +390,7 @@ public class PersistentSessionImpl imple
     }
 
     // get the object
-    ObjectData objectData = this.provider.getObjectService().getObject(getRepositoryId(),
+    ObjectData objectData = this.binding.getObjectService().getObject(getRepositoryId(),
         objectId.getId(), context.getFilterString(), context.isIncludeAllowableActions(),
         context.getIncludeRelationships(), context.getRenditionFilterString(),
         context.isIncludePolicies(), context.isIncludeAcls(), null);
@@ -439,7 +439,7 @@ public class PersistentSessionImpl imple
     }
 
     // get the object
-    ObjectData objectData = this.provider.getObjectService().getObjectByPath(getRepositoryId(),
+    ObjectData objectData = this.binding.getObjectService().getObjectByPath(getRepositoryId(),
         path, context.getFilterString(), context.isIncludeAllowableActions(),
         context.getIncludeRelationships(), context.getRenditionFilterString(),
         context.isIncludePolicies(), context.isIncludeAcls(), null);
@@ -507,7 +507,7 @@ public class PersistentSessionImpl imple
     }
 
     final String repositoryId = getRepositoryId();
-    final RepositoryService repositoryService = getProvider().getRepositoryService();
+    final RepositoryService repositoryService = getBinding().getRepositoryService();
 
     // set up PagingList object
     return new AbstractPagingList<ObjectType>() {
@@ -543,7 +543,7 @@ public class PersistentSessionImpl imple
    * @see org.apache.opencmis.client.api.Session#getTypeDefinition(java.lang.String)
    */
   public ObjectType getTypeDefinition(String typeId) {
-    TypeDefinition typeDefinition = getProvider().getRepositoryService().getTypeDefinition(
+    TypeDefinition typeDefinition = getBinding().getRepositoryService().getTypeDefinition(
         getRepositoryId(), typeId, null);
     return objectFactory.convertTypeDefinition(typeDefinition);
   }
@@ -555,7 +555,7 @@ public class PersistentSessionImpl imple
    */
   public List<Container<ObjectType>> getTypeDescendants(String typeId, int depth,
       boolean includePropertyDefinitions) {
-    List<TypeDefinitionContainer> descendants = getProvider().getRepositoryService()
+    List<TypeDefinitionContainer> descendants = getBinding().getRepositoryService()
         .getTypeDescendants(getRepositoryId(), typeId, BigInteger.valueOf(depth),
             includePropertyDefinitions, null);
 
@@ -598,7 +598,7 @@ public class PersistentSessionImpl imple
   public PagingList<QueryResult> query(final String statement, final boolean searchAllVersions,
       OperationContext context, final int itemsPerPage) {
 
-    final DiscoveryService discoveryService = getProvider().getDiscoveryService();
+    final DiscoveryService discoveryService = getBinding().getDiscoveryService();
     final ObjectFactory of = getObjectFactory();
     final OperationContext ctxt = new OperationContextImpl(context);
 
@@ -654,7 +654,7 @@ public class PersistentSessionImpl imple
   public void connect() {
     fLock.writeLock().lock();
     try {
-      this.provider = CmisProviderHelper.createProvider(this.parameters);
+      this.binding = CmisBindingHelper.createProvider(this.parameters);
 
       /* get initial repository id from session parameter */
       String repositoryId = this.determineRepositoryId(this.parameters);
@@ -662,7 +662,7 @@ public class PersistentSessionImpl imple
         throw new IllegalStateException("Repository Id is not set!");
       }
 
-      RepositoryInfoData data = getProvider().getRepositoryService().getRepositoryInfo(
+      RepositoryInfoData data = getBinding().getRepositoryService().getRepositoryInfo(
           repositoryId, null);
 
       this.repositoryInfo = new RepositoryInfoImpl(data);
@@ -675,12 +675,12 @@ public class PersistentSessionImpl imple
   /*
    * (non-Javadoc)
    * 
-   * @see org.apache.opencmis.client.api.Session#getProvider()
+   * @see org.apache.opencmis.client.api.Session#getBinding()
    */
-  public CmisProvider getProvider() {
+  public CmisBinding getBinding() {
     fLock.readLock().lock();
     try {
-      return this.provider;
+      return this.binding;
     }
     finally {
       fLock.readLock().unlock();
@@ -721,7 +721,7 @@ public class PersistentSessionImpl imple
       throw new IllegalArgumentException("Folder Id must be set!");
     }
 
-    String newId = getProvider().getObjectService().createDocument(getRepositoryId(),
+    String newId = getBinding().getObjectService().createDocument(getRepositoryId(),
         objectFactory.convertProperties(properties, null, CREATE_UPDATABILITY),
         (folderId == null ? null : folderId.getId()),
         objectFactory.convertContentStream(contentStream), versioningState,
@@ -765,7 +765,7 @@ public class PersistentSessionImpl imple
       throw new IllegalArgumentException("Source object must be a document!");
     }
 
-    String newId = getProvider().getObjectService().createDocumentFromSource(getRepositoryId(),
+    String newId = getBinding().getObjectService().createDocumentFromSource(getRepositoryId(),
         source.getId(), objectFactory.convertProperties(properties, type, CREATE_UPDATABILITY),
         (folderId == null ? null : folderId.getId()), versioningState,
         objectFactory.convertPolicies(policies), objectFactory.convertAces(addAces),
@@ -790,7 +790,7 @@ public class PersistentSessionImpl imple
       throw new IllegalArgumentException("Folder Id must be set!");
     }
 
-    String newId = getProvider().getObjectService().createFolder(getRepositoryId(),
+    String newId = getBinding().getObjectService().createFolder(getRepositoryId(),
         objectFactory.convertProperties(properties, null, CREATE_UPDATABILITY),
         (folderId == null ? null : folderId.getId()), objectFactory.convertPolicies(policies),
         objectFactory.convertAces(addAces), objectFactory.convertAces(removeAces), null);
@@ -814,7 +814,7 @@ public class PersistentSessionImpl imple
       throw new IllegalArgumentException("Folder Id must be set!");
     }
 
-    String newId = getProvider().getObjectService().createPolicy(getRepositoryId(),
+    String newId = getBinding().getObjectService().createPolicy(getRepositoryId(),
         objectFactory.convertProperties(properties, null, CREATE_UPDATABILITY),
         (folderId == null ? null : folderId.getId()), objectFactory.convertPolicies(policies),
         objectFactory.convertAces(addAces), objectFactory.convertAces(removeAces), null);
@@ -834,7 +834,7 @@ public class PersistentSessionImpl imple
    */
   public ObjectId createRelationship(Map<String, ?> properties, List<Policy> policies,
       List<Ace> addAces, List<Ace> removeAces) {
-    String newId = getProvider().getObjectService().createRelationship(getRepositoryId(),
+    String newId = getBinding().getObjectService().createRelationship(getRepositoryId(),
         objectFactory.convertProperties(properties, null, CREATE_UPDATABILITY),
         objectFactory.convertPolicies(policies), objectFactory.convertAces(addAces),
         objectFactory.convertAces(removeAces), null);

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/RenditionImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/RenditionImpl.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/RenditionImpl.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/RenditionImpl.java Thu Apr 15 09:03:50 2010
@@ -157,7 +157,7 @@ public class RenditionImpl implements Re
       return null;
     }
 
-    ContentStreamData contentStream = session.getProvider().getObjectService().getContentStream(
+    ContentStreamData contentStream = session.getBinding().getObjectService().getContentStream(
         session.getRepositoryInfo().getId(), objectId, streamId, null, null, null);
     if (contentStream == null) {
       return null;

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/SessionFactoryImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/SessionFactoryImpl.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/SessionFactoryImpl.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/SessionFactoryImpl.java Thu Apr 15 09:03:50 2010
@@ -30,7 +30,7 @@ import org.apache.chemistry.opencmis.com
 import org.apache.chemistry.opencmis.commons.enums.SessionType;
 import org.apache.chemistry.opencmis.commons.exceptions.CmisNotSupportedException;
 import org.apache.chemistry.opencmis.commons.exceptions.CmisRuntimeException;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.RepositoryInfoData;
 
 /**
@@ -100,9 +100,9 @@ public class SessionFactoryImpl implemen
    * @see org.apache.opencmis.client.api.SessionFactory#getRepositories(java.util.Map)
    */
   public List<Repository> getRepositories(Map<String, String> parameters) {
-    CmisProvider provider = CmisProviderHelper.createProvider(parameters);
+    CmisBinding binding = CmisBindingHelper.createProvider(parameters);
 
-    List<RepositoryInfoData> repositoryInfos = provider.getRepositoryService().getRepositoryInfos(
+    List<RepositoryInfoData> repositoryInfos = binding.getRepositoryService().getRepositoryInfos(
         null);
 
     List<Repository> result = new ArrayList<Repository>();

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/repository/PersistentObjectFactoryImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/repository/PersistentObjectFactoryImpl.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/repository/PersistentObjectFactoryImpl.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-client/chemistry-opencmis-client-impl/src/main/java/org/apache/chemistry/opencmis/client/runtime/repository/PersistentObjectFactoryImpl.java Thu Apr 15 09:03:50 2010
@@ -81,12 +81,12 @@ import org.apache.chemistry.opencmis.com
 import org.apache.chemistry.opencmis.commons.provider.AccessControlEntry;
 import org.apache.chemistry.opencmis.commons.provider.AccessControlList;
 import org.apache.chemistry.opencmis.commons.provider.AllowableActionsData;
+import org.apache.chemistry.opencmis.commons.provider.BindingsObjectFactory;
 import org.apache.chemistry.opencmis.commons.provider.ContentStreamData;
 import org.apache.chemistry.opencmis.commons.provider.ObjectData;
 import org.apache.chemistry.opencmis.commons.provider.PropertiesData;
 import org.apache.chemistry.opencmis.commons.provider.PropertyData;
 import org.apache.chemistry.opencmis.commons.provider.PropertyIdData;
-import org.apache.chemistry.opencmis.commons.provider.ProviderObjectFactory;
 import org.apache.chemistry.opencmis.commons.provider.RenditionData;
 
 /**
@@ -117,10 +117,10 @@ public class PersistentObjectFactoryImpl
   }
 
   /**
-   * Returns the provider object factory.
+   * Returns the bindings object factory.
    */
-  protected ProviderObjectFactory getProviderObjectFactory() {
-    return session.getProvider().getObjectFactory();
+  protected BindingsObjectFactory getProviderObjectFactory() {
+    return session.getBinding().getObjectFactory();
   }
 
   // allowable actions
@@ -182,7 +182,7 @@ public class PersistentObjectFactoryImpl
       return null;
     }
 
-    ProviderObjectFactory pof = getProviderObjectFactory();
+    BindingsObjectFactory pof = getProviderObjectFactory();
 
     List<AccessControlEntry> providerAces = new ArrayList<AccessControlEntry>();
     for (Ace ace : aces) {
@@ -468,7 +468,7 @@ public class PersistentObjectFactoryImpl
     }
 
     // some preparation
-    ProviderObjectFactory pof = getProviderObjectFactory();
+    BindingsObjectFactory pof = getProviderObjectFactory();
     List<PropertyData<?>> propertyList = new ArrayList<PropertyData<?>>();
 
     // the big loop

Added: incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/BindingsObjectFactory.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/BindingsObjectFactory.java?rev=934333&view=auto
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/BindingsObjectFactory.java (added)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/BindingsObjectFactory.java Thu Apr 15 09:03:50 2010
@@ -0,0 +1,75 @@
+/*
+ * 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.commons.provider;
+
+import java.io.InputStream;
+import java.math.BigDecimal;
+import java.math.BigInteger;
+import java.util.GregorianCalendar;
+import java.util.List;
+
+/**
+ * Factory for CMIS binding objects.
+ * 
+ * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
+ * 
+ */
+public interface BindingsObjectFactory {
+
+  AccessControlEntry createAccessControlEntry(String principal, List<String> permissions);
+
+  AccessControlList createAccessControlList(List<AccessControlEntry> aces);
+
+  PropertyBooleanData createPropertyBooleanData(String id, List<Boolean> values);
+
+  PropertyBooleanData createPropertyBooleanData(String id, Boolean value);
+
+  PropertyIdData createPropertyIdData(String id, List<String> values);
+
+  PropertyIdData createPropertyIdData(String id, String value);
+
+  PropertyIntegerData createPropertyIntegerData(String id, List<BigInteger> values);
+
+  PropertyIntegerData createPropertyIntegerData(String id, BigInteger value);
+
+  PropertyDateTimeData createPropertyDateTimeData(String id, List<GregorianCalendar> values);
+
+  PropertyDateTimeData createPropertyDateTimeData(String id, GregorianCalendar value);
+
+  PropertyDecimalData createPropertyDecimalData(String id, List<BigDecimal> values);
+
+  PropertyDecimalData createPropertyDecimalData(String id, BigDecimal value);
+
+  PropertyHtmlData createPropertyHtmlData(String id, List<String> values);
+
+  PropertyHtmlData createPropertyHtmlData(String id, String value);
+
+  PropertyStringData createPropertyStringData(String id, List<String> values);
+
+  PropertyStringData createPropertyStringData(String id, String value);
+
+  PropertyUriData createPropertyUriData(String id, List<String> values);
+
+  PropertyUriData createPropertyUriData(String id, String value);
+
+  PropertiesData createPropertiesData(List<PropertyData<?>> properties);
+
+  ContentStreamData createContentStream(BigInteger length, String mimetype, String filename,
+      InputStream stream);
+}

Added: incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/CmisBinding.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/CmisBinding.java?rev=934333&view=auto
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/CmisBinding.java (added)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-api/src/main/java/org/apache/chemistry/opencmis/commons/provider/CmisBinding.java Thu Apr 15 09:03:50 2010
@@ -0,0 +1,101 @@
+/*
+ * 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.commons.provider;
+
+import java.io.Serializable;
+
+/**
+ * Entry point for all CMIS binding related operations. It provides access to the service interface
+ * objects which are very similar to the CMIS 1.0 domain model.
+ * 
+ * <p>
+ * Each instance of this class represents a session. A session comprises of a connection to one CMIS
+ * endpoint over one binding for one particular user and a set of caches. All repositories that are
+ * exposed by this CMIS endpoint are accessible in this session. All CMIS operations and extension
+ * points are provided if they are supported by the underlying binding.
+ * </p>
+ * 
+ * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
+ * 
+ */
+public interface CmisBinding extends Serializable {
+
+  /**
+   * Gets a Repository Service interface object.
+   */
+  RepositoryService getRepositoryService();
+
+  /**
+   * Gets a Navigation Service interface object.
+   */
+  NavigationService getNavigationService();
+
+  /**
+   * Gets an Object Service interface object.
+   */
+  ObjectService getObjectService();
+
+  /**
+   * Gets a Versioning Service interface object.
+   */
+  VersioningService getVersioningService();
+
+  /**
+   * Gets a Relationship Service interface object.
+   */
+  RelationshipService getRelationshipService();
+
+  /**
+   * Gets a Discovery Service interface object.
+   */
+  DiscoveryService getDiscoveryService();
+
+  /**
+   * Gets a Multifiling Service interface object.
+   */
+  MultiFilingService getMultiFilingService();
+
+  /**
+   * Gets an ACL Service interface object.
+   */
+  AclService getAclService();
+
+  /**
+   * Gets a Policy Service interface object.
+   */
+  PolicyService getPolicyService();
+
+  /**
+   * Gets a factory for CMIS provider specific objects.
+   */
+  BindingsObjectFactory getObjectFactory();
+
+  /**
+   * Clears all caches of the current CMIS binding session.
+   */
+  void clearAllCaches();
+
+  /**
+   * Clears all caches of the current CMIS binding session that are related to the given repository.
+   * 
+   * @param repositoryId
+   *          the repository id
+   */
+  void clearRepositoryCache(String repositoryId);
+}

Added: incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-impl/src/main/java/org/apache/chemistry/opencmis/commons/impl/dataobjects/BindingsObjectFactoryImpl.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-impl/src/main/java/org/apache/chemistry/opencmis/commons/impl/dataobjects/BindingsObjectFactoryImpl.java?rev=934333&view=auto
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-impl/src/main/java/org/apache/chemistry/opencmis/commons/impl/dataobjects/BindingsObjectFactoryImpl.java (added)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-commons/chemistry-opencmis-commons-impl/src/main/java/org/apache/chemistry/opencmis/commons/impl/dataobjects/BindingsObjectFactoryImpl.java Thu Apr 15 09:03:50 2010
@@ -0,0 +1,136 @@
+/*
+ * 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.commons.impl.dataobjects;
+
+import java.io.InputStream;
+import java.io.Serializable;
+import java.math.BigDecimal;
+import java.math.BigInteger;
+import java.util.GregorianCalendar;
+import java.util.List;
+
+import org.apache.chemistry.opencmis.commons.provider.AccessControlEntry;
+import org.apache.chemistry.opencmis.commons.provider.AccessControlList;
+import org.apache.chemistry.opencmis.commons.provider.BindingsObjectFactory;
+import org.apache.chemistry.opencmis.commons.provider.ContentStreamData;
+import org.apache.chemistry.opencmis.commons.provider.PropertiesData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyBooleanData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyDateTimeData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyDecimalData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyHtmlData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyIdData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyIntegerData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyStringData;
+import org.apache.chemistry.opencmis.commons.provider.PropertyUriData;
+
+/**
+ * CMIS binding object factory implementation.
+ * 
+ * @author <a href="mailto:fmueller@opentext.com">Florian M&uuml;ller</a>
+ * 
+ */
+public class BindingsObjectFactoryImpl implements BindingsObjectFactory, Serializable {
+
+  private static final long serialVersionUID = 1L;
+
+  public BindingsObjectFactoryImpl() {
+  }
+
+  public AccessControlEntry createAccessControlEntry(String principal, List<String> permissions) {
+    return new AccessControlEntryImpl(new AccessControlPrincipalDataImpl(principal), permissions);
+  }
+
+  public AccessControlList createAccessControlList(List<AccessControlEntry> aces) {
+    return new AccessControlListImpl(aces);
+  }
+
+  public ContentStreamData createContentStream(BigInteger length, String mimetype, String filename,
+      InputStream stream) {
+    return new ContentStreamDataImpl(length, mimetype, filename, stream);
+  }
+
+  public PropertiesData createPropertiesData(List<PropertyData<?>> properties) {
+    return new PropertiesDataImpl(properties);
+  }
+
+  public PropertyBooleanData createPropertyBooleanData(String id, List<Boolean> values) {
+    return new PropertyBooleanDataImpl(id, values);
+  }
+
+  public PropertyBooleanData createPropertyBooleanData(String id, Boolean value) {
+    return new PropertyBooleanDataImpl(id, value);
+  }
+
+  public PropertyDateTimeData createPropertyDateTimeData(String id, List<GregorianCalendar> values) {
+    return new PropertyDateTimeDataImpl(id, values);
+  }
+
+  public PropertyDateTimeData createPropertyDateTimeData(String id, GregorianCalendar value) {
+    return new PropertyDateTimeDataImpl(id, value);
+  }
+
+  public PropertyDecimalData createPropertyDecimalData(String id, List<BigDecimal> values) {
+    return new PropertyDecimalDataImpl(id, values);
+  }
+
+  public PropertyDecimalData createPropertyDecimalData(String id, BigDecimal value) {
+    return new PropertyDecimalDataImpl(id, value);
+  }
+
+  public PropertyHtmlData createPropertyHtmlData(String id, List<String> values) {
+    return new PropertyHtmlDataImpl(id, values);
+  }
+
+  public PropertyHtmlData createPropertyHtmlData(String id, String value) {
+    return new PropertyHtmlDataImpl(id, value);
+  }
+
+  public PropertyIdData createPropertyIdData(String id, List<String> values) {
+    return new PropertyIdDataImpl(id, values);
+  }
+
+  public PropertyIdData createPropertyIdData(String id, String value) {
+    return new PropertyIdDataImpl(id, value);
+  }
+
+  public PropertyIntegerData createPropertyIntegerData(String id, List<BigInteger> values) {
+    return new PropertyIntegerDataImpl(id, values);
+  }
+
+  public PropertyIntegerData createPropertyIntegerData(String id, BigInteger value) {
+    return new PropertyIntegerDataImpl(id, value);
+  }
+
+  public PropertyStringData createPropertyStringData(String id, List<String> values) {
+    return new PropertyStringDataImpl(id, values);
+  }
+
+  public PropertyStringData createPropertyStringData(String id, String value) {
+    return new PropertyStringDataImpl(id, value);
+  }
+
+  public PropertyUriData createPropertyUriData(String id, List<String> values) {
+    return new PropertyUriDataImpl(id, values);
+  }
+
+  public PropertyUriData createPropertyUriData(String id, String value) {
+    return new PropertyUriDataImpl(id, value);
+  }
+}

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/SessionFactory.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/SessionFactory.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/SessionFactory.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-fit/src/test/java/org/apache/chemistry/opencmis/fit/SessionFactory.java Thu Apr 15 09:03:50 2010
@@ -22,11 +22,11 @@ import java.util.HashMap;
 import java.util.Map;
 
 import org.apache.chemistry.opencmis.client.api.Session;
-import org.apache.chemistry.opencmis.client.provider.factory.CmisProviderFactory;
+import org.apache.chemistry.opencmis.client.bindings.factory.CmisBindingFactory;
 import org.apache.chemistry.opencmis.client.runtime.SessionFactoryImpl;
 import org.apache.chemistry.opencmis.commons.SessionParameter;
 import org.apache.chemistry.opencmis.commons.enums.BindingType;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 
 /**
  * Session factory for integration tests.
@@ -111,7 +111,7 @@ public class SessionFactory {
   /**
    * Creates a new CmisProvider object that uses the AtomPub binding. For low-level tests only!
    */
-  public static CmisProvider createAtomPubProvider() {
+  public static CmisBinding createAtomPubBinding() {
     String url = "http://" + HOST + ":" + PORT + ATOMPUB_PATH;
 
     Map<String, String> parameters = new HashMap<String, String>();
@@ -121,13 +121,13 @@ public class SessionFactory {
 
     parameters.put(SessionParameter.ATOMPUB_URL, url);
 
-    return CmisProviderFactory.newInstance().createCmisAtomPubProvider(parameters);
+    return CmisBindingFactory.newInstance().createCmisAtomPubBinding(parameters);
   }
 
   /**
    * Creates a new CmisProvider object that uses the Web Services binding. For low-level tests only!
    */
-  public static CmisProvider createWebServicesProvider() {
+  public static CmisBinding createWebServicesBinding() {
     String url = "http://" + HOST + ":" + PORT + WEBSERVICES_PATH;
 
     Map<String, String> parameters = new HashMap<String, String>();
@@ -147,6 +147,6 @@ public class SessionFactory {
     parameters.put(SessionParameter.WEBSERVICES_POLICY_SERVICE, url + "PolicyService?wsdl");
     parameters.put(SessionParameter.WEBSERVICES_ACL_SERVICE, url + "ACLService?wsdl");
 
-    return CmisProviderFactory.newInstance().createCmisWebServicesProvider(parameters);
+    return CmisBindingFactory.newInstance().createCmisWebServicesBinding(parameters);
   }
 }
\ No newline at end of file

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=934333&r1=934332&r2=934333&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 Apr 15 09:03:50 2010
@@ -21,11 +21,11 @@ package org.apache.chemistry.opencmis.fi
 import java.util.ArrayList;
 import java.util.List;
 
-import org.apache.chemistry.opencmis.client.provider.factory.CmisProviderFactory;
+import org.apache.chemistry.opencmis.client.bindings.factory.CmisBindingFactory;
 import org.apache.chemistry.opencmis.commons.PropertyIds;
 import org.apache.chemistry.opencmis.commons.SessionParameter;
 import org.apache.chemistry.opencmis.commons.enums.UnfileObjects;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.PropertiesData;
 import org.apache.chemistry.opencmis.commons.provider.PropertyData;
 import org.apache.chemistry.opencmis.commons.provider.RepositoryInfoData;
@@ -34,13 +34,13 @@ import org.junit.Assert;
 
 public class FixtureSetup {
 
-	private CmisProvider provider = null;
+	private CmisBinding binding = null;
 	private String rootFolderId = null; // root
 	private String testRootFolderId = null; // test root
 	private String repositoryId = null;
 
 	public void teardown() {
-		this.provider.getObjectService().deleteTree(this.repositoryId,
+		this.binding.getObjectService().deleteTree(this.repositoryId,
 				this.testRootFolderId, true, UnfileObjects.DELETE, true, null);
 	}
 
@@ -49,9 +49,9 @@ public class FixtureSetup {
 				SessionParameter.REPOSITORY_ID);
 		Assert.assertNotNull(this.repositoryId);
 
-		this.provider = CmisProviderFactory.newInstance().createCmisProvider(
+		this.binding = CmisBindingFactory.newInstance().createCmisBinding(
 				Fixture.getParamter());
-		Assert.assertNotNull(this.provider);
+		Assert.assertNotNull(this.binding);
 
 		// root folder
 		if (Fixture.getParamter().containsKey(
@@ -61,7 +61,7 @@ public class FixtureSetup {
 					FixtureSessionParameter.TEST_ROOT_FOLDER_ID);
 			Assert.assertNotNull(this.rootFolderId);
 		} else {
-			RepositoryInfoData rid = this.provider.getRepositoryService()
+			RepositoryInfoData rid = this.binding.getRepositoryService()
 					.getRepositoryInfo(this.repositoryId, null);
 			Assert.assertNotNull(rid);
 			this.rootFolderId = rid.getRootFolderId();
@@ -76,21 +76,21 @@ public class FixtureSetup {
 
 		// create test root folder
 		List<PropertyData<?>> propList = new ArrayList<PropertyData<?>>();
-		propList.add(this.provider.getObjectFactory().createPropertyStringData(
+		propList.add(this.binding.getObjectFactory().createPropertyStringData(
 				PropertyIds.CMIS_NAME, Fixture.TEST_ROOT_FOLDER_NAME));
-		propList.add(this.provider.getObjectFactory().createPropertyIdData(
+		propList.add(this.binding.getObjectFactory().createPropertyIdData(
 				PropertyIds.CMIS_OBJECT_TYPE_ID, folderTypeId));
 
-		PropertiesData properties = this.provider.getObjectFactory()
+		PropertiesData properties = this.binding.getObjectFactory()
 				.createPropertiesData(propList);
 
-		this.testRootFolderId = this.provider.getObjectService().createFolder(
+		this.testRootFolderId = this.binding.getObjectService().createFolder(
 				this.repositoryId, properties, this.rootFolderId, null, null,
 				null, null);
 		Assert.assertNotNull(this.testRootFolderId);
 
-		ObjectGenerator og = new ObjectGenerator(provider.getObjectFactory(),
-				provider.getNavigationService(), provider.getObjectService(),
+		ObjectGenerator og = new ObjectGenerator(binding.getObjectFactory(),
+				binding.getNavigationService(), binding.getObjectService(),
 				this.repositoryId);
 
 		og.setContentSizeInKB(10);

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Command.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Command.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Command.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Command.java Thu Apr 15 09:03:50 2010
@@ -20,7 +20,7 @@ package org.apache.chemistry.opencmis.co
 
 import java.io.PrintWriter;
 
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 
 /**
  * Command interface.
@@ -43,5 +43,5 @@ public interface Command {
   /**
    * Executes the command.
    */
-  void execute(CmisProvider provider, String[] args, PrintWriter output);
+  void execute(CmisBinding binding, String[] args, PrintWriter output);
 }

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Commander.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Commander.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Commander.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/Commander.java Thu Apr 15 09:03:50 2010
@@ -26,10 +26,10 @@ import java.util.LinkedHashMap;
 import java.util.Map;
 import java.util.Properties;
 
-import org.apache.chemistry.opencmis.client.provider.factory.CmisProviderFactory;
+import org.apache.chemistry.opencmis.client.bindings.factory.CmisBindingFactory;
 import org.apache.chemistry.opencmis.commons.SessionParameter;
 import org.apache.chemistry.opencmis.commons.exceptions.CmisBaseException;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 
 /**
  * Commander tool main.
@@ -68,14 +68,14 @@ public class Commander {
       }
 
       // get provider object
-      CmisProvider provider = createProvider(args[0]);
+      CmisBinding binding = createBinding(args[0]);
 
       // prepare args
       String[] commandArgs = new String[args.length - 2];
       System.arraycopy(args, 2, commandArgs, 0, commandArgs.length);
 
       // execute
-      command.execute(provider, commandArgs, fPW);
+      command.execute(binding, commandArgs, fPW);
     }
     catch (Exception e) {
       fPW.println("Exception:");
@@ -109,7 +109,7 @@ public class Commander {
   /**
    * Creates the provider object
    */
-  private CmisProvider createProvider(String configFile) throws Exception {
+  private CmisBinding createBinding(String configFile) throws Exception {
     Properties properties = new Properties();
     properties.load(new FileInputStream(configFile));
 
@@ -121,14 +121,14 @@ public class Commander {
       sessionParameters.put(key, value);
     }
 
-    CmisProviderFactory factory = CmisProviderFactory.newInstance();
+    CmisBindingFactory factory = CmisBindingFactory.newInstance();
 
-    CmisProvider result = null;
+    CmisBinding result = null;
     if (sessionParameters.containsKey(SessionParameter.ATOMPUB_URL)) {
-      result = factory.createCmisAtomPubProvider(sessionParameters);
+      result = factory.createCmisAtomPubBinding(sessionParameters);
     }
     else if (sessionParameters.containsKey(SessionParameter.WEBSERVICES_REPOSITORY_SERVICE)) {
-      result = factory.createCmisWebServicesProvider(sessionParameters);
+      result = factory.createCmisWebServicesBinding(sessionParameters);
     }
     else {
       throw new IllegalArgumentException("Cannot find CMIS binding information in config file!");

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/DeleteCommand.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/DeleteCommand.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/DeleteCommand.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/DeleteCommand.java Thu Apr 15 09:03:50 2010
@@ -20,7 +20,7 @@ package org.apache.chemistry.opencmis.co
 
 import java.io.PrintWriter;
 
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 
 public class DeleteCommand implements Command {
 
@@ -42,13 +42,7 @@ public class DeleteCommand implements Co
     return "DELETE <repository id> <object id> [all versions: true/false]";
   }
 
-  /*
-   * (non-Javadoc)
-   * 
-   * @see org.apache.opencmis.commander.Command#execute(org.apache.opencmis.commons.provider.CmisProvider,
-   * java.lang.String[], java.io.PrintWriter)
-   */
-  public void execute(CmisProvider provider, String[] args, PrintWriter output) {
+  public void execute(CmisBinding binding, String[] args, PrintWriter output) {
     if (args.length < 2) {
       output.println(getUsage());
       return;
@@ -61,7 +55,7 @@ public class DeleteCommand implements Co
     output.println("Deleting " + objectId + " ...");
     output.flush();
 
-    provider.getObjectService().deleteObject(repositoryId, objectId, allVersions, null);
+    binding.getObjectService().deleteObject(repositoryId, objectId, allVersions, null);
 
     output.println("done.");
   }

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/InfosCommand.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/InfosCommand.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/InfosCommand.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/InfosCommand.java Thu Apr 15 09:03:50 2010
@@ -21,7 +21,7 @@ package org.apache.chemistry.opencmis.co
 import java.io.PrintWriter;
 import java.util.List;
 
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.RepositoryInfoData;
 
 public class InfosCommand implements Command {
@@ -44,14 +44,8 @@ public class InfosCommand implements Com
     return "INFOS";
   }
 
-  /*
-   * (non-Javadoc)
-   * 
-   * @see org.apache.opencmis.commander.Command#execute(org.apache.opencmis.commons.provider.CmisProvider,
-   * java.lang.String[], java.io.PrintWriter)
-   */
-  public void execute(CmisProvider provider, String[] args, PrintWriter output) {
-    List<RepositoryInfoData> repositoryInfos = provider.getRepositoryService().getRepositoryInfos(
+  public void execute(CmisBinding binding, String[] args, PrintWriter output) {
+    List<RepositoryInfoData> repositoryInfos = binding.getRepositoryService().getRepositoryInfos(
         null);
 
     for (RepositoryInfoData repositoryInfo : repositoryInfos) {

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/ListCommand.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/ListCommand.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/ListCommand.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tools/src/main/java/org/apache/chemistry/opencmis/commander/ListCommand.java Thu Apr 15 09:03:50 2010
@@ -21,7 +21,7 @@ package org.apache.chemistry.opencmis.co
 import java.io.PrintWriter;
 
 import org.apache.chemistry.opencmis.commons.PropertyIds;
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.ObjectInFolderData;
 import org.apache.chemistry.opencmis.commons.provider.ObjectInFolderList;
 import org.apache.chemistry.opencmis.commons.provider.PropertyData;
@@ -46,13 +46,7 @@ public class ListCommand implements Comm
     return "LIST <repository id> <folder id>";
   }
 
-  /*
-   * (non-Javadoc)
-   * 
-   * @see org.apache.opencmis.commander.Command#execute(org.apache.opencmis.commons.provider.CmisProvider,
-   * java.lang.String[], java.io.PrintWriter)
-   */
-  public void execute(CmisProvider provider, String[] args, PrintWriter output) {
+  public void execute(CmisBinding binding, String[] args, PrintWriter output) {
     if (args.length < 2) {
       output.println(getUsage());
       return;
@@ -61,7 +55,7 @@ public class ListCommand implements Comm
     String repositoryId = args[0];
     String folderId = args[1];
 
-    ObjectInFolderList list = provider.getNavigationService().getChildren(repositoryId, folderId,
+    ObjectInFolderList list = binding.getNavigationService().getChildren(repositoryId, folderId,
         null, null, null, null, null, null, null, null, null);
 
     for (ObjectInFolderData object : list.getObjects()) {

Modified: incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/MultiThreadedObjectGenerator.java
URL: http://svn.apache.org/viewvc/incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/MultiThreadedObjectGenerator.java?rev=934333&r1=934332&r2=934333&view=diff
==============================================================================
--- incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/MultiThreadedObjectGenerator.java (original)
+++ incubator/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/MultiThreadedObjectGenerator.java Thu Apr 15 09:03:50 2010
@@ -18,10 +18,10 @@
  */
 package org.apache.chemistry.opencmis.util.repository;
 
-import org.apache.chemistry.opencmis.commons.provider.CmisProvider;
+import org.apache.chemistry.opencmis.commons.provider.BindingsObjectFactory;
+import org.apache.chemistry.opencmis.commons.provider.CmisBinding;
 import org.apache.chemistry.opencmis.commons.provider.NavigationService;
 import org.apache.chemistry.opencmis.commons.provider.ObjectService;
-import org.apache.chemistry.opencmis.commons.provider.ProviderObjectFactory;
 import org.apache.chemistry.opencmis.commons.provider.RepositoryInfoData;
 import org.apache.chemistry.opencmis.commons.provider.RepositoryService;
 
@@ -72,13 +72,13 @@ public class MultiThreadedObjectGenerato
     
   }  // ObjectCreatorRunner
   
-  static private ObjectGenerator createObjectGenerator(CmisProvider provider, String repoId,
+  static private ObjectGenerator createObjectGenerator(CmisBinding binding, String repoId,
       int docsPerFolder, int foldersPerFolders, int depth, String documentType, String folderType,
       int contentSizeInKB, String rootFolderId, boolean doCleanup) {
 
-    ProviderObjectFactory objectFactory = provider.getObjectFactory();
-    NavigationService navSvc = provider.getNavigationService();
-    ObjectService objSvc = provider.getObjectService();
+    BindingsObjectFactory objectFactory = binding.getObjectFactory();
+    NavigationService navSvc = binding.getNavigationService();
+    ObjectService objSvc = binding.getObjectService();
     
     ObjectGenerator gen = new ObjectGenerator(objectFactory, navSvc, objSvc, repoId);
     gen.setUseUuidsForNames(true);
@@ -94,8 +94,8 @@ public class MultiThreadedObjectGenerato
     return gen;
   }
   
-  static private String getRootFolderId(CmisProvider provider, String repositoryId, String rootFolderId) {
-    RepositoryService repSvc = provider.getRepositoryService();
+  static private String getRootFolderId(CmisBinding binding, String repositoryId, String rootFolderId) {
+    RepositoryService repSvc = binding.getRepositoryService();
 
     RepositoryInfoData rep = repSvc.getRepositoryInfo(repositoryId, null);
     if (null == rootFolderId || rootFolderId.length() == 0)
@@ -104,22 +104,22 @@ public class MultiThreadedObjectGenerato
     return rootFolderId;
   }
   
-  public static ObjectGeneratorRunner prepareForCreateTree(CmisProvider provider, String repoId,
+  public static ObjectGeneratorRunner prepareForCreateTree(CmisBinding binding, String repoId,
       int docsPerFolder, int foldersPerFolders, int depth, String documentType, String folderType,
       int contentSizeInKB, String rootFolderId, boolean doCleanup) {
     
-    ObjectGenerator objGen = createObjectGenerator(provider, repoId, docsPerFolder,
+    ObjectGenerator objGen = createObjectGenerator(binding, repoId, docsPerFolder,
         foldersPerFolders, depth, documentType, folderType, contentSizeInKB, rootFolderId,
         doCleanup);    
 
     ObjectGeneratorRunner gen = new ObjectGeneratorRunner(objGen, Action.CreateTree);
     gen.fFoldersPerFolders = foldersPerFolders;
     gen.fDepth = depth;
-    gen.fRootFolderId = getRootFolderId(provider, repoId, rootFolderId);
+    gen.fRootFolderId = getRootFolderId(binding, repoId, rootFolderId);
     return gen;
   }
   
-  public static ObjectGeneratorRunner[] prepareForCreateTreeMT(CmisProvider provider, String repoId,
+  public static ObjectGeneratorRunner[] prepareForCreateTreeMT(CmisBinding provider, String repoId,
       int docsPerFolder, int foldersPerFolders, int depth, String documentType, String folderType,
       int contentSizeInKB, String[] rootFolderIds, boolean doCleanup) {
     
@@ -138,7 +138,7 @@ public class MultiThreadedObjectGenerato
     return runners;
   }
   
-  public static ObjectGeneratorRunner prepareForCreateDocument(CmisProvider provider, String repoId,
+  public static ObjectGeneratorRunner prepareForCreateDocument(CmisBinding provider, String repoId,
       String documentType, int contentSizeInKB, String rootFolderId, int noDocuments, boolean doCleanup) {
     
     ObjectGenerator objGen = createObjectGenerator(provider, repoId, 0, 0, 0, documentType, null,
@@ -151,23 +151,23 @@ public class MultiThreadedObjectGenerato
   }
 
   public static ObjectGeneratorRunner[] prepareForCreateDocumentMT(int threadCount,
-      CmisProvider provider, String repoId, String documentType, int contentSizeInKB,
+      CmisBinding binding, String repoId, String documentType, int contentSizeInKB,
       String rootFolderId, int noDocuments, boolean doCleanup) {
     
     ObjectGeneratorRunner[] runners = new ObjectGeneratorRunner[threadCount];
     for (int i=0; i<threadCount; i++) {
-      ObjectGenerator objGen = createObjectGenerator(provider, repoId, 0, 0, 0, documentType, null,
+      ObjectGenerator objGen = createObjectGenerator(binding, repoId, 0, 0, 0, documentType, null,
           contentSizeInKB, rootFolderId, doCleanup);
       
       ObjectGeneratorRunner gen = new ObjectGeneratorRunner(objGen, Action.CreateDocument);
-      gen.fRootFolderId = getRootFolderId(provider, repoId, rootFolderId);
+      gen.fRootFolderId = getRootFolderId(binding, repoId, rootFolderId);
       gen.fCount = noDocuments;
       runners[i] = gen;
     }
     return runners;
   }
 
-  public static ObjectGeneratorRunner prepareForCreateFolder(CmisProvider provider, String repoId,
+  public static ObjectGeneratorRunner prepareForCreateFolder(CmisBinding provider, String repoId,
       String folderType, String rootFolderId, int noFolders, boolean doCleanup) {
     
     ObjectGenerator objGen = createObjectGenerator(provider, repoId, 0, 0, 0, null, folderType,
@@ -180,16 +180,16 @@ public class MultiThreadedObjectGenerato
   }
 
   public static ObjectGeneratorRunner[] prepareForCreateFolderMT(int threadCount,
-      CmisProvider provider, String repoId, String folderType, String rootFolderId, int noFolders,
+      CmisBinding binding, String repoId, String folderType, String rootFolderId, int noFolders,
       boolean doCleanup) {
     
     ObjectGeneratorRunner[] runners = new ObjectGeneratorRunner[threadCount];
     for (int i=0; i<threadCount; i++) {
-      ObjectGenerator objGen = createObjectGenerator(provider, repoId, 0, 0, 0, null, folderType,
+      ObjectGenerator objGen = createObjectGenerator(binding, repoId, 0, 0, 0, null, folderType,
           0, rootFolderId, doCleanup);
       
       ObjectGeneratorRunner gen = new ObjectGeneratorRunner(objGen, Action.CreateFolders);
-      gen.fRootFolderId = getRootFolderId(provider, repoId, rootFolderId);
+      gen.fRootFolderId = getRootFolderId(binding, repoId, rootFolderId);
       gen.fCount = noFolders;
       runners[i] = gen;
     }