You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@continuum.apache.org by oc...@apache.org on 2010/05/06 11:23:34 UTC

svn commit: r941625 [13/24] - in /continuum/branches/continuum-flat-multi-module: ./ continuum-api/ continuum-api/src/main/java/org/apache/continuum/builder/distributed/ continuum-api/src/main/java/org/apache/continuum/builder/distributed/manager/ cont...

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-api/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportService.java
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-api/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportService.java?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-api/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportService.java (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-api/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportService.java Thu May  6 09:23:13 2010
@@ -1,10 +1,5 @@
 package org.apache.continuum.distributed.transport.slave;
 
-import com.atlassian.xmlrpc.ServiceObject;
-
-import java.util.List;
-import java.util.Map;
-
 /*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
@@ -24,6 +19,11 @@ import java.util.Map;
  * under the License.
  */
 
+import com.atlassian.xmlrpc.ServiceObject;
+
+import java.util.List;
+import java.util.Map;
+
 /**
  * SlaveBuildAgentTransportService
  */
@@ -33,10 +33,10 @@ public interface SlaveBuildAgentTranspor
     public Boolean buildProjects( List<Map<String, Object>> projectsBuildContext )
         throws Exception;
 
-    public Map getBuildResult( int projectId )
+    public Map<String, Object> getBuildResult( int projectId )
         throws Exception;
 
-    public Integer getProjectCurrentlyBuilding()
+    public Map<String, Object> getProjectCurrentlyBuilding()
         throws Exception;
 
     public List<Map<String, String>> getAvailableInstallations()
@@ -61,7 +61,7 @@ public interface SlaveBuildAgentTranspor
         throws Exception;
 
     public String releasePrepare( Map project, Map properties, Map releaseVersion, Map developmentVersion,
-                                  Map environments )
+                                  Map environments, String username )
         throws Exception;
 
     public Map<String, Object> getReleaseResult( String releaseId )
@@ -77,12 +77,12 @@ public interface SlaveBuildAgentTranspor
         throws Exception;
 
     public Boolean releasePerform( String releaseId, String goals, String arguments, boolean useReleaseProfile,
-                                   Map repository )
+                                   Map repository, String username )
         throws Exception;
 
     public String releasePerformFromScm( String goals, String arguments, boolean useReleaseProfile, Map repository,
                                          String scmUrl, String scmUsername, String scmPassword, String scmTag,
-                                         String scmTagBase, Map environments )
+                                         String scmTagBase, Map environments, String username )
         throws Exception;
 
     public String releaseCleanup( String releaseId )
@@ -90,4 +90,46 @@ public interface SlaveBuildAgentTranspor
 
     public Boolean releaseRollback( String releaseId, int projectId )
         throws Exception;
+
+    public Integer getBuildSizeOfAgent()
+        throws Exception;
+
+    public List<Map<String, Object>> getProjectsInPrepareBuildQueue()
+        throws Exception;
+
+    public List<Map<String, Object>> getProjectsAndBuildDefinitionsInPrepareBuildQueue()
+        throws Exception;
+
+    public List<Map<String, Object>> getProjectsInBuildQueue()
+        throws Exception;
+
+    public Map<String, Object> getProjectCurrentlyPreparingBuild()
+        throws Exception;
+
+    public List<Map<String, Object>> getProjectsAndBuildDefinitionsCurrentlyPreparingBuild()
+        throws Exception;
+
+    public Boolean isProjectGroupInQueue( int projectGroupId )
+        throws Exception;
+
+    public Boolean isProjectScmRootInQueue( int projectScmRootId, List<Integer> projectIds )
+        throws Exception;
+
+    public Boolean isProjectCurrentlyBuilding( int projectId )
+        throws Exception;
+
+    public Boolean isProjectInBuildQueue( int projectId )
+        throws Exception;
+
+    public Boolean removeFromPrepareBuildQueue( int projectGroupId, int scmRootId )
+        throws Exception;
+
+    public Boolean removeFromPrepareBuildQueue( List<String> hashCodes )
+        throws Exception;
+
+    public Boolean removeFromBuildQueue( int projectId, int buildDefinitionId )
+        throws Exception;
+
+    public Boolean removeFromBuildQueue( List<String> hashCodes )
+        throws Exception;
 }

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/pom.xml
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/pom.xml?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/pom.xml (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/pom.xml Thu May  6 09:23:13 2010
@@ -21,7 +21,7 @@ under the License.
   <parent>
     <groupId>org.apache.continuum</groupId>
     <artifactId>continuum-distributed-slave</artifactId>
-    <version>1.4.0-SNAPSHOT</version>
+    <version>1.4.1-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>continuum-distributed-slave-client</artifactId>

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportClient.java
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportClient.java?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportClient.java (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-client/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportClient.java Thu May  6 09:23:13 2010
@@ -106,34 +106,34 @@ public class SlaveBuildAgentTransportCli
         return installations;
     }
 
-    public Map getBuildResult( int projectId )
+    public Map<String, Object> getBuildResult( int projectId )
         throws Exception
     {
-        Map buildResult;
+        Map<String, Object> buildResult;
 
         try
         {
             buildResult = slave.getBuildResult( projectId );
-            log.info( "Build result for project " + projectId + " acquired." );
+            log.info( "Build result for project '" + projectId + "' acquired." );
         }
         catch ( Exception e )
         {
-            log.error( "Failed to get build result for project " + projectId, e );
-            throw new Exception( "Failed to get build result for project " + projectId, e );
+            log.error( "Failed to get build result for project '" + projectId + "'", e );
+            throw new Exception( "Failed to get build result for project '" + projectId + "'", e );
         }
 
         return buildResult;
     }
 
-    public Integer getProjectCurrentlyBuilding()
+    public Map<String, Object> getProjectCurrentlyBuilding()
         throws Exception
     {
-        Integer projectId;
+        Map map;
 
         try
         {
-            projectId = slave.getProjectCurrentlyBuilding();
-            log.info( "Currently building project " + projectId );
+            map = slave.getProjectCurrentlyBuilding();
+            log.info( "Retrieving currently building project" );
         }
         catch ( Exception e )
         {
@@ -141,7 +141,7 @@ public class SlaveBuildAgentTransportCli
             throw new Exception( "Failed to get the currently building project", e );
         }
 
-        return projectId;
+        return map;
     }
 
     public Boolean ping()
@@ -190,12 +190,12 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.generateWorkingCopyContent( projectId, directory, baseUrl, imagesBaseUrl );
-            log.info( "Generated working copy content" );
+            log.info( "Generated working copy content for project '" + projectId + "'" );
         }
         catch ( Exception e )
         {
-            log.error( "Error generating working copy content", e );
-            throw new Exception( "Error generating working copy content", e );
+            log.error( "Error generating working copy content for project '" + projectId + "'", e );
+            throw new Exception( "Error generating working copy content for project '" + projectId + "'", e );
         }
 
         return result;
@@ -209,12 +209,12 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.getProjectFileContent( projectId, directory, filename );
-            log.info( "Retrived project file content" );
+            log.info( "Retrieved project '" + projectId + "' file content" );
         }
         catch ( Exception e )
         {
-            log.error( "Error retrieving project file content", e );
-            throw new Exception( "Error retrieving project file content", e );
+            log.error( "Error retrieving project '" + projectId + "' file content", e );
+            throw new Exception( "Error retrieving project '" + projectId + "' file content", e );
         }
 
         return result;
@@ -228,12 +228,12 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.getReleasePluginParameters( projectId, pomFilename );
-            log.info( "Retrieving release plugin parameters" );
+            log.info( "Retrieving release plugin parameters for project '" + projectId + "'" );
         }
         catch ( Exception e )
         {
-            log.error( "Error retrieving release plugin parameters", e );
-            throw new Exception( "Error retrieving release plugin parameters", e );
+            log.error( "Error retrieving release plugin parameters for project '" + projectId + "'", e );
+            throw new Exception( "Error retrieving release plugin parameters for project '" + projectId + "'", e );
         }
 
         return result;
@@ -247,27 +247,27 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.processProject( projectId, pomFilename, autoVersionSubmodules );
-            log.info( "Processing project" );
+            log.info( "Processing project '" + projectId + "'" );
         }
         catch ( Exception e )
         {
-            log.error( "Error processing project", e );
-            throw new Exception( "Error processing project", e );
+            log.error( "Error processing project '" + projectId + "'", e );
+            throw new Exception( "Error processing project '" + projectId + "'", e );
         }
 
         return result;
     }
 
     public String releasePrepare( Map project, Map properties, Map releaseVersion, Map developmentVersion,
-                                  Map environments )
+                                  Map environments, String username )
         throws Exception
     {
         String releaseId;
 
         try
         {
-            releaseId = slave.releasePrepare( project, properties, releaseVersion, developmentVersion, environments );
-            log.info( "Preparing release" );
+            releaseId = slave.releasePrepare( project, properties, releaseVersion, developmentVersion, environments, username );
+            log.info( "Preparing release '" + releaseId + "'" );
         }
         catch ( Exception e )
         {
@@ -286,12 +286,12 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.getReleaseResult( releaseId );
-            log.info( "Retrieving release result for " + releaseId );
+            log.info( "Retrieving release result, releaseId=" + releaseId );
         }
         catch ( Exception e )
         {
-            log.error( "Error retrieving release result for " + releaseId, e );
-            throw new Exception( "Error retrieving release result for " + releaseId, e );
+            log.error( "Error retrieving release result, releaseId=" + releaseId, e );
+            throw new Exception( "Error retrieving release result, releaseId=" + releaseId, e );
         }
 
         return result;
@@ -305,12 +305,12 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.getListener( releaseId );
-            log.info( "Retrieving listener for " + releaseId );
+            log.info( "Retrieving listener for releaseId=" + releaseId );
         }
         catch ( Exception e )
         {
-            log.error( "Error retrieving listener for " + releaseId, e );
-            throw new Exception( "Error retrieving listener for " + releaseId, e );
+            log.error( "Error retrieving listener for releaseId=" + releaseId, e );
+            throw new Exception( "Error retrieving listener for releaseId=" + releaseId, e );
         }
 
         return result;
@@ -325,12 +325,12 @@ public class SlaveBuildAgentTransportCli
         {
             slave.removeListener( releaseId );
             result = Boolean.FALSE;
-            log.info( "Removing listener for " + releaseId );
+            log.info( "Removing listener for releaseId=" + releaseId );
         }
         catch ( Exception e )
         {
-            log.error( "Error removing listener for " + releaseId, e );
-            throw new Exception( "Error removing listener for " + releaseId, e );
+            log.error( "Error removing listener for releaseId=" + releaseId, e );
+            throw new Exception( "Error removing listener for releaseId=" + releaseId, e );
         }
 
         return result;
@@ -344,33 +344,33 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.getPreparedReleaseName( releaseId );
-            log.info( "Retrieving prepared release name for " + releaseId );
+            log.info( "Retrieving prepared release name, releaseId=" + releaseId );
         }
         catch ( Exception e )
         {
-            log.error( "Error while retrieving prepared release name for " + releaseId );
-            throw new Exception( "Error while retrieving prepared release name for " + releaseId );
+            log.error( "Error while retrieving prepared release name, releaseId=" + releaseId );
+            throw new Exception( "Error while retrieving prepared release name, releaseId=" + releaseId );
         }
 
         return result;
     }
 
     public Boolean releasePerform( String releaseId, String goals, String arguments, boolean useReleaseProfile,
-                                   Map repository )
+                                   Map repository, String username )
         throws Exception
     {
         Boolean result;
 
         try
         {
-            slave.releasePerform( releaseId, goals, arguments, useReleaseProfile, repository );
+            slave.releasePerform( releaseId, goals, arguments, useReleaseProfile, repository, username );
             result = Boolean.FALSE;
-            log.info( "Performing release" );
+            log.info( "Performing release of releaseId=" + releaseId );
         }
         catch ( Exception e )
         {
-            log.error( "Error performing release", e );
-            throw new Exception( "Error performing release", e );
+            log.error( "Error performing release of releaseId=" + releaseId, e );
+            throw new Exception( "Error performing release of releaseId=" + releaseId, e );
         }
 
         return result;
@@ -378,7 +378,7 @@ public class SlaveBuildAgentTransportCli
 
     public String releasePerformFromScm( String goals, String arguments, boolean useReleaseProfile, Map repository,
                                          String scmUrl, String scmUsername, String scmPassword, String scmTag,
-                                         String scmTagBase, Map environments )
+                                         String scmTagBase, Map environments, String username )
         throws Exception
     {
         String result;
@@ -386,13 +386,13 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.releasePerformFromScm( goals, arguments, useReleaseProfile, repository, scmUrl, scmUsername,
-                                                  scmPassword, scmTag, scmTagBase, environments );
-            log.info( "Performing release" );
+                                                  scmPassword, scmTag, scmTagBase, environments, username );
+            log.info( "Performing release of scmUrl=" + scmUrl );
         }
         catch ( Exception e )
         {
-            log.error( "Error performing release from scm", e );
-            throw new Exception( "Error performing release from scm", e );
+            log.error( "Error performing release from scm '" + scmUrl + "'", e );
+            throw new Exception( "Error performing release from scm '" + scmUrl + "'", e );
         }
 
         return result;
@@ -406,12 +406,12 @@ public class SlaveBuildAgentTransportCli
         try
         {
             result = slave.releaseCleanup( releaseId );
-            log.info( "Cleanup release of " + releaseId );
+            log.info( "Cleanup release, releaseId=" + releaseId );
         }
         catch ( Exception e )
         {
-            log.error( "Error cleaning up release of " + releaseId, e );
-            throw new Exception( "Error cleaning up release of " + releaseId, e );
+            log.error( "Error cleaning up release, releaseId=" + releaseId, e );
+            throw new Exception( "Error cleaning up release, releaseId=" + releaseId, e );
         }
 
         return result;
@@ -426,12 +426,281 @@ public class SlaveBuildAgentTransportCli
         {
             slave.releaseRollback( releaseId, projectId );
             result = Boolean.TRUE;
-            log.info( "Rollback release " + releaseId );
+            log.info( "Rollback release. releaseId=" + releaseId + ", projectId=" + projectId );
         }
         catch ( Exception e )
         {
-            log.error( "Failed to rollback release " + releaseId );
-            throw new Exception( "Failed to rollback release " + releaseId );
+            log.error( "Failed to rollback release. releaseId=" + releaseId + ", projectId=" + projectId );
+            throw new Exception( "Failed to rollback release. releaseId=" + releaseId + ", projectId=" + projectId );
+        }
+
+        return result;
+    }
+
+    public Integer getBuildSizeOfAgent()
+        throws Exception
+    {
+        Integer size;
+
+        try
+        {
+            size = slave.getBuildSizeOfAgent();
+            log.info( "Retrieving build size of agent" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to retrieve build size of agent", e );
+            throw new Exception( "Failed to retrieve build size of agent", e );
+        }
+
+        return size;
+    }
+
+    public Map<String, Object> getProjectCurrentlyPreparingBuild()
+        throws Exception
+    {
+        Map<String, Object> projects;
+
+        try
+        {
+            projects = slave.getProjectCurrentlyPreparingBuild();
+            log.info( "Retrieving projects currently preparing build" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to retrieve projects currently preparing build", e );
+            throw new Exception( "Failed to retrieve projects currently preparing build", e );
+        }
+
+        return projects;
+    }
+
+    public List<Map<String, Object>> getProjectsAndBuildDefinitionsCurrentlyPreparingBuild()
+        throws Exception
+    {
+        List<Map<String, Object>> projects;
+
+        try
+        {
+            projects = slave.getProjectsAndBuildDefinitionsCurrentlyPreparingBuild();
+            log.info( "Retrieving projects currently preparing build" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to retrieve projects currently preparing build", e );
+            throw new Exception( "Failed to retrieve projects currently preparing build", e );
+        }
+
+        return projects;
+    }
+
+    public List<Map<String, Object>> getProjectsInBuildQueue()
+        throws Exception
+    {
+        List<Map<String, Object>> projects;
+
+        try
+        {
+            projects = slave.getProjectsInBuildQueue();
+            log.info( "Retrieving projects in build queue" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to retrieve projects in build queue", e );
+            throw new Exception( "Failed to retrieve projects in build queue", e );
+        }
+
+        return projects;
+    }
+
+    public List<Map<String, Object>> getProjectsInPrepareBuildQueue()
+        throws Exception
+    {
+        List<Map<String, Object>> projects;
+
+        try
+        {
+            projects = slave.getProjectsInPrepareBuildQueue();
+            log.info( "Retrieving projects in prepare build queue" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to retrieve projects in prepare build queue", e );
+            throw new Exception( "Failed to retrieve projects in prepare build queue", e );
+        }
+
+        return projects;
+    }
+
+    public List<Map<String, Object>> getProjectsAndBuildDefinitionsInPrepareBuildQueue()
+        throws Exception
+    {
+        List<Map<String, Object>> projects;
+
+        try
+        {
+            projects = slave.getProjectsAndBuildDefinitionsInPrepareBuildQueue();
+            log.info( "Retrieving projects in prepare build queue" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to retrieve projects in prepare build queue", e );
+            throw new Exception( "Failed to retrieve projects in prepare build queue", e );
+        }
+
+        return projects;
+    }
+
+    public Boolean isProjectGroupInQueue( int projectGroupId )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.isProjectGroupInQueue( projectGroupId );
+            log.info( "Checking if project group '" + projectGroupId + "' is in queue" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to check if project group '" + projectGroupId + "' is in queue", e );
+            throw new Exception( "Failed to check if project group '" + projectGroupId + "' is in queue", e );
+        }
+
+        return result;
+    }
+
+    public Boolean isProjectScmRootInQueue( int projectScmRootId, List<Integer> projectIds )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.isProjectScmRootInQueue( projectScmRootId, projectIds );
+            log.info( "Checking if project scm root '" + projectScmRootId + "' is in queue" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to check if project scm root '" + projectScmRootId + "' is in queue", e );
+            throw new Exception( "Failed to check if project scm root '" + projectScmRootId + "' is in queue", e );
+        }
+
+        return result;
+    }
+
+    public Boolean isProjectCurrentlyBuilding( int projectId )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.isProjectCurrentlyBuilding( projectId );
+            log.info( "Checking if project " + projectId + " is currently building in agent" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to check if project " + projectId + " is currently building in agent", e );
+            throw new Exception( "Failed to check if project " + projectId + " is currently building in agent", e );
+        }
+
+        return result;
+    }
+
+    public Boolean isProjectInBuildQueue( int projectId )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.isProjectInBuildQueue( projectId );
+            log.info( "Checking if project " + projectId + "is in build queue of agent" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to check if project " + projectId + " is in build queue of agent", e );
+            throw new Exception( "Failed to check if project " + projectId + " is in build queue of agent", e );
+        }
+
+        return result;
+    }
+
+    public Boolean removeFromPrepareBuildQueue( int projectGroupId, int scmRootId )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.removeFromPrepareBuildQueue( projectGroupId, scmRootId );
+            log.debug( "Remove projects from prepare build queue. projectGroupId=" + projectGroupId +
+            		   ", scmRootId=" + scmRootId );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to remove projects from prepare build queue. projectGroupId=" + projectGroupId +
+                       ", scmRootId=" + scmRootId );
+            throw new Exception( "Failed to remove from prepare build queue. projectGroupId=" + projectGroupId +
+                                 " scmRootId=" + scmRootId, e );
+        }
+
+        return result;
+    }
+
+    public Boolean removeFromPrepareBuildQueue( List<String> hashCodes )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.removeFromPrepareBuildQueue( hashCodes );
+            log.info( "Removing projects from prepare build queue of agent" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to remove projects from prepare build queue of agent", e );
+            throw new Exception( "Failed to remove projects from prepare build queue of agent", e );
+        }
+
+        return result;
+    }
+
+    public Boolean removeFromBuildQueue( int projectId, int buildDefinitionId )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.removeFromBuildQueue( projectId, buildDefinitionId );
+            log.info( "Removing project '" + projectId + "' from build queue of agent" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to remove project '" + projectId + "' from build queue of agent", e );
+            throw new Exception( "Failed to remove project '" + projectId + "' from build queue of agent", e );
+        }
+
+        return result;
+    }
+
+    public Boolean removeFromBuildQueue( List<String> hashCodes )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            result = slave.removeFromBuildQueue( hashCodes );
+            log.info( "Removing projects from build queue of agent" );
+        }
+        catch ( Exception e )
+        {
+            log.error( "Failed to remove projects from build queue of agent", e );
+            throw new Exception( "Failed to remove projects from build queue of agent", e );
         }
 
         return result;

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/pom.xml
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/pom.xml?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/pom.xml (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/pom.xml Thu May  6 09:23:13 2010
@@ -21,7 +21,7 @@ under the License.
   <parent>
     <groupId>org.apache.continuum</groupId>
     <artifactId>continuum-distributed-slave</artifactId>
-    <version>1.4.0-SNAPSHOT</version>
+    <version>1.4.1-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>continuum-distributed-slave-server</artifactId>

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportServer.java
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportServer.java?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportServer.java (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/continuum-distributed-slave-server/src/main/java/org/apache/continuum/distributed/transport/slave/SlaveBuildAgentTransportServer.java Thu May  6 09:23:13 2010
@@ -90,33 +90,31 @@ public class SlaveBuildAgentTransportSer
         try
         {
             buildResult = continuumBuildAgentService.getBuildResult( projectId );
-            log.info( "Build result for project " + projectId + " acquired." );
+            log.info( "Build result for project '" + projectId + "' acquired." );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to get build result for project " + projectId, e );
+            log.error( "Failed to get build result for project '" + projectId + "'", e );
             throw e;
         }
 
         return buildResult;
     }
 
-    public Integer getProjectCurrentlyBuilding()
+    public Map<String, Object> getProjectCurrentlyBuilding()
         throws Exception
     {
-        Integer projectId = continuumBuildAgentService.getProjectCurrentlyBuilding();
+        Map<String, Object> project = continuumBuildAgentService.getProjectCurrentlyBuilding();
 
-        log.info( "Currently building project " + projectId );
+        log.info( "Retrieving currently building project" );
 
-        return projectId;
+        return project;
     }
 
     public Boolean ping()
         throws Exception
     {
-        log.info( "Ping ok" );
-
-        return Boolean.TRUE;
+        return continuumBuildAgentService.ping(); 
     }
 
     public Boolean cancelBuild()
@@ -144,12 +142,12 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
-            return continuumBuildAgentService.generateWorkingCopyContent( projectId, directory, baseUrl,
-                                                                          imagesBaseUrl );
+            log.info( "Generate working copy content for project '" + projectId + "'" );
+            return continuumBuildAgentService.generateWorkingCopyContent( projectId, directory, baseUrl, imagesBaseUrl );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to generate working copy content", e );
+            log.error( "Failed to generate working copy content for projectId=" + projectId, e );
             throw e;
         }
     }
@@ -159,11 +157,12 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Retrieve project '" + projectId + "' file content" );
             return continuumBuildAgentService.getProjectFileContent( projectId, directory, filename );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to retrieve project file content", e );
+            log.error( "Failed to retrieve project '" + projectId + "' file content", e );
             throw e;
         }
     }
@@ -173,11 +172,12 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Retrieving release plugin parameters for project '" + projectId + "'" );
             return continuumBuildAgentService.getReleasePluginParameters( projectId, pomFilename );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to retrieve release plugin parameters", e );
+            log.error( "Failed to retrieve release plugin parameters for project '" + projectId + "'", e );
             throw e;
         }
     }
@@ -187,23 +187,25 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Processing project '" + projectId + "'" );
             return continuumBuildAgentService.processProject( projectId, pomFilename, autoVersionSubmodules );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to process project", e );
+            log.error( "Failed to process project '" + projectId + "'", e );
             throw e;
         }
     }
 
     public String releasePrepare( Map project, Map properties, Map releaseVersion, Map developmentVersion,
-                                  Map environments )
+                                  Map environments, String username )
         throws Exception
     {
         try
         {
+            log.info( "Preparing release" );
             return continuumBuildAgentService.releasePrepare( project, properties, releaseVersion, developmentVersion,
-                                                              environments );
+                                                              environments, username );
         }
         catch ( ContinuumBuildAgentException e )
         {
@@ -217,11 +219,12 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Retrieving listener for releaseId=" + releaseId );
             return continuumBuildAgentService.getListener( releaseId );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to retrieve listener state of " + releaseId, e );
+            log.error( "Failed to retrieve listener state of releaseId=" + releaseId, e );
             throw e;
         }
     }
@@ -231,11 +234,12 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Retrieving release result, releaseId=" + releaseId );
             return continuumBuildAgentService.getReleaseResult( releaseId );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to retrieve release result of " + releaseId, e );
+            log.error( "Failed to retrieve release result of releaseId=" + releaseId, e );
             throw e;
         }
     }
@@ -249,10 +253,11 @@ public class SlaveBuildAgentTransportSer
         {
             continuumBuildAgentService.removeListener( releaseId );
             result = Boolean.TRUE;
+            log.info( "Removing listener for releaseId=" + releaseId );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to remove listener of " + releaseId, e );
+            log.error( "Failed to remove listener of releaseId=" + releaseId, e );
             throw e;
         }
 
@@ -264,29 +269,31 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Retrieving prepared release name, releaseId=" + releaseId );
             return continuumBuildAgentService.getPreparedReleaseName( releaseId );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to retrieve prepared release name of " + releaseId );
+            log.error( "Failed to retrieve prepared release name of releaseId=" + releaseId );
             throw e;
         }
     }
 
     public Boolean releasePerform( String releaseId, String goals, String arguments, boolean useReleaseProfile,
-                                   Map repository )
+                                   Map repository, String username )
         throws Exception
     {
         Boolean result;
 
         try
         {
-            continuumBuildAgentService.releasePerform( releaseId, goals, arguments, useReleaseProfile, repository );
+            continuumBuildAgentService.releasePerform( releaseId, goals, arguments, useReleaseProfile, repository, username );
             result = Boolean.TRUE;
+            log.info( "Perform release of releaseId=" + releaseId );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Unable to perform release", e );
+            log.error( "Unable to perform release of releaseId=" + releaseId, e );
             throw e;
         }
 
@@ -295,18 +302,19 @@ public class SlaveBuildAgentTransportSer
 
     public String releasePerformFromScm( String goals, String arguments, boolean useReleaseProfile, Map repository,
                                          String scmUrl, String scmUsername, String scmPassword, String scmTag,
-                                         String scmTagBase, Map environments )
+                                         String scmTagBase, Map environments, String username )
         throws Exception
     {
         try
         {
+            log.info( "Perform release of scmUrl=" + scmUrl );
             return continuumBuildAgentService.releasePerformFromScm( goals, arguments, useReleaseProfile, repository,
                                                                      scmUrl, scmUsername, scmPassword, scmTag,
-                                                                     scmTagBase, environments );
+                                                                     scmTagBase, environments, username );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Unable to perform release", e );
+            log.error( "Unable to perform release of scmUrl=" + scmUrl, e );
             throw e;
         }
     }
@@ -316,11 +324,12 @@ public class SlaveBuildAgentTransportSer
     {
         try
         {
+            log.info( "Cleanup release, releaseId=" + releaseId );
             return continuumBuildAgentService.releaseCleanup( releaseId );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Unable to cleanup release of " + releaseId, e );
+            log.error( "Unable to cleanup release, releaseId=" + releaseId, e );
             throw e;
         }
     }
@@ -334,10 +343,198 @@ public class SlaveBuildAgentTransportSer
         {
             continuumBuildAgentService.releaseRollback( releaseId, projectId );
             result = Boolean.TRUE;
+            log.info( "Rollback release. releaseId=" + releaseId + ", projectId=" + projectId );
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to rollback release. releaseId=" + releaseId + ", projectId=" + projectId, e );
+            throw e;
+        }
+
+        return result;
+    }
+
+    public Integer getBuildSizeOfAgent()
+        throws Exception
+    {
+        try
+        {
+            return continuumBuildAgentService.getBuildSizeOfAgent();
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to retrieve build size of agent", e );
+            throw e;
+        }
+    }
+
+    public Map<String, Object> getProjectCurrentlyPreparingBuild()
+        throws Exception
+    {
+        try
+        {
+            return continuumBuildAgentService.getProjectCurrentlyPreparingBuild();
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to retrieve projects currently preparing build", e );
+            throw e;
+        }
+    }
+
+    public List<Map<String, Object>> getProjectsAndBuildDefinitionsCurrentlyPreparingBuild()
+        throws Exception
+    {
+        try
+        {
+            return continuumBuildAgentService.getProjectsAndBuildDefinitionsCurrentlyPreparingBuild();
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to retrieve projects currently preparing build", e );
+            throw e;
+        }
+    }
+
+    public List<Map<String, Object>> getProjectsInBuildQueue()
+        throws Exception
+    {
+        try
+        {
+            log.info( "Retrieving projects in build queue" );
+            return continuumBuildAgentService.getProjectsInBuildQueue();
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to retrieve projects in build queue", e );
+            throw e;
+        }
+    }
+
+    public List<Map<String, Object>> getProjectsInPrepareBuildQueue()
+        throws Exception
+    {
+        try
+        {
+            log.info( "Retrieving projects in prepare build queue" );
+            return continuumBuildAgentService.getProjectsInPrepareBuildQueue();
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to retrieve projects in prepare build queue", e );
+            throw e;
+        }
+    }
+
+    public List<Map<String, Object>> getProjectsAndBuildDefinitionsInPrepareBuildQueue()
+        throws Exception
+    {
+        try
+        {
+            log.info( "Retrieving projects in prepare build queue" );
+            return continuumBuildAgentService.getProjectsAndBuildDefinitionsInPrepareBuildQueue();
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to retrieve projects in prepare build queue", e );
+            throw e;
+        }
+    }
+
+    public Boolean isProjectGroupInQueue( int projectGroupId )
+        throws Exception
+    {
+        log.info( "Checking if project group '" + projectGroupId + "' is in queue" );
+        return continuumBuildAgentService.isProjectGroupInQueue( projectGroupId );
+    }
+
+    public Boolean isProjectScmRootInQueue( int projectScmRootId, List<Integer> projectIds )
+        throws Exception
+    {
+        log.info( "Checking if project scm root '" + projectScmRootId + "' is in queue" );
+        return continuumBuildAgentService.isProjectScmRootInQueue( projectScmRootId, projectIds );
+    }
+
+    public Boolean isProjectCurrentlyBuilding( int projectId )
+        throws Exception
+    {
+        log.info( "Checking if project " + projectId + " is currently building in agent" );
+        return continuumBuildAgentService.isProjectCurrentlyBuilding( projectId );
+    }
+
+    public Boolean isProjectInBuildQueue( int projectId )
+        throws Exception
+    {
+        log.info( "Checking if project " + projectId + "is in build queue of agent" );
+        return continuumBuildAgentService.isProjectInBuildQueue( projectId );
+    }
+
+    public Boolean removeFromPrepareBuildQueue( int projectGroupId, int scmRootId )
+        throws Exception
+    {
+        try
+        {
+            log.info( "Remove projects from prepare build queue. projectGroupId=" + projectGroupId +
+                      ", scmRootId=" + scmRootId );
+            return continuumBuildAgentService.removeFromPrepareBuildQueue( projectGroupId, scmRootId );
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to remove projects from prepare build queue. projectGroupId=" + projectGroupId +
+                       ", scmRootId=" + scmRootId );
+            throw e;
+        }
+    }
+
+    public Boolean removeFromPrepareBuildQueue( List<String> hashCodes )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            continuumBuildAgentService.removeFromPrepareBuildQueue( hashCodes );
+            result = Boolean.TRUE;
+            log.info( "Remove projects from prepare build queue" );
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to remove projects from prepare build queue" );
+            throw e;
+        }
+
+        return result;
+    }
+
+    public Boolean removeFromBuildQueue( int projectId, int buildDefinitionId )
+        throws Exception
+    {
+        try
+        {
+            log.debug( "Remove project '" + projectId + "' from build queue" );
+            return continuumBuildAgentService.removeFromBuildQueue( projectId, buildDefinitionId );
+        }
+        catch ( ContinuumBuildAgentException e )
+        {
+            log.error( "Failed to remove project '" + projectId + "' from build queue" );
+            throw e;
+        }
+    }
+
+    public Boolean removeFromBuildQueue( List<String> hashCodes )
+        throws Exception
+    {
+        Boolean result;
+
+        try
+        {
+            continuumBuildAgentService.removeFromBuildQueue( hashCodes );
+            result = Boolean.TRUE;
+            log.info( "Remove projects from build queue" );
         }
         catch ( ContinuumBuildAgentException e )
         {
-            log.error( "Failed to rollback release " + releaseId, e );
+            log.error( "Failed to remove projects from build queue" );
             throw e;
         }
 

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/pom.xml
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/pom.xml?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/pom.xml (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/continuum-distributed-slave/pom.xml Thu May  6 09:23:13 2010
@@ -20,7 +20,7 @@ under the License.
   <parent>
     <artifactId>continuum-distributed</artifactId>
     <groupId>org.apache.continuum</groupId>
-    <version>1.4.0-SNAPSHOT</version>
+    <version>1.4.1-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>continuum-distributed-slave</artifactId>

Modified: continuum/branches/continuum-flat-multi-module/continuum-distributed/pom.xml
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-distributed/pom.xml?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-distributed/pom.xml (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-distributed/pom.xml Thu May  6 09:23:13 2010
@@ -21,7 +21,7 @@ under the License.
   <parent>
     <groupId>org.apache.continuum</groupId>
     <artifactId>continuum</artifactId>
-    <version>1.4.0-SNAPSHOT</version>
+    <version>1.4.1-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>continuum-distributed</artifactId>
@@ -30,6 +30,7 @@ under the License.
   <modules>
     <module>continuum-distributed-master</module>
     <module>continuum-distributed-slave</module>
+    <module>continuum-distributed-commons</module>
     <!-- <module>continuum-distributed-tests</module> -->
   </modules>
 </project>

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/
------------------------------------------------------------------------------
--- svn:mergeinfo (added)
+++ svn:mergeinfo Thu May  6 09:23:13 2010
@@ -0,0 +1,4 @@
+/continuum/branches/continuum-1.2.x/continuum-docs:690684,690689-690799,698449-698533,698817-698819,699529,700250,700273,700936,705894,705910,708339,722279,722624,723119,723487,724016,724024,725845,726103,726239,726462
+/continuum/branches/continuum-1.3.x/continuum-docs:760767-900271,904130,915354,915760,915848-915864,916073-916074
+/continuum/branches/continuum-distributed-builds/continuum-docs:713270-734307
+/continuum/tags/continuum-1.2.3/continuum-docs:733253

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/pom.xml
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/pom.xml?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/pom.xml (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/pom.xml Thu May  6 09:23:13 2010
@@ -22,7 +22,7 @@
   <parent>
     <groupId>org.apache.continuum</groupId>
     <artifactId>continuum</artifactId>
-    <version>1.4.0-SNAPSHOT</version>
+    <version>1.4.1-SNAPSHOT</version>
   </parent>
   <artifactId>continuum-docs</artifactId>
   <name>Continuum :: Documentation</name>
@@ -31,7 +31,7 @@
   <distributionManagement>
     <site>
       <id>apache</id>
-      <url>scpexe://people.apache.org/www/continuum.apache.org/docs/${project.version}</url>
+      <url>scp://people.apache.org/www/continuum.apache.org/docs/${project.version}</url>
     </site>
   </distributionManagement>
   <build>
@@ -44,6 +44,21 @@
           <template>continuum-site.vm</template>
         </configuration>
       </plugin>
+      <plugin>
+        <artifactId>maven-pdf-plugin</artifactId>
+        <executions>
+          <execution>
+            <id>site-pdf</id>
+            <phase>site</phase>
+            <goals>
+              <goal>pdf</goal>
+            </goals>
+            <configuration>
+              <outputDirectory>${project.reporting.outputDirectory}</outputDirectory>
+            </configuration>
+          </execution>
+        </executions>
+      </plugin>
     </plugins>
   </build>
   <reporting>
@@ -73,28 +88,4 @@
       </plugin>
     </plugins>
   </reporting>
-  <profiles>
-    <profile>
-      <id>pdf</id>
-      <build>
-          <plugins>
-            <plugin>
-              <artifactId>maven-pdf-plugin</artifactId>
-              <executions>
-                <execution>
-                  <id>site-pdf</id>
-                  <phase>site</phase>
-                  <goals>
-                    <goal>pdf</goal>
-                  </goals>
-                  <configuration>
-                    <outputDirectory>${project.reporting.outputDirectory}</outputDirectory>
-                  </configuration>
-                </execution>
-              </executions>
-            </plugin>
-          </plugins>
-        </build>
-    </profile>
-  </profiles>
 </project>

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/pom.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/
            ('svn:mergeinfo' removed)

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/appearance.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/appearance.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/appearance.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/appearance.apt Thu May  6 09:23:13 2010
@@ -3,18 +3,18 @@
  ------
  Olivier Lamy
  ------
- Nov 13 2007
+ 2010-02-22
  ------
- 
+
 Configure Appearance
- 
+
 ~~%{toc|section=0}
- 
+
 * {Banner}
 
   You can configure the right logo of the banner including title and link on the image.
-  You have to add some information in a pom (like a company pom) (coming from org.apache:apache in this example) :
-  
+  You have to add some information in a POM (like a company POM) (coming from org.apache:apache in this example):
+
 +----------------------------+
   <organization>
     <name>The Apache Software Foundation</name>
@@ -23,31 +23,31 @@ Configure Appearance
   <properties>
     <organization.logo>http://www.apache.org/images/asf_logo_wide.gif</organization.logo>
   </properties>
-+----------------------------+  
++----------------------------+
+
+  From the menu, choose the <<Appearance>> entry :
 
-  From the menu, choose the 'Appearance' entry :
-  
 [../images/configure-appearance.png] Appearance
 
-  Use the 'Select a Company POM' link :
-  
-[../images/select-company-pom.png] 'Select a Company POM'   
-
-  The result will be displayed (using org.apache:apache in this example) :
-  
-[../images/selected-company-pom.png] 'Selected a Company POM'  
+  Use the <<Select a Company POM>> link :
+
+[../images/select-company-pom.png] 'Select a Company POM'
+
+  The result will be displayed (using org.apache:apache in this example):
+
+[../images/selected-company-pom.png] 'Selected a Company POM'
+
+  <<Note:>> the POM is searched for in the central repository and in the repositories available for the active profiles from your <<<${user.home}/.m2/settings.xml>>>.
 
-  Note : the pom is searched in central repository and the repositories available for the active profiles from your <<<${user.home}/.m2/settings.xml>>> 
- 
 * {Footer}
- 
-  You can configure the footer by putting your own html content in the 'Appearance' entry of the menu.
- 
+
+  You can configure the footer by putting your own html content in the <<Appearance>> entry of the menu.
+
 [../images/configuration-footer.png] 'Configure footer'
 
   The default value is :
-    
+
++----------------------------+
+<div class="xright">Copyright &copy; 2005-${currentYear}&nbsp;The Apache Software Foundation</div> <div class="clear"><hr/></div>
 +----------------------------+
-<div class="xright">Copyright &copy; 2005-${currentYear}&nbsp;The Apache Software Foundation</div> <div class="clear"><hr/></div> 
-+----------------------------+      
- 
+

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agent-groups.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agent-groups.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agent-groups.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agent-groups.apt Thu May  6 09:23:13 2010
@@ -23,3 +23,7 @@ Managing Build Agent Groups
 [../images/build-agent-groups-edit.png] Add/Edit Build Agent Group
 
   Build Agent can be associated to one or more Build Agent Group
+
+  To use a Build Agent Group in a Project, you need to attach it to a build environment.
+
+  Refer to {{{./buildEnvironment.html}Attach Build Agent Group to a Build Environment}}

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agent-groups.apt
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agents.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agents.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agents.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agents.apt Thu May  6 09:23:13 2010
@@ -4,11 +4,11 @@
 
 Managing Build Agents
 
-  Before this, you may want to enable the Distributed Builds option in the {{{configuration.html}General Configuration}}
-  and {{{../installation/build-agent.html}install a Build Agent}}, or read about the {{{distributed-builds.html}Distributed
+  Before this, you may want to enable the Distributed Builds option in the {{{./configuration.html}General Configuration}}
+  and {{{../installation/build-agent.html}install a Build Agent}}, or read about the {{{./distributed-builds.html}Distributed
   Builds}} feature.
 
-  From the menu, choose the 'Build Agents' item
+  From the menu, choose the <<Build Agents>> item
 
 [../images/build-agents-menu.png] Build Agents Menu
 
@@ -16,15 +16,18 @@ Managing Build Agents
 
 [../images/build-agents.png] Build Agents List
 
-  To add a new Build Agent, click the 'Add' button
+  To add a new Build Agent, click the <<Add>> button.
+  You will be prompted to enter the Build Agent URL and Description.
 
-  To edit an existing Build Agent, click the 'edit' link to the right of the entry.
 
-  You will be prompted to enter or edit the Build Agent URL and Description:
+  To edit an existing Build Agent, click the <<Edit>> link to the right of the entry.
+  You will be prompted to edit the Build Agent Description.
+
+  <<Note:>> Once a Build Agent has been saved you can not change its URL.
 
 [../images/build-agent-edit.png] Add/Edit Build Agent
 
-  Be sure to enable the agent by checking the 'Enabled' checkbox.
+  Be sure to enable the agent by checking the <<Enabled>> checkbox.
 
-  After you save your changes, verify that 'Enabled' is true.  If it is false, most likely Continuum was unable to ping
+  After you save your changes, verify that the <<Enabled>> checkbox is checked.  If it is not checked, most likely Continuum was unable to ping
   the agent.  Consult the log file for additional information.

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/build-agents.apt
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/distributed-builds.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/distributed-builds.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/distributed-builds.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/distributed-builds.apt Thu May  6 09:23:13 2010
@@ -1,6 +1,9 @@
  ------------------
  Distributed Builds
  ------------------
+ ------------------
+ 2010-02-22
+ ------------------
 
 Understanding Distributed Builds
 
@@ -25,19 +28,17 @@ Understanding Distributed Builds
     listens for any build requests from the Master it is
     assigned to.
 
-    There is a one-to-many relationship between the Master and the Slaves.
+    There is a one-to-many relationship between the Master and the Build Agents.
     A Master may have many Build Agents, but each Build Agent can only have one Master.
 
-    TODO: insert image here
+~~TODO: insert image here
 
 * Behavior
 
     Distributed Builds happen at the project group level of Continuum.
     When the entire project group is built in the Master, independent projects
-    (single project or multi-module project) are distributed to any available
-    registered Slave.  A Slave is said to be available when it is currently not
-    building anything as it can only attend to a single build request from the
-    Master.
+    (single project or multi-module project) are distributed to a single
+    registered Build Agent.
 
     In a project group containing a mix of projects, the distribution of work
     goes through the following steps:
@@ -47,20 +48,24 @@ Understanding Distributed Builds
     [[2]] Every independent project within the project group is identified,
     whether as a single project or a multi-module project.  Projects with
     inter-dependencies cannot be distributed separately, so multi-module
-    projects are delegated to a Slave as one build.
+    projects are delegated to a Build Agent as one build.
 
     [[3]] For each independent project, the Master iterates over the list of
-    registered Slaves and queries each if available.  The query is an XML-RPC
-    <<<ping()>>> followed by an <<<isAvailable()>>> invocation.
+    registered Build Agents and queries each if available.  The query is an XML-RPC
+    <<<ping()>>> followed by a <<<getBuildSizeOfAgent()>>> invocation.
 
-    [[4]] If a Build Agent is available, the Master collects the information
-    necessary for the build (SCM url, project id, etc.) and passes it when
-    invoking <<<buildProjects()>>>.
+    [[4]] If there is a Build Agent available, the Master collects the information
+    necessary for the build (SCM URL, project id, etc.) and passes it when
+    invoking <<<buildProjects()>>> to the Build Agent with the smallest number of
+    tasks in its queue. The Master also passes the <<<name>>> of the local repository
+    of the project's project group. Make sure that a local repository with the same <<<name>>>
+    is configured in the Build Agent's configuration file since that is what will be 
+    used when the project is built in the build agent. Otherwise, it will use the 
+    local repository set in the build agent's <<<settings.xml>>> file.
 
     [[5]] In the Build Agent, the build request is processed: the build is queued and
-    executed.  Upon execution, the Build Agent first performs an SCM checkout then
-    the actual build follows.  The SCM checkout will result in invoking a
-    <<<returnScmResult()>>> callback method in the Master.
+    executed.  Upon execution, the Build Agent first performs an SCM checkout or an SCM
+    update followed by an SCM changelog to get the latest update date, then the actual build follows.
 
     [[6]] At this point, when the build is running, the Master can invoke
     <<<cancelBuild()>>> which returns a transient build result, and
@@ -68,51 +73,61 @@ Understanding Distributed Builds
 
     [[7]] After the build, the Build Agent returns the complete build result to the
     Master by invoking the callback method <<<returnBuildResult()>>>, which the
-    Master aggregates to provide a unified view of projects
+    Master aggregates to provide a unified view of projects.
 
-    TODO: insert sequence diagram here
+    A <<<ping()>>> is always called before each XML-RPC invocation to check if 
+    the agent is available. If it's not, the agent will be disabled.
+
+~~TODO: insert sequence diagram here
 
 * Setup
 
-    * {{{../installation/build-agent.html}Install and Configure}} one or more Build Agents, then
+    * {{{../installation/build-agent.html}Install and Configure}} one or more Build Agents.
+
+    * {{{./configuration.html}Enable}} the Distributed Builds option in the General Configuration.
+
+    * {{{./build-agents.html}Add}} your Build Agents to the Continuum Master.
+
+    * {{{./build-agent-groups.html}Add}} your Build Agents to a Build Agent Group.
+
+    * {{{./buildEnvironment.html} Add}} your Build Agent Group to a Build Environment.
 
-    * {{{configuration.html}Enable}} the Distributed Builds option in the General Configuration, and 
+    * Configure a project to use that Build Environment.
 
-    * {{{build-agents.html}Add}} your Build Agents to the Continuum Master.
-  
-    * {{{build-agent-groups.html}Add}} your Build Agents to a Build Agent Group.
+    * Make sure that the {{{./localRepository.html} local repository}} of the {{{./projectgroup.html} project group}} is properly configured.
+    In this case, it should point to the path of the repository where the Build Agent is installed/running.
 
-    * {{{profiles.html} Add}} your Build Agent Group to Build Environment.
+    []
 
-    <<WARNING>> Need to have a central remote repository to store the artifacts created from the build agent so that other agents will be able to use the new artifacts.
+    <<Warning:>> You need to have a central remote repository to store the artifacts created from the Build Agent so that other agents will be able to use the new artifacts.
 
 * Limitations
 
-    * only system administrator can enable/disable distributed builds
+    * Only system administrator can enable/disable distributed builds
 
-    * releases are not supported
+    * Credentials (i.e. svn credentials) are passed along if specified, but if server cache is used it will need to be done individually on the Build Agents
 
-    * credentials (s.a. svn credentials) are passed along if specified, but if server cache is used it will need to be done individually on the slaves
+    * There is no tracking of SCM changes
 
-    * there is no tracking of scm changes
+    * The Build Agent needs a configuration web interface
 
-    * the Build Agent needs a configuration web interface
+    * All projects in a project group will be distributed to the same Build Agent
 
 * Future Enhancements
 
     * Remote builders
 
-        * Builders can be installed on remote machines, a Continuum manager will send actions to run to builders. An action can be something to run on all builders, on some of them or eventually only to an available builder if we don't want to run more than one build. Actions can be sent with JMS and builders can apply some filters if they don't want to receive all actions. With that, we can do some parallel builds but the dependency tree must be respected for the build order. To work correctly with dependencies, each builders must use a central local repository. Maybe we can use an internal Archiva.
+        * Builders can be installed on remote machines, a Continuum manager will send actions to run to builders. An action can be something to run on all builders, on some of them or eventually only to an available builder if we don't want to run more than one build. Actions can be sent with JMS and builders can apply some filters if they don't want to receive all actions. With that, we can do some parallel builds but the dependency tree must be respected for the build order. To work correctly with dependencies, each builder must use a central local repository. Maybe we can use an internal Archiva.
 
-        * With Continuum builders configured to receive all commands, users can run multi-platform build for each build definition execution
+        * With Continuum builders configured to receive all commands, users can run multi-platform build for each build definition execution.
 
-        * With Continuum builders configured to receive only some project types, users can use a different builder by project group. In this case, the build of all projects will be done quickly because commands are balanced on few servers
+        * With Continuum builders configured to receive only some project types, users can use a different builder by project group. In this case, the build of all projects will be done quickly because commands are balanced on several servers.
 
-        * With Continuum builders configured to build something when it is available, users can install few builders on several machine to balance the charge. In this case, it will be possible to run some parallel builds.
+        * With Continuum builders configured to build something when it is available, users can install builders on several machine to balance the charge. In this case, it will be possible to run some parallel builds.
 
-        * When the builder work will be done, a message will be sent to the manager to notify the end of the process.
+        * When the builders work is done, a message will be sent to the manager to notify the end of the process.
 
-        * With JMS used for the communication, we can add some listeners to create reports/statistics, log some informations
+        * With JMS used for the communication, we can add some listeners to create reports/statistics, log some information.
 
     * Policy-based distribution
 

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/distributed-builds.apt
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/external-db.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/external-db.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/external-db.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/external-db.apt Thu May  6 09:23:13 2010
@@ -29,3 +29,10 @@ How to use an external database?
 ** Webapp
 
     To use an external database with the Continuum webapp, you should configure the DataSource in your container.
+
+* Shutdown Procedure
+
+   When using an external database, it is very important to stop Continuum prior to stopping or restarting the database.
+   Continuum may exhibit unpredictable behavior if the database disappears while it is running, and may not recover
+   once the database comes back up.  If this happens, you must re-start Continuum.  If you experience errors after
+   re-starting, the data may be corrupted and may need to be fixed by editing records directly in the database.
\ No newline at end of file

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/index.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/index.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/index.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/index.apt Thu May  6 09:23:13 2010
@@ -3,43 +3,49 @@
  ------
  Emmanuel Venisse
  ------
- Oct 3 2007
+ 2010-02-18
  ------
 
 Administrator's Guides
 
- * {{{security/index.html}Managing Users and Security}}
+ * {{{./security/index.html}Managing Users and Security}}
 
- * {{{projectgroup.html}Adding a Project Group}}
+ * {{{./projectgroup.html}Managing Project Groups}}
 
- * {{{builder.html}Managing Builders}}
+ * {{{./builder.html}Managing Builders}}
 
- * {{{jdk.html}Managing JDKs}}
+ * {{{./jdk.html}Managing JDKs}}
 
- * {{{profiles.html}Managing Build Environments}}
+ * {{{./buildEnvironment.html}Managing Build Environments}}
 
- * {{{build-agents.html}Managing Build Agents}}
+ * {{{./build-agents.html}Managing Build Agents}}
 
- * {{{build-agent-groups.html}Managing Build Agent Groups}}
+ * {{{./build-agent-groups.html}Managing Build Agent Groups}}
 
- * {{{schedules.html}Managing Schedules}}
+ * {{{./schedules.html}Managing Schedules}}
 
- * {{{configuration.html}Managing General Configuration}}
+ * {{{./configuration.html}Managing General Configuration}}
 
- * {{{localRepository.html}Managing Local Repositories}}
+ * {{{./localRepository.html}Managing Local Repositories}}
 
- * {{{purgeConfiguration.html}Managing Purge Configuration}}
+ * {{{./purgeConfiguration.html}Managing Purge Configuration}}
 
- * {{{parallelBuilds.html}Managing Parallel Builds}}
+ * {{{./parallelBuilds.html}Managing Parallel Builds}}
 
- * {{{external-db.html}External Databases}}
+ * {{{./buildQueue.html}Managing Build Queues}}
 
- * {{{monitoring.html}Monitoring Continuum}}
+ * {{{./queues.html}Managing Project Queues}}
 
- * {{{appearance.html}Appearance Configuration}}
+ * {{{./external-db.html}External Databases}}
 
- * {{{builddefTemplate.html}Build Definition Templates}}
+ * {{{./monitoring.html}Monitoring Continuum}}
 
- * {{{shutdown.html}Shutting Down Continuum}}
+ * {{{./logging.html} Log Files}}
 
- * {{{distributed-builds.html}Understanding Distributed Builds}}
+ * {{{./appearance.html}Appearance Configuration}}
+
+ * {{{./builddefTemplate.html}Build Definition Templates}}
+
+ * {{{./shutdown.html}Shutting Down Continuum}}
+
+ * {{{./distributed-builds.html}Understanding Distributed Builds}}

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/localRepository.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/localRepository.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/localRepository.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/localRepository.apt Thu May  6 09:23:13 2010
@@ -1,39 +1,49 @@
  ------
  Local Repository
  ------
- 
+ ------
+ 2010-02-18
+ ------
+
 Local Repository
 
+  Local repositories can be configured for a specific project group's use.
+  This is where the artifacts used for building the projects can be found
+  instead of the default (<<<$USER_HOME/.m2/repository>>>).
+
 	Click the <<Local Repositories>> link under the <<Administration>> section
 
 [../images/localrepositories.png] Local Repositories
 
 	You will see all the local repositories that have been created.
-	
+
 	To display:
-	
+
 [../images/localrepositories-view.png]
-	
-	In this screen you can add/edit/delete/purge a local repository. 
-	
-	You can purge a repository if it has a default {{{purgeConfiguration.html} Purge Configuration}}, otherwise the purge icon is disabled.
+
+	In this screen you can add/edit/delete/purge a local repository.
+
+	You can purge a repository if it has a default {{{./purgeConfiguration.html} Purge Configuration}}, otherwise the purge icon is disabled.
 
 [../images/disabled_purgenow.gif] disabled purge icon
 
 
 * Adding / Editing a Local Repository
 
-	All fields are mandatory. 
-	
+	All fields are mandatory.
+
 	* Name: must be a unique repository name.
-	
+
 	* Location: must be the absolute path of a unique repository location.
-	
+
 	* Layout: "default" or "legacy". Default layout is for maven2, while legacy layout is for maven1.
 
 [../images/localrepository-add.png]
+
+	Adding a local repository will automatically create a default {{{./purgeConfiguration.html} Purge Configuration}} for that repository.
 	
-	Adding a local repository will automatically create a default {{{purgeConfiguration.html} Purge Configuration}} for that repository.
+	If you're using distributed builds, you must configure a <<<localRepository>>> with the same <<<name>>> in the build agent's configuration file where the
+	<<<location>>> is the local path to the local repository in the build agent machine. See {{{./distributed-builds.html}Distributed Builds}} for more details.
 
 * Default
 

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/localRepository.apt
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/parallelBuilds.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/parallelBuilds.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/parallelBuilds.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/parallelBuilds.apt Thu May  6 09:23:13 2010
@@ -1,7 +1,10 @@
  ------
  Parallel Build Queue
  ------
- 
+ ------
+ 2010-02-18
+ ------
+
 Managing Parallel Builds
 
     Since 1.3.1, Continuum can be configured to checkout and build projects in parallel or concurrently.
@@ -9,51 +12,26 @@ Managing Parallel Builds
 * Configuring Parallel Builds
 
     The number of build queues to be used when checking out or building projects can be configured in the Configuration page, via
-    the Number of Allowed Builds in Parallel field (see {{{configuration.html} Managing General Configuration}}).
+    the Number of Allowed Builds in Parallel field (see {{{./configuration.html} Managing General Configuration}}).
     The value should be greater than one (1) to be able to create a build queue aside from the default.
 
     Another thing to note is that if Distributed Builds is enabled, Parallel Builds is automatically disabled. To make it
     short, you're only allowed to use one of these functionalities at a time in the current implementation.
 
-* Adding a Build Queue
-
-    By default, there is already a DEFAULT_BUILD_QUEUE that cannot be deleted configured in Continuum. To add more build queues..
-
-    Click the <<Build Queue>> link under the <<Administration>> section.
-
-[../images/buildQueue.png] Build Queue
-
-    You will see all the build queues.
-
-[../images/listBuildQueue.png] Build Queues list
+    To configure parallel builds:
 
-    Here you can add/delete the build queue. Take note that you would only be allowed to create N number of build queues, where
-    N = the Number of Allowed Builds in Parallel set in the Configuration page.
+    [[1]] Create a build queue to be used for the projects.
+          Refer to {{{./buildQueue.html} Managing Build Queues}}
 
-    Input the name for the build queue and save.           
+    [[2]] Attach the build queue(s) to a build schedule.
+          Refer to {{{./schedules.html} Attaching Build Queue to a Schedule}}
 
-[../images/addBuildQueue.png] Add Parallel Build Queue
+    [[3]] Create or edit the project's build definition to use the build schedule configured with the build queue(s).
+          Refer to {{{../user_guides/managing_builddef/index.html} Managing Build Definitions}}
 
-* Attaching Build Queues to a Schedule
+    []
 
-    Build queues can be attached to a schedule. When a build is triggered, Continuum gets the build queues attached to the build
-    definition's associated schedule. The project build will then be queued to the build queue with the least number of tasks.
-
-    To attach build queues to a schedule:
-
-    [[1]] Click the <<Schedules>> link under the <<Administration>> section. From the schedules list page, create a new schedule
-    or edit an existing one.
-
-    [[2]] In the Add Build Queue field, move build queues from the left hand list box to the right hand list box by clicking the appropriate
-    buttons in between the two list boxes. All build queues on the right hand list box will be attached to the schedule when you click Save.
-
-[../images/editSchedule.png] Edit Schedule
-
-* Viewing Checkouts and Builds in Queues
-
-    Current checkouts and builds, and all other projects queued in the checkout and build queues can be viewed in the <<Queues>> page.
-    These executing and queued tasks can also be cancelled by clicking the corresponding Cancel icons for each task. Multiple-cancel is
-    also supported.
+    A screen similar to the following is displayed under the <<Queues>> page when the project is built (force/sheduled).
 
 [../images/parallelBuildsQueues.png] Queues
 
@@ -65,3 +43,5 @@ Managing Parallel Builds
 
     [[2]] Concurrent build of inter-dependent projects in a group is not yet supported.
 
+    [[3]] All projects in a project group will be enqueued to the same {{{./buildQueue.html} Build Queue}}.
+

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/parallelBuilds.apt
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/projectgroup.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/projectgroup.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/projectgroup.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/projectgroup.apt Thu May  6 09:23:13 2010
@@ -1,26 +1,71 @@
  ------
- Adding Project Group
+ Managing Project Groups
  ------
  Olivier Lamy
  ------
- Oct 11 2007
+ 2010-02-18
  ------
 
-Adding Project Group
+Managing Project Groups
+
+[../images/project-groups.png] Group Summary homepage
+
+* Adding a Project Group
+
+  From the home page (Group Summary) Use the the <<<Add Project Group>>> button
 
-  From the home page (Group Summary) Use the the 'Add Project Group' button
-  
 [../images/add-project-group.png] Add Project Group
 
-  Then You will have the project Group detail. 
-    
+  Then You will have the project Group detail.
+
 [../images/add-project-group-detail.png] Edit Project Group detail
 
   Some fields are mandatory :
-    
+
   * Project Group Name
-    
+
   * Project Group Id
 
- 
-  
+  []
+
+* Editing a Project Group
+
+  From the home page (Group Summary), click the project group name link.
+
+  The project group information will then be displayed.
+
+[../images/project-group-summary.png] Project Group Summary
+
+  Then, click on the <<<Edit>>> button.
+
+[../images/update-project-group.png] Update Project Group
+
+  The following fields can be updated:
+
+  * <<Project Group Name>>: The name of the project group.
+
+  * <<Description>>: A brief description about the group.
+
+  * {{{./localRepository.html} <<Local Repository>>}}: The specific repository used for the project
+  which points to the exact location of the repository in the machine used for building.
+
+  * <<Homepage Url>>: The site of the project.
+
+  []
+
+  And, projects can be moved to another project group.
+
+* Deleting a Project Group
+
+  There are two ways to delete a project group.
+
+  From the home page (Group Summary), click the Delete icon to the right of the group you wish to delete.
+
+  From the Project Group Summary page, click the <<<Delete Group>>> button.
+
+  Confirm the deletion
+
+  Note that user roles for this project group will not be removed.  This is intentional so that if you are
+  sharing a user database among several Continuum instances, users will still be able to access the same
+  group on a different server.
+

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/purgeConfiguration.apt
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/queues.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/queues.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/queues.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/queues.apt Thu May  6 09:23:13 2010
@@ -8,19 +8,30 @@
 
 Managing Queues
 
-	Click the <<Queues>> link under the <<Administration>> section
+    Current checkouts and builds, and all other projects queued in the checkout, build, and prepare build queues
+    can be viewed in the <<Queues>> page.
 
 [../images/queues.png] Queues
 
-  To display :
+    Prepare Build Queue
   
+[../images/queues-prepare.png] Prepare Build Queue
+
+    Build Queues
+
 [../images/queues-view.png] Queues View  
+
+    Checkout Queue
+
+[../images/queues-checkout.png] Checkout Queue
 	
-	You must have a <<"Manage Continuum Queues">> role for you to:
+	You must have a <<Manage Continuum Queues>> role for you to:
 
-    [[1]] Cancel current checkouts, current builds, queued checkouts and queued builds by clicking the  
+    [[1]] Cancel current checkouts, current builds, queued prepare builds, queued checkouts and queued builds by clicking the  
 
 [../images/cancelbuild.gif] cancel build icon.
   
-    [[2]] Cancel multiple queued tasks by selecting the corresponding checkboxes of the checkouts or builds you want to cancel and
-    then click the <<Cancel Entries>> button.
\ No newline at end of file
+    [[2]] Cancel multiple queued tasks by selecting the corresponding checkboxes of the checkouts, builds, or project updates
+    you want to cancel and then click the <<Cancel Entries>> button.
+
+    Note: Cancelling current prepare build is not allowed to prevent data corruption.

Modified: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/schedules.apt
URL: http://svn.apache.org/viewvc/continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/schedules.apt?rev=941625&r1=941624&r2=941625&view=diff
==============================================================================
--- continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/schedules.apt (original)
+++ continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/schedules.apt Thu May  6 09:23:13 2010
@@ -23,7 +23,7 @@ Managing Schedules
     
     [[2]] Fill in the needed information in the <<Edit Schedules>> page shown below.
 
-[../images/add_schedule.png] Adding a build schedule
+[../images/editSchedule.png] Adding a build schedule
     
         * <<Name>> The unique identifier of the schedule. This is a required field.
         
@@ -39,6 +39,10 @@ Managing Schedules
             not atomic and a developer might be committing midway through an update. It is not typically
             needed if using Subversion.
         
+        *<<Add Build Queue>> Move build queues from the left hand list box to the right hand list box by
+            clicking the appropriate buttons in between the two list boxes. All build queues on the right
+            hand list box will be attached to the schedule.
+        
         * <<Enabled>> When selected, scheduled build will be executed.
         []
 
@@ -56,4 +60,4 @@ Managing Schedules
 
 * Deleting Schedules
     
-    To delete a schedule, click the delete icon, the rightmost icon inline with the schedule to be deleted.
\ No newline at end of file
+    To delete a schedule, click the delete icon, the rightmost icon inline with the schedule to be deleted.

Propchange: continuum/branches/continuum-flat-multi-module/continuum-docs/src/site/apt/administrator_guides/security/customising-security.apt
------------------------------------------------------------------------------
    svn:eol-style = native