You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by re...@apache.org on 2015/03/01 19:35:22 UTC

[01/50] [abbrv] stratos git commit: re-arranging wordpress sample to new format

Repository: stratos
Updated Branches:
  refs/heads/docker-grouping-merge 368138888 -> d0a0b85f4
  refs/heads/master 08045d9cf -> d0a0b85f4


re-arranging wordpress sample to new format


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

Branch: refs/heads/docker-grouping-merge
Commit: 909b0de867200da3fc036975dbff1df309c143b7
Parents: b4faf43
Author: R-Rajkumar <rr...@gmail.com>
Authored: Thu Feb 26 19:07:34 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../wordpress/artifacts/application.json        |  4 +-
 .../wordpress/artifacts/autoscaling-policy.json | 14 -----
 .../wordpress/artifacts/deployment-policy.json  | 15 ------
 .../artifacts/ec2/deployment-policy.json        | 55 -------------------
 .../artifacts/kubernetes/deployment-policy.json | 55 -------------------
 .../kubernetes/kubernetes-cluster.json          | 56 --------------------
 .../artifacts/mock/deployment-policy.json       | 55 -------------------
 .../artifacts/network-partition-2.json          | 15 ------
 .../wordpress/artifacts/network-partition.json  | 15 ------
 .../artifacts/openstack/deployment-policy.json  | 55 -------------------
 .../wordpress/scripts/common/deploy.sh          | 13 +++--
 11 files changed, 10 insertions(+), 342 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/application.json b/samples/applications/wordpress/artifacts/application.json
index 9a6b0d6..ed60e88 100644
--- a/samples/applications/wordpress/artifacts/application.json
+++ b/samples/applications/wordpress/artifacts/application.json
@@ -15,7 +15,7 @@
                         "cartridgeMin": 2,
                         "cartridgeMax": 5,
                         "subscribableInfo": {
-                            "alias": "mysql1",
+                            "alias": "my-mysql",
 			    "deploymentPolicy":"deployment-policy-1",
                             "autoscalingPolicy": "autoscaling-policy-1"
                         }
@@ -25,7 +25,7 @@
                         "cartridgeMin": 2,
                         "cartridgeMax": 5,
                         "subscribableInfo": {
-                            "alias": "php1",
+                            "alias": "my-php",
                             "deploymentPolicy":"deployment-policy-1",
                             "autoscalingPolicy": "autoscaling-policy-1",
                             "artifactRepository":{

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/autoscaling-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/autoscaling-policy.json b/samples/applications/wordpress/artifacts/autoscaling-policy.json
deleted file mode 100755
index b41726e..0000000
--- a/samples/applications/wordpress/artifacts/autoscaling-policy.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-    "id": "autoscaling-policy-1",
-    "loadThresholds": {
-        "requestsInFlight": {
-            "threshold": 80
-        },
-        "memoryConsumption": {
-            "threshold": 90
-        },
-        "loadAverage": {
-            "threshold": 50
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/deployment-policy.json b/samples/applications/wordpress/artifacts/deployment-policy.json
deleted file mode 100644
index 666c299..0000000
--- a/samples/applications/wordpress/artifacts/deployment-policy.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-   "id": "deployment-policy-1",
-   "networkPartition": [
-      {
-         "id": "network-partition-1",
-         "partitionAlgo": "one-after-another",
-         "partitions": [
-            {
-               "id": "partition-1",
-               "max": 5
-            }
-         ]
-      }
-   ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/ec2/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/ec2/deployment-policy.json b/samples/applications/wordpress/artifacts/ec2/deployment-policy.json
deleted file mode 100644
index 67f5a5f..0000000
--- a/samples/applications/wordpress/artifacts/ec2/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "ec2",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/kubernetes/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/kubernetes/deployment-policy.json b/samples/applications/wordpress/artifacts/kubernetes/deployment-policy.json
deleted file mode 100644
index cb72ffd..0000000
--- a/samples/applications/wordpress/artifacts/kubernetes/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "kubernetes",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/kubernetes/kubernetes-cluster.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/kubernetes/kubernetes-cluster.json b/samples/applications/wordpress/artifacts/kubernetes/kubernetes-cluster.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/applications/wordpress/artifacts/kubernetes/kubernetes-cluster.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/mock/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/mock/deployment-policy.json b/samples/applications/wordpress/artifacts/mock/deployment-policy.json
deleted file mode 100644
index 40b8692..0000000
--- a/samples/applications/wordpress/artifacts/mock/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "mock",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/network-partition-2.json b/samples/applications/wordpress/artifacts/network-partition-2.json
deleted file mode 100644
index 0d07838..0000000
--- a/samples/applications/wordpress/artifacts/network-partition-2.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-2",
-    "partitions": [
-        {
-            "id": "partition-2",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/network-partition.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/network-partition.json b/samples/applications/wordpress/artifacts/network-partition.json
deleted file mode 100644
index 2a5b7ec..0000000
--- a/samples/applications/wordpress/artifacts/network-partition.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-1",
-    "partitions": [
-        {
-            "id": "partition-1",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/artifacts/openstack/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/artifacts/openstack/deployment-policy.json b/samples/applications/wordpress/artifacts/openstack/deployment-policy.json
deleted file mode 100644
index a2d1e8c..0000000
--- a/samples/applications/wordpress/artifacts/openstack/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "openstack",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/909b0de8/samples/applications/wordpress/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/scripts/common/deploy.sh b/samples/applications/wordpress/scripts/common/deploy.sh
index 3a41d05..a24339b 100755
--- a/samples/applications/wordpress/scripts/common/deploy.sh
+++ b/samples/applications/wordpress/scripts/common/deploy.sh
@@ -11,6 +11,9 @@ artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
 
 set -e
 
@@ -19,16 +22,16 @@ if [[ -z "${iaas}" ]]; then
     exit
 fi
 
-echo ${artifacts_path}/autoscaling-policy.json
+echo ${autoscaling_policies_path}/autoscaling-policy-1.json
 echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
 
 echo "Adding network partitions..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding mysql cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${cartridges_path}/mysql.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges


[31/50] [abbrv] stratos git commit: Fixing application policy in tomcat-sso sample application

Posted by re...@apache.org.
Fixing application policy in tomcat-sso sample application


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

Branch: refs/heads/docker-grouping-merge
Commit: 4124be80e40a8e4f17256143c401c9347c5c82bc
Parents: 4e7a7c9
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 02:06:47 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 02:06:47 2015 +0530

----------------------------------------------------------------------
 samples/applications/tomcat-sso/artifacts/application-policy.json | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/4124be80/samples/applications/tomcat-sso/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application-policy.json b/samples/applications/tomcat-sso/artifacts/application-policy.json
index 9d2c6a1..2c73f9a 100644
--- a/samples/applications/tomcat-sso/artifacts/application-policy.json
+++ b/samples/applications/tomcat-sso/artifacts/application-policy.json
@@ -1,7 +1,7 @@
 {
    "networkPartition":[
       {
-         "id":"network-partition-1",
+         "id":"network-partition-3",
          "activeByDefault":"true"
       }
    ]


[36/50] [abbrv] stratos git commit: Adding metadata service api methods to manager properties against applications

Posted by re...@apache.org.
Adding metadata service api methods to manager properties against applications


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

Branch: refs/heads/docker-grouping-merge
Commit: dd8d3d64f24f2f5e295ba116163d4fecfe9f6360
Parents: 716d517
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 15:19:16 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 15:19:16 2015 +0530

----------------------------------------------------------------------
 .../service/registry/CarbonRegistry.java        |  73 ++++++++++-
 .../metadata/service/registry/DataStore.java    |   9 +-
 .../service/services/MetaDataAdmin.java         | 126 ++++++++++++++++++-
 3 files changed, 198 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/dd8d3d64/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/CarbonRegistry.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/CarbonRegistry.java b/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/CarbonRegistry.java
index e52c028..559a492 100644
--- a/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/CarbonRegistry.java
+++ b/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/CarbonRegistry.java
@@ -48,6 +48,35 @@ public class CarbonRegistry implements DataStore {
     public CarbonRegistry() {
     }
 
+    public List<NewProperty> getApplicationProperties(String applicationName) throws RegistryException {
+        Registry tempRegistry = getRegistry();
+        String resourcePath = mainResource + applicationName;
+
+        if (!tempRegistry.resourceExists(resourcePath)) {
+            return null;
+        }
+
+        PrivilegedCarbonContext ctx = PrivilegedCarbonContext.getThreadLocalCarbonContext();
+        ctx.setTenantId(MultitenantConstants.SUPER_TENANT_ID);
+        ctx.setTenantDomain(MultitenantConstants.SUPER_TENANT_DOMAIN_NAME);
+
+        Resource regResource = tempRegistry.get(resourcePath);
+        ArrayList<NewProperty> newProperties = new ArrayList<NewProperty>();
+
+        Properties props = regResource.getProperties();
+        Enumeration<?> x = props.propertyNames();
+        while (x.hasMoreElements()) {
+            String key = (String) x.nextElement();
+            List<String> values = regResource.getPropertyValues(key);
+            NewProperty property = new NewProperty();
+            property.setKey(key);
+            String[] valueArr = new String[values.size()];
+            property.setValues(values.toArray(valueArr));
+
+            newProperties.add(property);
+        }
+        return newProperties;
+    }
 
     /**
      * Get Properties of clustor
@@ -57,7 +86,7 @@ public class CarbonRegistry implements DataStore {
      * @return
      * @throws RegistryException
      */
-    public List<NewProperty> getPropertiesOfCluster(String applicationName, String clusterId) throws RegistryException {
+    public List<NewProperty> getClusterProperties(String applicationName, String clusterId) throws RegistryException {
         Registry tempRegistry = getRegistry();
         String resourcePath = mainResource + applicationName + "/" + clusterId;
 
@@ -91,6 +120,46 @@ public class CarbonRegistry implements DataStore {
         return newProperties;
     }
 
+    public void addPropertiesToApplication(String applicationId, NewProperty[] properties) throws RegistryException {
+        for (NewProperty property : properties) {
+            addPropertyToApplication(applicationId, property);
+        }
+    }
+
+    public void addPropertyToApplication(String applicationId, NewProperty property) throws RegistryException {
+        Registry registry = getRegistry();
+        String resourcePath = mainResource + applicationId;
+
+        try {
+            PrivilegedCarbonContext ctx = PrivilegedCarbonContext.getThreadLocalCarbonContext();
+            ctx.setTenantId(MultitenantConstants.SUPER_TENANT_ID);
+            ctx.setTenantDomain(MultitenantConstants.SUPER_TENANT_DOMAIN_NAME);
+
+            registry.beginTransaction();
+            Resource nodeResource = null;
+            if (registry.resourceExists(resourcePath)) {
+                nodeResource = registry.get(resourcePath);
+            } else {
+                nodeResource = registry.newResource();
+                if (log.isDebugEnabled()) {
+                    log.debug("Registry resource is create at path for application: " + nodeResource.getPath());
+                }
+            }
+
+            nodeResource.setProperty(property.getKey(), Arrays.asList(property.getValues()));
+            registry.put(resourcePath, nodeResource);
+            registry.commitTransaction();
+
+            log.info(String.format("Registry property is persisted: [resource-path] %s [Property Name] %s [Property Values] %s",
+                    resourcePath, property.getKey(), Arrays.asList(property.getValues())));
+        } catch (Exception e) {
+            String msg = "Failed to persist properties in registry: " + resourcePath;
+            registry.rollbackTransaction();
+            log.error(msg, e);
+            throw new RegistryException(msg, e);
+        }
+    }
+
     /**
      * Add property to cluster
      *
@@ -133,7 +202,6 @@ public class CarbonRegistry implements DataStore {
             log.error(msg, e);
             throw new RegistryException(msg, e);
         }
-
     }
 
     private UserRegistry getRegistry() throws RegistryException {
@@ -185,7 +253,6 @@ public class CarbonRegistry implements DataStore {
     public void addPropertiesToCluster(String applicationName, String clusterId, NewProperty[] properties) throws RegistryException {
         for (NewProperty property : properties) {
             this.addPropertyToCluster(applicationName, clusterId, property);
-
         }
     }
 

http://git-wip-us.apache.org/repos/asf/stratos/blob/dd8d3d64/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/DataStore.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/DataStore.java b/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/DataStore.java
index f9f42bb..3e678ee 100644
--- a/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/DataStore.java
+++ b/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/registry/DataStore.java
@@ -29,10 +29,17 @@ import java.util.List;
  */
 public interface DataStore {
 
+    public void addPropertyToApplication(String applicationId, NewProperty property) throws RegistryException;
+
+    public void addPropertiesToApplication(String applicationName, NewProperty[] properties)
+            throws RegistryException;
+
     public void addPropertiesToCluster(String applicationName, String clusterId, NewProperty[] properties)
             throws RegistryException;
 
-    public List<NewProperty> getPropertiesOfCluster(String applicationName, String clusterId)
+    public List<NewProperty> getApplicationProperties(String applicationName) throws RegistryException;
+
+    public List<NewProperty> getClusterProperties(String applicationName, String clusterId)
             throws RegistryException;
 
     public void addPropertyToCluster(String applicationId, String clusterId, NewProperty property) throws RegistryException;

http://git-wip-us.apache.org/repos/asf/stratos/blob/dd8d3d64/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/services/MetaDataAdmin.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/services/MetaDataAdmin.java b/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/services/MetaDataAdmin.java
index 6b43d95..72bddd4 100644
--- a/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/services/MetaDataAdmin.java
+++ b/components/org.apache.stratos.metadata.service/src/main/java/org/apache/stratos/metadata/service/services/MetaDataAdmin.java
@@ -55,6 +55,38 @@ public class MetaDataAdmin {
     }
 
     @GET
+    @Path("/application/{application_id}/properties")
+    @Produces("application/json")
+    @Consumes("application/json")
+    @AuthorizationAction("/permission/protected/manage/monitor/tenants")
+    public Response getApplicationProperties(@PathParam("application_id") String applicationId)
+            throws RestAPIException {
+
+        List<NewProperty> properties;
+        NewProperty[] propertiesArr = null;
+        try {
+            properties = registry
+                    .getApplicationProperties(applicationId);
+            if (properties != null) {
+                propertiesArr = new NewProperty[properties.size()];
+                propertiesArr = properties.toArray(propertiesArr);
+            }
+        } catch (RegistryException e) {
+            String msg = "Error occurred while getting properties ";
+            log.error(msg, e);
+            throw new RestAPIException(msg, e);
+        }
+
+        Response.ResponseBuilder rb;
+        if (propertiesArr == null) {
+            rb = Response.status(Response.Status.NOT_FOUND);
+        } else {
+            rb = Response.ok().entity(propertiesArr);
+        }
+        return rb.build();
+    }
+
+    @GET
     @Path("/application/{application_id}/cluster/{cluster_id}/properties")
     @Produces("application/json")
     @Consumes("application/json")
@@ -65,7 +97,7 @@ public class MetaDataAdmin {
         NewProperty[] propertiesArr = null;
         try {
             properties = registry
-                    .getPropertiesOfCluster(applicationId, clusterId);
+                    .getClusterProperties(applicationId, clusterId);
             if (properties != null) {
                 propertiesArr = new NewProperty[properties.size()];
                 propertiesArr = properties.toArray(propertiesArr);
@@ -86,6 +118,44 @@ public class MetaDataAdmin {
     }
 
     @GET
+    @Path("/application/{application_id}/property/{property_name}")
+    @Produces("application/json")
+    @Consumes("application/json")
+    @AuthorizationAction("/permission/protected/manage/monitor/tenants")
+    public Response getApplicationProperty(@PathParam("application_id") String applicationId,
+                                           @PathParam("property_name") String propertyName)
+            throws RestAPIException {
+        List<NewProperty> properties;
+
+
+        NewProperty property = null;
+        try {
+            properties = registry.getApplicationProperties(applicationId);
+            if (properties == null) {
+                return Response.status(Response.Status.NOT_FOUND).build();
+            }
+            for (NewProperty p : properties) {
+                if (propertyName.equals(p.getKey())) {
+                    property = p;
+                    break;
+                }
+            }
+        } catch (RegistryException e) {
+            String msg = "Error occurred while getting property";
+            log.error(msg, e);
+            throw new RestAPIException(msg, e);
+        }
+
+        Response.ResponseBuilder rb;
+        if (property == null) {
+            rb = Response.status(Response.Status.NOT_FOUND);
+        } else {
+            rb = Response.ok().entity(property);
+        }
+        return rb.build();
+    }
+
+    @GET
     @Path("/application/{application_id}/cluster/{cluster_id}/property/{property_name}")
     @Produces("application/json")
     @Consumes("application/json")
@@ -95,10 +165,8 @@ public class MetaDataAdmin {
 
 
         NewProperty property = null;
-
         try {
-            properties = registry
-                    .getPropertiesOfCluster(applicationId, clusterId);
+            properties = registry.getClusterProperties(applicationId, clusterId);
             if (properties == null) {
                 return Response.status(Response.Status.NOT_FOUND).build();
             }
@@ -124,11 +192,36 @@ public class MetaDataAdmin {
     }
 
     @POST
+    @Path("application/{application_id}/property")
+    @Produces("application/json")
+    @Consumes("application/json")
+    @AuthorizationAction("/permission/protected/manage/monitor/tenants")
+    public Response addPropertyToApplication(@PathParam("application_id") String applicationId,
+                                             NewProperty property)
+            throws RestAPIException {
+
+        URI url = uriInfo.getAbsolutePathBuilder().path(applicationId + "/" + property.getKey()).build();
+        if (StringUtils.isEmpty(property.getKey())) {
+            throw new RestAPIException("Property key can not be empty");
+        }
+
+        try {
+            registry.addPropertyToApplication(applicationId, property);
+        } catch (RegistryException e) {
+            String msg = "Error occurred while adding property";
+            log.error(msg, e);
+            throw new RestAPIException(msg, e);
+        }
+        return Response.created(url).build();
+    }
+
+    @POST
     @Path("application/{application_id}/cluster/{cluster_id}/property")
     @Produces("application/json")
     @Consumes("application/json")
     @AuthorizationAction("/permission/protected/manage/monitor/tenants")
-    public Response addPropertyToACluster(@PathParam("application_id") String applicationId, @PathParam("cluster_id") String clusterId, NewProperty property)
+    public Response addPropertyToCluster(@PathParam("application_id") String applicationId,
+                                         @PathParam("cluster_id") String clusterId, NewProperty property)
             throws RestAPIException {
 
         URI url = uriInfo.getAbsolutePathBuilder().path(applicationId + "/" + clusterId + "/" + property.getKey()).build();
@@ -148,11 +241,32 @@ public class MetaDataAdmin {
     }
 
     @POST
+    @Path("application/{application_id}/properties")
+    @Produces("application/json")
+    @Consumes("application/json")
+    @AuthorizationAction("/permission/protected/manage/monitor/tenants")
+    public Response addPropertiesToApplication(@PathParam("application_id") String applicationId,
+                                               NewProperty[] properties)
+            throws RestAPIException {
+        URI url = uriInfo.getAbsolutePathBuilder().path(applicationId).build();
+
+        try {
+            registry.addPropertiesToApplication(applicationId, properties);
+        } catch (RegistryException e) {
+            String msg = "Error occurred while adding properties ";
+            log.error(msg, e);
+            throw new RestAPIException(msg, e);
+        }
+        return Response.created(url).build();
+    }
+
+    @POST
     @Path("application/{application_id}/cluster/{cluster_id}/properties")
     @Produces("application/json")
     @Consumes("application/json")
     @AuthorizationAction("/permission/protected/manage/monitor/tenants")
-    public Response addPropertiesToACluster(@PathParam("application_id") String applicationId, @PathParam("cluster_id") String clusterId, NewProperty[] properties)
+    public Response addPropertiesToCluster(@PathParam("application_id") String applicationId,
+                                           @PathParam("cluster_id") String clusterId, NewProperty[] properties)
             throws RestAPIException {
         URI url = uriInfo.getAbsolutePathBuilder().path(applicationId + "/" + clusterId).build();
 


[49/50] [abbrv] stratos git commit: Changed PORT_MAPPINGS port to KubernetesServicePort from port

Posted by re...@apache.org.
Changed PORT_MAPPINGS port to KubernetesServicePort from port


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

Branch: refs/heads/master
Commit: d0a0b85f485790a3ee1cc73c472b8314aae12358
Parents: 718cacd
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 23:52:31 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 .../stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/d0a0b85f/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index 34af6ac..c6064fe 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -542,7 +542,7 @@ public class KubernetesIaas extends Iaas {
                             portMappingStrBuilder.append(":");
                         }
                         portMappingStrBuilder.append(String.format("PROTOCOL:%s|PORT:%d|PROXY_PORT:%d",
-                                portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
+                                portMapping.getProtocol(), portMapping.getKubernetesServicePort(), portMapping.getProxyPort()));
 
                         if (log.isInfoEnabled()) {
                             log.info(String.format("Kubernetes service port generated: [cluster-id] %s [port] %d " +


[42/50] [abbrv] stratos git commit: Updating autoscaling logic to work with practical values

Posted by re...@apache.org.
Updating autoscaling logic to work with practical values


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

Branch: refs/heads/docker-grouping-merge
Commit: 08045d9cf13197ec32a8776e2f3abca354aa613a
Parents: 960e424
Author: Lahiru Sandaruwan <la...@apache.org>
Authored: Sun Mar 1 22:59:21 2015 +0530
Committer: Lahiru Sandaruwan <la...@apache.org>
Committed: Sun Mar 1 22:59:31 2015 +0530

----------------------------------------------------------------------
 .../autoscaler/rule/RuleTasksDelegator.java     | 27 +++++++++++++-------
 .../src/main/conf/drools/scaling.drl            |  6 +++--
 2 files changed, 22 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/08045d9c/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/rule/RuleTasksDelegator.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/rule/RuleTasksDelegator.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/rule/RuleTasksDelegator.java
index bb28bc5..66568af 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/rule/RuleTasksDelegator.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/rule/RuleTasksDelegator.java
@@ -86,27 +86,36 @@ public class RuleTasksDelegator {
     }
 
     public int getNumberOfInstancesRequiredBasedOnMemoryConsumption(float threshold, double predictedValue,
-                                                                    int activeInstanceCount) {
+                                                                    int min, int max) {
+        double numberOfAdditionalInstancesRequired = 0;
+        if(predictedValue != threshold) {
 
-        double numberOfInstances;
-        if(threshold != 0) {
+            float scalingRange = 100 - threshold;
+            int instanceRange = max - min;
 
-            numberOfInstances = (activeInstanceCount * predictedValue) / threshold;
-            return (int) Math.ceil(numberOfInstances);
+            if(instanceRange != 0){
+
+                float gradient = scalingRange / instanceRange;
+                numberOfAdditionalInstancesRequired = (predictedValue - threshold) / gradient;
+            }
+        }
+        if(min + numberOfAdditionalInstancesRequired > max){
+            return max;
+        } else {
+            return (int) Math.ceil(min + numberOfAdditionalInstancesRequired);
         }
-        return activeInstanceCount;
     }
 
     public int getNumberOfInstancesRequiredBasedOnLoadAverage(float threshold, double predictedValue,
-                                                              int activeInstanceCount) {
+                                                              int min) {
 
         double numberOfInstances;
         if(threshold != 0) {
 
-            numberOfInstances = (activeInstanceCount * predictedValue) / threshold;
+            numberOfInstances = (min * predictedValue) / threshold;
             return (int) Math.ceil(numberOfInstances);
         }
-        return activeInstanceCount;
+        return min;
     }
 
     public int getMaxNumberOfInstancesRequired(int numberOfInstancesRequiredBasedOnRif,

http://git-wip-us.apache.org/repos/asf/stratos/blob/08045d9c/products/stratos/modules/distribution/src/main/conf/drools/scaling.drl
----------------------------------------------------------------------
diff --git a/products/stratos/modules/distribution/src/main/conf/drools/scaling.drl b/products/stratos/modules/distribution/src/main/conf/drools/scaling.drl
index a871469..3d13308 100644
--- a/products/stratos/modules/distribution/src/main/conf/drools/scaling.drl
+++ b/products/stratos/modules/distribution/src/main/conf/drools/scaling.drl
@@ -84,12 +84,14 @@ dialect "mvel"
         laPredictedValue : Double() from delegator.getLoadAveragePredictedValue(clusterInstanceContext)
 
         activeInstancesCount : Integer() from clusterInstanceContext.getActiveMemberCount()
+        maxInstancesCount : Integer() from clusterInstanceContext.getMaxInstanceCount()
+        minInstancesCount : Integer() from clusterInstanceContext.getMinInstanceCount()
         requestsServedPerInstance : Float() from  clusterInstanceContext.getRequestsServedPerInstance()
         averageRequestsServedPerInstance : Float() from  clusterInstanceContext.getAverageRequestsServedPerInstance()
 
         numberOfInstancesReuquiredBasedOnRif : Integer() from delegator.getNumberOfInstancesRequiredBasedOnRif(rifPredictedValue, requestsServedPerInstance, averageRequestsServedPerInstance, arspiReset)
-        numberOfInstancesReuquiredBasedOnMemoryConsumption : Integer() from delegator.getNumberOfInstancesRequiredBasedOnMemoryConsumption(mcThreshold, mcPredictedValue, activeInstancesCount)
-        numberOfInstancesReuquiredBasedOnLoadAverage : Integer() from delegator.getNumberOfInstancesRequiredBasedOnLoadAverage(laThreshold, laPredictedValue, activeInstancesCount)
+        numberOfInstancesReuquiredBasedOnMemoryConsumption : Integer() from delegator.getNumberOfInstancesRequiredBasedOnMemoryConsumption(mcThreshold, mcPredictedValue, minInstancesCount, maxInstancesCount)
+        numberOfInstancesReuquiredBasedOnLoadAverage : Integer() from delegator.getNumberOfInstancesRequiredBasedOnLoadAverage(laThreshold, laPredictedValue, minInstancesCount)
 
         numberOfRequiredInstances : Integer() from delegator.getMaxNumberOfInstancesRequired(numberOfInstancesReuquiredBasedOnRif, numberOfInstancesReuquiredBasedOnMemoryConsumption ,mcReset ,numberOfInstancesReuquiredBasedOnLoadAverage, laReset) 
 


[21/50] [abbrv] stratos git commit: Updating integration test execution method and activemq bind port

Posted by re...@apache.org.
Updating integration test execution method and activemq bind port


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

Branch: refs/heads/docker-grouping-merge
Commit: 16a8ef5765db66e66b9d6eb28eaba0352f3f3ee9
Parents: 9b25a04
Author: Imesh Gunaratne <im...@apache.org>
Authored: Fri Feb 27 23:56:02 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Fri Feb 27 23:56:02 2015 +0530

----------------------------------------------------------------------
 .../integration/tests/SampleApplicationsTest.java     | 14 ++++++++++----
 .../integration/tests/StratosTestServerManager.java   |  2 +-
 .../integration/src/test/resources/jndi.properties    |  2 +-
 3 files changed, 12 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/16a8ef57/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/SampleApplicationsTest.java
----------------------------------------------------------------------
diff --git a/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/SampleApplicationsTest.java b/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/SampleApplicationsTest.java
index abc7e2e..f916083 100644
--- a/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/SampleApplicationsTest.java
+++ b/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/SampleApplicationsTest.java
@@ -60,16 +60,22 @@ public class SampleApplicationsTest extends StratosTestServerManager {
         try {
             initializeApplicationEventReceiver();
 
-            String scriptPath = getApplicationsPath() + "/single-cartridge/scripts/mock/deploy.sh";
-            executeCommand(scriptPath);
-
-            assertApplicationActivation("single-cartridge-app");
+            runApplicationTest("single-cartridge", "single-cartridge-app");
         } catch (Exception e) {
             log.error(e);
             assertTrue("An error occurred", false);
         }
     }
 
+    private void runApplicationTest(String applicationId) {
+        runApplicationTest(applicationId, applicationId);
+    }
+
+    private void runApplicationTest(String applicationFolderName, String applicationId) {
+        executeCommand(getApplicationsPath() + "/" + applicationFolderName + "/scripts/mock/deploy.sh");
+        assertApplicationActivation(applicationId);
+    }
+
     /**
      * Initialize application event receiver
      */

http://git-wip-us.apache.org/repos/asf/stratos/blob/16a8ef57/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
----------------------------------------------------------------------
diff --git a/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java b/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
index 2d1deac..fd74f75 100755
--- a/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
+++ b/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
@@ -49,7 +49,7 @@ public class StratosTestServerManager extends TestServerManager {
     private final static String CARBON_ZIP = SampleApplicationsTest.class.getResource("/").getPath() +
             "/../../../distribution/target/apache-stratos-4.1.0-SNAPSHOT.zip";
     private final static int PORT_OFFSET = 0;
-    private static final String ACTIVEMQ_BIND_ADDRESS = "tcp://localhost:61616";
+    private static final String ACTIVEMQ_BIND_ADDRESS = "tcp://localhost:61617";
     private static final String MOCK_IAAS_XML = "mock-iaas.xml";
 
     private ServerUtils serverUtils;

http://git-wip-us.apache.org/repos/asf/stratos/blob/16a8ef57/products/stratos/modules/integration/src/test/resources/jndi.properties
----------------------------------------------------------------------
diff --git a/products/stratos/modules/integration/src/test/resources/jndi.properties b/products/stratos/modules/integration/src/test/resources/jndi.properties
index 21d7420..beefe3c 100644
--- a/products/stratos/modules/integration/src/test/resources/jndi.properties
+++ b/products/stratos/modules/integration/src/test/resources/jndi.properties
@@ -18,5 +18,5 @@
 #
 
 connectionfactoryName=TopicConnectionFactory
-java.naming.provider.url=tcp://localhost:61616
+java.naming.provider.url=tcp://localhost:61617
 java.naming.factory.initial=org.apache.activemq.jndi.ActiveMQInitialContextFactory


[08/50] [abbrv] stratos git commit: fixing a NPE in rest API

Posted by re...@apache.org.
fixing a NPE in rest API


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

Branch: refs/heads/docker-grouping-merge
Commit: bf8b3dc16c40edc5ecb0490c752da66c944edf39
Parents: 9cc8e30
Author: R-Rajkumar <rr...@gmail.com>
Authored: Fri Feb 27 16:01:17 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:43:39 2015 +0530

----------------------------------------------------------------------
 .../apache/stratos/rest/endpoint/api/StratosApiV41Utils.java   | 6 ++++++
 1 file changed, 6 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/bf8b3dc1/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41Utils.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41Utils.java b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41Utils.java
index e3a44c5..c8f6337 100644
--- a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41Utils.java
+++ b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41Utils.java
@@ -1008,6 +1008,12 @@ public class StratosApiV41Utils {
                 log.error(message);
                 throw new RestAPIException(message);
             }
+            if (applicationPolicy == null) {
+                String message = String.format("Application policy cannot be null : [application-id] %s. "
+                		+ "Are you passing application policy?", applicationId);
+                log.error(message);
+                throw new RestAPIException(message);
+			}
 
             ApplicationBean applicationBean = getApplication(applicationId);
             int tenantId = CarbonContext.getThreadLocalCarbonContext().getTenantId();


[09/50] [abbrv] stratos git commit: fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class

Posted by re...@apache.org.
fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class


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

Branch: refs/heads/docker-grouping-merge
Commit: 90f3480b3920bf0c6b6008c3a65c50886da3582a
Parents: bf8b3dc
Author: R-Rajkumar <rr...@gmail.com>
Authored: Fri Feb 27 16:30:57 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:44:04 2015 +0530

----------------------------------------------------------------------
 .../iaases/kubernetes/KubernetesIaas.java       |   2 +-
 .../main/resources/CloudControllerService.wsdl  | 249 ++++++++++++++++---
 2 files changed, 212 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/90f3480b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index 47e620c..4ba2393 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -390,7 +390,7 @@ public class KubernetesIaas extends Iaas {
 
         // Add pod id to member context and persist
         memberContext.setKubernetesPodId(podId);
-        memberContext.setKubernetesPodLabel(podLabel);
+        memberContext.setKubernetesPodName(podLabel);
         CloudControllerContext.getInstance().persist();
 
         if (log.isInfoEnabled()) {

http://git-wip-us.apache.org/repos/asf/stratos/blob/90f3480b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
index ee7f352..07cdf86 100644
--- a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
+++ b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
@@ -97,6 +97,7 @@
                 </xs:complexType>
             </xs:element>
 <<<<<<< HEAD
+<<<<<<< HEAD
             <xs:element name="getDeploymentPolicies">
                 <xs:complexType>
                     <xs:sequence></xs:sequence>
@@ -317,11 +318,17 @@
                     <xs:sequence>
                         <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax21:CartridgeNotFoundException"/>
                     </xs:sequence>
+=======
+            <xs:element name="getDeploymentPolicies">
+                <xs:complexType>
+                    <xs:sequence></xs:sequence>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCloudControllerException">
+            <xs:element name="getDeploymentPoliciesResponse">
                 <xs:complexType>
                     <xs:sequence>
+<<<<<<< HEAD
                         <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax21:CloudControllerException"/>
                     </xs:sequence>
                 </xs:complexType>
@@ -732,6 +739,37 @@
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"></xs:element>
+=======
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax222:InvalidCartridgeDefinitionException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax222:CartridgeAlreadyExistsException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="addCartridge">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -764,7 +802,18 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+<<<<<<< HEAD
             <xs:element name="getServiceGroupCartridges">
+=======
+            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax222:InvalidCartridgeTypeException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="removeCartridge">
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
@@ -936,6 +985,7 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+<<<<<<< HEAD
             <xs:element name="getServiceGroupDependenciesResponse">
                 <xs:complexType>
                     <xs:sequence>
@@ -951,6 +1001,9 @@
                 </xs:complexType>
             </xs:element>
             <xs:element name="validatePartition">
+=======
+            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="partition" nillable="true" type="ax26:Partition"/>
@@ -1027,6 +1080,7 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+<<<<<<< HEAD
             <xs:element name="validateDeploymentPolicy">
                 <xs:complexType>
                     <xs:sequence>
@@ -1062,6 +1116,8 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+=======
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
             <xs:element name="CloudControllerServiceInvalidServiceGroupException">
                 <xs:complexType>
                     <xs:sequence>
@@ -1112,6 +1168,20 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax222:CartridgeNotFoundException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="CloudControllerServiceCloudControllerException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
             <xs:element name="startInstances">
                 <xs:complexType>
                     <xs:sequence>
@@ -1476,11 +1546,12 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addServiceGroup">
+            <xs:element name="CloudControllerServiceUnregisteredClusterException">
                 <xs:complexType>
                     <xs:sequence>
 <<<<<<< HEAD
 <<<<<<< HEAD
+<<<<<<< HEAD
                         <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
 >>>>>>> Add deployment policy
                     </xs:sequence>
@@ -1522,22 +1593,30 @@
             </xs:element>
             <xs:element name="getServiceGroup">
 >>>>>>> fixing merging issues
+=======
+                        <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax222:UnregisteredClusterException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="unregisterService">
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="startInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:ServiceGroup"></xs:element>
+                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax224:InstanceContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceUnregisteredClusterException">
+            <xs:element name="startInstanceResponse">
                 <xs:complexType>
                     <xs:sequence>
+<<<<<<< HEAD
                         <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax222:UnregisteredClusterException"></xs:element>
 <<<<<<< HEAD
 >>>>>>> fixing STRATOS-1214 - deployement policy changes
@@ -1587,15 +1666,19 @@
 >>>>>>> fixing STRATOS-1214 - deployement policy changes
 =======
 >>>>>>> fixing merging issues
+=======
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="unregisterService">
+            <xs:element name="CloudControllerServiceInvalidMemberException">
                 <xs:complexType>
                     <xs:sequence>
 <<<<<<< HEAD
 <<<<<<< HEAD
 <<<<<<< HEAD
+<<<<<<< HEAD
                         <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax224:ServiceGroup"></xs:element>
 <<<<<<< HEAD
 >>>>>>> Add deployment policy
@@ -1613,6 +1696,23 @@
 =======
                         <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
 >>>>>>> fixing merging issues
+=======
+                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax222:InvalidMemberException"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="terminateInstance">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="addServiceGroup">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax224:ServiceGroup"></xs:element>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -1658,6 +1758,7 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+<<<<<<< HEAD
             <xs:element name="updateKubernetesMaster">
                 <xs:complexType>
                     <xs:sequence>
@@ -1683,6 +1784,22 @@
 >>>>>>> fixing STRATOS-1214 - deployement policy changes
 >>>>>>> fixing STRATOS-1214 - deployement policy changes
 =======
+=======
+            <xs:element name="getServiceGroup">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getServiceGroupResponse">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:ServiceGroup"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
             <xs:element name="registerService">
                 <xs:complexType>
                     <xs:sequence>
@@ -1771,13 +1888,17 @@
             <xs:complexType name="DeploymentPolicyNotExistsException">
                 <xs:sequence></xs:sequence>
             </xs:complexType>
+<<<<<<< HEAD
             <xs:complexType name="InvalidMemberException">
 >>>>>>> fixing merging issues
+=======
+            <xs:complexType name="InvalidCartridgeDefinitionException">
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidCartridgeTypeException">
+            <xs:complexType name="InvalidIaasProviderException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
@@ -1796,6 +1917,7 @@
                 <xs:sequence></xs:sequence>
 >>>>>>> Add deployment policy
             </xs:complexType>
+<<<<<<< HEAD
 =======
 >>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
             <xs:complexType name="CartridgeDefinitionNotExistsException">
@@ -1815,13 +1937,17 @@
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                 </xs:sequence>
+=======
+            <xs:complexType name="CartridgeAlreadyExistsException">
+                <xs:sequence></xs:sequence>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
             </xs:complexType>
-            <xs:complexType name="InvalidIaasProviderException">
+            <xs:complexType name="CartridgeDefinitionNotExistsException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="CartridgeDefinitionNotExistsException">
+            <xs:complexType name="InvalidCartridgeTypeException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
@@ -1902,6 +2028,7 @@
 <<<<<<< HEAD
 <<<<<<< HEAD
 <<<<<<< HEAD
+<<<<<<< HEAD
             <xs:complexType name="UnregisteredClusterException">
 =======
 =======
@@ -1926,6 +2053,8 @@
                 <xs:sequence></xs:sequence>
             </xs:complexType>
 >>>>>>> fixing merging issues
+=======
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
             <xs:complexType name="InvalidKubernetesClusterException">
 >>>>>>> Add deployment policy
                 <xs:sequence>
@@ -1934,6 +2063,7 @@
             </xs:complexType>
 <<<<<<< HEAD
 <<<<<<< HEAD
+<<<<<<< HEAD
             <xs:complexType name="ApplicationClusterRegistrationException">
 =======
             <xs:complexType name="InvalidServiceGroupException">
@@ -1941,12 +2071,16 @@
 =======
             <xs:complexType name="CartridgeNotFoundException">
 >>>>>>> fixing merging issues
+=======
+            <xs:complexType name="InvalidServiceGroupException">
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
 <<<<<<< HEAD
 <<<<<<< HEAD
+<<<<<<< HEAD
             <xs:complexType name="ClusterInstanceCreationException">
 =======
             <xs:complexType name="CartridgeNotFoundException">
@@ -1954,10 +2088,20 @@
 =======
             <xs:complexType name="InvalidServiceGroupException">
 >>>>>>> fixing merging issues
+=======
+            <xs:complexType name="CartridgeNotFoundException">
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
+            <xs:complexType name="CloudControllerException">
+                <xs:complexContent>
+                    <xs:extension base="xs:RuntimeException">
+                        <xs:sequence></xs:sequence>
+                    </xs:extension>
+                </xs:complexContent>
+            </xs:complexType>
             <xs:complexType name="InvalidClusterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
@@ -2022,6 +2166,11 @@
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                 </xs:sequence>
             </xs:complexType>
+            <xs:complexType name="InvalidMemberException">
+                <xs:sequence>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                </xs:sequence>
+            </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://domain.common.stratos.apache.org/xsd">
             <xs:complexType name="NameValuePair">
@@ -2295,6 +2444,7 @@
                     <xs:element minOccurs="0" name="portUuid" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
+<<<<<<< HEAD
             <xs:complexType name="FloatingNetworks">
                 <xs:sequence>
 <<<<<<< HEAD
@@ -2303,6 +2453,14 @@
             </xs:complexType>
             <xs:complexType name="FloatingNetwork">
 =======
+=======
+            <xs:complexType name="Dependencies">
+                <xs:sequence>
+                    <xs:element minOccurs="0" name="killBehaviour" nillable="true" type="xs:string"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"></xs:element>
+                </xs:sequence>
+            </xs:complexType>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
             <xs:complexType name="InstanceContext">
 >>>>>>> fixing merging issues
                 <xs:sequence>
@@ -2380,6 +2538,7 @@
                 </xs:sequence>
             </xs:complexType>
 <<<<<<< HEAD
+<<<<<<< HEAD
             <xs:complexType name="Volume">
                 <xs:sequence>
 <<<<<<< HEAD
@@ -2410,6 +2569,8 @@
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"></xs:element>
                 </xs:sequence>
             </xs:complexType>
+=======
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
             <xs:complexType name="CartridgeInfo">
                 <xs:sequence>
 >>>>>>> fixing merging issues
@@ -2958,18 +3119,27 @@
     <wsdl:message name="removeCartridgeRequest">
         <wsdl:part name="parameters" element="ns:removeCartridge"/>
     </wsdl:message>
+<<<<<<< HEAD
     <wsdl:message name="addCartridgeRequest">
         <wsdl:part name="parameters" element="ns:addCartridge"/>
     </wsdl:message>
     <wsdl:message name="CloudControllerServiceCartridgeAlreadyExistsException">
         <wsdl:part name="parameters" element="ns:CloudControllerServiceCartridgeAlreadyExistsException"/>
     </wsdl:message>
+=======
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
     <wsdl:message name="getNetworkPartitionsRequest">
         <wsdl:part name="parameters" element="ns:getNetworkPartitions"></wsdl:part>
     </wsdl:message>
     <wsdl:message name="getNetworkPartitionsResponse">
         <wsdl:part name="parameters" element="ns:getNetworkPartitionsResponse"></wsdl:part>
     </wsdl:message>
+    <wsdl:message name="addCartridgeRequest">
+        <wsdl:part name="parameters" element="ns:addCartridge"></wsdl:part>
+    </wsdl:message>
+    <wsdl:message name="CloudControllerServiceCartridgeAlreadyExistsException">
+        <wsdl:part name="parameters" element="ns:CloudControllerServiceCartridgeAlreadyExistsException"></wsdl:part>
+    </wsdl:message>
     <wsdl:portType name="CloudControllerServicePortType">
         <wsdl:operation name="getDeploymentPolicies">
             <wsdl:input message="ns:getDeploymentPoliciesRequest" wsaw:Action="urn:getDeploymentPolicies"></wsdl:input>
@@ -3203,16 +3373,16 @@
             <wsdl:input message="ns:removeCartridgeRequest" wsaw:Action="urn:removeCartridge"/>
             <wsdl:fault message="ns:CloudControllerServiceInvalidCartridgeTypeException" name="CloudControllerServiceInvalidCartridgeTypeException" wsaw:Action="urn:removeCartridgeCloudControllerServiceInvalidCartridgeTypeException"/>
         </wsdl:operation>
+        <wsdl:operation name="getNetworkPartitions">
+            <wsdl:input message="ns:getNetworkPartitionsRequest" wsaw:Action="urn:getNetworkPartitions"></wsdl:input>
+            <wsdl:output message="ns:getNetworkPartitionsResponse" wsaw:Action="urn:getNetworkPartitionsResponse"></wsdl:output>
+        </wsdl:operation>
         <wsdl:operation name="addCartridge">
             <wsdl:input message="ns:addCartridgeRequest" wsaw:Action="urn:addCartridge"/>
             <wsdl:fault message="ns:CloudControllerServiceInvalidCartridgeDefinitionException" name="CloudControllerServiceInvalidCartridgeDefinitionException" wsaw:Action="urn:addCartridgeCloudControllerServiceInvalidCartridgeDefinitionException"/>
             <wsdl:fault message="ns:CloudControllerServiceInvalidIaasProviderException" name="CloudControllerServiceInvalidIaasProviderException" wsaw:Action="urn:addCartridgeCloudControllerServiceInvalidIaasProviderException"/>
             <wsdl:fault message="ns:CloudControllerServiceCartridgeAlreadyExistsException" name="CloudControllerServiceCartridgeAlreadyExistsException" wsaw:Action="urn:addCartridgeCloudControllerServiceCartridgeAlreadyExistsException"/>
         </wsdl:operation>
-        <wsdl:operation name="getNetworkPartitions">
-            <wsdl:input message="ns:getNetworkPartitionsRequest" wsaw:Action="urn:getNetworkPartitions"></wsdl:input>
-            <wsdl:output message="ns:getNetworkPartitionsResponse" wsaw:Action="urn:getNetworkPartitionsResponse"></wsdl:output>
-        </wsdl:operation>
     </wsdl:portType>
     <wsdl:binding name="CloudControllerServiceSoap11Binding" type="ns:CloudControllerServicePortType">
 <<<<<<< HEAD
@@ -3742,15 +3912,6 @@
                 <soap:fault use="literal" name="CloudControllerServiceInvalidCartridgeTypeException"/>
             </wsdl:fault>
         </wsdl:operation>
-        <wsdl:operation name="getNetworkPartitions">
-            <soap:operation soapAction="urn:getNetworkPartitions" style="document"></soap:operation>
-            <wsdl:input>
-                <soap:body use="literal"></soap:body>
-            </wsdl:input>
-            <wsdl:output>
-                <soap:body use="literal"></soap:body>
-            </wsdl:output>
-        </wsdl:operation>
         <wsdl:operation name="addCartridge">
             <soap:operation soapAction="urn:addCartridge" style="document"/>
             <wsdl:input>
@@ -3766,6 +3927,15 @@
                 <soap:fault use="literal" name="CloudControllerServiceCartridgeAlreadyExistsException"/>
             </wsdl:fault>
         </wsdl:operation>
+        <wsdl:operation name="getNetworkPartitions">
+            <soap:operation soapAction="urn:getNetworkPartitions" style="document"></soap:operation>
+            <wsdl:input>
+                <soap:body use="literal"></soap:body>
+            </wsdl:input>
+            <wsdl:output>
+                <soap:body use="literal"></soap:body>
+            </wsdl:output>
+        </wsdl:operation>
     </wsdl:binding>
     <wsdl:binding name="CloudControllerServiceSoap12Binding" type="ns:CloudControllerServicePortType">
 <<<<<<< HEAD
@@ -4291,15 +4461,6 @@
                 <soap12:fault use="literal" name="CloudControllerServiceInvalidCartridgeTypeException"/>
             </wsdl:fault>
         </wsdl:operation>
-        <wsdl:operation name="getNetworkPartitions">
-            <soap12:operation soapAction="urn:getNetworkPartitions" style="document"></soap12:operation>
-            <wsdl:input>
-                <soap12:body use="literal"></soap12:body>
-            </wsdl:input>
-            <wsdl:output>
-                <soap12:body use="literal"></soap12:body>
-            </wsdl:output>
-        </wsdl:operation>
         <wsdl:operation name="addCartridge">
             <soap12:operation soapAction="urn:addCartridge" style="document"/>
             <wsdl:input>
@@ -4315,6 +4476,15 @@
                 <soap12:fault use="literal" name="CloudControllerServiceCartridgeAlreadyExistsException"/>
             </wsdl:fault>
         </wsdl:operation>
+        <wsdl:operation name="getNetworkPartitions">
+            <soap12:operation soapAction="urn:getNetworkPartitions" style="document"></soap12:operation>
+            <wsdl:input>
+                <soap12:body use="literal"></soap12:body>
+            </wsdl:input>
+            <wsdl:output>
+                <soap12:body use="literal"></soap12:body>
+            </wsdl:output>
+        </wsdl:operation>
     </wsdl:binding>
     <wsdl:binding name="CloudControllerServiceHttpBinding" type="ns:CloudControllerServicePortType">
 <<<<<<< HEAD
@@ -4683,6 +4853,7 @@
             </wsdl:input>
         </wsdl:operation>
 <<<<<<< HEAD
+<<<<<<< HEAD
         <wsdl:operation name="addCartridge">
             <http:operation location="addCartridge"/>
             <wsdl:input>
@@ -4691,6 +4862,14 @@
         </wsdl:operation>
 =======
 >>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
+=======
+        <wsdl:operation name="addCartridge">
+            <http:operation location="addCartridge"></http:operation>
+            <wsdl:input>
+                <mime:content type="text/xml" part="parameters"></mime:content>
+            </wsdl:input>
+        </wsdl:operation>
+>>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
         <wsdl:operation name="getNetworkPartitions">
             <http:operation location="getNetworkPartitions"></http:operation>
             <wsdl:input>
@@ -4700,12 +4879,6 @@
                 <mime:content type="text/xml" part="parameters"></mime:content>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="addCartridge">
-            <http:operation location="addCartridge"></http:operation>
-            <wsdl:input>
-                <mime:content type="text/xml" part="parameters"></mime:content>
-            </wsdl:input>
-        </wsdl:operation>
     </wsdl:binding>
     <wsdl:service name="CloudControllerService">
         <wsdl:port name="CloudControllerServiceHttpSoap11Endpoint" binding="ns:CloudControllerServiceSoap11Binding">


[47/50] [abbrv] stratos git commit: Samples - Added METADATA_SERVICE_URL to kubernetes cluster definition for ec2

Posted by re...@apache.org.
Samples - Added METADATA_SERVICE_URL to kubernetes cluster definition for ec2


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

Branch: refs/heads/master
Commit: 718cacd37b5cc6da1d82ba9b4de4e73f431fea89
Parents: 188377a
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 23:29:04 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 samples/kubernetes-clusters/kubernetes-cluster-ec2.json | 4 ++++
 1 file changed, 4 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/718cacd3/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
----------------------------------------------------------------------
diff --git a/samples/kubernetes-clusters/kubernetes-cluster-ec2.json b/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
index 94cb4bf..0affc00 100644
--- a/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
+++ b/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
@@ -59,6 +59,10 @@
         {
             "name": "payload_parameter.LOG_LEVEL",
             "value": "DEBUG"
+        },
+        {
+            "name": "payload_parameter.METADATA_SERVICE_URL",
+            "value": "https://54.179.197.243:9443"
         }
     ]
 }


[46/50] [abbrv] stratos git commit: Tomcat and WSO2 IS SAML SSO docker files added with PCA plugins Changed PORT_MAPPINGS payload format in KubernetesIaaS

Posted by re...@apache.org.
Tomcat and WSO2 IS SAML SSO docker files added with PCA plugins
Changed PORT_MAPPINGS payload format in KubernetesIaaS


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

Branch: refs/heads/master
Commit: 188377afe2732ea867d233a1a2eb03f062586749
Parents: f9948c5
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 23:20:03 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 .../iaases/kubernetes/KubernetesIaas.java       |   2 +-
 .../cartridge.agent/cartridge.agent/config.py   |   5 +-
 .../cartridge.agent/plugins/TestPlugin.py       |  26 -
 .../plugins/TestPlugin.yapsy-plugin             |   9 -
 .../base-image/files/populate-user-data.sh      |   4 +-
 .../base-image/files/run                        |  15 +-
 .../service-images/tomcat-saml-sso/Dockerfile   |  46 ++
 .../tomcat-saml-sso/files/create-admin-user.sh  |  21 +
 .../service-images/tomcat-saml-sso/files/env    |   2 +
 .../packs/plugins/TomcatServerStarterPlugin.py  |  59 ++
 .../TomcatServerStarterPlugin.yapsy-plugin      |   9 +
 .../plugins/TomcatWSO2ISMetadataPublisher.py    |  55 ++
 .../TomcatWSO2ISMetadataPublisher.yapsy-plugin  |   9 +
 .../service-images/wso2is-saml-sso/Dockerfile   |  39 ++
 .../wso2is-saml-sso/files/carbon.xml            | 625 +++++++++++++++++++
 .../service-images/wso2is-saml-sso/files/env    |   2 +
 .../packs/plugins/WSO2ISMetaDataHandler.py      | 144 +++++
 .../plugins/WSO2ISMetaDataHandler.yapsy-plugin  |   9 +
 18 files changed, 1040 insertions(+), 41 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index d8b06fc..34af6ac 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -541,7 +541,7 @@ public class KubernetesIaas extends Iaas {
                         if (portMappingStrBuilder.toString().length() > 0) {
                             portMappingStrBuilder.append(":");
                         }
-                        portMappingStrBuilder.append(String.format("PROTOCOL=%s|PORT=%d|PROXY_PORT=%d",
+                        portMappingStrBuilder.append(String.format("PROTOCOL:%s|PORT:%d|PROXY_PORT:%d",
                                 portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
 
                         if (log.isInfoEnabled()) {

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
index 1ad9499..5f5f07d 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
@@ -297,7 +297,10 @@ class CartridgeAgentConfiguration:
                         if param.strip() != "":
                             param_value = param.strip().split("=")
                             try:
-                                self.__payload_params[param_value[0]] = param_value[1]
+                                if str(param_value[1]).strip().lower() == "null" or str(param_value[1]).strip() == "":
+                                    self.__payload_params[param_value[0]] = None
+                                else:
+                                    self.__payload_params[param_value[0]] = param_value[1]
                             except IndexError:
                                 # If an index error comes when reading values, keep on reading
                                 pass

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py
deleted file mode 100644
index e4c69f6..0000000
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py
+++ /dev/null
@@ -1,26 +0,0 @@
-# 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.
-
-from plugins.contracts import ICartridgeAgentPlugin
-
-
-class TestPlugin(ICartridgeAgentPlugin):
-
-    def run_plugin(self, values, log):
-        log.debug("Running test plugin for event %s" % values["EVENT"])
-        for key, value in values.iteritems():
-            log.debug("%s => %s" % (key, value))
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin
deleted file mode 100644
index d321048..0000000
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin
+++ /dev/null
@@ -1,9 +0,0 @@
-[Core]
-Name = Test plugin for MemberInitializedEvent and ArtifactUpdatedEvent
-Module = TestPlugin
-
-[Documentation]
-Description = MemberInitializedEvent,ArtifactUpdatedEvent
-Author = Op1
-Version = 0.1
-Website = stratos.apache.org
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh b/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
index dce722d..522b392 100755
--- a/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
+++ b/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
@@ -22,4 +22,6 @@
 
 # Persists the payload parameters by storing the environment variables in the launch-params file
 
-echo "APPLICATION_ID=${APPLICATION_ID},APPLICATION_PATH=${APPLICATION_PATH},SERVICE_NAME=${SERVICE_NAME},HOST_NAME=${HOST_NAME},MULTITENANT=false,TENANT_ID=${TENANT_ID},TENANT_RANGE=*,CARTRIDGE_ALIAS=${CARTRIDGE_ALIAS},CLUSTER_ID=${CLUSTER_ID},CLUSTER_INSTANCE_ID=${CLUSTER_INSTANCE_ID},CARTRIDGE_KEY=${CARTRIDGE_KEY},DEPLOYMENT=${DEPLOYMENT},REPO_URL=${REPO_URL},PORTS=${PORTS},PUPPET_IP=${PUPPET_IP},PUPPET_HOSTNAME=${PUPPET_HOSTNAME},PUPPET_ENV=${PUPPET_ENV},MEMBER_ID=${MEMBER_ID},LB_CLUSTER_ID=${LB_CLUSTER_ID},NETWORK_PARTITION_ID=${NETWORK_PARTITION_ID},PARTITION_ID=${PARTITION_ID},MIN_COUNT=${MIN_COUNT},INTERNAL=${INTERNAL},CLUSTERING_PRIMARY_KEY=${CLUSTERING_PRIMARY_KEY}" >> /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/payload/launch-params
+#echo "APPLICATION_ID=${APPLICATION_ID},APPLICATION_PATH=${APPLICATION_PATH},SERVICE_NAME=${SERVICE_NAME},HOST_NAME=${HOST_NAME},MULTITENANT=false,TENANT_ID=${TENANT_ID},TENANT_RANGE=*,CARTRIDGE_ALIAS=${CARTRIDGE_ALIAS},CLUSTER_ID=${CLUSTER_ID},CLUSTER_INSTANCE_ID=${CLUSTER_INSTANCE_ID},CARTRIDGE_KEY=${CARTRIDGE_KEY},DEPLOYMENT=${DEPLOYMENT},REPO_URL=${REPO_URL},PORTS=${PORTS},PUPPET_IP=${PUPPET_IP},PUPPET_HOSTNAME=${PUPPET_HOSTNAME},PUPPET_ENV=${PUPPET_ENV},MEMBER_ID=${MEMBER_ID},LB_CLUSTER_ID=${LB_CLUSTER_ID},NETWORK_PARTITION_ID=${NETWORK_PARTITION_ID},PARTITION_ID=${PARTITION_ID},MIN_COUNT=${MIN_COUNT},INTERNAL=${INTERNAL},CLUSTERING_PRIMARY_KEY=${CLUSTERING_PRIMARY_KEY}" >> /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/payload/launch-params
+
+set -o posix ; set | sed -e ':a;N;$!ba;s/\n/,/g' > /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/payload/launch-params
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/base-image/files/run
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/base-image/files/run b/tools/docker-images/cartridge-docker-images/base-image/files/run
index 513e6e7..69f45b6 100755
--- a/tools/docker-images/cartridge-docker-images/base-image/files/run
+++ b/tools/docker-images/cartridge-docker-images/base-image/files/run
@@ -160,9 +160,15 @@ else
 fi
 
 if [ -z "${APPLICATION_PATH}" ]; then
-	sed -i "s/APPLICATION_PATH/ /g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+	sed -i "s/APPLICATION-PATH/ /g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
 else
-	sed -i "s#APPLICATION_PATH#${APPLICATION_PATH}#g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+	sed -i "s#APPLICATION-PATH#${APPLICATION_PATH}#g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+fi
+
+if [ -z "${METADATA_SERVICE_URL}" ]; then
+	sed -i "s/METADATA-SERVICE-URL/ /g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+else
+	sed -i "s#METADATA-SERVICE-URL#${METADATA_SERVICE_URL}#g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
 fi
 
 if [ -z "${LOG_LEVEL}" ]; then
@@ -171,7 +177,10 @@ else
 	sed -i "s/LOG_LEVEL/${LOG_LEVEL}/g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/logging.ini
 fi
 
+# copy plugins to PCA
+cp -R /mnt/plugins /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/
+
 # Start cartridge agent
 cd /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT
 python agent.py > /tmp/agent.screen.log 2>&1 &
-/usr/sbin/apache2ctl -D FOREGROUND
+#/usr/sbin/apache2ctl -D FOREGROUND

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile
new file mode 100644
index 0000000..1096d45
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile
@@ -0,0 +1,46 @@
+FROM chamilad/base-image:4.1.0-beta
+MAINTAINER dev@stratos.apache.org
+
+# ----------------------
+# Install prerequisites
+# ----------------------
+# RUN apt-get update && \ apt-get install -yq --no-install-recommends openjdk-7-jre wget ca-certificates && \apt-get clean && \rm -rf /var/lib/apt/lists/*
+WORKDIR /opt
+# RUN wget --no-check-certificate --no-cookies --header "Cookie: oraclelicense=accept-securebackup-cookie" http://download.oracle.com/otn-pub/java/jdk/7u67-b01/jdk-7u67-linux-x64.tar.gz
+ADD packs/jdk-7u67-linux-x64.tar.gz /mnt/jdk-7u67-linux-x64.tar.gz
+# RUN tar zxvf /mnt/jdk-7u67-linux-x64.tar.gz
+RUN mv /mnt/jdk-7u67-linux-x64.tar.gz/jdk1.7.0_67 /opt/jdk1.7.0_67
+ENV JAVA_HOME /opt/jdk1.7.0_67
+
+
+ENV CATALINA_HOME /opt/tomcat
+
+# ----------------------
+# Install Tomcat
+# ----------------------
+ADD packs/apache-tomcat-7.0.59.tar.gz /opt/apache-tomcat-7.0.59.tar.gz
+RUN mv /opt/apache-tomcat-7.0.59.tar.gz/apache-tomcat-7.0.59 /opt/tomcat
+
+# -----------------------
+# Add shell scripts
+# -----------------------
+ADD files/create-admin-user.sh /opt/create-admin-user.sh
+# ADD files/run.sh /opt/run.sh
+RUN chmod +x /opt/create-admin-user.sh && \
+    bash /opt/create-admin-user.sh
+
+ADD files/env /tmp/env
+RUN cat /tmp/env >> /etc/environment
+
+#------------------------
+# Copy Tomcat related PCA plugins
+#-----------------------
+ADD packs/plugins /mnt/plugins
+
+
+EXPOSE 8080
+
+# -----------------------
+# Define entry point
+# -----------------------
+ENTRYPOINT /usr/local/bin/run | /usr/sbin/sshd -D

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh
new file mode 100755
index 0000000..2f9a9c9
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh
@@ -0,0 +1,21 @@
+#!/bin/bash
+
+if [ -f /.tomcat-admin-created ]; then
+    echo "Tomcat 'admin' user already created"
+    exit 0
+fi
+
+PWD="admin"
+
+echo "=> Creating Tomcat admin user"
+sed -i -r 's/<\/tomcat-users>//' ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="manager-gui"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="manager-script"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="manager-jmx"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="admin-gui"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="admin-script"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo "<user username=\"admin\" password=\"${PWD}\" roles=\"manager-gui,manager-script,manager-jmx,admin-gui, admin-script\"/>" >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '</tomcat-users>' >> ${CATALINA_HOME}/conf/tomcat-users.xml 
+echo "=> Done!"
+touch /.tomcat-admin-created
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env
new file mode 100644
index 0000000..97d9119
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env
@@ -0,0 +1,2 @@
+JAVA_HOME=/opt/jdk1.7.0_67
+CATALINA_HOME=/opt/tomcat
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py
new file mode 100644
index 0000000..eda93c1
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py
@@ -0,0 +1,59 @@
+# 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.
+
+import mdsclient
+from plugins.contracts import ICartridgeAgentPlugin
+import time
+import zipfile
+import subprocess
+from modules.util.log import LogFactory
+import os
+
+
+class TomcatServerStarterPlugin(ICartridgeAgentPlugin):
+
+    def run_plugin(self, values):
+        log = LogFactory().get_log(__name__)
+        # wait till SAML_ENDPOINT becomes available
+        mds_response = None
+        while mds_response is None:
+            log.debug("Waiting for SAML_ENDPOINT to be available from metadata service for app ID: %s" % values["APPLICATION_ID"])
+            time.sleep(5)
+            mds_response = mdsclient.get(app=True)
+            if mds_response is not None and mds_response.properties.get("SAML_ENDPOINT") is None:
+                mds_response = None
+
+        saml_endpoint = mds_response.properties["SAML_ENDPOINT"]
+        log.debug("SAML_ENDPOINT value read from Metadata service: %s" % saml_endpoint)
+
+        # start tomcat
+        tomcat_start_command = "exec /opt/tomcat/bin/startup.sh"
+        log.info("Starting Tomcat server: [command] %s, [STRATOS_SAML_ENDPOINT] %s" % (tomcat_start_command, saml_endpoint))
+        env_var = os.environ.copy()
+        env_var["STRATOS_SAML_ENDPOINT"] = saml_endpoint
+        env_var["JAVA_HOME"] = "/opt/jdk1.7.0_67"
+        p = subprocess.Popen(tomcat_start_command, env=env_var, shell=True)
+        output, errors = p.communicate()
+        log.debug("Tomcat server started")
+
+
+
+
+
+
+
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin
new file mode 100644
index 0000000..87e0de2
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin
@@ -0,0 +1,9 @@
+[Core]
+Name = TomcatServerStarterPlugin to read SAML SSO related metadata needed to configure SAML SSO for apps and start tomcat
+Module = TomcatServerStarterPlugin
+
+[Documentation]
+Description = ArtifactUpdatedEvent
+Author = Op1
+Version = 0.1
+Website = stratos.apache.org
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py
new file mode 100644
index 0000000..66084d8
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py
@@ -0,0 +1,55 @@
+# 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.
+
+import mdsclient
+from plugins.contracts import ICartridgeAgentPlugin
+import time
+import zipfile
+import subprocess
+
+
+class TomcatWSO2ISMetadataPublisher(ICartridgeAgentPlugin):
+
+    def run_plugin(self, values):
+        # publish callback and issuer id from tomcat for IS to pickup
+        publish_data = mdsclient.MDSPutRequest()
+        # hostname_entry = {"key": "TOMCAT_HOSTNAME", "values": member_hostname}
+        cluster_hostname = values["HOST_NAME"]
+        # set port name checking if lb is present or not
+        payload_ports = values["PORT_MAPPINGS"].split("|")
+        if values.get("LB_CLUSTER_ID") is not None:
+            port_no = payload_ports[2].split(":")[1]
+        else:
+            port_no = payload_ports[1].split(":")[1]
+
+        callback_url = "https://%s:%s/travelocity.com/home.jsp" % (cluster_hostname, port_no)
+        saml_callback_entry = {"key": "CALLBACK_URL", "values": callback_url}
+        issuer_entry = {"key": "SSO_ISSUER", "values": "travelocity.com"}
+        # properties_data = [hostname_entry, saml_callback_entry]
+        properties_data = [saml_callback_entry, issuer_entry]
+        publish_data.properties = properties_data
+
+        mdsclient.put(publish_data, app=True)
+
+
+
+
+
+
+
+
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin
new file mode 100644
index 0000000..6dadbe1
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin
@@ -0,0 +1,9 @@
+[Core]
+Name = TomcatWSO2ISMetadataPublisher to publish metadata needed for a WSO2IS SAML SSO service provider
+Module = TomcatWSO2ISMetadataPublisher
+
+[Documentation]
+Description = InstanceStartedEvent
+Author = Op1
+Version = 0.1
+Website = stratos.apache.org
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile
new file mode 100644
index 0000000..f23f21e
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile
@@ -0,0 +1,39 @@
+FROM chamilad/base-image:4.1.0-beta
+MAINTAINER dev@stratos.apache.org
+
+ENV DEBIAN_FRONTEND noninteractive
+ENV WSO2_IS_VERSION 5.0.0
+
+# ----------------------
+# Install prerequisites
+# ----------------------
+WORKDIR /opt
+ADD packs/jdk-7u67-linux-x64.tar.gz /mnt/jdk-7u67-linux-x64.tar.gz
+RUN mv /mnt/jdk-7u67-linux-x64.tar.gz/jdk1.7.0_67 /opt/jdk1.7.0_67
+
+ENV JAVA_HOME /opt/jdk1.7.0_67
+
+# -----------------------------
+# Install WSO2 Identity Server
+# -----------------------------
+ADD packs/wso2is-${WSO2_IS_VERSION}-patched.zip /opt/wso2is-${WSO2_IS_VERSION}-patched.zip
+RUN unzip /opt/wso2is-${WSO2_IS_VERSION}-patched.zip -d /opt/
+ENV CARBON_HOME /opt/wso2is-${WSO2_IS_VERSION}
+
+ADD files/env /tmp/env
+RUN cat /tmp/env >> /etc/environment
+
+ADD files/carbon.xml ${CARBON_HOME}/repository/conf/carbon.xml
+
+#------------------------
+# Copy Tomcat related PCA plugins
+#-----------------------
+ADD packs/plugins /mnt/plugins
+
+
+EXPOSE 9443
+
+# -----------------------
+# Define entry point
+# -----------------------
+ENTRYPOINT /usr/local/bin/run | /usr/sbin/sshd -D

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml
new file mode 100644
index 0000000..42d0765
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml
@@ -0,0 +1,625 @@
+<?xml version="1.0" encoding="ISO-8859-1"?>
+
+<!--
+  ~ Copyright 2005-2011 WSO2, Inc. (http://wso2.com)
+  ~
+  ~ Licensed 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.
+  -->
+
+<!--
+    This is the main server configuration file
+
+    ${carbon.home} represents the carbon.home system property.
+    Other system properties can be specified in a similar manner.
+-->
+<Server xmlns="http://wso2.org/projects/carbon/carbon.xml">
+
+    <!--
+       Product Name
+    -->
+    <Name>WSO2 Identity Server</Name>
+
+    <!--
+       machine readable unique key to identify each product
+    -->
+    <ServerKey>IS</ServerKey>
+
+    <!--
+       Product Version
+    -->
+    <Version>5.0.0</Version>
+
+    <!--
+       Host name or IP address of the machine hosting this server
+       e.g. www.wso2.org, 192.168.1.10
+       This is will become part of the End Point Reference of the
+       services deployed on this server instance.
+    -->
+    <HostName>CLUSTER_HOST_NAME</HostName>
+
+    <!--
+    Host name to be used for the Carbon management console
+    -->
+    <MgtHostName>CLUSTER_HOST_NAME</MgtHostName>
+
+    <!--
+        The URL of the back end server. This is where the admin services are hosted and
+        will be used by the clients in the front end server.
+        This is required only for the Front-end server. This is used when seperating BE server from FE server
+       -->
+    <ServerURL>local:/${carbon.context}/services/</ServerURL>
+    <!--
+    <ServerURL>https://localhost:${carbon.management.port}${carbon.context}/services/</ServerURL>
+    -->
+    <!--
+    The URL of the index page. This is where the user will be redirected after signing in to the
+    carbon server.
+    -->
+    <!-- IndexPageURL>/carbon/admin/index.jsp</IndexPageURL-->
+
+    <!--
+    For cApp deployment, we have to identify the roles that can be acted by the current server.
+    The following property is used for that purpose. Any number of roles can be defined here.
+    Regular expressions can be used in the role.
+    Ex : <Role>.*</Role> means this server can act any role
+    -->
+    <ServerRoles>
+        <Role>IdentityServer</Role>
+    </ServerRoles>
+
+    <!-- uncommnet this line to subscribe to a bam instance automatically -->
+    <!--<BamServerURL>https://bamhost:bamport/services/</BamServerURL>-->
+
+    <!--
+       The fully qualified name of the server
+    -->
+    <Package>org.wso2.carbon</Package>
+
+    <!--
+       Webapp context root of WSO2 Carbon.
+    -->
+    <WebContextRoot>/</WebContextRoot>
+
+    <!-- In-order to  get the registry http Port from the back-end when the default http transport is not the same-->
+    <!--RegistryHttpPort>9763</RegistryHttpPort-->
+
+    <!--
+    Number of items to be displayed on a management console page. This is used at the
+    backend server for pagination of various items.
+    -->
+    <ItemsPerPage>15</ItemsPerPage>
+
+    <!-- The endpoint URL of the cloud instance management Web service -->
+    <!--<InstanceMgtWSEndpoint>https://ec2.amazonaws.com/</InstanceMgtWSEndpoint>-->
+
+    <!--
+       Ports used by this server
+    -->
+    <Ports>
+
+        <!-- Ports offset. This entry will set the value of the ports defined below to
+         the define value + Offset.
+         e.g. Offset=2 and HTTPS port=9443 will set the effective HTTPS port to 9445
+         -->
+        <Offset>0</Offset>
+
+        <!-- The JMX Ports -->
+        <JMX>
+            <!--The port RMI registry is exposed-->
+            <RMIRegistryPort>9999</RMIRegistryPort>
+            <!--The port RMI server should be exposed-->
+            <RMIServerPort>11111</RMIServerPort>
+        </JMX>
+
+        <!-- Embedded LDAP server specific ports -->
+        <EmbeddedLDAP>
+            <!-- Port which embedded LDAP server runs -->
+            <LDAPServerPort>10389</LDAPServerPort>
+            <!-- Port which KDC (Kerberos Key Distribution Center) server runs -->
+            <KDCServerPort>8000</KDCServerPort>
+        </EmbeddedLDAP>
+
+        <!-- Embedded Qpid broker ports -->
+        <EmbeddedQpid>
+            <!-- Broker TCP Port -->
+            <BrokerPort>5672</BrokerPort>
+            <!-- SSL Port -->
+            <BrokerSSLPort>8672</BrokerSSLPort>
+        </EmbeddedQpid>
+
+        <!--
+                 Override datasources JNDIproviderPort defined in bps.xml and datasources.properties files
+        -->
+        <!--<JNDIProviderPort>2199</JNDIProviderPort>-->
+        <!--Override receive port of thrift based entitlement service.-->
+        <ThriftEntitlementReceivePort>10500</ThriftEntitlementReceivePort>
+
+    </Ports>
+
+    <!--
+        JNDI Configuration
+    -->
+    <JNDI>
+        <!--
+             The fully qualified name of the default initial context factory
+        -->
+        <DefaultInitialContextFactory>org.wso2.carbon.tomcat.jndi.CarbonJavaURLContextFactory</DefaultInitialContextFactory>
+        <!--
+             The restrictions that are done to various JNDI Contexts in a Multi-tenant environment
+        -->
+        <Restrictions>
+            <!--
+                Contexts that will be available only to the super-tenant
+            -->
+            <!-- <SuperTenantOnly>
+                <UrlContexts>
+                    <UrlContext>
+                        <Scheme>foo</Scheme>
+                    </UrlContext>
+                    <UrlContext>
+                        <Scheme>bar</Scheme>
+                    </UrlContext>
+                </UrlContexts>
+            </SuperTenantOnly> -->
+            <!--
+                Contexts that are common to all tenants
+            -->
+            <AllTenants>
+                <UrlContexts>
+                    <UrlContext>
+                        <Scheme>java</Scheme>
+                    </UrlContext>
+                    <!-- <UrlContext>
+                        <Scheme>foo</Scheme>
+                    </UrlContext> -->
+                </UrlContexts>
+            </AllTenants>
+            <!--
+                 All other contexts not mentioned above will be available on a per-tenant basis
+                 (i.e. will not be shared among tenants)
+            -->
+        </Restrictions>
+    </JNDI>
+
+    <!--
+        Property to determine if the server is running an a cloud deployment environment.
+        This property should only be used to determine deployment specific details that are
+        applicable only in a cloud deployment, i.e when the server deployed *-as-a-service.
+    -->
+    <IsCloudDeployment>false</IsCloudDeployment>
+
+    <!--
+	Property to determine whether usage data should be collected for metering purposes
+    -->
+    <EnableMetering>false</EnableMetering>
+
+    <!-- The Max time a thread should take for execution in seconds -->
+    <MaxThreadExecutionTime>600</MaxThreadExecutionTime>
+
+    <!--
+        A flag to enable or disable Ghost Deployer. By default this is set to false. That is
+        because the Ghost Deployer works only with the HTTP/S transports. If you are using
+        other transports, don't enable Ghost Deployer.
+    -->
+    <GhostDeployment>
+        <Enabled>false</Enabled>
+        <PartialUpdate>false</PartialUpdate>
+    </GhostDeployment>
+
+    <!--
+    Axis2 related configurations
+    -->
+    <Axis2Config>
+        <!--
+             Location of the Axis2 Services & Modules repository
+
+             This can be a directory in the local file system, or a URL.
+
+             e.g.
+             1. /home/wso2wsas/repository/ - An absolute path
+             2. repository - In this case, the path is relative to CARBON_HOME
+             3. file:///home/wso2wsas/repository/
+             4. http://wso2wsas/repository/
+        -->
+        <RepositoryLocation>${carbon.home}/repository/deployment/server/</RepositoryLocation>
+
+        <!--
+         Deployment update interval in seconds. This is the interval between repository listener
+         executions.
+        -->
+        <DeploymentUpdateInterval>15</DeploymentUpdateInterval>
+
+        <!--
+            Location of the main Axis2 configuration descriptor file, a.k.a. axis2.xml file
+
+            This can be a file on the local file system, or a URL
+
+            e.g.
+            1. /home/repository/axis2.xml - An absolute path
+            2. conf/axis2.xml - In this case, the path is relative to CARBON_HOME
+            3. file:///home/carbon/repository/axis2.xml
+            4. http://repository/conf/axis2.xml
+        -->
+        <ConfigurationFile>${carbon.home}/repository/conf/axis2/axis2.xml</ConfigurationFile>
+
+        <!--
+          ServiceGroupContextIdleTime, which will be set in ConfigurationContex
+          for multiple clients which are going to access the same ServiceGroupContext
+          Default Value is 30 Sec.
+        -->
+        <ServiceGroupContextIdleTime>30000</ServiceGroupContextIdleTime>
+
+        <!--
+          This repository location is used to crete the client side configuration
+          context used by the server when calling admin services.
+        -->
+        <ClientRepositoryLocation>${carbon.home}/repository/deployment/client/</ClientRepositoryLocation>
+        <!-- This axis2 xml is used in createing the configuration context by the FE server
+         calling to BE server -->
+        <clientAxis2XmlLocation>${carbon.home}/repository/conf/axis2/axis2_client.xml</clientAxis2XmlLocation>
+        <!-- If this parameter is set, the ?wsdl on an admin service will not give the admin service wsdl. -->
+        <HideAdminServiceWSDLs>true</HideAdminServiceWSDLs>
+
+        <!--WARNING-Use With Care! Uncommenting bellow parameter would expose all AdminServices in HTTP transport.
+        With HTTP transport your credentials and data routed in public channels are vulnerable for sniffing attacks.
+        Use bellow parameter ONLY if your communication channels are confirmed to be secured by other means -->
+        <!--HttpAdminServices>*</HttpAdminServices-->
+
+    </Axis2Config>
+
+    <!--
+       The default user roles which will be created when the server
+       is started up for the first time.
+    -->
+    <ServiceUserRoles>
+        <Role>
+            <Name>admin</Name>
+            <Description>Default Administrator Role</Description>
+        </Role>
+        <Role>
+            <Name>user</Name>
+            <Description>Default User Role</Description>
+        </Role>
+    </ServiceUserRoles>
+
+    <!--
+      Enable following config to allow Emails as usernames.
+    -->
+    <!--EnableEmailUserName>true</EnableEmailUserName-->
+
+    <!--
+      Security configurations
+    -->
+    <Security>
+        <!--
+            KeyStore which will be used for encrypting/decrypting passwords
+            and other sensitive information.
+        -->
+        <KeyStore>
+            <!-- Keystore file location-->
+            <Location>${carbon.home}/repository/resources/security/wso2carbon.jks</Location>
+            <!-- Keystore type (JKS/PKCS12 etc.)-->
+            <Type>JKS</Type>
+            <!-- Keystore password-->
+            <Password>wso2carbon</Password>
+            <!-- Private Key alias-->
+            <KeyAlias>wso2carbon</KeyAlias>
+            <!-- Private Key password-->
+            <KeyPassword>wso2carbon</KeyPassword>
+        </KeyStore>
+
+        <!--
+           Encrypt Decrypt Store will be used for encrypting and decrypting
+       -->
+        <RegistryKeyStore>
+            <!-- Keystore file location-->
+            <Location>${carbon.home}/repository/resources/security/wso2carbon.jks</Location>
+            <!-- Keystore type (JKS/PKCS12 etc.)-->
+            <Type>JKS</Type>
+            <!-- Keystore password-->
+            <Password>wso2carbon</Password>
+            <!-- Private Key alias-->
+            <KeyAlias>wso2carbon</KeyAlias>
+            <!-- Private Key password-->
+            <KeyPassword>wso2carbon</KeyPassword>
+        </RegistryKeyStore>
+
+        <!--
+            System wide trust-store which is used to maintain the certificates of all
+            the trusted parties.
+        -->
+        <TrustStore>
+            <!-- trust-store file location -->
+            <Location>${carbon.home}/repository/resources/security/client-truststore.jks</Location>
+            <!-- trust-store type (JKS/PKCS12 etc.) -->
+            <Type>JKS</Type>
+            <!-- trust-store password -->
+            <Password>wso2carbon</Password>
+        </TrustStore>
+
+        <!--
+            The Authenticator configuration to be used at the JVM level. We extend the
+            java.net.Authenticator to make it possible to authenticate to given servers and
+            proxies.
+        -->
+        <NetworkAuthenticatorConfig>
+            <!--
+                Below is a sample configuration for a single authenticator. Please note that
+                all child elements are mandatory. Not having some child elements would lead to
+                exceptions at runtime.
+            -->
+            <!-- <Credential> -->
+            <!--
+                the pattern that would match a subset of URLs for which this authenticator
+                would be used
+            -->
+            <!-- <Pattern>regularExpression</Pattern> -->
+            <!--
+                the type of this authenticator. Allowed values are:
+                1. server
+                2. proxy
+            -->
+            <!-- <Type>proxy</Type> -->
+            <!-- the username used to log in to server/proxy -->
+            <!-- <Username>username</Username> -->
+            <!-- the password used to log in to server/proxy -->
+            <!-- <Password>password</Password> -->
+            <!-- </Credential> -->
+        </NetworkAuthenticatorConfig>
+
+        <!--
+         The Tomcat realm to be used for hosted Web applications. Allowed values are;
+         1. UserManager
+         2. Memory
+
+         If this is set to 'UserManager', the realm will pick users & roles from the system's
+         WSO2 User Manager. If it is set to 'memory', the realm will pick users & roles from
+         CARBON_HOME/repository/conf/tomcat/tomcat-users.xml
+        -->
+        <TomcatRealm>UserManager</TomcatRealm>
+
+        <!--Option to disable storing of tokens issued by STS-->
+        <DisableTokenStore>false</DisableTokenStore>
+
+        <!--
+         Security token store class name. If this is not set, default class will be
+         org.wso2.carbon.security.util.SecurityTokenStore
+        -->
+        <TokenStoreClassName>org.wso2.carbon.identity.sts.store.DBTokenStore</TokenStoreClassName>
+    </Security>
+
+    <!--
+       The temporary work directory
+    -->
+    <WorkDirectory>${carbon.home}/tmp/work</WorkDirectory>
+
+    <!--
+       House-keeping configuration
+    -->
+    <HouseKeeping>
+
+        <!--
+           true  - Start House-keeping thread on server startup
+           false - Do not start House-keeping thread on server startup.
+                   The user will run it manually as and when he wishes.
+        -->
+        <AutoStart>true</AutoStart>
+
+        <!--
+           The interval in *minutes*, between house-keeping runs
+        -->
+        <Interval>10</Interval>
+
+        <!--
+          The maximum time in *minutes*, temp files are allowed to live
+          in the system. Files/directories which were modified more than
+          "MaxTempFileLifetime" minutes ago will be removed by the
+          house-keeping task
+        -->
+        <MaxTempFileLifetime>30</MaxTempFileLifetime>
+    </HouseKeeping>
+
+    <!--
+       Configuration for handling different types of file upload & other file uploading related
+       config parameters.
+       To map all actions to a particular FileUploadExecutor, use
+       <Action>*</Action>
+    -->
+    <FileUploadConfig>
+        <!--
+           The total file upload size limit in MB
+        -->
+        <TotalFileSizeLimit>100</TotalFileSizeLimit>
+
+        <Mapping>
+            <Actions>
+                <Action>keystore</Action>
+                <Action>certificate</Action>
+                <Action>*</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.AnyFileUploadExecutor</Class>
+        </Mapping>
+
+        <Mapping>
+            <Actions>
+                <Action>jarZip</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.JarZipUploadExecutor</Class>
+        </Mapping>
+        <Mapping>
+            <Actions>
+                <Action>dbs</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.DBSFileUploadExecutor</Class>
+        </Mapping>
+        <Mapping>
+            <Actions>
+                <Action>tools</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.ToolsFileUploadExecutor</Class>
+        </Mapping>
+        <Mapping>
+            <Actions>
+                <Action>toolsAny</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.ToolsAnyFileUploadExecutor</Class>
+        </Mapping>
+    </FileUploadConfig>
+
+    <!--
+       Processors which process special HTTP GET requests such as ?wsdl, ?policy etc.
+
+       In order to plug in a processor to handle a special request, simply add an entry to this
+       section.
+
+       The value of the Item element is the first parameter in the query string(e.g. ?wsdl)
+       which needs special processing
+
+       The value of the Class element is a class which implements
+       org.wso2.carbon.transport.HttpGetRequestProcessor
+    -->
+    <HttpGetRequestProcessors>
+        <Processor>
+            <Item>info</Item>
+            <Class>org.wso2.carbon.core.transports.util.InfoProcessor</Class>
+        </Processor>
+        <Processor>
+            <Item>wsdl</Item>
+            <Class>org.wso2.carbon.core.transports.util.Wsdl11Processor</Class>
+        </Processor>
+        <Processor>
+            <Item>wsdl2</Item>
+            <Class>org.wso2.carbon.core.transports.util.Wsdl20Processor</Class>
+        </Processor>
+        <Processor>
+            <Item>xsd</Item>
+            <Class>org.wso2.carbon.core.transports.util.XsdProcessor</Class>
+        </Processor>
+    </HttpGetRequestProcessors>
+
+    <!-- Deployment Synchronizer Configuration. t Enabled value to true when running with "svn based" dep sync.
+	In master nodes you need to set both AutoCommit and AutoCheckout to true
+	and in  worker nodes set only AutoCheckout to true.
+    -->
+    <DeploymentSynchronizer>
+        <Enabled>false</Enabled>
+        <AutoCommit>false</AutoCommit>
+        <AutoCheckout>true</AutoCheckout>
+        <RepositoryType>svn</RepositoryType>
+        <SvnUrl>http://svnrepo.example.com/repos/</SvnUrl>
+        <SvnUser>username</SvnUser>
+        <SvnPassword>password</SvnPassword>
+        <SvnUrlAppendTenantId>true</SvnUrlAppendTenantId>
+    </DeploymentSynchronizer>
+
+    <!-- Deployment Synchronizer Configuration. Uncomment the following section when running with "registry based" dep sync.
+        In master nodes you need to set both AutoCommit and AutoCheckout to true
+        and in  worker nodes set only AutoCheckout to true.
+    -->
+    <!--<DeploymentSynchronizer>
+        <Enabled>true</Enabled>
+        <AutoCommit>false</AutoCommit>
+        <AutoCheckout>true</AutoCheckout>
+    </DeploymentSynchronizer>-->
+
+    <!-- Mediation persistence configurations. Only valid if mediation features are available i.e. ESB -->
+    <!--<MediationConfig>
+        <LoadFromRegistry>false</LoadFromRegistry>
+        <SaveToFile>false</SaveToFile>
+        <Persistence>enabled</Persistence>
+        <RegistryPersistence>enabled</RegistryPersistence>
+    </MediationConfig>-->
+
+    <!--
+    Server intializing code, specified as implementation classes of org.wso2.carbon.core.ServerInitializer.
+    This code will be run when the Carbon server is initialized
+    -->
+    <ServerInitializers>
+        <!--<Initializer></Initializer>-->
+    </ServerInitializers>
+
+    <!--
+    Indicates whether the Carbon Servlet is required by the system, and whether it should be
+    registered
+    -->
+    <RequireCarbonServlet>${require.carbon.servlet}</RequireCarbonServlet>
+
+    <!--
+    Carbon H2 OSGI Configuration
+    By default non of the servers start.
+        name="web" - Start the web server with the H2 Console
+        name="webPort" - The port (default: 8082)
+        name="webAllowOthers" - Allow other computers to connect
+        name="webSSL" - Use encrypted (HTTPS) connections
+        name="tcp" - Start the TCP server
+        name="tcpPort" - The port (default: 9092)
+        name="tcpAllowOthers" - Allow other computers to connect
+        name="tcpSSL" - Use encrypted (SSL) connections
+        name="pg" - Start the PG server
+        name="pgPort"  - The port (default: 5435)
+        name="pgAllowOthers"  - Allow other computers to connect
+        name="trace" - Print additional trace information; for all servers
+        name="baseDir" - The base directory for H2 databases; for all servers
+    -->
+    <!--H2DatabaseConfiguration>
+        <property name="web" />
+        <property name="webPort">8082</property>
+        <property name="webAllowOthers" />
+        <property name="webSSL" />
+        <property name="tcp" />
+        <property name="tcpPort">9092</property>
+        <property name="tcpAllowOthers" />
+        <property name="tcpSSL" />
+        <property name="pg" />
+        <property name="pgPort">5435</property>
+        <property name="pgAllowOthers" />
+        <property name="trace" />
+        <property name="baseDir">${carbon.home}</property>
+    </H2DatabaseConfiguration-->
+    <!--Disabling statistics reporter by default-->
+    <StatisticsReporterDisabled>true</StatisticsReporterDisabled>
+
+    <!-- Enable accessing Admin Console via HTTP -->
+    <!-- EnableHTTPAdminConsole>true</EnableHTTPAdminConsole -->
+
+    <!--
+       Default Feature Repository of WSO2 Carbon.
+    -->
+    <FeatureRepository>
+        <RepositoryName>default repository</RepositoryName>
+        <RepositoryURL>${p2.repo.url}</RepositoryURL>
+    </FeatureRepository>
+
+    <!--
+	Configure API Management
+   -->
+    <APIManagement>
+
+        <!--Uses the embedded API Manager by default. If you want to use an external
+        API Manager instance to manage APIs, configure below  externalAPIManager-->
+
+        <Enabled>true</Enabled>
+
+        <!--Uncomment and configure API Gateway and
+        Publisher URLs to use external API Manager instance-->
+
+        <!--ExternalAPIManager>
+
+            <APIGatewayURL>http://localhost:8281</APIGatewayURL>
+            <APIPublisherURL>http://localhost:8281/publisher</APIPublisherURL>
+
+        </ExternalAPIManager-->
+
+        <LoadAPIContextsInServerStartup>true</LoadAPIContextsInServerStartup>
+    </APIManagement>
+</Server>

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env
new file mode 100644
index 0000000..e7555c7
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env
@@ -0,0 +1,2 @@
+JAVA_HOME=/opt/jdk1.7.0_67
+CARBON_HOME=/opt/wso2is-5.0.0
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py
new file mode 100644
index 0000000..53e10fe
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py
@@ -0,0 +1,144 @@
+# 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.
+
+import mdsclient
+from plugins.contracts import ICartridgeAgentPlugin
+from xml.dom.minidom import parse
+import socket
+from modules.util.log import LogFactory
+import time
+import subprocess
+import os
+
+
+class WSO2ISMetaDataHandler(ICartridgeAgentPlugin):
+
+    def run_plugin(self, values):
+        log = LogFactory().get_log(__name__)
+        # read tomcat app related values from metadata
+        mds_response = None
+        while mds_response is None:
+            log.debug("Waiting for SSO_ISSUER and CALLBACK_URL to be available from metadata service for app ID: %s"
+                      % values["APPLICATION_ID"])
+            time.sleep(5)
+            mds_response = mdsclient.get(app=True)
+            if mds_response is not None and mds_response.properties.get("SSO_ISSUER") is None or \
+                    mds_response.properties.get("CALLBACK_URL") is None:
+                mds_response = None
+        # mds_response = mdsclient.get()
+        issuer = mds_response.properties["SSO_ISSUER"]
+        acs = mds_response.properties["CALLBACK_URL"]
+
+        # add a service provider in the security/sso-idp-config.xml file
+        # is_root = values["APPLICATION_PATH"]
+        is_root = os.environ.get("CARBON_HOME")
+        sso_idp_file = "%s/repository/conf/security/sso-idp-config.xml" % is_root
+
+        # <SSOIdentityProviderConfig>
+        #     <ServiceProviders>
+        #         <ServiceProvider>
+        #         <Issuer>wso2.my.dashboard</Issuer>
+        #         <AssertionConsumerService>https://is.wso2.com/dashboard/acs</AssertionConsumerService>
+        #         <SignAssertion>true</SignAssertion>
+        #         <SignResponse>true</SignResponse>
+        #         <EnableAttributeProfile>false</EnableAttributeProfile>
+        #         <IncludeAttributeByDefault>false</IncludeAttributeByDefault>
+        #         <Claims>
+        #             <Claim>http://wso2.org/claims/role</Claim>
+        #         </Claims>
+        #         <EnableSingleLogout>false</EnableSingleLogout>
+        #         <SingleLogoutUrl></SingleLogoutUrl>
+        #         <EnableAudienceRestriction>true</EnableAudienceRestriction>
+        #         <AudiencesList>
+        #             <Audience>carbonServer</Audience>
+        #         </AudiencesList>
+        #         <ConsumingServiceIndex></ConsumingServiceIndex>
+        #     </ServiceProvider>
+        with open(sso_idp_file, "r") as f:
+            sp_dom = parse(f)
+
+        root_element = sp_dom.documentElement
+        sps_element = sp_dom.getElementsByTagName("ServiceProviders")[0]
+
+        sp_entry = sp_dom.createElement("ServiceProvider")
+
+        sp_entry_issuer = sp_dom.createElement("Issuer")
+        sp_entry_issuer.appendChild(sp_dom.createTextNode(issuer))
+
+        sp_entry_acs = sp_dom.createElement("AssertionConsumerService")
+        sp_entry_acs.appendChild(sp_dom.createTextNode(acs))
+
+        sp_entry_sign_resp = sp_dom.createElement("SignResponse")
+        sp_entry_sign_resp.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry_sign_assert = sp_dom.createElement("SignAssertion")
+        sp_entry_sign_assert.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry_single_logout = sp_dom.createElement("EnableSingleLogout")
+        sp_entry_single_logout.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry_attribute_profile = sp_dom.createElement("EnableAttributeProfile")
+        sp_entry_attribute_profile.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry.appendChild(sp_entry_issuer)
+        sp_entry.appendChild(sp_entry_acs)
+        sp_entry.appendChild(sp_entry_sign_resp)
+        sp_entry.appendChild(sp_entry_sign_assert)
+        sp_entry.appendChild(sp_entry_single_logout)
+        sp_entry.appendChild(sp_entry_attribute_profile)
+
+        sps_element.appendChild(sp_entry)
+
+        with open(sso_idp_file, 'w+') as f:
+            root_element.writexml(f, newl="\n")
+        # root_element.writexml(f)
+
+        # data = json.loads(urllib.urlopen("http://ip.jsontest.com/").read())
+        # ip_entry = data["ip"]
+
+        # publish SAML_ENDPOINT to metadata service
+        # member_hostname = socket.gethostname()
+        member_hostname = values["HOST_NAME"]
+        payload_ports = values["PORT_MAPPINGS"].split("|")
+        if values.get("LB_CLUSTER_ID") is not None:
+            port_no = payload_ports[2].split(":")[1]
+        else:
+            port_no = payload_ports[1].split(":")[1]
+        saml_endpoint = "https://%s:%s/samlsso" % (member_hostname, port_no)
+        publish_data = mdsclient.MDSPutRequest()
+        hostname_entry = {"key": "SAML_ENDPOINT", "values": saml_endpoint}
+        properties_data = [hostname_entry]
+        publish_data.properties = properties_data
+
+        mdsclient.put(publish_data, app=True)
+
+        # start servers
+        log.info("Starting WSO2 IS server")
+
+        # set configurations
+        carbon_replace_command = "sed -i \"s/CLUSTER_HOST_NAME/%s/g\" %s" % (member_hostname, "/opt/wso2is-5.0.0/repository/conf/carbon.xml")
+
+        p = subprocess.Popen(carbon_replace_command, shell=True)
+        output, errors = p.communicate()
+        log.debug("Set carbon.xml hostname")
+
+        wso2is_start_command = "exec /opt/wso2is-5.0.0/bin/wso2server.sh start"
+        env_var = os.environ.copy()
+        env_var["JAVA_HOME"] = "/opt/jdk1.7.0_67"
+        p = subprocess.Popen(wso2is_start_command, env=env_var, shell=True)
+        output, errors = p.communicate()
+        log.debug("WSO2 IS server started")

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin
new file mode 100644
index 0000000..d0d7e91
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin
@@ -0,0 +1,9 @@
+[Core]
+Name = WSO2ISMetaDataHandler to read  and publish metadata from and to Metadata service
+Module = WSO2ISMetaDataHandler
+
+[Documentation]
+Description = InstanceStartedEvent
+Author = Op1
+Version = 0.1
+Website = stratos.apache.org
\ No newline at end of file


[39/50] [abbrv] stratos git commit: fixing incorrect partition algo in single-cartridge-app

Posted by re...@apache.org.
fixing incorrect partition algo in single-cartridge-app


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

Branch: refs/heads/docker-grouping-merge
Commit: 5b2571bf233e1d2f6cd26a4dd9cb038bbb05ebdd
Parents: 7cde490
Author: R-Rajkumar <rr...@gmail.com>
Authored: Sun Mar 1 18:30:38 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Sun Mar 1 18:30:38 2015 +0530

----------------------------------------------------------------------
 samples/deployment-policies/deployment-policy-4.json | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/5b2571bf/samples/deployment-policies/deployment-policy-4.json
----------------------------------------------------------------------
diff --git a/samples/deployment-policies/deployment-policy-4.json b/samples/deployment-policies/deployment-policy-4.json
index aabbac9..b21bc42 100644
--- a/samples/deployment-policies/deployment-policy-4.json
+++ b/samples/deployment-policies/deployment-policy-4.json
@@ -13,7 +13,7 @@
       },
       {
          "id": "network-partition-2",
-         "partitionAlgo": "network-partition-1",
+         "partitionAlgo": "one-after-another",
          "partitions": [
             {
                "id": "network-partition-2-partition-1",


[35/50] [abbrv] stratos git commit: Updating load balancer jndi.properties file

Posted by re...@apache.org.
Updating load balancer jndi.properties file


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

Branch: refs/heads/docker-grouping-merge
Commit: 716d5176a2a2ae3f592a611638f13039416f6d7a
Parents: 1bfdb7d
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 14:42:04 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 14:42:04 2015 +0530

----------------------------------------------------------------------
 .../modules/distribution/src/main/conf/jndi.properties         | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/716d5176/products/load-balancer/modules/distribution/src/main/conf/jndi.properties
----------------------------------------------------------------------
diff --git a/products/load-balancer/modules/distribution/src/main/conf/jndi.properties b/products/load-balancer/modules/distribution/src/main/conf/jndi.properties
index ee38fb4..0d6663a 100644
--- a/products/load-balancer/modules/distribution/src/main/conf/jndi.properties
+++ b/products/load-balancer/modules/distribution/src/main/conf/jndi.properties
@@ -20,6 +20,6 @@
 # Please use loadbalancer.conf for updating mb-ip, mb-port and templates/jndi.properties.template
 # file for updating other configurations.
 #
-connectionfactoryName=topicConnectionfactory
-connectionfactory.topicConnectionfactory=amqp://admin:admin@carbon/carbon?brokerlist='tcp://localhost:5677'
-java.naming.factory.initial=org.wso2.andes.jndi.PropertiesFileInitialContextFactory
+connectionfactoryName=TopicConnectionFactory
+java.naming.provider.url=tcp://localhost:61616
+java.naming.factory.initial=org.apache.activemq.jndi.ActiveMQInitialContextFactory


[48/50] [abbrv] stratos git commit: Tomcat and WSO2 IS SAML SSO docker files added with PCA plugins Changed PORT_MAPPINGS payload format in KubernetesIaaS

Posted by re...@apache.org.
Tomcat and WSO2 IS SAML SSO docker files added with PCA plugins
Changed PORT_MAPPINGS payload format in KubernetesIaaS


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

Branch: refs/heads/docker-grouping-merge
Commit: 188377afe2732ea867d233a1a2eb03f062586749
Parents: f9948c5
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 23:20:03 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 .../iaases/kubernetes/KubernetesIaas.java       |   2 +-
 .../cartridge.agent/cartridge.agent/config.py   |   5 +-
 .../cartridge.agent/plugins/TestPlugin.py       |  26 -
 .../plugins/TestPlugin.yapsy-plugin             |   9 -
 .../base-image/files/populate-user-data.sh      |   4 +-
 .../base-image/files/run                        |  15 +-
 .../service-images/tomcat-saml-sso/Dockerfile   |  46 ++
 .../tomcat-saml-sso/files/create-admin-user.sh  |  21 +
 .../service-images/tomcat-saml-sso/files/env    |   2 +
 .../packs/plugins/TomcatServerStarterPlugin.py  |  59 ++
 .../TomcatServerStarterPlugin.yapsy-plugin      |   9 +
 .../plugins/TomcatWSO2ISMetadataPublisher.py    |  55 ++
 .../TomcatWSO2ISMetadataPublisher.yapsy-plugin  |   9 +
 .../service-images/wso2is-saml-sso/Dockerfile   |  39 ++
 .../wso2is-saml-sso/files/carbon.xml            | 625 +++++++++++++++++++
 .../service-images/wso2is-saml-sso/files/env    |   2 +
 .../packs/plugins/WSO2ISMetaDataHandler.py      | 144 +++++
 .../plugins/WSO2ISMetaDataHandler.yapsy-plugin  |   9 +
 18 files changed, 1040 insertions(+), 41 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index d8b06fc..34af6ac 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -541,7 +541,7 @@ public class KubernetesIaas extends Iaas {
                         if (portMappingStrBuilder.toString().length() > 0) {
                             portMappingStrBuilder.append(":");
                         }
-                        portMappingStrBuilder.append(String.format("PROTOCOL=%s|PORT=%d|PROXY_PORT=%d",
+                        portMappingStrBuilder.append(String.format("PROTOCOL:%s|PORT:%d|PROXY_PORT:%d",
                                 portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
 
                         if (log.isInfoEnabled()) {

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
index 1ad9499..5f5f07d 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
@@ -297,7 +297,10 @@ class CartridgeAgentConfiguration:
                         if param.strip() != "":
                             param_value = param.strip().split("=")
                             try:
-                                self.__payload_params[param_value[0]] = param_value[1]
+                                if str(param_value[1]).strip().lower() == "null" or str(param_value[1]).strip() == "":
+                                    self.__payload_params[param_value[0]] = None
+                                else:
+                                    self.__payload_params[param_value[0]] = param_value[1]
                             except IndexError:
                                 # If an index error comes when reading values, keep on reading
                                 pass

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py
deleted file mode 100644
index e4c69f6..0000000
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.py
+++ /dev/null
@@ -1,26 +0,0 @@
-# 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.
-
-from plugins.contracts import ICartridgeAgentPlugin
-
-
-class TestPlugin(ICartridgeAgentPlugin):
-
-    def run_plugin(self, values, log):
-        log.debug("Running test plugin for event %s" % values["EVENT"])
-        for key, value in values.iteritems():
-            log.debug("%s => %s" % (key, value))
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin
deleted file mode 100644
index d321048..0000000
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/plugins/TestPlugin.yapsy-plugin
+++ /dev/null
@@ -1,9 +0,0 @@
-[Core]
-Name = Test plugin for MemberInitializedEvent and ArtifactUpdatedEvent
-Module = TestPlugin
-
-[Documentation]
-Description = MemberInitializedEvent,ArtifactUpdatedEvent
-Author = Op1
-Version = 0.1
-Website = stratos.apache.org
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh b/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
index dce722d..522b392 100755
--- a/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
+++ b/tools/docker-images/cartridge-docker-images/base-image/files/populate-user-data.sh
@@ -22,4 +22,6 @@
 
 # Persists the payload parameters by storing the environment variables in the launch-params file
 
-echo "APPLICATION_ID=${APPLICATION_ID},APPLICATION_PATH=${APPLICATION_PATH},SERVICE_NAME=${SERVICE_NAME},HOST_NAME=${HOST_NAME},MULTITENANT=false,TENANT_ID=${TENANT_ID},TENANT_RANGE=*,CARTRIDGE_ALIAS=${CARTRIDGE_ALIAS},CLUSTER_ID=${CLUSTER_ID},CLUSTER_INSTANCE_ID=${CLUSTER_INSTANCE_ID},CARTRIDGE_KEY=${CARTRIDGE_KEY},DEPLOYMENT=${DEPLOYMENT},REPO_URL=${REPO_URL},PORTS=${PORTS},PUPPET_IP=${PUPPET_IP},PUPPET_HOSTNAME=${PUPPET_HOSTNAME},PUPPET_ENV=${PUPPET_ENV},MEMBER_ID=${MEMBER_ID},LB_CLUSTER_ID=${LB_CLUSTER_ID},NETWORK_PARTITION_ID=${NETWORK_PARTITION_ID},PARTITION_ID=${PARTITION_ID},MIN_COUNT=${MIN_COUNT},INTERNAL=${INTERNAL},CLUSTERING_PRIMARY_KEY=${CLUSTERING_PRIMARY_KEY}" >> /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/payload/launch-params
+#echo "APPLICATION_ID=${APPLICATION_ID},APPLICATION_PATH=${APPLICATION_PATH},SERVICE_NAME=${SERVICE_NAME},HOST_NAME=${HOST_NAME},MULTITENANT=false,TENANT_ID=${TENANT_ID},TENANT_RANGE=*,CARTRIDGE_ALIAS=${CARTRIDGE_ALIAS},CLUSTER_ID=${CLUSTER_ID},CLUSTER_INSTANCE_ID=${CLUSTER_INSTANCE_ID},CARTRIDGE_KEY=${CARTRIDGE_KEY},DEPLOYMENT=${DEPLOYMENT},REPO_URL=${REPO_URL},PORTS=${PORTS},PUPPET_IP=${PUPPET_IP},PUPPET_HOSTNAME=${PUPPET_HOSTNAME},PUPPET_ENV=${PUPPET_ENV},MEMBER_ID=${MEMBER_ID},LB_CLUSTER_ID=${LB_CLUSTER_ID},NETWORK_PARTITION_ID=${NETWORK_PARTITION_ID},PARTITION_ID=${PARTITION_ID},MIN_COUNT=${MIN_COUNT},INTERNAL=${INTERNAL},CLUSTERING_PRIMARY_KEY=${CLUSTERING_PRIMARY_KEY}" >> /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/payload/launch-params
+
+set -o posix ; set | sed -e ':a;N;$!ba;s/\n/,/g' > /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/payload/launch-params
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/base-image/files/run
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/base-image/files/run b/tools/docker-images/cartridge-docker-images/base-image/files/run
index 513e6e7..69f45b6 100755
--- a/tools/docker-images/cartridge-docker-images/base-image/files/run
+++ b/tools/docker-images/cartridge-docker-images/base-image/files/run
@@ -160,9 +160,15 @@ else
 fi
 
 if [ -z "${APPLICATION_PATH}" ]; then
-	sed -i "s/APPLICATION_PATH/ /g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+	sed -i "s/APPLICATION-PATH/ /g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
 else
-	sed -i "s#APPLICATION_PATH#${APPLICATION_PATH}#g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+	sed -i "s#APPLICATION-PATH#${APPLICATION_PATH}#g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+fi
+
+if [ -z "${METADATA_SERVICE_URL}" ]; then
+	sed -i "s/METADATA-SERVICE-URL/ /g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
+else
+	sed -i "s#METADATA-SERVICE-URL#${METADATA_SERVICE_URL}#g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/agent.conf
 fi
 
 if [ -z "${LOG_LEVEL}" ]; then
@@ -171,7 +177,10 @@ else
 	sed -i "s/LOG_LEVEL/${LOG_LEVEL}/g" /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/logging.ini
 fi
 
+# copy plugins to PCA
+cp -R /mnt/plugins /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT/
+
 # Start cartridge agent
 cd /mnt/apache-stratos-python-cartridge-agent-4.1.0-SNAPSHOT
 python agent.py > /tmp/agent.screen.log 2>&1 &
-/usr/sbin/apache2ctl -D FOREGROUND
+#/usr/sbin/apache2ctl -D FOREGROUND

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile
new file mode 100644
index 0000000..1096d45
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/Dockerfile
@@ -0,0 +1,46 @@
+FROM chamilad/base-image:4.1.0-beta
+MAINTAINER dev@stratos.apache.org
+
+# ----------------------
+# Install prerequisites
+# ----------------------
+# RUN apt-get update && \ apt-get install -yq --no-install-recommends openjdk-7-jre wget ca-certificates && \apt-get clean && \rm -rf /var/lib/apt/lists/*
+WORKDIR /opt
+# RUN wget --no-check-certificate --no-cookies --header "Cookie: oraclelicense=accept-securebackup-cookie" http://download.oracle.com/otn-pub/java/jdk/7u67-b01/jdk-7u67-linux-x64.tar.gz
+ADD packs/jdk-7u67-linux-x64.tar.gz /mnt/jdk-7u67-linux-x64.tar.gz
+# RUN tar zxvf /mnt/jdk-7u67-linux-x64.tar.gz
+RUN mv /mnt/jdk-7u67-linux-x64.tar.gz/jdk1.7.0_67 /opt/jdk1.7.0_67
+ENV JAVA_HOME /opt/jdk1.7.0_67
+
+
+ENV CATALINA_HOME /opt/tomcat
+
+# ----------------------
+# Install Tomcat
+# ----------------------
+ADD packs/apache-tomcat-7.0.59.tar.gz /opt/apache-tomcat-7.0.59.tar.gz
+RUN mv /opt/apache-tomcat-7.0.59.tar.gz/apache-tomcat-7.0.59 /opt/tomcat
+
+# -----------------------
+# Add shell scripts
+# -----------------------
+ADD files/create-admin-user.sh /opt/create-admin-user.sh
+# ADD files/run.sh /opt/run.sh
+RUN chmod +x /opt/create-admin-user.sh && \
+    bash /opt/create-admin-user.sh
+
+ADD files/env /tmp/env
+RUN cat /tmp/env >> /etc/environment
+
+#------------------------
+# Copy Tomcat related PCA plugins
+#-----------------------
+ADD packs/plugins /mnt/plugins
+
+
+EXPOSE 8080
+
+# -----------------------
+# Define entry point
+# -----------------------
+ENTRYPOINT /usr/local/bin/run | /usr/sbin/sshd -D

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh
new file mode 100755
index 0000000..2f9a9c9
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/create-admin-user.sh
@@ -0,0 +1,21 @@
+#!/bin/bash
+
+if [ -f /.tomcat-admin-created ]; then
+    echo "Tomcat 'admin' user already created"
+    exit 0
+fi
+
+PWD="admin"
+
+echo "=> Creating Tomcat admin user"
+sed -i -r 's/<\/tomcat-users>//' ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="manager-gui"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="manager-script"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="manager-jmx"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="admin-gui"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '<role rolename="admin-script"/>' >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo "<user username=\"admin\" password=\"${PWD}\" roles=\"manager-gui,manager-script,manager-jmx,admin-gui, admin-script\"/>" >> ${CATALINA_HOME}/conf/tomcat-users.xml
+echo '</tomcat-users>' >> ${CATALINA_HOME}/conf/tomcat-users.xml 
+echo "=> Done!"
+touch /.tomcat-admin-created
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env
new file mode 100644
index 0000000..97d9119
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/files/env
@@ -0,0 +1,2 @@
+JAVA_HOME=/opt/jdk1.7.0_67
+CATALINA_HOME=/opt/tomcat
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py
new file mode 100644
index 0000000..eda93c1
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.py
@@ -0,0 +1,59 @@
+# 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.
+
+import mdsclient
+from plugins.contracts import ICartridgeAgentPlugin
+import time
+import zipfile
+import subprocess
+from modules.util.log import LogFactory
+import os
+
+
+class TomcatServerStarterPlugin(ICartridgeAgentPlugin):
+
+    def run_plugin(self, values):
+        log = LogFactory().get_log(__name__)
+        # wait till SAML_ENDPOINT becomes available
+        mds_response = None
+        while mds_response is None:
+            log.debug("Waiting for SAML_ENDPOINT to be available from metadata service for app ID: %s" % values["APPLICATION_ID"])
+            time.sleep(5)
+            mds_response = mdsclient.get(app=True)
+            if mds_response is not None and mds_response.properties.get("SAML_ENDPOINT") is None:
+                mds_response = None
+
+        saml_endpoint = mds_response.properties["SAML_ENDPOINT"]
+        log.debug("SAML_ENDPOINT value read from Metadata service: %s" % saml_endpoint)
+
+        # start tomcat
+        tomcat_start_command = "exec /opt/tomcat/bin/startup.sh"
+        log.info("Starting Tomcat server: [command] %s, [STRATOS_SAML_ENDPOINT] %s" % (tomcat_start_command, saml_endpoint))
+        env_var = os.environ.copy()
+        env_var["STRATOS_SAML_ENDPOINT"] = saml_endpoint
+        env_var["JAVA_HOME"] = "/opt/jdk1.7.0_67"
+        p = subprocess.Popen(tomcat_start_command, env=env_var, shell=True)
+        output, errors = p.communicate()
+        log.debug("Tomcat server started")
+
+
+
+
+
+
+
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin
new file mode 100644
index 0000000..87e0de2
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatServerStarterPlugin.yapsy-plugin
@@ -0,0 +1,9 @@
+[Core]
+Name = TomcatServerStarterPlugin to read SAML SSO related metadata needed to configure SAML SSO for apps and start tomcat
+Module = TomcatServerStarterPlugin
+
+[Documentation]
+Description = ArtifactUpdatedEvent
+Author = Op1
+Version = 0.1
+Website = stratos.apache.org
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py
new file mode 100644
index 0000000..66084d8
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.py
@@ -0,0 +1,55 @@
+# 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.
+
+import mdsclient
+from plugins.contracts import ICartridgeAgentPlugin
+import time
+import zipfile
+import subprocess
+
+
+class TomcatWSO2ISMetadataPublisher(ICartridgeAgentPlugin):
+
+    def run_plugin(self, values):
+        # publish callback and issuer id from tomcat for IS to pickup
+        publish_data = mdsclient.MDSPutRequest()
+        # hostname_entry = {"key": "TOMCAT_HOSTNAME", "values": member_hostname}
+        cluster_hostname = values["HOST_NAME"]
+        # set port name checking if lb is present or not
+        payload_ports = values["PORT_MAPPINGS"].split("|")
+        if values.get("LB_CLUSTER_ID") is not None:
+            port_no = payload_ports[2].split(":")[1]
+        else:
+            port_no = payload_ports[1].split(":")[1]
+
+        callback_url = "https://%s:%s/travelocity.com/home.jsp" % (cluster_hostname, port_no)
+        saml_callback_entry = {"key": "CALLBACK_URL", "values": callback_url}
+        issuer_entry = {"key": "SSO_ISSUER", "values": "travelocity.com"}
+        # properties_data = [hostname_entry, saml_callback_entry]
+        properties_data = [saml_callback_entry, issuer_entry]
+        publish_data.properties = properties_data
+
+        mdsclient.put(publish_data, app=True)
+
+
+
+
+
+
+
+
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin
new file mode 100644
index 0000000..6dadbe1
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/tomcat-saml-sso/packs/plugins/TomcatWSO2ISMetadataPublisher.yapsy-plugin
@@ -0,0 +1,9 @@
+[Core]
+Name = TomcatWSO2ISMetadataPublisher to publish metadata needed for a WSO2IS SAML SSO service provider
+Module = TomcatWSO2ISMetadataPublisher
+
+[Documentation]
+Description = InstanceStartedEvent
+Author = Op1
+Version = 0.1
+Website = stratos.apache.org
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile
new file mode 100644
index 0000000..f23f21e
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/Dockerfile
@@ -0,0 +1,39 @@
+FROM chamilad/base-image:4.1.0-beta
+MAINTAINER dev@stratos.apache.org
+
+ENV DEBIAN_FRONTEND noninteractive
+ENV WSO2_IS_VERSION 5.0.0
+
+# ----------------------
+# Install prerequisites
+# ----------------------
+WORKDIR /opt
+ADD packs/jdk-7u67-linux-x64.tar.gz /mnt/jdk-7u67-linux-x64.tar.gz
+RUN mv /mnt/jdk-7u67-linux-x64.tar.gz/jdk1.7.0_67 /opt/jdk1.7.0_67
+
+ENV JAVA_HOME /opt/jdk1.7.0_67
+
+# -----------------------------
+# Install WSO2 Identity Server
+# -----------------------------
+ADD packs/wso2is-${WSO2_IS_VERSION}-patched.zip /opt/wso2is-${WSO2_IS_VERSION}-patched.zip
+RUN unzip /opt/wso2is-${WSO2_IS_VERSION}-patched.zip -d /opt/
+ENV CARBON_HOME /opt/wso2is-${WSO2_IS_VERSION}
+
+ADD files/env /tmp/env
+RUN cat /tmp/env >> /etc/environment
+
+ADD files/carbon.xml ${CARBON_HOME}/repository/conf/carbon.xml
+
+#------------------------
+# Copy Tomcat related PCA plugins
+#-----------------------
+ADD packs/plugins /mnt/plugins
+
+
+EXPOSE 9443
+
+# -----------------------
+# Define entry point
+# -----------------------
+ENTRYPOINT /usr/local/bin/run | /usr/sbin/sshd -D

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml
new file mode 100644
index 0000000..42d0765
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/carbon.xml
@@ -0,0 +1,625 @@
+<?xml version="1.0" encoding="ISO-8859-1"?>
+
+<!--
+  ~ Copyright 2005-2011 WSO2, Inc. (http://wso2.com)
+  ~
+  ~ Licensed 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.
+  -->
+
+<!--
+    This is the main server configuration file
+
+    ${carbon.home} represents the carbon.home system property.
+    Other system properties can be specified in a similar manner.
+-->
+<Server xmlns="http://wso2.org/projects/carbon/carbon.xml">
+
+    <!--
+       Product Name
+    -->
+    <Name>WSO2 Identity Server</Name>
+
+    <!--
+       machine readable unique key to identify each product
+    -->
+    <ServerKey>IS</ServerKey>
+
+    <!--
+       Product Version
+    -->
+    <Version>5.0.0</Version>
+
+    <!--
+       Host name or IP address of the machine hosting this server
+       e.g. www.wso2.org, 192.168.1.10
+       This is will become part of the End Point Reference of the
+       services deployed on this server instance.
+    -->
+    <HostName>CLUSTER_HOST_NAME</HostName>
+
+    <!--
+    Host name to be used for the Carbon management console
+    -->
+    <MgtHostName>CLUSTER_HOST_NAME</MgtHostName>
+
+    <!--
+        The URL of the back end server. This is where the admin services are hosted and
+        will be used by the clients in the front end server.
+        This is required only for the Front-end server. This is used when seperating BE server from FE server
+       -->
+    <ServerURL>local:/${carbon.context}/services/</ServerURL>
+    <!--
+    <ServerURL>https://localhost:${carbon.management.port}${carbon.context}/services/</ServerURL>
+    -->
+    <!--
+    The URL of the index page. This is where the user will be redirected after signing in to the
+    carbon server.
+    -->
+    <!-- IndexPageURL>/carbon/admin/index.jsp</IndexPageURL-->
+
+    <!--
+    For cApp deployment, we have to identify the roles that can be acted by the current server.
+    The following property is used for that purpose. Any number of roles can be defined here.
+    Regular expressions can be used in the role.
+    Ex : <Role>.*</Role> means this server can act any role
+    -->
+    <ServerRoles>
+        <Role>IdentityServer</Role>
+    </ServerRoles>
+
+    <!-- uncommnet this line to subscribe to a bam instance automatically -->
+    <!--<BamServerURL>https://bamhost:bamport/services/</BamServerURL>-->
+
+    <!--
+       The fully qualified name of the server
+    -->
+    <Package>org.wso2.carbon</Package>
+
+    <!--
+       Webapp context root of WSO2 Carbon.
+    -->
+    <WebContextRoot>/</WebContextRoot>
+
+    <!-- In-order to  get the registry http Port from the back-end when the default http transport is not the same-->
+    <!--RegistryHttpPort>9763</RegistryHttpPort-->
+
+    <!--
+    Number of items to be displayed on a management console page. This is used at the
+    backend server for pagination of various items.
+    -->
+    <ItemsPerPage>15</ItemsPerPage>
+
+    <!-- The endpoint URL of the cloud instance management Web service -->
+    <!--<InstanceMgtWSEndpoint>https://ec2.amazonaws.com/</InstanceMgtWSEndpoint>-->
+
+    <!--
+       Ports used by this server
+    -->
+    <Ports>
+
+        <!-- Ports offset. This entry will set the value of the ports defined below to
+         the define value + Offset.
+         e.g. Offset=2 and HTTPS port=9443 will set the effective HTTPS port to 9445
+         -->
+        <Offset>0</Offset>
+
+        <!-- The JMX Ports -->
+        <JMX>
+            <!--The port RMI registry is exposed-->
+            <RMIRegistryPort>9999</RMIRegistryPort>
+            <!--The port RMI server should be exposed-->
+            <RMIServerPort>11111</RMIServerPort>
+        </JMX>
+
+        <!-- Embedded LDAP server specific ports -->
+        <EmbeddedLDAP>
+            <!-- Port which embedded LDAP server runs -->
+            <LDAPServerPort>10389</LDAPServerPort>
+            <!-- Port which KDC (Kerberos Key Distribution Center) server runs -->
+            <KDCServerPort>8000</KDCServerPort>
+        </EmbeddedLDAP>
+
+        <!-- Embedded Qpid broker ports -->
+        <EmbeddedQpid>
+            <!-- Broker TCP Port -->
+            <BrokerPort>5672</BrokerPort>
+            <!-- SSL Port -->
+            <BrokerSSLPort>8672</BrokerSSLPort>
+        </EmbeddedQpid>
+
+        <!--
+                 Override datasources JNDIproviderPort defined in bps.xml and datasources.properties files
+        -->
+        <!--<JNDIProviderPort>2199</JNDIProviderPort>-->
+        <!--Override receive port of thrift based entitlement service.-->
+        <ThriftEntitlementReceivePort>10500</ThriftEntitlementReceivePort>
+
+    </Ports>
+
+    <!--
+        JNDI Configuration
+    -->
+    <JNDI>
+        <!--
+             The fully qualified name of the default initial context factory
+        -->
+        <DefaultInitialContextFactory>org.wso2.carbon.tomcat.jndi.CarbonJavaURLContextFactory</DefaultInitialContextFactory>
+        <!--
+             The restrictions that are done to various JNDI Contexts in a Multi-tenant environment
+        -->
+        <Restrictions>
+            <!--
+                Contexts that will be available only to the super-tenant
+            -->
+            <!-- <SuperTenantOnly>
+                <UrlContexts>
+                    <UrlContext>
+                        <Scheme>foo</Scheme>
+                    </UrlContext>
+                    <UrlContext>
+                        <Scheme>bar</Scheme>
+                    </UrlContext>
+                </UrlContexts>
+            </SuperTenantOnly> -->
+            <!--
+                Contexts that are common to all tenants
+            -->
+            <AllTenants>
+                <UrlContexts>
+                    <UrlContext>
+                        <Scheme>java</Scheme>
+                    </UrlContext>
+                    <!-- <UrlContext>
+                        <Scheme>foo</Scheme>
+                    </UrlContext> -->
+                </UrlContexts>
+            </AllTenants>
+            <!--
+                 All other contexts not mentioned above will be available on a per-tenant basis
+                 (i.e. will not be shared among tenants)
+            -->
+        </Restrictions>
+    </JNDI>
+
+    <!--
+        Property to determine if the server is running an a cloud deployment environment.
+        This property should only be used to determine deployment specific details that are
+        applicable only in a cloud deployment, i.e when the server deployed *-as-a-service.
+    -->
+    <IsCloudDeployment>false</IsCloudDeployment>
+
+    <!--
+	Property to determine whether usage data should be collected for metering purposes
+    -->
+    <EnableMetering>false</EnableMetering>
+
+    <!-- The Max time a thread should take for execution in seconds -->
+    <MaxThreadExecutionTime>600</MaxThreadExecutionTime>
+
+    <!--
+        A flag to enable or disable Ghost Deployer. By default this is set to false. That is
+        because the Ghost Deployer works only with the HTTP/S transports. If you are using
+        other transports, don't enable Ghost Deployer.
+    -->
+    <GhostDeployment>
+        <Enabled>false</Enabled>
+        <PartialUpdate>false</PartialUpdate>
+    </GhostDeployment>
+
+    <!--
+    Axis2 related configurations
+    -->
+    <Axis2Config>
+        <!--
+             Location of the Axis2 Services & Modules repository
+
+             This can be a directory in the local file system, or a URL.
+
+             e.g.
+             1. /home/wso2wsas/repository/ - An absolute path
+             2. repository - In this case, the path is relative to CARBON_HOME
+             3. file:///home/wso2wsas/repository/
+             4. http://wso2wsas/repository/
+        -->
+        <RepositoryLocation>${carbon.home}/repository/deployment/server/</RepositoryLocation>
+
+        <!--
+         Deployment update interval in seconds. This is the interval between repository listener
+         executions.
+        -->
+        <DeploymentUpdateInterval>15</DeploymentUpdateInterval>
+
+        <!--
+            Location of the main Axis2 configuration descriptor file, a.k.a. axis2.xml file
+
+            This can be a file on the local file system, or a URL
+
+            e.g.
+            1. /home/repository/axis2.xml - An absolute path
+            2. conf/axis2.xml - In this case, the path is relative to CARBON_HOME
+            3. file:///home/carbon/repository/axis2.xml
+            4. http://repository/conf/axis2.xml
+        -->
+        <ConfigurationFile>${carbon.home}/repository/conf/axis2/axis2.xml</ConfigurationFile>
+
+        <!--
+          ServiceGroupContextIdleTime, which will be set in ConfigurationContex
+          for multiple clients which are going to access the same ServiceGroupContext
+          Default Value is 30 Sec.
+        -->
+        <ServiceGroupContextIdleTime>30000</ServiceGroupContextIdleTime>
+
+        <!--
+          This repository location is used to crete the client side configuration
+          context used by the server when calling admin services.
+        -->
+        <ClientRepositoryLocation>${carbon.home}/repository/deployment/client/</ClientRepositoryLocation>
+        <!-- This axis2 xml is used in createing the configuration context by the FE server
+         calling to BE server -->
+        <clientAxis2XmlLocation>${carbon.home}/repository/conf/axis2/axis2_client.xml</clientAxis2XmlLocation>
+        <!-- If this parameter is set, the ?wsdl on an admin service will not give the admin service wsdl. -->
+        <HideAdminServiceWSDLs>true</HideAdminServiceWSDLs>
+
+        <!--WARNING-Use With Care! Uncommenting bellow parameter would expose all AdminServices in HTTP transport.
+        With HTTP transport your credentials and data routed in public channels are vulnerable for sniffing attacks.
+        Use bellow parameter ONLY if your communication channels are confirmed to be secured by other means -->
+        <!--HttpAdminServices>*</HttpAdminServices-->
+
+    </Axis2Config>
+
+    <!--
+       The default user roles which will be created when the server
+       is started up for the first time.
+    -->
+    <ServiceUserRoles>
+        <Role>
+            <Name>admin</Name>
+            <Description>Default Administrator Role</Description>
+        </Role>
+        <Role>
+            <Name>user</Name>
+            <Description>Default User Role</Description>
+        </Role>
+    </ServiceUserRoles>
+
+    <!--
+      Enable following config to allow Emails as usernames.
+    -->
+    <!--EnableEmailUserName>true</EnableEmailUserName-->
+
+    <!--
+      Security configurations
+    -->
+    <Security>
+        <!--
+            KeyStore which will be used for encrypting/decrypting passwords
+            and other sensitive information.
+        -->
+        <KeyStore>
+            <!-- Keystore file location-->
+            <Location>${carbon.home}/repository/resources/security/wso2carbon.jks</Location>
+            <!-- Keystore type (JKS/PKCS12 etc.)-->
+            <Type>JKS</Type>
+            <!-- Keystore password-->
+            <Password>wso2carbon</Password>
+            <!-- Private Key alias-->
+            <KeyAlias>wso2carbon</KeyAlias>
+            <!-- Private Key password-->
+            <KeyPassword>wso2carbon</KeyPassword>
+        </KeyStore>
+
+        <!--
+           Encrypt Decrypt Store will be used for encrypting and decrypting
+       -->
+        <RegistryKeyStore>
+            <!-- Keystore file location-->
+            <Location>${carbon.home}/repository/resources/security/wso2carbon.jks</Location>
+            <!-- Keystore type (JKS/PKCS12 etc.)-->
+            <Type>JKS</Type>
+            <!-- Keystore password-->
+            <Password>wso2carbon</Password>
+            <!-- Private Key alias-->
+            <KeyAlias>wso2carbon</KeyAlias>
+            <!-- Private Key password-->
+            <KeyPassword>wso2carbon</KeyPassword>
+        </RegistryKeyStore>
+
+        <!--
+            System wide trust-store which is used to maintain the certificates of all
+            the trusted parties.
+        -->
+        <TrustStore>
+            <!-- trust-store file location -->
+            <Location>${carbon.home}/repository/resources/security/client-truststore.jks</Location>
+            <!-- trust-store type (JKS/PKCS12 etc.) -->
+            <Type>JKS</Type>
+            <!-- trust-store password -->
+            <Password>wso2carbon</Password>
+        </TrustStore>
+
+        <!--
+            The Authenticator configuration to be used at the JVM level. We extend the
+            java.net.Authenticator to make it possible to authenticate to given servers and
+            proxies.
+        -->
+        <NetworkAuthenticatorConfig>
+            <!--
+                Below is a sample configuration for a single authenticator. Please note that
+                all child elements are mandatory. Not having some child elements would lead to
+                exceptions at runtime.
+            -->
+            <!-- <Credential> -->
+            <!--
+                the pattern that would match a subset of URLs for which this authenticator
+                would be used
+            -->
+            <!-- <Pattern>regularExpression</Pattern> -->
+            <!--
+                the type of this authenticator. Allowed values are:
+                1. server
+                2. proxy
+            -->
+            <!-- <Type>proxy</Type> -->
+            <!-- the username used to log in to server/proxy -->
+            <!-- <Username>username</Username> -->
+            <!-- the password used to log in to server/proxy -->
+            <!-- <Password>password</Password> -->
+            <!-- </Credential> -->
+        </NetworkAuthenticatorConfig>
+
+        <!--
+         The Tomcat realm to be used for hosted Web applications. Allowed values are;
+         1. UserManager
+         2. Memory
+
+         If this is set to 'UserManager', the realm will pick users & roles from the system's
+         WSO2 User Manager. If it is set to 'memory', the realm will pick users & roles from
+         CARBON_HOME/repository/conf/tomcat/tomcat-users.xml
+        -->
+        <TomcatRealm>UserManager</TomcatRealm>
+
+        <!--Option to disable storing of tokens issued by STS-->
+        <DisableTokenStore>false</DisableTokenStore>
+
+        <!--
+         Security token store class name. If this is not set, default class will be
+         org.wso2.carbon.security.util.SecurityTokenStore
+        -->
+        <TokenStoreClassName>org.wso2.carbon.identity.sts.store.DBTokenStore</TokenStoreClassName>
+    </Security>
+
+    <!--
+       The temporary work directory
+    -->
+    <WorkDirectory>${carbon.home}/tmp/work</WorkDirectory>
+
+    <!--
+       House-keeping configuration
+    -->
+    <HouseKeeping>
+
+        <!--
+           true  - Start House-keeping thread on server startup
+           false - Do not start House-keeping thread on server startup.
+                   The user will run it manually as and when he wishes.
+        -->
+        <AutoStart>true</AutoStart>
+
+        <!--
+           The interval in *minutes*, between house-keeping runs
+        -->
+        <Interval>10</Interval>
+
+        <!--
+          The maximum time in *minutes*, temp files are allowed to live
+          in the system. Files/directories which were modified more than
+          "MaxTempFileLifetime" minutes ago will be removed by the
+          house-keeping task
+        -->
+        <MaxTempFileLifetime>30</MaxTempFileLifetime>
+    </HouseKeeping>
+
+    <!--
+       Configuration for handling different types of file upload & other file uploading related
+       config parameters.
+       To map all actions to a particular FileUploadExecutor, use
+       <Action>*</Action>
+    -->
+    <FileUploadConfig>
+        <!--
+           The total file upload size limit in MB
+        -->
+        <TotalFileSizeLimit>100</TotalFileSizeLimit>
+
+        <Mapping>
+            <Actions>
+                <Action>keystore</Action>
+                <Action>certificate</Action>
+                <Action>*</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.AnyFileUploadExecutor</Class>
+        </Mapping>
+
+        <Mapping>
+            <Actions>
+                <Action>jarZip</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.JarZipUploadExecutor</Class>
+        </Mapping>
+        <Mapping>
+            <Actions>
+                <Action>dbs</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.DBSFileUploadExecutor</Class>
+        </Mapping>
+        <Mapping>
+            <Actions>
+                <Action>tools</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.ToolsFileUploadExecutor</Class>
+        </Mapping>
+        <Mapping>
+            <Actions>
+                <Action>toolsAny</Action>
+            </Actions>
+            <Class>org.wso2.carbon.ui.transports.fileupload.ToolsAnyFileUploadExecutor</Class>
+        </Mapping>
+    </FileUploadConfig>
+
+    <!--
+       Processors which process special HTTP GET requests such as ?wsdl, ?policy etc.
+
+       In order to plug in a processor to handle a special request, simply add an entry to this
+       section.
+
+       The value of the Item element is the first parameter in the query string(e.g. ?wsdl)
+       which needs special processing
+
+       The value of the Class element is a class which implements
+       org.wso2.carbon.transport.HttpGetRequestProcessor
+    -->
+    <HttpGetRequestProcessors>
+        <Processor>
+            <Item>info</Item>
+            <Class>org.wso2.carbon.core.transports.util.InfoProcessor</Class>
+        </Processor>
+        <Processor>
+            <Item>wsdl</Item>
+            <Class>org.wso2.carbon.core.transports.util.Wsdl11Processor</Class>
+        </Processor>
+        <Processor>
+            <Item>wsdl2</Item>
+            <Class>org.wso2.carbon.core.transports.util.Wsdl20Processor</Class>
+        </Processor>
+        <Processor>
+            <Item>xsd</Item>
+            <Class>org.wso2.carbon.core.transports.util.XsdProcessor</Class>
+        </Processor>
+    </HttpGetRequestProcessors>
+
+    <!-- Deployment Synchronizer Configuration. t Enabled value to true when running with "svn based" dep sync.
+	In master nodes you need to set both AutoCommit and AutoCheckout to true
+	and in  worker nodes set only AutoCheckout to true.
+    -->
+    <DeploymentSynchronizer>
+        <Enabled>false</Enabled>
+        <AutoCommit>false</AutoCommit>
+        <AutoCheckout>true</AutoCheckout>
+        <RepositoryType>svn</RepositoryType>
+        <SvnUrl>http://svnrepo.example.com/repos/</SvnUrl>
+        <SvnUser>username</SvnUser>
+        <SvnPassword>password</SvnPassword>
+        <SvnUrlAppendTenantId>true</SvnUrlAppendTenantId>
+    </DeploymentSynchronizer>
+
+    <!-- Deployment Synchronizer Configuration. Uncomment the following section when running with "registry based" dep sync.
+        In master nodes you need to set both AutoCommit and AutoCheckout to true
+        and in  worker nodes set only AutoCheckout to true.
+    -->
+    <!--<DeploymentSynchronizer>
+        <Enabled>true</Enabled>
+        <AutoCommit>false</AutoCommit>
+        <AutoCheckout>true</AutoCheckout>
+    </DeploymentSynchronizer>-->
+
+    <!-- Mediation persistence configurations. Only valid if mediation features are available i.e. ESB -->
+    <!--<MediationConfig>
+        <LoadFromRegistry>false</LoadFromRegistry>
+        <SaveToFile>false</SaveToFile>
+        <Persistence>enabled</Persistence>
+        <RegistryPersistence>enabled</RegistryPersistence>
+    </MediationConfig>-->
+
+    <!--
+    Server intializing code, specified as implementation classes of org.wso2.carbon.core.ServerInitializer.
+    This code will be run when the Carbon server is initialized
+    -->
+    <ServerInitializers>
+        <!--<Initializer></Initializer>-->
+    </ServerInitializers>
+
+    <!--
+    Indicates whether the Carbon Servlet is required by the system, and whether it should be
+    registered
+    -->
+    <RequireCarbonServlet>${require.carbon.servlet}</RequireCarbonServlet>
+
+    <!--
+    Carbon H2 OSGI Configuration
+    By default non of the servers start.
+        name="web" - Start the web server with the H2 Console
+        name="webPort" - The port (default: 8082)
+        name="webAllowOthers" - Allow other computers to connect
+        name="webSSL" - Use encrypted (HTTPS) connections
+        name="tcp" - Start the TCP server
+        name="tcpPort" - The port (default: 9092)
+        name="tcpAllowOthers" - Allow other computers to connect
+        name="tcpSSL" - Use encrypted (SSL) connections
+        name="pg" - Start the PG server
+        name="pgPort"  - The port (default: 5435)
+        name="pgAllowOthers"  - Allow other computers to connect
+        name="trace" - Print additional trace information; for all servers
+        name="baseDir" - The base directory for H2 databases; for all servers
+    -->
+    <!--H2DatabaseConfiguration>
+        <property name="web" />
+        <property name="webPort">8082</property>
+        <property name="webAllowOthers" />
+        <property name="webSSL" />
+        <property name="tcp" />
+        <property name="tcpPort">9092</property>
+        <property name="tcpAllowOthers" />
+        <property name="tcpSSL" />
+        <property name="pg" />
+        <property name="pgPort">5435</property>
+        <property name="pgAllowOthers" />
+        <property name="trace" />
+        <property name="baseDir">${carbon.home}</property>
+    </H2DatabaseConfiguration-->
+    <!--Disabling statistics reporter by default-->
+    <StatisticsReporterDisabled>true</StatisticsReporterDisabled>
+
+    <!-- Enable accessing Admin Console via HTTP -->
+    <!-- EnableHTTPAdminConsole>true</EnableHTTPAdminConsole -->
+
+    <!--
+       Default Feature Repository of WSO2 Carbon.
+    -->
+    <FeatureRepository>
+        <RepositoryName>default repository</RepositoryName>
+        <RepositoryURL>${p2.repo.url}</RepositoryURL>
+    </FeatureRepository>
+
+    <!--
+	Configure API Management
+   -->
+    <APIManagement>
+
+        <!--Uses the embedded API Manager by default. If you want to use an external
+        API Manager instance to manage APIs, configure below  externalAPIManager-->
+
+        <Enabled>true</Enabled>
+
+        <!--Uncomment and configure API Gateway and
+        Publisher URLs to use external API Manager instance-->
+
+        <!--ExternalAPIManager>
+
+            <APIGatewayURL>http://localhost:8281</APIGatewayURL>
+            <APIPublisherURL>http://localhost:8281/publisher</APIPublisherURL>
+
+        </ExternalAPIManager-->
+
+        <LoadAPIContextsInServerStartup>true</LoadAPIContextsInServerStartup>
+    </APIManagement>
+</Server>

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env
new file mode 100644
index 0000000..e7555c7
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/files/env
@@ -0,0 +1,2 @@
+JAVA_HOME=/opt/jdk1.7.0_67
+CARBON_HOME=/opt/wso2is-5.0.0
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py
new file mode 100644
index 0000000..53e10fe
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.py
@@ -0,0 +1,144 @@
+# 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.
+
+import mdsclient
+from plugins.contracts import ICartridgeAgentPlugin
+from xml.dom.minidom import parse
+import socket
+from modules.util.log import LogFactory
+import time
+import subprocess
+import os
+
+
+class WSO2ISMetaDataHandler(ICartridgeAgentPlugin):
+
+    def run_plugin(self, values):
+        log = LogFactory().get_log(__name__)
+        # read tomcat app related values from metadata
+        mds_response = None
+        while mds_response is None:
+            log.debug("Waiting for SSO_ISSUER and CALLBACK_URL to be available from metadata service for app ID: %s"
+                      % values["APPLICATION_ID"])
+            time.sleep(5)
+            mds_response = mdsclient.get(app=True)
+            if mds_response is not None and mds_response.properties.get("SSO_ISSUER") is None or \
+                    mds_response.properties.get("CALLBACK_URL") is None:
+                mds_response = None
+        # mds_response = mdsclient.get()
+        issuer = mds_response.properties["SSO_ISSUER"]
+        acs = mds_response.properties["CALLBACK_URL"]
+
+        # add a service provider in the security/sso-idp-config.xml file
+        # is_root = values["APPLICATION_PATH"]
+        is_root = os.environ.get("CARBON_HOME")
+        sso_idp_file = "%s/repository/conf/security/sso-idp-config.xml" % is_root
+
+        # <SSOIdentityProviderConfig>
+        #     <ServiceProviders>
+        #         <ServiceProvider>
+        #         <Issuer>wso2.my.dashboard</Issuer>
+        #         <AssertionConsumerService>https://is.wso2.com/dashboard/acs</AssertionConsumerService>
+        #         <SignAssertion>true</SignAssertion>
+        #         <SignResponse>true</SignResponse>
+        #         <EnableAttributeProfile>false</EnableAttributeProfile>
+        #         <IncludeAttributeByDefault>false</IncludeAttributeByDefault>
+        #         <Claims>
+        #             <Claim>http://wso2.org/claims/role</Claim>
+        #         </Claims>
+        #         <EnableSingleLogout>false</EnableSingleLogout>
+        #         <SingleLogoutUrl></SingleLogoutUrl>
+        #         <EnableAudienceRestriction>true</EnableAudienceRestriction>
+        #         <AudiencesList>
+        #             <Audience>carbonServer</Audience>
+        #         </AudiencesList>
+        #         <ConsumingServiceIndex></ConsumingServiceIndex>
+        #     </ServiceProvider>
+        with open(sso_idp_file, "r") as f:
+            sp_dom = parse(f)
+
+        root_element = sp_dom.documentElement
+        sps_element = sp_dom.getElementsByTagName("ServiceProviders")[0]
+
+        sp_entry = sp_dom.createElement("ServiceProvider")
+
+        sp_entry_issuer = sp_dom.createElement("Issuer")
+        sp_entry_issuer.appendChild(sp_dom.createTextNode(issuer))
+
+        sp_entry_acs = sp_dom.createElement("AssertionConsumerService")
+        sp_entry_acs.appendChild(sp_dom.createTextNode(acs))
+
+        sp_entry_sign_resp = sp_dom.createElement("SignResponse")
+        sp_entry_sign_resp.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry_sign_assert = sp_dom.createElement("SignAssertion")
+        sp_entry_sign_assert.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry_single_logout = sp_dom.createElement("EnableSingleLogout")
+        sp_entry_single_logout.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry_attribute_profile = sp_dom.createElement("EnableAttributeProfile")
+        sp_entry_attribute_profile.appendChild(sp_dom.createTextNode("true"))
+
+        sp_entry.appendChild(sp_entry_issuer)
+        sp_entry.appendChild(sp_entry_acs)
+        sp_entry.appendChild(sp_entry_sign_resp)
+        sp_entry.appendChild(sp_entry_sign_assert)
+        sp_entry.appendChild(sp_entry_single_logout)
+        sp_entry.appendChild(sp_entry_attribute_profile)
+
+        sps_element.appendChild(sp_entry)
+
+        with open(sso_idp_file, 'w+') as f:
+            root_element.writexml(f, newl="\n")
+        # root_element.writexml(f)
+
+        # data = json.loads(urllib.urlopen("http://ip.jsontest.com/").read())
+        # ip_entry = data["ip"]
+
+        # publish SAML_ENDPOINT to metadata service
+        # member_hostname = socket.gethostname()
+        member_hostname = values["HOST_NAME"]
+        payload_ports = values["PORT_MAPPINGS"].split("|")
+        if values.get("LB_CLUSTER_ID") is not None:
+            port_no = payload_ports[2].split(":")[1]
+        else:
+            port_no = payload_ports[1].split(":")[1]
+        saml_endpoint = "https://%s:%s/samlsso" % (member_hostname, port_no)
+        publish_data = mdsclient.MDSPutRequest()
+        hostname_entry = {"key": "SAML_ENDPOINT", "values": saml_endpoint}
+        properties_data = [hostname_entry]
+        publish_data.properties = properties_data
+
+        mdsclient.put(publish_data, app=True)
+
+        # start servers
+        log.info("Starting WSO2 IS server")
+
+        # set configurations
+        carbon_replace_command = "sed -i \"s/CLUSTER_HOST_NAME/%s/g\" %s" % (member_hostname, "/opt/wso2is-5.0.0/repository/conf/carbon.xml")
+
+        p = subprocess.Popen(carbon_replace_command, shell=True)
+        output, errors = p.communicate()
+        log.debug("Set carbon.xml hostname")
+
+        wso2is_start_command = "exec /opt/wso2is-5.0.0/bin/wso2server.sh start"
+        env_var = os.environ.copy()
+        env_var["JAVA_HOME"] = "/opt/jdk1.7.0_67"
+        p = subprocess.Popen(wso2is_start_command, env=env_var, shell=True)
+        output, errors = p.communicate()
+        log.debug("WSO2 IS server started")

http://git-wip-us.apache.org/repos/asf/stratos/blob/188377af/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin
----------------------------------------------------------------------
diff --git a/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin
new file mode 100644
index 0000000..d0d7e91
--- /dev/null
+++ b/tools/docker-images/cartridge-docker-images/service-images/wso2is-saml-sso/packs/plugins/WSO2ISMetaDataHandler.yapsy-plugin
@@ -0,0 +1,9 @@
+[Core]
+Name = WSO2ISMetaDataHandler to read  and publish metadata from and to Metadata service
+Module = WSO2ISMetaDataHandler
+
+[Documentation]
+Description = InstanceStartedEvent
+Author = Op1
+Version = 0.1
+Website = stratos.apache.org
\ No newline at end of file


[43/50] [abbrv] stratos git commit: Changed PORT_MAPPINGS port to KubernetesServicePort from port

Posted by re...@apache.org.
Changed PORT_MAPPINGS port to KubernetesServicePort from port


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

Branch: refs/heads/docker-grouping-merge
Commit: d0a0b85f485790a3ee1cc73c472b8314aae12358
Parents: 718cacd
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 23:52:31 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 .../stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/d0a0b85f/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index 34af6ac..c6064fe 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -542,7 +542,7 @@ public class KubernetesIaas extends Iaas {
                             portMappingStrBuilder.append(":");
                         }
                         portMappingStrBuilder.append(String.format("PROTOCOL:%s|PORT:%d|PROXY_PORT:%d",
-                                portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
+                                portMapping.getProtocol(), portMapping.getKubernetesServicePort(), portMapping.getProxyPort()));
 
                         if (log.isInfoEnabled()) {
                             log.info(String.format("Kubernetes service port generated: [cluster-id] %s [port] %d " +


[45/50] [abbrv] stratos git commit: Samples - Added METADATA_SERVICE_URL to kubernetes cluster definition for ec2

Posted by re...@apache.org.
Samples - Added METADATA_SERVICE_URL to kubernetes cluster definition for ec2


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

Branch: refs/heads/docker-grouping-merge
Commit: 718cacd37b5cc6da1d82ba9b4de4e73f431fea89
Parents: 188377a
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 23:29:04 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 samples/kubernetes-clusters/kubernetes-cluster-ec2.json | 4 ++++
 1 file changed, 4 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/718cacd3/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
----------------------------------------------------------------------
diff --git a/samples/kubernetes-clusters/kubernetes-cluster-ec2.json b/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
index 94cb4bf..0affc00 100644
--- a/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
+++ b/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
@@ -59,6 +59,10 @@
         {
             "name": "payload_parameter.LOG_LEVEL",
             "value": "DEBUG"
+        },
+        {
+            "name": "payload_parameter.METADATA_SERVICE_URL",
+            "value": "https://54.179.197.243:9443"
         }
     ]
 }


[30/50] [abbrv] stratos git commit: Fixing deploy.sh in tomcat-sso sample application

Posted by re...@apache.org.
Fixing deploy.sh in tomcat-sso sample application


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

Branch: refs/heads/docker-grouping-merge
Commit: 4e7a7c978b2a035bb918b93c9e0281542b55beab
Parents: 66ea671
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 02:04:13 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 02:04:13 2015 +0530

----------------------------------------------------------------------
 samples/applications/tomcat-sso/scripts/common/deploy.sh | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/4e7a7c97/samples/applications/tomcat-sso/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/common/deploy.sh b/samples/applications/tomcat-sso/scripts/common/deploy.sh
index a20554a..32ba4be 100755
--- a/samples/applications/tomcat-sso/scripts/common/deploy.sh
+++ b/samples/applications/tomcat-sso/scripts/common/deploy.sh
@@ -46,4 +46,4 @@ curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/applicat
 sleep 1
 
 echo "Deploying application..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat/deploy
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat-sso/deploy


[13/50] [abbrv] stratos git commit: Adding kubernetes live test to cleanup kubernetes cluster

Posted by re...@apache.org.
Adding kubernetes live test to cleanup kubernetes cluster


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

Branch: refs/heads/docker-grouping-merge
Commit: 5587040c1fa9af1ffc3cdd89674e93dcf504fb9d
Parents: 7cc23ff
Author: Imesh Gunaratne <im...@apache.org>
Authored: Fri Feb 27 21:11:37 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Fri Feb 27 21:12:08 2015 +0530

----------------------------------------------------------------------
 .../pom.xml                                     |  17 +-
 .../client/live/AbstractLiveTest.java           | 228 +++++++++++++++++++
 .../live/KubernetesApiClientLiveTest.java       | 197 +---------------
 .../client/live/KubernetesClusterCleanTest.java |  61 +++++
 4 files changed, 306 insertions(+), 197 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/5587040c/components/org.apache.stratos.kubernetes.client/pom.xml
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.kubernetes.client/pom.xml b/components/org.apache.stratos.kubernetes.client/pom.xml
index 81c0733..921c717 100644
--- a/components/org.apache.stratos.kubernetes.client/pom.xml
+++ b/components/org.apache.stratos.kubernetes.client/pom.xml
@@ -110,7 +110,22 @@
                         <artifactId>maven-surefire-plugin</artifactId>
                         <configuration>
                             <groups>org.apache.stratos.kubernetes.client.LiveTests</groups>
-                            <systemPropertyVariables></systemPropertyVariables>
+                        </configuration>
+                    </plugin>
+                </plugins>
+            </build>
+        </profile>
+        <profile>
+            <id>clean</id>
+            <build>
+                <plugins>
+                    <plugin>
+                        <groupId>org.apache.maven.plugins</groupId>
+                        <artifactId>maven-surefire-plugin</artifactId>
+                        <configuration>
+                            <includes>
+                                <include>**/*/KubernetesClusterCleanTest.java</include>
+                            </includes>
                         </configuration>
                     </plugin>
                 </plugins>

http://git-wip-us.apache.org/repos/asf/stratos/blob/5587040c/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/AbstractLiveTest.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/AbstractLiveTest.java b/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/AbstractLiveTest.java
new file mode 100644
index 0000000..bf00c40
--- /dev/null
+++ b/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/AbstractLiveTest.java
@@ -0,0 +1,228 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.stratos.kubernetes.client.live;
+
+import junit.framework.TestCase;
+import org.apache.commons.lang3.StringUtils;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.stratos.kubernetes.client.KubernetesApiClient;
+import org.apache.stratos.kubernetes.client.KubernetesConstants;
+import org.apache.stratos.kubernetes.client.exceptions.KubernetesClientException;
+import org.apache.stratos.kubernetes.client.model.Pod;
+import org.apache.stratos.kubernetes.client.model.Port;
+import org.apache.stratos.kubernetes.client.model.Service;
+import org.junit.AfterClass;
+import org.junit.BeforeClass;
+
+import java.io.IOException;
+import java.util.ArrayList;
+import java.util.List;
+
+/**
+ * Abstract live test class.
+ */
+public class AbstractLiveTest extends TestCase {
+
+    protected static final Log log = LogFactory.getLog(AbstractLiveTest.class);
+
+    protected static final String DEFAULT_KUBERNETES_MASTER_IP = "172.17.8.101";
+    protected static final int KUBERNETES_API_PORT = 8080;
+
+    protected static final String DEFAULT_DOCKER_IMAGE = "fnichol/uhttpd";
+    protected static final int DEFAULT_CONTAINER_PORT = 80;
+    protected static final int SERVICE_PORT = 4500;
+    protected static final int POD_ACTIVATION_WAIT_TIME = 10000; // 10 seconds
+
+    protected static final String KUBERNETES_API_ENDPOINT = "kubernetes.api.endpoint";
+    protected static final String MINION_PUBLIC_IPS = "minion.public.ips";
+    protected static final String DOCKER_IMAGE = "docker.image";
+    protected static final String CONTAINER_PORT = "container.port";
+    protected static final String TEST_SERVICE_SOCKET = "test.service.socket";
+    protected static final String TEST_POD_ACTIVATION = "test.pod.activation";
+
+    protected KubernetesApiClient client;
+    protected String dockerImage;
+    protected String endpoint;
+    protected int containerPort;
+    protected boolean testPodActivation;
+    protected boolean testServiceSocket;
+    protected String[] minionPublicIPs = { "172.17.8.102" };
+    protected List<String> podIdList = new ArrayList<String>();
+    protected List<String> serviceIdList = new ArrayList<String>();
+
+    @BeforeClass
+    public void setUp() {
+        log.info("Setting up live test...");
+        endpoint = System.getProperty(KUBERNETES_API_ENDPOINT);
+        if (endpoint == null) {
+            endpoint = "http://" + DEFAULT_KUBERNETES_MASTER_IP + ":" + KUBERNETES_API_PORT + "/api/"
+                    + KubernetesConstants.KUBERNETES_API_VERSION + "/";
+        }
+        log.info(KUBERNETES_API_ENDPOINT + ": " + endpoint);
+        client = new KubernetesApiClient(endpoint);
+
+        dockerImage = System.getProperty(DOCKER_IMAGE);
+        if (dockerImage == null) {
+            dockerImage = DEFAULT_DOCKER_IMAGE;
+        }
+        log.info(DOCKER_IMAGE + ": " + dockerImage);
+
+        String containerPortStr = System.getProperty(CONTAINER_PORT);
+        if (StringUtils.isNotBlank(containerPortStr)) {
+            containerPort = Integer.parseInt(containerPortStr);
+        } else {
+            containerPort = DEFAULT_CONTAINER_PORT;
+        }
+        log.info(CONTAINER_PORT + ": " + containerPort);
+
+        testPodActivation = false;
+        String testPodActivationStr = System.getProperty(TEST_POD_ACTIVATION);
+        if (StringUtils.isNotBlank(testPodActivationStr)) {
+            testPodActivation = Boolean.parseBoolean(testPodActivationStr);
+        }
+        log.info(TEST_POD_ACTIVATION + ": " + testPodActivation);
+
+        testServiceSocket = false;
+        String testServiceSocketStr = System.getProperty(TEST_SERVICE_SOCKET);
+        if (StringUtils.isNotBlank(testServiceSocketStr)) {
+            testServiceSocket = Boolean.parseBoolean(testServiceSocketStr);
+        }
+        log.info(TEST_SERVICE_SOCKET + ": " + testServiceSocket);
+
+        String minionPublicIPsStr = System.getProperty(MINION_PUBLIC_IPS);
+        if(StringUtils.isNotBlank(minionPublicIPsStr)) {
+            minionPublicIPs = minionPublicIPsStr.split(",");
+        }
+        log.info(MINION_PUBLIC_IPS + ": " + minionPublicIPsStr);
+        log.info("Kubernetes live test setup completed");
+    }
+
+    @AfterClass
+    public void tearDown() {
+        log.info("Cleaning kubernetes resources...");
+        deleteServices();
+        deletePods();
+        log.info("Kubernetes resources cleaned");
+    }
+
+    protected void createPod(String podId, String podName, String containerPortName) throws KubernetesClientException {
+        log.info("Creating pod: [pod] " + podId);
+        List<Port> ports = createPorts(containerPortName);
+        client.createPod(podId, podName, dockerImage, ports, null);
+        podIdList.add(podId);
+
+        sleep(2000);
+        Pod pod = client.getPod(podId);
+        assertNotNull(pod);
+        log.info("Pod created successfully: [pod] " + podId);
+
+        if (testPodActivation) {
+            boolean activated = false;
+            long startTime = System.currentTimeMillis();
+            while(!activated) {
+                if((System.currentTimeMillis() - startTime) > POD_ACTIVATION_WAIT_TIME) {
+                    log.info(String.format("Pod did not activate within %d seconds: [pod] %s",
+                            POD_ACTIVATION_WAIT_TIME/1000, podId));
+                    break;
+                }
+
+                log.info("Waiting pod status to be changed to running: [pod] " + podId);
+                sleep(2000);
+                pod = client.getPod(podId);
+                if((pod != null) && (pod.getCurrentState().getStatus().equals(KubernetesConstants.POD_STATUS_RUNNING))) {
+                    activated = true;
+                    log.info("Pod state changed to running: [pod]" + pod.getId());
+                }
+            }
+
+            assertNotNull(pod);
+            assertEquals(KubernetesConstants.POD_STATUS_RUNNING, pod.getCurrentState().getStatus());
+        }
+    }
+
+    void deletePod(String podId) throws KubernetesClientException {
+        log.info("Deleting pod: " + podId);
+        client.deletePod(podId);
+        podIdList.remove(podId);
+
+        assertNull(client.getPod(podId));
+        log.info("Pod deleted successfully: " + podId);
+    }
+
+    public void deletePods() {
+        try {
+            for(String podId : podIdList) {
+                deletePod(podId);
+            }
+        } catch (KubernetesClientException e) {
+            log.error("Could not delete pods", e);
+        }
+    }
+
+    protected void createService(String serviceId, String serviceName, int servicePort, String containerPortName,
+                               String[] publicIPs) throws KubernetesClientException, InterruptedException, IOException {
+        log.info("Creating service...");
+        client.createService(serviceId, serviceName, servicePort, containerPortName, publicIPs);
+        serviceIdList.add(serviceId);
+
+        sleep(1000);
+        Service service = client.getService(serviceId);
+        assertNotNull(service);
+        log.info("Service creation successful");
+    }
+
+    void deleteService(String serviceId) throws KubernetesClientException {
+        log.info(String.format("Deleting service: [service] %s", serviceId));
+        client.deleteService(serviceId);
+        serviceIdList.remove(serviceId);
+
+        sleep(1000);
+        assertNull(client.getService(serviceId));
+        log.info(String.format("Service deleted successfully: [service] %s", serviceId));
+    }
+
+    protected void deleteServices() {
+        try {
+            for(String serviceId : serviceIdList) {
+                deleteService(serviceId);
+            }
+        } catch (KubernetesClientException e) {
+            log.error("Could not delete services", e);
+        }
+    }
+
+    protected void sleep(long time) {
+        try {
+            Thread.sleep(time);
+        } catch (InterruptedException ignore) {
+        }
+    }
+
+    protected List<Port> createPorts(String containerPortName) {
+        List<Port> ports = new ArrayList<Port>();
+        Port port = new Port();
+        port.setName(containerPortName);
+        port.setContainerPort(containerPort);
+        port.setProtocol("tcp");
+        ports.add(port);
+        return ports;
+    }
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/5587040c/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesApiClientLiveTest.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesApiClientLiveTest.java b/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesApiClientLiveTest.java
index a7fa5ad..5c425aa 100644
--- a/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesApiClientLiveTest.java
+++ b/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesApiClientLiveTest.java
@@ -20,25 +20,13 @@
  */
 package org.apache.stratos.kubernetes.client.live;
 
-import junit.framework.TestCase;
-import org.apache.commons.lang3.StringUtils;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.kubernetes.client.KubernetesApiClient;
-import org.apache.stratos.kubernetes.client.KubernetesConstants;
 import org.apache.stratos.kubernetes.client.exceptions.KubernetesClientException;
-import org.apache.stratos.kubernetes.client.model.Pod;
-import org.apache.stratos.kubernetes.client.model.Port;
-import org.apache.stratos.kubernetes.client.model.Service;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
 import org.junit.Test;
 import org.junit.experimental.categories.Category;
 
-import java.io.IOException;
 import java.net.Socket;
-import java.util.ArrayList;
-import java.util.List;
 
 /**
  * Notes:
@@ -51,90 +39,10 @@ import java.util.List;
  * available in the given kubernetes environment.
  */
 @Category(org.apache.stratos.kubernetes.client.LiveTests.class)
-public class KubernetesApiClientLiveTest extends TestCase {
+public class KubernetesApiClientLiveTest extends AbstractLiveTest {
 
     private static final Log log = LogFactory.getLog(KubernetesApiClientLiveTest.class);
 
-    private static final String DEFAULT_KUBERNETES_MASTER_IP = "172.17.8.101";
-    private static final int KUBERNETES_API_PORT = 8080;
-
-    private static final String DEFAULT_DOCKER_IMAGE = "fnichol/uhttpd";
-    private static final int DEFAULT_CONTAINER_PORT = 80;
-    private static final int SERVICE_PORT = 4500;
-    private static final int POD_ACTIVATION_WAIT_TIME = 10000; // 10 seconds
-
-    private static final String KUBERNETES_API_ENDPOINT = "kubernetes.api.endpoint";
-    private static final String MINION_PUBLIC_IPS = "minion.public.ips";
-    private static final String DOCKER_IMAGE = "docker.image";
-    private static final String CONTAINER_PORT = "container.port";
-    private static final String TEST_SERVICE_SOCKET = "test.service.socket";
-    private static final String TEST_POD_ACTIVATION = "test.pod.activation";
-
-    private KubernetesApiClient client;
-    private String dockerImage;
-    private String endpoint;
-    private int containerPort;
-    private boolean testPodActivation;
-    private boolean testServiceSocket;
-    private String[] minionPublicIPs = { "172.17.8.102" };
-    private List<String> podIdList = new ArrayList<String>();
-    private List<String> serviceIdList = new ArrayList<String>();
-
-    @BeforeClass
-    public void setUp() {
-        log.info("Setting up live test...");
-        endpoint = System.getProperty(KUBERNETES_API_ENDPOINT);
-        if (endpoint == null) {
-            endpoint = "http://" + DEFAULT_KUBERNETES_MASTER_IP + ":" + KUBERNETES_API_PORT + "/api/"
-                    + KubernetesConstants.KUBERNETES_API_VERSION + "/";
-        }
-        log.info(KUBERNETES_API_ENDPOINT + ": " + endpoint);
-        client = new KubernetesApiClient(endpoint);
-
-        dockerImage = System.getProperty(DOCKER_IMAGE);
-        if (dockerImage == null) {
-            dockerImage = DEFAULT_DOCKER_IMAGE;
-        }
-        log.info(DOCKER_IMAGE + ": " + dockerImage);
-
-        String containerPortStr = System.getProperty(CONTAINER_PORT);
-        if (StringUtils.isNotBlank(containerPortStr)) {
-            containerPort = Integer.parseInt(containerPortStr);
-        } else {
-            containerPort = DEFAULT_CONTAINER_PORT;
-        }
-        log.info(CONTAINER_PORT + ": " + containerPort);
-
-        testPodActivation = false;
-        String testPodActivationStr = System.getProperty(TEST_POD_ACTIVATION);
-        if (StringUtils.isNotBlank(testPodActivationStr)) {
-            testPodActivation = Boolean.parseBoolean(testPodActivationStr);
-        }
-        log.info(TEST_POD_ACTIVATION + ": " + testPodActivation);
-
-        testServiceSocket = false;
-        String testServiceSocketStr = System.getProperty(TEST_SERVICE_SOCKET);
-        if (StringUtils.isNotBlank(testServiceSocketStr)) {
-            testServiceSocket = Boolean.parseBoolean(testServiceSocketStr);
-        }
-        log.info(TEST_SERVICE_SOCKET + ": " + testServiceSocket);
-
-        String minionPublicIPsStr = System.getProperty(MINION_PUBLIC_IPS);
-        if(StringUtils.isNotBlank(minionPublicIPsStr)) {
-            minionPublicIPs = minionPublicIPsStr.split(",");
-        }
-        log.info(MINION_PUBLIC_IPS + ": " + minionPublicIPsStr);
-        log.info("Kubernetes live test setup completed");
-    }
-
-    @AfterClass
-    public void tearDown() {
-        log.info("Cleaning kubernetes resources...");
-        deleteServices();
-        deletePods();
-        log.info("Kubernetes resources cleaned");
-    }
-
     @Test
     public void testPodCreation() throws Exception {
         log.info("Testing pod creation...");
@@ -182,107 +90,4 @@ public class KubernetesApiClientLiveTest extends TestCase {
         deletePod("stratos-test-pod-1");
         deletePod("stratos-test-pod-2");
     }
-
-    private void createPod(String podId, String podName, String containerPortName) throws KubernetesClientException {
-        log.info("Creating pod: [pod] " + podId);
-        List<Port> ports = createPorts(containerPortName);
-        client.createPod(podId, podName, dockerImage, ports, null);
-        podIdList.add(podId);
-
-        sleep(2000);
-        Pod pod = client.getPod(podId);
-        assertNotNull(pod);
-        log.info("Pod created successfully: [pod] " + podId);
-
-        if (testPodActivation) {
-            boolean activated = false;
-            long startTime = System.currentTimeMillis();
-            while(!activated) {
-                if((System.currentTimeMillis() - startTime) > POD_ACTIVATION_WAIT_TIME) {
-                    log.info(String.format("Pod did not activate within %d seconds: [pod] %s",
-                            POD_ACTIVATION_WAIT_TIME/1000, podId));
-                    break;
-                }
-
-                log.info("Waiting pod status to be changed to running: [pod] " + podId);
-                sleep(2000);
-                pod = client.getPod(podId);
-                if((pod != null) && (pod.getCurrentState().getStatus().equals(KubernetesConstants.POD_STATUS_RUNNING))) {
-                    activated = true;
-                    log.info("Pod state changed to running: [pod]" + pod.getId());
-                }
-            }
-
-            assertNotNull(pod);
-            assertEquals(KubernetesConstants.POD_STATUS_RUNNING, pod.getCurrentState().getStatus());
-        }
-    }
-
-    private void deletePod(String podId) throws KubernetesClientException {
-        log.info("Deleting pod: " + podId);
-        client.deletePod(podId);
-        podIdList.remove(podId);
-
-        assertNull(client.getPod(podId));
-        log.info("Pod deleted successfully: " + podId);
-    }
-
-    public void deletePods() {
-        try {
-            for(String podId : podIdList) {
-                deletePod(podId);
-            }
-        } catch (KubernetesClientException e) {
-            log.error("Could not delete pods", e);
-        }
-    }
-
-    private void createService(String serviceId, String serviceName, int servicePort, String containerPortName,
-                               String[] publicIPs) throws KubernetesClientException, InterruptedException, IOException {
-        log.info("Creating service...");
-        client.createService(serviceId, serviceName, servicePort, containerPortName, publicIPs);
-        serviceIdList.add(serviceId);
-
-        sleep(1000);
-        Service service = client.getService(serviceId);
-        assertNotNull(service);
-        log.info("Service creation successful");
-    }
-
-    private void deleteService(String serviceId) throws KubernetesClientException {
-        log.info(String.format("Deleting service: [service] %s", serviceId));
-        client.deleteService(serviceId);
-        serviceIdList.remove(serviceId);
-
-        sleep(1000);
-        assertNull(client.getService(serviceId));
-        log.info(String.format("Service deleted successfully: [service] %s", serviceId));
-    }
-
-    public void deleteServices() {
-        try {
-            for(String serviceId : serviceIdList) {
-                deleteService(serviceId);
-            }
-        } catch (KubernetesClientException e) {
-            log.error("Could not delete services", e);
-        }
-    }
-
-    private void sleep(long time) {
-        try {
-            Thread.sleep(time);
-        } catch (InterruptedException ignore) {
-        }
-    }
-
-    private List<Port> createPorts(String containerPortName) {
-        List<Port> ports = new ArrayList<Port>();
-        Port port = new Port();
-        port.setName(containerPortName);
-        port.setContainerPort(containerPort);
-        port.setProtocol("tcp");
-        ports.add(port);
-        return ports;
-    }
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/5587040c/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesClusterCleanTest.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesClusterCleanTest.java b/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesClusterCleanTest.java
new file mode 100644
index 0000000..c1d150d
--- /dev/null
+++ b/components/org.apache.stratos.kubernetes.client/src/test/java/org/apache/stratos/kubernetes/client/live/KubernetesClusterCleanTest.java
@@ -0,0 +1,61 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.stratos.kubernetes.client.live;
+
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.stratos.kubernetes.client.model.Pod;
+import org.apache.stratos.kubernetes.client.model.Service;
+import org.junit.Test;
+
+import java.util.List;
+
+/**
+ * Live test to clean kubernetes cluster.
+ */
+public class KubernetesClusterCleanTest extends AbstractLiveTest {
+
+    private static final Log log = LogFactory.getLog(KubernetesClusterCleanTest.class);
+
+    @Test
+    public void testClean() {
+        try {
+            log.info("Cleaning kubernetes cluster...");
+            List<Pod> podList = client.getPods();
+            while((podList != null) && (podList.size() > 0)) {
+                for(Pod pod : podList) {
+                    deletePod(pod.getId());
+                }
+                podList = client.getPods();
+            }
+
+            List<Service> serviceList = client.getServices();
+            while((serviceList != null) && (serviceList.size() > 0)) {
+                for(Service service : serviceList) {
+                    deleteService(service.getId());
+                }
+                serviceList = client.getServices();
+            }
+            log.info("Kubernetes cluster cleaned successfully");
+        } catch (Exception e) {
+            log.error(e);
+        }
+    }
+}


[05/50] [abbrv] stratos git commit: re-arranging single-group-cartridge to new format

Posted by re...@apache.org.
re-arranging single-group-cartridge to new format


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

Branch: refs/heads/docker-grouping-merge
Commit: 7007f23bd62c1424573880b61c478b61b37a1cca
Parents: 36f0d3a
Author: R-Rajkumar <rr...@gmail.com>
Authored: Thu Feb 26 20:40:37 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../artifacts/autoscaling-policy.json           | 14 -----
 .../artifacts/deployment-policy.json            | 15 ------
 .../artifacts/ec2/deployment-policy.json        | 56 -------------------
 .../artifacts/kubernetes/deployment-policy.json | 57 --------------------
 .../kubernetes/kubernetes-cluster.json          | 56 -------------------
 .../artifacts/mock/deployment-policy.json       | 56 -------------------
 .../artifacts/network-partition-2.json          | 15 ------
 .../artifacts/network-partition.json            | 15 ------
 .../artifacts/openstack/deployment-policy.json  | 56 -------------------
 .../scripts/common/deploy.sh                    | 13 +++--
 .../scripts/kubernetes/deploy.sh                |  5 +-
 11 files changed, 11 insertions(+), 347 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/autoscaling-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/autoscaling-policy.json b/samples/applications/single-group-cartridge/artifacts/autoscaling-policy.json
deleted file mode 100755
index 2f670f6..0000000
--- a/samples/applications/single-group-cartridge/artifacts/autoscaling-policy.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-    "id": "autoscaling-policy-1",
-    "loadThresholds": {
-        "requestsInFlight": {
-            "threshold": 50
-        },
-        "memoryConsumption": {
-            "threshold": 70
-        },
-        "loadAverage": {
-            "threshold": 1000
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/deployment-policy.json b/samples/applications/single-group-cartridge/artifacts/deployment-policy.json
deleted file mode 100644
index 666c299..0000000
--- a/samples/applications/single-group-cartridge/artifacts/deployment-policy.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-   "id": "deployment-policy-1",
-   "networkPartition": [
-      {
-         "id": "network-partition-1",
-         "partitionAlgo": "one-after-another",
-         "partitions": [
-            {
-               "id": "partition-1",
-               "max": 5
-            }
-         ]
-      }
-   ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/ec2/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/ec2/deployment-policy.json b/samples/applications/single-group-cartridge/artifacts/ec2/deployment-policy.json
deleted file mode 100644
index 8f58f61..0000000
--- a/samples/applications/single-group-cartridge/artifacts/ec2/deployment-policy.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "applicationId": "cartridge-group-app",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "ec2",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "ap-southeast-1"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "my-tomcat",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "my-esb-php-group",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/kubernetes/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/kubernetes/deployment-policy.json b/samples/applications/single-group-cartridge/artifacts/kubernetes/deployment-policy.json
deleted file mode 100644
index 7b19958..0000000
--- a/samples/applications/single-group-cartridge/artifacts/kubernetes/deployment-policy.json
+++ /dev/null
@@ -1,57 +0,0 @@
-{
-    "applicationId": "cartridge-group-app",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id":"network-partition-1",
-                "kubernetesClusterId":"kubernetes-cluster-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "kubernetes",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "my-tomcat",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "my-esb-php-group",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/kubernetes/kubernetes-cluster.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/kubernetes/kubernetes-cluster.json b/samples/applications/single-group-cartridge/artifacts/kubernetes/kubernetes-cluster.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/applications/single-group-cartridge/artifacts/kubernetes/kubernetes-cluster.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/mock/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/mock/deployment-policy.json b/samples/applications/single-group-cartridge/artifacts/mock/deployment-policy.json
deleted file mode 100644
index bce6767..0000000
--- a/samples/applications/single-group-cartridge/artifacts/mock/deployment-policy.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "applicationId": "cartridge-group-app",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "mock",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "RegionOne"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "my-tomcat",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "my-esb-php-group",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/network-partition-2.json b/samples/applications/single-group-cartridge/artifacts/network-partition-2.json
deleted file mode 100644
index 0d07838..0000000
--- a/samples/applications/single-group-cartridge/artifacts/network-partition-2.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-2",
-    "partitions": [
-        {
-            "id": "partition-2",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/network-partition.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/network-partition.json b/samples/applications/single-group-cartridge/artifacts/network-partition.json
deleted file mode 100644
index 2a5b7ec..0000000
--- a/samples/applications/single-group-cartridge/artifacts/network-partition.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-1",
-    "partitions": [
-        {
-            "id": "partition-1",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/artifacts/openstack/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/artifacts/openstack/deployment-policy.json b/samples/applications/single-group-cartridge/artifacts/openstack/deployment-policy.json
deleted file mode 100644
index b205147..0000000
--- a/samples/applications/single-group-cartridge/artifacts/openstack/deployment-policy.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "applicationId": "cartridge-group-app",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "openstack",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "RegionOne"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "my-tomcat",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "myesb-php-group",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/scripts/common/deploy.sh b/samples/applications/single-group-cartridge/scripts/common/deploy.sh
index 63ad95d..92940b0 100755
--- a/samples/applications/single-group-cartridge/scripts/common/deploy.sh
+++ b/samples/applications/single-group-cartridge/scripts/common/deploy.sh
@@ -11,6 +11,9 @@ artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
 
 set -e
 
@@ -19,16 +22,16 @@ if [[ -z "${iaas}" ]]; then
     exit
 fi
 
-echo ${artifacts_path}/autoscaling-policy.json
+echo ${autoscaling_policies_path}/autoscaling-policy-1.json
 echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
 
 echo "Adding network partitions..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding tomcat cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${cartridges_path}/tomcat.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges

http://git-wip-us.apache.org/repos/asf/stratos/blob/7007f23b/samples/applications/single-group-cartridge/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-group-cartridge/scripts/kubernetes/deploy.sh b/samples/applications/single-group-cartridge/scripts/kubernetes/deploy.sh
index 32eff3c..0d614cc 100755
--- a/samples/applications/single-group-cartridge/scripts/kubernetes/deploy.sh
+++ b/samples/applications/single-group-cartridge/scripts/kubernetes/deploy.sh
@@ -8,8 +8,9 @@ prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 common_folder=`cd "${script_path}/../common"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernets-clusters"; pwd`
 
 echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/kubernetes-cluster.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-1.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
 
-bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file
+bash ${common_folder}/deploy.sh ${iaas}


[12/50] [abbrv] stratos git commit: fixing conflicts

Posted by re...@apache.org.
fixing conflicts


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

Branch: refs/heads/docker-grouping-merge
Commit: 7cc23ffc866625a3605df41eec67272cc639d1c6
Parents: b724ac2 a2d11ad
Author: R-Rajkumar <rr...@gmail.com>
Authored: Fri Feb 27 20:11:33 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 20:11:33 2015 +0530

----------------------------------------------------------------------
 .../apache/stratos/cli/StratosApplication.java  |   1 +
 .../main/resources/CloudControllerService.wsdl  | 412 +++++++++----------
 2 files changed, 207 insertions(+), 206 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/7cc23ffc/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/StratosApplication.java
----------------------------------------------------------------------
diff --cc components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/StratosApplication.java
index ca696a8,7d9c9be..532f043
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/StratosApplication.java
+++ b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/StratosApplication.java
@@@ -231,11 -231,6 +231,12 @@@ public class StratosApplication extend
          command = new ListPartialSearchTenantsCommand();
          commands.put(command.getName(),command);
  
 +        command = new DescribeApplicationSignupCommand();
 +        commands.put(command.getName(),command);
 +
 +        command = new DeleteApplicationSignupCommand();
 +        commands.put(command.getName(),command);
++
          command = new AddDeploymentPolicyCommand();
          commands.put(command.getName(), command);
  

http://git-wip-us.apache.org/repos/asf/stratos/blob/7cc23ffc/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
----------------------------------------------------------------------
diff --cc service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
index 2f95914,12949c2..499d49c
--- a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
+++ b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
@@@ -231,10 -211,87 +231,87 @@@
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
 -            <xs:element name="updateKubernetesMaster">
++            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax228:KubernetesMaster"></xs:element>
++                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax222:InvalidServiceGroupException"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="updateKubernetesMasterResponse">
++            <xs:element name="getServiceGroupSubGroups">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
++                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
++            <xs:element name="getServiceGroupSubGroupsResponse">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax222:NonExistingKubernetesHostException"></xs:element>
++                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="updateKubernetesHost">
++            <xs:element name="getServiceGroupCartridges">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax228:KubernetesHost"></xs:element>
++                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="updateKubernetesHostResponse">
++            <xs:element name="getServiceGroupCartridgesResponse">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
++                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
++            <xs:element name="getServiceGroupDependencies">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax222:InvalidKubernetesClusterException"></xs:element>
++                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="addKubernetesCluster">
++            <xs:element name="getServiceGroupDependenciesResponse">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax228:KubernetesCluster"></xs:element>
++                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:Dependencies"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="addKubernetesClusterResponse">
++            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
++                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="getKubernetesCluster">
++            <xs:element name="CloudControllerServiceCloudControllerException">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
++                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="getKubernetesClusterResponse">
++            <xs:element name="startInstances">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="return" nillable="true" type="ax228:KubernetesCluster"></xs:element>
++                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax224:InstanceContext"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="removeKubernetesCluster">
++            <xs:element name="startInstancesResponse">
+                 <xs:complexType>
+                     <xs:sequence>
 -                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
++                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
+                     </xs:sequence>
+                 </xs:complexType>
+             </xs:element>
 -            <xs:element name="removeKubernetesClusterResponse">
 +            <xs:element name="getDeploymentPolicy">
                  <xs:complexType>
                      <xs:sequence>
 -                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
 +                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
@@@ -264,17 -323,10 +341,10 @@@
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
-             <xs:element name="CloudControllerServiceInvalidIaasProviderException">
-                 <xs:complexType>
-                     <xs:sequence>
-                         <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
-                     </xs:sequence>
-                 </xs:complexType>
-             </xs:element>
 -            <xs:element name="getServiceGroupSubGroupsResponse">
 +            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
                  <xs:complexType>
                      <xs:sequence>
 -                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
 +                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax222:CartridgeDefinitionNotExistsException"></xs:element>
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
@@@ -520,17 -576,10 +590,10 @@@
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
-             <xs:element name="CloudControllerServiceCloudControllerException">
-                 <xs:complexType>
-                     <xs:sequence>
-                         <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
-                     </xs:sequence>
-                 </xs:complexType>
-             </xs:element>
 -            <xs:element name="removeDeployementPolicy">
 +            <xs:element name="terminateInstance">
                  <xs:complexType>
                      <xs:sequence>
 -                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
 +                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
@@@ -618,10 -604,24 +618,10 @@@
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
-             <xs:element name="unregisterService">
+             <xs:element name="startInstanceResponse">
                  <xs:complexType>
                      <xs:sequence>
-                         <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
 -                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
 -                    </xs:sequence>
 -                </xs:complexType>
 -            </xs:element>
 -            <xs:element name="CloudControllerServiceInvalidMemberException">
 -                <xs:complexType>
 -                    <xs:sequence>
 -                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax222:InvalidMemberException"></xs:element>
 -                    </xs:sequence>
 -                </xs:complexType>
 -            </xs:element>
 -            <xs:element name="terminateInstance">
 -                <xs:complexType>
 -                    <xs:sequence>
 -                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
++                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
                      </xs:sequence>
                  </xs:complexType>
              </xs:element>
@@@ -728,16 -740,22 +728,16 @@@
                      <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
 -            <xs:complexType name="NonExistingKubernetesMasterException">
 -                <xs:sequence>
 -                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
 -                </xs:sequence>
 +            <xs:complexType name="DeploymentPolicyAlreadyExistsException">
 +                <xs:sequence></xs:sequence>
              </xs:complexType>
 -            <xs:complexType name="NonExistingKubernetesHostException">
 -                <xs:sequence>
 -                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
 -                </xs:sequence>
 +            <xs:complexType name="InvalidDeploymentPolicyException">
 +                <xs:sequence></xs:sequence>
              </xs:complexType>
 -            <xs:complexType name="InvalidKubernetesClusterException">
 -                <xs:sequence>
 -                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
 -                </xs:sequence>
 +            <xs:complexType name="DeploymentPolicyNotExistsException">
 +                <xs:sequence></xs:sequence>
              </xs:complexType>
-             <xs:complexType name="InvalidCartridgeDefinitionException">
+             <xs:complexType name="InvalidServiceGroupException">
                  <xs:sequence>
                      <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
@@@ -747,7 -765,19 +747,19 @@@
                      <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
+             <xs:complexType name="CloudControllerException">
+                 <xs:complexContent>
+                     <xs:extension base="xs:RuntimeException">
+                         <xs:sequence></xs:sequence>
+                     </xs:extension>
+                 </xs:complexContent>
+             </xs:complexType>
 -            <xs:complexType name="InvalidClusterException">
++            <xs:complexType name="InvalidCartridgeDefinitionException">
+                 <xs:sequence>
+                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                 </xs:sequence>
+             </xs:complexType>
 -            <xs:complexType name="InvalidPartitionException">
 +            <xs:complexType name="CartridgeDefinitionNotExistsException">
                  <xs:sequence>
                      <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
@@@ -791,23 -808,6 +803,11 @@@
                      <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
-             <xs:complexType name="CloudControllerException">
-                 <xs:complexContent>
-                     <xs:extension base="xs:RuntimeException">
-                         <xs:sequence></xs:sequence>
-                     </xs:extension>
-                 </xs:complexContent>
-             </xs:complexType>
-             <xs:complexType name="InvalidServiceGroupException">
-                 <xs:sequence>
-                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
-                 </xs:sequence>
-             </xs:complexType>
 +            <xs:complexType name="UnregisteredClusterException">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
          </xs:schema>
          <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://domain.common.stratos.apache.org/xsd">
              <xs:complexType name="NameValuePair">
@@@ -931,57 -993,66 +931,114 @@@
                      <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
 +            <xs:complexType name="ClusterContext">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="kubernetesServices" nillable="true" type="xs:anyType"></xs:element>
 +                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
 +                    <xs:element minOccurs="0" name="payload" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
 +                    <xs:element minOccurs="0" name="timeoutInMillis" type="xs:long"></xs:element>
 +                    <xs:element minOccurs="0" name="volumeRequired" type="xs:boolean"></xs:element>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax224:Volume"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="ApplicationClusterContext">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="autoscalePolicyName" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyClusterIds" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
 +                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
 +                    <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="textPayload" nillable="true" type="xs:string"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="DeploymentPolicy">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionsRef" nillable="true" type="ax224:NetworkPartitionRef"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="NetworkPartitionRef">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="partitionAlgo" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax224:PartitionRef"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="PartitionRef">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="max" type="xs:int"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
+             <xs:complexType name="Dependencies">
+                 <xs:sequence>
+                     <xs:element minOccurs="0" name="killBehaviour" nillable="true" type="xs:string"></xs:element>
+                     <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"></xs:element>
+                 </xs:sequence>
+             </xs:complexType>
+             <xs:complexType name="InstanceContext">
+                 <xs:sequence>
+                     <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="clusterInstanceId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="initTime" type="xs:long"></xs:element>
+                     <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="obsoleteExpiryTime" type="xs:long"></xs:element>
+                     <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
 -                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax226:Properties"></xs:element>
++                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
+                 </xs:sequence>
+             </xs:complexType>
+             <xs:complexType name="MemberContext">
+                 <xs:sequence>
+                     <xs:element maxOccurs="unbounded" minOccurs="0" name="allocatedIPs" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="clusterInstanceId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="defaultPrivateIP" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="defaultPublicIP" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dynamicPayload" nillable="true" type="ax232:NameValuePair"></xs:element>
++                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dynamicPayload" nillable="true" type="ax233:NameValuePair"></xs:element>
+                     <xs:element minOccurs="0" name="initTime" type="xs:long"></xs:element>
+                     <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="instanceMetadata" nillable="true" type="ax224:InstanceMetadata"></xs:element>
+                     <xs:element minOccurs="0" name="kubernetesPodId" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="kubernetesPodName" nillable="true" type="xs:string"></xs:element>
++                    <xs:element minOccurs="0" name="kubernetesPodLabel" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="lbClusterId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="obsoleteExpiryTime" type="xs:long"></xs:element>
+                     <xs:element minOccurs="0" name="obsoleteInitTime" type="xs:long"></xs:element>
+                     <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
+                     <xs:element maxOccurs="unbounded" minOccurs="0" name="privateIPs" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax226:Properties"></xs:element>
++                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
+                     <xs:element maxOccurs="unbounded" minOccurs="0" name="publicIPs" nillable="true" type="xs:string"></xs:element>
+                 </xs:sequence>
+             </xs:complexType>
+             <xs:complexType name="InstanceMetadata">
+                 <xs:sequence>
+                     <xs:element minOccurs="0" name="hostname" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="hypervisor" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="imageId" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="loginPort" type="xs:int"></xs:element>
+                     <xs:element minOccurs="0" name="operatingSystem64bit" type="xs:boolean"></xs:element>
+                     <xs:element minOccurs="0" name="operatingSystemArchitecture" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="operatingSystemName" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="operatingSystemVersion" nillable="true" type="xs:string"></xs:element>
+                     <xs:element minOccurs="0" name="ram" type="xs:int"></xs:element>
+                 </xs:sequence>
+             </xs:complexType>
 -            <xs:complexType name="CartridgeInfo">
 +            <xs:complexType name="CartridgeConfig">
                  <xs:sequence>
 -                    <xs:element maxOccurs="unbounded" minOccurs="0" name="appTypes" nillable="true" type="ax224:AppType"></xs:element>
                      <xs:element minOccurs="0" name="baseDir" nillable="true" type="xs:string"></xs:element>
                      <xs:element minOccurs="0" name="category" nillable="true" type="xs:string"></xs:element>
                      <xs:element minOccurs="0" name="defaultAutoscalingPolicy" nillable="true" type="xs:string"></xs:element>
@@@ -1007,110 -1075,42 +1064,53 @@@
                      <xs:element minOccurs="0" name="version" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
 -            <xs:complexType name="AppType">
 +            <xs:complexType name="IaasConfig">
                  <xs:sequence>
 -                    <xs:element minOccurs="0" name="appSpecificMapping" type="xs:boolean"></xs:element>
 +                    <xs:element minOccurs="0" name="className" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="credential" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="identity" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="imageId" nillable="true" type="xs:string"></xs:element>
                      <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="networkInterfaces" nillable="true" type="ax224:NetworkInterfaces"></xs:element>
 +                    <xs:element minOccurs="0" name="payload" nillable="true" type="xs:base64Binary"></xs:element>
 +                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
 +                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
 -            <xs:complexType name="ClusterContext">
 +            <xs:complexType name="NetworkInterfaces">
                  <xs:sequence>
 -                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="kubernetesServices" nillable="true" type="xs:anyType"></xs:element>
 -                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
 -                    <xs:element minOccurs="0" name="payload" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax226:Properties"></xs:element>
 -                    <xs:element minOccurs="0" name="timeoutInMillis" type="xs:long"></xs:element>
 -                    <xs:element minOccurs="0" name="volumeRequired" type="xs:boolean"></xs:element>
 -                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax224:Volume"></xs:element>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkInterfaces" nillable="true" type="ax224:NetworkInterface"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="NetworkInterface">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="fixedIp" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="floatingNetworks" nillable="true" type="ax224:FloatingNetworks"></xs:element>
 +                    <xs:element minOccurs="0" name="networkUuid" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="portUuid" nillable="true" type="xs:string"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="FloatingNetworks">
 +                <xs:sequence>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="floatingNetworks" nillable="true" type="ax224:FloatingNetwork"></xs:element>
 +                </xs:sequence>
 +            </xs:complexType>
 +            <xs:complexType name="FloatingNetwork">
 +                <xs:sequence>
 +                    <xs:element minOccurs="0" name="floatingIP" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="networkUuid" nillable="true" type="xs:string"></xs:element>
                  </xs:sequence>
              </xs:complexType>
 -            <xs:complexType name="ApplicationClusterContext">
 +            <xs:complexType name="NetworkPartition">
                  <xs:sequence>
 -                    <xs:element minOccurs="0" name="autoscalePolicyName" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyClusterIds" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
 -                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax226:Properties"></xs:element>
 -                    <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"></xs:element>
 -                    <xs:element minOccurs="0" name="textPayload" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="activeByDefault" type="xs:boolean"></xs:element>
 +                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
 +                    <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax224:Partition"></xs:element>
                  </xs:sequence>
              </xs:complexType>
-             <xs:complexType name="InstanceContext">
-                 <xs:sequence>
-                     <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="clusterInstanceId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="initTime" type="xs:long"></xs:element>
-                     <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="obsoleteExpiryTime" type="xs:long"></xs:element>
-                     <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
-                     <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
-                 </xs:sequence>
-             </xs:complexType>
-             <xs:complexType name="MemberContext">
-                 <xs:sequence>
-                     <xs:element maxOccurs="unbounded" minOccurs="0" name="allocatedIPs" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="clusterInstanceId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="defaultPrivateIP" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="defaultPublicIP" nillable="true" type="xs:string"></xs:element>
-                     <xs:element maxOccurs="unbounded" minOccurs="0" name="dynamicPayload" nillable="true" type="ax233:NameValuePair"></xs:element>
-                     <xs:element minOccurs="0" name="initTime" type="xs:long"></xs:element>
-                     <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="instanceMetadata" nillable="true" type="ax224:InstanceMetadata"></xs:element>
-                     <xs:element minOccurs="0" name="kubernetesPodId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="kubernetesPodLabel" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="lbClusterId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="obsoleteExpiryTime" type="xs:long"></xs:element>
-                     <xs:element minOccurs="0" name="obsoleteInitTime" type="xs:long"></xs:element>
-                     <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
-                     <xs:element maxOccurs="unbounded" minOccurs="0" name="privateIPs" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
-                     <xs:element maxOccurs="unbounded" minOccurs="0" name="publicIPs" nillable="true" type="xs:string"></xs:element>
-                 </xs:sequence>
-             </xs:complexType>
-             <xs:complexType name="InstanceMetadata">
-                 <xs:sequence>
-                     <xs:element minOccurs="0" name="hostname" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="hypervisor" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="imageId" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="loginPort" type="xs:int"></xs:element>
-                     <xs:element minOccurs="0" name="operatingSystem64bit" type="xs:boolean"></xs:element>
-                     <xs:element minOccurs="0" name="operatingSystemArchitecture" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="operatingSystemName" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="operatingSystemVersion" nillable="true" type="xs:string"></xs:element>
-                     <xs:element minOccurs="0" name="ram" type="xs:int"></xs:element>
-                 </xs:sequence>
-             </xs:complexType>
-             <xs:complexType name="Dependencies">
-                 <xs:sequence>
-                     <xs:element minOccurs="0" name="killBehaviour" nillable="true" type="xs:string"></xs:element>
-                     <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"></xs:element>
-                 </xs:sequence>
-             </xs:complexType>
              <xs:complexType name="ServiceGroup">
                  <xs:sequence>
                      <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridges" nillable="true" type="xs:string"></xs:element>
@@@ -1335,24 -1335,24 +1335,24 @@@
      <wsdl:message name="getMasterForKubernetesClusterResponse">
          <wsdl:part name="parameters" element="ns:getMasterForKubernetesClusterResponse"></wsdl:part>
      </wsdl:message>
--    <wsdl:message name="startInstancesRequest">
--        <wsdl:part name="parameters" element="ns:startInstances"></wsdl:part>
--    </wsdl:message>
--    <wsdl:message name="startInstancesResponse">
--        <wsdl:part name="parameters" element="ns:startInstancesResponse"></wsdl:part>
--    </wsdl:message>
--    <wsdl:message name="CloudControllerServiceInvalidIaasProviderException">
--        <wsdl:part name="parameters" element="ns:CloudControllerServiceInvalidIaasProviderException"></wsdl:part>
--    </wsdl:message>
      <wsdl:message name="updateCartridgeRequest">
          <wsdl:part name="parameters" element="ns:updateCartridge"></wsdl:part>
      </wsdl:message>
      <wsdl:message name="CloudControllerServiceInvalidCartridgeDefinitionException">
          <wsdl:part name="parameters" element="ns:CloudControllerServiceInvalidCartridgeDefinitionException"></wsdl:part>
      </wsdl:message>
++    <wsdl:message name="CloudControllerServiceInvalidIaasProviderException">
++        <wsdl:part name="parameters" element="ns:CloudControllerServiceInvalidIaasProviderException"></wsdl:part>
++    </wsdl:message>
      <wsdl:message name="CloudControllerServiceCartridgeDefinitionNotExistsException">
          <wsdl:part name="parameters" element="ns:CloudControllerServiceCartridgeDefinitionNotExistsException"></wsdl:part>
      </wsdl:message>
++    <wsdl:message name="startInstancesRequest">
++        <wsdl:part name="parameters" element="ns:startInstances"></wsdl:part>
++    </wsdl:message>
++    <wsdl:message name="startInstancesResponse">
++        <wsdl:part name="parameters" element="ns:startInstancesResponse"></wsdl:part>
++    </wsdl:message>
      <wsdl:message name="startInstanceRequest">
          <wsdl:part name="parameters" element="ns:startInstance"></wsdl:part>
      </wsdl:message>
@@@ -1556,6 -1556,6 +1556,12 @@@
              <wsdl:output message="ns:getMasterForKubernetesClusterResponse" wsaw:Action="urn:getMasterForKubernetesClusterResponse"></wsdl:output>
              <wsdl:fault message="ns:CloudControllerServiceNonExistingKubernetesClusterException" name="CloudControllerServiceNonExistingKubernetesClusterException" wsaw:Action="urn:getMasterForKubernetesClusterCloudControllerServiceNonExistingKubernetesClusterException"></wsdl:fault>
          </wsdl:operation>
++        <wsdl:operation name="updateCartridge">
++            <wsdl:input message="ns:updateCartridgeRequest" wsaw:Action="urn:updateCartridge"></wsdl:input>
++            <wsdl:fault message="ns:CloudControllerServiceInvalidCartridgeDefinitionException" name="CloudControllerServiceInvalidCartridgeDefinitionException" wsaw:Action="urn:updateCartridgeCloudControllerServiceInvalidCartridgeDefinitionException"></wsdl:fault>
++            <wsdl:fault message="ns:CloudControllerServiceInvalidIaasProviderException" name="CloudControllerServiceInvalidIaasProviderException" wsaw:Action="urn:updateCartridgeCloudControllerServiceInvalidIaasProviderException"></wsdl:fault>
++            <wsdl:fault message="ns:CloudControllerServiceCartridgeDefinitionNotExistsException" name="CloudControllerServiceCartridgeDefinitionNotExistsException" wsaw:Action="urn:updateCartridgeCloudControllerServiceCartridgeDefinitionNotExistsException"></wsdl:fault>
++        </wsdl:operation>
          <wsdl:operation name="startInstances">
              <wsdl:input message="ns:startInstancesRequest" wsaw:Action="urn:startInstances"></wsdl:input>
              <wsdl:output message="ns:startInstancesResponse" wsaw:Action="urn:startInstancesResponse"></wsdl:output>
@@@ -1563,12 -1563,12 +1569,6 @@@
              <wsdl:fault message="ns:CloudControllerServiceInvalidIaasProviderException" name="CloudControllerServiceInvalidIaasProviderException" wsaw:Action="urn:startInstancesCloudControllerServiceInvalidIaasProviderException"></wsdl:fault>
              <wsdl:fault message="ns:CloudControllerServiceCloudControllerException" name="CloudControllerServiceCloudControllerException" wsaw:Action="urn:startInstancesCloudControllerServiceCloudControllerException"></wsdl:fault>
          </wsdl:operation>
--        <wsdl:operation name="updateCartridge">
--            <wsdl:input message="ns:updateCartridgeRequest" wsaw:Action="urn:updateCartridge"></wsdl:input>
--            <wsdl:fault message="ns:CloudControllerServiceInvalidCartridgeDefinitionException" name="CloudControllerServiceInvalidCartridgeDefinitionException" wsaw:Action="urn:updateCartridgeCloudControllerServiceInvalidCartridgeDefinitionException"></wsdl:fault>
--            <wsdl:fault message="ns:CloudControllerServiceInvalidIaasProviderException" name="CloudControllerServiceInvalidIaasProviderException" wsaw:Action="urn:updateCartridgeCloudControllerServiceInvalidIaasProviderException"></wsdl:fault>
--            <wsdl:fault message="ns:CloudControllerServiceCartridgeDefinitionNotExistsException" name="CloudControllerServiceCartridgeDefinitionNotExistsException" wsaw:Action="urn:updateCartridgeCloudControllerServiceCartridgeDefinitionNotExistsException"></wsdl:fault>
--        </wsdl:operation>
          <wsdl:operation name="startInstance">
              <wsdl:input message="ns:startInstanceRequest" wsaw:Action="urn:startInstance"></wsdl:input>
              <wsdl:output message="ns:startInstanceResponse" wsaw:Action="urn:startInstanceResponse"></wsdl:output>
@@@ -1957,21 -1957,21 +1957,6 @@@
                  <soap:fault use="literal" name="CloudControllerServiceNonExistingKubernetesClusterException"></soap:fault>
              </wsdl:fault>
          </wsdl:operation>
--        <wsdl:operation name="updateCartridge">
--            <soap:operation soapAction="urn:updateCartridge" style="document"></soap:operation>
--            <wsdl:input>
--                <soap:body use="literal"></soap:body>
--            </wsdl:input>
--            <wsdl:fault name="CloudControllerServiceCartridgeDefinitionNotExistsException">
--                <soap:fault use="literal" name="CloudControllerServiceCartridgeDefinitionNotExistsException"></soap:fault>
--            </wsdl:fault>
--            <wsdl:fault name="CloudControllerServiceInvalidCartridgeDefinitionException">
--                <soap:fault use="literal" name="CloudControllerServiceInvalidCartridgeDefinitionException"></soap:fault>
--            </wsdl:fault>
--            <wsdl:fault name="CloudControllerServiceInvalidIaasProviderException">
--                <soap:fault use="literal" name="CloudControllerServiceInvalidIaasProviderException"></soap:fault>
--            </wsdl:fault>
--        </wsdl:operation>
          <wsdl:operation name="startInstances">
              <soap:operation soapAction="urn:startInstances" style="document"></soap:operation>
              <wsdl:input>
@@@ -1990,6 -1990,6 +1975,21 @@@
                  <soap:fault use="literal" name="CloudControllerServiceInvalidIaasProviderException"></soap:fault>
              </wsdl:fault>
          </wsdl:operation>
++        <wsdl:operation name="updateCartridge">
++            <soap:operation soapAction="urn:updateCartridge" style="document"></soap:operation>
++            <wsdl:input>
++                <soap:body use="literal"></soap:body>
++            </wsdl:input>
++            <wsdl:fault name="CloudControllerServiceCartridgeDefinitionNotExistsException">
++                <soap:fault use="literal" name="CloudControllerServiceCartridgeDefinitionNotExistsException"></soap:fault>
++            </wsdl:fault>
++            <wsdl:fault name="CloudControllerServiceInvalidCartridgeDefinitionException">
++                <soap:fault use="literal" name="CloudControllerServiceInvalidCartridgeDefinitionException"></soap:fault>
++            </wsdl:fault>
++            <wsdl:fault name="CloudControllerServiceInvalidIaasProviderException">
++                <soap:fault use="literal" name="CloudControllerServiceInvalidIaasProviderException"></soap:fault>
++            </wsdl:fault>
++        </wsdl:operation>
          <wsdl:operation name="startInstance">
              <soap:operation soapAction="urn:startInstance" style="document"></soap:operation>
              <wsdl:input>
@@@ -2452,21 -2452,21 +2452,6 @@@
                  <soap12:fault use="literal" name="CloudControllerServiceNonExistingKubernetesClusterException"></soap12:fault>
              </wsdl:fault>
          </wsdl:operation>
--        <wsdl:operation name="updateCartridge">
--            <soap12:operation soapAction="urn:updateCartridge" style="document"></soap12:operation>
--            <wsdl:input>
--                <soap12:body use="literal"></soap12:body>
--            </wsdl:input>
--            <wsdl:fault name="CloudControllerServiceCartridgeDefinitionNotExistsException">
--                <soap12:fault use="literal" name="CloudControllerServiceCartridgeDefinitionNotExistsException"></soap12:fault>
--            </wsdl:fault>
--            <wsdl:fault name="CloudControllerServiceInvalidCartridgeDefinitionException">
--                <soap12:fault use="literal" name="CloudControllerServiceInvalidCartridgeDefinitionException"></soap12:fault>
--            </wsdl:fault>
--            <wsdl:fault name="CloudControllerServiceInvalidIaasProviderException">
--                <soap12:fault use="literal" name="CloudControllerServiceInvalidIaasProviderException"></soap12:fault>
--            </wsdl:fault>
--        </wsdl:operation>
          <wsdl:operation name="startInstances">
              <soap12:operation soapAction="urn:startInstances" style="document"></soap12:operation>
              <wsdl:input>
@@@ -2485,6 -2485,6 +2470,21 @@@
                  <soap12:fault use="literal" name="CloudControllerServiceInvalidIaasProviderException"></soap12:fault>
              </wsdl:fault>
          </wsdl:operation>
++        <wsdl:operation name="updateCartridge">
++            <soap12:operation soapAction="urn:updateCartridge" style="document"></soap12:operation>
++            <wsdl:input>
++                <soap12:body use="literal"></soap12:body>
++            </wsdl:input>
++            <wsdl:fault name="CloudControllerServiceCartridgeDefinitionNotExistsException">
++                <soap12:fault use="literal" name="CloudControllerServiceCartridgeDefinitionNotExistsException"></soap12:fault>
++            </wsdl:fault>
++            <wsdl:fault name="CloudControllerServiceInvalidCartridgeDefinitionException">
++                <soap12:fault use="literal" name="CloudControllerServiceInvalidCartridgeDefinitionException"></soap12:fault>
++            </wsdl:fault>
++            <wsdl:fault name="CloudControllerServiceInvalidIaasProviderException">
++                <soap12:fault use="literal" name="CloudControllerServiceInvalidIaasProviderException"></soap12:fault>
++            </wsdl:fault>
++        </wsdl:operation>
          <wsdl:operation name="startInstance">
              <soap12:operation soapAction="urn:startInstance" style="document"></soap12:operation>
              <wsdl:input>
@@@ -2848,12 -2848,12 +2848,6 @@@
                  <mime:content type="text/xml" part="parameters"></mime:content>
              </wsdl:output>
          </wsdl:operation>
--        <wsdl:operation name="updateCartridge">
--            <http:operation location="updateCartridge"></http:operation>
--            <wsdl:input>
--                <mime:content type="text/xml" part="parameters"></mime:content>
--            </wsdl:input>
--        </wsdl:operation>
          <wsdl:operation name="startInstances">
              <http:operation location="startInstances"></http:operation>
              <wsdl:input>
@@@ -2863,6 -2863,6 +2857,12 @@@
                  <mime:content type="text/xml" part="parameters"></mime:content>
              </wsdl:output>
          </wsdl:operation>
++        <wsdl:operation name="updateCartridge">
++            <http:operation location="updateCartridge"></http:operation>
++            <wsdl:input>
++                <mime:content type="text/xml" part="parameters"></mime:content>
++            </wsdl:input>
++        </wsdl:operation>
          <wsdl:operation name="startInstance">
              <http:operation location="startInstance"></http:operation>
              <wsdl:input>


[07/50] [abbrv] stratos git commit: PCA - Check ports activity when publishing instance activated event. If ports activation times out, no InstanceActivatedEvent is published

Posted by re...@apache.org.
PCA - Check ports activity when publishing instance activated event. If ports activation times out, no InstanceActivatedEvent is published


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

Branch: refs/heads/docker-grouping-merge
Commit: a4fc8ef232e6e94ca314c10c33fa6c15334913a0
Parents: 6d408dd
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Fri Feb 27 00:31:59 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../publisher/CartridgeAgentEventPublisher.java |  4 +-
 .../cartridge.agent/cartridge.agent/agent.py    |  7 --
 .../publisher/cartridgeagentpublisher.py        | 77 ++++++++++++--------
 .../modules/util/cartridgeagentutils.py         |  4 +-
 4 files changed, 50 insertions(+), 42 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/a4fc8ef2/components/org.apache.stratos.cartridge.agent/src/main/java/org/apache/stratos/cartridge/agent/event/publisher/CartridgeAgentEventPublisher.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cartridge.agent/src/main/java/org/apache/stratos/cartridge/agent/event/publisher/CartridgeAgentEventPublisher.java b/components/org.apache.stratos.cartridge.agent/src/main/java/org/apache/stratos/cartridge/agent/event/publisher/CartridgeAgentEventPublisher.java
index 9a4e0c2..c3b3f14 100644
--- a/components/org.apache.stratos.cartridge.agent/src/main/java/org/apache/stratos/cartridge/agent/event/publisher/CartridgeAgentEventPublisher.java
+++ b/components/org.apache.stratos.cartridge.agent/src/main/java/org/apache/stratos/cartridge/agent/event/publisher/CartridgeAgentEventPublisher.java
@@ -149,8 +149,8 @@ public class CartridgeAgentEventPublisher {
 					for (Integer port: ports){
 						portsStr += port + ", ";
 					}
-					log.info(String.format(
-							"Ports activation timed out. Aborting InstanceActivatedEvent publishing. [IPAdress] %s [Ports] %s",
+					log.error(String.format(
+							"Ports activation timed out. Aborting InstanceActivatedEvent publishing. [IPAddress] %s [Ports] %s",
 							listenAddress,
 							portsStr));
 				}

http://git-wip-us.apache.org/repos/asf/stratos/blob/a4fc8ef2/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.py
index 4d09b78..1efb0c6 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.py
@@ -88,13 +88,6 @@ class CartridgeAgent(threading.Thread):
         except Exception as e:
             self.__log.exception("Error processing start servers event: %s" % e)
 
-        # Wait for all ports to be active
-        cartridgeagentutils.wait_until_ports_active(
-            self.__config.listen_address,
-            self.__config.ports,
-            int(self.__config.read_property("port.check.timeout", critical=False))
-        )
-
         # check if artifact management is required before publishing instance activated event
         repo_url = self.__config.repo_url
         if repo_url is None or str(repo_url).strip() == "":

http://git-wip-us.apache.org/repos/asf/stratos/blob/a4fc8ef2/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/publisher/cartridgeagentpublisher.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/publisher/cartridgeagentpublisher.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/publisher/cartridgeagentpublisher.py
index 875332a..aea0e58 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/publisher/cartridgeagentpublisher.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/publisher/cartridgeagentpublisher.py
@@ -61,44 +61,57 @@ def publish_instance_started_event():
 def publish_instance_activated_event():
     global activated, log
     if not activated:
+        # Wait for all ports to be active
+
+        listen_address = CartridgeAgentConfiguration().listen_address
+        configuration__ports = CartridgeAgentConfiguration().ports
+        ports_active = cartridgeagentutils.wait_until_ports_active(
+            listen_address,
+            configuration__ports,
+            int(CartridgeAgentConfiguration().read_property("port.check.timeout", critical=False))
+        )
         log.info("Publishing instance activated event")
 
-        service_name = CartridgeAgentConfiguration().service_name
-        cluster_id = CartridgeAgentConfiguration().cluster_id
-        member_id = CartridgeAgentConfiguration().member_id
-        instance_id = CartridgeAgentConfiguration().instance_id
-        cluster_instance_id = CartridgeAgentConfiguration().cluster_instance_id
-        network_partition_id = CartridgeAgentConfiguration().network_partition_id
-        partition_id = CartridgeAgentConfiguration().partition_id
-
-        instance_activated_event = InstanceActivatedEvent(service_name, cluster_id, cluster_instance_id, member_id,
-                                                          instance_id, network_partition_id, partition_id)
-
-        publisher = get_publisher(constants.INSTANCE_STATUS_TOPIC + constants.INSTANCE_ACTIVATED_EVENT)
-        publisher.publish(instance_activated_event)
-
-        log.info("Instance activated event published")
-        log.info("Starting health statistics notifier")
-
-        if CEPPublisherConfiguration.get_instance().enabled:
-            interval_default = 15  # seconds
-            interval = CartridgeAgentConfiguration().read_property("stats.notifier.interval", False)
-            if interval is not None and len(interval) > 0:
-                try:
-                    interval = int(interval)
-                except ValueError:
+        if ports_active:
+            service_name = CartridgeAgentConfiguration().service_name
+            cluster_id = CartridgeAgentConfiguration().cluster_id
+            member_id = CartridgeAgentConfiguration().member_id
+            instance_id = CartridgeAgentConfiguration().instance_id
+            cluster_instance_id = CartridgeAgentConfiguration().cluster_instance_id
+            network_partition_id = CartridgeAgentConfiguration().network_partition_id
+            partition_id = CartridgeAgentConfiguration().partition_id
+
+            instance_activated_event = InstanceActivatedEvent(service_name, cluster_id, cluster_instance_id, member_id,
+                                                              instance_id, network_partition_id, partition_id)
+
+            publisher = get_publisher(constants.INSTANCE_STATUS_TOPIC + constants.INSTANCE_ACTIVATED_EVENT)
+            publisher.publish(instance_activated_event)
+
+            log.info("Instance activated event published")
+            log.info("Starting health statistics notifier")
+
+            if CEPPublisherConfiguration.get_instance().enabled:
+                interval_default = 15  # seconds
+                interval = CartridgeAgentConfiguration().read_property("stats.notifier.interval", False)
+                if interval is not None and len(interval) > 0:
+                    try:
+                        interval = int(interval)
+                    except ValueError:
+                        interval = interval_default
+                else:
                     interval = interval_default
+
+                health_stats_publisher = HealthStatisticsPublisherManager(interval)
+                log.info("Starting Health statistics publisher with interval %r" % interval)
+                health_stats_publisher.start()
             else:
-                interval = interval_default
+                log.warn("Statistics publisher is disabled")
 
-            health_stats_publisher = HealthStatisticsPublisherManager(interval)
-            log.info("Starting Health statistics publisher with interval %r" % interval)
-            health_stats_publisher.start()
+            activated = True
+            log.info("Health statistics notifier started")
         else:
-            log.warn("Statistics publisher is disabled")
-
-        activated = True
-        log.info("Health statistics notifier started")
+            log.error("Ports activation timed out. Aborting InstanceActivatedEvent publishing. [IPAddress] %s [Ports] %s"
+                      % (listen_address, configuration__ports))
     else:
         log.warn("Instance already activated")
 

http://git-wip-us.apache.org/repos/asf/stratos/blob/a4fc8ef2/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/util/cartridgeagentutils.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/util/cartridgeagentutils.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/util/cartridgeagentutils.py
index f8a4078..0f825bf 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/util/cartridgeagentutils.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/util/cartridgeagentutils.py
@@ -84,10 +84,12 @@ def wait_until_ports_active(ip_address, ports, ports_check_timeout=600000):
 
         if duration > ports_check_timeout:
             log.info("Port check timeout reached: [ip] %r [ports] %r [timeout] %r" % (ip_address, ports, ports_check_timeout))
-            return
+            return False
 
         time.sleep(5)
+
     log.info("Ports activated: [ip] %r [ports] %r" % (ip_address, ports))
+    return True
 
 
 def check_ports_active(ip_address, ports):


[20/50] [abbrv] stratos git commit: Enabling integration test in stratos product

Posted by re...@apache.org.
Enabling integration test in stratos product


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

Branch: refs/heads/docker-grouping-merge
Commit: 9b25a04c6f383a05e4bf21e013e13740b30ea4ae
Parents: 4b786cd
Author: Imesh Gunaratne <im...@apache.org>
Authored: Fri Feb 27 23:21:03 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Fri Feb 27 23:21:03 2015 +0530

----------------------------------------------------------------------
 products/stratos/pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/9b25a04c/products/stratos/pom.xml
----------------------------------------------------------------------
diff --git a/products/stratos/pom.xml b/products/stratos/pom.xml
index 13d35fd..3c7d621 100755
--- a/products/stratos/pom.xml
+++ b/products/stratos/pom.xml
@@ -34,7 +34,7 @@
     <modules>
         <module>modules/p2-profile-gen</module>
         <module>modules/distribution</module>
-        <!--<module>modules/integration</module>-->
+        <module>modules/integration</module>
     </modules>
 
     <dependencyManagement>


[04/50] [abbrv] stratos git commit: adding comments and removing commented code

Posted by re...@apache.org.
adding comments and removing commented code


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

Branch: refs/heads/docker-grouping-merge
Commit: 08663db4ae8ba8ffcebc56922cada928a3ec9414
Parents: 7007f23
Author: R-Rajkumar <rr...@gmail.com>
Authored: Thu Feb 26 21:24:02 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../stratos/autoscaler/util/AutoscalerUtil.java | 83 ++++++--------------
 1 file changed, 22 insertions(+), 61 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/08663db4/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/util/AutoscalerUtil.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/util/AutoscalerUtil.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/util/AutoscalerUtil.java
index f23229e..6ec0197 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/util/AutoscalerUtil.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/util/AutoscalerUtil.java
@@ -369,6 +369,12 @@ public class AutoscalerUtil {
         return "*";
     }
     
+    /**
+     * Get network partition ids referred in an application. Network partition ids are not referred directly.
+     * Cartridge or cartridge group can refer deployment policy which has network partition references.
+     * @param applicationId the application id
+     * @return list of network partition ids
+     */
     public static List<String> getNetworkPartitionIdsReferedInApplication(String applicationId) {
     	
     	List<String> deploymentPolicyIdsReferedInApplication = getDeploymentPolicyIdsReferedInApplication(applicationId);
@@ -399,6 +405,11 @@ public class AutoscalerUtil {
     	return networkPartitionIds;
 	}    
     
+    /**
+     * Get deployment policy ids referred in an application.
+     * @param applicationId the application id
+     * @return list of deployment policy ids
+     */
     private static List<String> getDeploymentPolicyIdsReferedInApplication(String applicationId) {
     	
     	Map<String, String> aliasToDeploymentPolicyIdMap = getAliasToDeploymentPolicyIdMapOfApplication(applicationId);
@@ -418,6 +429,12 @@ public class AutoscalerUtil {
 		return deploymentPolicyIds;
     }
     
+    /**
+     * Get deployment policy id of an alias in the given application
+     * @param applicationId the application id
+     * @param alias the cartridge or cartridge-group alias
+     * @return the deployment policy id if found, null otherwise
+     */
     public static String getDeploymentPolicyIdByAlias(String applicationId, String alias) {
     	
     	if (alias == null || alias.isEmpty()) {
@@ -433,6 +450,11 @@ public class AutoscalerUtil {
     	return aliasToDeploymentPolicyIdMap.get(alias);
     }
     
+    /**
+     * Get alias to deployment policy id map in the given application.
+     * @param applicationId the application id
+     * @return alias to deployment policy map
+     */
     private static Map<String, String> getAliasToDeploymentPolicyIdMapOfApplication(String applicationId) {
     	
     	Map<String, String> aliasToDeploymentPolicyIdMap = new HashMap<String, String>();
@@ -529,65 +551,4 @@ public class AutoscalerUtil {
 			}
 		}
     }
-
-//    public static LbClusterMonitor getLbClusterMonitor(Cluster cluster) throws PolicyValidationException, PartitionValidationException {
-//        if (null == cluster) {
-//               return null;
-//           }
-//
-//           String autoscalePolicyName = cluster.getAutoscalePolicyName();
-//           String deploymentPolicyName = cluster.getDeploymentPolicyName();
-//
-//           if (log.isDebugEnabled()) {
-//               log.debug("Deployment policy name: " + deploymentPolicyName);
-//               log.debug("Autoscaler policy name: " + autoscalePolicyName);
-//           }
-//
-//           AutoscalePolicy policy =
-//                                    PolicyManager.getInstance()
-//                                                 .getAutoscalePolicy(autoscalePolicyName);
-//           DeploymentPolicy deploymentPolicy =
-//                                               PolicyManager.getInstance()
-//                                                            .getDeploymentPolicy(deploymentPolicyName);
-//
-//           if (deploymentPolicy == null) {
-//               String msg = "Deployment Policy is null. Policy name: " + deploymentPolicyName;
-//               log.error(msg);
-//               throw new PolicyValidationException(msg);
-//           }
-//
-//           Partition[] allPartitions = deploymentPolicy.getAllPartitions();
-//           if (allPartitions == null) {
-//               String msg =
-//                            "Deployment Policy's Partitions are null. Policy name: " +
-//                                    deploymentPolicyName;
-//               log.error(msg);
-//               throw new PolicyValidationException(msg);
-//           }
-//
-//           try {
-//               validateExistenceOfPartions(allPartitions);
-//           } catch (InvalidPartitionException e) {
-//               String msg = "Deployment Policy is invalid. Policy name: " + deploymentPolicyName;
-//               log.error(msg, e);
-//               throw new PolicyValidationException(msg, e);
-//           }
-//
-//           CloudControllerClient.getInstance()
-//                                .validateDeploymentPolicy(cluster.getServiceName(),
-//                                                            allPartitions);
-//
-//           LbClusterMonitor clusterMonitor =
-//                                           new LbClusterMonitor(cluster.getClusterId(),
-//                                                              cluster.getServiceName(),
-//                                                              deploymentPolicy, policy);
-//           fNetworkPartitionroup partitionGroup: deploymentPoliNetworkPartitionnGroups()){
-//
-//               NetworkPartitionContext networkPartitionContext
-//                       = PartitionManager.getInstance().getNetworkPartitionLbHolder(partitionGroup.getNetworkPartitionId());
-//               clusterMonitor.addNetworkPartitionCtxt(networkPartitionContext);
-//           }
-//        return null;
-//    }
-
 }


[22/50] [abbrv] stratos git commit: fixing group-cartridges sample

Posted by re...@apache.org.
fixing group-cartridges sample


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

Branch: refs/heads/docker-grouping-merge
Commit: 530880a6d96c32c81eea6d4d01bb89b51c87d9c1
Parents: 16a8ef5
Author: R-Rajkumar <rr...@gmail.com>
Authored: Sat Feb 28 00:58:20 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Sat Feb 28 00:58:20 2015 +0530

----------------------------------------------------------------------
 .../artifacts/application-policy.json           | 12 +++++
 .../group-cartridges/artifacts/application.json | 14 ++---
 .../artifacts/autoscaling-policy.json           | 14 -----
 .../artifacts/deployment-policy.json            | 15 ------
 .../artifacts/ec2/deployment-policy.json        | 41 --------------
 .../artifacts/kubernetes/deployment-policy.json | 42 ---------------
 .../kubernetes/kubernetes-cluster.json          | 56 --------------------
 .../artifacts/mock/deployment-policy.json       | 56 --------------------
 .../artifacts/openstack/deployment-policy.json  | 41 --------------
 .../group-cartridges/scripts/common/deploy.sh   | 17 ++++--
 .../group-cartridges/scripts/common/undeploy.sh | 15 ++++--
 11 files changed, 46 insertions(+), 277 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/application-policy.json b/samples/applications/group-cartridges/artifacts/application-policy.json
new file mode 100644
index 0000000..239d6d9
--- /dev/null
+++ b/samples/applications/group-cartridges/artifacts/application-policy.json
@@ -0,0 +1,12 @@
+{
+   "networkPartition":[
+      {
+         "id":"network-partition-1",
+         "activeByDefault":"false"
+      },
+      {
+         "id":"network-partition-2",
+         "activeByDefault":"true"
+      }
+   ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/application.json b/samples/applications/group-cartridges/artifacts/application.json
index 77fd774..8a82371 100644
--- a/samples/applications/group-cartridges/artifacts/application.json
+++ b/samples/applications/group-cartridges/artifacts/application.json
@@ -1,6 +1,6 @@
 {
-    "applicationId": "single_group_v3",
-    "alias": "single_group_v3",
+    "applicationId": "group-cartridges",
+    "alias": "my-group-cartridges",
     "components": {
       "cartridges":[  
          {  
@@ -8,8 +8,9 @@
             "cartridgeMin": 1,
             "cartridgeMax": 2,
             "subscribableInfo": {
-                "alias": "mytomcat",
+                "alias": "my-tomcat1",
                 "autoscalingPolicy": "autoscaling-policy-1",
+                "deploymentPolicy":"deployment-policy-2",
                 "artifactRepository":{
                       "privateRepo":false,
                       "repoUrl":"https://github.com/imesh/stratos-tomcat1-applications.git",
@@ -22,9 +23,10 @@
             "type":"mysql",
             "cartridgeMin": 1,
             "cartridgeMax": 10,    
-			"subscribableInfo":{  
-                "alias":"mymysql",
+		"subscribableInfo":{  
+                "alias":"my-mysql",
                 "autoscalingPolicy":"autoscaling-policy-1",
+		"deploymentPolicy":"deployment-policy-2",
                 "artifactRepository":{
                     "privateRepo":false,
                     "repoUrl":"",
@@ -37,7 +39,7 @@
       ],
        "dependencies": {
             "startupOrders": [
-                "cartridge.mysql,cartridge.tomcat1"
+                "cartridge.my-mysql,cartridge.my-tomcat1"
             ],
             "terminationBehaviour": "terminate-all"
         }

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/autoscaling-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/autoscaling-policy.json b/samples/applications/group-cartridges/artifacts/autoscaling-policy.json
deleted file mode 100755
index 830ae17..0000000
--- a/samples/applications/group-cartridges/artifacts/autoscaling-policy.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-    "id": "autoscaling-policy-1",
-    "loadThresholds": {
-        "requestsInFlight": {
-            "upperLimit": 80
-        },
-        "memoryConsumption": {
-            "upperLimit": 90
-        },
-        "loadAverage": {
-            "upperLimit": 50
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/deployment-policy.json b/samples/applications/group-cartridges/artifacts/deployment-policy.json
deleted file mode 100644
index d858aed..0000000
--- a/samples/applications/group-cartridges/artifacts/deployment-policy.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-   "id": "deployment-policy-2",
-   "networkPartition": [
-      {
-         "id": "network-partition-1",
-         "partitionAlgo": "one-after-another",
-         "partitions": [
-            {
-               "id": "partition-1",
-               "max": 5
-            }
-         ]
-      }
-   ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/ec2/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/ec2/deployment-policy.json b/samples/applications/group-cartridges/artifacts/ec2/deployment-policy.json
deleted file mode 100644
index 2665e2e..0000000
--- a/samples/applications/group-cartridges/artifacts/ec2/deployment-policy.json
+++ /dev/null
@@ -1,41 +0,0 @@
-{
-    "applicationId": "single_group_v3",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "ec2",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "ap-southeast-1"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mygroup6",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/kubernetes/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/kubernetes/deployment-policy.json b/samples/applications/group-cartridges/artifacts/kubernetes/deployment-policy.json
deleted file mode 100644
index c12e444..0000000
--- a/samples/applications/group-cartridges/artifacts/kubernetes/deployment-policy.json
+++ /dev/null
@@ -1,42 +0,0 @@
-{
-    "applicationId": "single_group_v3",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id":"network-partition-1",
-                "kubernetesClusterId":"kubernetes-cluster-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "kubernetes",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mygroup6",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/kubernetes/kubernetes-cluster.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/kubernetes/kubernetes-cluster.json b/samples/applications/group-cartridges/artifacts/kubernetes/kubernetes-cluster.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/applications/group-cartridges/artifacts/kubernetes/kubernetes-cluster.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/mock/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/mock/deployment-policy.json b/samples/applications/group-cartridges/artifacts/mock/deployment-policy.json
deleted file mode 100644
index 26c684a..0000000
--- a/samples/applications/group-cartridges/artifacts/mock/deployment-policy.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "applicationId": "single_group_v3",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "mock",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "RegionOne"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mytomcat",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "mymysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/artifacts/openstack/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/artifacts/openstack/deployment-policy.json b/samples/applications/group-cartridges/artifacts/openstack/deployment-policy.json
deleted file mode 100644
index 13df308..0000000
--- a/samples/applications/group-cartridges/artifacts/openstack/deployment-policy.json
+++ /dev/null
@@ -1,41 +0,0 @@
-{
-    "applicationId": "single_group_v3",
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "openstack",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "RegionOne"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mygroup6",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/scripts/common/deploy.sh b/samples/applications/group-cartridges/scripts/common/deploy.sh
index 8bef5fc..74be5ec 100755
--- a/samples/applications/group-cartridges/scripts/common/deploy.sh
+++ b/samples/applications/group-cartridges/scripts/common/deploy.sh
@@ -11,6 +11,9 @@ artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
 
 set -e
 
@@ -19,9 +22,17 @@ if [[ -z "${iaas}" ]]; then
     exit
 fi
 
-echo ${artifacts_path}/autoscaling-policy.json
+echo ${autoscaling_policies_path}/autoscaling-policy-1.json
 echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+
+echo "Adding network partitions..."
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+
+echo "Adding deployment policies..."
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-2.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding tomcat cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${cartridges_path}/mysql.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
@@ -43,4 +54,4 @@ curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/applicat
 sleep 1
 
 echo "Deploying application..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single_group_v3/deploy
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/group-cartridges/deploy

http://git-wip-us.apache.org/repos/asf/stratos/blob/530880a6/samples/applications/group-cartridges/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/group-cartridges/scripts/common/undeploy.sh b/samples/applications/group-cartridges/scripts/common/undeploy.sh
index 3ad5810..d7e24d6 100644
--- a/samples/applications/group-cartridges/scripts/common/undeploy.sh
+++ b/samples/applications/group-cartridges/scripts/common/undeploy.sh
@@ -6,12 +6,12 @@ host_port=9443
 set -e
 
 echo "Undeploying application..."
-curl -X POST -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single_group_v3/undeploy
+curl -X POST -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/group-cartridges/undeploy
 
 sleep 10
 
 echo "Deleting application..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single_group_v3
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/group-cartridges
 
 echo "Removing groups..."
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridgeGroups/group8
@@ -23,4 +23,13 @@ curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/tomcat2
 
 echo "Removing autoscale policies..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
\ No newline at end of file
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
+
+echo "Removing deployment policies..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-1
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-2
+
+echo "Removing network partitions..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-1
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-2
+


[14/50] [abbrv] stratos git commit: update sample-cartridges sample to use only one NW partition

Posted by re...@apache.org.
update sample-cartridges sample to use only one NW partition


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

Branch: refs/heads/docker-grouping-merge
Commit: 22fdf78be8a62312a65b23e017f0de20cfad82b2
Parents: 5587040
Author: Lahiru Sandaruwan <la...@apache.org>
Authored: Fri Feb 27 22:08:08 2015 +0530
Committer: Lahiru Sandaruwan <la...@apache.org>
Committed: Fri Feb 27 22:08:08 2015 +0530

----------------------------------------------------------------------
 .../artifacts/application-policy.json                |  4 ----
 .../artifacts/network-partition-2.json               | 15 ---------------
 .../sample-cartridges/scripts/common/deploy.sh       |  3 +--
 3 files changed, 1 insertion(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/22fdf78b/samples/applications/dependent-scaling/sample-cartridges/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/dependent-scaling/sample-cartridges/artifacts/application-policy.json b/samples/applications/dependent-scaling/sample-cartridges/artifacts/application-policy.json
index 5aa91dd..9d2c6a1 100644
--- a/samples/applications/dependent-scaling/sample-cartridges/artifacts/application-policy.json
+++ b/samples/applications/dependent-scaling/sample-cartridges/artifacts/application-policy.json
@@ -3,10 +3,6 @@
       {
          "id":"network-partition-1",
          "activeByDefault":"true"
-      },
-      {
-         "id":"network-partition-2",
-         "activeByDefault":"false"
       }
    ]
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/22fdf78b/samples/applications/dependent-scaling/sample-cartridges/artifacts/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/applications/dependent-scaling/sample-cartridges/artifacts/network-partition-2.json b/samples/applications/dependent-scaling/sample-cartridges/artifacts/network-partition-2.json
deleted file mode 100644
index 0d07838..0000000
--- a/samples/applications/dependent-scaling/sample-cartridges/artifacts/network-partition-2.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-2",
-    "partitions": [
-        {
-            "id": "partition-2",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/22fdf78b/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh b/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
index 5eb92c2..196b4ca 100755
--- a/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
+++ b/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
@@ -25,7 +25,6 @@ curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscal
 
 echo "Adding network partitions..."
 curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
 curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
@@ -44,4 +43,4 @@ curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/applicat
 sleep 1
 
 echo "Deploying application..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/dependency-scaling-cartridges-app/deploy
\ No newline at end of file
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/dependency-scaling-cartridges-app/deploy


[50/50] [abbrv] stratos git commit: PCA - Metadata client related changes

Posted by re...@apache.org.
PCA - Metadata client related changes


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

Branch: refs/heads/master
Commit: f9948c5e3f259fb3b25b5ec40740fdbaa14e4d8d
Parents: 08045d9
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 22:04:55 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 .../cartridge.agent/cartridge.agent/agent.conf  |   3 +-
 .../cartridge.agent/cartridge.agent/config.py   |   6 +-
 .../cartridge.agent/constants.py                |   3 +
 .../cartridge.agent/mdsclient.py                | 118 +++++++++++++++++++
 .../modules/artifactmgt/git/agentgithandler.py  |   5 +-
 .../modules/event/eventhandler.py               |   8 +-
 .../src/test/resources/agent.conf               |   1 +
 .../src/test/resources/payload/launch-params    |   2 +-
 .../src/test/resources/payload/launch-params2   |   1 +
 9 files changed, 140 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
index 1e1f764..51f5831 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
@@ -38,7 +38,8 @@ monitoring.server.secure.port         =MONITORING-SERVER-SECURE-PORT
 monitoring.server.admin.username      =MONITORING-SERVER-ADMIN-USERNAME
 monitoring.server.admin.password      =MONITORING-SERVER-ADMIN-PASSWORD
 log.file.paths                        =LOG_FILE_PATHS
-APPLICATION_PATH                      =APPLICATION_PATH
+APPLICATION_PATH                      =APPLICATION-PATH
+METADATA_SERVICE_URL                  =METADATA-SERVICE-URL
 super.tenant.repository.path          =/repository/deployment/server/
 tenant.repository.path                =/repository/tenants/
 extension.instance.started            =instance-started.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
index 33d2fbb..1ad9499 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
@@ -296,7 +296,11 @@ class CartridgeAgentConfiguration:
                     for param in metadata_payload_content.split(","):
                         if param.strip() != "":
                             param_value = param.strip().split("=")
-                            self.__payload_params[param_value[0]] = param_value[1]
+                            try:
+                                self.__payload_params[param_value[0]] = param_value[1]
+                            except IndexError:
+                                # If an index error comes when reading values, keep on reading
+                                pass
 
                     # self.payload_params = dict(
                     #     param.split("=") for param in metadata_payload_content.split(","))

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
index 1427a2b..7331d7f 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
@@ -43,6 +43,8 @@ PERSISTENCE_MAPPING = "PERSISTENCE_MAPPING"
 DEPENDENCY_CLUSTER_IDS = "DEPENDENCY_CLUSTER_IDS"
 EXPORT_METADATA_KEYS = "EXPORT_METADATA_KEYS"
 IMPORT_METADATA_KEYS = "IMPORT_METADATA_KEYS"
+CARTRIDGE_ALIAS = "CARTRIDGE_ALIAS"
+TOKEN = "TOKEN"
 
 # stratos.sh environment variables keys
 LOG_FILE_PATHS = "LOG_FILE_PATHS"
@@ -62,6 +64,7 @@ PROVIDER = "PROVIDER"
 INTERNAL = "INTERNAL"
 LB_PRIVATE_IP = "lb.private.ip"
 LB_PUBLIC_IP = "lb.public.ip"
+METADATA_SERVICE_URL = "METADATA_SERVICE_URL"
 
 # stratos.sh extension points shell scripts names keys
 INSTANCE_STARTED_SCRIPT = "extension.instance.started"

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py
new file mode 100644
index 0000000..f67eca0
--- /dev/null
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py
@@ -0,0 +1,118 @@
+# 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.
+
+import urllib2, urllib
+from urllib2 import URLError, HTTPError
+import json
+from modules.util.log import LogFactory
+from config import CartridgeAgentConfiguration
+import constants
+
+
+log = LogFactory().get_log(__name__)
+config = CartridgeAgentConfiguration()
+mds_url = config.read_property(constants.METADATA_SERVICE_URL)
+alias = config.read_property(constants.CARTRIDGE_ALIAS)
+app_id = config.read_property(constants.APPLICATION_ID)
+token = config.read_property(constants.TOKEN)
+alias_resource_url = mds_url + "/metadata/api/application/" + app_id + "/cluster/" + alias + "/properties"
+app_resource_url = mds_url + "/metadata/api/application/" + app_id + "/properties"
+
+
+def put(put_req, app=False):
+    """ Publish a set of key values to the metadata service
+    :param MDSPutRequest put_req:
+    :param
+    :return: the response string or None if exception
+    :rtype: str
+    """
+    # serialize put request object to json
+    request_data = json.dumps(put_req, default=lambda o: o.__dict__)
+    if app:
+        put_request = urllib2.Request(app_resource_url)
+    else:
+        put_request = urllib2.Request(alias_resource_url)
+
+    put_request.add_header("Authorization", "Bearer %s" % token)
+    put_request.add_header('Content-Type', 'application/json')
+
+    try:
+        log.debug("Publishing metadata to Metadata service. [URL] %s, [DATA] %s" % (put_request.get_full_url(), request_data))
+        handler = urllib2.urlopen(put_request, request_data)
+        log.debug("Metadata service response: %s" % handler.getcode())
+
+        return handler.read()
+    except HTTPError as e:
+        log.exception("Error while publishing to Metadata service. The server couldn\'t fulfill the request.: %s" % e)
+        return None
+    except URLError as e:
+        log.exception("Error while publishing to Metadata service. Couldn't reach server URL. : %s" % e)
+        return None
+
+
+def get(app=False):
+    """ Retrieves the key value pairs for the application ID from the metadata service
+    :param
+    :return : MDSResponse object with properties dictionary as key value pairs
+    :rtype: MDSResponse
+    """
+    try:
+        if app:
+            log.debug("Retrieving metadata from the Metadata service. [URL] %s" % app_resource_url)
+            req_response = urllib2.urlopen(app_resource_url)
+        else:
+            log.debug("Retrieving metadata from the Metadata service. [URL] %s" % alias_resource_url)
+            req_response = urllib2.urlopen(alias_resource_url)
+
+        get_response = json.loads(req_response.read())
+        properties = get_response["properties"]
+        log.debug("Retrieved values from Metadata service: %s" % properties)
+        response_obj = MDSResponse()
+
+        for md_property in properties:
+            response_obj.properties[md_property["key"]] = md_property["values"]
+
+        return response_obj
+    except HTTPError as e:
+        log.exception("Error while retrieving from Metadata service. The server couldn\'t fulfill the request.: %s" % e)
+        return None
+    except URLError as e:
+        log.exception("Error while retrieving from Metadata service. Couldn't reach server URL. : %s" % e)
+        return None
+
+
+def update(data):
+    raise NotImplementedError
+
+
+def delete(keys):
+    raise NotImplementedError
+
+
+class MDSPutRequest:
+    """ Class to encapsulate the publish request.
+    The properties member is a list of dictionaries with the format as follows.
+    {"key": key_name, "values": value}
+    """
+    properties = []
+
+
+class MDSResponse:
+    """ Class to encapsulate the response from the metadata service retrieval.
+    The properties member is a dictionary with the retrieved key value pairs.
+    """
+    properties = {}

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
index a9164b0..5fad062 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
@@ -182,10 +182,11 @@ class AgentGitHandler:
 
     @staticmethod
     def clone(git_repo):
-        if os.path.isdir(git_repo.local_repo_path):
-            # delete and recreate local repo path if exists
+        if os.path.isdir(git_repo.local_repo_path) and os.listdir(git_repo.local_repo_path) != []:
+            # delete and recreate local repo path if not empty dir
             AgentGitHandler.log.debug("Local repository path not empty. Cleaning.")
             GitUtils.delete_folder_tree(git_repo.local_repo_path)
+            GitUtils.create_dir(git_repo.local_repo_path)
 
         try:
             Repo.clone_from(git_repo.repo_url, git_repo.local_repo_path)

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
index 079ebd2..e414ec7 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
@@ -113,7 +113,11 @@ class EventHandler:
             if plugins_for_event is not None:
                 for plugin_info in plugins_for_event:
                     self.__log.debug("Executing plugin %s for event %s" % (plugin_info.name, event))
-                    PluginExecutor(plugin_info, plugin_values).start()
+                    plugin_thread = PluginExecutor(plugin_info, plugin_values)
+                    plugin_thread.start()
+
+                    # block till plugin run completes.
+                    plugin_thread.join()
             else:
                 self.__log.debug("No plugins registered for event %s" % event)
         except Exception as e:
@@ -610,6 +614,6 @@ class PluginExecutor(Thread):
 
     def run(self):
         try:
-            self.__plugin_info.plugin_object.run_plugin(self.__values, self.__log)
+            self.__plugin_info.plugin_object.run_plugin(self.__values)
         except Exception as e:
             self.__log.exception("Error while executing plugin %s: %s" % (self.__plugin_info.name, e))

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
index bb264ac..eeee06e 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
+++ b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
@@ -38,6 +38,7 @@ monitoring.server.secure.port         =7711
 monitoring.server.admin.username      =admin
 monitoring.server.admin.password      =admin
 log.file.paths                        =
+METADATA_SERVICE_URL                  =https://localhost:9443
 super.tenant.repository.path          =/repository/deployment/server/
 tenant.repository.path                =/repository/tenants/
 extension.instance.started            =instance-started.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
index 858d622..a909a1e 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
+++ b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
@@ -1 +1 @@
-APPLICATION_ID=application1,SERVICE_NAME=php,HOST_NAME=php.php.stratos.org,MULTITENANT=false,TENANT_ID=-1234,TENANT_RANGE=*,CARTRIDGE_ALIAS=php,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single-cartridge-app-1,CARTRIDGE_KEY=PUjpXCLujDhYr5A6,DEPLOYMENT=default,REPO_URL=https://github.com/imesh/stratos-php-applications.git,PORTS=9080,PUPPET_IP=127.0.0.1,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_ENV=false,MEMBER_ID=php.member-1,LB_CLUSTER_ID=null,NETWORK_PARTITION_ID=network-p1,PARTITION_ID=p1,APPLICATION_PATH=/tmp/stratos-pca-test-app-path/,MIN_COUNT=1,INTERNAL=false,CLUSTERING_PRIMARY_KEY=A,LOG_FILE_PATHS=/tmp/temp.log,PERSISTENCE_MAPPING=null,MP_IP=192.168.1.4,MB_PORT=1883
\ No newline at end of file
+APPLICATION_ID=single_group_v1,APPLICATION_PATH=/tmp/tomcat/webapps,BASH=/bin/bash,BASHOPTS=cmdhist:complete_fullquote:extquote:force_fignore:hostcomplete:interactive_comments:progcomp:promptvars:sourcepath,BASH_ALIASES=(),BASH_ARGC=(),BASH_ARGV=(),BASH_CMDS=(),BASH_LINENO=([0]="0"),BASH_SOURCE=([0]="/usr/local/bin/populate-user-data.sh"),BASH_VERSINFO=([0]="4" [1]="3" [2]="30" [3]="1" [4]="release" [5]="x86_64-pc-linux-gnu"),BASH_VERSION='4.3.30(1)-release',CARTRIDGE_ALIAS=mytomcat,CARTRIDGE_KEY=6abTFgRg7oCkXWCt,CATALINA_HOME=/opt/tomcat,CEP_IP=54.179.197.243,CEP_PORT=7711,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single_group_v1-1,DEPENDENCY_CLUSTER_IDS=myphp.php.domain,DEPLOYMENT=default,DIRSTACK=(),EUID=0,GROUPS=(),GROUP_NAME=null,HOME=/root,HOSTNAME=mytomcat-tomcat-domain3bd3cd47-b95d-475a-aa11-3e3ddc089d49,HOSTTYPE=x86_64,HOST_NAME=mytomcat.tomcat.stratos.org,IFS=' 	,',INSTANCE_ID=null,INTERNAL=false,JAVA_HOME=/opt/jdk1.7.0_67,KUBERNETES_CLUSTER_ID=kubernetes-cluster-1,KUB
 ERNETES_PORT=tcp://10.100.0.2:443,KUBERNETES_PORT_443_TCP=tcp://10.100.0.2:443,KUBERNETES_PORT_443_TCP_ADDR=10.100.0.2,KUBERNETES_PORT_443_TCP_PORT=443,KUBERNETES_PORT_443_TCP_PROTO=tcp,KUBERNETES_RO_PORT=tcp://10.100.0.1:80,KUBERNETES_RO_PORT_80_TCP=tcp://10.100.0.1:80,KUBERNETES_RO_PORT_80_TCP_ADDR=10.100.0.1,KUBERNETES_RO_PORT_80_TCP_PORT=80,KUBERNETES_RO_PORT_80_TCP_PROTO=tcp,KUBERNETES_RO_SERVICE_HOST=10.100.0.1,KUBERNETES_RO_SERVICE_PORT=80,KUBERNETES_SERVICE_HOST=10.100.0.2,KUBERNETES_SERVICE_PORT=443,LB_CLUSTER_ID=null,LOG_LEVEL=DEBUG,MACHTYPE=x86_64-pc-linux-gnu,MB_IP=54.179.197.243,MB_PORT=1883,MEMBER_ID=php.member-1,METADATA_SERVICE_URL=https://54.179.197.243:9443,MIN_COUNT=1,MULTITENANT=false,MYPHP_PHP_DOMAIN_1_PORT=tcp://10.100.171.218:4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP=tcp://10.100.171.218:4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_ADDR=10.100.171.218,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_PORT=4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_PROTO=tcp,MYPHP_PHP_DOMAIN_1_SERVICE_HOST=10.
 100.171.218,MYPHP_PHP_DOMAIN_1_SERVICE_PORT=4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT=tcp://10.100.16.250:4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP=tcp://10.100.16.250:4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_ADDR=10.100.16.250,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_PORT=4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_PROTO=tcp,MYTOMCAT_TOMCAT_DOMAIN_1_SERVICE_HOST=10.100.16.250,MYTOMCAT_TOMCAT_DOMAIN_1_SERVICE_PORT=4500,NETWORK_PARTITION_ID=network-partition-1,OPTERR=1,OPTIND=1,OSTYPE=linux-gnu,PARTITION_ID=partition-1,PATH=/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin,PIPESTATUS=([0]="0"),PORTS=8080,POSIXLY_CORRECT=y,PPID=14,PRIMARY=false,PROVIDER=apache,PS4='+ ',PUPPET_DNS_AVAILABLE=null,PUPPET_ENV=false,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_IP=127.0.0.1,PWD=/opt,REPO_URL=https://github.com/imesh/stratos-tomcat-applications.git,SERVICE_NAME=php,SHELL=/bin/bash,SHELLOPTS=braceexpand:hashall:interactive-comments:posix,SHLVL=2,TENANT_ID=-1234,TENANT_RANGE='*',TER
 M=dumb,TOKEN=eyJhbGciOiJSUzI1NiJ9.eyJleHAiOi04NzI0ODEyNDEsInN1YiI6ImFkbWluIiwiYXpwIjoid3I5SllVaDNtTXd6bVhHVllqWmVIWnhCV2xFYSIsImFwcElkIjoic2luZ2xlX2dyb3VwX3YxIiwiYXVkIjpbIndyOUpZVWgzbU13em1YR1ZZalplSFp4QldsRWEiXSwiaXNzIjoiaHR0cHM6XC9cL2xvY2FsaG9zdDo5NDQzXC9vYXV0aDJlbmRwb2ludHNcL3Rva2VuIiwiaWF0IjotODcyNDgwMjQwfQ.OSa1gIXUT9amhk1YEU02Yc3JtUYqanzrXh5K1YyvRXcpSiY2Ccn2BfJO0hILF5UooRcGBihzfX3979NRcvGwcUDUvOUJ0eaGPmxFZYbu0nr3xD8lhAO3fa1QYsKAvMnMdwyu2uSgSp6R6EUdVleiwlabUoDsuEcKGkIAn_VQvG0,UID=0,_=posix
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2 b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2
new file mode 100644
index 0000000..858d622
--- /dev/null
+++ b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2
@@ -0,0 +1 @@
+APPLICATION_ID=application1,SERVICE_NAME=php,HOST_NAME=php.php.stratos.org,MULTITENANT=false,TENANT_ID=-1234,TENANT_RANGE=*,CARTRIDGE_ALIAS=php,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single-cartridge-app-1,CARTRIDGE_KEY=PUjpXCLujDhYr5A6,DEPLOYMENT=default,REPO_URL=https://github.com/imesh/stratos-php-applications.git,PORTS=9080,PUPPET_IP=127.0.0.1,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_ENV=false,MEMBER_ID=php.member-1,LB_CLUSTER_ID=null,NETWORK_PARTITION_ID=network-p1,PARTITION_ID=p1,APPLICATION_PATH=/tmp/stratos-pca-test-app-path/,MIN_COUNT=1,INTERNAL=false,CLUSTERING_PRIMARY_KEY=A,LOG_FILE_PATHS=/tmp/temp.log,PERSISTENCE_MAPPING=null,MP_IP=192.168.1.4,MB_PORT=1883
\ No newline at end of file


[38/50] [abbrv] stratos git commit: using deployment-policy-4 in single-cartridge app

Posted by re...@apache.org.
using deployment-policy-4 in single-cartridge app


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

Branch: refs/heads/docker-grouping-merge
Commit: 7cde490c30ffeaac1ee09255be4912664d202f80
Parents: d66ee5b
Author: R-Rajkumar <rr...@gmail.com>
Authored: Sun Mar 1 18:23:08 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Sun Mar 1 18:23:08 2015 +0530

----------------------------------------------------------------------
 samples/applications/single-cartridge/scripts/common/deploy.sh   | 2 +-
 samples/applications/single-cartridge/scripts/common/undeploy.sh | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/7cde490c/samples/applications/single-cartridge/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/scripts/common/deploy.sh b/samples/applications/single-cartridge/scripts/common/deploy.sh
index ee56281..74fd82c 100755
--- a/samples/applications/single-cartridge/scripts/common/deploy.sh
+++ b/samples/applications/single-cartridge/scripts/common/deploy.sh
@@ -30,7 +30,7 @@ curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}
 curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-4.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding php cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/php.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges

http://git-wip-us.apache.org/repos/asf/stratos/blob/7cde490c/samples/applications/single-cartridge/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/scripts/common/undeploy.sh b/samples/applications/single-cartridge/scripts/common/undeploy.sh
index 65499db..b5781df 100644
--- a/samples/applications/single-cartridge/scripts/common/undeploy.sh
+++ b/samples/applications/single-cartridge/scripts/common/undeploy.sh
@@ -20,7 +20,7 @@ echo "Removing autoscale policies..."
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
 
 echo "Removing deployment policies..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-1
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-4
 
 echo "Removing network partitions..."
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-1


[11/50] [abbrv] stratos git commit: fixing merge conflicts

Posted by re...@apache.org.
fixing merge conflicts


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

Branch: refs/heads/docker-grouping-merge
Commit: b724ac2248325e6822dd8983a7a43c9c73abeb59
Parents: 90f3480
Author: R-Rajkumar <rr...@gmail.com>
Authored: Fri Feb 27 20:04:27 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 20:04:27 2015 +0530

----------------------------------------------------------------------
 .../iaases/kubernetes/KubernetesIaas.java       |    2 +-
 .../src/main/resources/AutoscalerService.wsdl   |  652 +---
 .../main/resources/CloudControllerService.wsdl  | 3648 ++++--------------
 3 files changed, 938 insertions(+), 3364 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/b724ac22/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index 4ba2393..47e620c 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -390,7 +390,7 @@ public class KubernetesIaas extends Iaas {
 
         // Add pod id to member context and persist
         memberContext.setKubernetesPodId(podId);
-        memberContext.setKubernetesPodName(podLabel);
+        memberContext.setKubernetesPodLabel(podLabel);
         CloudControllerContext.getInstance().persist();
 
         if (log.isInfoEnabled()) {

http://git-wip-us.apache.org/repos/asf/stratos/blob/b724ac22/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl b/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
index 10efda0..25d751c 100644
--- a/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
+++ b/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
@@ -1,50 +1,16 @@
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<?xml version="1.0" encoding="UTF-8"?><wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax25="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax21="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax22="http://common.stratos.apache.org/xsd" xmlns:ax219="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax212="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax222="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" x
 mlns:ax211="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
-=======
-=======
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax25="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax23="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax220="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://common.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns
 :mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
-=======
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax25="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax23="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax221="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax223="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://common.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http=
 "http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://common.stratos.apache.org/xsd" xmlns:ax25="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax23="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax220="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax211="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns
 :mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax25="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://common.stratos.apache.org/xsd" xmlns:ax23="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax220="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax211="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns
 :mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
->>>>>>> fixing merging issues
-=======
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax25="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax23="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax220="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://common.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns
 :mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
+<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://common.stratos.apache.org/xsd" xmlns:ax27="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax25="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax23="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax216="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax220="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax211="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns
 :mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
     <wsdl:documentation>AutoscalerService</wsdl:documentation>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
     <wsdl:types>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="AutoscalePolicy">
                 <xs:sequence>
-<<<<<<< HEAD
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="displayName" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="instanceRoundingFactor" type="xs:float"/>
-                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"/>
-                    <xs:element minOccurs="0" name="loadThresholds" nillable="true" type="ax29:LoadThresholds"/>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-=======
                     <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="displayName" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="instanceRoundingFactor" type="xs:float"></xs:element>
                     <xs:element minOccurs="0" name="isPublic" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="loadThresholds" nillable="true" type="ax25:LoadThresholds"></xs:element>
+                    <xs:element minOccurs="0" name="loadThresholds" nillable="true" type="ax23:LoadThresholds"></xs:element>
                     <xs:element minOccurs="0" name="tenantId" type="xs:int"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="LoadThresholds">
@@ -55,17 +21,17 @@
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax211="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd">
+        <xs:schema xmlns:ax214="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd">
             <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
             <xs:complexType name="ApplicationContext">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="components" nillable="true" type="ax29:ComponentContext"></xs:element>
+                    <xs:element minOccurs="0" name="components" nillable="true" type="ax213:ComponentContext"></xs:element>
                     <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="multiTenant" type="xs:boolean"></xs:element>
                     <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax210:Properties"></xs:element>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
                     <xs:element minOccurs="0" name="status" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="tenantAdminUsername" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="tenantDomain" nillable="true" type="xs:string"></xs:element>
@@ -74,10 +40,10 @@
             </xs:complexType>
             <xs:complexType name="ComponentContext">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="applicationClusterContexts" nillable="true" type="ax29:ApplicationClusterContext"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax29:CartridgeContext"></xs:element>
-                    <xs:element minOccurs="0" name="dependencyContext" nillable="true" type="ax29:DependencyContext"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax29:GroupContext"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="applicationClusterContexts" nillable="true" type="ax213:ApplicationClusterContext"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax213:CartridgeContext"></xs:element>
+                    <xs:element minOccurs="0" name="dependencyContext" nillable="true" type="ax213:DependencyContext"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax213:GroupContext"></xs:element>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ApplicationClusterContext">
@@ -89,7 +55,7 @@
                     <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax210:Properties"></xs:element>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
                     <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="textPayload" nillable="true" type="xs:string"></xs:element>
                 </xs:sequence>
@@ -98,20 +64,20 @@
                 <xs:sequence>
                     <xs:element minOccurs="0" name="cartridgeMax" type="xs:int"></xs:element>
                     <xs:element minOccurs="0" name="cartridgeMin" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="subscribableInfoContext" nillable="true" type="ax29:SubscribableInfoContext"></xs:element>
+                    <xs:element minOccurs="0" name="subscribableInfoContext" nillable="true" type="ax213:SubscribableInfoContext"></xs:element>
                     <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"></xs:element>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="SubscribableInfoContext">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="artifactRepositoryContext" nillable="true" type="ax29:ArtifactRepositoryContext"></xs:element>
+                    <xs:element minOccurs="0" name="artifactRepositoryContext" nillable="true" type="ax213:ArtifactRepositoryContext"></xs:element>
                     <xs:element minOccurs="0" name="autoscalingPolicy" nillable="true" type="xs:string"></xs:element>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyAliases" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"></xs:element>
                     <xs:element minOccurs="0" name="maxMembers" type="xs:int"></xs:element>
                     <xs:element minOccurs="0" name="minMembers" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax210:Properties"></xs:element>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ArtifactRepositoryContext">
@@ -133,9 +99,9 @@
             <xs:complexType name="GroupContext">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax29:CartridgeContext"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax213:CartridgeContext"></xs:element>
                     <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax29:GroupContext"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax213:GroupContext"></xs:element>
                     <xs:element minOccurs="0" name="groupMaxInstances" type="xs:int"></xs:element>
                     <xs:element minOccurs="0" name="groupMinInstances" type="xs:int"></xs:element>
                     <xs:element minOccurs="0" name="groupScalingEnabled" type="xs:boolean"></xs:element>
@@ -146,19 +112,11 @@
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="ServiceGroup">
                 <xs:sequence>
-<<<<<<< HEAD
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridges" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax27:Dependencies"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax27:ServiceGroup"/>
-                    <xs:element minOccurs="0" name="groupscalingEnabled" type="xs:boolean"/>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-=======
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridges" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax218:Dependencies"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax218:ServiceGroup"></xs:element>
+                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax220:Dependencies"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax220:ServiceGroup"></xs:element>
                     <xs:element minOccurs="0" name="groupscalingEnabled" type="xs:boolean"></xs:element>
                     <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Dependencies">
@@ -169,101 +127,17 @@
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-        <xs:schema xmlns:ax28="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax216="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax218="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax220="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://common.stratos.apache.org/xsd" xmlns:ax223="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
-            <xs:import namespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://application.exception.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://pojo.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://exception.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://policy.exception.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://common.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd"/>
-            <xs:element name="getApplications">
-                <xs:complexType>
-                    <xs:sequence/>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getApplicationsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="AutoscalerServiceApplicationDefinitionException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax25:ApplicationDefinitionException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="addApplication">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax24:ApplicationContext"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroup">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax27:ServiceGroup"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getAutoscalingPolicy">
-=======
-=======
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-        <xs:schema xmlns:ax214="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://common.stratos.apache.org/xsd" xmlns:ax216="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax219="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
-            <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-=======
-        <xs:schema xmlns:ax214="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax222="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax224="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://common.stratos.apache.org/xsd" xmlns:ax216="http://exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-            <xs:import namespace="http://policy.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-=======
-        <xs:schema xmlns:ax214="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://common.stratos.apache.org/xsd" xmlns:ax216="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax219="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
+        <xs:schema xmlns:ax215="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://common.stratos.apache.org/xsd" xmlns:ax26="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax219="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
             <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-        <xs:schema xmlns:ax214="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://common.stratos.apache.org/xsd" xmlns:ax216="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax219="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
->>>>>>> fixing merging issues
-=======
-        <xs:schema xmlns:ax214="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://common.stratos.apache.org/xsd" xmlns:ax216="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax219="http://pojo.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
             <xs:import namespace="http://policy.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
+            <xs:import namespace="http://exception.autoscaler.stratos.apache.org/xsd"></xs:import>
+            <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
             <xs:import namespace="http://application.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
             <xs:import namespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd"></xs:import>
             <xs:import namespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
+            <xs:import namespace="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
             <xs:import namespace="http://pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-=======
->>>>>>> fixing STRATOS-1214 - deployement policy changes
             <xs:element name="getAutoScalingPolicies">
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                 <xs:complexType>
                     <xs:sequence></xs:sequence>
                 </xs:complexType>
@@ -271,37 +145,21 @@
             <xs:element name="getAutoScalingPoliciesResponse">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:AutoscalePolicy"/>
-=======
                         <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-=======
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-            <xs:element name="AutoscalerServiceInvalidPolicyException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPolicyException" nillable="true" type="ax23:InvalidPolicyException"></xs:element>
-=======
-=======
->>>>>>> fixing merging issues
-=======
-            <xs:import namespace="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
             <xs:element name="AutoscalerServiceInvalidPolicyException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPolicyException" nillable="true" type="ax23:InvalidPolicyException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidPolicyException" nillable="true" type="ax25:InvalidPolicyException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="addAutoScalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -312,343 +170,144 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
-            <xs:element name="AutoscalerServiceApplicationDefinitionException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax27:ApplicationDefinitionException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="addApplication">
+            <xs:element name="updateAutoScalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
-=======
                         <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
-=======
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
-=======
-                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax27:ApplicationContext"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax28:ApplicationContext"></xs:element>
->>>>>>> fixing merging issues
-=======
-                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax29:ApplicationContext"></xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplications">
+            <xs:element name="updateAutoScalingPolicyResponse">
                 <xs:complexType>
-<<<<<<< HEAD
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-                    </xs:sequence>
-=======
-                    <xs:sequence></xs:sequence>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getApplicationsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax216:NetworkPartition"/>
-=======
-                        <xs:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax27:ApplicationDefinitionException"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax27:ApplicationContext"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax28:ApplicationContext"></xs:element>
->>>>>>> fixing merging issues
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:ApplicationContext"></xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deployApplication">
+            <xs:element name="removeAutoScalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="applicationPolicy" nillable="true" type="ax214:ApplicationPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="autoscalePolicyId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deployApplicationResponse">
+            <xs:element name="removeAutoScalingPolicyResponse">
                 <xs:complexType>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax216:NetworkPartition"/>
-                    </xs:sequence>
-=======
-                    <xs:sequence></xs:sequence>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationPolicy">
+            <xs:element name="AutoscalerServiceInvalidArgumentException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax27:InvalidArgumentException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationPolicyResponse">
+            <xs:element name="updateClusterMonitor">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax216:NetworkPartition"/>
-=======
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="applicationPolicy" nillable="true" type="ax214:ApplicationPolicy"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-                        <xs:element minOccurs="0" name="autoscalingPolicyId" nillable="true" type="xs:string"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:ApplicationPolicy"></xs:element>
->>>>>>> fixing merging issues
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax214:ApplicationPolicy"></xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="undeployApplication">
+            <xs:element name="findClusterId">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getAutoscalingPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalingPolicyId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getAutoscalingPolicyResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getAutoScalingPolicies">
-                <xs:complexType>
-                    <xs:sequence></xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getAutoScalingPoliciesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="removeAutoScalingPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax217:AutoScalerException"/>
-=======
-                        <xs:element minOccurs="0" name="autoscalingPolicyId" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-                        <xs:element minOccurs="0" name="autoscalePolicyId" nillable="true" type="xs:string"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeAutoScalingPolicyResponse">
+            <xs:element name="findClusterIdResponse">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax27:ServiceGroup"/>
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-=======
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-=======
->>>>>>> fixing merging issues
-            <xs:element name="updateAutoScalingPolicy">
+            <xs:element name="serviceGroupExist">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax25:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateAutoScalingPolicyResponse">
+            <xs:element name="serviceGroupExistResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeAutoScalingPolicy">
+            <xs:element name="AutoscalerServiceAutoScalerException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicyId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax27:AutoScalerException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeAutoScalingPolicyResponse">
+            <xs:element name="undeployServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-            <xs:element name="updateAutoScalingPolicy">
+            <xs:element name="AutoscalerServiceApplicationDefinitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax212:ApplicationDefinitionException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateAutoScalingPolicyResponse">
+            <xs:element name="addApplication">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="InvalidPolicyException" nillable="true" type="ax219:InvalidPolicyException"/>
-=======
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
+                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax215:ApplicationContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeAutoScalingPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax29:AutoscalePolicy"/>
-=======
-                        <xs:element minOccurs="0" name="autoscalePolicyId" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-            <xs:element name="AutoscalerServiceInvalidArgumentException">
+            <xs:element name="getApplications">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax216:InvalidArgumentException"></xs:element>
->>>>>>> fixing merging issues
-                    </xs:sequence>
+                    <xs:sequence></xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateClusterMonitor">
+            <xs:element name="getApplicationsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax217:Properties"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax215:ApplicationContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="findClusterId">
+            <xs:element name="deployApplication">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:AutoscalePolicy"/>
-=======
-                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax216:InvalidArgumentException"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
                         <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
->>>>>>> fixing merging issues
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="findClusterIdResponse">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax29:AutoscalePolicy"/>
-=======
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax217:Properties"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax28:Properties"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
->>>>>>> fixing merging issues
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="serviceGroupExist">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="applicationPolicy" nillable="true" type="ax217:ApplicationPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="serviceGroupExistResponse">
+            <xs:element name="deployApplicationResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceAutoScalerException">
+            <xs:element name="getApplicationPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax216:AutoScalerException"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-            <xs:element name="deployApplication">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax215:DeploymentPolicy"/>
-=======
-            <xs:element name="undeployServiceGroup">
+            <xs:element name="getApplicationPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax217:ApplicationPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -656,7 +315,6 @@
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -667,93 +325,59 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deleteApplication">
+            <xs:element name="undeployApplication">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroup">
+            <xs:element name="getAutoscalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax217:InvalidArgumentException"/>
-=======
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
->>>>>>> fixing merging issues
+                        <xs:element minOccurs="0" name="autoscalingPolicyId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="getAutoscalingPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax219:ServiceGroup"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroups">
+            <xs:element name="deleteApplication">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupsResponse">
+            <xs:element name="getApplication">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax27:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addNetworkPartition">
+            <xs:element name="getApplicationResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax216:NetworkPartition"/>
-=======
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax220:ServiceGroup"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-=======
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax220:ServiceGroup"></xs:element>
-=======
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax223:ServiceGroup"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-<<<<<<< HEAD
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-=======
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax220:ServiceGroup"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax220:ServiceGroup"></xs:element>
->>>>>>> fixing merging issues
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax219:ServiceGroup"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:ApplicationContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="AutoscalerServiceInvalidServiceGroupException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax220:InvalidServiceGroupException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax219:InvalidServiceGroupException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="addServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax219:ServiceGroup"></xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
+                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax220:ServiceGroup"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -764,34 +388,20 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplication">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-<<<<<<< HEAD
-            <xs:element name="getApplication">
+            <xs:element name="getServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationResponse">
+            <xs:element name="getServiceGroupResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax220:ServiceGroup"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deleteApplication">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
-=======
             <xs:element name="getServiceGroups">
                 <xs:complexType>
                     <xs:sequence></xs:sequence>
@@ -800,129 +410,29 @@
             <xs:element name="getServiceGroupsResponse">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax220:ServiceGroup"></xs:element>
-<<<<<<< HEAD
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax223:ServiceGroup"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-<<<<<<< HEAD
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-=======
                         <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax220:ServiceGroup"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-            <xs:element name="getApplicationResponse">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax28:ApplicationContext"></xs:element>
->>>>>>> fixing merging issues
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:ApplicationContext"></xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
         </xs:schema>
-<<<<<<< HEAD
-        <xs:schema xmlns:ax214="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd">
-            <xs:import namespace="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
-            <xs:complexType name="DeploymentPolicy">
-                <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="allPartitions" nillable="true" type="ax214:Partition"/>
-                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="applicationLevelNetworkPartitions" nillable="true" type="ax214:NetworkPartition"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="childLevelNetworkPartitions" nillable="true" type="ax214:ChildLevelNetworkPartition"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="childPolicies" nillable="true" type="ax211:ChildPolicy"/>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"/>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-=======
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="ApplicationPolicy">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax213:ApplicationPolicyNetworkPartitionReference"></xs:element>
-<<<<<<< HEAD
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
-=======
-=======
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax211:ApplicationPolicyNetworkPartitionReference"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax29:ApplicationPolicyNetworkPartitionReference"></xs:element>
->>>>>>> fixing merging issues
-=======
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax213:ApplicationPolicyNetworkPartitionReference"></xs:element>
->>>>>>> implementing getApplicationNetworkPartitions web service method, rest API and updating AS wsdl
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax216:ApplicationPolicyNetworkPartitionReference"></xs:element>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ApplicationPolicyNetworkPartitionReference">
                 <xs:sequence>
-<<<<<<< HEAD
-                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="childLevelNetworkPartitions" nillable="true" type="ax214:ChildLevelNetworkPartition"/>
-=======
                     <xs:element minOccurs="0" name="activeByDefault" type="xs:boolean"></xs:element>
                     <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://application.exception.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="ApplicationDefinitionException">
                 <xs:sequence>
-<<<<<<< HEAD
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
-                </xs:sequence>
-            </xs:complexType>
-        </xs:schema>
-        <xs:schema xmlns:ax213="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://network.partition.deployment.policy.pojo.autoscaler.stratos.apache.org/xsd">
-            <xs:import namespace="http://common.stratos.apache.org/xsd"/>
-            <xs:complexType name="Partition">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"/>
-                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax22:Properties"/>
-                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"/>
-                </xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="NetworkPartition">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="activeByDefault" type="xs:boolean"/>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax212:Partition"/>
-                </xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="ChildLevelNetworkPartition">
-                <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="childLevelPartitions" nillable="true" type="ax212:ChildLevelPartition"/>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="min" type="xs:int"/>
-                    <xs:element minOccurs="0" name="partitionAlgo" nillable="true" type="xs:string"/>
-                </xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="ChildLevelPartition">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="max" type="xs:int"/>
-                    <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="partitionId" nillable="true" type="xs:string"/>
-=======
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
->>>>>>> Adding back missing commit 954488432a60f6e80a34a8b5d3f868568d4f8a0c on application policy deployment
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
@@ -936,7 +446,7 @@
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://common.stratos.apache.org/xsd">
             <xs:complexType name="Properties">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax210:Property"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax29:Property"></xs:element>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Property">
@@ -1770,4 +1280,4 @@
             <http:address location="http://172.17.42.1:9763/services/AutoscalerService.AutoscalerServiceHttpEndpoint/"></http:address>
         </wsdl:port>
     </wsdl:service>
-</wsdl:definitions>
+</wsdl:definitions>
\ No newline at end of file


[29/50] [abbrv] stratos git commit: Fixing tomcat cartridge type in tomcat-sso sample application

Posted by re...@apache.org.
Fixing tomcat cartridge type in tomcat-sso sample application


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

Branch: refs/heads/docker-grouping-merge
Commit: 66ea671497125ea43e7f1c62d5b984033dbf3e04
Parents: c9f1ad8
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 01:57:19 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 01:57:19 2015 +0530

----------------------------------------------------------------------
 samples/applications/tomcat-sso/artifacts/application.json | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/66ea6714/samples/applications/tomcat-sso/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application.json b/samples/applications/tomcat-sso/artifacts/application.json
index e4928c8..31e5180 100644
--- a/samples/applications/tomcat-sso/artifacts/application.json
+++ b/samples/applications/tomcat-sso/artifacts/application.json
@@ -5,7 +5,7 @@
 
         "cartridges": [
             {
-                "type": "tomcat",
+                "type": "tomcat-sso",
                 "cartridgeMin": 1,
                 "cartridgeMax": 1,
                 "subscribableInfo": {


[17/50] [abbrv] stratos git commit: Fixing tomcat sample application

Posted by re...@apache.org.
Fixing tomcat sample application


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

Branch: refs/heads/docker-grouping-merge
Commit: c52f74c7c33c422353ab490314afc04a4fe9ca4a
Parents: eb9b873
Author: Imesh Gunaratne <im...@apache.org>
Authored: Fri Feb 27 22:45:44 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Fri Feb 27 22:45:57 2015 +0530

----------------------------------------------------------------------
 .../tomcat/artifacts/application-policy.json    |  8 +++
 .../tomcat/artifacts/application.json           | 39 +++++++-------
 .../tomcat/artifacts/autoscaling-policy.json    | 14 -----
 .../tomcat/artifacts/ec2/deployment-policy.json | 39 --------------
 .../artifacts/kubernetes/deployment-policy.json | 41 --------------
 .../kubernetes/kubernetes-cluster.json          | 56 --------------------
 .../artifacts/mock/deployment-policy.json       | 40 --------------
 .../artifacts/openstack/deployment-policy.json  | 40 --------------
 .../tomcat/scripts/common/deploy.sh             | 14 ++++-
 .../tomcat/scripts/kubernetes/deploy.sh         |  5 +-
 .../kubernetes-cluster-1.json                   | 48 +++++++++++++++++
 .../kubernetes-cluster-1.json                   | 56 --------------------
 .../kubernetes/network-partition-1.json         |  6 +--
 .../kubernetes/network-partition-2.json         |  8 +--
 14 files changed, 98 insertions(+), 316 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/application-policy.json b/samples/applications/tomcat/artifacts/application-policy.json
new file mode 100644
index 0000000..9d2c6a1
--- /dev/null
+++ b/samples/applications/tomcat/artifacts/application-policy.json
@@ -0,0 +1,8 @@
+{
+   "networkPartition":[
+      {
+         "id":"network-partition-1",
+         "activeByDefault":"true"
+      }
+   ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/application.json b/samples/applications/tomcat/artifacts/application.json
index e72a782..91db4ea 100644
--- a/samples/applications/tomcat/artifacts/application.json
+++ b/samples/applications/tomcat/artifacts/application.json
@@ -1,24 +1,25 @@
-{  
-   "applicationId":"tomcat",
-   "alias":"tomcat",
-   "multiTenant":false,
-   "components":{  
-      "cartridges":[  
-         {  
-            "type":"tomcat",
+{
+    "applicationId": "tomcat",
+    "alias": "tomcat",
+    "multiTenant": false,
+    "components": {
+        "cartridges": [
+            {
+                "type": "tomcat",
                 "cartridgeMin": 1,
                 "cartridgeMax": 5,
-				"subscribableInfo":{  
-               	"alias":"tomcat-1",
-               	"autoscalingPolicy":"autoscaling-policy-1",
-                "artifactRepository":{
-                   "privateRepo":false,
-                   "repoUrl":"https://github.com/imesh/stratos-tomcat-applications.git",
-                   "repoUsername":"",
-                   "repoPassword":""
+                "subscribableInfo": {
+                    "alias": "tomcat-1",
+                    "autoscalingPolicy": "autoscaling-policy-1",
+                    "deploymentPolicy": "deployment-policy-1",
+                    "artifactRepository": {
+                        "privateRepo": false,
+                        "repoUrl": "https://github.com/imesh/stratos-tomcat-applications.git",
+                        "repoUsername": "",
+                        "repoPassword": ""
+                    }
                 }
             }
-         }
-      ]
-   }
+        ]
+    }
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/autoscaling-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/autoscaling-policy.json b/samples/applications/tomcat/artifacts/autoscaling-policy.json
deleted file mode 100644
index 9f6a370..0000000
--- a/samples/applications/tomcat/artifacts/autoscaling-policy.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-  "id": "autoscaling-policy-1",
-  "loadThresholds": {
-    "requestsInFlight": {
-      "threshold": 50
-    },
-    "memoryConsumption": {
-      "threshold": 40
-    },
-    "loadAverage": {
-      "threshold": 40
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/ec2/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/ec2/deployment-policy.json b/samples/applications/tomcat/artifacts/ec2/deployment-policy.json
deleted file mode 100644
index e690bbf..0000000
--- a/samples/applications/tomcat/artifacts/ec2/deployment-policy.json
+++ /dev/null
@@ -1,39 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "ec2",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "php1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/kubernetes/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/kubernetes/deployment-policy.json b/samples/applications/tomcat/artifacts/kubernetes/deployment-policy.json
deleted file mode 100644
index 52114de..0000000
--- a/samples/applications/tomcat/artifacts/kubernetes/deployment-policy.json
+++ /dev/null
@@ -1,41 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "kubernetesClusterId": "kubernetes-cluster-1",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "kubernetes",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "tomcat-1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/kubernetes/kubernetes-cluster.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/kubernetes/kubernetes-cluster.json b/samples/applications/tomcat/artifacts/kubernetes/kubernetes-cluster.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/applications/tomcat/artifacts/kubernetes/kubernetes-cluster.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/mock/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/mock/deployment-policy.json b/samples/applications/tomcat/artifacts/mock/deployment-policy.json
deleted file mode 100644
index 0444ea3..0000000
--- a/samples/applications/tomcat/artifacts/mock/deployment-policy.json
+++ /dev/null
@@ -1,40 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "mock",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "php1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/artifacts/openstack/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/artifacts/openstack/deployment-policy.json b/samples/applications/tomcat/artifacts/openstack/deployment-policy.json
deleted file mode 100644
index cf8d9f7..0000000
--- a/samples/applications/tomcat/artifacts/openstack/deployment-policy.json
+++ /dev/null
@@ -1,40 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "openstack",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "RegionOne"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "php1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/scripts/common/deploy.sh b/samples/applications/tomcat/scripts/common/deploy.sh
index a275a38..0b4667b 100755
--- a/samples/applications/tomcat/scripts/common/deploy.sh
+++ b/samples/applications/tomcat/scripts/common/deploy.sh
@@ -11,6 +11,9 @@ artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 iaas_cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
 
 set -e
 
@@ -21,7 +24,14 @@ fi
 
 echo ${artifacts_path}/autoscaling-policy.json
 echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+
+echo "Adding network partitions..."
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+
+echo "Adding deployment policy..."
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding tomcat cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/tomcat.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
@@ -34,4 +44,4 @@ curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/applicat
 sleep 1
 
 echo "Deploying application..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat/deploy
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat/deploy

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/applications/tomcat/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat/scripts/kubernetes/deploy.sh b/samples/applications/tomcat/scripts/kubernetes/deploy.sh
index 32eff3c..d6c47c1 100755
--- a/samples/applications/tomcat/scripts/kubernetes/deploy.sh
+++ b/samples/applications/tomcat/scripts/kubernetes/deploy.sh
@@ -7,9 +7,10 @@ iaas="kubernetes"
 prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 common_folder=`cd "${script_path}/../common"; pwd`
-iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernetes-clusters"; pwd`
+
 
 echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/kubernetes-cluster.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-1.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
 
 bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/kubernetes-clusters/kubernetes-cluster-1.json
----------------------------------------------------------------------
diff --git a/samples/kubernetes-clusters/kubernetes-cluster-1.json b/samples/kubernetes-clusters/kubernetes-cluster-1.json
new file mode 100644
index 0000000..799fbc0
--- /dev/null
+++ b/samples/kubernetes-clusters/kubernetes-cluster-1.json
@@ -0,0 +1,48 @@
+{
+    "clusterId": "kubernetes-cluster-1",
+    "description": "Kubernetes Cluster 1",
+    "kubernetesMaster": {
+        "hostId": "master",
+        "hostname": "master.dev.kubernetes.org",
+        "privateIPAddress": "172.17.8.101",
+        "publicIPAddress": "172.17.8.101",
+        "property": [
+        ]
+    },
+    "portRange": {
+        "upper": "5000",
+        "lower": "4500"
+    },
+    "kubernetesHosts": [
+        {
+            "hostId": "minion-1",
+            "hostname": "minion-1.dev.kubernetes.org",
+            "privateIPAddress": "172.17.8.102",
+            "publicIPAddress": "172.17.8.102",
+            "property": [
+            ]
+        }
+    ],
+    "property": [
+        {
+            "name": "payload_parameter.MB_IP",
+            "value": "172.17.8.1"
+        },
+        {
+            "name": "payload_parameter.MB_PORT",
+            "value": "1883"
+        },
+        {
+            "name": "payload_parameter.CEP_IP",
+            "value": "172.17.8.1"
+        },
+        {
+            "name": "payload_parameter.CEP_PORT",
+            "value": "7711"
+        },
+        {
+            "name": "payload_parameter.LOG_LEVEL",
+            "value": "DEBUG"
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/kubernets-clusters/kubernetes-cluster-1.json
----------------------------------------------------------------------
diff --git a/samples/kubernets-clusters/kubernetes-cluster-1.json b/samples/kubernets-clusters/kubernetes-cluster-1.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/kubernets-clusters/kubernetes-cluster-1.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/network-partitions/kubernetes/network-partition-1.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/kubernetes/network-partition-1.json b/samples/network-partitions/kubernetes/network-partition-1.json
index 2a5b7ec..907ba63 100644
--- a/samples/network-partitions/kubernetes/network-partition-1.json
+++ b/samples/network-partitions/kubernetes/network-partition-1.json
@@ -3,11 +3,11 @@
     "partitions": [
         {
             "id": "partition-1",
-            "provider": "mock",
+            "provider": "kubernetes",
             "property": [
                 {
-                    "name": "region",
-                    "value": "default"
+                    "name": "cluster",
+                    "value": "kubernetes-cluster-1"
                 }
             ]
         }

http://git-wip-us.apache.org/repos/asf/stratos/blob/c52f74c7/samples/network-partitions/kubernetes/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/kubernetes/network-partition-2.json b/samples/network-partitions/kubernetes/network-partition-2.json
index 0d07838..4b6a3d8 100644
--- a/samples/network-partitions/kubernetes/network-partition-2.json
+++ b/samples/network-partitions/kubernetes/network-partition-2.json
@@ -2,12 +2,12 @@
     "id": "network-partition-2",
     "partitions": [
         {
-            "id": "partition-2",
-            "provider": "mock",
+            "id": "partition-1",
+            "provider": "kubernetes",
             "property": [
                 {
-                    "name": "region",
-                    "value": "default"
+                    "name": "cluster",
+                    "value": "kubernetes-cluster-1"
                 }
             ]
         }


[27/50] [abbrv] stratos git commit: Adding tomcat-sso sample application written by udara

Posted by re...@apache.org.
Adding tomcat-sso sample application written by udara


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

Branch: refs/heads/docker-grouping-merge
Commit: 8b9f5fb37ace7280e9781996b60b216eb8f0d2b8
Parents: a854a9c
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 01:48:45 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 01:48:56 2015 +0530

----------------------------------------------------------------------
 .../conf/configurator/JndiConfigurator.java     |  0
 samples/applications/tomcat-sso/README.md       | 18 ++++++
 .../artifacts/application-policy.json           |  8 +++
 .../tomcat-sso/artifacts/application.json       | 38 ++++++++++++
 .../tomcat-sso/scripts/common/deploy.sh         | 49 +++++++++++++++
 .../tomcat-sso/scripts/common/undeploy.sh       | 21 +++++++
 .../tomcat-sso/scripts/ec2/deploy.sh            |  9 +++
 .../tomcat-sso/scripts/ec2/undeploy.sh          |  7 +++
 .../tomcat-sso/scripts/kubernetes/deploy.sh     | 16 +++++
 .../tomcat-sso/scripts/kubernetes/undeploy.sh   | 13 ++++
 .../tomcat-sso/scripts/mock/deploy.sh           |  9 +++
 .../tomcat-sso/scripts/mock/undeploy.sh         |  7 +++
 .../tomcat-sso/scripts/openstack/deploy.sh      |  9 +++
 .../tomcat-sso/scripts/openstack/undeploy.sh    |  7 +++
 samples/cartridges/kubernetes/tomcat-sso.json   | 30 +++++++++
 samples/cartridges/kubernetes/wso2-is.json      | 27 +++++++++
 .../kubernetes-cluster-ec2.json                 | 64 ++++++++++++++++++++
 17 files changed, 332 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/components/org.apache.stratos.load.balancer/src/main/java/org/apache/stratos/load/balancer/conf/configurator/JndiConfigurator.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.load.balancer/src/main/java/org/apache/stratos/load/balancer/conf/configurator/JndiConfigurator.java b/components/org.apache.stratos.load.balancer/src/main/java/org/apache/stratos/load/balancer/conf/configurator/JndiConfigurator.java
deleted file mode 100644
index e69de29..0000000

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/README.md
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/README.md b/samples/applications/tomcat-sso/README.md
new file mode 100644
index 0000000..2faa840
--- /dev/null
+++ b/samples/applications/tomcat-sso/README.md
@@ -0,0 +1,18 @@
+Tomcat Application
+==================
+Tomcat application provides an Apache Tomcat 7 cluster. It has no cartridge groups or any dependencies.
+
+Application folder structure
+----------------------------
+```
+artifacts/<iaas>/ IaaS specific artifacts
+scripts/common/ Common scripts for all iaases
+scripts/<iaas> IaaS specific scripts
+```
+
+How to run
+----------
+```
+cd scripts/<iaas>/
+./deploy.sh
+```
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application-policy.json b/samples/applications/tomcat-sso/artifacts/application-policy.json
new file mode 100644
index 0000000..9d2c6a1
--- /dev/null
+++ b/samples/applications/tomcat-sso/artifacts/application-policy.json
@@ -0,0 +1,8 @@
+{
+   "networkPartition":[
+      {
+         "id":"network-partition-1",
+         "activeByDefault":"true"
+      }
+   ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application.json b/samples/applications/tomcat-sso/artifacts/application.json
new file mode 100644
index 0000000..e4928c8
--- /dev/null
+++ b/samples/applications/tomcat-sso/artifacts/application.json
@@ -0,0 +1,38 @@
+{
+    "applicationId": "tomcat-sso",
+    "alias": "tomcat-sso",
+    "components": {
+
+        "cartridges": [
+            {
+                "type": "tomcat",
+                "cartridgeMin": 1,
+                "cartridgeMax": 1,
+                "subscribableInfo": {
+                    "alias": "mytomcat",
+                    "autoscalingPolicy": "autoscaling-policy-1",
+                    "deploymentPolicy": "deployment-policy-1",
+                    "artifactRepository":{
+                        "privateRepo":false,
+                        "repoUrl":"https://github.com/chamilad/travelocity-sample",
+                        "repoUsername":"",
+                        "repoPassword":""
+                    }
+                }
+            },
+            {
+                "type": "wso2is",
+                "cartridgeMin": 1,
+                "cartridgeMax": 1,
+                "subscribableInfo": {
+                    "alias": "mywso2is",
+                    "autoscalingPolicy": "autoscaling-policy-1",
+                    "deploymentPolicy": "deployment-policy-1"
+                }
+            }
+        ],
+        "dependencies": {
+            "terminationBehaviour": "terminate-none"
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/common/deploy.sh b/samples/applications/tomcat-sso/scripts/common/deploy.sh
new file mode 100755
index 0000000..65d8f4d
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/common/deploy.sh
@@ -0,0 +1,49 @@
+#!/bin/bash
+
+iaas=$1
+host_ip="localhost"
+host_port=9443
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+
+artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
+iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+iaas_cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
+cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
+
+set -e
+
+if [[ -z "${iaas}" ]]; then
+    echo "Usage: deploy.sh [iaas]"
+    exit
+fi
+
+echo ${artifacts_path}/autoscaling-policy.json
+echo "Adding autoscale policy..."
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+
+echo "Adding network partitions..."
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+
+echo "Adding deployment policy..."
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+
+echo "Adding tomcat cartridge..."
+curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/tomcat-sso.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
+
+echo "Adding wso2-is cartridge..."
+curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/wso2-is.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
+
+sleep 1
+
+echo "Creating application..."
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications
+
+sleep 1
+
+echo "Deploying application..."
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat/deploy

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/common/undeploy.sh b/samples/applications/tomcat-sso/scripts/common/undeploy.sh
new file mode 100644
index 0000000..9bff2b0
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/common/undeploy.sh
@@ -0,0 +1,21 @@
+#!/bin/bash
+
+host_ip="localhost"
+host_port=9443
+
+set -e
+
+echo "Undeploying application..."
+curl -X POST -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single-cartridge-app/undeploy
+
+sleep 10
+
+echo "Deleting application..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single-cartridge-app
+
+echo "Removing cartridges..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/tomcat-sso
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/wso2-is
+
+echo "Removing autoscale policies..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/ec2/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/ec2/deploy.sh b/samples/applications/tomcat-sso/scripts/ec2/deploy.sh
new file mode 100755
index 0000000..1370667
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/ec2/deploy.sh
@@ -0,0 +1,9 @@
+#!/bin/bash
+
+iaas="ec2"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh b/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh
new file mode 100644
index 0000000..17d8c71
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh b/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh
new file mode 100755
index 0000000..753af7e
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh
@@ -0,0 +1,16 @@
+#!/bin/bash
+
+host_ip="localhost"
+host_port=9443
+iaas="kubernetes"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernetes-clusters"; pwd`
+
+
+echo "Adding kubernetes cluster..."
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-ec2.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+
+bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh b/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh
new file mode 100755
index 0000000..c450ea0
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh
@@ -0,0 +1,13 @@
+#!/bin/bash
+
+host_ip="localhost"
+host_port=9443
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh
+
+echo "Removing kubernetes cluster..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters/kubernetes-cluster-ec2

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/mock/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/mock/deploy.sh b/samples/applications/tomcat-sso/scripts/mock/deploy.sh
new file mode 100755
index 0000000..93f8517
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/mock/deploy.sh
@@ -0,0 +1,9 @@
+#!/bin/sh
+
+iaas="mock"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/mock/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/mock/undeploy.sh b/samples/applications/tomcat-sso/scripts/mock/undeploy.sh
new file mode 100755
index 0000000..17d8c71
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/mock/undeploy.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/openstack/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/openstack/deploy.sh b/samples/applications/tomcat-sso/scripts/openstack/deploy.sh
new file mode 100755
index 0000000..4c39959
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/openstack/deploy.sh
@@ -0,0 +1,9 @@
+#!/bin/bash
+
+iaas="openstack"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh b/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh
new file mode 100644
index 0000000..17d8c71
--- /dev/null
+++ b/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/cartridges/kubernetes/tomcat-sso.json
----------------------------------------------------------------------
diff --git a/samples/cartridges/kubernetes/tomcat-sso.json b/samples/cartridges/kubernetes/tomcat-sso.json
new file mode 100755
index 0000000..d7e9f30
--- /dev/null
+++ b/samples/cartridges/kubernetes/tomcat-sso.json
@@ -0,0 +1,30 @@
+{
+    "type": "tomcat-sso",
+    "provider": "apache",
+    "host": "tomcat.stratos.org",
+    "category": "data",
+    "displayName": "Tomcat 7",
+    "description": "Tomcat 7 Cartridge",
+    "version": "7",
+    "multiTenant": "false",
+    "portMapping": [
+        {
+            "protocol": "http",
+            "port": "8080",
+            "proxyPort": "8280"
+        }
+    ],
+    "deployment":{
+           "baseDir":"/opt/tomcat/webapps"
+    },
+    "iaasProvider":[
+        {
+            "type":"kubernetes",
+            "imageId":"chamilad/tomcat:4.1.0-beta",
+            "networkInterfaces":[
+            ],
+            "property":[
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/cartridges/kubernetes/wso2-is.json
----------------------------------------------------------------------
diff --git a/samples/cartridges/kubernetes/wso2-is.json b/samples/cartridges/kubernetes/wso2-is.json
new file mode 100644
index 0000000..b2a746e
--- /dev/null
+++ b/samples/cartridges/kubernetes/wso2-is.json
@@ -0,0 +1,27 @@
+{
+    "type": "wso2is",
+    "provider": "data",
+    "host": "wso2is.stratos.org",
+    "category": "data",
+    "displayName": "WSO2 IS 5.0.0",
+    "description": "WSO2 IS 5.0.0 Cartridge",
+    "version": "7",
+    "multiTenant": "false",
+    "portMapping": [
+        {
+            "protocol": "http",
+            "port": "9443",
+            "proxyPort": "8280"
+        }
+    ],
+    "iaasProvider":[
+        {
+            "type":"kubernetes",
+            "imageId":"chamilad/wso2is:4.1.0-beta",
+            "networkInterfaces":[
+            ],
+            "property":[
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/8b9f5fb3/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
----------------------------------------------------------------------
diff --git a/samples/kubernetes-clusters/kubernetes-cluster-ec2.json b/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
new file mode 100644
index 0000000..94cb4bf
--- /dev/null
+++ b/samples/kubernetes-clusters/kubernetes-cluster-ec2.json
@@ -0,0 +1,64 @@
+{
+    "clusterId": "kubernetes-cluster-ec2",
+    "description": "Kubernetes Cluster EC2",
+    "kubernetesMaster": {
+        "hostId": "KubHostMaster1",
+        "hostname": "master.dev.kubernetes.example.org",
+        "privateIPAddress": "10.175.144.104",
+        "publicIPAddress": "54.151.228.48",
+        "property": [
+        ]
+    },
+    "portRange": {
+        "upper": "5000",
+        "lower": "4500"
+    },
+    "kubernetesHosts": [
+        {
+            "hostId": "KubHostSlave1",
+            "hostname": "slave1.dev.kubernetes.example.org",
+            "privateIPAddress": "10.151.10.16",
+            "publicIPAddress": "54.179.64.66",
+            "property": [
+            ]
+        },
+        {
+            "hostId": "KubHostSlave2",
+            "hostname": "slave2.dev.kubernetes.example.org",
+            "privateIPAddress": "10.150.148.75",
+            "publicIPAddress": "54.151.241.37",
+            "property": [
+            ]
+        },
+        {
+            "hostId": "KubHostSlave3",
+            "hostname": "slave2.dev.kubernetes.example.org",
+            "privateIPAddress": "10.148.100.77",
+            "publicIPAddress": "54.179.225.120",
+            "property": [
+            ]
+        }
+    ],
+    "property": [
+        {
+            "name": "payload_parameter.MB_IP",
+            "value": "54.179.197.243"
+        },
+        {
+            "name": "payload_parameter.MB_PORT",
+            "value": "1883"
+        },
+        {
+            "name": "payload_parameter.CEP_IP",
+            "value": "54.179.197.243"
+        },
+        {
+            "name": "payload_parameter.CEP_PORT",
+            "value": "7711"
+        },
+        {
+            "name": "payload_parameter.LOG_LEVEL",
+            "value": "DEBUG"
+        }
+    ]
+}


[37/50] [abbrv] stratos git commit: fixing single-cartridge app

Posted by re...@apache.org.
fixing single-cartridge app


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

Branch: refs/heads/docker-grouping-merge
Commit: d66ee5b1ce5fe7e7333ce222e268429217c9d4c0
Parents: dd8d3d6
Author: R-Rajkumar <rr...@gmail.com>
Authored: Sun Mar 1 18:19:29 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Sun Mar 1 18:19:29 2015 +0530

----------------------------------------------------------------------
 .../single-cartridge/artifacts/application.json |  2 +-
 .../deployment-policy-4.json                    | 29 ++++++++++++++++++++
 2 files changed, 30 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/d66ee5b1/samples/applications/single-cartridge/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/artifacts/application.json b/samples/applications/single-cartridge/artifacts/application.json
index 5babe77..273823e 100644
--- a/samples/applications/single-cartridge/artifacts/application.json
+++ b/samples/applications/single-cartridge/artifacts/application.json
@@ -11,7 +11,7 @@
 		"subscribableInfo":{  
                	"alias":"my-php",
                	"autoscalingPolicy":"autoscaling-policy-1",
-                "deploymentPolicy":"deployment-policy-1",
+                "deploymentPolicy":"deployment-policy-4",
                 "artifactRepository":{
                    "privateRepo":false,
                    "repoUrl":"https://github.com/imesh/stratos-php-applications.git",

http://git-wip-us.apache.org/repos/asf/stratos/blob/d66ee5b1/samples/deployment-policies/deployment-policy-4.json
----------------------------------------------------------------------
diff --git a/samples/deployment-policies/deployment-policy-4.json b/samples/deployment-policies/deployment-policy-4.json
new file mode 100644
index 0000000..aabbac9
--- /dev/null
+++ b/samples/deployment-policies/deployment-policy-4.json
@@ -0,0 +1,29 @@
+{
+   "id": "deployment-policy-4",
+   "networkPartition": [
+      {
+         "id": "network-partition-1",
+         "partitionAlgo": "one-after-another",
+         "partitions": [
+            {
+               "id": "partition-1",
+               "max": 20
+            }
+         ]
+      },
+      {
+         "id": "network-partition-2",
+         "partitionAlgo": "network-partition-1",
+         "partitions": [
+            {
+               "id": "network-partition-2-partition-1",
+               "max": 20
+            },
+            {
+               "id": "network-partition-2-partition-2",
+               "max": 20
+            }
+         ]
+      }
+   ]
+}


[40/50] [abbrv] stratos git commit: updating single-cartridge app sample

Posted by re...@apache.org.
updating single-cartridge app sample


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

Branch: refs/heads/docker-grouping-merge
Commit: bc2e71653c5ab0349efb675161214b878ba207d2
Parents: 5b2571b
Author: R-Rajkumar <rr...@gmail.com>
Authored: Sun Mar 1 18:43:15 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Sun Mar 1 18:43:15 2015 +0530

----------------------------------------------------------------------
 .../single-cartridge/artifacts/application-policy.json           | 4 ----
 samples/applications/single-cartridge/artifacts/application.json | 2 +-
 samples/applications/single-cartridge/scripts/common/deploy.sh   | 2 +-
 samples/applications/single-cartridge/scripts/common/undeploy.sh | 2 +-
 samples/deployment-policies/deployment-policy-1.json             | 2 +-
 5 files changed, 4 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/bc2e7165/samples/applications/single-cartridge/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/artifacts/application-policy.json b/samples/applications/single-cartridge/artifacts/application-policy.json
index 5aa91dd..9d2c6a1 100644
--- a/samples/applications/single-cartridge/artifacts/application-policy.json
+++ b/samples/applications/single-cartridge/artifacts/application-policy.json
@@ -3,10 +3,6 @@
       {
          "id":"network-partition-1",
          "activeByDefault":"true"
-      },
-      {
-         "id":"network-partition-2",
-         "activeByDefault":"false"
       }
    ]
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/bc2e7165/samples/applications/single-cartridge/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/artifacts/application.json b/samples/applications/single-cartridge/artifacts/application.json
index 273823e..5babe77 100644
--- a/samples/applications/single-cartridge/artifacts/application.json
+++ b/samples/applications/single-cartridge/artifacts/application.json
@@ -11,7 +11,7 @@
 		"subscribableInfo":{  
                	"alias":"my-php",
                	"autoscalingPolicy":"autoscaling-policy-1",
-                "deploymentPolicy":"deployment-policy-4",
+                "deploymentPolicy":"deployment-policy-1",
                 "artifactRepository":{
                    "privateRepo":false,
                    "repoUrl":"https://github.com/imesh/stratos-php-applications.git",

http://git-wip-us.apache.org/repos/asf/stratos/blob/bc2e7165/samples/applications/single-cartridge/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/scripts/common/deploy.sh b/samples/applications/single-cartridge/scripts/common/deploy.sh
index 74fd82c..ee56281 100755
--- a/samples/applications/single-cartridge/scripts/common/deploy.sh
+++ b/samples/applications/single-cartridge/scripts/common/deploy.sh
@@ -30,7 +30,7 @@ curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}
 curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-4.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding php cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/php.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges

http://git-wip-us.apache.org/repos/asf/stratos/blob/bc2e7165/samples/applications/single-cartridge/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/scripts/common/undeploy.sh b/samples/applications/single-cartridge/scripts/common/undeploy.sh
index b5781df..65499db 100644
--- a/samples/applications/single-cartridge/scripts/common/undeploy.sh
+++ b/samples/applications/single-cartridge/scripts/common/undeploy.sh
@@ -20,7 +20,7 @@ echo "Removing autoscale policies..."
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
 
 echo "Removing deployment policies..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-4
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-1
 
 echo "Removing network partitions..."
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-1

http://git-wip-us.apache.org/repos/asf/stratos/blob/bc2e7165/samples/deployment-policies/deployment-policy-1.json
----------------------------------------------------------------------
diff --git a/samples/deployment-policies/deployment-policy-1.json b/samples/deployment-policies/deployment-policy-1.json
index 666c299..108d529 100644
--- a/samples/deployment-policies/deployment-policy-1.json
+++ b/samples/deployment-policies/deployment-policy-1.json
@@ -7,7 +7,7 @@
          "partitions": [
             {
                "id": "partition-1",
-               "max": 5
+               "max": 20
             }
          ]
       }


[18/50] [abbrv] stratos git commit: Removing unused kubernetes exceptions in autoscaler

Posted by re...@apache.org.
http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl b/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
index 25d751c..70d79a4 100644
--- a/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
+++ b/service-stubs/org.apache.stratos.autoscaler.service.stub/src/main/resources/AutoscalerService.wsdl
@@ -1,416 +1,414 @@
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://common.stratos.apache.org/xsd" xmlns:ax27="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax25="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax23="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax216="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax218="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax220="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax213="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax211="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns
 :mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
-    <wsdl:documentation>AutoscalerService</wsdl:documentation>
+<?xml version="1.0" encoding="UTF-8"?><wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax25="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax21="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax22="http://common.stratos.apache.org/xsd" xmlns:ax216="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax213="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:ax211="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/
 soap/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
     <wsdl:types>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="AutoscalePolicy">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="displayName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="instanceRoundingFactor" type="xs:float"></xs:element>
-                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="loadThresholds" nillable="true" type="ax23:LoadThresholds"></xs:element>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"></xs:element>
+                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="displayName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="instanceRoundingFactor" type="xs:float"/>
+                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="loadThresholds" nillable="true" type="ax29:LoadThresholds"/>
+                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="LoadThresholds">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="loadAverageThreshold" type="xs:float"></xs:element>
-                    <xs:element minOccurs="0" name="memoryConsumptionThreshold" type="xs:float"></xs:element>
-                    <xs:element minOccurs="0" name="requestsInFlightThreshold" type="xs:float"></xs:element>
+                    <xs:element minOccurs="0" name="loadAverageThreshold" type="xs:float"/>
+                    <xs:element minOccurs="0" name="memoryConsumptionThreshold" type="xs:float"/>
+                    <xs:element minOccurs="0" name="requestsInFlightThreshold" type="xs:float"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax214="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd">
-            <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
+        <xs:schema xmlns:ax23="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd">
+            <xs:import namespace="http://common.stratos.apache.org/xsd"/>
             <xs:complexType name="ApplicationContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="components" nillable="true" type="ax213:ComponentContext"></xs:element>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="multiTenant" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="status" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="tenantAdminUsername" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="tenantDomain" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"></xs:element>
+                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="components" nillable="true" type="ax21:ComponentContext"/>
+                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="multiTenant" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
+                    <xs:element minOccurs="0" name="status" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="tenantAdminUsername" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="tenantDomain" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ComponentContext">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="applicationClusterContexts" nillable="true" type="ax213:ApplicationClusterContext"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax213:CartridgeContext"></xs:element>
-                    <xs:element minOccurs="0" name="dependencyContext" nillable="true" type="ax213:DependencyContext"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax213:GroupContext"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="applicationClusterContexts" nillable="true" type="ax21:ApplicationClusterContext"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax21:CartridgeContext"/>
+                    <xs:element minOccurs="0" name="dependencyContext" nillable="true" type="ax21:DependencyContext"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax21:GroupContext"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ApplicationClusterContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="autoscalePolicyName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyClusterIds" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="textPayload" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="autoscalePolicyName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyClusterIds" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
+                    <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="textPayload" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="CartridgeContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="cartridgeMax" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="cartridgeMin" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="subscribableInfoContext" nillable="true" type="ax213:SubscribableInfoContext"></xs:element>
-                    <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="cartridgeMax" type="xs:int"/>
+                    <xs:element minOccurs="0" name="cartridgeMin" type="xs:int"/>
+                    <xs:element minOccurs="0" name="subscribableInfoContext" nillable="true" type="ax21:SubscribableInfoContext"/>
+                    <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="SubscribableInfoContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="artifactRepositoryContext" nillable="true" type="ax213:ArtifactRepositoryContext"></xs:element>
-                    <xs:element minOccurs="0" name="autoscalingPolicy" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyAliases" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="maxMembers" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="minMembers" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
+                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="artifactRepositoryContext" nillable="true" type="ax21:ArtifactRepositoryContext"/>
+                    <xs:element minOccurs="0" name="autoscalingPolicy" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyAliases" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="maxMembers" type="xs:int"/>
+                    <xs:element minOccurs="0" name="minMembers" type="xs:int"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ArtifactRepositoryContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="privateRepo" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="repoPassword" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="repoUrl" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="repoUsername" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="privateRepo" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="repoPassword" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="repoUrl" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="repoUsername" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="DependencyContext">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="scalingDependents" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrdersContexts" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="terminationBehaviour" nillable="true" type="xs:string"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="scalingDependents" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrdersContexts" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="terminationBehaviour" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="GroupContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax213:CartridgeContext"></xs:element>
-                    <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax213:GroupContext"></xs:element>
-                    <xs:element minOccurs="0" name="groupMaxInstances" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="groupMinInstances" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="groupScalingEnabled" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax21:CartridgeContext"/>
+                    <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax21:GroupContext"/>
+                    <xs:element minOccurs="0" name="groupMaxInstances" type="xs:int"/>
+                    <xs:element minOccurs="0" name="groupMinInstances" type="xs:int"/>
+                    <xs:element minOccurs="0" name="groupScalingEnabled" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="ServiceGroup">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridges" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax220:Dependencies"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax220:ServiceGroup"></xs:element>
-                    <xs:element minOccurs="0" name="groupscalingEnabled" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridges" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax216:Dependencies"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax216:ServiceGroup"/>
+                    <xs:element minOccurs="0" name="groupscalingEnabled" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Dependencies">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="scalingDependants" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="terminationBehaviour" nillable="true" type="xs:string"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="scalingDependants" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="terminationBehaviour" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax215="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax221="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax212="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax28="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://common.stratos.apache.org/xsd" xmlns:ax26="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax219="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
-            <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://policy.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://application.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://pojo.autoscaler.stratos.apache.org/xsd"></xs:import>
-            <xs:element name="getAutoScalingPolicies">
+        <xs:schema xmlns:ax28="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax214="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://common.stratos.apache.org/xsd" xmlns:ax212="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
+            <xs:import namespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://application.exception.autoscaler.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://policy.exception.autoscaler.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://exception.autoscaler.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://common.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://pojo.autoscaler.stratos.apache.org/xsd"/>
+            <xs:element name="getApplications">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getAutoScalingPoliciesResponse">
+            <xs:element name="getApplicationsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceInvalidPolicyException">
+            <xs:element name="AutoscalerServiceApplicationDefinitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPolicyException" nillable="true" type="ax25:InvalidPolicyException"></xs:element>
+                        <xs:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax25:ApplicationDefinitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addAutoScalingPolicy">
+            <xs:element name="addApplication">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax24:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addAutoScalingPolicyResponse">
+            <xs:element name="AutoscalerServiceInvalidPolicyException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidPolicyException" nillable="true" type="ax27:InvalidPolicyException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateAutoScalingPolicy">
+            <xs:element name="addAutoScalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax29:AutoscalePolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateAutoScalingPolicyResponse">
+            <xs:element name="addAutoScalingPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeAutoScalingPolicy">
+            <xs:element name="getAutoScalingPolicies">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalePolicyId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeAutoScalingPolicyResponse">
+            <xs:element name="getAutoScalingPoliciesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:AutoscalePolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceInvalidArgumentException">
+            <xs:element name="updateAutoScalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax27:InvalidArgumentException"></xs:element>
+                        <xs:element minOccurs="0" name="autoscalePolicy" nillable="true" type="ax29:AutoscalePolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateClusterMonitor">
+            <xs:element name="updateAutoScalingPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax29:Properties"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="findClusterId">
+            <xs:element name="removeAutoScalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="autoscalePolicyId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="findClusterIdResponse">
+            <xs:element name="removeAutoScalingPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="serviceGroupExist">
+            <xs:element name="deployApplication">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="applicationPolicy" nillable="true" type="ax212:ApplicationPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="serviceGroupExistResponse">
+            <xs:element name="deployApplicationResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceAutoScalerException">
+            <xs:element name="undeployApplication">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax27:AutoScalerException"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="undeployServiceGroup">
+            <xs:element name="AutoscalerServiceInvalidArgumentException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax214:InvalidArgumentException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceApplicationDefinitionException">
+            <xs:element name="updateClusterMonitor">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax212:ApplicationDefinitionException"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax22:Properties"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addApplication">
+            <xs:element name="AutoscalerServiceInvalidServiceGroupException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax215:ApplicationContext"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax25:InvalidServiceGroupException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplications">
-                <xs:complexType>
-                    <xs:sequence></xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getApplicationsResponse">
+            <xs:element name="addServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax215:ApplicationContext"></xs:element>
+                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax217:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deployApplication">
+            <xs:element name="findClusterId">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="applicationPolicy" nillable="true" type="ax217:ApplicationPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deployApplicationResponse">
+            <xs:element name="findClusterIdResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationPolicy">
+            <xs:element name="AutoscalerServiceAutoScalerException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax214:AutoScalerException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationPolicyResponse">
+            <xs:element name="getApplicationNetworkPartitions">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax217:ApplicationPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationNetworkPartitions">
+            <xs:element name="getApplicationNetworkPartitionsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getApplicationNetworkPartitionsResponse">
+            <xs:element name="undeployServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="undeployApplication">
+            <xs:element name="getServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getAutoscalingPolicy">
+            <xs:element name="getServiceGroupResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="autoscalingPolicyId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax217:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getAutoscalingPolicyResponse">
+            <xs:element name="getAutoscalingPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax23:AutoscalePolicy"></xs:element>
+                        <xs:element minOccurs="0" name="autoscalingPolicyId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="deleteApplication">
+            <xs:element name="getAutoscalingPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:AutoscalePolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="getApplication">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="getApplicationResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:ApplicationContext"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceInvalidServiceGroupException">
+            <xs:element name="getApplicationPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax219:InvalidServiceGroupException"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addServiceGroup">
+            <xs:element name="getApplicationPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax220:ServiceGroup"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax212:ApplicationPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeServiceGroup">
+            <xs:element name="deleteApplication">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="groupName" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroup">
+            <xs:element name="serviceGroupExist">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="serviceGroupExistResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax220:ServiceGroup"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="getServiceGroups">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
             <xs:element name="getServiceGroupsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax220:ServiceGroup"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax217:ServiceGroup"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="removeServiceGroup">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="groupName" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -418,866 +416,855 @@
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="ApplicationPolicy">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax216:ApplicationPolicyNetworkPartitionReference"></xs:element>
+                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionReferences" nillable="true" type="ax211:ApplicationPolicyNetworkPartitionReference"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ApplicationPolicyNetworkPartitionReference">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="activeByDefault" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="activeByDefault" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://application.exception.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="ApplicationDefinitionException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-        </xs:schema>
-        <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://kubernetes.exception.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="InvalidServiceGroupException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://common.stratos.apache.org/xsd">
             <xs:complexType name="Properties">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax29:Property"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax22:Property"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Property">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://policy.exception.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="InvalidPolicyException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://exception.autoscaler.stratos.apache.org/xsd">
             <xs:complexType name="InvalidArgumentException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="AutoScalerException">
                 <xs:complexContent>
                     <xs:extension base="xs:RuntimeException">
-                        <xs:sequence></xs:sequence>
+                        <xs:sequence/>
                     </xs:extension>
                 </xs:complexContent>
             </xs:complexType>
         </xs:schema>
     </wsdl:types>
     <wsdl:message name="removeAutoScalingPolicyRequest">
-        <wsdl:part name="parameters" element="ns:removeAutoScalingPolicy"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:removeAutoScalingPolicy"/>
     </wsdl:message>
     <wsdl:message name="removeAutoScalingPolicyResponse">
-        <wsdl:part name="parameters" element="ns:removeAutoScalingPolicyResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:removeAutoScalingPolicyResponse"/>
     </wsdl:message>
     <wsdl:message name="AutoscalerServiceInvalidPolicyException">
-        <wsdl:part name="parameters" element="ns:AutoscalerServiceInvalidPolicyException"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:AutoscalerServiceInvalidPolicyException"/>
     </wsdl:message>
     <wsdl:message name="getAutoScalingPoliciesRequest">
-        <wsdl:part name="parameters" element="ns:getAutoScalingPolicies"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getAutoScalingPolicies"/>
     </wsdl:message>
     <wsdl:message name="getAutoScalingPoliciesResponse">
-        <wsdl:part name="parameters" element="ns:getAutoScalingPoliciesResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getAutoScalingPoliciesResponse"/>
     </wsdl:message>
     <wsdl:message name="getServiceGroupsRequest">
-        <wsdl:part name="parameters" element="ns:getServiceGroups"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getServiceGroups"/>
     </wsdl:message>
     <wsdl:message name="getServiceGroupsResponse">
-        <wsdl:part name="parameters" element="ns:getServiceGroupsResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getServiceGroupsResponse"/>
     </wsdl:message>
     <wsdl:message name="AutoscalerServiceAutoScalerException">
-        <wsdl:part name="parameters" element="ns:AutoscalerServiceAutoScalerException"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:AutoscalerServiceAutoScalerException"/>
     </wsdl:message>
     <wsdl:message name="getApplicationRequest">
-        <wsdl:part name="parameters" element="ns:getApplication"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplication"/>
     </wsdl:message>
     <wsdl:message name="getApplicationResponse">
-        <wsdl:part name="parameters" element="ns:getApplicationResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplicationResponse"/>
     </wsdl:message>
     <wsdl:message name="deployApplicationRequest">
-        <wsdl:part name="parameters" element="ns:deployApplication"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:deployApplication"/>
     </wsdl:message>
     <wsdl:message name="deployApplicationResponse">
-        <wsdl:part name="parameters" element="ns:deployApplicationResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:deployApplicationResponse"/>
     </wsdl:message>
     <wsdl:message name="AutoscalerServiceApplicationDefinitionException">
-        <wsdl:part name="parameters" element="ns:AutoscalerServiceApplicationDefinitionException"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:AutoscalerServiceApplicationDefinitionException"/>
     </wsdl:message>
     <wsdl:message name="getApplicationNetworkPartitionsRequest">
-        <wsdl:part name="parameters" element="ns:getApplicationNetworkPartitions"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplicationNetworkPartitions"/>
     </wsdl:message>
     <wsdl:message name="getApplicationNetworkPartitionsResponse">
-        <wsdl:part name="parameters" element="ns:getApplicationNetworkPartitionsResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplicationNetworkPartitionsResponse"/>
     </wsdl:message>
     <wsdl:message name="serviceGroupExistRequest">
-        <wsdl:part name="parameters" element="ns:serviceGroupExist"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:serviceGroupExist"/>
     </wsdl:message>
     <wsdl:message name="serviceGroupExistResponse">
-        <wsdl:part name="parameters" element="ns:serviceGroupExistResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:serviceGroupExistResponse"/>
     </wsdl:message>
     <wsdl:message name="addAutoScalingPolicyRequest">
-        <wsdl:part name="parameters" element="ns:addAutoScalingPolicy"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:addAutoScalingPolicy"/>
     </wsdl:message>
     <wsdl:message name="addAutoScalingPolicyResponse">
-        <wsdl:part name="parameters" element="ns:addAutoScalingPolicyResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:addAutoScalingPolicyResponse"/>
     </wsdl:message>
     <wsdl:message name="addServiceGroupRequest">
-        <wsdl:part name="parameters" element="ns:addServiceGroup"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:addServiceGroup"/>
     </wsdl:message>
     <wsdl:message name="AutoscalerServiceInvalidServiceGroupException">
-        <wsdl:part name="parameters" element="ns:AutoscalerServiceInvalidServiceGroupException"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:AutoscalerServiceInvalidServiceGroupException"/>
+    </wsdl:message>
+    <wsdl:message name="deleteApplicationRequest">
+        <wsdl:part name="parameters" element="ns:deleteApplication"/>
     </wsdl:message>
     <wsdl:message name="getServiceGroupRequest">
-        <wsdl:part name="parameters" element="ns:getServiceGroup"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getServiceGroup"/>
     </wsdl:message>
     <wsdl:message name="getServiceGroupResponse">
-        <wsdl:part name="parameters" element="ns:getServiceGroupResponse"></wsdl:part>
-    </wsdl:message>
-    <wsdl:message name="deleteApplicationRequest">
-        <wsdl:part name="parameters" element="ns:deleteApplication"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getServiceGroupResponse"/>
     </wsdl:message>
     <wsdl:message name="undeployServiceGroupRequest">
-        <wsdl:part name="parameters" element="ns:undeployServiceGroup"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:undeployServiceGroup"/>
     </wsdl:message>
     <wsdl:message name="getAutoscalingPolicyRequest">
-        <wsdl:part name="parameters" element="ns:getAutoscalingPolicy"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getAutoscalingPolicy"/>
     </wsdl:message>
     <wsdl:message name="getAutoscalingPolicyResponse">
-        <wsdl:part name="parameters" element="ns:getAutoscalingPolicyResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getAutoscalingPolicyResponse"/>
     </wsdl:message>
     <wsdl:message name="updateAutoScalingPolicyRequest">
-        <wsdl:part name="parameters" element="ns:updateAutoScalingPolicy"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:updateAutoScalingPolicy"/>
     </wsdl:message>
     <wsdl:message name="updateAutoScalingPolicyResponse">
-        <wsdl:part name="parameters" element="ns:updateAutoScalingPolicyResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:updateAutoScalingPolicyResponse"/>
     </wsdl:message>
     <wsdl:message name="findClusterIdRequest">
-        <wsdl:part name="parameters" element="ns:findClusterId"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:findClusterId"/>
     </wsdl:message>
     <wsdl:message name="findClusterIdResponse">
-        <wsdl:part name="parameters" element="ns:findClusterIdResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:findClusterIdResponse"/>
     </wsdl:message>
     <wsdl:message name="getApplicationsRequest">
-        <wsdl:part name="parameters" element="ns:getApplications"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplications"/>
     </wsdl:message>
     <wsdl:message name="getApplicationsResponse">
-        <wsdl:part name="parameters" element="ns:getApplicationsResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplicationsResponse"/>
     </wsdl:message>
     <wsdl:message name="addApplicationRequest">
-        <wsdl:part name="parameters" element="ns:addApplication"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:addApplication"/>
     </wsdl:message>
     <wsdl:message name="updateClusterMonitorRequest">
-        <wsdl:part name="parameters" element="ns:updateClusterMonitor"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:updateClusterMonitor"/>
     </wsdl:message>
     <wsdl:message name="AutoscalerServiceInvalidArgumentException">
-        <wsdl:part name="parameters" element="ns:AutoscalerServiceInvalidArgumentException"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:AutoscalerServiceInvalidArgumentException"/>
     </wsdl:message>
     <wsdl:message name="undeployApplicationRequest">
-        <wsdl:part name="parameters" element="ns:undeployApplication"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:undeployApplication"/>
     </wsdl:message>
     <wsdl:message name="removeServiceGroupRequest">
-        <wsdl:part name="parameters" element="ns:removeServiceGroup"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:removeServiceGroup"/>
     </wsdl:message>
     <wsdl:message name="getApplicationPolicyRequest">
-        <wsdl:part name="parameters" element="ns:getApplicationPolicy"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplicationPolicy"/>
     </wsdl:message>
     <wsdl:message name="getApplicationPolicyResponse">
-        <wsdl:part name="parameters" element="ns:getApplicationPolicyResponse"></wsdl:part>
+        <wsdl:part name="parameters" element="ns:getApplicationPolicyResponse"/>
     </wsdl:message>
     <wsdl:portType name="AutoscalerServicePortType">
         <wsdl:operation name="removeAutoScalingPolicy">
-            <wsdl:input message="ns:removeAutoScalingPolicyRequest" wsaw:Action="urn:removeAutoScalingPolicy"></wsdl:input>
-            <wsdl:output message="ns:removeAutoScalingPolicyResponse" wsaw:Action="urn:removeAutoScalingPolicyResponse"></wsdl:output>
-            <wsdl:fault message="ns:AutoscalerServiceInvalidPolicyException" name="AutoscalerServiceInvalidPolicyException" wsaw:Action="urn:removeAutoScalingPolicyAutoscalerServiceInvalidPolicyException"></wsdl:fault>
+            <wsdl:input message="ns:removeAutoScalingPolicyRequest" wsaw:Action="urn:removeAutoScalingPolicy"/>
+            <wsdl:output message="ns:removeAutoScalingPolicyResponse" wsaw:Action="urn:removeAutoScalingPolicyResponse"/>
+            <wsdl:fault message="ns:AutoscalerServiceInvalidPolicyException" name="AutoscalerServiceInvalidPolicyException" wsaw:Action="urn:removeAutoScalingPolicyAutoscalerServiceInvalidPolicyException"/>
         </wsdl:operation>
         <wsdl:operation name="getAutoScalingPolicies">
-            <wsdl:input message="ns:getAutoScalingPoliciesRequest" wsaw:Action="urn:getAutoScalingPolicies"></wsdl:input>
-            <wsdl:output message="ns:getAutoScalingPoliciesResponse" wsaw:Action="urn:getAutoScalingPoliciesResponse"></wsdl:output>
+            <wsdl:input message="ns:getAutoScalingPoliciesRequest" wsaw:Action="urn:getAutoScalingPolicies"/>
+            <wsdl:output message="ns:getAutoScalingPoliciesResponse" wsaw:Action="urn:getAutoScalingPoliciesResponse"/>
         </wsdl:operation>
         <wsdl:operation name="getServiceGroups">
-            <wsdl:input message="ns:getServiceGroupsRequest" wsaw:Action="urn:getServiceGroups"></wsdl:input>
-            <wsdl:output message="ns:getServiceGroupsResponse" wsaw:Action="urn:getServiceGroupsResponse"></wsdl:output>
-            <wsdl:fault message="ns:AutoscalerServiceAutoScalerException" name="AutoscalerServiceAutoScalerException" wsaw:Action="urn:getServiceGroupsAutoscalerServiceAutoScalerException"></wsdl:fault>
+            <wsdl:input message="ns:getServiceGroupsRequest" wsaw:Action="urn:getServiceGroups"/>
+            <wsdl:output message="ns:getServiceGroupsResponse" wsaw:Action="urn:getServiceGroupsResponse"/>
+            <wsdl:fault message="ns:AutoscalerServiceAutoScalerException" name="AutoscalerServiceAutoScalerException" wsaw:Action="urn:getServiceGroupsAutoscalerServiceAutoScalerException"/>
         </wsdl:operation>
         <wsdl:operation name="getApplication">
-            <wsdl:input message="ns:getApplicationRequest" wsaw:Action="urn:getApplication"></wsdl:input>
-            <wsdl:output message="ns:getApplicationResponse" wsaw:Action="urn:getApplicationResponse"></wsdl:output>
+            <wsdl:input message="ns:getApplicationRequest" wsaw:Action="urn:getApplication"/>
+            <wsdl:output message="ns:getApplicationResponse" wsaw:Action="urn:getApplicationResponse"/>
         </wsdl:operation>
         <wsdl:operation name="deployApplication">
-            <wsdl:input message="ns:deployApplicationRequest" wsaw:Action="urn:deployApplication"></wsdl:input>
-            <wsdl:output message="ns:deployApplicationResponse" wsaw:Action="urn:deployApplicationResponse"></wsdl:output>
-            <wsdl:fault message="ns:AutoscalerServiceApplicationDefinitionException" name="AutoscalerServiceApplicationDefinitionException" wsaw:Action="urn:deployApplicationAutoscalerServiceApplicationDefinitionException"></wsdl:fault>
+            <wsdl:input message="ns:deployApplicationRequest" wsaw:Action="urn:deployApplication"/>
+            <wsdl:output message="ns:deployApplicationResponse" wsaw:Action="urn:deployApplicationResponse"/>
+            <wsdl:fault message="ns:AutoscalerServiceApplicationDefinitionException" name="AutoscalerServiceApplicationDefinitionException" wsaw:Action="urn:deployApplicationAutoscalerServiceApplicationDefinitionException"/>
         </wsdl:operation>
         <wsdl:operation name="getApplicationNetworkPartitions">
-            <wsdl:input message="ns:getApplicationNetworkPartitionsRequest" wsaw:Action="urn:getApplicationNetworkPartitions"></wsdl:input>
-            <wsdl:output message="ns:getApplicationNetworkPartitionsResponse" wsaw:Action="urn:getApplicationNetworkPartitionsResponse"></wsdl:output>
-            <wsdl:fault message="ns:AutoscalerServiceAutoScalerException" name="AutoscalerServiceAutoScalerException" wsaw:Action="urn:getApplicationNetworkPartitionsAutoscalerServiceAutoScalerException"></wsdl:fault>
+            <wsdl:input message="ns:getApplicationNetworkPartitionsRequest" wsaw:Action="urn:getApplicationNetworkPartitions"/>
+            <wsdl:output message="ns:getApplicationNetworkPartitionsResponse" wsaw:Action="urn:getApplicationNetworkPartitionsResponse"/>
+            <wsdl:fault message="ns:AutoscalerServiceAutoScalerException" name="AutoscalerServiceAutoScalerException" wsaw:Action="urn:getApplicationNetworkPartitionsAutoscalerServiceAutoScalerException"/>
         </wsdl:operation>
         <wsdl:operation name="serviceGroupExist">
-            <wsdl:input message="ns:serviceGroupExistRequest" wsaw:Action="urn:serviceGroupExist"></wsdl:input>
-            <wsdl:output message="ns:serviceGroupExistResponse" wsaw:Action="urn:serviceGroupExistResponse"></wsdl:output>
+            <wsdl:input message="ns:serviceGroupExistRequest" wsaw:Action="urn:serviceGroupExist"/>
+            <wsdl:output message="ns:serviceGroupExistResponse" wsaw:Action="urn:serviceGroupExistResponse"/>
         </wsdl:operation>
         <wsdl:operation name="addAutoScalingPolicy">
-            <wsdl:input message="ns:addAutoScalingPolicyRequest" wsaw:Action="urn:addAutoScalingPolicy"></wsdl:input>
-            <wsdl:output message="ns:addAutoScalingPolicyResponse" wsaw:Action="urn:addAutoScalingPolicyResponse"></wsdl:output>
-            <wsdl:fault message="ns:AutoscalerServiceInvalidPolicyException" name="AutoscalerServiceInvalidPolicyException" wsaw:Action="urn:addAutoScalingPolicyAutoscalerServiceInvalidPolicyException"></wsdl:fault>
+            <wsdl:input message="ns:addAutoScalingPolicyRequest" wsaw:Action="urn:addAutoScalingPolicy"/>
+            <wsdl:output message="ns:addAutoScalingPolicyResponse" wsaw:Action="urn:addAutoScalingPolicyResponse"/>
+            <wsdl:fault message="ns:AutoscalerServiceInvalidPolicyException" name="AutoscalerServiceInvalidPolicyException" wsaw:Action="urn:addAutoScalingPolicyAutoscalerServiceInvalidPolicyException"/>
         </wsdl:operation>
         <wsdl:operation name="addServiceGroup">
-            <wsdl:input message="ns:addServiceGroupRequest" wsaw:Action="urn:addServiceGroup"></wsdl:input>
-            <wsdl:fault message="ns:AutoscalerServiceInvalidServiceGroupException" name="AutoscalerServiceInvalidServiceGroupException" wsaw:Action="urn:addServiceGroupAutoscalerServiceInvalidServiceGroupException"></wsdl:fault>
-        </wsdl:operation>
-        <wsdl:operation name="getServiceGroup">
-            <wsdl:input message="ns:getServiceGroupRequest" wsaw:Action="urn:getServiceGroup"></wsdl:input>
-            <wsdl:output message="ns:getServiceGroupResponse" wsaw:Action="urn:getServiceGroupResponse"></wsdl:output>
+            <wsdl:input message="ns:addServiceGroupRequest" wsaw:Action="urn:addServiceGroup"/>
+            <wsdl:fault message="ns:AutoscalerServiceInvalidServiceGroupException" name="AutoscalerServiceInvalidServiceGroupException" wsaw:Action="urn:addServiceGroupAutoscalerServiceInvalidServiceGroupException"/>
         </wsdl:operation>
         <wsdl:operation name="deleteApplication">
-            <wsdl:input message="ns:deleteApplicationRequest" wsaw:Action="urn:deleteApplication"></wsdl:input>
+            <wsdl:input message="ns:deleteApplicationRequest" wsaw:Action="urn:deleteApplication"/>
+        </wsdl:operation>
+        <wsdl:operation name="getServiceGroup">
+            <wsdl:input message="ns:getServiceGroupRequest" wsaw:Action="urn:getServiceGroup"/>
+            <wsdl:output message="ns:getServiceGroupResponse" wsaw:Action="urn:getServiceGroupResponse"/>
         </wsdl:operation>
         <wsdl:operation name="undeployServiceGroup">
-            <wsdl:input message="ns:undeployServiceGroupRequest" wsaw:Action="urn:undeployServiceGroup"></wsdl:input>
-            <wsdl:fault message="ns:AutoscalerServiceAutoScalerException" name="AutoscalerServiceAutoScalerException" wsaw:Action="urn:undeployServiceGroupAutoscalerServiceAutoScalerException"></wsdl:fault>
+            <wsdl:input message="ns:undeployServiceGroupRequest" wsaw:Action="urn:undeployServiceGroup"/>
+            <wsdl:fault message="ns:AutoscalerServiceAutoScalerException" name="AutoscalerServiceAutoScalerException" wsaw:Action="urn:undeployServiceGroupAutoscalerServiceAutoScalerException"/>
         </wsdl:operation>
         <wsdl:operation name="getAutoscalingPolicy">
-            <wsdl:input message="ns:getAutoscalingPolicyRequest" wsaw:Action="urn:getAutoscalingPolicy"></wsdl:input>
-            <wsdl:output message="ns:getAutoscalingPolicyResponse" wsaw:Action="urn:getAutoscalingPolicyResponse"></wsdl:output>
+            <wsdl:input message="ns:getAutoscalingPolicyRequest" wsaw:Action="urn:getAutoscalingPolicy"/>
+            <wsdl:output message="ns:getAutoscalingPolicyResponse" wsaw:Action="urn:getAutoscalingPolicyResponse"/>
         </wsdl:operation>
         <wsdl:operation name="updateAutoScalingPolicy">
-            <wsdl:input message="ns:updateAutoScalingPolicyRequest" wsaw:Action="urn:updateAutoScalingPolicy"></wsdl:input>
-            <wsdl:output message="ns:updateAutoScalingPolicyResponse" wsaw:Action="urn:updateAutoScalingPolicyResponse"></wsdl:output>
-            <wsdl:fault message="ns:AutoscalerServiceInvalidPolicyException" name="AutoscalerServiceInvalidPolicyException" wsaw:Action="urn:updateAutoScalingPolicyAutoscalerServiceInvalidPolicyException"></wsdl:fault>
+            <wsdl:input message="ns:updateAutoScalingPolicyRequest" wsaw:Action="urn:updateAutoScalingPolicy"/>
+            <wsdl:output message="ns:updateAutoScalingPolicyResponse" wsaw:Action="urn:updateAutoScalingPolicyResponse"/>
+            <wsdl:fault message="ns:AutoscalerServiceInvalidPolicyException" name="AutoscalerServiceInvalidPolicyException" wsaw:Action="urn:updateAutoScalingPolicyAutoscalerServiceInvalidPolicyException"/>
         </wsdl:operation>
         <wsdl:operation name="findClusterId">
-            <wsdl:input message="ns:findClusterIdRequest" wsaw:Action="urn:findClusterId"></wsdl:input>
-            <wsdl:output message="ns:findClusterIdResponse" wsaw:Action="urn:findClusterIdResponse"></wsdl:output>
+            <wsdl:input message="ns:findClusterIdRequest" wsaw:Action="urn:findClusterId"/>
+            <wsdl:output message="ns:findClusterIdResponse" wsaw:Action="urn:findClusterIdResponse"/>
         </wsdl:operation>
         <wsdl:operation name="getApplications">
-            <wsdl:input message="ns:getApplicationsRequest" wsaw:Action="urn:getApplications"></wsdl:input>
-            <wsdl:output message="ns:getApplicationsResponse" wsaw:Action="urn:getApplicationsResponse"></wsdl:output>
+            <wsdl:input message="ns:getApplicationsRequest" wsaw:Action="urn:getApplications"/>
+            <wsdl:output message="ns:getApplicationsResponse" wsaw:Action="urn:getApplicationsResponse"/>
         </wsdl:operation>
         <wsdl:operation name="addApplication">
-            <wsdl:input message="ns:addApplicationRequest" wsaw:Action="urn:addApplication"></wsdl:input>
-            <wsdl:fault message="ns:AutoscalerServiceApplicationDefinitionException" name="AutoscalerServiceApplicationDefinitionException" wsaw:Action="urn:addApplicationAutoscalerServiceApplicationDefinitionException"></wsdl:fault>
+            <wsdl:input message="ns:addApplicationRequest" wsaw:Action="urn:addApplication"/>
+            <wsdl:fault message="ns:AutoscalerServiceApplicationDefinitionException" name="AutoscalerServiceApplicationDefinitionException" wsaw:Action="urn:addApplicationAutoscalerServiceApplicationDefinitionException"/>
         </wsdl:operation>
         <wsdl:operation name="updateClusterMonitor">
-            <wsdl:input message="ns:updateClusterMonitorRequest" wsaw:Action="urn:updateClusterMonitor"></wsdl:input>
-            <wsdl:fault message="ns:AutoscalerServiceInvalidArgumentException" name="AutoscalerServiceInvalidArgumentException" wsaw:Action="urn:updateClusterMonitorAutoscalerServiceInvalidArgumentException"></wsdl:fault>
+            <wsdl:input message="ns:updateClusterMonitorRequest" wsaw:Action="urn:updateClusterMonitor"/>
+            <wsdl:fault message="ns:AutoscalerServiceInvalidArgumentException" name="AutoscalerServiceInvalidArgumentException" wsaw:Action="urn:updateClusterMonitorAutoscalerServiceInvalidArgumentException"/>
         </wsdl:operation>
         <wsdl:operation name="undeployApplication">
-            <wsdl:input message="ns:undeployApplicationRequest" wsaw:Action="urn:undeployApplication"></wsdl:input>
+            <wsdl:input message="ns:undeployApplicationRequest" wsaw:Action="urn:undeployApplication"/>
         </wsdl:operation>
         <wsdl:operation name="removeServiceGroup">
-            <wsdl:input message="ns:removeServiceGroupRequest" wsaw:Action="urn:removeServiceGroup"></wsdl:input>
+            <wsdl:input message="ns:removeServiceGroupRequest" wsaw:Action="urn:removeServiceGroup"/>
         </wsdl:operation>
         <wsdl:operation name="getApplicationPolicy">
-            <wsdl:input message="ns:getApplicationPolicyRequest" wsaw:Action="urn:getApplicationPolicy"></wsdl:input>
-            <wsdl:output message="ns:getApplicationPolicyResponse" wsaw:Action="urn:getApplicationPolicyResponse"></wsdl:output>
+            <wsdl:input message="ns:getApplicationPolicyRequest" wsaw:Action="urn:getApplicationPolicy"/>
+            <wsdl:output message="ns:getApplicationPolicyResponse" wsaw:Action="urn:getApplicationPolicyResponse"/>
         </wsdl:operation>
     </wsdl:portType>
     <wsdl:binding name="AutoscalerServiceSoap11Binding" type="ns:AutoscalerServicePortType">
-        <soap:binding transport="http://schemas.xmlsoap.org/soap/http" style="document"></soap:binding>
+        <soap:binding transport="http://schemas.xmlsoap.org/soap/http" style="document"/>
         <wsdl:operation name="getAutoScalingPolicies">
-            <soap:operation soapAction="urn:getAutoScalingPolicies" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getAutoScalingPolicies" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
         <wsdl:operation name="removeAutoScalingPolicy">
-            <soap:operation soapAction="urn:removeAutoScalingPolicy" style="document"></soap:operation>
+            <soap:operation soapAction="urn:removeAutoScalingPolicy" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
             <wsdl:fault name="AutoscalerServiceInvalidPolicyException">
-                <soap:fault use="literal" name="AutoscalerServiceInvalidPolicyException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceInvalidPolicyException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="getServiceGroups">
-            <soap:operation soapAction="urn:getServiceGroups" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getServiceGroups" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
             <wsdl:fault name="AutoscalerServiceAutoScalerException">
-                <soap:fault use="literal" name="AutoscalerServiceAutoScalerException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceAutoScalerException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="getApplication">
-            <soap:operation soapAction="urn:getApplication" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getApplication" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
         <wsdl:operation name="deployApplication">
-            <soap:operation soapAction="urn:deployApplication" style="document"></soap:operation>
+            <soap:operation soapAction="urn:deployApplication" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
             <wsdl:fault name="AutoscalerServiceApplicationDefinitionException">
-                <soap:fault use="literal" name="AutoscalerServiceApplicationDefinitionException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceApplicationDefinitionException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="getApplicationNetworkPartitions">
-            <soap:operation soapAction="urn:getApplicationNetworkPartitions" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getApplicationNetworkPartitions" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
             <wsdl:fault name="AutoscalerServiceAutoScalerException">
-                <soap:fault use="literal" name="AutoscalerServiceAutoScalerException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceAutoScalerException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="serviceGroupExist">
-            <soap:operation soapAction="urn:serviceGroupExist" style="document"></soap:operation>
+            <soap:operation soapAction="urn:serviceGroupExist" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
         <wsdl:operation name="addAutoScalingPolicy">
-            <soap:operation soapAction="urn:addAutoScalingPolicy" style="document"></soap:operation>
+            <soap:operation soapAction="urn:addAutoScalingPolicy" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
             <wsdl:fault name="AutoscalerServiceInvalidPolicyException">
-                <soap:fault use="literal" name="AutoscalerServiceInvalidPolicyException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceInvalidPolicyException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="addServiceGroup">
-            <soap:operation soapAction="urn:addServiceGroup" style="document"></soap:operation>
+            <soap:operation soapAction="urn:addServiceGroup" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:fault name="AutoscalerServiceInvalidServiceGroupException">
-                <soap:fault use="literal" name="AutoscalerServiceInvalidServiceGroupException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceInvalidServiceGroupException"/>
             </wsdl:fault>
         </wsdl:operation>
-        <wsdl:operation name="deleteApplication">
-            <soap:operation soapAction="urn:deleteApplication" style="document"></soap:operation>
-            <wsdl:input>
-                <soap:body use="literal"></soap:body>
-            </wsdl:input>
-        </wsdl:operation>
         <wsdl:operation name="getServiceGroup">
-            <soap:operation soapAction="urn:getServiceGroup" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getServiceGroup" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
+        <wsdl:operation name="deleteApplication">
+            <soap:operation soapAction="urn:deleteApplication" style="document"/>
+            <wsdl:input>
+                <soap:body use="literal"/>
+            </wsdl:input>
+        </wsdl:operation>
         <wsdl:operation name="undeployServiceGroup">
-            <soap:operation soapAction="urn:undeployServiceGroup" style="document"></soap:operation>
+            <soap:operation soapAction="urn:undeployServiceGroup" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:fault name="AutoscalerServiceAutoScalerException">
-                <soap:fault use="literal" name="AutoscalerServiceAutoScalerException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceAutoScalerException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="getAutoscalingPolicy">
-            <soap:operation soapAction="urn:getAutoscalingPolicy" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getAutoscalingPolicy" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
         <wsdl:operation name="updateAutoScalingPolicy">
-            <soap:operation soapAction="urn:updateAutoScalingPolicy" style="document"></soap:operation>
+            <soap:operation soapAction="urn:updateAutoScalingPolicy" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
             <wsdl:fault name="AutoscalerServiceInvalidPolicyException">
-                <soap:fault use="literal" name="AutoscalerServiceInvalidPolicyException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceInvalidPolicyException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="findClusterId">
-            <soap:operation soapAction="urn:findClusterId" style="document"></soap:operation>
+            <soap:operation soapAction="urn:findClusterId" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
         <wsdl:operation name="getApplications">
-            <soap:operation soapAction="urn:getApplications" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getApplications" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
         <wsdl:operation name="addApplication">
-            <soap:operation soapAction="urn:addApplication" style="document"></soap:operation>
+            <soap:operation soapAction="urn:addApplication" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:fault name="AutoscalerServiceApplicationDefinitionException">
-                <soap:fault use="literal" name="AutoscalerServiceApplicationDefinitionException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceApplicationDefinitionException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="updateClusterMonitor">
-            <soap:operation soapAction="urn:updateClusterMonitor" style="document"></soap:operation>
+            <soap:operation soapAction="urn:updateClusterMonitor" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:fault name="AutoscalerServiceInvalidArgumentException">
-                <soap:fault use="literal" name="AutoscalerServiceInvalidArgumentException"></soap:fault>
+                <soap:fault use="literal" name="AutoscalerServiceInvalidArgumentException"/>
             </wsdl:fault>
         </wsdl:operation>
         <wsdl:operation name="undeployApplication">
-            <soap:operation soapAction="urn:undeployApplication" style="document"></soap:operation>
+            <soap:operation soapAction="urn:undeployApplication" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
         </wsdl:operation>
         <wsdl:operation name="removeServiceGroup">
-            <soap:operation soapAction="urn:removeServiceGroup" style="document"></soap:operation>
+            <soap:operation soapAction="urn:removeServiceGroup" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
         </wsdl:operation>
         <wsdl:operation name="getApplicationPolicy">
-            <soap:operation soapAction="urn:getApplicationPolicy" style="document"></soap:operation>
+            <soap:operation soapAction="urn:getApplicationPolicy" style="document"/>
             <wsdl:input>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:input>
             <wsdl:output>
-                <soap:body use="literal"></soap:body>
+                <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
     </wsdl:binding>
     <wsdl:binding name="AutoscalerServiceSoap12Binding" type="ns:AutoscalerServicePortType">
-        <soap12:binding transport="http://schemas.xmlsoap.org/soap/http" style="document"></soap12:binding>
+        <soap12:binding transport="http://schemas.xmlsoap.org/soap/http" s

<TRUNCATED>

[25/50] [abbrv] stratos git commit: changing a'mq port to 61617 in messaging component tests

Posted by re...@apache.org.
changing a'mq port to 61617 in messaging component tests


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

Branch: refs/heads/docker-grouping-merge
Commit: d58cc946df6685c2d8e864d4556a1295e58343cb
Parents: cc92e5d
Author: R-Rajkumar <rr...@gmail.com>
Authored: Sat Feb 28 17:28:04 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Sat Feb 28 17:28:04 2015 +0530

----------------------------------------------------------------------
 .../java/org/apache/stratos/messaging/test/AmqpSubscriberTest.java | 2 +-
 .../src/test/resources/jndi.properties                             | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/d58cc946/components/org.apache.stratos.messaging/src/test/java/org/apache/stratos/messaging/test/AmqpSubscriberTest.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/test/java/org/apache/stratos/messaging/test/AmqpSubscriberTest.java b/components/org.apache.stratos.messaging/src/test/java/org/apache/stratos/messaging/test/AmqpSubscriberTest.java
index e5c27d1..3f69b9f 100644
--- a/components/org.apache.stratos.messaging/src/test/java/org/apache/stratos/messaging/test/AmqpSubscriberTest.java
+++ b/components/org.apache.stratos.messaging/src/test/java/org/apache/stratos/messaging/test/AmqpSubscriberTest.java
@@ -64,7 +64,7 @@ public class AmqpSubscriberTest {
             log.info("Initializing ActiveMQ...");
             broker = new BrokerService();
             broker.setBrokerName("testBroker");
-            broker.addConnector("tcp://localhost:61616");
+            broker.addConnector("tcp://localhost:61617");
         } catch (Exception e) {
             throw new RuntimeException("Could not initialize ActiveMQ", e);
         }

http://git-wip-us.apache.org/repos/asf/stratos/blob/d58cc946/components/org.apache.stratos.messaging/src/test/resources/jndi.properties
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/test/resources/jndi.properties b/components/org.apache.stratos.messaging/src/test/resources/jndi.properties
index 21d7420..beefe3c 100644
--- a/components/org.apache.stratos.messaging/src/test/resources/jndi.properties
+++ b/components/org.apache.stratos.messaging/src/test/resources/jndi.properties
@@ -18,5 +18,5 @@
 #
 
 connectionfactoryName=TopicConnectionFactory
-java.naming.provider.url=tcp://localhost:61616
+java.naming.provider.url=tcp://localhost:61617
 java.naming.factory.initial=org.apache.activemq.jndi.ActiveMQInitialContextFactory


[28/50] [abbrv] stratos git commit: Fixing deployment policy in tomcat-sso sample application

Posted by re...@apache.org.
Fixing deployment policy in tomcat-sso sample application


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

Branch: refs/heads/docker-grouping-merge
Commit: c9f1ad8f873e8610ebe24a80391c3415680fe3f4
Parents: 8b9f5fb
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 01:53:12 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 01:53:12 2015 +0530

----------------------------------------------------------------------
 .../applications/tomcat-sso/scripts/common/deploy.sh |  4 ++--
 samples/deployment-policies/deployment-policy-3.json | 15 +++++++++++++++
 .../kubernetes/network-partition-3.json              | 15 +++++++++++++++
 3 files changed, 32 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/c9f1ad8f/samples/applications/tomcat-sso/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/common/deploy.sh b/samples/applications/tomcat-sso/scripts/common/deploy.sh
index 65d8f4d..a20554a 100755
--- a/samples/applications/tomcat-sso/scripts/common/deploy.sh
+++ b/samples/applications/tomcat-sso/scripts/common/deploy.sh
@@ -27,10 +27,10 @@ echo "Adding autoscale policy..."
 curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
 
 echo "Adding network partitions..."
-curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-3.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-3.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding tomcat cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/tomcat-sso.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges

http://git-wip-us.apache.org/repos/asf/stratos/blob/c9f1ad8f/samples/deployment-policies/deployment-policy-3.json
----------------------------------------------------------------------
diff --git a/samples/deployment-policies/deployment-policy-3.json b/samples/deployment-policies/deployment-policy-3.json
new file mode 100644
index 0000000..1a4f2a2
--- /dev/null
+++ b/samples/deployment-policies/deployment-policy-3.json
@@ -0,0 +1,15 @@
+{
+   "id": "deployment-policy-3",
+   "networkPartition": [
+      {
+         "id": "network-partition-3",
+         "partitionAlgo": "one-after-another",
+         "partitions": [
+            {
+               "id": "partition-1",
+               "max": 5
+            }
+         ]
+      }
+   ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/c9f1ad8f/samples/network-partitions/kubernetes/network-partition-3.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/kubernetes/network-partition-3.json b/samples/network-partitions/kubernetes/network-partition-3.json
new file mode 100644
index 0000000..dd3874f
--- /dev/null
+++ b/samples/network-partitions/kubernetes/network-partition-3.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-3",
+    "partitions": [
+        {
+            "id": "partition-1",
+            "provider": "kubernetes",
+            "property": [
+                {
+                    "name": "cluster",
+                    "value": "kubernetes-cluster-ec2"
+                }
+            ]
+        }
+    ]
+}


[32/50] [abbrv] stratos git commit: Fixing deployment policy in tomcat-sso sample application

Posted by re...@apache.org.
Fixing deployment policy in tomcat-sso sample application


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

Branch: refs/heads/docker-grouping-merge
Commit: f7a397edea38bfd17eb0820baf7f0dc82d62cb65
Parents: 4124be8
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 02:13:40 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 02:13:40 2015 +0530

----------------------------------------------------------------------
 samples/applications/tomcat-sso/artifacts/application.json | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/f7a397ed/samples/applications/tomcat-sso/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application.json b/samples/applications/tomcat-sso/artifacts/application.json
index 31e5180..7106a4f 100644
--- a/samples/applications/tomcat-sso/artifacts/application.json
+++ b/samples/applications/tomcat-sso/artifacts/application.json
@@ -11,7 +11,7 @@
                 "subscribableInfo": {
                     "alias": "mytomcat",
                     "autoscalingPolicy": "autoscaling-policy-1",
-                    "deploymentPolicy": "deployment-policy-1",
+                    "deploymentPolicy": "deployment-policy-3",
                     "artifactRepository":{
                         "privateRepo":false,
                         "repoUrl":"https://github.com/chamilad/travelocity-sample",
@@ -27,7 +27,7 @@
                 "subscribableInfo": {
                     "alias": "mywso2is",
                     "autoscalingPolicy": "autoscaling-policy-1",
-                    "deploymentPolicy": "deployment-policy-1"
+                    "deploymentPolicy": "deployment-policy-3"
                 }
             }
         ],


[33/50] [abbrv] stratos git commit: Renaming tomcat-sso sample application to tomcat-single-signon and adding mock artifacts

Posted by re...@apache.org.
Renaming tomcat-sso sample application to tomcat-single-signon and adding mock artifacts


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

Branch: refs/heads/docker-grouping-merge
Commit: 42c0baea9f8134e317f44ce28bfc37bb032b749f
Parents: f7a397e
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 10:48:39 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 10:48:39 2015 +0530

----------------------------------------------------------------------
 .../applications/tomcat-single-signon/README.md | 18 +++++++
 .../artifacts/application-policy.json           |  8 ++++
 .../artifacts/application.json                  | 38 +++++++++++++++
 .../scripts/common/deploy.sh                    | 48 +++++++++++++++++++
 .../scripts/common/undeploy.sh                  | 21 +++++++++
 .../tomcat-single-signon/scripts/ec2/deploy.sh  |  9 ++++
 .../scripts/ec2/undeploy.sh                     |  7 +++
 .../scripts/kubernetes/deploy.sh                | 16 +++++++
 .../scripts/kubernetes/undeploy.sh              | 13 ++++++
 .../tomcat-single-signon/scripts/mock/deploy.sh |  9 ++++
 .../scripts/mock/undeploy.sh                    |  7 +++
 .../scripts/openstack/deploy.sh                 |  9 ++++
 .../scripts/openstack/undeploy.sh               |  7 +++
 samples/applications/tomcat-sso/README.md       | 18 -------
 .../artifacts/application-policy.json           |  8 ----
 .../tomcat-sso/artifacts/application.json       | 38 ---------------
 .../tomcat-sso/scripts/common/deploy.sh         | 49 --------------------
 .../tomcat-sso/scripts/common/undeploy.sh       | 21 ---------
 .../tomcat-sso/scripts/ec2/deploy.sh            |  9 ----
 .../tomcat-sso/scripts/ec2/undeploy.sh          |  7 ---
 .../tomcat-sso/scripts/kubernetes/deploy.sh     | 16 -------
 .../tomcat-sso/scripts/kubernetes/undeploy.sh   | 13 ------
 .../tomcat-sso/scripts/mock/deploy.sh           |  9 ----
 .../tomcat-sso/scripts/mock/undeploy.sh         |  7 ---
 .../tomcat-sso/scripts/openstack/deploy.sh      |  9 ----
 .../tomcat-sso/scripts/openstack/undeploy.sh    |  7 ---
 samples/cartridges/kubernetes/tomcat-sso.json   | 30 ------------
 samples/cartridges/kubernetes/tomcat3.json      | 30 ++++++++++++
 samples/cartridges/mock/tomcat3.json            | 30 ++++++++++++
 samples/cartridges/mock/wso2-is.json            | 27 +++++++++++
 .../mock/network-partition-3.json               | 15 ++++++
 31 files changed, 312 insertions(+), 241 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/README.md
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/README.md b/samples/applications/tomcat-single-signon/README.md
new file mode 100644
index 0000000..2faa840
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/README.md
@@ -0,0 +1,18 @@
+Tomcat Application
+==================
+Tomcat application provides an Apache Tomcat 7 cluster. It has no cartridge groups or any dependencies.
+
+Application folder structure
+----------------------------
+```
+artifacts/<iaas>/ IaaS specific artifacts
+scripts/common/ Common scripts for all iaases
+scripts/<iaas> IaaS specific scripts
+```
+
+How to run
+----------
+```
+cd scripts/<iaas>/
+./deploy.sh
+```
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/artifacts/application-policy.json b/samples/applications/tomcat-single-signon/artifacts/application-policy.json
new file mode 100644
index 0000000..2c73f9a
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/artifacts/application-policy.json
@@ -0,0 +1,8 @@
+{
+   "networkPartition":[
+      {
+         "id":"network-partition-3",
+         "activeByDefault":"true"
+      }
+   ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/artifacts/application.json b/samples/applications/tomcat-single-signon/artifacts/application.json
new file mode 100644
index 0000000..2f237c1
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/artifacts/application.json
@@ -0,0 +1,38 @@
+{
+    "applicationId": "tomcat-single-signon",
+    "alias": "tomcat-single-signon",
+    "components": {
+
+        "cartridges": [
+            {
+                "type": "tomcat3",
+                "cartridgeMin": 1,
+                "cartridgeMax": 1,
+                "subscribableInfo": {
+                    "alias": "mytomcat3",
+                    "autoscalingPolicy": "autoscaling-policy-1",
+                    "deploymentPolicy": "deployment-policy-3",
+                    "artifactRepository":{
+                        "privateRepo":false,
+                        "repoUrl":"https://github.com/chamilad/travelocity-sample",
+                        "repoUsername":"",
+                        "repoPassword":""
+                    }
+                }
+            },
+            {
+                "type": "wso2is",
+                "cartridgeMin": 1,
+                "cartridgeMax": 1,
+                "subscribableInfo": {
+                    "alias": "mywso2is",
+                    "autoscalingPolicy": "autoscaling-policy-1",
+                    "deploymentPolicy": "deployment-policy-3"
+                }
+            }
+        ],
+        "dependencies": {
+            "terminationBehaviour": "terminate-none"
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/common/deploy.sh b/samples/applications/tomcat-single-signon/scripts/common/deploy.sh
new file mode 100755
index 0000000..07dd56d
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/common/deploy.sh
@@ -0,0 +1,48 @@
+#!/bin/bash
+
+iaas=$1
+host_ip="localhost"
+host_port=9443
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+
+artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
+iaas_cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
+cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
+
+set -e
+
+if [[ -z "${iaas}" ]]; then
+    echo "Usage: deploy.sh [iaas]"
+    exit
+fi
+
+echo ${artifacts_path}/autoscaling-policy.json
+echo "Adding autoscale policy..."
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+
+echo "Adding network partitions..."
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-3.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+
+echo "Adding deployment policy..."
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-3.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+
+echo "Adding tomcat cartridge..."
+curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/tomcat3.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
+
+echo "Adding wso2-is cartridge..."
+curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/wso2-is.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
+
+sleep 1
+
+echo "Creating application..."
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications
+
+sleep 1
+
+echo "Deploying application..."
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat-single-signon/deploy

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/common/undeploy.sh b/samples/applications/tomcat-single-signon/scripts/common/undeploy.sh
new file mode 100644
index 0000000..8ba2646
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/common/undeploy.sh
@@ -0,0 +1,21 @@
+#!/bin/bash
+
+host_ip="localhost"
+host_port=9443
+
+set -e
+
+echo "Undeploying application..."
+curl -X POST -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single-cartridge-app/undeploy
+
+sleep 10
+
+echo "Deleting application..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single-cartridge-app
+
+echo "Removing cartridges..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/tomcat3
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/wso2-is
+
+echo "Removing autoscale policies..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/ec2/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/ec2/deploy.sh b/samples/applications/tomcat-single-signon/scripts/ec2/deploy.sh
new file mode 100755
index 0000000..1370667
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/ec2/deploy.sh
@@ -0,0 +1,9 @@
+#!/bin/bash
+
+iaas="ec2"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/ec2/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/ec2/undeploy.sh b/samples/applications/tomcat-single-signon/scripts/ec2/undeploy.sh
new file mode 100644
index 0000000..17d8c71
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/ec2/undeploy.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/kubernetes/deploy.sh b/samples/applications/tomcat-single-signon/scripts/kubernetes/deploy.sh
new file mode 100755
index 0000000..753af7e
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/kubernetes/deploy.sh
@@ -0,0 +1,16 @@
+#!/bin/bash
+
+host_ip="localhost"
+host_port=9443
+iaas="kubernetes"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernetes-clusters"; pwd`
+
+
+echo "Adding kubernetes cluster..."
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-ec2.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+
+bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/kubernetes/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/kubernetes/undeploy.sh b/samples/applications/tomcat-single-signon/scripts/kubernetes/undeploy.sh
new file mode 100755
index 0000000..c450ea0
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/kubernetes/undeploy.sh
@@ -0,0 +1,13 @@
+#!/bin/bash
+
+host_ip="localhost"
+host_port=9443
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh
+
+echo "Removing kubernetes cluster..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters/kubernetes-cluster-ec2

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/mock/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/mock/deploy.sh b/samples/applications/tomcat-single-signon/scripts/mock/deploy.sh
new file mode 100755
index 0000000..93f8517
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/mock/deploy.sh
@@ -0,0 +1,9 @@
+#!/bin/sh
+
+iaas="mock"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/mock/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/mock/undeploy.sh b/samples/applications/tomcat-single-signon/scripts/mock/undeploy.sh
new file mode 100755
index 0000000..17d8c71
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/mock/undeploy.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/openstack/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/openstack/deploy.sh b/samples/applications/tomcat-single-signon/scripts/openstack/deploy.sh
new file mode 100755
index 0000000..4c39959
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/openstack/deploy.sh
@@ -0,0 +1,9 @@
+#!/bin/bash
+
+iaas="openstack"
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-single-signon/scripts/openstack/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-single-signon/scripts/openstack/undeploy.sh b/samples/applications/tomcat-single-signon/scripts/openstack/undeploy.sh
new file mode 100644
index 0000000..17d8c71
--- /dev/null
+++ b/samples/applications/tomcat-single-signon/scripts/openstack/undeploy.sh
@@ -0,0 +1,7 @@
+#!/bin/bash
+
+prgdir=`dirname "$0"`
+script_path=`cd "$prgdir"; pwd`
+common_folder=`cd "${script_path}/../common"; pwd`
+
+bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/README.md
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/README.md b/samples/applications/tomcat-sso/README.md
deleted file mode 100644
index 2faa840..0000000
--- a/samples/applications/tomcat-sso/README.md
+++ /dev/null
@@ -1,18 +0,0 @@
-Tomcat Application
-==================
-Tomcat application provides an Apache Tomcat 7 cluster. It has no cartridge groups or any dependencies.
-
-Application folder structure
-----------------------------
-```
-artifacts/<iaas>/ IaaS specific artifacts
-scripts/common/ Common scripts for all iaases
-scripts/<iaas> IaaS specific scripts
-```
-
-How to run
-----------
-```
-cd scripts/<iaas>/
-./deploy.sh
-```
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/artifacts/application-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application-policy.json b/samples/applications/tomcat-sso/artifacts/application-policy.json
deleted file mode 100644
index 2c73f9a..0000000
--- a/samples/applications/tomcat-sso/artifacts/application-policy.json
+++ /dev/null
@@ -1,8 +0,0 @@
-{
-   "networkPartition":[
-      {
-         "id":"network-partition-3",
-         "activeByDefault":"true"
-      }
-   ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/artifacts/application.json b/samples/applications/tomcat-sso/artifacts/application.json
deleted file mode 100644
index 7106a4f..0000000
--- a/samples/applications/tomcat-sso/artifacts/application.json
+++ /dev/null
@@ -1,38 +0,0 @@
-{
-    "applicationId": "tomcat-sso",
-    "alias": "tomcat-sso",
-    "components": {
-
-        "cartridges": [
-            {
-                "type": "tomcat-sso",
-                "cartridgeMin": 1,
-                "cartridgeMax": 1,
-                "subscribableInfo": {
-                    "alias": "mytomcat",
-                    "autoscalingPolicy": "autoscaling-policy-1",
-                    "deploymentPolicy": "deployment-policy-3",
-                    "artifactRepository":{
-                        "privateRepo":false,
-                        "repoUrl":"https://github.com/chamilad/travelocity-sample",
-                        "repoUsername":"",
-                        "repoPassword":""
-                    }
-                }
-            },
-            {
-                "type": "wso2is",
-                "cartridgeMin": 1,
-                "cartridgeMax": 1,
-                "subscribableInfo": {
-                    "alias": "mywso2is",
-                    "autoscalingPolicy": "autoscaling-policy-1",
-                    "deploymentPolicy": "deployment-policy-3"
-                }
-            }
-        ],
-        "dependencies": {
-            "terminationBehaviour": "terminate-none"
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/common/deploy.sh b/samples/applications/tomcat-sso/scripts/common/deploy.sh
deleted file mode 100755
index 32ba4be..0000000
--- a/samples/applications/tomcat-sso/scripts/common/deploy.sh
+++ /dev/null
@@ -1,49 +0,0 @@
-#!/bin/bash
-
-iaas=$1
-host_ip="localhost"
-host_port=9443
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-
-artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
-iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
-iaas_cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
-cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
-autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
-network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
-deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
-
-set -e
-
-if [[ -z "${iaas}" ]]; then
-    echo "Usage: deploy.sh [iaas]"
-    exit
-fi
-
-echo ${artifacts_path}/autoscaling-policy.json
-echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
-
-echo "Adding network partitions..."
-curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-3.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
-
-echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-3.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
-
-echo "Adding tomcat cartridge..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/tomcat-sso.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
-
-echo "Adding wso2-is cartridge..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_cartridges_path}/wso2-is.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
-
-sleep 1
-
-echo "Creating application..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications
-
-sleep 1
-
-echo "Deploying application..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/tomcat-sso/deploy

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/common/undeploy.sh b/samples/applications/tomcat-sso/scripts/common/undeploy.sh
deleted file mode 100644
index 9bff2b0..0000000
--- a/samples/applications/tomcat-sso/scripts/common/undeploy.sh
+++ /dev/null
@@ -1,21 +0,0 @@
-#!/bin/bash
-
-host_ip="localhost"
-host_port=9443
-
-set -e
-
-echo "Undeploying application..."
-curl -X POST -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single-cartridge-app/undeploy
-
-sleep 10
-
-echo "Deleting application..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/single-cartridge-app
-
-echo "Removing cartridges..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/tomcat-sso
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/wso2-is
-
-echo "Removing autoscale policies..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/ec2/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/ec2/deploy.sh b/samples/applications/tomcat-sso/scripts/ec2/deploy.sh
deleted file mode 100755
index 1370667..0000000
--- a/samples/applications/tomcat-sso/scripts/ec2/deploy.sh
+++ /dev/null
@@ -1,9 +0,0 @@
-#!/bin/bash
-
-iaas="ec2"
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh b/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh
deleted file mode 100644
index 17d8c71..0000000
--- a/samples/applications/tomcat-sso/scripts/ec2/undeploy.sh
+++ /dev/null
@@ -1,7 +0,0 @@
-#!/bin/bash
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh b/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh
deleted file mode 100755
index 753af7e..0000000
--- a/samples/applications/tomcat-sso/scripts/kubernetes/deploy.sh
+++ /dev/null
@@ -1,16 +0,0 @@
-#!/bin/bash
-
-host_ip="localhost"
-host_port=9443
-iaas="kubernetes"
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-kubernetes_clusters_path=`cd "${script_path}/../../../../kubernetes-clusters"; pwd`
-
-
-echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-ec2.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
-
-bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh b/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh
deleted file mode 100755
index c450ea0..0000000
--- a/samples/applications/tomcat-sso/scripts/kubernetes/undeploy.sh
+++ /dev/null
@@ -1,13 +0,0 @@
-#!/bin/bash
-
-host_ip="localhost"
-host_port=9443
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/undeploy.sh
-
-echo "Removing kubernetes cluster..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters/kubernetes-cluster-ec2

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/mock/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/mock/deploy.sh b/samples/applications/tomcat-sso/scripts/mock/deploy.sh
deleted file mode 100755
index 93f8517..0000000
--- a/samples/applications/tomcat-sso/scripts/mock/deploy.sh
+++ /dev/null
@@ -1,9 +0,0 @@
-#!/bin/sh
-
-iaas="mock"
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/mock/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/mock/undeploy.sh b/samples/applications/tomcat-sso/scripts/mock/undeploy.sh
deleted file mode 100755
index 17d8c71..0000000
--- a/samples/applications/tomcat-sso/scripts/mock/undeploy.sh
+++ /dev/null
@@ -1,7 +0,0 @@
-#!/bin/bash
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/openstack/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/openstack/deploy.sh b/samples/applications/tomcat-sso/scripts/openstack/deploy.sh
deleted file mode 100755
index 4c39959..0000000
--- a/samples/applications/tomcat-sso/scripts/openstack/deploy.sh
+++ /dev/null
@@ -1,9 +0,0 @@
-#!/bin/bash
-
-iaas="openstack"
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh b/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh
deleted file mode 100644
index 17d8c71..0000000
--- a/samples/applications/tomcat-sso/scripts/openstack/undeploy.sh
+++ /dev/null
@@ -1,7 +0,0 @@
-#!/bin/bash
-
-prgdir=`dirname "$0"`
-script_path=`cd "$prgdir"; pwd`
-common_folder=`cd "${script_path}/../common"; pwd`
-
-bash ${common_folder}/undeploy.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/cartridges/kubernetes/tomcat-sso.json
----------------------------------------------------------------------
diff --git a/samples/cartridges/kubernetes/tomcat-sso.json b/samples/cartridges/kubernetes/tomcat-sso.json
deleted file mode 100755
index d7e9f30..0000000
--- a/samples/cartridges/kubernetes/tomcat-sso.json
+++ /dev/null
@@ -1,30 +0,0 @@
-{
-    "type": "tomcat-sso",
-    "provider": "apache",
-    "host": "tomcat.stratos.org",
-    "category": "data",
-    "displayName": "Tomcat 7",
-    "description": "Tomcat 7 Cartridge",
-    "version": "7",
-    "multiTenant": "false",
-    "portMapping": [
-        {
-            "protocol": "http",
-            "port": "8080",
-            "proxyPort": "8280"
-        }
-    ],
-    "deployment":{
-           "baseDir":"/opt/tomcat/webapps"
-    },
-    "iaasProvider":[
-        {
-            "type":"kubernetes",
-            "imageId":"chamilad/tomcat:4.1.0-beta",
-            "networkInterfaces":[
-            ],
-            "property":[
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/cartridges/kubernetes/tomcat3.json
----------------------------------------------------------------------
diff --git a/samples/cartridges/kubernetes/tomcat3.json b/samples/cartridges/kubernetes/tomcat3.json
new file mode 100755
index 0000000..2f0f5cd
--- /dev/null
+++ b/samples/cartridges/kubernetes/tomcat3.json
@@ -0,0 +1,30 @@
+{
+    "type": "tomcat3",
+    "provider": "apache",
+    "host": "tomcat.stratos.org",
+    "category": "data",
+    "displayName": "Tomcat 7",
+    "description": "Tomcat 7 Cartridge",
+    "version": "7",
+    "multiTenant": "false",
+    "portMapping": [
+        {
+            "protocol": "http",
+            "port": "8080",
+            "proxyPort": "8280"
+        }
+    ],
+    "deployment":{
+           "baseDir":"/opt/tomcat/webapps"
+    },
+    "iaasProvider":[
+        {
+            "type":"kubernetes",
+            "imageId":"chamilad/tomcat:4.1.0-beta",
+            "networkInterfaces":[
+            ],
+            "property":[
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/cartridges/mock/tomcat3.json
----------------------------------------------------------------------
diff --git a/samples/cartridges/mock/tomcat3.json b/samples/cartridges/mock/tomcat3.json
new file mode 100755
index 0000000..af4f745
--- /dev/null
+++ b/samples/cartridges/mock/tomcat3.json
@@ -0,0 +1,30 @@
+{
+    "type": "tomcat3",
+    "provider": "apache",
+    "host": "tomcat.stratos.org",
+    "category": "data",
+    "displayName": "Tomcat 7",
+    "description": "Tomcat 7 Cartridge",
+    "version": "7",
+    "multiTenant": "false",
+    "portMapping": [
+        {
+            "protocol": "http",
+            "port": "8080",
+            "proxyPort": "8280"
+        }
+    ],
+    "deployment":{
+           "baseDir":"/opt/tomcat/webapps"
+    },
+    "iaasProvider":[
+        {
+            "type":"mock",
+            "imageId":"not-needed",
+            "networkInterfaces":[
+            ],
+            "property":[
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/cartridges/mock/wso2-is.json
----------------------------------------------------------------------
diff --git a/samples/cartridges/mock/wso2-is.json b/samples/cartridges/mock/wso2-is.json
new file mode 100644
index 0000000..b11132f
--- /dev/null
+++ b/samples/cartridges/mock/wso2-is.json
@@ -0,0 +1,27 @@
+{
+    "type": "wso2is",
+    "provider": "data",
+    "host": "wso2is.stratos.org",
+    "category": "data",
+    "displayName": "WSO2 IS 5.0.0",
+    "description": "WSO2 IS 5.0.0 Cartridge",
+    "version": "7",
+    "multiTenant": "false",
+    "portMapping": [
+        {
+            "protocol": "http",
+            "port": "9443",
+            "proxyPort": "8280"
+        }
+    ],
+    "iaasProvider":[
+        {
+            "type":"mock",
+            "imageId":"not-needed",
+            "networkInterfaces":[
+            ],
+            "property":[
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/42c0baea/samples/network-partitions/mock/network-partition-3.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/mock/network-partition-3.json b/samples/network-partitions/mock/network-partition-3.json
new file mode 100644
index 0000000..264fd0a
--- /dev/null
+++ b/samples/network-partitions/mock/network-partition-3.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-3",
+    "partitions": [
+        {
+            "id": "partition-1",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}


[10/50] [abbrv] stratos git commit: fixing merge conflicts

Posted by re...@apache.org.
http://git-wip-us.apache.org/repos/asf/stratos/blob/b724ac22/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
index 07cdf86..2f95914 100644
--- a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
+++ b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
@@ -1,365 +1,299 @@
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<<<<<<< HEAD
-<?xml version="1.0" encoding="UTF-8"?><wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns="http://impl.services.controller.cloud.stratos.apache.org" xmlns:ax27="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax23="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax24="http://common.stratos.apache.org/xsd" xmlns:ax21="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax212="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax210="http://domain.common.stratos.apache.org/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
+<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns="http://impl.services.controller.cloud.stratos.apache.org" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax228="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax233="http://domain.common.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax230="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax222="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:ax224="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax225="http://common.stratos.apache.org/xsd" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
+    <wsdl:documentation>CloudControllerService</wsdl:documentation>
     <wsdl:types>
-        <xs:schema xmlns:ax29="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax213="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax26="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax22="http://exception.controller.cloud.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
-            <xs:import namespace="http://exception.controller.cloud.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://domain.controller.cloud.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://topology.domain.messaging.stratos.apache.org/xsd"/>
-            <xs:element name="getCartridges">
-                <xs:complexType>
-                    <xs:sequence/>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+        <xs:schema xmlns:ax232="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax229="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax227="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax223="http://exception.controller.cloud.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
+            <xs:import namespace="http://exception.controller.cloud.stratos.apache.org/xsd"></xs:import>
+            <xs:import namespace="http://domain.controller.cloud.stratos.apache.org/xsd"></xs:import>
+            <xs:import namespace="http://topology.domain.messaging.stratos.apache.org/xsd"></xs:import>
+            <xs:import namespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd"></xs:import>
+            <xs:element name="CloudControllerServiceInvalidClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax21:InvalidCartridgeDefinitionException"/>
+                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax222:InvalidClusterException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="terminateInstances">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax21:InvalidIaasProviderException"/>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
+            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax21:CartridgeAlreadyExistsException"/>
+                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax222:CartridgeNotFoundException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addCartridge">
+            <xs:element name="getCartridgeInfo">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax26:CartridgeConfig"/>
+                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
+            <xs:element name="getCartridgeInfoResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax21:InvalidCartridgeTypeException"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:CartridgeInfo"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeCartridge">
-=======
-=======
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-=======
->>>>>>> fixing STRATOS-1214 - deployement policy changes
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns="http://impl.services.controller.cloud.stratos.apache.org" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax228="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax231="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax222="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax224="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:ax226="http://common.stratos.apache.org/xsd" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
-=======
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns="http://impl.services.controller.cloud.stratos.apache.org" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax228="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax233="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax222="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:ax231="http://domain.common.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:ax224="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax226="http://common.stratos.apache.org/xsd" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
->>>>>>> fixing merging issues
-    <wsdl:documentation>CloudControllerService</wsdl:documentation>
-    <wsdl:types>
-        <xs:schema xmlns:ax230="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax223="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:ax234="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax225="http://domain.controller.cloud.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
-            <xs:import namespace="http://exception.controller.cloud.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://domain.controller.cloud.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://topology.domain.messaging.stratos.apache.org/xsd"></xs:import>
-            <xs:element name="CloudControllerServiceDeploymentPolicyNotExistsException">
+            <xs:element name="CloudControllerServiceInvalidPartitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax222:DeploymentPolicyNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax222:InvalidPartitionException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPolicy">
+            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax222:InvalidCartridgeTypeException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPolicyResponse">
+            <xs:element name="validateDeploymentPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax224:Partition"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-<<<<<<< HEAD
-            <xs:element name="getDeploymentPolicies">
-                <xs:complexType>
-                    <xs:sequence></xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPoliciesResponse">
+            <xs:element name="validateDeploymentPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+            <xs:element name="validatePartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax222:InvalidCartridgeDefinitionException"></xs:element>
+                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="validatePartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
+            <xs:element name="getClusterContext">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax222:CartridgeAlreadyExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addCartridge">
+            <xs:element name="getClusterContextResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:ClusterContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
+            <xs:element name="updateClusterStatus">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax222:CartridgeDefinitionNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="status" nillable="true" type="ax229:ClusterStatus"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridge">
+            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
+                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax222:ApplicationClusterRegistrationException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridges">
->>>>>>> Add deployment policy
+            <xs:element name="createApplicationClusters">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="appId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="appClustersContexts" nillable="true" type="ax224:ApplicationClusterContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
+            <xs:element name="CloudControllerServiceClusterInstanceCreationException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax21:CartridgeDefinitionNotExistsException"/>
+                        <xs:element minOccurs="0" name="ClusterInstanceCreationException" nillable="true" type="ax222:ClusterInstanceCreationException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridge">
+            <xs:element name="createClusterInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax26:CartridgeConfig"/>
+                        <xs:element minOccurs="0" name="serviceType" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="partitionId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
+            <xs:element name="getKubernetesClusters">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax21:InvalidServiceGroupException"/>
-                    </xs:sequence>
+                    <xs:sequence></xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroup">
+            <xs:element name="getKubernetesClustersResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax232:KubernetesCluster"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax222:NonExistingKubernetesClusterException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addServiceGroup">
+            <xs:element name="getMasterForKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax26:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeServiceGroup">
+            <xs:element name="getMasterForKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax232:KubernetesMaster"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getClusterContext">
+            <xs:element name="getHostsForKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getClusterContextResponse">
+            <xs:element name="getHostsForKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ClusterContext"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax232:KubernetesHost"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
+            <xs:element name="CloudControllerServiceDeploymentPolicyAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax21:NonExistingKubernetesClusterException"/>
+                        <xs:element minOccurs="0" name="DeploymentPolicyAlreadyExistsException" nillable="true" type="ax222:DeploymentPolicyAlreadyExistsException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesCluster">
+            <xs:element name="CloudControllerServiceInvalidDeploymentPolicyException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="InvalidDeploymentPolicyException" nillable="true" type="ax222:InvalidDeploymentPolicyException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesClusterResponse">
+            <xs:element name="addDeployementPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
+            <xs:element name="CloudControllerServiceDeploymentPolicyNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax21:NonExistingKubernetesHostException"/>
+                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax222:DeploymentPolicyNotExistsException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesHost">
+            <xs:element name="updateDeployementPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesHostResponse">
+            <xs:element name="removeDeployementPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
+            <xs:element name="getDeploymentPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax21:InvalidKubernetesClusterException"/>
+                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesCluster">
+            <xs:element name="getDeploymentPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesClusterResponse">
+            <xs:element name="getDeploymentPolicies">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
-                    </xs:sequence>
+                    <xs:sequence></xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesCluster">
+            <xs:element name="getDeploymentPoliciesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusterResponse">
+            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax222:InvalidCartridgeDefinitionException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusters">
-                <xs:complexType>
-                    <xs:sequence/>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getKubernetesClustersResponse">
+            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
+            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax21:CartridgeNotFoundException"/>
+                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax222:CartridgeDefinitionNotExistsException"></xs:element>
                     </xs:sequence>
-=======
-            <xs:element name="getDeploymentPolicies">
-                <xs:complexType>
-                    <xs:sequence></xs:sequence>
->>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPoliciesResponse">
+            <xs:element name="updateCartridge">
                 <xs:complexType>
                     <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax21:CloudControllerException"/>
+                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstance">
+            <xs:element name="getCartridges">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax26:InstanceContext"/>
-                    </xs:sequence>
+                    <xs:sequence></xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstanceResponse">
-=======
             <xs:element name="getCartridgesResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
-=======
-            <xs:element name="CloudControllerServiceDeploymentPolicyNotExistsException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax222:DeploymentPolicyNotExistsException"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax222:InvalidCartridgeTypeException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -397,296 +331,126 @@
                 </xs:complexType>
             </xs:element>
             <xs:element name="getNetworkPartition">
-=======
-            <xs:element name="getDeploymentPolicies">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPoliciesResponse">
+            <xs:element name="getNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax225:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:NetworkPartition"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+            <xs:element name="CloudControllerServiceNetworkPartitionNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax228:InvalidCartridgeDefinitionException"></xs:element>
+                        <xs:element minOccurs="0" name="NetworkPartitionNotExistsException" nillable="true" type="ax222:NetworkPartitionNotExistsException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="removeNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax228:InvalidIaasProviderException"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
+            <xs:element name="updateNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax228:CartridgeDefinitionNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax224:NetworkPartition"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridge">
+            <xs:element name="CloudControllerServiceInvalidKubernetesHostException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax225:CartridgeConfig"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidKubernetesHostException" nillable="true" type="ax222:InvalidKubernetesHostException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridges">
+            <xs:element name="addKubernetesHost">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax232:KubernetesHost"></xs:element>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgesResponse">
-=======
-            <xs:element name="CloudControllerServiceInvalidMemberException">
->>>>>>> fixing merging issues
+            <xs:element name="addKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax222:InvalidMemberException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
+            <xs:element name="CloudControllerServiceInvalidKubernetesMasterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax222:InvalidCartridgeTypeException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidKubernetesMasterException" nillable="true" type="ax222:InvalidKubernetesMasterException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCloudControllerException">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesMasterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesMasterException" nillable="true" type="ax222:NonExistingKubernetesMasterException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstance">
+            <xs:element name="updateKubernetesMaster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax232:KubernetesMaster"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPolicies">
+            <xs:element name="updateKubernetesMasterResponse">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPoliciesResponse">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax222:NonExistingKubernetesHostException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+            <xs:element name="updateKubernetesHost">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax222:InvalidCartridgeDefinitionException"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax232:KubernetesHost"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="updateKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
+            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax222:CartridgeDefinitionNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax222:CartridgeAlreadyExistsException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridge">
+            <xs:element name="addCartridge">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridges">
-                <xs:complexType>
-                    <xs:sequence></xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeCartridge">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceNetworkPartitionAlreadyExistsException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="NetworkPartitionAlreadyExistsException" nillable="true" type="ax222:NetworkPartitionAlreadyExistsException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="addNetworkPartition">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax224:NetworkPartition"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getNetworkPartitions">
-                <xs:complexType>
-                    <xs:sequence></xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getNetworkPartitionsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:NetworkPartition"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getNetworkPartition">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getNetworkPartitionResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:NetworkPartition"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceNetworkPartitionNotExistsException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="NetworkPartitionNotExistsException" nillable="true" type="ax222:NetworkPartitionNotExistsException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeNetworkPartition">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateNetworkPartition">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax224:NetworkPartition"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesHostException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesHostException" nillable="true" type="ax222:InvalidKubernetesHostException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax222:NonExistingKubernetesClusterException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="addKubernetesHost">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax228:KubernetesHost"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="addKubernetesHostResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesMasterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesMasterException" nillable="true" type="ax222:InvalidKubernetesMasterException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesMasterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesMasterException" nillable="true" type="ax222:NonExistingKubernetesMasterException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateKubernetesMaster">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax228:KubernetesMaster"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateKubernetesMasterResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax222:NonExistingKubernetesHostException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateKubernetesHost">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax228:KubernetesHost"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateKubernetesHostResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax222:CartridgeAlreadyExistsException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="addCartridge">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
+            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax222:InvalidKubernetesClusterException"></xs:element>
@@ -696,7 +460,7 @@
             <xs:element name="addKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax228:KubernetesCluster"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax232:KubernetesCluster"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -717,7 +481,7 @@
             <xs:element name="getKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax228:KubernetesCluster"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax232:KubernetesCluster"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -739,45 +503,48 @@
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"></xs:element>
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+            <xs:element name="removeKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax222:InvalidCartridgeDefinitionException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="CloudControllerServiceInvalidMemberException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax222:InvalidMemberException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
+            <xs:element name="CloudControllerServiceCloudControllerException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax222:CartridgeAlreadyExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addCartridge">
+            <xs:element name="terminateInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
->>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
+                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesHostResponse">
-<<<<<<< HEAD
+            <xs:element name="startInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax224:InstanceContext"></xs:element>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="startInstanceResponse">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -802,18 +569,7 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
             <xs:element name="getServiceGroupCartridges">
-=======
-            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax222:InvalidCartridgeTypeException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeCartridge">
->>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
@@ -821,58 +577,12 @@
                 </xs:complexType>
             </xs:element>
             <xs:element name="getServiceGroupCartridgesResponse">
->>>>>>> fixing STRATOS-1214 - deployement policy changes
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-            <xs:element name="getKubernetesCluster">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getKubernetesClusterResponse">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax230:KubernetesCluster"></xs:element>
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax233:KubernetesCluster"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeKubernetesCluster">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeKubernetesClusterResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeKubernetesHost">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeKubernetesHostResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-=======
             <xs:element name="getServiceGroupDependencies">
                 <xs:complexType>
                     <xs:sequence>
@@ -887,904 +597,48 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-            <xs:element name="removeKubernetesClusterResponse">
->>>>>>> Add deployment policy
+            <xs:element name="startInstances">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:MemberContext"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax224:InstanceContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-<<<<<<< HEAD
-            <xs:element name="CloudControllerServiceInvalidMemberException">
+            <xs:element name="startInstancesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax21:InvalidMemberException"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstance">
-=======
-            <xs:element name="removeKubernetesHost">
-=======
-            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
+            <xs:element name="CloudControllerServiceUnregisteredClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax222:CartridgeNotFoundException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceCloudControllerException">
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
->>>>>>> fixing merging issues
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-<<<<<<< HEAD
-            <xs:element name="removeKubernetesHostResponse">
->>>>>>> Add deployment policy
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="registerService">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="registrant" nillable="true" type="ax26:Registrant"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="registerServiceResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupSubGroups">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupSubGroupsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupCartridges">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupCartridgesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupDependencies">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="getServiceGroupDependenciesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:Dependencies"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidPartitionException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax21:InvalidPartitionException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="validatePartition">
-=======
-            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
->>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax26:Partition"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="validatePartitionResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="validateDeploymentPolicy">
-=======
-            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
-=======
-            <xs:element name="startInstances">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax224:InstanceContext"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstancesResponse">
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax222:InvalidServiceGroupException"></xs:element>
-=======
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax228:InvalidServiceGroupException"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidClusterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax222:InvalidClusterException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="terminateInstances">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgeInfo">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgeInfoResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:CartridgeInfo"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidPartitionException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax222:InvalidPartitionException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="validateDeploymentPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-<<<<<<< HEAD
-<<<<<<< HEAD
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:Dependencies"></xs:element>
-=======
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax225:Dependencies"></xs:element>
->>>>>>> adding getApplicationPolicy web service, rest API and updating AS CC wsdls
-=======
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax224:Partition"></xs:element>
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax222:CartridgeNotFoundException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstance">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax224:InstanceContext"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstanceResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-=======
->>>>>>> fixing axis2 fault - property kubernetesPodLabel is not readable in the bean class
-            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax222:InvalidServiceGroupException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupSubGroups">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupSubGroupsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupCartridges">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupCartridgesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
->>>>>>> fixing merging issues
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupDependencies">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getServiceGroupDependenciesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:Dependencies"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax222:CartridgeNotFoundException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceCloudControllerException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstances">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax224:InstanceContext"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstancesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidClusterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax222:InvalidClusterException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="terminateInstances">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-<<<<<<< HEAD
-            <xs:element name="getCartridgeInfo">
->>>>>>> Add deployment policy
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax26:Partition"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="validateDeploymentPolicyResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstances">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax26:InstanceContext"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="startInstancesResponse">
-=======
-            <xs:element name="getCartridgeInfoResponse">
-=======
-            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
-=======
-            <xs:element name="getCartridgeInfo">
->>>>>>> fixing merging issues
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="createApplicationClusters">
->>>>>>> fixing STRATOS-1214 - deployement policy changes
-=======
-            <xs:element name="getCartridgeInfoResponse">
->>>>>>> fixing merging issues
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:CartridgeInfo"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidPartitionException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax222:InvalidPartitionException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="validateDeploymentPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax224:Partition"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="validateDeploymentPolicyResponse">
->>>>>>> Add deployment policy
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:MemberContext"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-<<<<<<< HEAD
-            <xs:element name="CloudControllerServiceInvalidClusterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax21:InvalidClusterException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="terminateInstances">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateClusterStatus">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="status" nillable="true" type="ax212:ClusterStatus"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceUnregisteredClusterException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax21:UnregisteredClusterException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="unregisterService">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgeInfo">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgeInfoResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:CartridgeInfo"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax21:ApplicationClusterRegistrationException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="createApplicationClusters">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="appId" nillable="true" type="xs:string"/>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="appClustersContexts" nillable="true" type="ax26:ApplicationClusterContext"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceClusterInstanceCreationException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="ClusterInstanceCreationException" nillable="true" type="ax21:ClusterInstanceCreationException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="createClusterInstance">
-=======
-            <xs:element name="validatePartition">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="validatePartitionResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getClusterContext">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getClusterContextResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:ClusterContext"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="updateClusterStatus">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="status" nillable="true" type="ax233:ClusterStatus"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax222:ApplicationClusterRegistrationException"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="createApplicationClusters">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="appId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element maxOccur

<TRUNCATED>

[34/50] [abbrv] stratos git commit: Changing kubernetes service id to service- to avoid validation failures

Posted by re...@apache.org.
Changing kubernetes service id to service-<seq-no> to avoid validation failures


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

Branch: refs/heads/docker-grouping-merge
Commit: 1bfdb7ddb144977762c22574556a2f2db29aa5d6
Parents: 42c0bae
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 14:38:56 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 14:38:56 2015 +0530

----------------------------------------------------------------------
 .../context/CloudControllerContext.java         |  9 +++++
 .../iaases/kubernetes/KubernetesIaas.java       | 40 +++++++++++---------
 2 files changed, 31 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/1bfdb7dd/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/context/CloudControllerContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/context/CloudControllerContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/context/CloudControllerContext.java
index 8543810..ac3997d 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/context/CloudControllerContext.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/context/CloudControllerContext.java
@@ -168,6 +168,7 @@ public class CloudControllerContext implements Serializable {
 
     private transient AsyncDataPublisher dataPublisher;
     private boolean coordinator;
+    private int kubernetesServiceSeqNo;
 
     private CloudControllerContext() {
         // Check clustering status
@@ -729,4 +730,12 @@ public class CloudControllerContext implements Serializable {
             destinationList.add(item);
         }
     }
+
+    public int getKubernetesServiceSeqNo() {
+        return kubernetesServiceSeqNo;
+    }
+
+    public void setKubernetesServiceSeqNo(int kubernetesServiceSeqNo) {
+        this.kubernetesServiceSeqNo = kubernetesServiceSeqNo;
+    }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/1bfdb7dd/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index f675a21..07da283 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -207,7 +207,7 @@ public class KubernetesIaas extends Iaas {
                     kubernetesPortRange.getLower());
 
             // Generate kubernetes service ports and update port mappings in cartridge
-            updateKubernetesServicePorts(kubClusterContext, clusterContext.getClusterId(), cartridge);
+            generateKubernetesServicePorts(kubClusterContext, clusterContext.getClusterId(), cartridge);
 
             // Create kubernetes services for port mappings
             KubernetesApiClient kubernetesApi = kubClusterContext.getKubApi();
@@ -411,7 +411,8 @@ public class KubernetesIaas extends Iaas {
      * @throws KubernetesClientException
      */
     private void createKubernetesServices(KubernetesApiClient kubernetesApi, ClusterContext clusterContext,
-                                                             KubernetesCluster kubernetesCluster) throws KubernetesClientException {
+                                                             KubernetesCluster kubernetesCluster)
+            throws KubernetesClientException {
 
         String clusterId = clusterContext.getClusterId();
         String cartridgeType = clusterContext.getCartridgeType();
@@ -445,7 +446,7 @@ public class KubernetesIaas extends Iaas {
             log.debug(String.format("Minion public IPs: %s", minionPublicIPs));
         }
 
-        int i = kubernetesServices.size();
+        int kubernetesServiceSeqNo = CloudControllerContext.getInstance().getKubernetesServiceSeqNo();
         for (PortMapping portMapping : cartridge.getPortMappings()) {
 
             // Skip if already created
@@ -455,7 +456,7 @@ public class KubernetesIaas extends Iaas {
             }
 
             // Service id = cluster id + kubernetes service seq number of cluster
-            String serviceId = KubernetesIaasUtil.fixSpecialCharacters(clusterId + "-" + (++i));
+            String serviceId = KubernetesIaasUtil.fixSpecialCharacters("service" + "-" + (++kubernetesServiceSeqNo));
             String serviceLabel = KubernetesIaasUtil.fixSpecialCharacters(clusterId);
 
             if (log.isInfoEnabled()) {
@@ -468,8 +469,15 @@ public class KubernetesIaas extends Iaas {
             // Create kubernetes service for port mapping
             int servicePort = portMapping.getKubernetesServicePort();
             String containerPortName = KubernetesIaasUtil.preparePortNameFromPortMapping(portMapping);
-            kubernetesApi.createService(serviceId, serviceLabel, servicePort, containerPortName,
-                    minionPublicIPs.toArray(new String[minionPublicIPs.size()]));
+
+            try {
+                kubernetesApi.createService(serviceId, serviceLabel, servicePort, containerPortName,
+                        minionPublicIPs.toArray(new String[minionPublicIPs.size()]));
+            } finally {
+                // Persist kubernetes service sequence no
+                CloudControllerContext.getInstance().setKubernetesServiceSeqNo(kubernetesServiceSeqNo);
+                CloudControllerContext.getInstance().persist();
+            }
 
             try {
                 Thread.sleep(1000);
@@ -508,26 +516,24 @@ public class KubernetesIaas extends Iaas {
         return false;
     }
 
-    private void updateKubernetesServicePorts(KubernetesClusterContext kubernetesClusterContext, String clusterId,
-                                              Cartridge cartridge) {
+    private void generateKubernetesServicePorts(KubernetesClusterContext kubernetesClusterContext, String clusterId,
+                                                Cartridge cartridge) {
         if(cartridge != null) {
-            boolean servicePortsUpdated = false;
             StringBuilder portMappingStrBuilder = new StringBuilder();
             for (PortMapping portMapping : cartridge.getPortMappings()) {
                 if(portMapping.getKubernetesServicePort() == 0) {
                     int nextServicePort = kubernetesClusterContext.getNextServicePort();
                     if (nextServicePort == -1) {
-                        throw new RuntimeException(String.format("Could not generate service port: [cluster-id] %s [port] %d",
-                                clusterId, portMapping.getPort()));
+                        throw new RuntimeException(String.format("Could not generate service port: [cluster-id] %s " +
+                                        "[port] %d", clusterId, portMapping.getPort()));
                     }
                     portMapping.setKubernetesServicePort(nextServicePort);
-                    servicePortsUpdated = true;
 	                portMapping.setKubernetesServicePortMapping(true);
 
+                    // Add port mappings to payload
                     if(portMappingStrBuilder.toString().length() > 0) {
                         portMappingStrBuilder.append(":");
                     }
-
                     portMappingStrBuilder.append(String.format("PROTOCOL=%s|PORT=%d|PROXY_PORT=%d",
                             portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
 
@@ -541,11 +547,9 @@ public class KubernetesIaas extends Iaas {
             NameValuePair nameValuePair = new NameValuePair(PORT_MAPPINGS, portMappingStrBuilder.toString());
             payload.add(nameValuePair);
 
-            if(servicePortsUpdated) {
-                // Persist service ports added to port mappings
-                CloudControllerContext.getInstance().updateKubernetesClusterContext(kubernetesClusterContext);
-                CloudControllerContext.getInstance().persist();
-            }
+            // Persist service ports added to port mappings
+            CloudControllerContext.getInstance().updateKubernetesClusterContext(kubernetesClusterContext);
+            CloudControllerContext.getInstance().persist();
         }
     }
 


[24/50] [abbrv] stratos git commit: Removing obsolete classes and interfaces in messaging component domain/topology package

Posted by re...@apache.org.
Removing obsolete classes and interfaces in messaging component domain/topology package


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

Branch: refs/heads/docker-grouping-merge
Commit: cc92e5d7e676745434657823a2fc5779a65d11b9
Parents: 350d535
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sat Feb 28 11:14:35 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sat Feb 28 11:14:35 2015 +0530

----------------------------------------------------------------------
 .../domain/instance/ApplicationInstance.java    |   2 +-
 .../domain/instance/ClusterInstance.java        |   2 +-
 .../domain/instance/GroupInstance.java          |   2 +-
 .../messaging/domain/topology/Cartridge.java    |  89 ----
 .../messaging/domain/topology/Composite.java    |  15 -
 .../domain/topology/CompositeApplication.java   | 298 -----------
 .../domain/topology/ConfigCartridge.java        |  20 -
 .../topology/ConfigCompositeApplication.java    |  42 --
 .../domain/topology/ConfigDependencies.java     |  57 ---
 .../messaging/domain/topology/ConfigGroup.java  |  33 --
 .../messaging/domain/topology/Dependencies.java | 334 ------------
 .../messaging/domain/topology/GroupTemp.java    | 503 -------------------
 .../LifeCycleStateTransitionBehavior.java       |  35 --
 .../messaging/domain/topology/Member.java       |   1 +
 .../messaging/domain/topology/Scalable.java     |   5 -
 .../messaging/domain/topology/Subscribable.java |  25 -
 .../LifeCycleStateTransitionBehavior.java       |  33 ++
 .../CompositeApplicationCreatedEvent.java       |  50 --
 .../topology/CompositeApplicationEvent.java     |  31 --
 .../CompositeApplicationRemovedEvent.java       |  48 --
 .../single-cartridge/scripts/common/deploy.sh   |   1 -
 21 files changed, 37 insertions(+), 1589 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ApplicationInstance.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ApplicationInstance.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ApplicationInstance.java
index f158b8b..a1185b0 100644
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ApplicationInstance.java
+++ b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ApplicationInstance.java
@@ -20,7 +20,7 @@
 package org.apache.stratos.messaging.domain.instance;
 
 import org.apache.stratos.messaging.domain.application.ApplicationStatus;
-import org.apache.stratos.messaging.domain.topology.LifeCycleStateTransitionBehavior;
+import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateTransitionBehavior;
 import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateManager;
 
 import java.util.Stack;

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ClusterInstance.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ClusterInstance.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ClusterInstance.java
index 5dd9d19..2d8de21 100644
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ClusterInstance.java
+++ b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/ClusterInstance.java
@@ -20,7 +20,7 @@
 package org.apache.stratos.messaging.domain.instance;
 
 import org.apache.stratos.messaging.domain.topology.ClusterStatus;
-import org.apache.stratos.messaging.domain.topology.LifeCycleStateTransitionBehavior;
+import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateTransitionBehavior;
 import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateManager;
 
 import java.util.Stack;

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/GroupInstance.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/GroupInstance.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/GroupInstance.java
index c609d73..a1b0026 100644
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/GroupInstance.java
+++ b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/instance/GroupInstance.java
@@ -20,7 +20,7 @@
 package org.apache.stratos.messaging.domain.instance;
 
 import org.apache.stratos.messaging.domain.application.GroupStatus;
-import org.apache.stratos.messaging.domain.topology.LifeCycleStateTransitionBehavior;
+import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateTransitionBehavior;
 import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateManager;
 
 import java.util.Stack;

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Cartridge.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Cartridge.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Cartridge.java
deleted file mode 100644
index b13c588..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Cartridge.java
+++ /dev/null
@@ -1,89 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-import java.util.ArrayList;
-import java.util.List;
-
-public class Cartridge implements Subscribable, Scalable {
-	
-	private String alias; // type
-	private String cartridgeId;
-	private Dependencies dependencies;
-	private Subscribable parent;
-	private GroupTemp homeGroupTemp;
-    private Cluster cluster;
-    private static final Log log = LogFactory.getLog(Cartridge.class);
-
-	public Cartridge(String alias) {
-		this.alias = alias;
-	}
-	
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-	
-	public String getAlias() {
-		return alias;
-	}
-
-	public String getCartridgeId() {
-		return cartridgeId;
-	}
-
-	public void setCartridgeId(String cartridgeId) {
-		this.cartridgeId = cartridgeId;
-	}
-
-	public Subscribable getParent() {
-		return parent;
-	}
-
-	public GroupTemp getHomeGroup() {
-		return homeGroupTemp;
-	}
-
-	public void setHomeGroup(GroupTemp homeGroupTemp) {
-		this.homeGroupTemp = homeGroupTemp;
-	}
-
-	public void setParent(Subscribable parent) {
-		this.parent = parent;
-	}
-
-	public Dependencies getDependencies() {
-		return dependencies;
-	}
-	
-	public List<Subscribable>  getAllDependencies() {
-		return new ArrayList<Subscribable>(0);
-	}
-
-	public void setDependencies(Dependencies dependencies) {
-		this.dependencies = dependencies;
-	}
-
-	public void subscribe() {	
-	}
-	
-	public void unsubscribe() {	
-	}
-	
-	public String toString() {
-		String result = "";
-		result = alias;
-		if (dependencies != null) {
-			result = result + " dependencies:" + dependencies.toString();
-		} 
-		return result;
-	}
-
-    public Cluster getCluster() {
-        return cluster;
-    }
-
-    public void setCluster(Cluster cluster) {
-        this.cluster = cluster;
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Composite.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Composite.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Composite.java
deleted file mode 100644
index 8b0d75d..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Composite.java
+++ /dev/null
@@ -1,15 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.util.List;
-
-public interface Composite {
-	
-	public void add(Subscribable subscribable);
-	
-	public void remove(Subscribable subscribable);
-	
-	public Subscribable getParent();
-	
-	public void setParent(Subscribable subscribable);
-	
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/CompositeApplication.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/CompositeApplication.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/CompositeApplication.java
deleted file mode 100644
index 90e8787..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/CompositeApplication.java
+++ /dev/null
@@ -1,298 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.messaging.domain.topology;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-import java.io.Serializable;
-import java.util.*;
-
-
-
-/**
- * Defines a topology of serviceMap in Stratos.
- */
-// Grouping
-public class CompositeApplication implements Serializable {
-    private static final long serialVersionUID = -1L;
-    // Key: Service.serviceName
-    private String alias;
-    private GroupTemp top_level;
-    private Map<String, GroupTemp> all_groups  = null;
-    private List<String> clusterIds;
-    private static final Log log = LogFactory.getLog(CompositeApplication.class);
-
-    public CompositeApplication() {
-       
-    }
-
-    public String getAlias() {
-		return alias;
-	}
-
-
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-
-	/*
-	public Group getTop_level() {
-		return this.top_level;
-	}*/
-	/*
-	public void setTop_level(Group top_level) {
-		this.top_level = top_level;
-	} */
-	
-
-	public Map<String, GroupTemp> getAll_groups() {
-		return all_groups;
-	}
-
-	public void setAll_groups(Map<String, GroupTemp> all_groups) {
-		this.all_groups = all_groups;
-	}
-	
-	
-	public List<GroupTemp> findAllGroupsForServiceType(String serviceType) {
-		Set<String> group_names = this.all_groups.keySet();
-		List<GroupTemp> found_groups = new ArrayList<GroupTemp>();
-		
-		for (String group_name: group_names) {
-            GroupTemp gr = this.all_groups.get(group_name);
-			Subscribable sub = gr.getSubscribable(serviceType);
-			if (sub != null) {
-				found_groups.add(gr);
-			} 
-		}
-		
-		return found_groups;
-	}
-	
-	public GroupTemp getGroupFromGroupAlias(String alias) {
-		return this.all_groups.get(alias);
-	}
-	
-
-	public String [] getDependencies (String alias, boolean kill_flag) {
-		if (log.isDebugEnabled()) {
-			log.debug("getting dependencies from group :" +  this.top_level);
-		}
-		
-		String [] dependenciesAliasArray = null;
-		List<Subscribable> results = null;
-		if (kill_flag && top_level.getDependencies().getKill_behavior().equals("kill-all")) {
-			if (log.isDebugEnabled()) {
-				log.debug("kill-all: returning all dependencies for " + alias);
-			}
-			
-			results = top_level.getAllDependencies();
-			dependenciesAliasArray = new String [results.size()];
-		} else {
-			if (log.isDebugEnabled()) {
-				log.debug("getting selected dependencies from group : " + alias);
-			}
-			Dependencies group_deps = this.top_level.getDependencies();
-			results = group_deps.getDependencies(alias, kill_flag);
-			dependenciesAliasArray = new String [results.size()];
-			for (int i = 0; i < results.size(); i++ ) {
-				Subscribable s = results.get(i);
-				dependenciesAliasArray[i] = s.getAlias();
-				if (log.isDebugEnabled()) {
-					log.debug("adding " + s.getAlias() + " to dependency array");
-				}
-			}
-		}
-		
-		if (log.isDebugEnabled()) {
-			log.debug("returning dependencies for subscribale : " + alias);
-		}
-		return dependenciesAliasArray;
-	}
-	
-	public String [] getDownStreamDependencies (String alias) {
-		if (log.isDebugEnabled()) {
-			log.debug("getting dependencies from group :" +  this.top_level);
-		}
-		
-		String [] dependenciesAliasArray = null;
-		List<Subscribable> results = null;
-		
-		if (log.isDebugEnabled()) {
-			log.debug("getting selected dependencies from group : " + alias);
-		}
-		Dependencies group_deps = this.top_level.getDependencies();
-		results = group_deps.getDownStreamDependents(alias);
-		dependenciesAliasArray = new String [results.size()];
-		for (int i = 0; i < results.size(); i++ ) {
-			Subscribable s = results.get(i);
-			dependenciesAliasArray[i] = s.getAlias();
-			if (log.isDebugEnabled()) {
-				log.debug("adding " + s.getAlias() + " to dependency array");
-			}
-		}
-		
-		if (log.isDebugEnabled()) {
-			log.debug("returning dependencies for subscribale : " + alias);
-		}
-		return dependenciesAliasArray;
-	}
-	
-	public String extractClusterGroupFromClusterId (String clusterId) {
-		String sub1 = extractAlias(clusterId);
-		if (sub1 == null) {
-			return null;
-		}
-		
-		String [] s = sub1.split("-");
-		if (log.isDebugEnabled())  {
-			log.debug("clusterGroup alias is " + sub1 + " size: " + s.length);
-		}
-		if (s.length == 0) {
-			return null;
-		} 
-		if (log.isDebugEnabled())  {
-			log.debug("cluster " + clusterId + " is in group " +  s[0]);
-		}
-		return s[0];
-	}
-	
-	private String extractAlias (String clusterId) {
-		String [] s = clusterId.split("\\.");
-		if (log.isDebugEnabled())  {
-			log.debug("clusterId alias is " + clusterId + " size: " + s.length);
-		}
-		if (s.length == 0) {
-			return null;
-		} 
-		if (log.isDebugEnabled())  {
-			log.debug("clusterId alias is " + clusterId + " alias: " + s[0]);
-		}
-		return s[0];
-	}
-	
-	
-	/*
-	public String [] getUpstreamDependencies (String alias) {
-		String [] dependenciesAliasArray = new String[0];
-		if (log.isDebugEnabled()) {
-			log.debug("searching home group for  : " + alias);
-		}
-		Group gr = getTop_level().findGroup(alias);
-		if (gr == null) {
-			if (log.isDebugEnabled()) {
-				log.debug("no home group found for  : " + alias);
-			}
-			return dependenciesAliasArray;
-		}
-		Subscribable sub = gr.getSubscribable(alias);
-		if (log.isDebugEnabled()) {
-			log.debug("found home group for  : " + alias + " , group is " + gr.getAlias() + " subscribable is " + sub);
-		}
-		//List<Subscribable> results = gr.getUpstreamDependencies(sub);
-		List<Subscribable> results = gr.getDependencies().getUpstreamDependents(sub.getAlias());
-		if (log.isDebugEnabled()) {
-			log.debug("home group upstream result for  : " + alias + " is " + results.size());
-		}
-		dependenciesAliasArray = new String [results.size()];
-		for (int i = 0; i < results.size(); i++) {
-			Subscribable item = results.get(i);
-			if (item != null) {
-				dependenciesAliasArray[i] = item.getAlias();
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("dependenciesAliasArray in getUpstreamDependencies has null value");
-					dependenciesAliasArray[i] = null;
-				}
-			}
-		}
-		return dependenciesAliasArray;
-	} */
-	
-	public String extractAliasFromClusterId (String clusterId) {
-		String [] s = clusterId.split("\\.");
-		if (log.isDebugEnabled())  {
-			log.debug("clusterId alias is " + clusterId + " size: " + s.length);
-		}
-		if (s.length == 0) {
-			return null;
-		} 
-		if (log.isDebugEnabled())  {
-			log.debug("clusterId alias is " + clusterId + " alias: " + s[0]);
-		}
-		return s[0];
-	}
-	
-	/*
-	public String [] getAllInPathOf(String aServiceId) {
-	// check kill_all_enabled flag
-		String [] upstreamDependencies = this.getUpstreamDependencies(aServiceId);
-		String [] downstreamDependencies = this.getDownStreamDependencies(aServiceId);
-		
- 		List<String> all = new ArrayList<String>(upstreamDependencies.length + downstreamDependencies.length + 1);
- 		for (String str : upstreamDependencies) {
- 			all.add(str);
- 		}
- 		for (String str : downstreamDependencies) {
- 			all.add(str);
- 		}
- 		all.add(aServiceId);
- 		String [] arrayAll = new String[all.size()];
- 		arrayAll = all.toArray(arrayAll);
- 		return arrayAll;
-	} */
-	
-	public Map<String, String> getAllInPathOfAsMap(String aServiceId, GroupTemp home_group) {
-		// check kill_all_enabled flag
-			Map<String, String> upstreamDependencies = home_group.getUpstreamDependenciesAsMap(aServiceId);
-			Map<String, String> downstreamDependencies = home_group.getDownStreamDependenciesAsMap(aServiceId);
-			
-	 		Map<String, String> all = new HashMap<String, String>();
-	 		all.putAll(upstreamDependencies);
-	 		all.putAll(downstreamDependencies);
-	 		
-	 		all.put(aServiceId,  home_group.getAlias());
-	 		
-	 		return all;
-		}
-	
-
-	@Override
-    public String toString() {
-		String result = "compositeApplication [" + alias + "]";
-		if (top_level != null) {
-			result = result + top_level.toString();
-		}
-        return result;
-    }
-
-    public List<String> getClusterIds() {
-        return clusterIds;
-    }
-
-    public void setClusterIds(List<String> clusterIds) {
-        this.clusterIds = clusterIds;
-    }
-
-    public void addClusterIdToApp(String clusterId) {
-        this.clusterIds.add(clusterId);
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCartridge.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCartridge.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCartridge.java
deleted file mode 100644
index ad494ee..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCartridge.java
+++ /dev/null
@@ -1,20 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.io.Serializable;
-
-
-public class ConfigCartridge  implements Serializable {
-	/**
-	 * 
-	 */
-	private static final long serialVersionUID = 1L;
-	private String alias;
-
-	public String getAlias() {
-		return alias;
-	}
-
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCompositeApplication.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCompositeApplication.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCompositeApplication.java
deleted file mode 100644
index e2c753b..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigCompositeApplication.java
+++ /dev/null
@@ -1,42 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-
-import java.io.Serializable;
-import java.util.List;
-
-
-
-public class ConfigCompositeApplication  implements Serializable {
-	
-	/* grouping_poc */
-	private String applicationId;
-	private String alias;
-	private List<ConfigGroup> components;
-	private List<ConfigCartridge> cartridges;
-	
-	public String getApplicationId() {
-		return applicationId;
-	}
-	public void setApplicationId(String applicationId) {
-		this.applicationId = applicationId;
-	}
-	public String getAlias() {
-		return alias;
-	}
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-	public List<ConfigGroup> getComponents() {
-		return components;
-	}
-	public void setComponents(List<ConfigGroup> components) {
-		this.components = components;
-	}
-	public List<ConfigCartridge> getCartridges() {
-		return cartridges;
-	}
-	public void setCartridges(List<ConfigCartridge> cartridges) {
-		this.cartridges = cartridges;
-	}
-	
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigDependencies.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigDependencies.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigDependencies.java
deleted file mode 100644
index f8281d9..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigDependencies.java
+++ /dev/null
@@ -1,57 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.List;
-
-
-public class ConfigDependencies  implements Serializable {
-	private static final long serialVersionUID = 1L;
-	private List<Pair> startup_order = new ArrayList<Pair>();
-	private String kill_behavior;
-		
-	
-	public String getKill_behavior() {
-		return kill_behavior;
-	}
-
-	public void setKill_behavior(String kill_behavior) {
-		this.kill_behavior = kill_behavior;
-	}
-
-	public List<Pair> getStartup_order() {
-		return startup_order;
-	}
-
-	public void setStartup_order(List<Pair> startup_order) {
-		this.startup_order = startup_order;
-	}
-	
-	
-
-	public static class Pair  implements Serializable {
-		private String key;
-		private String value;
-		
-		private Pair() {}
-		
-		public Pair(String key, String value) {
-			this.key = key;
-			this.value = value;
-		}
-		
-		public String getKey() {
-			return key;
-		}
-		public void setKey(String key) {
-			this.key = key;
-		}
-		public String getValue() {
-			return value;
-		}
-		public void setValue(String value) {
-			this.value = value;
-		}
-	}
-	
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigGroup.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigGroup.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigGroup.java
deleted file mode 100644
index 25b4991..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/ConfigGroup.java
+++ /dev/null
@@ -1,33 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.io.Serializable;
-import java.util.List;
-
-
-public class ConfigGroup   implements Serializable {
-	private static final long serialVersionUID = 1L;
-	private  String alias;
-	private  List<String> subscribables;
-	private ConfigDependencies dependencies;
-	
-	
-	public String getAlias() {
-		return alias;
-	}
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-	public List<String> getSubscribables() {
-		return subscribables;
-	}
-	public void setSubscribables(List<String> subscribables) {
-		this.subscribables = subscribables;
-	}
-	public ConfigDependencies getDependencies() {
-		return dependencies;
-	}
-	public void setDependencies(ConfigDependencies dependencies) {
-		this.dependencies = dependencies;
-	}
-	
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Dependencies.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Dependencies.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Dependencies.java
deleted file mode 100644
index bef7f0e..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Dependencies.java
+++ /dev/null
@@ -1,334 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-public class Dependencies implements Serializable{
-	
-	/**
-	 * 
-	 */
-	private static final long serialVersionUID = 1L;
-	private Map<String, List<Subscribable>> dependencies = new HashMap<String, List<Subscribable>>();
-	private String kill_behavior = KILL_UNDEFINED;
-	private boolean isKillAllEnabled = false;
-	private GroupTemp groupTemp;
-	private static final Log log = LogFactory.getLog(Dependencies.class);
-	public static String KILL_NONE = "kill-none";
-	public static String KILL_ALL = "kill-all";
-	public static String KILL_DEPENDENTS = "kill-dependents";
-	public static String KILL_UNDEFINED = "kill-undefined";
-	
-	
-	public String getKill_behavior() {
-		return kill_behavior;
-	}
-	
-	public void  enableKillAll() {
-		isKillAllEnabled = true;
-	}
-	
-	public void  disableKillAll() {
-		isKillAllEnabled = false;
-	}
-	
-	public boolean isKillAllEnabled() {
-		return isKillAllEnabled;
-	}
-	
-	public String getKill_behavior_for_alias(String alias) {
-		if (dependencies.containsKey(alias)) {
-			return kill_behavior;
-		}
-		return KILL_UNDEFINED;
-	}
-
-	public void setKill_behavior(String kill_behavior) {
-		this.kill_behavior = kill_behavior;
-	}
-
-	public void addDependency (String alias, Subscribable dependency) {
-		List<Subscribable> my_dep = dependencies.get(alias);
-		if (my_dep != null) {
-			log.debug(" adding another dependency " + dependency.getAlias() + " for " + alias);
-			my_dep.add(dependency);
-		} else {
-			log.debug("initializing dependency list for " + alias + " with dependency " + dependency.getAlias() );
-			my_dep = new ArrayList<Subscribable>();
-			my_dep.add(dependency);
-			dependencies.put(alias, my_dep);
-		}
-	}
-
-	
-	public List<Subscribable> getDependencies(Subscribable subscribable, boolean kill_flag) {
-		String alias = subscribable.getAlias();		
-		return getDependencies(alias, kill_flag);
-	}
-	
-	public List<Subscribable> getDependencies(String alias, boolean kill_flag) {
-		if (log.isDebugEnabled()) {
-			log.debug("checking dependency tree for " + alias + " kill_flag is " + kill_flag);
-		}
-
-		if (kill_flag) {
-			if (kill_behavior.equals("kill-none")) {
-				if (log.isDebugEnabled()) {
-					log.debug(KILL_NONE + ": returning none dependencies for " + alias);
-				}
-				return new ArrayList<Subscribable>(0);
-			} else if (kill_behavior.equals("KILL_DEPENDENTS")) {
-				if (log.isDebugEnabled()) {
-					log.debug(KILL_DEPENDENTS + ": returning all dependencies for " + alias);
-				}
-				return getDependents (alias, kill_flag);
-			} 
-				log.error("invalid kill option:" + kill_behavior + "rwhile checking dependencies for " + alias);
-			} 
-		// kill_flag false, get "startup dependencies"
-		return getDependents (alias, false);
-	}
-	
-	
-	public List<Subscribable> getDownStreamDependents (String alias) {
-		List<Subscribable> results = new ArrayList<Subscribable>();
-		if (log.isDebugEnabled()) {
-			log.debug("in dependency tree for " + alias  + " / " + dependencies.size());
-		}
-		if (dependencies.containsKey(alias)) {
-			log.debug("adding the list of dependencies for :" + alias);
-			List<Subscribable> my_dep = dependencies.get(alias);
-			Iterator<Subscribable> it = my_dep.iterator();
-			while (it.hasNext()) {
-				Subscribable obj = it.next();
-				if (obj instanceof Scalable) {
-					log.debug("adding scalable " + obj.getAlias() + " as dependency for " + alias);
-					results.add(obj);
-					log.debug("adding subsequent downstream dependencies for " + obj.getAlias() + " as dependency for " + alias);
-					List<Subscribable> sub2 = this.getDownStreamDependents(obj.getAlias());
-					results.addAll(sub2);
-					if (log.isDebugEnabled()) {
-						log.debug("added " + sub2.size() + " elements as subsequent downstream dependencies for " + obj.getAlias() + 
-								" as dependency for " + alias);
-					}
-				} else {
-					log.debug("adding nested dependencies from " + obj.getAlias() + " for " + alias);
-					List<Subscribable> sub_results = obj.getAllDependencies();
-					results.addAll(sub_results);		
-				}
-			}
-		} else {
-			log.debug("continue to check nested dependencies for :" + alias);
-			// convert map to List
-			Set<String> keys = dependencies.keySet();
-			for (String key : keys) {
-				if (log.isDebugEnabled()) {
-					log.debug("looping over dependency list with key:" + key + " for alias " + alias);
-				}
-				List<Subscribable> my_dep = dependencies.get(key);
-				if (my_dep != null) {
-					Iterator<Subscribable> it = my_dep.iterator();
-					while (it.hasNext()) {
-						Subscribable obj = it.next();
-						Dependencies deps = obj.getDependencies();
-						if (deps != null) {
-							if (log.isDebugEnabled()) {
-								log.debug("found nested nested dependencies while looping with key:" + key + " for alias " + alias);
-							}
-							results = deps.getDownStreamDependents(alias);
-						}
-					}
-				}
-			}
-		}
-		return results;
-	}
-		
-		private List<Subscribable> getDependents (String alias, boolean kill_flag) {
-			List<Subscribable> results = new ArrayList<Subscribable>();
-			if (log.isDebugEnabled()) {
-				log.debug("in dependency tree for " + alias + " kill_flag is " + kill_flag + " / " + dependencies.size());
-			}
-			if (dependencies.containsKey(alias)) {
-				log.debug("adding the list of dependencies for :" + alias);
-				List<Subscribable> my_dep = dependencies.get(alias);
-				Iterator<Subscribable> it = my_dep.iterator();
-				while (it.hasNext()) {
-					Subscribable obj = it.next();
-					if (obj instanceof Scalable) {
-						log.debug("adding scalable " + obj.getAlias() + " as dependency for " + alias);
-						results.add(obj);
-					} else {
-						log.debug("adding nested dependencies from " + obj.getAlias() + " for " + alias);
-						List<Subscribable> sub_results = obj.getAllDependencies();
-						results.addAll(sub_results);
-					}
-				}
-			} else {
-				log.debug("continue to check nested dependencies for :" + alias);
-				// convert map to List
-				Set<String> keys = dependencies.keySet();
-				for (String key : keys) {
-					if (log.isDebugEnabled()) {
-						log.debug("looping over dependency list with key:" + key + " for alias " + alias);
-					}
-					List<Subscribable> my_dep = dependencies.get(key);
-					if (my_dep != null) {
-						Iterator<Subscribable> it = my_dep.iterator();
-						while (it.hasNext()) {
-							Subscribable obj = it.next();
-							Dependencies deps = obj.getDependencies();
-							if (deps != null) {
-								if (log.isDebugEnabled()) {
-									log.debug("found nested nested dependencies while looping with key:" + key + " for alias " + alias);
-								}
-								results = deps.getDependencies(alias, kill_flag);
-							}
-						}
-					}
-				}
-			}
-
-		
-		return results;
-	}
-	
-	public List<Subscribable> getUpstreamDependents (String alias) {
-		List<Subscribable> results = new ArrayList<Subscribable>();
-		Set<String> keys = dependencies.keySet();
-		for (String key : keys) {
-			if (log.isDebugEnabled()) {
-				log.debug("looping over dependency list with key:" + key + " for alias " + alias + 
-						" in group " + this.getGroupTemp().getAlias());
-			}
-			List<Subscribable> my_dep = dependencies.get(key);
-			if (my_dep != null) {
-				Iterator<Subscribable> it = my_dep.iterator();
-				while (it.hasNext()) {
-					Subscribable obj = it.next();
-					if (alias.equals(obj.getAlias())) {
-						//results.add(obj);
-						// adding "key"
-						Subscribable key_upstreamdep = this.groupTemp.getSubscribable(key);
-						if (log.isDebugEnabled()) {
-							log.debug("adding subscribalbe " + key_upstreamdep.getAlias() + " to upstream dependency list");
-						}
-						results.add(key_upstreamdep);
-						if (log.isDebugEnabled()) {
-							log.debug("adding subsequent upstream dependencies for " + key_upstreamdep.getAlias() + 
-									" as dependency for " + alias);
-						}
-						List<Subscribable> sub2 = this.getUpstreamDependents(key);
-						results.addAll(sub2);
-						if (log.isDebugEnabled()) {
-							log.debug("added " + sub2.size() + " elements as subsequent upstream dependencies for " + key_upstreamdep.getAlias() + 
-									" as dependency for " + alias);
-						}
-					}
-					
-				}
-			}
-		}
-		// get upstream subscribables which have group as dependency
-		Subscribable parent = groupTemp.getParent();
-		if (parent instanceof GroupTemp) {
-			GroupTemp gr = (GroupTemp)parent;
-			List<Subscribable> results2 = gr.getUpstreamDependencies(this.groupTemp);
-			for (Subscribable s : results2) {
-				if (!results.contains(s)) {
-					results.add(s);
-				}
-			}
-			if (log.isDebugEnabled()) {
-				log.debug("added " + results2.size() + " elements as subsequent upstream dependencies for " + this.groupTemp.getAlias() +
-						" as dependency for " + alias);
-			}
-			
-		}
-		
-		return results;
-		
-	}
-	
-	/*
-	public List<Subscribable> getAllDependencies() {
-		List<Subscribable> results = new ArrayList<Subscribable>();
-		
-		if (log.isDebugEnabled()) {
-			log.debug("adding all nested dependencies to result list");
-		}
-		
-		Set<String> keys = dependencies.keySet();
-		if (log.isDebugEnabled()) {
-			log.debug("adding all nested dependencies to result list with number of keys " + keys.size());
-		}
-		
-		Iterator<String> keyit = keys.iterator();
-		
-		while (keyit.hasNext()) {
-			String key = keyit.next();
-			List<Subscribable> values = dependencies.get(key);
-			
-			Iterator<Subscribable> it = values.iterator();
-			while (it.hasNext()) {
-				Subscribable obj = it.next();
-				if (obj instanceof Scalable) {
-					if (log.isDebugEnabled()) {
-						log.debug("adding scalable / cartridge " + obj.getAlias() + " to result list");
-					}
-					results.add(obj);
-				} else {
-					if (log.isDebugEnabled()) {
-						log.debug("adding nested dependencies to result list");
-					}
-					List<Subscribable> sub_results = obj.getDependencies().getAllDependencies();
-					results.addAll(sub_results);
-				}
-			}
-			
-		}
-		
-		return results;
-	} */
-		
-	public GroupTemp getGroupTemp() {
-		return groupTemp;
-	}
-
-	public void setGroupTemp(GroupTemp groupTemp) {
-		this.groupTemp = groupTemp;
-	}
-
-	public String toString() {
-		String result = "";
-		StringBuffer buf = new StringBuffer();
-		
-		Set<String> keys = dependencies.keySet();
-		
-		Iterator<String> keyit = keys.iterator();
-		
-		while (keyit.hasNext()) {
-			String key = keyit.next();
-			buf.append("Key:" + key).append(" ");
-			List<Subscribable> values = dependencies.get(key);
-			
-			Iterator<Subscribable> it = values.iterator();
-			while (it.hasNext()) {
-				Subscribable obj = it.next();
-				buf.append("value:" + obj.getAlias()).append(" ");
-			}
-		}
-		
-		
-		return buf.toString();
-	}
-	
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/GroupTemp.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/GroupTemp.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/GroupTemp.java
deleted file mode 100644
index 36adae6..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/GroupTemp.java
+++ /dev/null
@@ -1,503 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
-
-import org.apache.commons.logging.LogFactory;
-import org.apache.commons.logging.Log;
-
-public class GroupTemp implements Subscribable,Composite, Serializable {
-	
-	/**
-	 * 
-	 */
-	private static final long serialVersionUID = 1L;
-	private String alias;
-	private Map<String, Subscribable> subscribables = new HashMap<String, Subscribable>();
-	private Dependencies dependencies;
-	private Subscribable parent = null;
-	private GroupTemp homeGroupTemp;
-	private static final Log log = LogFactory.getLog(GroupTemp.class);
-
-	public GroupTemp(String alias) {
-		this.alias = alias;
-	}
-
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-	
-	public String getAlias() {
-		return alias;
-	}
-	
-	public Map<String, Subscribable> getSubscribables() {
-		return subscribables;
-	}
-	
-	public Subscribable getSubscribable(String alias) {
-		return subscribables.get(alias);
-	}
-
-	public Subscribable getParent() {
-		return parent;
-	}
-
-	public GroupTemp getHomeGroup() {
-		return homeGroupTemp;
-	}
-
-	public void setHomeGroup(GroupTemp homeGroupTemp) {
-		this.homeGroupTemp = homeGroupTemp;
-	}
-
-	public void setParent(Subscribable parent) {
-		this.parent = parent;
-	}
-	
-	public String getKillBehaviorForAlias(String alias) {
-		if (this.dependencies != null) {
-			return this.dependencies.getKill_behavior_for_alias(alias);
-		} else {
-			return Dependencies.KILL_UNDEFINED;
-		}
-	}
-	
-	public String findKillBehavior(String alias) {
-		
-		List<GroupTemp> all_groupTemps = getAllGroups();
-		String kill_behavior = Dependencies.KILL_UNDEFINED;
-		
-		if (log.isDebugEnabled()) {
-			log.debug("searching kill behavior for " + alias + " in group " + this.alias);
-		}
-		
-		for (GroupTemp groupTemp : all_groupTemps) {
-			kill_behavior = groupTemp.getKillBehaviorForAlias(alias);
-			if (Dependencies.KILL_UNDEFINED.equals(kill_behavior)) {
-				if (log.isDebugEnabled()) {
-					log.debug("kill behavior for " + alias + " in group " + this.alias + " is undefined");
-				}
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("found kill behavior for " + alias + " in group " + this.alias);
-				}
-				return groupTemp.getKillBehaviorForAlias(alias);
-			}
-		}
-		return dependencies.getKill_behavior();
-	}
-	
-	public List<GroupTemp> getAllGroups () {
-		List<GroupTemp> results = new ArrayList<GroupTemp>();
-		// adding the group to list
-		results.add(this);
-		Set<String> keys = subscribables.keySet();
-		if (log.isDebugEnabled()) {
-			log.debug("adding all nested groups to result list with number of keys " + keys.size() + " in group " + this.alias);
-		}
-		
-		Iterator<String> keyit = keys.iterator();
-		
-		while (keyit.hasNext()) {
-			String key = keyit.next();
-			Object obj = subscribables.get(key);
-			if (!(obj instanceof GroupTemp)) {
-				if (log.isDebugEnabled()) {
-					log.debug("skipping non composite obj " + obj);
-				}
-
-			} else  {
-				
-				GroupTemp groupTemp = (GroupTemp) obj;
-				if (log.isDebugEnabled()) {
-					log.debug("adding nested groups / composite to result list " + groupTemp.getAlias());
-			    }
-				List<GroupTemp> sub_results = groupTemp.getAllGroups();
-				results.addAll(sub_results);
-			}
-		}
-		
-		return results;
-	}
-	
-	public Dependencies findDependencies(String alias) {
-		GroupTemp gr = findGroup(alias);
-		if (gr !=null) {
-			return gr.dependencies;
-		}
-		return null;
-	}
-	
-	public GroupTemp findGroup(String alias) {
-		List<GroupTemp> all_groupTemps = getAllGroups();
-		for (GroupTemp groupTemp : all_groupTemps) {
-			if (log.isDebugEnabled()) {
-				log.debug("findGroup in group  " + groupTemp.getAlias() + " for alias " + alias);
-			}
-			if (groupTemp.subscribables.containsKey(alias)) {
-				return groupTemp;
-			} else {
-				// does it need to be checked ?
-			}
-		}
-		
-		return null;
-	}
-	
-	// returns all groups which equal the kill_behavior as parameter
-	public String [] findAllGroupsWithKill(String [] aliases, String kill_behavior) {
-		List<String> results = new ArrayList<String>();
-		for (String alias : aliases) {
-			GroupTemp gr = findGroup(alias);
-			// no null check, shouldn't be null
-			if (gr != null) {
-				Dependencies dep = gr.getDependencies();
-				if (dep != null) {
-					if (kill_behavior.equals(dep.getKill_behavior())) {
-						results.add(gr.getAlias());
-					}
-				}
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("no group found for alias  " + alias);
-				}
-			}
-		}
-		String [] arr = new String[results.size()];
-		arr = results.toArray(arr);
-		return arr;
-	}
-	
-	public String [] findAllGroupsWithKill2(Map<String, String> aliasesMap, String kill_behavior) {
-		List<String> results = new ArrayList<String>();
-		Set<String> aliases = aliasesMap.keySet();
-		for (String alias : aliases) {
-			GroupTemp gr = findGroup(alias);
-			// no null check, shouldn't be null
-			if (gr != null) {
-				Dependencies dep = gr.getDependencies();
-				if (dep != null) {
-					if (kill_behavior.equals(dep.getKill_behavior())) {
-						results.add(gr.getAlias());
-					}
-				}
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("no group found for alias  " + alias);
-				}
-			}
-		}
-		String [] arr = new String[results.size()];
-		arr = results.toArray(arr);
-		return arr;
-	}
-	
-
-	public Dependencies getDependencies() {
-		return dependencies;
-	}
-	
-	public List<Subscribable>  getAllDependencies() {
-		List<Subscribable> results = new ArrayList<Subscribable>();
-		
-		if (log.isDebugEnabled()) {
-			log.debug("adding all nested subscribables to result list in subscribable " + this.alias);
-		}
-		
-		Set<String> keys = subscribables.keySet();
-		if (log.isDebugEnabled()) {
-			log.debug("adding all nested dependencies to result list with number of keys " + keys.size());
-		}
-		
-		Iterator<String> keyit = keys.iterator();
-		
-		while (keyit.hasNext()) {
-			String key = keyit.next();
-			Subscribable obj = subscribables.get(key);
-			if (obj instanceof Scalable) {
-				if (log.isDebugEnabled()) {
-					log.debug("adding scalable / cartridge " + obj.getAlias() + " to result list");
-				}
-				results.add(obj);
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("adding nested dependencies to result list");
-				}
-				List<Subscribable> sub_results = obj.getAllDependencies();
-				results.addAll(sub_results);
-			}
-		}
-		if (log.isDebugEnabled()) {
-			log.debug("returning " + results.size() + " subscribables while getting all dependent subscribables ");
-		}
-		return results;
-	}
-	
-	public String [] getDownStreamDependenciesAsArray (String alias) {
-		if (log.isDebugEnabled()) {
-			log.debug("getting dependencies from group :" +  this.getAlias());
-		}
-		
-		String [] dependenciesAliasArray = null;
-		List<Subscribable> results = null;
-		
-		if (log.isDebugEnabled()) {
-			log.debug("getting selected dependencies from group : " + alias);
-		}
-		Dependencies group_deps = this.getDependencies();
-		results = group_deps.getDownStreamDependents(alias);
-		dependenciesAliasArray = new String [results.size()];
-		for (int i = 0; i < results.size(); i++ ) {
-			Subscribable s = results.get(i);
-			dependenciesAliasArray[i] = s.getAlias();
-			if (log.isDebugEnabled()) {
-				log.debug("adding " + s.getAlias() + " to dependency array");
-			}
-		}
-		
-		if (log.isDebugEnabled()) {
-			log.debug("returning dependencies for subscribale : " + alias);
-		}
-		return dependenciesAliasArray;
-	}
-	
-	public Map<String, String> getDownStreamDependenciesAsMap (String alias) {
-		if (log.isDebugEnabled()) {
-			log.debug("getting dependencies from group :" +  this.getAlias());
-		}
-		
-		Map<String, String> dependencies_map= null;
-		List<Subscribable> results = null;
-		
-		if (log.isDebugEnabled()) {
-			log.debug("getting selected dependencies from group : " + alias);
-		}
-		Dependencies group_deps = this.getDependencies();
-		results = group_deps.getDownStreamDependents(alias);
-		dependencies_map = new HashMap<String, String>(results.size());
-		for (int i = 0; i < results.size(); i++ ) {
-			Subscribable s = results.get(i);
-			
-			GroupTemp gr = s.getHomeGroup(); // TODO - need to change return type to Group
-			String gr_alias = null;
-			if (gr != null) {
-				gr_alias = gr.getAlias();
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("home group is null for subscribable " + s.getAlias());
-				}
-			}
-			dependencies_map.put(s.getAlias(), gr_alias);
-			if (log.isDebugEnabled()) {
-				log.debug("adding " + s.getAlias() + " in group " + gr_alias + " to downstream dependency map ");
-			}
-			
-		}
-		
-		if (log.isDebugEnabled()) {
-			log.debug("returning dependencies for subscribale : " + alias);
-		}
-		return dependencies_map;
-	}
-	
-	public String [] getUpstreamDependenciesAsArray (String alias) {
-		String [] dependenciesAliasArray = new String[0];
-		if (log.isDebugEnabled()) {
-			log.debug("searching home group for  : " + alias);
-		}
-		GroupTemp gr = this;
-		Subscribable sub = gr.getSubscribable(alias);
-		if (log.isDebugEnabled()) {
-			log.debug("found home group for  : " + alias + " , group is " + gr.getAlias() + " subscribable is " + sub);
-		}
-		//List<Subscribable> results = gr.getUpstreamDependencies(sub);
-		List<Subscribable> results = gr.getDependencies().getUpstreamDependents(sub.getAlias());
-		if (log.isDebugEnabled()) {
-			log.debug("home group upstream result for  : " + alias + " is " + results.size());
-		}
-		dependenciesAliasArray = new String [results.size()];
-		for (int i = 0; i < results.size(); i++) {
-			Subscribable item = results.get(i);
-			if (item != null) {
-				dependenciesAliasArray[i] = item.getAlias();
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("dependenciesAliasArray in getUpstreamDependencies has null value");
-					dependenciesAliasArray[i] = null;
-				}
-			}
-		}
-		return dependenciesAliasArray;
-	}
-	
-	public Map<String, String> getUpstreamDependenciesAsMap (String alias) {
-		if (log.isDebugEnabled()) {
-			log.debug("searching home group for  : " + alias);
-		}
-		GroupTemp gr = this;
-		Map<String, String> dependencies_map = null;
-		Subscribable sub = gr.getSubscribable(alias);
-		if (log.isDebugEnabled()) {
-			log.debug("found home group for  : " + alias + " , group is " + gr.getAlias() + " subscribable is " + sub);
-		}
-
-		List<Subscribable> results = gr.getDependencies().getUpstreamDependents(sub.getAlias());
-		if (log.isDebugEnabled()) {
-			log.debug("home group upstream result for  : " + alias + " is " + results.size());
-		}
-		dependencies_map = new HashMap<String, String>(results.size());
-		for (int i = 0; i < results.size(); i++) {
-			Subscribable s = results.get(i);
-			if (s != null) {
-				GroupTemp home_gr = s.getHomeGroup(); // TODO - need to change return type to Group
-				String key = null;
-				String val = null;
-				if (home_gr != null) {
-					key =  s.getAlias();
-					val = home_gr.getAlias();
-					if (log.isDebugEnabled()) {
-						log.debug("adding " + key + " in group " + val + " to upstream dependency map ");
-					}
-					dependencies_map.put(key, val);
-				} 
-				
-			} else {
-				if (log.isDebugEnabled()) {
-					log.debug("dependenciesAliasMap in getUpstreamDependencies has null value");
-				}
-			}
-			
-			
-		}
-		return dependencies_map;
-	}
-	
-	public List<Subscribable>  getUpstreamDependencies(Subscribable subscribable) {
-		List<Subscribable> upstream = new ArrayList<Subscribable>();
-		Subscribable parentSubscribable = this.getParent();
-		if (log.isDebugEnabled()) {
-			log.debug("getting upstream dependencies for " + subscribable.getAlias() + " in group " + this.alias);
-		}
-		if (subscribable instanceof Scalable)  {
-			// this would be typically where the upstream search starts
-			if (log.isDebugEnabled()) {
-				log.debug("subscribable is  cartridge with alias " + subscribable.getAlias() + " in group " + this.alias);
-			}
-			if (parent == null) {
-				if (log.isDebugEnabled()) {
-					log.debug("parent is null, stopping upstream search in group " + this.alias + " for " + alias  );
-				}
-				return upstream;
-			} else if (parent instanceof GroupTemp) {
-
-				GroupTemp parentGroupTemp = (GroupTemp) parentSubscribable;
-				if (log.isDebugEnabled()) {
-					log.debug("continue upstream search in parent group " + parentGroupTemp.alias + " for " + alias  );
-				}
-				// continue with group alias as dependency alias (dependent would be group)
-				List<Subscribable> list = parentGroupTemp.getUpstreamDependencies(this);
-				if (log.isDebugEnabled()) {
-					log.debug("found " + list.size() + " items in upstream search in parent group " + parentGroupTemp.alias + " for " + alias  );
-				}
-				upstream.addAll(list);
-			}
-		} else if (subscribable instanceof GroupTemp) {
-			// get local dependencies
-			if (log.isDebugEnabled()) {
-				log.debug(subscribable.getAlias() + " is a group,  checking in dependencies list of this group " + this.alias + " for " + alias  );
-			}
-			List<Subscribable> listlocal = dependencies.getUpstreamDependents(subscribable.getAlias());
-			if (log.isDebugEnabled()) {
-				log.debug("found " + listlocal.size() + " items in upstream search in group " + this.alias + " for " + alias  );
-			}
-			// add local cartridges which depend on the group
-			upstream.addAll(listlocal);
-			// continue upstream with parent of this group
-			Subscribable parent = this.getParent();
-			if (parent == null) {
-				if (log.isDebugEnabled()) {
-					log.debug("parent is null, stopping upstream search in group " + this.alias + " for " + alias  );
-				}
-				return upstream;
-			} else if (parent instanceof GroupTemp) {
-				if (log.isDebugEnabled()) {
-					log.debug("continue upstream search in parent group " + parent.getAlias() + " for " + alias  );
-				}
-				// continue with group alias as dependency alias (dependent would be group)
-				List<Subscribable> list = ((GroupTemp) parent).getUpstreamDependencies(this);
-				if (log.isDebugEnabled()) {
-					log.debug("found " + list.size() + " items in upstream search in parent group " + parent.getAlias() + " for " + alias  );
-				}
-				// merge upstream dependencies and local dependencies
-				upstream.addAll(list);
-			}
-
-		} 
-		return upstream;
-	}
-
-	public void setDependencies(Dependencies dependencies) {
-		this.dependencies = dependencies;
-	}
-
-	
-
-
-
-	@Override
-	public void subscribe() {
-		// TODO Auto-generated method stub
-		log.debug("subscribing to group: " + alias);
-		
-		Iterator<String> it = subscribables.keySet().iterator();
-		
-		while (it.hasNext()) {
-			String key = it.next();
-			Subscribable subscribable = subscribables.get(key);
-			subscribable.subscribe();
-		}
-		
-	}
-
-	@Override
-	public void unsubscribe() {
-		// TODO Auto-generated method stub
-		
-	}
-
-	@Override
-	public void add(Subscribable subscribale) {
-		// TODO Auto-generated method stub
-		if (log.isDebugEnabled()) {
-			log.debug("building the group, adding subscribable " + subscribale.getAlias() + "  to group  " + this.getAlias());
-		}
-		subscribables.put(subscribale.getAlias(), subscribale);
-	}
-
-	@Override
-	public void remove(Subscribable subscribale) {
-		// TODO Auto-generated method stub
-		subscribables.remove(subscribale.getAlias());
-	}
-	
-	public String toString() {
-		StringBuffer buf = new StringBuffer();
-		Iterator<String> it = subscribables.keySet().iterator();
-		
-		while (it.hasNext()) {
-			String key = it.next();
-			Subscribable subscribable = subscribables.get(key);
-			buf.append("subscribable: " + subscribable.toString());
-			
-		}
-		return buf.toString();
-	}
-
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/LifeCycleStateTransitionBehavior.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/LifeCycleStateTransitionBehavior.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/LifeCycleStateTransitionBehavior.java
deleted file mode 100644
index 3c575a4..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/LifeCycleStateTransitionBehavior.java
+++ /dev/null
@@ -1,35 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.messaging.domain.topology;
-
-import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleState;
-
-import java.util.Stack;
-
-public interface LifeCycleStateTransitionBehavior<T extends LifeCycleState> {
-
-    public boolean isStateTransitionValid(T newState);
-
-    public Stack<T> getTransitionedStates ();
-
-    public T getStatus();
-
-    public boolean setStatus(T newState);
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Member.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Member.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Member.java
index 2501db5..24753fd 100644
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Member.java
+++ b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Member.java
@@ -21,6 +21,7 @@ package org.apache.stratos.messaging.domain.topology;
 
 import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateManager;
 import org.apache.stratos.messaging.adapters.MapAdapter;
+import org.apache.stratos.messaging.domain.topology.lifecycle.LifeCycleStateTransitionBehavior;
 
 import javax.xml.bind.annotation.XmlRootElement;
 import javax.xml.bind.annotation.adapters.XmlJavaTypeAdapter;

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Scalable.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Scalable.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Scalable.java
deleted file mode 100644
index ba4c000..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Scalable.java
+++ /dev/null
@@ -1,5 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-public interface Scalable {
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Subscribable.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Subscribable.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Subscribable.java
deleted file mode 100644
index 1c18b7a..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/Subscribable.java
+++ /dev/null
@@ -1,25 +0,0 @@
-package org.apache.stratos.messaging.domain.topology;
-
-import java.util.List;
-
-
-
-public interface Subscribable {
-	
-
-	
-    public String getAlias();
-	
-	public Dependencies getDependencies();
-	
-	public List<Subscribable>  getAllDependencies();
-	
-	public void subscribe();
-	
-	public void unsubscribe();	
-	
-	public void setHomeGroup(GroupTemp homeGroupTemp);
-	
-	public GroupTemp getHomeGroup();
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/lifecycle/LifeCycleStateTransitionBehavior.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/lifecycle/LifeCycleStateTransitionBehavior.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/lifecycle/LifeCycleStateTransitionBehavior.java
new file mode 100644
index 0000000..f05491c
--- /dev/null
+++ b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/domain/topology/lifecycle/LifeCycleStateTransitionBehavior.java
@@ -0,0 +1,33 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
+package org.apache.stratos.messaging.domain.topology.lifecycle;
+
+import java.util.Stack;
+
+public interface LifeCycleStateTransitionBehavior<T extends LifeCycleState> {
+
+    public boolean isStateTransitionValid(T newState);
+
+    public Stack<T> getTransitionedStates ();
+
+    public T getStatus();
+
+    public boolean setStatus(T newState);
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationCreatedEvent.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationCreatedEvent.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationCreatedEvent.java
deleted file mode 100644
index f218322..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationCreatedEvent.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.messaging.event.topology;
-
-import java.io.Serializable;
-import java.util.*;
-
-import org.apache.stratos.messaging.domain.topology.ConfigCompositeApplication;
-
-
-/**
- *
- * event is fired when application is created
- */
-public class CompositeApplicationCreatedEvent extends TopologyEvent implements Serializable{
-	private static final long serialVersionUID = -1L;
-	private ConfigCompositeApplication compositeApplication;
-	
-	public CompositeApplicationCreatedEvent(ConfigCompositeApplication configCompositeApplication) {
-		this.compositeApplication = configCompositeApplication;
-		
-	}
-
-	public String getApplicationAlias() {
-		return compositeApplication.getAlias();
-	}
-	
-	public ConfigCompositeApplication getCompositeApplication () {
-		return this.compositeApplication;
-	}
-}
-
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationEvent.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationEvent.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationEvent.java
deleted file mode 100644
index cf2a6af..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationEvent.java
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.messaging.event.topology;
-
-import org.apache.stratos.messaging.event.Event;
-
-import java.io.Serializable;
-
-/**
- * Tenant event definition.
- */
-public abstract class CompositeApplicationEvent extends Event implements Serializable {
-    private static final long serialVersionUID = -1L;
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationRemovedEvent.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationRemovedEvent.java b/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationRemovedEvent.java
deleted file mode 100644
index db6e3e3..0000000
--- a/components/org.apache.stratos.messaging/src/main/java/org/apache/stratos/messaging/event/topology/CompositeApplicationRemovedEvent.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.messaging.event.topology;
-
-import java.io.Serializable;
-import java.util.*;
-
-import org.apache.stratos.messaging.domain.topology.CompositeApplication;
-import org.apache.stratos.messaging.domain.topology.ConfigCompositeApplication;
-
-
-/**
- *
- * event is fired when application is created
- */
-public class CompositeApplicationRemovedEvent extends TopologyEvent implements Serializable{
-	private static final long serialVersionUID = -1L;
-	private String compositeApplicationAlias;
-	
-	public CompositeApplicationRemovedEvent(String compositeApplicationAlias) {
-		this.compositeApplicationAlias = compositeApplicationAlias;
-		
-	}
-
-	public String getApplicationAlias() {
-		return compositeApplicationAlias;
-	}
-	
-}
-
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/cc92e5d7/samples/applications/single-cartridge/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/scripts/common/deploy.sh b/samples/applications/single-cartridge/scripts/common/deploy.sh
index 7d4424e..ee56281 100755
--- a/samples/applications/single-cartridge/scripts/common/deploy.sh
+++ b/samples/applications/single-cartridge/scripts/common/deploy.sh
@@ -8,7 +8,6 @@ prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 
 artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
-iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 iaas_cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
 autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`


[03/50] [abbrv] stratos git commit: Fix dependent-scaling samples

Posted by re...@apache.org.
Fix dependent-scaling samples


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

Branch: refs/heads/docker-grouping-merge
Commit: b4faf43d9492c8ec6a44dc4a997ee1922dc9bc6a
Parents: dd8b2d1
Author: Lahiru Sandaruwan <la...@apache.org>
Authored: Thu Feb 26 18:59:33 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../sample-cartridges/scripts/common/deploy.sh              | 9 ++++++++-
 .../sample-groups/artifacts/application.json                | 2 +-
 2 files changed, 9 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/b4faf43d/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh b/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
index 674f9c7..5eb92c2 100755
--- a/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
+++ b/samples/applications/dependent-scaling/sample-cartridges/scripts/common/deploy.sh
@@ -23,6 +23,13 @@ echo ${artifacts_path}/autoscaling-policy.json
 echo "Adding autoscale policy..."
 curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
 
+echo "Adding network partitions..."
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+
+echo "Adding deployment policy..."
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+
 echo "Adding tomcat cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${cartridges_path}/tomcat.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges
 
@@ -37,4 +44,4 @@ curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/applicat
 sleep 1
 
 echo "Deploying application..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/sample-cartridges-app/deploy
\ No newline at end of file
+curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/application-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/applications/dependency-scaling-cartridges-app/deploy
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/b4faf43d/samples/applications/dependent-scaling/sample-groups/artifacts/application.json
----------------------------------------------------------------------
diff --git a/samples/applications/dependent-scaling/sample-groups/artifacts/application.json b/samples/applications/dependent-scaling/sample-groups/artifacts/application.json
index 2b9cccb..b4af2eb 100644
--- a/samples/applications/dependent-scaling/sample-groups/artifacts/application.json
+++ b/samples/applications/dependent-scaling/sample-groups/artifacts/application.json
@@ -8,7 +8,7 @@
                 "alias": "my-esb-php-group",
                 "groupMinInstances": 1,
                 "groupMaxInstances": 2,
-	        "deploymentPolicy":"deployment-policy-1",
+		"deploymentPolicy": "deployment-policy-1",
                 "cartridges": [
                     {
                         "type": "esb",


[02/50] [abbrv] stratos git commit: Fixing member context not found issues, STRATOS-1110

Posted by re...@apache.org.
Fixing member context not found issues, STRATOS-1110


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

Branch: refs/heads/docker-grouping-merge
Commit: dd8b2d173ae894cf608722c613af510ed2b562f3
Parents: d0ea5d8
Author: Lahiru Sandaruwan <la...@apache.org>
Authored: Thu Feb 26 18:59:09 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../impl/CloudControllerServiceImpl.java        | 44 --------------------
 1 file changed, 44 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/dd8b2d17/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
index 5518aaa..3f17439 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
@@ -583,11 +583,6 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 if (cluster != null) {
                     Member member = cluster.getMember(memberId);
                     if (member != null) {
-                        // change member status if termination on a faulty member
-                        if (fixMemberStatus(member, topology)) {
-                            // set the time this member was added to ReadyToShutdown status
-                            memberContext.setObsoleteInitTime(System.currentTimeMillis());
-                        }
 
                         // check if ready to shutdown member is expired and send
                         // member terminated if it is.
@@ -643,45 +638,6 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         return false;
     }
 
-
-    /**
-     * Corrects the member status upon termination call if the member is in an Active state
-     *
-     * @param member   The {@link org.apache.stratos.messaging.domain.topology.Member} object that is being
-     *                 checked for status
-     * @param topology The {@link org.apache.stratos.messaging.domain.topology.Topology} object to update
-     *                 the topology if needed.
-     */
-    private boolean fixMemberStatus(Member member, Topology topology) {
-        if (member.getStatus() == MemberStatus.Active) {
-            MemberReadyToShutdownEvent memberReadyToShutdownEvent = new MemberReadyToShutdownEvent(
-                    member.getServiceName(),
-                    member.getClusterId(),
-                    member.getClusterInstanceId(), member.getMemberId(),
-                    member.getNetworkPartitionId(),
-                    member.getPartitionId());
-
-            member.setStatus(MemberStatus.ReadyToShutDown);
-            log.info("Member Ready to shut down event adding status started");
-
-            TopologyManager.updateTopology(topology);
-
-            TopologyEventPublisher.sendMemberReadyToShutdownEvent(memberReadyToShutdownEvent);
-            //publishing data
-            StatisticsDataPublisher.publish(member.getMemberId(),
-                    member.getPartitionId(),
-                    member.getNetworkPartitionId(),
-                    member.getClusterId(),
-                    member.getServiceName(),
-                    MemberStatus.ReadyToShutDown.toString(),
-                    null);
-
-            return true;
-        }
-
-        return false;
-    }
-
     @Override
     public void terminateInstances(String clusterId) throws InvalidClusterException {
 


[26/50] [abbrv] stratos git commit: Adding port mappings to payload in kubernetes workflow

Posted by re...@apache.org.
Adding port mappings to payload in kubernetes workflow


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

Branch: refs/heads/docker-grouping-merge
Commit: a854a9caf5adea1a9f28e25e41b32eab3164ce2f
Parents: d58cc94
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 00:41:06 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 00:41:06 2015 +0530

----------------------------------------------------------------------
 .../iaases/kubernetes/KubernetesIaas.java        | 19 +++++++++++++++++--
 .../iaases/kubernetes/KubernetesIaasUtil.java    |  1 -
 2 files changed, 17 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/a854a9ca/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index 47e620c..f675a21 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -42,6 +42,7 @@ import org.apache.stratos.kubernetes.client.exceptions.KubernetesClientException
 import org.apache.stratos.kubernetes.client.model.EnvironmentVariable;
 import org.apache.stratos.kubernetes.client.model.Pod;
 import org.apache.stratos.kubernetes.client.model.Service;
+import org.apache.stratos.kubernetes.client.model.Port;
 import org.apache.stratos.messaging.domain.topology.KubernetesService;
 
 import java.util.ArrayList;
@@ -59,6 +60,7 @@ public class KubernetesIaas extends Iaas {
     private static final String PAYLOAD_PARAMETER_SEPARATOR = ",";
     private static final String PAYLOAD_PARAMETER_NAME_VALUE_SEPARATOR = "=";
     private static final String PAYLOAD_PARAMETER_PREFIX = "payload_parameter.";
+    private static final String PORT_MAPPINGS = "PORT_MAPPINGS";
 
     private PartitionValidator partitionValidator;
     private List<NameValuePair> payload;
@@ -385,8 +387,8 @@ public class KubernetesIaas extends Iaas {
         EnvironmentVariable[] environmentVariables = KubernetesIaasUtil.prepareEnvironmentVariables(
                 clusterContext, memberContext);
 
-        kubernetesApi.createPod(podId, podLabel, dockerImage,
-                KubernetesIaasUtil.convertPortMappings(cartridge.getPortMappings()), environmentVariables);
+        List<Port> ports = KubernetesIaasUtil.convertPortMappings(cartridge.getPortMappings());
+        kubernetesApi.createPod(podId, podLabel, dockerImage, ports, environmentVariables);
 
         // Add pod id to member context and persist
         memberContext.setKubernetesPodId(podId);
@@ -510,6 +512,7 @@ public class KubernetesIaas extends Iaas {
                                               Cartridge cartridge) {
         if(cartridge != null) {
             boolean servicePortsUpdated = false;
+            StringBuilder portMappingStrBuilder = new StringBuilder();
             for (PortMapping portMapping : cartridge.getPortMappings()) {
                 if(portMapping.getKubernetesServicePort() == 0) {
                     int nextServicePort = kubernetesClusterContext.getNextServicePort();
@@ -520,12 +523,24 @@ public class KubernetesIaas extends Iaas {
                     portMapping.setKubernetesServicePort(nextServicePort);
                     servicePortsUpdated = true;
 	                portMapping.setKubernetesServicePortMapping(true);
+
+                    if(portMappingStrBuilder.toString().length() > 0) {
+                        portMappingStrBuilder.append(":");
+                    }
+
+                    portMappingStrBuilder.append(String.format("PROTOCOL=%s|PORT=%d|PROXY_PORT=%d",
+                            portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
+
                     if (log.isInfoEnabled()) {
                         log.info(String.format("Kubernetes service port generated: [cluster-id] %s [port] %d " +
                                 "[service-port] %d", clusterId, portMapping.getPort(), nextServicePort));
                     }
                 }
             }
+
+            NameValuePair nameValuePair = new NameValuePair(PORT_MAPPINGS, portMappingStrBuilder.toString());
+            payload.add(nameValuePair);
+
             if(servicePortsUpdated) {
                 // Persist service ports added to port mappings
                 CloudControllerContext.getInstance().updateKubernetesClusterContext(kubernetesClusterContext);

http://git-wip-us.apache.org/repos/asf/stratos/blob/a854a9ca/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaasUtil.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaasUtil.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaasUtil.java
index 80cc395..7bfc68e 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaasUtil.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaasUtil.java
@@ -116,7 +116,6 @@ public class KubernetesIaasUtil {
             Port port = new Port();
             port.setName(preparePortNameFromPortMapping(portMapping));
             port.setContainerPort(portMapping.getPort());
-            port.setHostPort(portMapping.getKubernetesServicePort());
             ports.add(port);
         }
         return ports;


[06/50] [abbrv] stratos git commit: re-arranging samples to new format

Posted by re...@apache.org.
re-arranging samples to new format


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

Branch: refs/heads/docker-grouping-merge
Commit: 36f0d3a6f2848be360c22589a518eb8112941f49
Parents: 909b0de
Author: R-Rajkumar <rr...@gmail.com>
Authored: Thu Feb 26 20:17:43 2015 +0530
Committer: R-Rajkumar <rr...@gmail.com>
Committed: Fri Feb 27 19:42:44 2015 +0530

----------------------------------------------------------------------
 .../artifacts/autoscaling-policy.json           | 14 -----
 .../artifacts/deployment-policy.json            | 15 ------
 .../artifacts/ec2/deployment-policy.json        | 55 -------------------
 .../artifacts/kubernetes/deployment-policy.json | 55 -------------------
 .../kubernetes/kubernetes-cluster.json          | 56 --------------------
 .../artifacts/mock/deployment-policy.json       | 55 -------------------
 .../artifacts/network-partition-2.json          | 15 ------
 .../artifacts/network-partition.json            | 15 ------
 .../artifacts/openstack/deployment-policy.json  | 55 -------------------
 .../scripts/common/deploy.sh                    | 13 +++--
 .../scripts/common/undeploy.sh                  | 10 +++-
 .../scripts/kubernetes/deploy.sh                |  5 +-
 .../artifacts/autoscaling-policy.json           | 14 -----
 .../artifacts/deployment-policy.json            | 15 ------
 .../artifacts/ec2/deployment-policy.json        | 55 -------------------
 .../artifacts/kubernetes/deployment-policy.json | 55 -------------------
 .../kubernetes/kubernetes-cluster.json          | 56 --------------------
 .../artifacts/mock/deployment-policy.json       | 55 -------------------
 .../artifacts/network-partition-2.json          | 15 ------
 .../artifacts/network-partition.json            | 15 ------
 .../artifacts/openstack/deployment-policy.json  | 55 -------------------
 .../scripts/common/deploy.sh                    | 13 +++--
 .../scripts/common/undeploy.sh                  | 10 +++-
 .../scripts/kubernetes/deploy.sh                |  5 +-
 .../wordpress/scripts/kubernetes/deploy.sh      |  5 +-
 .../ec2/network-partition-1.json                | 15 ++++++
 .../ec2/network-partition-2.json                | 15 ++++++
 .../kubernetes/network-partition-1.json         | 15 ++++++
 .../kubernetes/network-partition-2.json         | 15 ++++++
 .../openstack/network-partition-1.json          | 15 ++++++
 .../openstack/network-partition-2.json          | 15 ++++++
 31 files changed, 133 insertions(+), 688 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/autoscaling-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/autoscaling-policy.json b/samples/applications/wordpress-extended-v1/artifacts/autoscaling-policy.json
deleted file mode 100755
index b41726e..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/autoscaling-policy.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-    "id": "autoscaling-policy-1",
-    "loadThresholds": {
-        "requestsInFlight": {
-            "threshold": 80
-        },
-        "memoryConsumption": {
-            "threshold": 90
-        },
-        "loadAverage": {
-            "threshold": 50
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/deployment-policy.json b/samples/applications/wordpress-extended-v1/artifacts/deployment-policy.json
deleted file mode 100644
index 666c299..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/deployment-policy.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-   "id": "deployment-policy-1",
-   "networkPartition": [
-      {
-         "id": "network-partition-1",
-         "partitionAlgo": "one-after-another",
-         "partitions": [
-            {
-               "id": "partition-1",
-               "max": 5
-            }
-         ]
-      }
-   ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/ec2/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/ec2/deployment-policy.json b/samples/applications/wordpress-extended-v1/artifacts/ec2/deployment-policy.json
deleted file mode 100644
index 67f5a5f..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/ec2/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "ec2",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/kubernetes/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/kubernetes/deployment-policy.json b/samples/applications/wordpress-extended-v1/artifacts/kubernetes/deployment-policy.json
deleted file mode 100644
index cb72ffd..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/kubernetes/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "kubernetes",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/kubernetes/kubernetes-cluster.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/kubernetes/kubernetes-cluster.json b/samples/applications/wordpress-extended-v1/artifacts/kubernetes/kubernetes-cluster.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/kubernetes/kubernetes-cluster.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/mock/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/mock/deployment-policy.json b/samples/applications/wordpress-extended-v1/artifacts/mock/deployment-policy.json
deleted file mode 100644
index a9548fd..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/mock/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "mock",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql-php-group1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "tomcat1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/network-partition-2.json b/samples/applications/wordpress-extended-v1/artifacts/network-partition-2.json
deleted file mode 100644
index 0d07838..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/network-partition-2.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-2",
-    "partitions": [
-        {
-            "id": "partition-2",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/network-partition.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/network-partition.json b/samples/applications/wordpress-extended-v1/artifacts/network-partition.json
deleted file mode 100644
index 2a5b7ec..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/network-partition.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-1",
-    "partitions": [
-        {
-            "id": "partition-1",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/artifacts/openstack/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/artifacts/openstack/deployment-policy.json b/samples/applications/wordpress-extended-v1/artifacts/openstack/deployment-policy.json
deleted file mode 100644
index a2d1e8c..0000000
--- a/samples/applications/wordpress-extended-v1/artifacts/openstack/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "openstack",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/scripts/common/deploy.sh b/samples/applications/wordpress-extended-v1/scripts/common/deploy.sh
index 4672be7..d87660e 100755
--- a/samples/applications/wordpress-extended-v1/scripts/common/deploy.sh
+++ b/samples/applications/wordpress-extended-v1/scripts/common/deploy.sh
@@ -11,6 +11,9 @@ artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
 
 set -e
 
@@ -19,16 +22,16 @@ if [[ -z "${iaas}" ]]; then
     exit
 fi
 
-echo ${artifacts_path}/autoscaling-policy.json
+echo ${autoscaling_policies_path}/autoscaling-policy-1.json
 echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
 
 echo "Adding network partitions..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding mysql cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${cartridges_path}/mysql.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/scripts/common/undeploy.sh b/samples/applications/wordpress-extended-v1/scripts/common/undeploy.sh
index 410c429..c82fcae 100644
--- a/samples/applications/wordpress-extended-v1/scripts/common/undeploy.sh
+++ b/samples/applications/wordpress-extended-v1/scripts/common/undeploy.sh
@@ -22,4 +22,12 @@ curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/tomcat
 
 echo "Removing autoscale policies..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
\ No newline at end of file
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
+
+echo "Removing deployment policies..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-1
+
+echo "Removing network partitions..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-1
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-2
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v1/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v1/scripts/kubernetes/deploy.sh b/samples/applications/wordpress-extended-v1/scripts/kubernetes/deploy.sh
index 32eff3c..0d614cc 100755
--- a/samples/applications/wordpress-extended-v1/scripts/kubernetes/deploy.sh
+++ b/samples/applications/wordpress-extended-v1/scripts/kubernetes/deploy.sh
@@ -8,8 +8,9 @@ prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 common_folder=`cd "${script_path}/../common"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernets-clusters"; pwd`
 
 echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/kubernetes-cluster.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-1.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
 
-bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/autoscaling-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/autoscaling-policy.json b/samples/applications/wordpress-extended-v2/artifacts/autoscaling-policy.json
deleted file mode 100755
index b41726e..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/autoscaling-policy.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-    "id": "autoscaling-policy-1",
-    "loadThresholds": {
-        "requestsInFlight": {
-            "threshold": 80
-        },
-        "memoryConsumption": {
-            "threshold": 90
-        },
-        "loadAverage": {
-            "threshold": 50
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/deployment-policy.json b/samples/applications/wordpress-extended-v2/artifacts/deployment-policy.json
deleted file mode 100644
index 666c299..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/deployment-policy.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-   "id": "deployment-policy-1",
-   "networkPartition": [
-      {
-         "id": "network-partition-1",
-         "partitionAlgo": "one-after-another",
-         "partitions": [
-            {
-               "id": "partition-1",
-               "max": 5
-            }
-         ]
-      }
-   ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/ec2/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/ec2/deployment-policy.json b/samples/applications/wordpress-extended-v2/artifacts/ec2/deployment-policy.json
deleted file mode 100644
index 67f5a5f..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/ec2/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "ec2",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/kubernetes/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/kubernetes/deployment-policy.json b/samples/applications/wordpress-extended-v2/artifacts/kubernetes/deployment-policy.json
deleted file mode 100644
index cb72ffd..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/kubernetes/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "kubernetes",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/kubernetes/kubernetes-cluster.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/kubernetes/kubernetes-cluster.json b/samples/applications/wordpress-extended-v2/artifacts/kubernetes/kubernetes-cluster.json
deleted file mode 100644
index 2988ed1..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/kubernetes/kubernetes-cluster.json
+++ /dev/null
@@ -1,56 +0,0 @@
-{
-    "clusterId": "kubernetes-cluster-1",
-    "description": "Kubernetes CoreOS cluster",
-    "kubernetesMaster": {
-        "hostId": "KubHostMaster1",
-        "hostname": "master.dev.kubernetes.example.org",
-        "privateIPAddress": "172.17.8.100",
-        "publicIPAddress": "172.17.8.100",
-        "property": [
-        ]
-    },
-    "portRange": {
-        "upper": "5000",
-        "lower": "4500"
-    },
-    "kubernetesHosts": [
-        {
-            "hostId": "KubHostSlave1",
-            "hostname": "slave1.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.101",
-            "publicIPAddress": "172.17.8.101",
-            "property": [
-            ]
-        },
-        {
-            "hostId": "KubHostSlave2",
-            "hostname": "slave2.dev.kubernetes.example.org",
-            "privateIPAddress": "172.17.8.102",
-            "publicIPAddress": "172.17.8.102",
-            "property": [
-            ]
-        }
-    ],
-    "property": [
-        {
-            "name": "payload_parameter.MB_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.MB_PORT",
-            "value": "1883"
-        },
-        {
-            "name": "payload_parameter.CEP_IP",
-            "value": "172.17.8.1"
-        },
-        {
-            "name": "payload_parameter.CEP_PORT",
-            "value": "7711"
-        },
-        {
-            "name": "payload_parameter.LOG_LEVEL",
-            "value": "DEBUG"
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/mock/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/mock/deployment-policy.json b/samples/applications/wordpress-extended-v2/artifacts/mock/deployment-policy.json
deleted file mode 100644
index a9548fd..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/mock/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "mock",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql-php-group1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "tomcat1",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/network-partition-2.json b/samples/applications/wordpress-extended-v2/artifacts/network-partition-2.json
deleted file mode 100644
index 0d07838..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/network-partition-2.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-2",
-    "partitions": [
-        {
-            "id": "partition-2",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/network-partition.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/network-partition.json b/samples/applications/wordpress-extended-v2/artifacts/network-partition.json
deleted file mode 100644
index 2a5b7ec..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/network-partition.json
+++ /dev/null
@@ -1,15 +0,0 @@
-{
-    "id": "network-partition-1",
-    "partitions": [
-        {
-            "id": "partition-1",
-            "provider": "mock",
-            "property": [
-                {
-                    "name": "region",
-                    "value": "default"
-                }
-            ]
-        }
-    ]
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/artifacts/openstack/deployment-policy.json
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/artifacts/openstack/deployment-policy.json b/samples/applications/wordpress-extended-v2/artifacts/openstack/deployment-policy.json
deleted file mode 100644
index a2d1e8c..0000000
--- a/samples/applications/wordpress-extended-v2/artifacts/openstack/deployment-policy.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{
-    "applicationPolicy": {
-        "networkPartition": [
-            {
-                "id": "network-partition-1",
-                "activeByDefault": "true",
-                "partitions": [
-                    {
-                        "id": "partition-1",
-                        "provider": "openstack",
-                        "property": [
-                            {
-                                "name": "region",
-                                "value": "default"
-                            }
-                        ]
-                    }
-                ]
-            }
-        ]
-    },
-    "childPolicies": [
-        {
-            "alias": "mysql",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        },
-        {
-            "alias": "php",
-            "networkPartition": [
-                {
-                    "id": "network-partition-1",
-                    "partitionAlgo": "one-after-another",
-                    "partitions": [
-                        {
-                            "id": "partition-1",
-                            "max": 5
-                        }
-                    ]
-                }
-            ]
-        }
-    ]
-}
-

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/scripts/common/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/scripts/common/deploy.sh b/samples/applications/wordpress-extended-v2/scripts/common/deploy.sh
index 4672be7..d87660e 100755
--- a/samples/applications/wordpress-extended-v2/scripts/common/deploy.sh
+++ b/samples/applications/wordpress-extended-v2/scripts/common/deploy.sh
@@ -11,6 +11,9 @@ artifacts_path=`cd "${script_path}/../../artifacts"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
 cartridges_path=`cd "${script_path}/../../../../cartridges/${iaas}"; pwd`
 cartridges_groups_path=`cd "${script_path}/../../../../cartridges-groups"; pwd`
+autoscaling_policies_path=`cd "${script_path}/../../../../autoscaling-policies"; pwd`
+network_partitions_path=`cd "${script_path}/../../../../network-partitions/${iaas}"; pwd`
+deployment_policies_path=`cd "${script_path}/../../../../deployment-policies"; pwd`
 
 set -e
 
@@ -19,16 +22,16 @@ if [[ -z "${iaas}" ]]; then
     exit
 fi
 
-echo ${artifacts_path}/autoscaling-policy.json
+echo ${autoscaling_policies_path}/autoscaling-policy-1.json
 echo "Adding autoscale policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/autoscaling-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${autoscaling_policies_path}/autoscaling-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies
 
 echo "Adding network partitions..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-1.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
+curl -X POST -H "Content-Type: application/json" -d "@${network_partitions_path}/network-partition-2.json" -k -v -u admin:admin https://${host_ip}:9443/api/networkPartitions
 
 echo "Adding deployment policy..."
-curl -X POST -H "Content-Type: application/json" -d "@${artifacts_path}/deployment-policy.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
+curl -X POST -H "Content-Type: application/json" -d "@${deployment_policies_path}/deployment-policy-1.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies
 
 echo "Adding mysql cartridge..."
 curl -X POST -H "Content-Type: application/json" -d "@${cartridges_path}/mysql.json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/scripts/common/undeploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/scripts/common/undeploy.sh b/samples/applications/wordpress-extended-v2/scripts/common/undeploy.sh
index 410c429..c82fcae 100644
--- a/samples/applications/wordpress-extended-v2/scripts/common/undeploy.sh
+++ b/samples/applications/wordpress-extended-v2/scripts/common/undeploy.sh
@@ -22,4 +22,12 @@ curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://
 curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/cartridges/tomcat
 
 echo "Removing autoscale policies..."
-curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
\ No newline at end of file
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/autoscalingPolicies/autoscaling-policy-1
+
+echo "Removing deployment policies..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/deploymentPolicies/deployment-policy-1
+
+echo "Removing network partitions..."
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-1
+curl -X DELETE -H "Content-Type: application/json" -k -v -u admin:admin https://${host_ip}:${host_port}/api/networkPartitions/network-partition-2
+

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress-extended-v2/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress-extended-v2/scripts/kubernetes/deploy.sh b/samples/applications/wordpress-extended-v2/scripts/kubernetes/deploy.sh
index 32eff3c..0d614cc 100755
--- a/samples/applications/wordpress-extended-v2/scripts/kubernetes/deploy.sh
+++ b/samples/applications/wordpress-extended-v2/scripts/kubernetes/deploy.sh
@@ -8,8 +8,9 @@ prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 common_folder=`cd "${script_path}/../common"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernets-clusters"; pwd`
 
 echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/kubernetes-cluster.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-1.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
 
-bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/applications/wordpress/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/wordpress/scripts/kubernetes/deploy.sh b/samples/applications/wordpress/scripts/kubernetes/deploy.sh
index 32eff3c..0d614cc 100755
--- a/samples/applications/wordpress/scripts/kubernetes/deploy.sh
+++ b/samples/applications/wordpress/scripts/kubernetes/deploy.sh
@@ -8,8 +8,9 @@ prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 common_folder=`cd "${script_path}/../common"; pwd`
 iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernets-clusters"; pwd`
 
 echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/kubernetes-cluster.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-1.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
 
-bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file
+bash ${common_folder}/deploy.sh ${iaas}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/network-partitions/ec2/network-partition-1.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/ec2/network-partition-1.json b/samples/network-partitions/ec2/network-partition-1.json
new file mode 100644
index 0000000..2a5b7ec
--- /dev/null
+++ b/samples/network-partitions/ec2/network-partition-1.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-1",
+    "partitions": [
+        {
+            "id": "partition-1",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/network-partitions/ec2/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/ec2/network-partition-2.json b/samples/network-partitions/ec2/network-partition-2.json
new file mode 100644
index 0000000..0d07838
--- /dev/null
+++ b/samples/network-partitions/ec2/network-partition-2.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-2",
+    "partitions": [
+        {
+            "id": "partition-2",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/network-partitions/kubernetes/network-partition-1.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/kubernetes/network-partition-1.json b/samples/network-partitions/kubernetes/network-partition-1.json
new file mode 100644
index 0000000..2a5b7ec
--- /dev/null
+++ b/samples/network-partitions/kubernetes/network-partition-1.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-1",
+    "partitions": [
+        {
+            "id": "partition-1",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/network-partitions/kubernetes/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/kubernetes/network-partition-2.json b/samples/network-partitions/kubernetes/network-partition-2.json
new file mode 100644
index 0000000..0d07838
--- /dev/null
+++ b/samples/network-partitions/kubernetes/network-partition-2.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-2",
+    "partitions": [
+        {
+            "id": "partition-2",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/network-partitions/openstack/network-partition-1.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/openstack/network-partition-1.json b/samples/network-partitions/openstack/network-partition-1.json
new file mode 100644
index 0000000..2a5b7ec
--- /dev/null
+++ b/samples/network-partitions/openstack/network-partition-1.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-1",
+    "partitions": [
+        {
+            "id": "partition-1",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/36f0d3a6/samples/network-partitions/openstack/network-partition-2.json
----------------------------------------------------------------------
diff --git a/samples/network-partitions/openstack/network-partition-2.json b/samples/network-partitions/openstack/network-partition-2.json
new file mode 100644
index 0000000..0d07838
--- /dev/null
+++ b/samples/network-partitions/openstack/network-partition-2.json
@@ -0,0 +1,15 @@
+{
+    "id": "network-partition-2",
+    "partitions": [
+        {
+            "id": "partition-2",
+            "provider": "mock",
+            "property": [
+                {
+                    "name": "region",
+                    "value": "default"
+                }
+            ]
+        }
+    ]
+}


[19/50] [abbrv] stratos git commit: Removing unused kubernetes exceptions in autoscaler

Posted by re...@apache.org.
Removing unused kubernetes exceptions in autoscaler


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

Branch: refs/heads/docker-grouping-merge
Commit: 4b786cd6d804bd86be8ce581e8560f7cbd5c7696
Parents: c52f74c
Author: Imesh Gunaratne <im...@apache.org>
Authored: Fri Feb 27 23:20:17 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Fri Feb 27 23:20:17 2015 +0530

----------------------------------------------------------------------
 .../InvalidServiceGroupException.java           |  46 +
 .../InvalidKubernetesClusterException.java      |  49 -
 .../InvalidKubernetesHostException.java         |  49 -
 .../InvalidKubernetesMasterException.java       |  27 -
 .../InvalidServiceGroupException.java           |  46 -
 .../KubernetesEndpointValidationException.java  |  52 -
 .../NonExistingKubernetesClusterException.java  |  49 -
 .../NonExistingKubernetesHostException.java     |  48 -
 .../NonExistingKubernetesMasterException.java   |  48 -
 .../autoscaler/services/AutoscalerService.java  |   2 +-
 .../services/impl/AutoscalerServiceImpl.java    |   2 +-
 .../scripts/kubernetes/deploy.sh                |   5 +-
 .../src/main/resources/AutoscalerService.wsdl   | 963 +++++++++----------
 13 files changed, 526 insertions(+), 860 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/application/InvalidServiceGroupException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/application/InvalidServiceGroupException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/application/InvalidServiceGroupException.java
new file mode 100644
index 0000000..04884ea
--- /dev/null
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/application/InvalidServiceGroupException.java
@@ -0,0 +1,46 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.stratos.autoscaler.exception.application;
+
+public class InvalidServiceGroupException extends Exception {
+
+
+    private static final long serialVersionUID = 2651280146514042590L;
+
+    private String message;
+
+    public InvalidServiceGroupException(String msg) {
+        super(msg);
+        this.setMessage(msg);
+    }
+
+    public InvalidServiceGroupException(String msg, Exception ex) {
+        super(msg, ex);
+        this.setMessage(msg);
+    }
+
+    public String getMessage() {
+        return message;
+    }
+
+    public void setMessage(String message) {
+        this.message = message;
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesClusterException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesClusterException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesClusterException.java
deleted file mode 100644
index e4321b1..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesClusterException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling invalid Kubernetes cluster
- */
-public class InvalidKubernetesClusterException extends Exception {
-
-    private String message;
-
-    public InvalidKubernetesClusterException(String message, Exception exception){
-        super(message, exception);
-        this.message = message;
-    }
-
-    public InvalidKubernetesClusterException(Exception exception){
-        super(exception);
-    }
-
-    public InvalidKubernetesClusterException(String msg){
-        super(msg);
-        this.message = msg;
-    }
-
-    @Override
-    public String getMessage() {
-        return this.message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesHostException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesHostException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesHostException.java
deleted file mode 100644
index f0c651c..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesHostException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling invalid Kubernetes Host
- */
-public class InvalidKubernetesHostException extends Exception {
-
-    private String message;
-
-    public InvalidKubernetesHostException(String message, Exception exception){
-        super(message, exception);
-        this.message = message;
-    }
-
-    public InvalidKubernetesHostException(Exception exception){
-        super(exception);
-    }
-
-    public InvalidKubernetesHostException(String msg){
-        super(msg);
-        this.message = msg;
-    }
-
-    @Override
-    public String getMessage() {
-        return this.message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesMasterException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesMasterException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesMasterException.java
deleted file mode 100644
index 5852952..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidKubernetesMasterException.java
+++ /dev/null
@@ -1,27 +0,0 @@
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling invalid Kubernetes Master
- */
-public class InvalidKubernetesMasterException extends Exception {
-    private String message;
-
-    public InvalidKubernetesMasterException(String message, Exception exception){
-        super(message, exception);
-        this.message = message;
-    }
-
-    public InvalidKubernetesMasterException(Exception exception){
-        super(exception);
-    }
-
-    public InvalidKubernetesMasterException(String msg){
-        super(msg);
-        this.message = msg;
-    }
-
-    @Override
-    public String getMessage() {
-        return this.message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidServiceGroupException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidServiceGroupException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidServiceGroupException.java
deleted file mode 100644
index 6c1f709..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/InvalidServiceGroupException.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-public class InvalidServiceGroupException extends Exception {
-
-
-    private static final long serialVersionUID = 2651280146514042590L;
-
-    private String message;
-
-    public InvalidServiceGroupException(String msg) {
-        super(msg);
-        this.setMessage(msg);
-    }
-
-    public InvalidServiceGroupException(String msg, Exception ex) {
-        super(msg, ex);
-        this.setMessage(msg);
-    }
-
-    public String getMessage() {
-        return message;
-    }
-
-    public void setMessage(String message) {
-        this.message = message;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/KubernetesEndpointValidationException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/KubernetesEndpointValidationException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/KubernetesEndpointValidationException.java
deleted file mode 100644
index ce80ed7..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/KubernetesEndpointValidationException.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling Kubernetes endpoint validation
- */
-public class KubernetesEndpointValidationException extends Exception {
-    private String message;
-
-    public KubernetesEndpointValidationException(String message, Exception exception){
-        super(message, exception);
-        this.setMessage(message);
-    }
-
-    public KubernetesEndpointValidationException(String msg) {
-        super(msg);
-        this.message = msg;
-    }
-    public KubernetesEndpointValidationException(Exception exception){
-        super(exception);
-    }
-
-
-    public String getMessage() {
-        return message;
-    }
-
-
-    public void setMessage(String message) {
-        this.message = message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesClusterException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesClusterException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesClusterException.java
deleted file mode 100644
index 326494c..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesClusterException.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling non-existing Kubernetes cluster
- */
-public class NonExistingKubernetesClusterException extends Exception {
-
-    private String message;
-
-    public NonExistingKubernetesClusterException(String message, Exception exception){
-        super(message, exception);
-        this.message = message;
-    }
-
-    public NonExistingKubernetesClusterException(Exception exception){
-        super(exception);
-    }
-
-    public NonExistingKubernetesClusterException(String msg){
-        super(msg);
-        this.message = msg;
-    }
-
-    @Override
-    public String getMessage() {
-        return this.message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesHostException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesHostException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesHostException.java
deleted file mode 100644
index 99c2588..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesHostException.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling non-existing Kubernetes Host
- */
-public class NonExistingKubernetesHostException extends Exception {
-    private String message;
-
-    public NonExistingKubernetesHostException(String message, Exception exception){
-        super(message, exception);
-        this.message = message;
-    }
-
-    public NonExistingKubernetesHostException(Exception exception){
-        super(exception);
-    }
-
-    public NonExistingKubernetesHostException(String msg){
-        super(msg);
-        this.message = msg;
-    }
-
-    @Override
-    public String getMessage() {
-        return this.message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesMasterException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesMasterException.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesMasterException.java
deleted file mode 100644
index 48228b5..0000000
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/exception/kubernetes/NonExistingKubernetesMasterException.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-package org.apache.stratos.autoscaler.exception.kubernetes;
-
-/**
- * Exception class for handling non-existing Kubernetes Master
- */
-public class NonExistingKubernetesMasterException extends Exception {
-    private String message;
-
-    public NonExistingKubernetesMasterException(String message, Exception exception){
-        super(message, exception);
-        this.message = message;
-    }
-
-    public NonExistingKubernetesMasterException(Exception exception){
-        super(exception);
-    }
-
-    public NonExistingKubernetesMasterException(String msg){
-        super(msg);
-        this.message = msg;
-    }
-
-    @Override
-    public String getMessage() {
-        return this.message;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/AutoscalerService.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/AutoscalerService.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/AutoscalerService.java
index 183ff62..fb9d85f 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/AutoscalerService.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/services/AutoscalerService.java
@@ -25,7 +25,7 @@ import org.apache.stratos.autoscaler.applications.pojo.ApplicationContext;
 import org.apache.stratos.autoscaler.exception.AutoScalerException;
 import org.apache.stratos.autoscaler.exception.InvalidArgumentException;
 import org.apache.stratos.autoscaler.exception.application.ApplicationDefinitionException;
-import org.apache.stratos.autoscaler.exception.kubernetes.InvalidServiceGroupException;
+import org.apache.stratos.autoscaler.exception.application.InvalidServiceGroupException;
 import org.apache.stratos.autoscaler.exception.policy.InvalidPolicyException;
 import org.apache.stratos.autoscaler.pojo.ServiceGroup;
 import org.apache.stratos.autoscaler.pojo.policy.autoscale.AutoscalePolicy;

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/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 0d4bcfb..9c9a728 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
@@ -42,7 +42,7 @@ import org.apache.stratos.autoscaler.context.AutoscalerContext;
 import org.apache.stratos.autoscaler.exception.AutoScalerException;
 import org.apache.stratos.autoscaler.exception.InvalidArgumentException;
 import org.apache.stratos.autoscaler.exception.application.ApplicationDefinitionException;
-import org.apache.stratos.autoscaler.exception.kubernetes.InvalidServiceGroupException;
+import org.apache.stratos.autoscaler.exception.application.InvalidServiceGroupException;
 import org.apache.stratos.autoscaler.exception.policy.InvalidPolicyException;
 import org.apache.stratos.autoscaler.monitor.cluster.ClusterMonitor;
 import org.apache.stratos.autoscaler.pojo.Dependencies;

http://git-wip-us.apache.org/repos/asf/stratos/blob/4b786cd6/samples/applications/single-cartridge/scripts/kubernetes/deploy.sh
----------------------------------------------------------------------
diff --git a/samples/applications/single-cartridge/scripts/kubernetes/deploy.sh b/samples/applications/single-cartridge/scripts/kubernetes/deploy.sh
index 32eff3c..d6c47c1 100755
--- a/samples/applications/single-cartridge/scripts/kubernetes/deploy.sh
+++ b/samples/applications/single-cartridge/scripts/kubernetes/deploy.sh
@@ -7,9 +7,10 @@ iaas="kubernetes"
 prgdir=`dirname "$0"`
 script_path=`cd "$prgdir"; pwd`
 common_folder=`cd "${script_path}/../common"; pwd`
-iaas_artifacts_path=`cd "${script_path}/../../artifacts/${iaas}"; pwd`
+kubernetes_clusters_path=`cd "${script_path}/../../../../kubernetes-clusters"; pwd`
+
 
 echo "Adding kubernetes cluster..."
-curl -X POST -H "Content-Type: application/json" -d "@${iaas_artifacts_path}/kubernetes-cluster.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
+curl -X POST -H "Content-Type: application/json" -d "@${kubernetes_clusters_path}/kubernetes-cluster-1.json" -k -u admin:admin https://${host_ip}:${host_port}/api/kubernetesClusters
 
 bash ${common_folder}/deploy.sh ${iaas}
\ No newline at end of file


[16/50] [abbrv] stratos git commit: Removing kubernetes cluster id from network partition and adding it as a partition property

Posted by re...@apache.org.
Removing kubernetes cluster id from network partition and adding it as a partition property


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

Branch: refs/heads/docker-grouping-merge
Commit: eb9b873115db7c41fe2c7c7184c5dca40a5fb50d
Parents: 22fdf78
Author: Imesh Gunaratne <im...@apache.org>
Authored: Fri Feb 27 22:45:11 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Fri Feb 27 22:45:56 2015 +0530

----------------------------------------------------------------------
 .../stratos/cli/RestCommandLineService.java     |    7 +-
 .../controller/domain/NetworkPartition.java     |    9 -
 .../cloud/controller/domain/Partition.java      |   21 +-
 .../KubernetesPartitionValidator.java           |    2 +-
 .../impl/CloudControllerServiceImpl.java        |    8 +-
 .../impl/CloudControllerServiceUtil.java        |   38 +-
 .../beans/partition/NetworkPartitionBean.java   |    9 -
 .../util/converter/ObjectConverter.java         |    1 -
 .../main/resources/CloudControllerService.wsdl  | 2459 +++++++++---------
 9 files changed, 1244 insertions(+), 1310 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/RestCommandLineService.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/RestCommandLineService.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/RestCommandLineService.java
index 67d6b7c..76676c4 100644
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/RestCommandLineService.java
+++ b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/RestCommandLineService.java
@@ -1598,10 +1598,9 @@ public class RestCommandLineService {
 
             RowMapper<NetworkPartitionBean> networkPartitionMapper = new RowMapper<NetworkPartitionBean>() {
                 public String[] getData(NetworkPartitionBean partition) {
-                    String[] data = new String[3];
+                    String[] data = new String[2];
                     data[0] = partition.getId();
-                    data[1] = (partition.getKubernetesClusterId() != null) ? partition.getKubernetesClusterId() : "";
-                    data[2] = String.valueOf(partition.getPartitions().size());;
+                    data[1] = String.valueOf(partition.getPartitions().size());;
                     return data;
                 }
             };
@@ -1610,7 +1609,7 @@ public class RestCommandLineService {
             partitions = networkPartitionsList.toArray(partitions);
 
             System.out.println("Network partitions found:");
-            CliUtils.printTable(partitions, networkPartitionMapper, "PartitionId", "Kubernetes Cluster Id", "Partitions");
+            CliUtils.printTable(partitions, networkPartitionMapper, "Network Partition ID", "Number of Partitions");
         } catch (Exception e) {
             String message = "Error in listing network partitions";
             printError(message, e);

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/NetworkPartition.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/NetworkPartition.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/NetworkPartition.java
index e9efd88..f70d161 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/NetworkPartition.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/NetworkPartition.java
@@ -30,7 +30,6 @@ public class NetworkPartition implements Serializable {
     private static final long serialVersionUID = -8043298009352097370L;
 
     private String id;
-    private String kubernetesClusterId;
     private boolean activeByDefault;
     private Partition[] partitions;
 
@@ -82,12 +81,4 @@ public class NetworkPartition implements Serializable {
         }
         return null;
     }
-
-    public String getKubernetesClusterId() {
-        return kubernetesClusterId;
-    }
-
-    public void setKubernetesClusterId(String kubernetesClusterId) {
-        this.kubernetesClusterId = kubernetesClusterId;
-    }
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/Partition.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/Partition.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/Partition.java
index b84d914..c69d07a 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/Partition.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/domain/Partition.java
@@ -19,6 +19,7 @@
 package org.apache.stratos.cloud.controller.domain;
 
 import org.apache.stratos.common.Properties;
+import org.apache.stratos.common.Property;
 
 import java.io.Serializable;
 
@@ -28,6 +29,9 @@ import java.io.Serializable;
 public class Partition implements Serializable {
 
     private static final long serialVersionUID = 3725971287992010720L;
+
+    private static final String KUBERNETES_CLUSTER = "cluster";
+
     /**
      * provider should match with an IaasProvider type.
      */
@@ -35,7 +39,6 @@ public class Partition implements Serializable {
     private String id;
     private String description;
     private boolean isPublic;
-    private String kubernetesClusterId;
     private Properties properties = new Properties();
 
     /**
@@ -121,6 +124,14 @@ public class Partition implements Serializable {
         this.provider = provider;
     }
 
+    public String getKubernetesClusterId() {
+        Property property = properties.getProperty(KUBERNETES_CLUSTER);
+        if(property != null) {
+            return property.getValue();
+        }
+        return null;
+    }
+
     @Override
     public String toString() {
         return "Partition [id=" + id + ", description=" + description + ", isPublic=" + isPublic
@@ -139,12 +150,4 @@ public class Partition implements Serializable {
     public int hashCode() {
         return this.id.hashCode();
     }
-
-    public String getKubernetesClusterId() {
-        return kubernetesClusterId;
-    }
-
-    public void setKubernetesClusterId(String kubernetesClusterId) {
-        this.kubernetesClusterId = kubernetesClusterId;
-    }
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesPartitionValidator.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesPartitionValidator.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesPartitionValidator.java
index 0c79309..8eedc88 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesPartitionValidator.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesPartitionValidator.java
@@ -56,7 +56,7 @@ public class KubernetesPartitionValidator implements PartitionValidator {
 
         String kubernetesClusterId = partition.getKubernetesClusterId();
         if (StringUtils.isBlank(kubernetesClusterId)) {
-            String message = "Kubernetes cluster id not found in partition: [partition-id] " + partition.getId();
+            String message = "Kubernetes cluster not defined in partition: [partition-id] " + partition.getId();
             log.error(message);
             throw new InvalidPartitionException(message);
         }

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
index 3f17439..d39fb00 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceImpl.java
@@ -32,8 +32,6 @@ import org.apache.stratos.cloud.controller.domain.kubernetes.KubernetesHost;
 import org.apache.stratos.cloud.controller.domain.kubernetes.KubernetesMaster;
 import org.apache.stratos.cloud.controller.exception.*;
 import org.apache.stratos.cloud.controller.iaases.Iaas;
-import org.apache.stratos.cloud.controller.messaging.publisher.StatisticsDataPublisher;
-import org.apache.stratos.cloud.controller.messaging.publisher.TopologyEventPublisher;
 import org.apache.stratos.cloud.controller.messaging.topology.TopologyBuilder;
 import org.apache.stratos.cloud.controller.messaging.topology.TopologyManager;
 import org.apache.stratos.cloud.controller.services.CloudControllerService;
@@ -42,7 +40,6 @@ import org.apache.stratos.cloud.controller.util.CloudControllerUtil;
 import org.apache.stratos.common.Property;
 import org.apache.stratos.common.threading.StratosThreadPool;
 import org.apache.stratos.messaging.domain.topology.*;
-import org.apache.stratos.messaging.event.topology.MemberReadyToShutdownEvent;
 
 import java.net.MalformedURLException;
 import java.net.URL;
@@ -1501,10 +1498,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                     }
                 }
             }
-            
-            // overwrites partitions' kubernetes cluster ids with network partition's kubernetes cluster id
-            CloudControllerServiceUtil.overwritesPartitionsKubernetesClusterIdsWithNetworkPartitionKubernetesClusterId(networkPartition);
-            
+
             // adding network partition to CC-Context
             CloudControllerContext.getInstance().addNetworkPartition(networkPartition);
             // persisting CC-Context

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceUtil.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceUtil.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceUtil.java
index 7cc8bed..dc492d5 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceUtil.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/services/impl/CloudControllerServiceUtil.java
@@ -19,22 +19,11 @@
 
 package org.apache.stratos.cloud.controller.services.impl;
 
-import java.util.List;
-import java.util.Properties;
-
 import com.google.common.net.InetAddresses;
-
-import org.apache.commons.lang.StringUtils;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.apache.stratos.cloud.controller.context.CloudControllerContext;
-import org.apache.stratos.cloud.controller.domain.DeploymentPolicy;
-import org.apache.stratos.cloud.controller.domain.IaasProvider;
-import org.apache.stratos.cloud.controller.domain.MemberContext;
-import org.apache.stratos.cloud.controller.domain.NetworkPartition;
-import org.apache.stratos.cloud.controller.domain.NetworkPartitionRef;
-import org.apache.stratos.cloud.controller.domain.Partition;
-import org.apache.stratos.cloud.controller.domain.PartitionRef;
+import org.apache.stratos.cloud.controller.domain.*;
 import org.apache.stratos.cloud.controller.exception.InvalidDeploymentPolicyException;
 import org.apache.stratos.cloud.controller.exception.InvalidIaasProviderException;
 import org.apache.stratos.cloud.controller.exception.InvalidPartitionException;
@@ -46,6 +35,8 @@ import org.apache.stratos.cloud.controller.util.CloudControllerUtil;
 import org.apache.stratos.common.constants.StratosConstants;
 import org.apache.stratos.messaging.domain.topology.MemberStatus;
 
+import java.util.Properties;
+
 /**
  * Cloud controller service utility methods.
  */
@@ -236,27 +227,4 @@ public class CloudControllerServiceUtil {
 			}
 		}
     }
-    
-    /**
-     * Overwrites partition's kubernetes cluster ids with network partition's kubernetes cluster ids.
-     * @param networkPartitions
-     */
-    public static void overwritesPartitionsKubernetesClusterIdsWithNetworkPartitionKubernetesClusterId(NetworkPartition networkPartition) {
-
-    	if(StringUtils.isNotBlank(networkPartition.getKubernetesClusterId())) {
-    		Partition[] partitions = networkPartition.getPartitions();
-    		if(partitions != null) {
-    			for(Partition partition : partitions) {
-    				if(partition != null) {
-    					if(log.isInfoEnabled()) {
-    						log.info(String.format("Overwriting partition's kubernetes cluster id: " +
-    								"[network-partition-id] %s [partition-id] %s [kubernetes-cluster-id] %s", 
-    								networkPartition.getId(), partition.getId(), networkPartition.getKubernetesClusterId()));
-    					}
-    					partition.setKubernetesClusterId(networkPartition.getKubernetesClusterId());
-    				}
-    			}
-    		}
-    	}
-    }
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/partition/NetworkPartitionBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/partition/NetworkPartitionBean.java b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/partition/NetworkPartitionBean.java
index 9a6cd37..dcdea43 100644
--- a/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/partition/NetworkPartitionBean.java
+++ b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/partition/NetworkPartitionBean.java
@@ -26,7 +26,6 @@ import java.util.List;
 public class NetworkPartitionBean {
 
     private String id;
-    private String kubernetesClusterId;
     private List<PartitionBean> partitions;
 
     public String getId() {
@@ -37,14 +36,6 @@ public class NetworkPartitionBean {
         this.id = id;
     }
 
-    public String getKubernetesClusterId() {
-        return kubernetesClusterId;
-    }
-
-    public void setKubernetesClusterId(String kubernetesClusterId) {
-        this.kubernetesClusterId = kubernetesClusterId;
-    }
-
     public List<PartitionBean> getPartitions() {
         return partitions;
     }

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/util/converter/ObjectConverter.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/util/converter/ObjectConverter.java b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/util/converter/ObjectConverter.java
index a53c511..0f05e5a 100644
--- a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/util/converter/ObjectConverter.java
+++ b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/util/converter/ObjectConverter.java
@@ -522,7 +522,6 @@ public class ObjectConverter {
 
         org.apache.stratos.cloud.controller.stub.domain.NetworkPartition networkPartition = new org.apache.stratos.cloud.controller.stub.domain.NetworkPartition();
         networkPartition.setId(networkPartitionBean.getId());
-        networkPartition.setKubernetesClusterId(networkPartitionBean.getKubernetesClusterId());
         if (networkPartitionBean.getPartitions() != null && !networkPartitionBean.getPartitions().isEmpty()) {
             networkPartition.setPartitions(convertPartitionToCCPartitionPojos(networkPartitionBean.getPartitions()));
         }


[15/50] [abbrv] stratos git commit: Removing kubernetes cluster id from network partition and adding it as a partition property

Posted by re...@apache.org.
http://git-wip-us.apache.org/repos/asf/stratos/blob/eb9b8731/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
index 499d49c..48e6d51 100644
--- a/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
+++ b/service-stubs/org.apache.stratos.cloud.controller.service.stub/src/main/resources/CloudControllerService.wsdl
@@ -1,669 +1,668 @@
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns="http://impl.services.controller.cloud.stratos.apache.org" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax228="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax233="http://domain.common.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax230="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax222="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:ax224="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax225="http://common.stratos.apache.org/xsd" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
-    <wsdl:documentation>CloudControllerService</wsdl:documentation>
+<?xml version="1.0" encoding="UTF-8"?><wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ns="http://impl.services.controller.cloud.stratos.apache.org" xmlns:ax27="http://domain.common.stratos.apache.org/xsd" xmlns:ax23="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax24="http://common.stratos.apache.org/xsd" xmlns:ax21="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:ax211="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
     <wsdl:types>
-        <xs:schema xmlns:ax232="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax229="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax227="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax223="http://exception.controller.cloud.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
-            <xs:import namespace="http://exception.controller.cloud.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://domain.controller.cloud.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://topology.domain.messaging.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd"></xs:import>
-            <xs:element name="CloudControllerServiceInvalidClusterException">
+        <xs:schema xmlns:ax213="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax210="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax26="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax22="http://exception.controller.cloud.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.controller.cloud.stratos.apache.org">
+            <xs:import namespace="http://exception.controller.cloud.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://domain.controller.cloud.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://topology.domain.messaging.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd"/>
+            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax222:InvalidClusterException"></xs:element>
+                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax21:CartridgeNotFoundException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstances">
+            <xs:element name="registerService">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="registrant" nillable="true" type="ax26:Registrant"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
+            <xs:element name="registerServiceResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax222:CartridgeNotFoundException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgeInfo">
+            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax21:InvalidServiceGroupException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgeInfoResponse">
+            <xs:element name="getServiceGroupSubGroups">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:CartridgeInfo"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidPartitionException">
+            <xs:element name="getServiceGroupSubGroupsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax222:InvalidPartitionException"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
+            <xs:element name="getServiceGroupCartridges">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax222:InvalidCartridgeTypeException"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validateDeploymentPolicy">
+            <xs:element name="getServiceGroupCartridgesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax224:Partition"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validateDeploymentPolicyResponse">
+            <xs:element name="getServiceGroupDependencies">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validatePartition">
+            <xs:element name="getServiceGroupDependenciesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax224:Partition"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:Dependencies"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validatePartitionResponse">
+            <xs:element name="CloudControllerServiceInvalidPartitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax21:InvalidPartitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getClusterContext">
+            <xs:element name="validatePartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax26:Partition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getClusterContextResponse">
+            <xs:element name="validatePartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:ClusterContext"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateClusterStatus">
+            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="status" nillable="true" type="ax229:ClusterStatus"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax21:InvalidCartridgeTypeException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
+            <xs:element name="validateDeploymentPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax222:ApplicationClusterRegistrationException"></xs:element>
+                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax26:Partition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="createApplicationClusters">
+            <xs:element name="validateDeploymentPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="appId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="appClustersContexts" nillable="true" type="ax224:ApplicationClusterContext"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceClusterInstanceCreationException">
+            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="ClusterInstanceCreationException" nillable="true" type="ax222:ClusterInstanceCreationException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax21:InvalidIaasProviderException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="createClusterInstance">
+            <xs:element name="CloudControllerServiceCloudControllerException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceType" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="partitionId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax21:CloudControllerException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusters">
+            <xs:element name="startInstances">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax26:InstanceContext"/>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClustersResponse">
+            <xs:element name="startInstancesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax232:KubernetesCluster"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:MemberContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
+            <xs:element name="CloudControllerServiceInvalidClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax222:NonExistingKubernetesClusterException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax21:InvalidClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getMasterForKubernetesCluster">
+            <xs:element name="terminateInstances">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getMasterForKubernetesClusterResponse">
+            <xs:element name="updateClusterStatus">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax232:KubernetesMaster"></xs:element>
+                        <xs:element minOccurs="0" name="serviceName" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="status" nillable="true" type="ax29:ClusterStatus"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getHostsForKubernetesCluster">
+            <xs:element name="CloudControllerServiceUnregisteredClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax21:UnregisteredClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getHostsForKubernetesClusterResponse">
+            <xs:element name="unregisterService">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax232:KubernetesHost"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceDeploymentPolicyAlreadyExistsException">
+            <xs:element name="getCartridgeInfo">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="DeploymentPolicyAlreadyExistsException" nillable="true" type="ax222:DeploymentPolicyAlreadyExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidDeploymentPolicyException">
+            <xs:element name="getCartridgeInfoResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidDeploymentPolicyException" nillable="true" type="ax222:InvalidDeploymentPolicyException"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:CartridgeInfo"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addDeployementPolicy">
+            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax21:ApplicationClusterRegistrationException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceDeploymentPolicyNotExistsException">
+            <xs:element name="createApplicationClusters">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax222:DeploymentPolicyNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="appId" nillable="true" type="xs:string"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="appClustersContexts" nillable="true" type="ax26:ApplicationClusterContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateDeployementPolicy">
+            <xs:element name="CloudControllerServiceClusterInstanceCreationException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="ClusterInstanceCreationException" nillable="true" type="ax21:ClusterInstanceCreationException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeDeployementPolicy">
+            <xs:element name="createClusterInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="serviceType" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="alias" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="instanceId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="partitionId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax222:InvalidServiceGroupException"></xs:element>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax21:NonExistingKubernetesClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupSubGroups">
+            <xs:element name="getMasterForKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupSubGroupsResponse">
+            <xs:element name="getMasterForKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax213:KubernetesMaster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupCartridges">
+            <xs:element name="getHostsForKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupCartridgesResponse">
+            <xs:element name="getHostsForKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax213:KubernetesHost"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupDependencies">
+            <xs:element name="CloudControllerServiceInvalidKubernetesHostException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidKubernetesHostException" nillable="true" type="ax21:InvalidKubernetesHostException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupDependenciesResponse">
+            <xs:element name="addKubernetesHost">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:Dependencies"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax213:KubernetesHost"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="addKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax222:InvalidIaasProviderException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCloudControllerException">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax222:CloudControllerException"></xs:element>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax21:NonExistingKubernetesHostException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstances">
+            <xs:element name="updateKubernetesHost">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax224:InstanceContext"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax213:KubernetesHost"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstancesResponse">
+            <xs:element name="updateKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPolicy">
+            <xs:element name="CloudControllerServiceInvalidKubernetesMasterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidKubernetesMasterException" nillable="true" type="ax21:InvalidKubernetesMasterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPolicyResponse">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesMasterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesMasterException" nillable="true" type="ax21:NonExistingKubernetesMasterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPolicies">
+            <xs:element name="updateKubernetesMaster">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax213:KubernetesMaster"/>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getDeploymentPoliciesResponse">
+            <xs:element name="updateKubernetesMasterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:DeploymentPolicy"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
+            <xs:element name="CloudControllerServiceDeploymentPolicyAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax222:InvalidCartridgeDefinitionException"></xs:element>
+                        <xs:element minOccurs="0" name="DeploymentPolicyAlreadyExistsException" nillable="true" type="ax21:DeploymentPolicyAlreadyExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
+            <xs:element name="CloudControllerServiceInvalidDeploymentPolicyException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax222:CartridgeDefinitionNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidDeploymentPolicyException" nillable="true" type="ax21:InvalidDeploymentPolicyException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridge">
+            <xs:element name="addDeployementPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
+                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax26:DeploymentPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridges">
+            <xs:element name="CloudControllerServiceDeploymentPolicyNotExistsException">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax21:DeploymentPolicyNotExistsException"/>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgesResponse">
+            <xs:element name="updateDeployementPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="ax26:DeploymentPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeCartridge">
+            <xs:element name="removeDeployementPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNetworkPartitionAlreadyExistsException">
+            <xs:element name="CloudControllerServiceNetworkPartitionNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NetworkPartitionAlreadyExistsException" nillable="true" type="ax222:NetworkPartitionAlreadyExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="NetworkPartitionNotExistsException" nillable="true" type="ax21:NetworkPartitionNotExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addNetworkPartition">
+            <xs:element name="updateNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax224:NetworkPartition"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitions">
+            <xs:element name="getCartridges">
                 <xs:complexType>
-                    <xs:sequence></xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionsResponse">
+            <xs:element name="getCartridgesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax224:NetworkPartition"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartition">
+            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax21:InvalidCartridgeDefinitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionResponse">
+            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:NetworkPartition"></xs:element>
+                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax21:CartridgeAlreadyExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNetworkPartitionNotExistsException">
+            <xs:element name="addCartridge">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NetworkPartitionNotExistsException" nillable="true" type="ax222:NetworkPartitionNotExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax26:CartridgeConfig"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeNetworkPartition">
+            <xs:element name="getDeploymentPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateNetworkPartition">
+            <xs:element name="getDeploymentPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax224:NetworkPartition"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:DeploymentPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesHostException">
+            <xs:element name="getDeploymentPolicies">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesHostException" nillable="true" type="ax222:InvalidKubernetesHostException"></xs:element>
-                    </xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesHost">
+            <xs:element name="getDeploymentPoliciesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
-                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax232:KubernetesHost"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:DeploymentPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesHostResponse">
+            <xs:element name="CloudControllerServiceNetworkPartitionAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="NetworkPartitionAlreadyExistsException" nillable="true" type="ax21:NetworkPartitionAlreadyExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesMasterException">
+            <xs:element name="addNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesMasterException" nillable="true" type="ax222:InvalidKubernetesMasterException"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesMasterException">
+            <xs:element name="getNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesMasterException" nillable="true" type="ax222:NonExistingKubernetesMasterException"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesMaster">
+            <xs:element name="getNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax232:KubernetesMaster"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesMasterResponse">
+            <xs:element name="getNetworkPartitions">
+                <xs:complexType>
+                    <xs:sequence/>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getNetworkPartitionsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
+            <xs:element name="removeNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax222:NonExistingKubernetesHostException"></xs:element>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesHost">
+            <xs:element name="removeCartridge">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax232:KubernetesHost"></xs:element>
+                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesHostResponse">
+            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax21:CartridgeDefinitionNotExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
+            <xs:element name="updateCartridge">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax222:CartridgeAlreadyExistsException"></xs:element>
+                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax26:CartridgeConfig"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addCartridge">
+            <xs:element name="getServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax224:CartridgeConfig"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
+            <xs:element name="getServiceGroupResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax222:InvalidKubernetesClusterException"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesCluster">
+            <xs:element name="addServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax232:KubernetesCluster"></xs:element>
+                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax26:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesClusterResponse">
+            <xs:element name="removeServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesCluster">
+            <xs:element name="getClusterContext">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusterResponse">
+            <xs:element name="getClusterContextResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax232:KubernetesCluster"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ClusterContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="removeKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="removeKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="removeKubernetesHost">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="removeKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="CloudControllerServiceInvalidMemberException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax222:InvalidMemberException"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstance">
+            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax21:InvalidKubernetesClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceUnregisteredClusterException">
+            <xs:element name="addKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax222:UnregisteredClusterException"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="unregisterService">
+            <xs:element name="addKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstance">
+            <xs:element name="getKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax224:InstanceContext"></xs:element>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstanceResponse">
+            <xs:element name="getKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:MemberContext"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addServiceGroup">
+            <xs:element name="getKubernetesClusters">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax224:ServiceGroup"></xs:element>
-                    </xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeServiceGroup">
+            <xs:element name="getKubernetesClustersResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroup">
+            <xs:element name="startInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax26:InstanceContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="startInstanceResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax224:ServiceGroup"></xs:element>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:MemberContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="registerService">
+            <xs:element name="CloudControllerServiceInvalidMemberException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="registrant" nillable="true" type="ax224:Registrant"></xs:element>
+                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax21:InvalidMemberException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="registerServiceResponse">
+            <xs:element name="terminateInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"></xs:element>
+                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -673,7 +672,7 @@
                 <xs:complexContent>
                     <xs:extension base="xs:Enum">
                         <xs:sequence>
-                            <xs:element minOccurs="0" name="code" type="xs:int"></xs:element>
+                            <xs:element minOccurs="0" name="code" type="xs:int"/>
                         </xs:sequence>
                     </xs:extension>
                 </xs:complexContent>
@@ -682,2296 +681,2286 @@
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://common.stratos.apache.org/xsd">
             <xs:complexType name="Properties">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax225:Property"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax24:Property"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Property">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://exception.controller.cloud.stratos.apache.org/xsd">
-            <xs:complexType name="InvalidClusterException">
+            <xs:complexType name="CartridgeNotFoundException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="CartridgeNotFoundException">
+            <xs:complexType name="InvalidServiceGroupException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="InvalidPartitionException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="InvalidCartridgeTypeException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="ApplicationClusterRegistrationException">
+            <xs:complexType name="InvalidIaasProviderException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="ClusterInstanceCreationException">
+            <xs:complexType name="CloudControllerException">
+                <xs:complexContent>
+                    <xs:extension base="xs:RuntimeException">
+                        <xs:sequence/>
+                    </xs:extension>
+                </xs:complexContent>
+            </xs:complexType>
+            <xs:complexType name="InvalidClusterException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NonExistingKubernetesClusterException">
+            <xs:complexType name="UnregisteredClusterException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="DeploymentPolicyAlreadyExistsException">
-                <xs:sequence></xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="InvalidDeploymentPolicyException">
-                <xs:sequence></xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="DeploymentPolicyNotExistsException">
-                <xs:sequence></xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="InvalidServiceGroupException">
+            <xs:complexType name="ApplicationClusterRegistrationException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidIaasProviderException">
+            <xs:complexType name="ClusterInstanceCreationException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="CloudControllerException">
-                <xs:complexContent>
-                    <xs:extension base="xs:RuntimeException">
-                        <xs:sequence></xs:sequence>
-                    </xs:extension>
-                </xs:complexContent>
-            </xs:complexType>
-            <xs:complexType name="InvalidCartridgeDefinitionException">
+            <xs:complexType name="NonExistingKubernetesClusterException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="CartridgeDefinitionNotExistsException">
+            <xs:complexType name="InvalidKubernetesHostException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NetworkPartitionAlreadyExistsException">
-                <xs:sequence></xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="NetworkPartitionNotExistsException">
-                <xs:sequence></xs:sequence>
-            </xs:complexType>
-            <xs:complexType name="InvalidKubernetesHostException">
+            <xs:complexType name="NonExistingKubernetesHostException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="InvalidKubernetesMasterException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="NonExistingKubernetesMasterException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NonExistingKubernetesHostException">
+            <xs:complexType name="DeploymentPolicyAlreadyExistsException">
+                <xs:sequence/>
+            </xs:complexType>
+            <xs:complexType name="InvalidDeploymentPolicyException">
+                <xs:sequence/>
+            </xs:complexType>
+            <xs:complexType name="DeploymentPolicyNotExistsException">
+                <xs:sequence/>
+            </xs:complexType>
+            <xs:complexType name="NetworkPartitionNotExistsException">
+                <xs:sequence/>
+            </xs:complexType>
+            <xs:complexType name="InvalidCartridgeDefinitionException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="CartridgeAlreadyExistsException">
-                <xs:sequence></xs:sequence>
+                <xs:sequence/>
             </xs:complexType>
-            <xs:complexType name="InvalidKubernetesClusterException">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
-                </xs:sequence>
+            <xs:complexType name="NetworkPartitionAlreadyExistsException">
+                <xs:sequence/>
             </xs:complexType>
-            <xs:complexType name="InvalidMemberException">
+            <xs:complexType name="CartridgeDefinitionNotExistsException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="UnregisteredClusterException">
+            <xs:complexType name="InvalidKubernetesClusterException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-        </xs:schema>
-        <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://domain.common.stratos.apache.org/xsd">
-            <xs:complexType name="NameValuePair">
+            <xs:complexType name="InvalidMemberException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax231="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd">
-            <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
-            <xs:complexType name="KubernetesCluster">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="kubernetesHosts" nillable="true" type="ax230:KubernetesHost"></xs:element>
-                    <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax230:KubernetesMaster"></xs:element>
-                    <xs:element minOccurs="0" name="portRange" nillable="true" type="ax230:PortRange"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax231:Properties"></xs:element>
-                </xs:sequence>
-            </xs:complexType>
+        <xs:schema xmlns:ax212="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd">
+            <xs:import namespace="http://common.stratos.apache.org/xsd"/>
             <xs:complexType name="KubernetesHost">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="hostId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="hostname" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="privateIPAddress" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax231:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="publicIPAddress" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="hostId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="hostname" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="privateIPAddress" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax212:Properties"/>
+                    <xs:element minOccurs="0" name="publicIPAddress" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="KubernetesMaster">
                 <xs:complexContent>
-                    <xs:extension base="ax230:KubernetesHost">
+                    <xs:extension base="ax211:KubernetesHost">
                         <xs:sequence>
-                            <xs:element minOccurs="0" name="endpoint" nillable="true" type="xs:string"></xs:element>
+                            <xs:element minOccurs="0" name="endpoint" nillable="true" type="xs:string"/>
                         </xs:sequence>
                     </xs:extension>
                 </xs:complexContent>
             </xs:complexType>
-            <xs:complexType name="PortRange">
+            <xs:complexType name="KubernetesCluster">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="lower" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="upper" type="xs:int"></xs:element>
+                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="kubernetesHosts" nillable="true" type="ax211:KubernetesHost"/>
+                    <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax211:KubernetesMaster"/>
+                    <xs:element minOccurs="0" name="portRange" nillable="true" type="ax211:PortRange"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax212:Properties"/>
                 </xs:sequence>
             </xs:complexType>
-        </xs:schema>
-        <xs:schema xmlns:ax234="http://domain.common.stratos.apache.org/xsd" xmlns:ax226="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://domain.controller.cloud.stratos.apache.org/xsd">
-            <xs:import namespace="http://common.stratos.apache.org/xsd"></xs:import>
-            <xs:import namespace="http://domain.common.stratos.apache.org/xsd"></xs:import>
-            <xs:complexType name="CartridgeInfo">
+            <xs:complexType name="PortRange">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="appTypes" nillable="true" type="ax224:AppType"></xs:element>
-                    <xs:element minOccurs="0" name="baseDir" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="category" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="defaultAutoscalingPolicy" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="defaultDeploymentPolicy" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="deploymentDirs" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="displayName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="lbConfig" nillable="true" type="ax224:LoadbalancerConfig"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="metadataKeys" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="multiTenant" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="persistence" nillable="true" type="ax224:Persistence"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="portMappings" nillable="true" type="ax224:PortMapping"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax225:Property"></xs:element>
-                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="serviceGroup" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="tenantPartitions" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="version" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="lower" type="xs:int"/>
+                    <xs:element minOccurs="0" name="upper" type="xs:int"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="AppType">
+        </xs:schema>
+        <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://domain.common.stratos.apache.org/xsd">
+            <xs:complexType name="NameValuePair">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="appSpecificMapping" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="LoadbalancerConfig">
+        </xs:schema>
+        <xs:schema xmlns:ax28="http://domain.common.stratos.apache.org/xsd" xmlns:ax25="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://domain.controller.cloud.stratos.apache.org/xsd">
+            <xs:import namespace="http://common.stratos.apache.org/xsd"/>
+            <xs:import namespace="http://domain.common.stratos.apache.org/xsd"/>
+            <xs:complexType name="Registrant">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="autoScalerPolicyName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="payload" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="persistence" nillable="true" type="ax23:Persistence"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25:Properties"/>
+                    <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Persistence">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="persistanceRequired" type="xs:boolean"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax224:Volume"></xs:element>
+                    <xs:element minOccurs="0" name="persistanceRequired" type="xs:boolean"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax23:Volume"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Volume">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="device" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="iaasType" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="mappingPath" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="removeOntermination" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="size" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="snapshotId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="volumeId" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="device" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="iaasType" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="mappingPath" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="removeOntermination" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="size" type="xs:int"/>
+                    <xs:element minOccurs="0" name="snapshotId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="volumeId" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="PortMapping">
+            <xs:complexType name="Dependencies">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="kubernetesServicePort" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="kubernetesServicePortMapping" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="port" type="xs:int"></xs:element>
-                    <xs:element minOccurs="0" name="protocol" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="proxyPort" type="xs:int"></xs:element>
+                    <xs:element minOccurs="0" name="killBehaviour" nillable="true" type="xs:string"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="startupOrders" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Partition">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"></xs:element>
+                    <xs:element minOccurs="0" name="description" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="isPublic" type="xs:boolean"/>
+                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25:Properties"/>
+                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="ClusterContext">
+            <xs:complexType name="InstanceContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="kubernetesServices" nillable="true" type="xs:anyType"></xs:element>
-                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="payload" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="timeoutInMillis" type="xs:long"></xs:element>
-                    <xs:element minOccurs="0" name="volumeRequired" type="xs:boolean"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax224:Volume"></xs:element>
+                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterInstanceId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="initTime" type="xs:long"/>
+                    <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="obsoleteExpiryTime" type="xs:long"/>
+                    <xs:element minOccurs="0" name="partition" nillable="true" type="ax23:Partition"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25:Properties"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="ApplicationClusterContext">
+            <xs:complexType name="MemberContext">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="autoscalePolicyName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"></xs:element>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyClusterIds" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="deploymentPolicyName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="lbCluster" type="xs:boolean"></xs:element>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax225:Properties"></xs:element>
-                    <xs:element minOccurs="0" name="tenantRange" nillable="true" type="xs:string"></xs:element>
-                    <xs:element minOccurs="0" name="textPayload" nillable="true" type="xs:string"></xs:element>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="allocatedIPs" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterInstanceId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="defaultPrivateIP" nillable="true" type="xs:string"/>
+        

<TRUNCATED>

[41/50] [abbrv] stratos git commit: Synchronize generateKubernetesServicePorts() method to avoid port collisions

Posted by re...@apache.org.
Synchronize generateKubernetesServicePorts() method to avoid port collisions


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

Branch: refs/heads/docker-grouping-merge
Commit: 960e4240f2eeed2a2a14a10783f1c9aea97ed2eb
Parents: bc2e716
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sun Mar 1 20:46:35 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sun Mar 1 20:46:35 2015 +0530

----------------------------------------------------------------------
 .../iaases/kubernetes/KubernetesIaas.java       | 60 +++++++++++---------
 1 file changed, 34 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/960e4240/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
index 07da283..d8b06fc 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/iaases/kubernetes/KubernetesIaas.java
@@ -516,40 +516,48 @@ public class KubernetesIaas extends Iaas {
         return false;
     }
 
+    /**
+     * Generate kubernetes service ports for cluster.
+     * @param kubernetesClusterContext
+     * @param clusterId
+     * @param cartridge
+     */
     private void generateKubernetesServicePorts(KubernetesClusterContext kubernetesClusterContext, String clusterId,
                                                 Cartridge cartridge) {
-        if(cartridge != null) {
-            StringBuilder portMappingStrBuilder = new StringBuilder();
-            for (PortMapping portMapping : cartridge.getPortMappings()) {
-                if(portMapping.getKubernetesServicePort() == 0) {
-                    int nextServicePort = kubernetesClusterContext.getNextServicePort();
-                    if (nextServicePort == -1) {
-                        throw new RuntimeException(String.format("Could not generate service port: [cluster-id] %s " +
-                                        "[port] %d", clusterId, portMapping.getPort()));
-                    }
-                    portMapping.setKubernetesServicePort(nextServicePort);
-	                portMapping.setKubernetesServicePortMapping(true);
+        synchronized (KubernetesIaas.class) {
+            if (cartridge != null) {
+                StringBuilder portMappingStrBuilder = new StringBuilder();
+                for (PortMapping portMapping : cartridge.getPortMappings()) {
+                    if (portMapping.getKubernetesServicePort() == 0) {
+                        int nextServicePort = kubernetesClusterContext.getNextServicePort();
+                        if (nextServicePort == -1) {
+                            throw new RuntimeException(String.format("Could not generate service port: [cluster-id] %s " +
+                                    "[port] %d", clusterId, portMapping.getPort()));
+                        }
+                        portMapping.setKubernetesServicePort(nextServicePort);
+                        portMapping.setKubernetesServicePortMapping(true);
 
-                    // Add port mappings to payload
-                    if(portMappingStrBuilder.toString().length() > 0) {
-                        portMappingStrBuilder.append(":");
-                    }
-                    portMappingStrBuilder.append(String.format("PROTOCOL=%s|PORT=%d|PROXY_PORT=%d",
-                            portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
+                        // Add port mappings to payload
+                        if (portMappingStrBuilder.toString().length() > 0) {
+                            portMappingStrBuilder.append(":");
+                        }
+                        portMappingStrBuilder.append(String.format("PROTOCOL=%s|PORT=%d|PROXY_PORT=%d",
+                                portMapping.getProtocol(), portMapping.getPort(), portMapping.getProxyPort()));
 
-                    if (log.isInfoEnabled()) {
-                        log.info(String.format("Kubernetes service port generated: [cluster-id] %s [port] %d " +
-                                "[service-port] %d", clusterId, portMapping.getPort(), nextServicePort));
+                        if (log.isInfoEnabled()) {
+                            log.info(String.format("Kubernetes service port generated: [cluster-id] %s [port] %d " +
+                                    "[service-port] %d", clusterId, portMapping.getPort(), nextServicePort));
+                        }
                     }
                 }
-            }
 
-            NameValuePair nameValuePair = new NameValuePair(PORT_MAPPINGS, portMappingStrBuilder.toString());
-            payload.add(nameValuePair);
+                NameValuePair nameValuePair = new NameValuePair(PORT_MAPPINGS, portMappingStrBuilder.toString());
+                payload.add(nameValuePair);
 
-            // Persist service ports added to port mappings
-            CloudControllerContext.getInstance().updateKubernetesClusterContext(kubernetesClusterContext);
-            CloudControllerContext.getInstance().persist();
+                // Persist service ports added to port mappings
+                CloudControllerContext.getInstance().updateKubernetesClusterContext(kubernetesClusterContext);
+                CloudControllerContext.getInstance().persist();
+            }
         }
     }
 


[44/50] [abbrv] stratos git commit: PCA - Metadata client related changes

Posted by re...@apache.org.
PCA - Metadata client related changes


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

Branch: refs/heads/docker-grouping-merge
Commit: f9948c5e3f259fb3b25b5ec40740fdbaa14e4d8d
Parents: 08045d9
Author: Chamila de Alwis <ch...@wso2.com>
Authored: Sun Mar 1 22:04:55 2015 +0530
Committer: Chamila de Alwis <ch...@wso2.com>
Committed: Sun Mar 1 23:54:57 2015 +0530

----------------------------------------------------------------------
 .../cartridge.agent/cartridge.agent/agent.conf  |   3 +-
 .../cartridge.agent/cartridge.agent/config.py   |   6 +-
 .../cartridge.agent/constants.py                |   3 +
 .../cartridge.agent/mdsclient.py                | 118 +++++++++++++++++++
 .../modules/artifactmgt/git/agentgithandler.py  |   5 +-
 .../modules/event/eventhandler.py               |   8 +-
 .../src/test/resources/agent.conf               |   1 +
 .../src/test/resources/payload/launch-params    |   2 +-
 .../src/test/resources/payload/launch-params2   |   1 +
 9 files changed, 140 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
index 1e1f764..51f5831 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/agent.conf
@@ -38,7 +38,8 @@ monitoring.server.secure.port         =MONITORING-SERVER-SECURE-PORT
 monitoring.server.admin.username      =MONITORING-SERVER-ADMIN-USERNAME
 monitoring.server.admin.password      =MONITORING-SERVER-ADMIN-PASSWORD
 log.file.paths                        =LOG_FILE_PATHS
-APPLICATION_PATH                      =APPLICATION_PATH
+APPLICATION_PATH                      =APPLICATION-PATH
+METADATA_SERVICE_URL                  =METADATA-SERVICE-URL
 super.tenant.repository.path          =/repository/deployment/server/
 tenant.repository.path                =/repository/tenants/
 extension.instance.started            =instance-started.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
index 33d2fbb..1ad9499 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/config.py
@@ -296,7 +296,11 @@ class CartridgeAgentConfiguration:
                     for param in metadata_payload_content.split(","):
                         if param.strip() != "":
                             param_value = param.strip().split("=")
-                            self.__payload_params[param_value[0]] = param_value[1]
+                            try:
+                                self.__payload_params[param_value[0]] = param_value[1]
+                            except IndexError:
+                                # If an index error comes when reading values, keep on reading
+                                pass
 
                     # self.payload_params = dict(
                     #     param.split("=") for param in metadata_payload_content.split(","))

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
index 1427a2b..7331d7f 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/constants.py
@@ -43,6 +43,8 @@ PERSISTENCE_MAPPING = "PERSISTENCE_MAPPING"
 DEPENDENCY_CLUSTER_IDS = "DEPENDENCY_CLUSTER_IDS"
 EXPORT_METADATA_KEYS = "EXPORT_METADATA_KEYS"
 IMPORT_METADATA_KEYS = "IMPORT_METADATA_KEYS"
+CARTRIDGE_ALIAS = "CARTRIDGE_ALIAS"
+TOKEN = "TOKEN"
 
 # stratos.sh environment variables keys
 LOG_FILE_PATHS = "LOG_FILE_PATHS"
@@ -62,6 +64,7 @@ PROVIDER = "PROVIDER"
 INTERNAL = "INTERNAL"
 LB_PRIVATE_IP = "lb.private.ip"
 LB_PUBLIC_IP = "lb.public.ip"
+METADATA_SERVICE_URL = "METADATA_SERVICE_URL"
 
 # stratos.sh extension points shell scripts names keys
 INSTANCE_STARTED_SCRIPT = "extension.instance.started"

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py
new file mode 100644
index 0000000..f67eca0
--- /dev/null
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/mdsclient.py
@@ -0,0 +1,118 @@
+# 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.
+
+import urllib2, urllib
+from urllib2 import URLError, HTTPError
+import json
+from modules.util.log import LogFactory
+from config import CartridgeAgentConfiguration
+import constants
+
+
+log = LogFactory().get_log(__name__)
+config = CartridgeAgentConfiguration()
+mds_url = config.read_property(constants.METADATA_SERVICE_URL)
+alias = config.read_property(constants.CARTRIDGE_ALIAS)
+app_id = config.read_property(constants.APPLICATION_ID)
+token = config.read_property(constants.TOKEN)
+alias_resource_url = mds_url + "/metadata/api/application/" + app_id + "/cluster/" + alias + "/properties"
+app_resource_url = mds_url + "/metadata/api/application/" + app_id + "/properties"
+
+
+def put(put_req, app=False):
+    """ Publish a set of key values to the metadata service
+    :param MDSPutRequest put_req:
+    :param
+    :return: the response string or None if exception
+    :rtype: str
+    """
+    # serialize put request object to json
+    request_data = json.dumps(put_req, default=lambda o: o.__dict__)
+    if app:
+        put_request = urllib2.Request(app_resource_url)
+    else:
+        put_request = urllib2.Request(alias_resource_url)
+
+    put_request.add_header("Authorization", "Bearer %s" % token)
+    put_request.add_header('Content-Type', 'application/json')
+
+    try:
+        log.debug("Publishing metadata to Metadata service. [URL] %s, [DATA] %s" % (put_request.get_full_url(), request_data))
+        handler = urllib2.urlopen(put_request, request_data)
+        log.debug("Metadata service response: %s" % handler.getcode())
+
+        return handler.read()
+    except HTTPError as e:
+        log.exception("Error while publishing to Metadata service. The server couldn\'t fulfill the request.: %s" % e)
+        return None
+    except URLError as e:
+        log.exception("Error while publishing to Metadata service. Couldn't reach server URL. : %s" % e)
+        return None
+
+
+def get(app=False):
+    """ Retrieves the key value pairs for the application ID from the metadata service
+    :param
+    :return : MDSResponse object with properties dictionary as key value pairs
+    :rtype: MDSResponse
+    """
+    try:
+        if app:
+            log.debug("Retrieving metadata from the Metadata service. [URL] %s" % app_resource_url)
+            req_response = urllib2.urlopen(app_resource_url)
+        else:
+            log.debug("Retrieving metadata from the Metadata service. [URL] %s" % alias_resource_url)
+            req_response = urllib2.urlopen(alias_resource_url)
+
+        get_response = json.loads(req_response.read())
+        properties = get_response["properties"]
+        log.debug("Retrieved values from Metadata service: %s" % properties)
+        response_obj = MDSResponse()
+
+        for md_property in properties:
+            response_obj.properties[md_property["key"]] = md_property["values"]
+
+        return response_obj
+    except HTTPError as e:
+        log.exception("Error while retrieving from Metadata service. The server couldn\'t fulfill the request.: %s" % e)
+        return None
+    except URLError as e:
+        log.exception("Error while retrieving from Metadata service. Couldn't reach server URL. : %s" % e)
+        return None
+
+
+def update(data):
+    raise NotImplementedError
+
+
+def delete(keys):
+    raise NotImplementedError
+
+
+class MDSPutRequest:
+    """ Class to encapsulate the publish request.
+    The properties member is a list of dictionaries with the format as follows.
+    {"key": key_name, "values": value}
+    """
+    properties = []
+
+
+class MDSResponse:
+    """ Class to encapsulate the response from the metadata service retrieval.
+    The properties member is a dictionary with the retrieved key value pairs.
+    """
+    properties = {}

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
index a9164b0..5fad062 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/artifactmgt/git/agentgithandler.py
@@ -182,10 +182,11 @@ class AgentGitHandler:
 
     @staticmethod
     def clone(git_repo):
-        if os.path.isdir(git_repo.local_repo_path):
-            # delete and recreate local repo path if exists
+        if os.path.isdir(git_repo.local_repo_path) and os.listdir(git_repo.local_repo_path) != []:
+            # delete and recreate local repo path if not empty dir
             AgentGitHandler.log.debug("Local repository path not empty. Cleaning.")
             GitUtils.delete_folder_tree(git_repo.local_repo_path)
+            GitUtils.create_dir(git_repo.local_repo_path)
 
         try:
             Repo.clone_from(git_repo.repo_url, git_repo.local_repo_path)

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
index 079ebd2..e414ec7 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
+++ b/components/org.apache.stratos.python.cartridge.agent/src/main/python/cartridge.agent/cartridge.agent/modules/event/eventhandler.py
@@ -113,7 +113,11 @@ class EventHandler:
             if plugins_for_event is not None:
                 for plugin_info in plugins_for_event:
                     self.__log.debug("Executing plugin %s for event %s" % (plugin_info.name, event))
-                    PluginExecutor(plugin_info, plugin_values).start()
+                    plugin_thread = PluginExecutor(plugin_info, plugin_values)
+                    plugin_thread.start()
+
+                    # block till plugin run completes.
+                    plugin_thread.join()
             else:
                 self.__log.debug("No plugins registered for event %s" % event)
         except Exception as e:
@@ -610,6 +614,6 @@ class PluginExecutor(Thread):
 
     def run(self):
         try:
-            self.__plugin_info.plugin_object.run_plugin(self.__values, self.__log)
+            self.__plugin_info.plugin_object.run_plugin(self.__values)
         except Exception as e:
             self.__log.exception("Error while executing plugin %s: %s" % (self.__plugin_info.name, e))

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
index bb264ac..eeee06e 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
+++ b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/agent.conf
@@ -38,6 +38,7 @@ monitoring.server.secure.port         =7711
 monitoring.server.admin.username      =admin
 monitoring.server.admin.password      =admin
 log.file.paths                        =
+METADATA_SERVICE_URL                  =https://localhost:9443
 super.tenant.repository.path          =/repository/deployment/server/
 tenant.repository.path                =/repository/tenants/
 extension.instance.started            =instance-started.sh

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
index 858d622..a909a1e 100644
--- a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
+++ b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params
@@ -1 +1 @@
-APPLICATION_ID=application1,SERVICE_NAME=php,HOST_NAME=php.php.stratos.org,MULTITENANT=false,TENANT_ID=-1234,TENANT_RANGE=*,CARTRIDGE_ALIAS=php,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single-cartridge-app-1,CARTRIDGE_KEY=PUjpXCLujDhYr5A6,DEPLOYMENT=default,REPO_URL=https://github.com/imesh/stratos-php-applications.git,PORTS=9080,PUPPET_IP=127.0.0.1,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_ENV=false,MEMBER_ID=php.member-1,LB_CLUSTER_ID=null,NETWORK_PARTITION_ID=network-p1,PARTITION_ID=p1,APPLICATION_PATH=/tmp/stratos-pca-test-app-path/,MIN_COUNT=1,INTERNAL=false,CLUSTERING_PRIMARY_KEY=A,LOG_FILE_PATHS=/tmp/temp.log,PERSISTENCE_MAPPING=null,MP_IP=192.168.1.4,MB_PORT=1883
\ No newline at end of file
+APPLICATION_ID=single_group_v1,APPLICATION_PATH=/tmp/tomcat/webapps,BASH=/bin/bash,BASHOPTS=cmdhist:complete_fullquote:extquote:force_fignore:hostcomplete:interactive_comments:progcomp:promptvars:sourcepath,BASH_ALIASES=(),BASH_ARGC=(),BASH_ARGV=(),BASH_CMDS=(),BASH_LINENO=([0]="0"),BASH_SOURCE=([0]="/usr/local/bin/populate-user-data.sh"),BASH_VERSINFO=([0]="4" [1]="3" [2]="30" [3]="1" [4]="release" [5]="x86_64-pc-linux-gnu"),BASH_VERSION='4.3.30(1)-release',CARTRIDGE_ALIAS=mytomcat,CARTRIDGE_KEY=6abTFgRg7oCkXWCt,CATALINA_HOME=/opt/tomcat,CEP_IP=54.179.197.243,CEP_PORT=7711,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single_group_v1-1,DEPENDENCY_CLUSTER_IDS=myphp.php.domain,DEPLOYMENT=default,DIRSTACK=(),EUID=0,GROUPS=(),GROUP_NAME=null,HOME=/root,HOSTNAME=mytomcat-tomcat-domain3bd3cd47-b95d-475a-aa11-3e3ddc089d49,HOSTTYPE=x86_64,HOST_NAME=mytomcat.tomcat.stratos.org,IFS=' 	,',INSTANCE_ID=null,INTERNAL=false,JAVA_HOME=/opt/jdk1.7.0_67,KUBERNETES_CLUSTER_ID=kubernetes-cluster-1,KUB
 ERNETES_PORT=tcp://10.100.0.2:443,KUBERNETES_PORT_443_TCP=tcp://10.100.0.2:443,KUBERNETES_PORT_443_TCP_ADDR=10.100.0.2,KUBERNETES_PORT_443_TCP_PORT=443,KUBERNETES_PORT_443_TCP_PROTO=tcp,KUBERNETES_RO_PORT=tcp://10.100.0.1:80,KUBERNETES_RO_PORT_80_TCP=tcp://10.100.0.1:80,KUBERNETES_RO_PORT_80_TCP_ADDR=10.100.0.1,KUBERNETES_RO_PORT_80_TCP_PORT=80,KUBERNETES_RO_PORT_80_TCP_PROTO=tcp,KUBERNETES_RO_SERVICE_HOST=10.100.0.1,KUBERNETES_RO_SERVICE_PORT=80,KUBERNETES_SERVICE_HOST=10.100.0.2,KUBERNETES_SERVICE_PORT=443,LB_CLUSTER_ID=null,LOG_LEVEL=DEBUG,MACHTYPE=x86_64-pc-linux-gnu,MB_IP=54.179.197.243,MB_PORT=1883,MEMBER_ID=php.member-1,METADATA_SERVICE_URL=https://54.179.197.243:9443,MIN_COUNT=1,MULTITENANT=false,MYPHP_PHP_DOMAIN_1_PORT=tcp://10.100.171.218:4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP=tcp://10.100.171.218:4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_ADDR=10.100.171.218,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_PORT=4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_PROTO=tcp,MYPHP_PHP_DOMAIN_1_SERVICE_HOST=10.
 100.171.218,MYPHP_PHP_DOMAIN_1_SERVICE_PORT=4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT=tcp://10.100.16.250:4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP=tcp://10.100.16.250:4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_ADDR=10.100.16.250,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_PORT=4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_PROTO=tcp,MYTOMCAT_TOMCAT_DOMAIN_1_SERVICE_HOST=10.100.16.250,MYTOMCAT_TOMCAT_DOMAIN_1_SERVICE_PORT=4500,NETWORK_PARTITION_ID=network-partition-1,OPTERR=1,OPTIND=1,OSTYPE=linux-gnu,PARTITION_ID=partition-1,PATH=/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin,PIPESTATUS=([0]="0"),PORTS=8080,POSIXLY_CORRECT=y,PPID=14,PRIMARY=false,PROVIDER=apache,PS4='+ ',PUPPET_DNS_AVAILABLE=null,PUPPET_ENV=false,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_IP=127.0.0.1,PWD=/opt,REPO_URL=https://github.com/imesh/stratos-tomcat-applications.git,SERVICE_NAME=php,SHELL=/bin/bash,SHELLOPTS=braceexpand:hashall:interactive-comments:posix,SHLVL=2,TENANT_ID=-1234,TENANT_RANGE='*',TER
 M=dumb,TOKEN=eyJhbGciOiJSUzI1NiJ9.eyJleHAiOi04NzI0ODEyNDEsInN1YiI6ImFkbWluIiwiYXpwIjoid3I5SllVaDNtTXd6bVhHVllqWmVIWnhCV2xFYSIsImFwcElkIjoic2luZ2xlX2dyb3VwX3YxIiwiYXVkIjpbIndyOUpZVWgzbU13em1YR1ZZalplSFp4QldsRWEiXSwiaXNzIjoiaHR0cHM6XC9cL2xvY2FsaG9zdDo5NDQzXC9vYXV0aDJlbmRwb2ludHNcL3Rva2VuIiwiaWF0IjotODcyNDgwMjQwfQ.OSa1gIXUT9amhk1YEU02Yc3JtUYqanzrXh5K1YyvRXcpSiY2Ccn2BfJO0hILF5UooRcGBihzfX3979NRcvGwcUDUvOUJ0eaGPmxFZYbu0nr3xD8lhAO3fa1QYsKAvMnMdwyu2uSgSp6R6EUdVleiwlabUoDsuEcKGkIAn_VQvG0,UID=0,_=posix
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/f9948c5e/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2 b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2
new file mode 100644
index 0000000..858d622
--- /dev/null
+++ b/components/org.apache.stratos.python.cartridge.agent/src/test/resources/payload/launch-params2
@@ -0,0 +1 @@
+APPLICATION_ID=application1,SERVICE_NAME=php,HOST_NAME=php.php.stratos.org,MULTITENANT=false,TENANT_ID=-1234,TENANT_RANGE=*,CARTRIDGE_ALIAS=php,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single-cartridge-app-1,CARTRIDGE_KEY=PUjpXCLujDhYr5A6,DEPLOYMENT=default,REPO_URL=https://github.com/imesh/stratos-php-applications.git,PORTS=9080,PUPPET_IP=127.0.0.1,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_ENV=false,MEMBER_ID=php.member-1,LB_CLUSTER_ID=null,NETWORK_PARTITION_ID=network-p1,PARTITION_ID=p1,APPLICATION_PATH=/tmp/stratos-pca-test-app-path/,MIN_COUNT=1,INTERNAL=false,CLUSTERING_PRIMARY_KEY=A,LOG_FILE_PATHS=/tmp/temp.log,PERSISTENCE_MAPPING=null,MP_IP=192.168.1.4,MB_PORT=1883
\ No newline at end of file


[23/50] [abbrv] stratos git commit: Copying jndi.properties file to stratos server instance started by the integration test

Posted by re...@apache.org.
Copying jndi.properties file to stratos server instance started by the integration test


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

Branch: refs/heads/docker-grouping-merge
Commit: 350d53583e807f1d0292a2a6295e40edd69f706d
Parents: 530880a
Author: Imesh Gunaratne <im...@apache.org>
Authored: Sat Feb 28 08:43:26 2015 +0530
Committer: Imesh Gunaratne <im...@apache.org>
Committed: Sat Feb 28 08:44:13 2015 +0530

----------------------------------------------------------------------
 .../tests/StratosTestServerManager.java         | 20 +++++++++++++-------
 1 file changed, 13 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/350d5358/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
----------------------------------------------------------------------
diff --git a/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java b/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
index fd74f75..ec9afeb 100755
--- a/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
+++ b/products/stratos/modules/integration/src/test/java/org/apache/stratos/integration/tests/StratosTestServerManager.java
@@ -50,7 +50,8 @@ public class StratosTestServerManager extends TestServerManager {
             "/../../../distribution/target/apache-stratos-4.1.0-SNAPSHOT.zip";
     private final static int PORT_OFFSET = 0;
     private static final String ACTIVEMQ_BIND_ADDRESS = "tcp://localhost:61617";
-    private static final String MOCK_IAAS_XML = "mock-iaas.xml";
+    private static final String MOCK_IAAS_XML_FILE = "mock-iaas.xml";
+    private static final String JNDI_PROPERTIES_FILE = "jndi.properties";
 
     private ServerUtils serverUtils;
     private String carbonHome;
@@ -123,13 +124,18 @@ public class StratosTestServerManager extends TestServerManager {
     }
 
     protected void copyArtifacts(String carbonHome) throws IOException {
-        log.info("Copying " + MOCK_IAAS_XML + " configuration file...");
-        URL mockIaasUrl = getClass().getResource("/" + MOCK_IAAS_XML);
-        assertNotNull(mockIaasUrl);
-        File srcFile = new File(mockIaasUrl.getFile());
-        File destFile = new File(carbonHome + "/repository/conf/" + MOCK_IAAS_XML);
+        copyConfigFile(carbonHome, MOCK_IAAS_XML_FILE);
+        copyConfigFile(carbonHome, JNDI_PROPERTIES_FILE);
+    }
+
+    private void copyConfigFile(String carbonHome, String fileName) throws IOException {
+        log.info("Copying " + fileName + " configuration file...");
+        URL fileURL = getClass().getResource("/" + fileName);
+        assertNotNull(fileURL);
+        File srcFile = new File(fileURL.getFile());
+        File destFile = new File(carbonHome + "/repository/conf/" + fileName);
         FileUtils.copyFile(srcFile, destFile);
-        log.info(MOCK_IAAS_XML + " configuration file copied");
+        log.info(fileName + " configuration file copied");
     }
 
     private boolean serverStarted(TestLogAppender testLogAppender) {