You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ace.apache.org by ma...@apache.org on 2012/03/16 09:58:23 UTC

svn commit: r1301381 [2/4] - in /ace/trunk: ./ ace-ant-tasks/ ace-client-automation/ ace-client-automation/src/main/java/org/apache/ace/client/automation/ ace-client-repository-api/ ace-client-repository-api/src/main/java/org/apache/ace/client/reposito...

Modified: ace/trunk/ace-client-repository-impl/src/main/java/org/apache/ace/client/repository/stateful/impl/StatefulGatewayRepositoryImpl.java
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-repository-impl/src/main/java/org/apache/ace/client/repository/stateful/impl/StatefulGatewayRepositoryImpl.java?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-repository-impl/src/main/java/org/apache/ace/client/repository/stateful/impl/StatefulGatewayRepositoryImpl.java (original)
+++ ace/trunk/ace-client-repository-impl/src/main/java/org/apache/ace/client/repository/stateful/impl/StatefulGatewayRepositoryImpl.java Fri Mar 16 08:58:19 2012
@@ -40,14 +40,14 @@ import org.apache.ace.client.repository.
 import org.apache.ace.client.repository.object.ArtifactObject;
 import org.apache.ace.client.repository.object.DeploymentArtifact;
 import org.apache.ace.client.repository.object.DeploymentVersionObject;
-import org.apache.ace.client.repository.object.GatewayObject;
+import org.apache.ace.client.repository.object.TargetObject;
 import org.apache.ace.client.repository.object.GroupObject;
 import org.apache.ace.client.repository.object.LicenseObject;
 import org.apache.ace.client.repository.repository.ArtifactRepository;
 import org.apache.ace.client.repository.repository.DeploymentVersionRepository;
-import org.apache.ace.client.repository.repository.GatewayRepository;
-import org.apache.ace.client.repository.stateful.StatefulGatewayObject;
-import org.apache.ace.client.repository.stateful.StatefulGatewayRepository;
+import org.apache.ace.client.repository.repository.TargetRepository;
+import org.apache.ace.client.repository.stateful.StatefulTargetObject;
+import org.apache.ace.client.repository.stateful.StatefulTargetRepository;
 import org.apache.ace.log.LogDescriptor;
 import org.apache.ace.log.LogEvent;
 import org.apache.ace.server.log.store.LogStore;
@@ -64,10 +64,10 @@ import org.osgi.service.log.LogService;
  * Implements the StatefulGatewayRepository. If an <code>AuditLogStore</code> is present,
  * it will be used; it is assumed that the auditlog store is up to date.
  */
-public class StatefulGatewayRepositoryImpl implements StatefulGatewayRepository, EventHandler {
+public class StatefulGatewayRepositoryImpl implements StatefulTargetRepository, EventHandler {
     private BundleContext m_context; /*Injected by dependency manager*/
     private ArtifactRepository m_artifactRepository; /*Injected by dependency manager*/
-    private GatewayRepository m_gatewayRepository; /*Injected by dependency manager*/
+    private TargetRepository m_gatewayRepository; /*Injected by dependency manager*/
     private DeploymentVersionRepository m_deploymentRepository; /*Injected by dependency manager*/
     private LogStore m_auditLogStore; /*Injected by dependency manager*/
     private EventAdmin m_eventAdmin; /*Injected by dependency manager*/
@@ -82,13 +82,13 @@ public class StatefulGatewayRepositoryIm
         m_sessionID = sessionID;
     }
 
-    public StatefulGatewayObject create(Map<String, String> attributes, Map<String, String> tags) throws IllegalArgumentException {
+    public StatefulTargetObject create(Map<String, String> attributes, Map<String, String> tags) throws IllegalArgumentException {
         throw new UnsupportedOperationException("Creating StatefulGatewayObjects is not supported.");
     }
 
-    public List<StatefulGatewayObject> get() {
+    public List<StatefulTargetObject> get() {
         synchronized(m_repository) {
-            List<StatefulGatewayObject> result = new ArrayList<StatefulGatewayObject>();
+            List<StatefulTargetObject> result = new ArrayList<StatefulTargetObject>();
             for (StatefulGatewayObjectImpl sgoi : m_repository.values()) {
                 result.add(sgoi);
             }
@@ -96,10 +96,10 @@ public class StatefulGatewayRepositoryIm
         }
     }
 
-    public List<StatefulGatewayObject> get(Filter filter) {
+    public List<StatefulTargetObject> get(Filter filter) {
         synchronized(m_repository) {
-            List<StatefulGatewayObject> result = new ArrayList<StatefulGatewayObject>();
-            for (StatefulGatewayObject entry : m_repository.values()) {
+            List<StatefulTargetObject> result = new ArrayList<StatefulTargetObject>();
+            for (StatefulTargetObject entry : m_repository.values()) {
                 if (filter.match(entry.getDictionary())) {
                     result.add(entry);
                 }
@@ -108,24 +108,24 @@ public class StatefulGatewayRepositoryIm
         }
     }
     
-    public StatefulGatewayObject get(String definition) {
+    public StatefulTargetObject get(String definition) {
     	return m_index.get(definition);
     }
 
-    public void remove(StatefulGatewayObject entity) {
+    public void remove(StatefulTargetObject entity) {
         throw new UnsupportedOperationException("Removing StatefulGatewayObjects is not supported.");
     }
 
-    public StatefulGatewayObject preregister(Map<String, String> attributes, Map<String, String> tags) {
+    public StatefulTargetObject preregister(Map<String, String> attributes, Map<String, String> tags) {
         synchronized(m_repository) {
-            GatewayObject go = m_gatewayRepository.create(attributes, tags);
+            TargetObject go = m_gatewayRepository.create(attributes, tags);
             return createStateful(go.getID());
         }
     }
 
     public void unregister(String gatewayID) {
         synchronized(m_repository) {
-            GatewayObject go = getGatewayObject(gatewayID);
+            TargetObject go = getGatewayObject(gatewayID);
             if (go == null) {
                 throw new IllegalArgumentException(gatewayID + " does not represent a GatewayObject.");
             }
@@ -146,10 +146,10 @@ public class StatefulGatewayRepositoryIm
      * @return The <code>GatewayObject</code> from the <code>GatewayRepository</code> which has the given
      * ID, or <code>null</code> if none can be found.
      */
-    GatewayObject getGatewayObject(String gatewayID) {
+    TargetObject getGatewayObject(String gatewayID) {
 //        synchronized(m_repository) {
             try {
-                List<GatewayObject> gateways = m_gatewayRepository.get(m_context.createFilter("(" + GatewayObject.KEY_ID + "=" + RepositoryUtil.escapeFilterValue(gatewayID) + ")"));
+                List<TargetObject> gateways = m_gatewayRepository.get(m_context.createFilter("(" + TargetObject.KEY_ID + "=" + RepositoryUtil.escapeFilterValue(gatewayID) + ")"));
                 if ((gateways != null) && (gateways.size() == 1)) {
                     return gateways.get(0);
                 }
@@ -201,7 +201,7 @@ public class StatefulGatewayRepositoryIm
     void removeStateful(StatefulGatewayObjectImpl entity) {
         synchronized(m_repository) {
             m_repository.remove(entity.getID());
-            notifyChanged(entity, StatefulGatewayObject.TOPIC_REMOVED);
+            notifyChanged(entity, StatefulTargetObject.TOPIC_REMOVED);
         }
     }
 
@@ -216,7 +216,7 @@ public class StatefulGatewayRepositoryIm
         if (!m_repository.containsKey(sgoi)) {
             m_repository.put(sgoi.getID(), sgoi);
             m_index.put(sgoi.getDefinition(), sgoi);
-            notifyChanged(sgoi, StatefulGatewayObject.TOPIC_ADDED);
+            notifyChanged(sgoi, StatefulTargetObject.TOPIC_ADDED);
             return true;
         }
         return false;
@@ -322,7 +322,7 @@ public class StatefulGatewayRepositoryIm
      */
     void register(String gatewayID) {
         Map<String, String> attr = new HashMap<String, String>();
-        attr.put(GatewayObject.KEY_ID, gatewayID);
+        attr.put(TargetObject.KEY_ID, gatewayID);
         Map<String, String> tags = new HashMap<String, String>();
         m_gatewayRepository.create(attr, tags);
         getStatefulGatewayObject(gatewayID).updateGatewayObject(false);
@@ -335,7 +335,7 @@ public class StatefulGatewayRepositoryIm
      * @param additionalProperties A Properties event, already containing some extra properties. If
      * RepositoryObject.EVENT_ENTITY is used, it will be overwritten.
      */
-    void notifyChanged(StatefulGatewayObject sgoi, String topic, Properties additionalProperties) {
+    void notifyChanged(StatefulTargetObject sgoi, String topic, Properties additionalProperties) {
         additionalProperties.put(RepositoryObject.EVENT_ENTITY, sgoi);
         additionalProperties.put(SessionFactory.SERVICE_SID, m_sessionID);
         m_eventAdmin.postEvent(new Event(topic, (Dictionary) additionalProperties));
@@ -346,7 +346,7 @@ public class StatefulGatewayRepositoryIm
      * @param sgoi The <code>StatefulGatewayObject</code> which has changed.
      * @param topic A topic string for posting the event.
      */
-    void notifyChanged(StatefulGatewayObject sgoi, String topic) {
+    void notifyChanged(StatefulTargetObject sgoi, String topic) {
         notifyChanged(sgoi, topic, new Properties());
     }
 
@@ -386,7 +386,7 @@ public class StatefulGatewayRepositoryIm
      */
     private List<StatefulGatewayObjectImpl> parseGatewayRepository() {
         List<StatefulGatewayObjectImpl> result = new ArrayList<StatefulGatewayObjectImpl>();
-        for (GatewayObject go : m_gatewayRepository.get()) {
+        for (TargetObject go : m_gatewayRepository.get()) {
             StatefulGatewayObjectImpl sgoi = getStatefulGatewayObject(go.getID());
             if (sgoi == null) {
                 result.add(createStateful(go.getID()));
@@ -465,7 +465,7 @@ public class StatefulGatewayRepositoryIm
      * @throws java.io.IOException When there is a problem processing an artifact for deployment.
      */
     DeploymentArtifact[] getNecessaryDeploymentArtifacts(String gatewayID, String version) throws IOException {
-        GatewayObject go = getGatewayObject(gatewayID);
+        TargetObject go = getGatewayObject(gatewayID);
 
         Map<ArtifactObject, String> bundles = new HashMap<ArtifactObject, String>();
         Map<ArtifactObject, String> artifacts = new HashMap<ArtifactObject, String>();
@@ -581,7 +581,7 @@ public class StatefulGatewayRepositoryIm
     */
     ArtifactObject[] getNecessaryArtifacts(String gatewayID) {
         List<ArtifactObject> result = new ArrayList<ArtifactObject>();
-        GatewayObject go = getGatewayObject(gatewayID);
+        TargetObject go = getGatewayObject(gatewayID);
 
         Map<String, ArtifactObject> allProcessors = new HashMap<String, ArtifactObject>();
         for (ArtifactObject bundle : m_artifactRepository.getResourceProcessors()) {
@@ -669,9 +669,9 @@ public class StatefulGatewayRepositoryIm
     }
 
     public void handleEvent(Event event) {
-        if (event.getTopic().equals(GatewayObject.TOPIC_ADDED) || event.getTopic().equals(GatewayObject.TOPIC_REMOVED)) {
+        if (event.getTopic().equals(TargetObject.TOPIC_ADDED) || event.getTopic().equals(TargetObject.TOPIC_REMOVED)) {
             synchronized(m_repository) {
-                String id = ((GatewayObject) event.getProperty(RepositoryObject.EVENT_ENTITY)).getID();
+                String id = ((TargetObject) event.getProperty(RepositoryObject.EVENT_ENTITY)).getID();
                 StatefulGatewayObjectImpl sgoi = getStatefulGatewayObject(id);
                 if (sgoi == null) {
                     createStateful(id);

Modified: ace/trunk/ace-client-repository-impl/src/test/java/org/apache/ace/client/repository/impl/ModelTest.java
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-repository-impl/src/test/java/org/apache/ace/client/repository/impl/ModelTest.java?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-repository-impl/src/test/java/org/apache/ace/client/repository/impl/ModelTest.java (original)
+++ ace/trunk/ace-client-repository-impl/src/test/java/org/apache/ace/client/repository/impl/ModelTest.java Fri Mar 16 08:58:19 2012
@@ -35,14 +35,14 @@ import org.apache.ace.client.repository.
 import org.apache.ace.client.repository.object.ArtifactObject;
 import org.apache.ace.client.repository.object.DeploymentArtifact;
 import org.apache.ace.client.repository.object.DeploymentVersionObject;
-import org.apache.ace.client.repository.object.GatewayObject;
+import org.apache.ace.client.repository.object.TargetObject;
 import org.apache.ace.client.repository.object.Group2LicenseAssociation;
 import org.apache.ace.client.repository.object.GroupObject;
 import org.apache.ace.client.repository.object.LicenseObject;
 import org.apache.ace.client.repository.repository.Artifact2GroupAssociationRepository;
 import org.apache.ace.client.repository.repository.ArtifactRepository;
 import org.apache.ace.client.repository.repository.DeploymentVersionRepository;
-import org.apache.ace.client.repository.repository.GatewayRepository;
+import org.apache.ace.client.repository.repository.TargetRepository;
 import org.apache.ace.client.repository.repository.Group2LicenseAssociationRepository;
 import org.apache.ace.client.repository.repository.GroupRepository;
 import org.apache.ace.client.repository.repository.License2GatewayAssociationRepository;
@@ -116,7 +116,7 @@ public class ModelTest {
         repos.put(Group2LicenseAssociationRepository.class, m_group2licenseRepository);
         repos.put(LicenseRepository.class, m_licenseRepository);
         repos.put(License2GatewayAssociationRepository.class, m_license2gatewayRepository);
-        repos.put(GatewayRepository.class, m_gatewayRepository);
+        repos.put(TargetRepository.class, m_gatewayRepository);
         repos.put(DeploymentVersionRepository.class, m_deploymentVersionRepository);
 
         m_repositoryAdmin.initialize(repos);
@@ -435,7 +435,7 @@ public class ModelTest {
     public void testLicense2GatewayAssociations() {
         initializeRepositoryAdmin();
         LicenseObject l1 = createBasicLicenseObject("license1");
-        GatewayObject g1 = createBasicGatewayObject("gateway1");
+        TargetObject g1 = createBasicGatewayObject("gateway1");
         m_license2gatewayRepository.create(l1, g1);
 
         assert l1.getGroups().size() == 0 : "License 1 should not be associated with any groups; it is associated with " + l1.getGroups().size() + ".";
@@ -673,9 +673,9 @@ public class ModelTest {
         return m_licenseRepository.create(attr, tags);
     }
 
-    private GatewayObject createBasicGatewayObject(String id) {
+    private TargetObject createBasicGatewayObject(String id) {
         Map<String, String> attr = new HashMap<String, String>();
-        attr.put(GatewayObject.KEY_ID, id);
+        attr.put(TargetObject.KEY_ID, id);
         Map<String, String> tags = new HashMap<String, String>();
 
         return m_gatewayRepository.create(attr, tags);

Modified: ace/trunk/ace-client-repository-useradmin/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-repository-useradmin/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-repository-useradmin/pom.xml (original)
+++ ace/trunk/ace-client-repository-useradmin/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.client.repository.useradmin</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-client-repository-useradmin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-client-repository-useradmin</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-client-repository-useradmin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-client-repository-useradmin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-client-repository-useradmin</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-client-repository-useradmin</url>
     </scm>
 
     <properties>
@@ -125,4 +125,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-client-rest/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-rest/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-rest/pom.xml (original)
+++ ace/trunk/ace-client-rest/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.client.rest</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-client-rest</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-client-rest</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-client-rest</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-client-rest</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-client-rest</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-client-rest</url>
     </scm>
 
     <properties>
@@ -100,4 +100,4 @@
             <version>1.7.1</version>
         </dependency>
     </dependencies>
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RESTClientServlet.java
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RESTClientServlet.java?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RESTClientServlet.java (original)
+++ ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RESTClientServlet.java Fri Mar 16 08:58:19 2012
@@ -36,7 +36,7 @@ import javax.servlet.http.HttpServletRes
 
 import org.apache.ace.client.repository.RepositoryObject;
 import org.apache.ace.client.repository.SessionFactory;
-import org.apache.ace.client.repository.stateful.StatefulGatewayObject;
+import org.apache.ace.client.repository.stateful.StatefulTargetObject;
 import org.apache.felix.dm.Component;
 import org.apache.felix.dm.DependencyManager;
 import org.osgi.service.cm.ConfigurationException;

Modified: ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RepositoryObjectSerializer.java
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RepositoryObjectSerializer.java?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RepositoryObjectSerializer.java (original)
+++ ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/RepositoryObjectSerializer.java Fri Mar 16 08:58:19 2012
@@ -29,7 +29,7 @@ import java.util.List;
 import org.apache.ace.client.repository.RepositoryObject;
 import org.apache.ace.client.repository.object.ArtifactObject;
 import org.apache.ace.client.repository.object.DeploymentArtifact;
-import org.apache.ace.client.repository.stateful.StatefulGatewayObject;
+import org.apache.ace.client.repository.stateful.StatefulTargetObject;
 import org.apache.ace.log.AuditEvent;
 import org.apache.ace.log.LogEvent;
 
@@ -63,8 +63,8 @@ public class RepositoryObjectSerializer 
         }
         result.add("tags", tags);
         // finally, if it's a target with state, add that as well
-        if (repositoryObject instanceof StatefulGatewayObject) {
-            StatefulGatewayObject stateful = (StatefulGatewayObject) repositoryObject;
+        if (repositoryObject instanceof StatefulTargetObject) {
+            StatefulTargetObject stateful = (StatefulTargetObject) repositoryObject;
             JsonObject state = new JsonObject();
             state.addProperty("registrationState", stateful.getRegistrationState().name());
             state.addProperty("provisioningState", stateful.getProvisioningState().name());
@@ -94,7 +94,7 @@ public class RepositoryObjectSerializer 
         return result;
     }
 
-    private JsonArray getAuditEvents(StatefulGatewayObject stateful) {
+    private JsonArray getAuditEvents(StatefulTargetObject stateful) {
         DateFormat format = SimpleDateFormat.getDateTimeInstance();
         List<LogEvent> auditEvents = stateful.getAuditEvents();
         JsonArray events = new JsonArray();

Modified: ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/Workspace.java
URL: http://svn.apache.org/viewvc/ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/Workspace.java?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/Workspace.java (original)
+++ ace/trunk/ace-client-rest/src/main/java/org/apache/ace/client/rest/Workspace.java Fri Mar 16 08:58:19 2012
@@ -33,13 +33,13 @@ import org.apache.ace.client.repository.
 import org.apache.ace.client.repository.SessionFactory;
 import org.apache.ace.client.repository.repository.Artifact2GroupAssociationRepository;
 import org.apache.ace.client.repository.repository.ArtifactRepository;
-import org.apache.ace.client.repository.repository.GatewayRepository;
+import org.apache.ace.client.repository.repository.TargetRepository;
 import org.apache.ace.client.repository.repository.Group2LicenseAssociationRepository;
 import org.apache.ace.client.repository.repository.GroupRepository;
 import org.apache.ace.client.repository.repository.License2GatewayAssociationRepository;
 import org.apache.ace.client.repository.repository.LicenseRepository;
-import org.apache.ace.client.repository.stateful.StatefulGatewayObject;
-import org.apache.ace.client.repository.stateful.StatefulGatewayRepository;
+import org.apache.ace.client.repository.stateful.StatefulTargetObject;
+import org.apache.ace.client.repository.stateful.StatefulTargetRepository;
 import org.apache.felix.dm.Component;
 import org.apache.felix.dm.DependencyManager;
 import org.osgi.framework.Filter;
@@ -70,8 +70,8 @@ public class Workspace {
     private volatile ArtifactRepository m_artifactRepository;
     private volatile GroupRepository m_featureRepository;
     private volatile LicenseRepository m_distributionRepository;
-    private volatile StatefulGatewayRepository m_statefulTargetRepository;
-    private volatile GatewayRepository m_targetRepository;
+    private volatile StatefulTargetRepository m_statefulTargetRepository;
+    private volatile TargetRepository m_targetRepository;
     private volatile Artifact2GroupAssociationRepository m_artifact2FeatureAssociationRepository;
     private volatile Group2LicenseAssociationRepository m_feature2DistributionAssociationRepository;
     private volatile License2GatewayAssociationRepository m_distribution2TargetAssociationRepository;
@@ -110,8 +110,8 @@ public class Workspace {
         addSessionDependency(component, ArtifactRepository.class, true);
         addSessionDependency(component, GroupRepository.class, true);
         addSessionDependency(component, LicenseRepository.class, true);
-        addSessionDependency(component, GatewayRepository.class, true);
-        addSessionDependency(component, StatefulGatewayRepository.class, true);
+        addSessionDependency(component, TargetRepository.class, true);
+        addSessionDependency(component, StatefulTargetRepository.class, true);
         addSessionDependency(component, Artifact2GroupAssociationRepository.class, true);
         addSessionDependency(component, Group2LicenseAssociationRepository.class, true);
         addSessionDependency(component, License2GatewayAssociationRepository.class, true);
@@ -125,7 +125,7 @@ public class Workspace {
             m_repositoryAdmin.login(m_repositoryAdmin.createLoginContext(user)
                 .setObrBase(new URL(m_obrURL))
                 .addShopRepository(new URL(m_repositoryURL), m_customerName, m_storeRepositoryName, true)
-                .addGatewayRepository(new URL(m_repositoryURL), m_customerName, m_licenseRepositoryName, true)
+                .addTargetRepository(new URL(m_repositoryURL), m_customerName, m_licenseRepositoryName, true)
                 .addDeploymentRepository(new URL(m_repositoryURL), m_customerName, m_deploymentRepositoryName, true)
                 );
             m_repositoryAdmin.checkout();
@@ -164,7 +164,7 @@ public class Workspace {
 
     public RepositoryObject addRepositoryObject(String entityType, Map<String, String> attributes, Map<String, String> tags) throws IllegalArgumentException {
         if (TARGET.equals(entityType)) {
-            return ((StatefulGatewayRepository) getObjectRepository(TARGET)).preregister(attributes, tags);
+            return ((StatefulTargetRepository) getObjectRepository(TARGET)).preregister(attributes, tags);
         }
         else {
             if (ARTIFACT2FEATURE.equals(entityType) || FEATURE2DISTRIBUTION.equals(entityType) || DISTRIBUTION2TARGET.equals(entityType)) {
@@ -184,9 +184,9 @@ public class Workspace {
 
 
                 if (left != null) {
-                    if (left instanceof StatefulGatewayObject) {
-                        if (((StatefulGatewayObject) left).isRegistered()) {
-                            attributes.put("leftEndpoint", ((StatefulGatewayObject) left).getGatewayObject().getAssociationFilter(attributes));
+                    if (left instanceof StatefulTargetObject) {
+                        if (((StatefulTargetObject) left).isRegistered()) {
+                            attributes.put("leftEndpoint", ((StatefulTargetObject) left).getGatewayObject().getAssociationFilter(attributes));
                         }
                     }
                     else {
@@ -194,9 +194,9 @@ public class Workspace {
                     }
                 }
                 if (right != null) {
-                    if (right instanceof StatefulGatewayObject) {
-                        if (((StatefulGatewayObject) right).isRegistered()) {
-                            attributes.put("rightEndpoint", ((StatefulGatewayObject) right).getGatewayObject().getAssociationFilter(attributes));
+                    if (right instanceof StatefulTargetObject) {
+                        if (((StatefulTargetObject) right).isRegistered()) {
+                            attributes.put("rightEndpoint", ((StatefulTargetObject) right).getGatewayObject().getAssociationFilter(attributes));
                         }
                     }
                     else {
@@ -242,9 +242,9 @@ public class Workspace {
             }
 
             if (left != null) {
-                if (left instanceof StatefulGatewayObject) {
-                    if (((StatefulGatewayObject) left).isRegistered()) {
-                        repositoryObject.addAttribute("leftEndpoint", ((StatefulGatewayObject) left).getGatewayObject().getAssociationFilter(getAttributes(((StatefulGatewayObject) left).getGatewayObject())));
+                if (left instanceof StatefulTargetObject) {
+                    if (((StatefulTargetObject) left).isRegistered()) {
+                        repositoryObject.addAttribute("leftEndpoint", ((StatefulTargetObject) left).getGatewayObject().getAssociationFilter(getAttributes(((StatefulTargetObject) left).getGatewayObject())));
                     }
                 }
                 else {
@@ -252,9 +252,9 @@ public class Workspace {
                 }
             }
             if (right != null) {
-                if (right instanceof StatefulGatewayObject) {
-                    if (((StatefulGatewayObject) right).isRegistered()) {
-                        repositoryObject.addAttribute("rightEndpoint", ((StatefulGatewayObject) right).getGatewayObject().getAssociationFilter(getAttributes(((StatefulGatewayObject) right).getGatewayObject())));
+                if (right instanceof StatefulTargetObject) {
+                    if (((StatefulTargetObject) right).isRegistered()) {
+                        repositoryObject.addAttribute("rightEndpoint", ((StatefulTargetObject) right).getGatewayObject().getAssociationFilter(getAttributes(((StatefulTargetObject) right).getGatewayObject())));
                     }
                 }
                 else {

Modified: ace/trunk/ace-configurator-serveruseradmin/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-configurator-serveruseradmin/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-configurator-serveruseradmin/pom.xml (original)
+++ ace/trunk/ace-configurator-serveruseradmin/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.configurator.serveruseradmin</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator-serveruseradmin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator-serveruseradmin</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator-serveruseradmin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-configurator-serveruseradmin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-configurator-serveruseradmin</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-configurator-serveruseradmin</url>
     </scm>
 
     <properties>
@@ -68,4 +68,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-configurator-useradmin-task/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-configurator-useradmin-task/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-configurator-useradmin-task/pom.xml (original)
+++ ace/trunk/ace-configurator-useradmin-task/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.configurator.useradmin.task</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator-useradmin-task</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator-useradmin-task</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator-useradmin-task</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-configurator-useradmin-task</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-configurator-useradmin-task</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-configurator-useradmin-task</url>
     </scm>
 
     <properties>
@@ -89,4 +89,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-configurator/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-configurator/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-configurator/pom.xml (original)
+++ ace/trunk/ace-configurator/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.configurator</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-configurator</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-configurator</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-configurator</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-configurator</url>
     </scm>
     
     <properties>
@@ -72,4 +72,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-consolelogger/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-consolelogger/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-consolelogger/pom.xml (original)
+++ ace/trunk/ace-consolelogger/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.consolelogger</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-consolelogger</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-consolelogger</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-consolelogger</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-consolelogger</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-consolelogger</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-consolelogger</url>
     </scm>
 
     <properties>
@@ -68,4 +68,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-api/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-api/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-api/pom.xml (original)
+++ ace/trunk/ace-deployment-api/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.api</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-api</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-api</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-api</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-api</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-api</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-api</url>
     </scm>
 
     <properties>
@@ -62,4 +62,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-deploymentadmin/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-deploymentadmin/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-deploymentadmin/pom.xml (original)
+++ ace/trunk/ace-deployment-deploymentadmin/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.deploymentadmin</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-deploymentadmin</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-deploymentadmin</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-deploymentadmin</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-deploymentadmin</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-deploymentadmin</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-deploymentadmin</url>
     </scm>
     
     <properties>
@@ -77,4 +77,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-provider-api/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-provider-api/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-provider-api/pom.xml (original)
+++ ace/trunk/ace-deployment-provider-api/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,20 +24,20 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
     <artifactId>org.apache.ace.deployment.provider.api</artifactId>
     <packaging>bundle</packaging>
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <name>Apache ACE :: Deployment :: Provider :: API</name>
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-api</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-api</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-api</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-api</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-api</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-api</url>
     </scm>
     
     <properties>

Modified: ace/trunk/ace-deployment-provider-base/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-provider-base/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-provider-base/pom.xml (original)
+++ ace/trunk/ace-deployment-provider-base/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,20 +24,20 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.provider.base</artifactId>
     <packaging>jar</packaging>
     <name>Apache ACE :: Deployment :: Provider :: Base (library)</name>
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-base</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-base</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-base</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-base</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-base</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-base</url>
     </scm>
 
     <dependencies>
@@ -59,4 +59,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-provider-filebased/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-provider-filebased/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-provider-filebased/pom.xml (original)
+++ ace/trunk/ace-deployment-provider-filebased/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.provider.filebased</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-filebased</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-filebased</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-filebased</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-filebased</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-filebased</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-filebased</url>
     </scm>
 
     <properties>
@@ -85,4 +85,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-provider-repositorybased/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-provider-repositorybased/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-provider-repositorybased/pom.xml (original)
+++ ace/trunk/ace-deployment-provider-repositorybased/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.provider.repositorybased</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-repositorybased</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-repositorybased</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-provider-repositorybased</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-repositorybased</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-repositorybased</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-provider-repositorybased</url>
     </scm>
 
     <properties>
@@ -94,4 +94,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-servlet/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-servlet/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-servlet/pom.xml (original)
+++ ace/trunk/ace-deployment-servlet/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.servlet</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description>Servlet that is used by management agents to get an overview of available versions and request 'deployment packages' of specific versions or deltas between versions.</description>
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-servlet</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-servlet</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-servlet</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-servlet</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-servlet</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-servlet</url>
     </scm>
 
     <properties>
@@ -93,4 +93,4 @@
             <artifactId>servlet-api</artifactId>
         </dependency>
     </dependencies>
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-streamgenerator/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-streamgenerator/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-streamgenerator/pom.xml (original)
+++ ace/trunk/ace-deployment-streamgenerator/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.streamgenerator</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-streamgenerator</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-streamgenerator</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-streamgenerator</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-streamgenerator</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-streamgenerator</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-streamgenerator</url>
     </scm>
 
     <properties>
@@ -89,4 +89,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-task/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-task/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-task/pom.xml (original)
+++ ace/trunk/ace-deployment-task/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.task</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description>This bundle is responsible for checking the deployment server for updates and for synchronizing the local instance with the server.</description>
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-task</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-task</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-task</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-task</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-task</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-task</url>
     </scm>
 
     <properties>
@@ -100,4 +100,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-deployment-verifier-ui/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-verifier-ui/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-verifier-ui/pom.xml (original)
+++ ace/trunk/ace-deployment-verifier-ui/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.verifier.ui</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-verifier-ui</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-verifier-ui</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-verifier-ui</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-verifier-ui</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-verifier-ui</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-verifier-ui</url>
     </scm>
 
    <properties>

Modified: ace/trunk/ace-deployment-verifier-ui/src/main/java/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-verifier-ui/src/main/java/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-verifier-ui/src/main/java/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java (original)
+++ ace/trunk/ace-deployment-verifier-ui/src/main/java/org/apache/ace/deployment/verifier/ui/ACEVerifierExtension.java Fri Mar 16 08:58:19 2012
@@ -32,9 +32,9 @@ import java.util.jar.JarInputStream;
 import org.apache.ace.client.repository.RepositoryObject;
 import org.apache.ace.client.repository.object.DeploymentArtifact;
 import org.apache.ace.client.repository.object.DeploymentVersionObject;
-import org.apache.ace.client.repository.object.GatewayObject;
+import org.apache.ace.client.repository.object.TargetObject;
 import org.apache.ace.client.repository.repository.DeploymentVersionRepository;
-import org.apache.ace.client.repository.stateful.StatefulGatewayObject;
+import org.apache.ace.client.repository.stateful.StatefulTargetObject;
 import org.apache.ace.deployment.verifier.VerifierService;
 import org.apache.ace.deployment.verifier.VerifierService.VerifyEnvironment;
 import org.apache.ace.deployment.verifier.VerifierService.VerifyReporter;
@@ -63,10 +63,10 @@ public class ACEVerifierExtension implem
 
     public Component create(Map<String, Object> context) {
         RepositoryObject object = getRepositoryObjectFromContext(context);
-        if (object instanceof StatefulGatewayObject) {
-            StatefulGatewayObject statefulTarget = (StatefulGatewayObject) object;
+        if (object instanceof StatefulTargetObject) {
+            StatefulTargetObject statefulTarget = (StatefulTargetObject) object;
             if (statefulTarget.isRegistered()) {
-                String id = object.getAttribute(GatewayObject.KEY_ID);
+                String id = object.getAttribute(TargetObject.KEY_ID);
                 return new ManifestArea(id, (object.getAttribute("manifest") == null) ? Constants.BUNDLE_MANIFESTVERSION + ": " + "2" + "\n" + Constants.BUNDLE_SYMBOLICNAME + ": " + "org.apache.felix.framework" + "\n" + Constants.EXPORT_PACKAGE + ": " + VerifierService.SYSTEM_PACKAGES + "," + VerifierService.JRE_1_6_PACKAGES + "," + "org.osgi.service.cm;version=1.2,org.osgi.service.metatype;version=1.1.1,org.osgi.service.cm; version=1.3.0,org.osgi.service.deploymentadmin.spi; version=1.0.1,org.osgi.service.deploymentadmin; version=1.1.0" + "\n" : object.getAttribute("manifest"), object);
             }
         }

Modified: ace/trunk/ace-deployment-verifier/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-deployment-verifier/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-deployment-verifier/pom.xml (original)
+++ ace/trunk/ace-deployment-verifier/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.deployment.verifier</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-verifier</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-verifier</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-deployment-verifier</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-verifier</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-deployment-verifier</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-deployment-verifier</url>
     </scm>
 
     <properties>

Modified: ace/trunk/ace-discovery-api/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-discovery-api/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-discovery-api/pom.xml (original)
+++ ace/trunk/ace-discovery-api/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.discovery.api</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-api</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-api</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-api</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-discovery-api</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-discovery-api</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-discovery-api</url>
     </scm>
     
     <properties>
@@ -50,4 +50,4 @@
         </import.package>
     </properties>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-discovery-property/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-discovery-property/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-discovery-property/pom.xml (original)
+++ ace/trunk/ace-discovery-property/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.discovery.property</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-property</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-property</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-property</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-discovery-property</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-discovery-property</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-discovery-property</url>
     </scm>
 
     <properties>
@@ -78,4 +78,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-discovery-upnp/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-discovery-upnp/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-discovery-upnp/pom.xml (original)
+++ ace/trunk/ace-discovery-upnp/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.discovery.upnp</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-upnp</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-upnp</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-discovery-upnp</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-discovery-upnp</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-discovery-upnp</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-discovery-upnp</url>
     </scm>
     
     <properties>
@@ -82,4 +82,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-gateway-log-store/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-gateway-log-store/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-gateway-log-store/pom.xml (original)
+++ ace/trunk/ace-gateway-log-store/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.gateway.log.store</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-gateway-log-store</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-gateway-log-store</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-gateway-log-store</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-gateway-log-store</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-gateway-log-store</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-gateway-log-store</url>
     </scm>
     
     <properties>
@@ -82,4 +82,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-gateway-log/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-gateway-log/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-gateway-log/pom.xml (original)
+++ ace/trunk/ace-gateway-log/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.gateway.log</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-gateway-log</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-gateway-log</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-gateway-log</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-gateway-log</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-gateway-log</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-gateway-log</url>
     </scm>
     
     <properties>
@@ -89,4 +89,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-glassfish-launcher/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-glassfish-launcher/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-glassfish-launcher/pom.xml (original)
+++ ace/trunk/ace-glassfish-launcher/pom.xml Fri Mar 16 08:58:19 2012
@@ -5,7 +5,7 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
     <modelVersion>4.0.0</modelVersion>
@@ -57,4 +57,4 @@
             <scope>compile</scope>
         </dependency>
     </dependencies>
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-http-redirector/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-http-redirector/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-http-redirector/pom.xml (original)
+++ ace/trunk/ace-http-redirector/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.http.redirector</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description>Redirects HTTP requests from one (local) URL to another. Multiple redirects can be configured via a managed service factory.</description>
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-http-redirector</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-http-redirector</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-http-redirector</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-http-redirector</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-http-redirector</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-http-redirector</url>
     </scm>
 
     <properties>
@@ -77,4 +77,4 @@
             <artifactId>org.apache.ace.httplistener</artifactId>
         </dependency>
     </dependencies>
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-httplistener/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-httplistener/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-httplistener/pom.xml (original)
+++ ace/trunk/ace-httplistener/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.httplistener</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-httplistener</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-httplistener</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-httplistener</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-httplistener</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-httplistener</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-httplistener</url>
     </scm>
 
     <properties>
@@ -75,4 +75,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-identification-api/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-identification-api/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-identification-api/pom.xml (original)
+++ ace/trunk/ace-identification-api/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.identification.api</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-api</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-api</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-api</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-identification-api</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-identification-api</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-identification-api</url>
     </scm>
     
     <properties>
@@ -50,4 +50,4 @@
         </import.package>
     </properties>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-identification-ifconfig/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-identification-ifconfig/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-identification-ifconfig/pom.xml (original)
+++ ace/trunk/ace-identification-ifconfig/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.identification.ifconfig</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-ifconfig</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-ifconfig</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-ifconfig</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-identification-ifconfig</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-identification-ifconfig</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-identification-ifconfig</url>
     </scm>
 
     <properties>
@@ -77,4 +77,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-identification-property/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-identification-property/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-identification-property/pom.xml (original)
+++ ace/trunk/ace-identification-property/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,11 +24,11 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
-    <version>0.8.1-incubator-SNAPSHOT</version>
+    <version>0.8.1-SNAPSHOT</version>
     <artifactId>org.apache.ace.identification.property</artifactId>
     <packaging>bundle</packaging>
 
@@ -36,9 +36,9 @@
     <description />
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-property</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-property</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-identification-property</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-identification-property</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-identification-property</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-identification-property</url>
     </scm>
     
     <properties>
@@ -79,4 +79,4 @@
         </dependency>
     </dependencies>
 
-</project>
\ No newline at end of file
+</project>

Modified: ace/trunk/ace-integrationtests/pom.xml
URL: http://svn.apache.org/viewvc/ace/trunk/ace-integrationtests/pom.xml?rev=1301381&r1=1301380&r2=1301381&view=diff
==============================================================================
--- ace/trunk/ace-integrationtests/pom.xml (original)
+++ ace/trunk/ace-integrationtests/pom.xml Fri Mar 16 08:58:19 2012
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.ace</groupId>
         <artifactId>ace-pom</artifactId>
-        <version>0.8.1-incubator-SNAPSHOT</version>
+        <version>0.8.1-SNAPSHOT</version>
         <relativePath>../pom/pom.xml</relativePath>
     </parent>
 
@@ -33,9 +33,9 @@
     <name>Apache ACE :: Integration Tests</name>
 
     <scm>
-        <connection>scm:svn:http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-integrationtests</connection>
-        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/incubator/ace/trunk/ace-integrationtests</developerConnection>
-        <url>http://svn.apache.org/repos/asf/incubator/ace/trunk/ace-integrationtests</url>
+        <connection>scm:svn:http://svn.apache.org/repos/asf/ace/trunk/ace-integrationtests</connection>
+        <developerConnection>scm:svn:https://svn.apache.org/repos/asf/ace/trunk/ace-integrationtests</developerConnection>
+        <url>http://svn.apache.org/repos/asf/ace/trunk/ace-integrationtests</url>
     </scm>
 
     <dependencies>
@@ -320,4 +320,4 @@
         </plugins>
     </build>
 
-</project>
\ No newline at end of file
+</project>