You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by ra...@apache.org on 2015/08/26 11:23:28 UTC

[1/4] stratos git commit: Removing ApplicationManager references in autoscaler component. AS should always refer to ApplicationHolder

Repository: stratos
Updated Branches:
  refs/heads/stratos-4.1.x 57ecc648e -> 3df27e0b2


Removing ApplicationManager references in autoscaler component. AS should always refer to ApplicationHolder


Project: http://git-wip-us.apache.org/repos/asf/stratos/repo
Commit: http://git-wip-us.apache.org/repos/asf/stratos/commit/b778c6dc
Tree: http://git-wip-us.apache.org/repos/asf/stratos/tree/b778c6dc
Diff: http://git-wip-us.apache.org/repos/asf/stratos/diff/b778c6dc

Branch: refs/heads/stratos-4.1.x
Commit: b778c6dcbda964933e99b9d00c7c62b9d7512875
Parents: 57ecc64
Author: Akila Perera <ra...@gmail.com>
Authored: Wed Aug 26 12:28:00 2015 +0530
Committer: Akila Perera <ra...@gmail.com>
Committed: Wed Aug 26 12:28:00 2015 +0530

----------------------------------------------------------------------
 .../services/impl/AutoscalerServiceImpl.java    | 148 ++++++++++++-------
 1 file changed, 91 insertions(+), 57 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/b778c6dc/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
index f0e797f..3ccd970 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
@@ -25,13 +25,7 @@ import org.apache.stratos.autoscaler.algorithms.networkpartition.NetworkPartitio
 import org.apache.stratos.autoscaler.applications.ApplicationHolder;
 import org.apache.stratos.autoscaler.applications.parser.ApplicationParser;
 import org.apache.stratos.autoscaler.applications.parser.DefaultApplicationParser;
-import org.apache.stratos.autoscaler.applications.pojo.ApplicationClusterContext;
-import org.apache.stratos.autoscaler.applications.pojo.ApplicationContext;
-import org.apache.stratos.autoscaler.applications.pojo.ArtifactRepositoryContext;
-import org.apache.stratos.autoscaler.applications.pojo.CartridgeContext;
-import org.apache.stratos.autoscaler.applications.pojo.ComponentContext;
-import org.apache.stratos.autoscaler.applications.pojo.GroupContext;
-import org.apache.stratos.autoscaler.applications.pojo.SubscribableInfoContext;
+import org.apache.stratos.autoscaler.applications.pojo.*;
 import org.apache.stratos.autoscaler.applications.topic.ApplicationBuilder;
 import org.apache.stratos.autoscaler.client.AutoscalerCloudControllerClient;
 import org.apache.stratos.autoscaler.context.AutoscalerContext;
@@ -44,7 +38,6 @@ import org.apache.stratos.autoscaler.exception.*;
 import org.apache.stratos.autoscaler.exception.application.ApplicationDefinitionException;
 import org.apache.stratos.autoscaler.exception.application.InvalidApplicationPolicyException;
 import org.apache.stratos.autoscaler.exception.application.InvalidServiceGroupException;
-import org.apache.stratos.autoscaler.exception.CartridgeNotFoundException;
 import org.apache.stratos.autoscaler.exception.policy.*;
 import org.apache.stratos.autoscaler.monitor.cluster.ClusterMonitor;
 import org.apache.stratos.autoscaler.monitor.component.ApplicationMonitor;
@@ -76,7 +69,6 @@ import org.apache.stratos.messaging.domain.application.ClusterDataHolder;
 import org.apache.stratos.messaging.domain.instance.ClusterInstance;
 import org.apache.stratos.messaging.domain.topology.Cluster;
 import org.apache.stratos.messaging.domain.topology.Member;
-import org.apache.stratos.messaging.message.receiver.application.ApplicationManager;
 import org.apache.stratos.messaging.message.receiver.topology.TopologyManager;
 import org.wso2.carbon.registry.api.RegistryException;
 
@@ -165,8 +157,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
 
         if (AutoscalerContext.getInstance().getApplicationContext(applicationId) == null) {
-            String message = "Application is not found as ApplicationContext. Please add application before updating it: " +
-                    "[application-id] " + applicationId;
+            String message =
+                    "Application is not found as ApplicationContext. Please add application before updating it: " +
+                            "[application-id] " + applicationId;
             log.error(message);
             throw new ApplicationDefinitionException(message);
         }
@@ -251,7 +244,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 application = ApplicationHolder.getApplications().getApplication(applicationId);
                 application.setApplicationPolicyId(applicationPolicyId);
                 ApplicationHolder.persistApplication(application);
-            } finally {
+            }
+            finally {
                 ApplicationHolder.releaseWriteLock();
             }
 
@@ -276,7 +270,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                     applicationId);
 
             return true;
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             ApplicationContext applicationContext = RegistryManager.getInstance().
                     getApplicationContext(applicationId);
             if (applicationContext != null) {
@@ -357,8 +352,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                             applicationContext.getApplicationId()));
                 }
             }
-        } catch (Exception e) {
-            String message = "Could not add application signup: [application-id]" + applicationContext.getApplicationId();
+        }
+        catch (Exception e) {
+            String message =
+                    "Could not add application signup: [application-id]" + applicationContext.getApplicationId();
             log.error(message, e);
             throw new RuntimeException(message, e);
         }
@@ -396,7 +393,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
             StratosManagerServiceClient serviceClient = StratosManagerServiceClient.getInstance();
 
-            ApplicationSignUp applicationSignUp[] = serviceClient.getApplicationSignUps(applicationContext.getApplicationId());
+            ApplicationSignUp applicationSignUp[] =
+                    serviceClient.getApplicationSignUps(applicationContext.getApplicationId());
             if (applicationSignUp != null) {
                 for (ApplicationSignUp appSignUp : applicationSignUp) {
                     if (appSignUp != null) {
@@ -405,7 +403,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 }
             }
 
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             String message = "Could not remove application signup(s)";
             log.error(message, e);
             throw new RuntimeException(message, e);
@@ -437,7 +436,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
     }
 
-    private void updateArtifactRepositoryList(List<ArtifactRepository> artifactRepositoryList, CartridgeContext[] cartridgeContexts) {
+    private void updateArtifactRepositoryList(List<ArtifactRepository> artifactRepositoryList,
+                                              CartridgeContext[] cartridgeContexts) {
 
         if (cartridgeContexts == null) {
             return;
@@ -445,7 +445,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         for (CartridgeContext cartridgeContext : cartridgeContexts) {
             SubscribableInfoContext subscribableInfoContext = cartridgeContext.getSubscribableInfoContext();
-            ArtifactRepositoryContext artifactRepositoryContext = subscribableInfoContext.getArtifactRepositoryContext();
+            ArtifactRepositoryContext artifactRepositoryContext =
+                    subscribableInfoContext.getArtifactRepositoryContext();
             if (artifactRepositoryContext != null) {
 
                 ArtifactRepository artifactRepository = new ArtifactRepository();
@@ -536,7 +537,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             if (log.isInfoEnabled()) {
                 log.info("Application undeployment process started: [application-id] " + applicationId);
             }
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             String message = "Could not start application undeployment process: [application-id] " + applicationId;
             log.error(message, e);
             throw new RuntimeException(message, e);
@@ -546,7 +548,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
     @Override
     public boolean deleteApplication(String applicationId) {
         try {
-            ApplicationContext applicationContext = AutoscalerContext.getInstance().getApplicationContext(applicationId);
+            ApplicationContext applicationContext =
+                    AutoscalerContext.getInstance().getApplicationContext(applicationId);
             Application application = ApplicationHolder.getApplications().getApplication(applicationId);
             if ((applicationContext == null) || (application == null)) {
                 String msg = String.format("Application cannot be deleted, application not found: [application-id] %s",
@@ -570,7 +573,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
             ApplicationBuilder.handleApplicationRemoval(applicationId);
             log.info(String.format("Application deleted successfully: [application-id] %s", applicationId));
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             String message = String.format("Could not delete application: [application-id] %s", applicationId);
             log.error(message, e);
             throw new RuntimeException(message, e);
@@ -714,7 +718,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         try {
             RegistryManager.getInstance().updateServiceGroup(cartridgeGroup);
-        } catch (org.wso2.carbon.registry.core.exceptions.RegistryException e) {
+        }
+        catch (org.wso2.carbon.registry.core.exceptions.RegistryException e) {
             String message = (String.format("Cannot update cartridge group: [group-name] %s",
                     cartridgeGroup.getName()));
             throw new RuntimeException(message, e);
@@ -745,7 +750,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 }
                 throw new CartridgeGroupNotFoundException(msg);
             }
-        } catch (org.wso2.carbon.registry.core.exceptions.RegistryException e) {
+        }
+        catch (org.wso2.carbon.registry.core.exceptions.RegistryException e) {
             String message = "Could not remove cartridge group: " + groupName;
             log.error(message, e);
             throw new RuntimeException(message, e);
@@ -759,15 +765,17 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
         try {
             return RegistryManager.getInstance().getServiceGroup(name);
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             throw new AutoScalerException("Error occurred while retrieving cartridge group", e);
         }
     }
 
     @Override
     public String findClusterId(String applicationId, String alias) {
+        ApplicationHolder.acquireReadLock();
         try {
-            Application application = ApplicationManager.getApplications().getApplication(applicationId);
+            Application application = ApplicationHolder.getApplications().getApplication(applicationId);
             if (application != null) {
 
                 ClusterDataHolder clusterData = application.getClusterDataHolderRecursivelyByAlias(alias);
@@ -776,11 +784,15 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 }
             }
             return null;
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             String message = String.format("Could not find cluster id: [application-id] %s [alias] %s",
                     applicationId, alias);
             throw new AutoScalerException(message, e);
         }
+        finally {
+            ApplicationHolder.releaseReadLock();
+        }
     }
 
     public ServiceGroup[] getServiceGroups() throws AutoScalerException {
@@ -794,7 +806,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
     public boolean undeployServiceGroup(String name) throws AutoScalerException {
         try {
             RegistryManager.getInstance().removeServiceGroup(name);
-        } catch (RegistryException e) {
+        }
+        catch (RegistryException e) {
             throw new AutoScalerException("Error occurred while removing the cartridge groups", e);
         }
         return true;
@@ -842,7 +855,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
     }
 
     @Override
-    public boolean removeApplicationPolicy(String applicationPolicyId) throws InvalidPolicyException, UnremovablePolicyException {
+    public boolean removeApplicationPolicy(String applicationPolicyId)
+            throws InvalidPolicyException, UnremovablePolicyException {
 
         if (removableApplicationPolicy(applicationPolicyId)) {
             return PolicyManager.getInstance().removeApplicationPolicy(applicationPolicyId);
@@ -873,9 +887,11 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
 
         String applicationPolicyId = applicationPolicy.getId();
-        ApplicationPolicy existingApplicationPolicy = PolicyManager.getInstance().getApplicationPolicy(applicationPolicyId);
+        ApplicationPolicy existingApplicationPolicy =
+                PolicyManager.getInstance().getApplicationPolicy(applicationPolicyId);
         if (existingApplicationPolicy == null) {
-            String msg = String.format("No such application policy found [application-policy-id] %s", applicationPolicyId);
+            String msg =
+                    String.format("No such application policy found [application-policy-id] %s", applicationPolicyId);
             log.error(msg);
             throw new ApplicatioinPolicyNotExistsException(msg);
         }
@@ -899,16 +915,17 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
 
         Application application;
+        ApplicationHolder.acquireReadLock();
         try {
-            ApplicationManager.acquireReadLockForApplication(applicationId);
-            application = ApplicationManager.getApplications().getApplication(applicationId);
+            application = ApplicationHolder.getApplications().getApplication(applicationId);
             if (application == null) {
                 log.warn(String.format("Could not find application, thus no members to be terminated " +
                         "[application-id] %s", applicationId));
                 return;
             }
-        } finally {
-            ApplicationManager.releaseReadLockForApplication(applicationId);
+        }
+        finally {
+            ApplicationHolder.releaseReadLock();
         }
 
         Set<ClusterDataHolder> allClusters = application.getClusterDataRecursively();
@@ -920,7 +937,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             try {
                 TopologyManager.acquireReadLockForCluster(serviceType, clusterId);
                 cluster = TopologyManager.getTopology().getService(serviceType).getCluster(clusterId);
-            } finally {
+            }
+            finally {
                 TopologyManager.releaseReadLockForCluster(serviceType, clusterId);
             }
 
@@ -950,12 +968,15 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
                 for (String memberIdToTerminate : memberListToTerminate) {
                     try {
-                        log.info(String.format("Terminating member forcefully [member-id] %s of the cluster [cluster-id] %s " +
-                                "[application-id] %s", memberIdToTerminate, clusterId, application));
+                        log.info(String.format(
+                                "Terminating member forcefully [member-id] %s of the cluster [cluster-id] %s " +
+                                        "[application-id] %s", memberIdToTerminate, clusterId, application));
                         AutoscalerCloudControllerClient.getInstance().terminateInstanceForcefully(memberIdToTerminate);
-                    } catch (Exception e) {
-                        log.error(String.format("Forceful termination of member %s has failed, but continuing forceful " +
-                                "deletion of other members", memberIdToTerminate));
+                    }
+                    catch (Exception e) {
+                        log.error(
+                                String.format("Forceful termination of member %s has failed, but continuing forceful " +
+                                        "deletion of other members", memberIdToTerminate));
                     }
                 }
             }
@@ -1016,7 +1037,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
 
         // deployment policy should contain at least one network partition reference
-        if (null == deploymentPolicy.getNetworkPartitionRefs() || deploymentPolicy.getNetworkPartitionRefs().length == 0) {
+        if (null == deploymentPolicy.getNetworkPartitionRefs() ||
+                deploymentPolicy.getNetworkPartitionRefs().length == 0) {
             String msg = String.format("Deployment policy does not have any network partition references: " +
                     "[deployment-policy-id] %s", deploymentPolicyId);
             log.error(msg);
@@ -1088,7 +1110,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             PartitionRef[] partitions = networkPartitionRef.getPartitionRefs();
             if (null == partitions || partitions.length == 0) {
                 String msg = String.format("Network partition does not have any partition references: "
-                        + "[deployment-policy-id] %s [network-partition-id] %s", deploymentPolicyId, networkPartitionId);
+                        + "[deployment-policy-id] %s [network-partition-id] %s", deploymentPolicyId,
+                        networkPartitionId);
                 log.error(msg);
                 throw new InvalidDeploymentPolicyException(msg);
             }
@@ -1097,7 +1120,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
     @Override
     public boolean updateDeploymentPolicy(DeploymentPolicy deploymentPolicy) throws RemoteException,
-            InvalidDeploymentPolicyException, DeploymentPolicyNotExistsException, InvalidPolicyException, CloudControllerConnectionException {
+            InvalidDeploymentPolicyException, DeploymentPolicyNotExistsException, InvalidPolicyException,
+            CloudControllerConnectionException {
 
         validateDeploymentPolicy(deploymentPolicy);
 
@@ -1137,24 +1161,30 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                     if (clusterLevelNetworkPartitionContext != null) {
                         try {
                             addNewPartitionsToClusterMonitor(clusterLevelNetworkPartitionContext, networkPartition,
-                                    deploymentPolicy.getDeploymentPolicyID(), clusterMonitor.getClusterContext().getServiceId());
-                        } catch (RemoteException e) {
+                                    deploymentPolicy.getDeploymentPolicyID(),
+                                    clusterMonitor.getClusterContext().getServiceId());
+                        }
+                        catch (RemoteException e) {
 
-                            String message = "Connection to cloud controller failed, Cluster monitor update failed for" +
-                                    " [deployment-policy] " + deploymentPolicy.getDeploymentPolicyID();
+                            String message =
+                                    "Connection to cloud controller failed, Cluster monitor update failed for" +
+                                            " [deployment-policy] " + deploymentPolicy.getDeploymentPolicyID();
                             log.error(message);
                             throw new CloudControllerConnectionException(message, e);
-                        } catch (CloudControllerServiceInvalidPartitionExceptionException e) {
+                        }
+                        catch (CloudControllerServiceInvalidPartitionExceptionException e) {
 
                             String message = "Invalid partition, Cluster monitor update failed for [deployment-policy] "
                                     + deploymentPolicy.getDeploymentPolicyID();
                             log.error(message);
                             throw new InvalidDeploymentPolicyException(message, e);
-                        } catch (CloudControllerServiceInvalidCartridgeTypeExceptionException e) {
+                        }
+                        catch (CloudControllerServiceInvalidCartridgeTypeExceptionException e) {
 
-                            String message = "Invalid cartridge type, Cluster monitor update failed for [deployment-policy] "
-                                    + deploymentPolicy.getDeploymentPolicyID() + " [cartridge] "
-                                    + clusterMonitor.getClusterContext().getServiceId();
+                            String message =
+                                    "Invalid cartridge type, Cluster monitor update failed for [deployment-policy] "
+                                            + deploymentPolicy.getDeploymentPolicyID() + " [cartridge] "
+                                            + clusterMonitor.getClusterContext().getServiceId();
                             log.error(message);
                             throw new InvalidDeploymentPolicyException(message, e);
                         }
@@ -1168,17 +1198,20 @@ public class AutoscalerServiceImpl implements AutoscalerService {
     private void removeOldPartitionsFromClusterMonitor(NetworkPartitionContext clusterLevelNetworkPartitionContext,
                                                        NetworkPartitionRef networkPartition) {
 
-        for (InstanceContext instanceContext : clusterLevelNetworkPartitionContext.getInstanceIdToInstanceContextMap().values()) {
+        for (InstanceContext instanceContext : clusterLevelNetworkPartitionContext.getInstanceIdToInstanceContextMap()
+                .values()) {
 
             ClusterInstanceContext clusterInstanceContext = (ClusterInstanceContext) instanceContext;
 
-            for (ClusterLevelPartitionContext clusterLevelPartitionContext : clusterInstanceContext.getPartitionCtxts()) {
+            for (ClusterLevelPartitionContext clusterLevelPartitionContext : clusterInstanceContext
+                    .getPartitionCtxts()) {
 
                 if (null == networkPartition.getPartitionRef(clusterLevelPartitionContext.getPartitionId())) {
 
                     //It has found that this partition context which is in cluster monitor is removed in updated policy
                     clusterLevelPartitionContext.setIsObsoletePartition(true);
-                    Iterator<MemberContext> memberContextIterator = clusterLevelPartitionContext.getActiveMembers().iterator();
+                    Iterator<MemberContext> memberContextIterator =
+                            clusterLevelPartitionContext.getActiveMembers().iterator();
                     while (memberContextIterator.hasNext()) {
 
                         clusterLevelPartitionContext.moveActiveMemberToTerminationPendingMembers(
@@ -1265,7 +1298,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         try {
             Collection<DeploymentPolicy> deploymentPolicies = PolicyManager.getInstance().getDeploymentPolicies();
             return deploymentPolicies.toArray(new DeploymentPolicy[deploymentPolicies.size()]);
-        } catch (Exception e) {
+        }
+        catch (Exception e) {
             String message = "Could not get deployment policies";
             log.error(message);
             throw new AutoScalerException(message, e);


[4/4] stratos git commit: Removing hard coded agent properties

Posted by ra...@apache.org.
Removing hard coded agent properties


Project: http://git-wip-us.apache.org/repos/asf/stratos/repo
Commit: http://git-wip-us.apache.org/repos/asf/stratos/commit/3df27e0b
Tree: http://git-wip-us.apache.org/repos/asf/stratos/tree/3df27e0b
Diff: http://git-wip-us.apache.org/repos/asf/stratos/diff/3df27e0b

Branch: refs/heads/stratos-4.1.x
Commit: 3df27e0b2fcef14fa0b6aa2d5a6c35436dad40b9
Parents: 282dd23
Author: Akila Perera <ra...@gmail.com>
Authored: Wed Aug 26 14:53:05 2015 +0530
Committer: Akila Perera <ra...@gmail.com>
Committed: Wed Aug 26 14:53:05 2015 +0530

----------------------------------------------------------------------
 .../org.apache.stratos.cartridge.agent/pom.xml  |  2 --
 .../agent/test/JavaCartridgeAgentTest.java      | 23 ++++++++++++++++----
 .../test/resources/test-conf/test.properties    | 20 +++++++++++++++++
 pom.xml                                         |  3 +++
 .../modules/distribution/pom.xml                |  5 +++--
 .../distribution/src/main/assembly/bin.xml      |  1 -
 .../python-cartridge-agent/distribution/pom.xml |  3 ++-
 .../distribution/src/main/assembly/bin.xml      |  6 +++--
 8 files changed, 51 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/components/org.apache.stratos.cartridge.agent/pom.xml
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cartridge.agent/pom.xml b/components/org.apache.stratos.cartridge.agent/pom.xml
index 4f094e2..accad57 100644
--- a/components/org.apache.stratos.cartridge.agent/pom.xml
+++ b/components/org.apache.stratos.cartridge.agent/pom.xml
@@ -30,7 +30,6 @@
     <packaging>jar</packaging>
     <name>Apache Stratos - Cartridge Agent</name>
     <description>Apache Stratos Cartridge Agent</description>
-    <url>http://apache.org</url>
 
     <build>
         <plugins>
@@ -92,7 +91,6 @@
         <dependency>
             <groupId>org.eclipse.jgit.wso2</groupId>
             <artifactId>org.eclipse.jgit</artifactId>
-            <!--version>2.1.0.wso2v1</version-->
             <version>2.3.1.wso2v2</version>
         </dependency>
         <dependency>

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/components/org.apache.stratos.cartridge.agent/src/test/java/org/apache/stratos/cartridge/agent/test/JavaCartridgeAgentTest.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cartridge.agent/src/test/java/org/apache/stratos/cartridge/agent/test/JavaCartridgeAgentTest.java b/components/org.apache.stratos.cartridge.agent/src/test/java/org/apache/stratos/cartridge/agent/test/JavaCartridgeAgentTest.java
index a10c323..7db8f70 100644
--- a/components/org.apache.stratos.cartridge.agent/src/test/java/org/apache/stratos/cartridge/agent/test/JavaCartridgeAgentTest.java
+++ b/components/org.apache.stratos.cartridge.agent/src/test/java/org/apache/stratos/cartridge/agent/test/JavaCartridgeAgentTest.java
@@ -77,7 +77,8 @@ public class JavaCartridgeAgentTest {
     private static final String PARTITION_ID = "partition-1";
     private static final String TENANT_ID = "-1234";
     private static final String SERVICE_NAME = "php";
-    public static final String AGENT_NAME = "apache-stratos-cartridge-agent-4.1.2";
+    public static final String AGENT_NAME = "distribution.name";
+    public static final String AGENT_VERSION = "distribution.version";
     private static HashMap<String, Executor> executorList;
     private static ArrayList<ServerSocket> serverSocketList;
     private final ArtifactUpdatedEvent artifactUpdatedEvent;
@@ -87,10 +88,24 @@ public class JavaCartridgeAgentTest {
     private ByteArrayOutputStreamLocal outputStream;
     private TopologyEventReceiver topologyEventReceiver;
     private InstanceStatusEventReceiver instanceStatusEventReceiver;
+    private String agentName;
+    private String agentVersion;
+    private Properties testProperties = new Properties();
 
     public JavaCartridgeAgentTest(ArtifactUpdatedEvent artifactUpdatedEvent, Boolean expectedResult) {
         this.artifactUpdatedEvent = artifactUpdatedEvent;
         this.expectedResult = expectedResult;
+        try {
+            testProperties
+                    .load(JavaCartridgeAgentTest.class.getResourceAsStream("/test.properties"));
+            agentName = testProperties.getProperty(AGENT_NAME);
+            agentVersion = testProperties.getProperty(AGENT_VERSION);
+            log.info("Java Cartridge Agent test properties: " + testProperties.toString());
+        }
+        catch (IOException e) {
+            log.error("Error loading test.properties file from classpath. Please make sure that file " +
+                    "exists in classpath.", e);
+        }
     }
 
     @BeforeClass
@@ -232,9 +247,9 @@ public class JavaCartridgeAgentTest {
     private String setupJavaAgent() {
         try {
             log.info("Setting up Java cartridge agent test setup");
-            String jcaZipSource = getResourcesFolderPath() + "/../../../../products/cartridge-agent/modules/distribution/target/" + AGENT_NAME + ".zip";
+            String jcaZipSource = getResourcesFolderPath() + "/../../../../products/cartridge-agent/modules/distribution/target/" + agentName + ".zip";
             String testHome = getResourcesFolderPath() + "/../" + UUID.randomUUID() + "/";
-            File agentHome = new File(testHome + AGENT_NAME);
+            File agentHome = new File(testHome + agentName);
             log.info("Extracting Java Cartridge Agent to test folder");
             ZipFile agentZip = new ZipFile(jcaZipSource);
             ProgressMonitor zipProgresMonitor = agentZip.getProgressMonitor();
@@ -249,7 +264,7 @@ public class JavaCartridgeAgentTest {
             }
 
             log.info("Copying agent jar");
-            String agentJar = "org.apache.stratos.cartridge.agent-4.1.2.jar";
+            String agentJar = "org.apache.stratos.cartridge.agent-" + agentVersion + ".jar";
             String agentJarSource = getResourcesFolderPath() + "/../" + agentJar;
             String agentJarDest = agentHome.getCanonicalPath() + "/lib/" + agentJar;
             FileUtils.copyFile(new File(agentJarSource), new File(agentJarDest));

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/components/org.apache.stratos.cartridge.agent/src/test/resources/test-conf/test.properties
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cartridge.agent/src/test/resources/test-conf/test.properties b/components/org.apache.stratos.cartridge.agent/src/test/resources/test-conf/test.properties
new file mode 100644
index 0000000..1aee0b8
--- /dev/null
+++ b/components/org.apache.stratos.cartridge.agent/src/test/resources/test-conf/test.properties
@@ -0,0 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
+# Stratos distribution properties added via filters during the build
+distribution.name=${java.cartridge.agent.distribution.name}-${project.version}
+distribution.version=${project.version}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 9ba2735..479806d 100644
--- a/pom.xml
+++ b/pom.xml
@@ -738,6 +738,9 @@
         <!-- product distribution properties -->
         <stratos.distribution.name>apache-stratos</stratos.distribution.name>
         <load.balancer.distribution.name>apache-stratos-load-balancer</load.balancer.distribution.name>
+        <java.cartridge.agent.distribution.name>apache-stratos-cartridge-agent</java.cartridge.agent.distribution.name>
+        <python.cartridge.agent.distribution.name>apache-stratos-python-cartridge-agent
+        </python.cartridge.agent.distribution.name>
 
         <project.build.sourceEncoding>UTF-8</project.build.sourceEncoding>
     </properties>

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/products/cartridge-agent/modules/distribution/pom.xml
----------------------------------------------------------------------
diff --git a/products/cartridge-agent/modules/distribution/pom.xml b/products/cartridge-agent/modules/distribution/pom.xml
index 15e416a..67c9c43 100644
--- a/products/cartridge-agent/modules/distribution/pom.xml
+++ b/products/cartridge-agent/modules/distribution/pom.xml
@@ -27,8 +27,8 @@
         <relativePath>../../pom.xml</relativePath>
     </parent>
 
-    <artifactId>apache-stratos-cartridge-agent</artifactId>
-    <name>Apache Stratos - Cartridge Agent Distribution</name>
+    <artifactId>java-cartridge-agent-distribution</artifactId>
+    <name>Apache Stratos - Java Cartridge Agent Distribution</name>
 
     <dependencies>
         <dependency>
@@ -55,6 +55,7 @@
                 <groupId>org.apache.maven.plugins</groupId>
                 <artifactId>maven-assembly-plugin</artifactId>
                 <configuration>
+                    <finalName>${java.cartridge.agent.distribution.name}-${project.version}</finalName>
                     <descriptors>
                         <descriptor>src/main/assembly/bin.xml</descriptor>
                     </descriptors>

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/products/cartridge-agent/modules/distribution/src/main/assembly/bin.xml
----------------------------------------------------------------------
diff --git a/products/cartridge-agent/modules/distribution/src/main/assembly/bin.xml b/products/cartridge-agent/modules/distribution/src/main/assembly/bin.xml
index 1c8486b..2b5767f 100644
--- a/products/cartridge-agent/modules/distribution/src/main/assembly/bin.xml
+++ b/products/cartridge-agent/modules/distribution/src/main/assembly/bin.xml
@@ -16,7 +16,6 @@
   ~ specific language governing permissions and limitations
   ~ under the License.
   -->
-
 <assembly xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
           xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.0"
           xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.0 http://maven.apache.org/xsd/assembly-1.1.0.xsd">

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/products/python-cartridge-agent/distribution/pom.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/distribution/pom.xml b/products/python-cartridge-agent/distribution/pom.xml
index 65e3527..10826e0 100644
--- a/products/python-cartridge-agent/distribution/pom.xml
+++ b/products/python-cartridge-agent/distribution/pom.xml
@@ -27,7 +27,7 @@
         <relativePath>../pom.xml</relativePath>
     </parent>
 
-    <artifactId>apache-stratos-python-cartridge-agent</artifactId>
+    <artifactId>python-cartridge-agent-distribution</artifactId>
     <packaging>pom</packaging>
     <name>Apache Stratos - Python Cartridge Agent</name>
     <description>Apache Stratos Python Cartridge Agent Distribution</description>
@@ -45,6 +45,7 @@
                             <goal>attached</goal>
                         </goals>
                         <configuration>
+                            <finalName>${python.cartridge.agent.distribution.name}-${project.version}</finalName>
                             <descriptors>
                                 <descriptor>src/main/assembly/bin.xml</descriptor>
                             </descriptors>

http://git-wip-us.apache.org/repos/asf/stratos/blob/3df27e0b/products/python-cartridge-agent/distribution/src/main/assembly/bin.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/distribution/src/main/assembly/bin.xml b/products/python-cartridge-agent/distribution/src/main/assembly/bin.xml
index bca0b25..fa8874c 100644
--- a/products/python-cartridge-agent/distribution/src/main/assembly/bin.xml
+++ b/products/python-cartridge-agent/distribution/src/main/assembly/bin.xml
@@ -24,7 +24,9 @@
     </formats>
     <fileSets>
         <fileSet>
-            <directory>${project.basedir}/../../../components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent</directory>
+            <directory>
+                ${project.basedir}/../../../components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent
+            </directory>
             <outputDirectory>.</outputDirectory>
             <includes>
                 <include>**/*</include>
@@ -52,4 +54,4 @@
             <fileMode>644</fileMode>
         </file>
     </files>
-</assembly>
+</assembly>
\ No newline at end of file


[2/4] stratos git commit: ApplicationCreatedEvent should be published when adding an application

Posted by ra...@apache.org.
ApplicationCreatedEvent should be published when adding an application


Project: http://git-wip-us.apache.org/repos/asf/stratos/repo
Commit: http://git-wip-us.apache.org/repos/asf/stratos/commit/be8ebd4c
Tree: http://git-wip-us.apache.org/repos/asf/stratos/tree/be8ebd4c
Diff: http://git-wip-us.apache.org/repos/asf/stratos/diff/be8ebd4c

Branch: refs/heads/stratos-4.1.x
Commit: be8ebd4c67dd29d4e345f52b657dd271268b1f17
Parents: b778c6d
Author: Akila Perera <ra...@gmail.com>
Authored: Wed Aug 26 12:35:35 2015 +0530
Committer: Akila Perera <ra...@gmail.com>
Committed: Wed Aug 26 12:35:35 2015 +0530

----------------------------------------------------------------------
 .../stratos/autoscaler/applications/topic/ApplicationBuilder.java  | 1 -
 .../stratos/autoscaler/services/impl/AutoscalerServiceImpl.java    | 2 ++
 2 files changed, 2 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/be8ebd4c/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/applications/topic/ApplicationBuilder.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/applications/topic/ApplicationBuilder.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/applications/topic/ApplicationBuilder.java
index 912a2f6..2f1b5f0 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/applications/topic/ApplicationBuilder.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/applications/topic/ApplicationBuilder.java
@@ -75,7 +75,6 @@ public class ApplicationBuilder {
                     application.getUniqueIdentifier());
         }
         ApplicationHolder.persistApplication(application);
-        ApplicationsEventPublisher.sendApplicationCreatedEvent(application);
         AutoscalerCloudControllerClient.getInstance().createApplicationClusters(application.getUniqueIdentifier(),
                 appClusterContexts);
     }

http://git-wip-us.apache.org/repos/asf/stratos/blob/be8ebd4c/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
index 3ccd970..738ced9 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/impl/AutoscalerServiceImpl.java
@@ -27,6 +27,7 @@ import org.apache.stratos.autoscaler.applications.parser.ApplicationParser;
 import org.apache.stratos.autoscaler.applications.parser.DefaultApplicationParser;
 import org.apache.stratos.autoscaler.applications.pojo.*;
 import org.apache.stratos.autoscaler.applications.topic.ApplicationBuilder;
+import org.apache.stratos.autoscaler.applications.topic.ApplicationsEventPublisher;
 import org.apache.stratos.autoscaler.client.AutoscalerCloudControllerClient;
 import org.apache.stratos.autoscaler.context.AutoscalerContext;
 import org.apache.stratos.autoscaler.context.InstanceContext;
@@ -142,6 +143,7 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             log.info(String.format("Application added successfully: [application-id] %s",
                     applicationContext.getApplicationId()));
         }
+        ApplicationsEventPublisher.sendApplicationCreatedEvent(application);
         return true;
     }
 


[3/4] stratos git commit: Removing hard coded versions

Posted by ra...@apache.org.
Removing hard coded versions


Project: http://git-wip-us.apache.org/repos/asf/stratos/repo
Commit: http://git-wip-us.apache.org/repos/asf/stratos/commit/282dd23e
Tree: http://git-wip-us.apache.org/repos/asf/stratos/tree/282dd23e
Diff: http://git-wip-us.apache.org/repos/asf/stratos/diff/282dd23e

Branch: refs/heads/stratos-4.1.x
Commit: 282dd23e0e05aa1f86a8dfc02e13b24002cd890c
Parents: be8ebd4
Author: Akila Perera <ra...@gmail.com>
Authored: Wed Aug 26 14:01:43 2015 +0530
Committer: Akila Perera <ra...@gmail.com>
Committed: Wed Aug 26 14:01:43 2015 +0530

----------------------------------------------------------------------
 README.md                                                 |  2 +-
 .../org.apache.stratos.manager.console/console/README.md  | 10 ++++------
 .../apache/stratos/rest/endpoint/api/StratosApiV41.java   |  2 +-
 tools/config-scripts/ec2/config.sh                        |  5 -----
 tools/config-scripts/gce/config.sh                        |  4 ----
 tools/config-scripts/openstack/config.sh                  |  5 -----
 tools/puppet3/modules/agent/files/README.txt              |  2 +-
 tools/puppet3/modules/haproxy/files/README.txt            |  2 +-
 tools/puppet3/modules/lb/files/README.txt                 |  2 +-
 tools/puppet3/modules/python_agent/files/README.txt       |  2 +-
 tools/stratos-installer/README.md                         |  3 ++-
 11 files changed, 12 insertions(+), 27 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/README.md
----------------------------------------------------------------------
diff --git a/README.md b/README.md
index 68f7131..8550a91 100644
--- a/README.md
+++ b/README.md
@@ -2,7 +2,7 @@ Apache Stratos
 ===========================
 Apache Stratos includes polyglot language and environment support together with the ability to run on top of multiple IaaS runtimes.
 Stratos is licensed under the Apache License, Version 2.0
-The following are the key features available in Apache Stratos 4.1.2:
+The following are the key features available in Apache Stratos:
 
 Features
 --------

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/components/org.apache.stratos.manager.console/console/README.md
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.manager.console/console/README.md b/components/org.apache.stratos.manager.console/console/README.md
index c0ce886..d95b1d9 100644
--- a/components/org.apache.stratos.manager.console/console/README.md
+++ b/components/org.apache.stratos.manager.console/console/README.md
@@ -1,14 +1,12 @@
-##Stratos 4.1.2 New UXD Implemantation##
+====================================
+ Apache Stratos UXD Implemantation
 ====================================
 
-Initial version with improved UXDesigns.
-
-### New Features ###
+### Features ###
 
 1. json-schema support for all form definitions (www.json-schema.org)  [STRATOS-944]
 2. JSON Hyper-Schema based UI form implementation
 3. JSON auto-correct feature
 4. Carbon based user Management
 5. Mobile friendly design
-6. Improved UXD [STRATOS-810]
-7. Include Application and Group Editor
+6. Include Application and Group Editor
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
index 757671a..af0ff89 100644
--- a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
+++ b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
@@ -65,7 +65,7 @@ import java.util.ArrayList;
 import java.util.List;
 
 /**
- * Stratos API v4.1 for Stratos 4.1.2 release.
+ * Stratos API v4.1
  */
 @Path("/")
 public class StratosApiV41 extends AbstractApi {

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/config-scripts/ec2/config.sh
----------------------------------------------------------------------
diff --git a/tools/config-scripts/ec2/config.sh b/tools/config-scripts/ec2/config.sh
index 89c5873..7588777 100755
--- a/tools/config-scripts/ec2/config.sh
+++ b/tools/config-scripts/ec2/config.sh
@@ -33,7 +33,6 @@ CP=`which cp`
 MV=`which mv`
 
 HOSTSFILE=/etc/hosts
-LOCKFILE=/mnt/apache-stratos-cartridge-agent-4.1.2/wso2carbon.lck
 DATE=`date +%d%m%y%S`
 RANDOMNUMBER="`${TR} -c -d 0-9 < /dev/urandom | ${HEAD} -c 4`${DATE}"
 
@@ -89,10 +88,6 @@ if [[ $answer = y ]] ; then
 	ARGS=("-n${NODEID}" "-d${DOMAIN}" "-s${PUPPET_IP}")
 	${ECHO} "\nRunning puppet installation with arguments: ${ARGS[@]}"
 	/root/bin/puppetinstall/puppetinstall "${ARGS[@]}"
-	#check for java agent lock file
-	if [ -e ${LOCKFILE} ]; then
-	${RM} ${LOCKFILE}
-	fi
 
 	${GREP} -q '/root/bin/init.sh > /tmp/puppet_log' /etc/rc.local || ${SED} -i 's/exit 0$/\/root\/bin\/init.sh \> \/tmp\/puppet_log\nexit 0/' /etc/rc.local
 	${RM} -rf /tmp/*

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/config-scripts/gce/config.sh
----------------------------------------------------------------------
diff --git a/tools/config-scripts/gce/config.sh b/tools/config-scripts/gce/config.sh
index d705f12..95eb6e0 100644
--- a/tools/config-scripts/gce/config.sh
+++ b/tools/config-scripts/gce/config.sh
@@ -36,7 +36,6 @@ CURL=`which curl`
 HOSTSFILE=/etc/hosts
 DATE=`date +%d%m%y%S`
 RANDOMNUMBER="`${TR} -c -d 0-9 < /dev/urandom | ${HEAD} -c 4`${DATE}"
-LOCKFILE=/mnt/apache-stratos-cartridge-agent-4.1.2/wso2carbon.lck
 
 function valid_ip()
 {
@@ -91,9 +90,6 @@ if [[ $answer = y ]] ; then
 	ARGS=("-n${NODEID}" "-d${DOMAIN}" "-s${PUPPET_IP}")
 	${ECHO} "\nRunning puppet installation with arguments: ${ARGS[@]}"
 	/root/bin/puppetinstall/puppetinstall "${ARGS[@]}"
-	if [ -e ${LOCKFILE} ]; then
-	    ${RM} ${LOCKFILE}
-	fi
 
 	${GREP} -q '/root/bin/init.sh > /tmp/puppet_log' /etc/rc.local || ${SED} -i 's/exit 0$/\/root\/bin\/init.sh \> \/tmp\/puppet_log\nexit 0/' /etc/rc.local
 	${RM} -rf /tmp/*

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/config-scripts/openstack/config.sh
----------------------------------------------------------------------
diff --git a/tools/config-scripts/openstack/config.sh b/tools/config-scripts/openstack/config.sh
index b5e4f2a..7588777 100755
--- a/tools/config-scripts/openstack/config.sh
+++ b/tools/config-scripts/openstack/config.sh
@@ -33,7 +33,6 @@ CP=`which cp`
 MV=`which mv`
 
 HOSTSFILE=/etc/hosts
-LOCKFILE=/mnt/apache-stratos-cartridge-agent-4.1.2/wso2carbon.lck
 DATE=`date +%d%m%y%S`
 RANDOMNUMBER="`${TR} -c -d 0-9 < /dev/urandom | ${HEAD} -c 4`${DATE}"
 
@@ -89,10 +88,6 @@ if [[ $answer = y ]] ; then
 	ARGS=("-n${NODEID}" "-d${DOMAIN}" "-s${PUPPET_IP}")
 	${ECHO} "\nRunning puppet installation with arguments: ${ARGS[@]}"
 	/root/bin/puppetinstall/puppetinstall "${ARGS[@]}"
-	#check for java agent lock file
-	if [ -e ${LOCKFILE} ]; then
-		${RM} ${LOCKFILE}
-	fi
 
 	${GREP} -q '/root/bin/init.sh > /tmp/puppet_log' /etc/rc.local || ${SED} -i 's/exit 0$/\/root\/bin\/init.sh \> \/tmp\/puppet_log\nexit 0/' /etc/rc.local
 	${RM} -rf /tmp/*

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/puppet3/modules/agent/files/README.txt
----------------------------------------------------------------------
diff --git a/tools/puppet3/modules/agent/files/README.txt b/tools/puppet3/modules/agent/files/README.txt
index 0d5686d..c988d4d 100644
--- a/tools/puppet3/modules/agent/files/README.txt
+++ b/tools/puppet3/modules/agent/files/README.txt
@@ -7,6 +7,6 @@ This folder should have following:
 eg:
 if $mb_type = activemq, folder structure of this folder would be:
 >$ls
->activemq  apache-stratos-python-cartridge-agent-4.1.2.zip
+>activemq  apache-stratos-python-cartridge-agent-<java-agent-version>.zip
 
 3. Under $mb_type folder, please add all the client jars, that should be copied to the agent's lib directory.

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/puppet3/modules/haproxy/files/README.txt
----------------------------------------------------------------------
diff --git a/tools/puppet3/modules/haproxy/files/README.txt b/tools/puppet3/modules/haproxy/files/README.txt
index 834a1df..0045c1c 100644
--- a/tools/puppet3/modules/haproxy/files/README.txt
+++ b/tools/puppet3/modules/haproxy/files/README.txt
@@ -7,6 +7,6 @@ This folder should have following:
 eg:
 if $mb_type = activemq, folder structure of this folder would be:
 >$ls
->activemq  apache-stratos-haproxy-extension-4.1.2.zip
+>activemq  apache-stratos-haproxy-extension-<haproxy-version>.zip
 
 3. Under $mb_type folder, please add all the client jars, that should be copied to the haproxy-extension's lib directory.

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/puppet3/modules/lb/files/README.txt
----------------------------------------------------------------------
diff --git a/tools/puppet3/modules/lb/files/README.txt b/tools/puppet3/modules/lb/files/README.txt
index 72bca56..90ce24e 100644
--- a/tools/puppet3/modules/lb/files/README.txt
+++ b/tools/puppet3/modules/lb/files/README.txt
@@ -7,6 +7,6 @@ This folder should have following:
 eg:
 if $mb_type = activemq, folder structure of this folder would be:
 >$ls
->activemq  apache-stratos-load-balancer-4.1.2.zip
+>activemq  apache-stratos-load-balancer-<load-balancer-version>.zip
 
 3. Under $mb_type folder, please add all the client jars, that should be copied to the load balancer's repository/components/lib directory.

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/puppet3/modules/python_agent/files/README.txt
----------------------------------------------------------------------
diff --git a/tools/puppet3/modules/python_agent/files/README.txt b/tools/puppet3/modules/python_agent/files/README.txt
index 0d5686d..163193e 100644
--- a/tools/puppet3/modules/python_agent/files/README.txt
+++ b/tools/puppet3/modules/python_agent/files/README.txt
@@ -7,6 +7,6 @@ This folder should have following:
 eg:
 if $mb_type = activemq, folder structure of this folder would be:
 >$ls
->activemq  apache-stratos-python-cartridge-agent-4.1.2.zip
+>activemq  apache-stratos-python-cartridge-agent-<python-agent-version>.zip
 
 3. Under $mb_type folder, please add all the client jars, that should be copied to the agent's lib directory.

http://git-wip-us.apache.org/repos/asf/stratos/blob/282dd23e/tools/stratos-installer/README.md
----------------------------------------------------------------------
diff --git a/tools/stratos-installer/README.md b/tools/stratos-installer/README.md
index 11f6699..b20d146 100644
--- a/tools/stratos-installer/README.md
+++ b/tools/stratos-installer/README.md
@@ -1,4 +1,5 @@
-Apache Stratos 4.1.2 Installer
+------------------------------
+Apache Stratos Installer
 ------------------------------
 
 Stratos-Installer is a tool to install Stratos in Single JVM as well as in distributed setup.