You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by ga...@apache.org on 2015/08/21 07:34:20 UTC

[1/6] stratos git commit: Refactoring log messages

Repository: stratos
Updated Branches:
  refs/heads/tenant-isolation 2f2debf5b -> a776ca196


Refactoring log messages


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

Branch: refs/heads/tenant-isolation
Commit: e873b944374cb3d154c7574269e40da50d727d1d
Parents: 4fdd431
Author: Dinithi <di...@wso2.com>
Authored: Wed Aug 19 18:04:04 2015 +0530
Committer: Dinithi <di...@wso2.com>
Committed: Wed Aug 19 18:04:04 2015 +0530

----------------------------------------------------------------------
 .../services/impl/AutoscalerServiceImpl.java    | 307 ++++++++++++-------
 .../rest/endpoint/api/StratosApiV41.java        |  11 +-
 .../rest/endpoint/api/StratosApiV41Utils.java   |   2 +-
 3 files changed, 198 insertions(+), 122 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/e873b944/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 b8e52c7..db9a305 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
@@ -108,11 +108,13 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             throws AutoScalingPolicyAlreadyExistException {
         String autoscalePolicyId = autoscalePolicy.getId();
         if (PolicyManager.getInstance().getAutoscalePolicyById(autoscalePolicyId) != null && PolicyManager
-                .getInstance().getAutoscalePolicyById(autoscalePolicyId).getTenantId() == autoscalePolicy.getTenantId
-                ()) {
-            String message = String.format("Autoscaling policy already exists: [autoscaling-policy-uuid] %s " +
-                    "[autoscaling-policy-id] %s", autoscalePolicy.getUuid(), autoscalePolicyId);
-            log.error(message);
+                .getInstance().getAutoscalePolicyById(autoscalePolicyId).getTenantId() == autoscalePolicy.getTenantId()) {
+            String logMessage = String.format("Autoscaling policy already exists: [tenant-id] %d " +
+                    "[autoscaling-policy-uuid] %s [autoscaling-policy-id] %s", autoscalePolicy.getTenantId(),
+                    autoscalePolicy.getUuid(), autoscalePolicyId);
+            String message = String.format("Autoscaling policy already exists: [autoscaling-policy-id] %s",
+                    autoscalePolicyId);
+            log.error(logMessage);
             throw new AutoScalingPolicyAlreadyExistException(message);
         }
         return PolicyManager.getInstance().addAutoscalePolicy(autoscalePolicy);
@@ -129,8 +131,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         if (removableAutoScalerPolicy(autoscalePolicyId)) {
             return PolicyManager.getInstance().removeAutoscalePolicy(autoscalePolicyId);
         } else {
-            throw new UnremovablePolicyException(String.format("This autoscaling policy:  cannot be removed, " +
-                    "since it is used in applications."));
+            throw new UnremovablePolicyException(String.format("Autoscaling policy cannot be removed, " +
+                    "since it is used in applications: [autoscaling-policy-id] %s", autoscalePolicyId));
         }
     }
 
@@ -227,8 +229,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             CartridgeNotFoundException {
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Adding application: [application-id] %s",
-                    applicationContext.getApplicationUuid()));
+            log.info(String.format("Adding application: [tenant-id] %d [application-uuid] %s [application-name] %s",
+                    applicationContext.getTenantId(), applicationContext.getApplicationUuid(), applicationContext.getName()));
         }
 
         ApplicationParser applicationParser = new DefaultApplicationParser();
@@ -244,8 +246,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         AutoscalerContext.getInstance().addApplicationContext(applicationContext);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Application added successfully: [application-id] %s",
-                    applicationContext.getApplicationUuid()));
+            log.info(String.format("Application added successfully: [tenant-id] %d [application-uuid] %s " +
+                            "[application-name] %s", applicationContext.getTenantId(),
+                    applicationContext.getApplicationUuid(), applicationContext.getName()));
         }
         return true;
     }
@@ -257,19 +260,19 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         String applicationId = applicationContext.getApplicationUuid();
         if (log.isInfoEnabled()) {
-            log.info(String.format("Updating application: [application-id] %s",
-                    applicationContext.getApplicationUuid()));
+            log.info(String.format("Updating application: [tenant-id] %d [application-uuid] %s [application-name] %s",
+                    applicationContext.getTenantId(), applicationContext.getApplicationUuid(), applicationContext.getName()));
         }
 
         if (AutoscalerContext.getInstance().getApplicationContext(applicationId) == null) {
-            String message = "Application is not found as ApplicationContext. Please add application before updating it: " +
+            String message = "Application not found as ApplicationContext. Please add application before updating it: " +
                     "[application-id] " + applicationId;
             log.error(message);
             throw new ApplicationDefinitionException(message);
         }
 
         if (ApplicationHolder.getApplications().getApplication(applicationId) == null) {
-            String message = "Application is not found as Application. Please add application before updating it: " +
+            String message = "Application not found as Application. Please add application before updating it: " +
                     "[application-id] " + applicationId;
             log.error(message);
             throw new ApplicationDefinitionException(message);
@@ -302,8 +305,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         AutoscalerContext.getInstance().updateApplicationContext(applicationContext);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Application updated successfully: [application-id] %s",
-                    applicationId));
+            log.info(String.format("Application updated successfully: [tenant-id] %d [application-uuid] %s " +
+                            "[application-name] %s", applicationContext.getTenantId(),
+                    applicationContext.getApplicationUuid(), applicationContext.getName()));
         }
         return true;
     }
@@ -350,14 +354,15 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         try {
             Application application = ApplicationHolder.getApplications().getApplication(applicationUuid);
             if (application == null) {
-                throw new RuntimeException(String.format("Application not found [application-uuid] : %s ",
+                throw new RuntimeException(String.format("Application not found: [application-uuid] : %s ",
                         applicationUuid));
             }
 
             ApplicationContext applicationContext = RegistryManager.getInstance().
                     getApplicationContext(applicationUuid);
             if (applicationContext == null) {
-                throw new RuntimeException("Application context not found: " + applicationUuid);
+                throw new RuntimeException(String.format("Application context not found: [application-uuid] %s",
+                        applicationUuid));
             }
 
             // validating application policy against the application
@@ -400,8 +405,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 applicationContext.setStatus(ApplicationContext.STATUS_CREATED);
                 AutoscalerContext.getInstance().updateApplicationContext(applicationContext);
             }
-            String message = "Application deployment failed: [application-uuid]" + applicationUuid;
-            log.error(message, e);
+            String logMessage = String.format("Application deployment failed: [application-uuid] %s ", applicationUuid);
+            String message = String.format("Application deployment failed: [application-id] %s", applicationUuid);
+            log.error(logMessage, e);
             throw new RuntimeException(message, e);
         }
     }
@@ -432,8 +438,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         try {
             if (log.isInfoEnabled()) {
-                log.info(String.format("Adding application signup: [application-id] %s",
-                        applicationContext.getApplicationUuid()));
+                log.info(String.format("Adding application signup: [tenant-id] %d [application-uuid] %s " +
+                                "[application-id] %s", applicationContext.getTenantId(),
+                        applicationContext.getApplicationUuid(), applicationContext.getApplicationId()));
             }
 
             ComponentContext components = applicationContext.getComponents();
@@ -469,12 +476,15 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 serviceClient.addApplicationSignUp(applicationSignUp);
 
                 if (log.isInfoEnabled()) {
-                    log.info(String.format("Application signup added successfully: [application-id] %s",
-                            applicationContext.getApplicationUuid()));
+                    log.info(String.format("Application signup added successfully: [tenant-id] %d [application-uuid] " +
+                                    "%s [application-id] %s", applicationContext.getTenantId(),
+                            applicationContext.getApplicationUuid(), applicationContext.getApplicationId()));
                 }
             }
         } catch (Exception e) {
-            String message = "Could not add application signup: [application-id]" + applicationContext.getApplicationUuid();
+            String message = String.format("Could not add application signup: [tenant-id] %d [application-uuid] %s " +
+            "[application-id] %s", applicationContext.getTenantId(), applicationContext.getApplicationUuid(),
+                    applicationContext.getApplicationId());
             log.error(message, e);
             throw new RuntimeException(message, e);
         }
@@ -506,8 +516,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
     private void removeApplicationSignUp(ApplicationContext applicationContext) {
         try {
             if (log.isInfoEnabled()) {
-                log.info(String.format("Removing application signup: [application-id] %s",
-                        applicationContext.getApplicationUuid()));
+                log.info(String.format("Removing application signup: [tenant-id] %d [application-uuid] %s " +
+                                "[application-id] %s", applicationContext.getTenantId(),
+                        applicationContext.getApplicationUuid(), applicationContext.getApplicationId()));
             }
 
             StratosManagerServiceClient serviceClient = StratosManagerServiceClient.getInstance();
@@ -522,7 +533,7 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             }
 
         } catch (Exception e) {
-            String message = "Could not remove application signup(s)";
+            String message = "Could not remove application signup(s): [application-id]";
             log.error(message, e);
             throw new RuntimeException(message, e);
         }
@@ -639,8 +650,11 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             }
 
             if (!applicationContext.getStatus().equals(ApplicationContext.STATUS_DEPLOYED)) {
+                String logMessage = String.format("Application is not deployed: [tenant-id] %d " +
+                        "[application-uuid] %s [application-id] %s", applicationContext.getTenantId(),
+                        applicationContext.getApplicationUuid(), applicationId);
                 String message = String.format("Application is not deployed: [application-id] %s", applicationId);
-                log.error(message);
+                log.error(logMessage);
                 throw new RuntimeException(message);
             }
             applicationContext.setStatus(ApplicationContext.STATUS_UNDEPLOYING);
@@ -653,7 +667,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             ApplicationBuilder.handleApplicationUnDeployedEvent(applicationId);
 
             if (log.isInfoEnabled()) {
-                log.info("Application undeployment process started: [application-id] " + applicationId);
+                log.info(String.format("Application undeployment process started: [tenant-id] %d " +
+                                "[application-uuid] %s [application-id] %s", applicationContext.getTenantId(),
+                        applicationContext.getApplicationUuid(), applicationId));
             }
         } catch (Exception e) {
             String message = "Could not start application undeployment process: [application-id] " + applicationId;
@@ -681,14 +697,19 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             }
 
             if (application.getInstanceContextCount() > 0) {
+                String logMessage = String.format("Application cannot be deleted, undeployment process is still in " +
+                                "progress: [tenant-id] %d [application-uuid] %s [application-id] %s",
+                        applicationContext.getTenantId(), applicationContext.getApplicationUuid(), applicationId);
                 String message = String.format("Application cannot be deleted, undeployment process is still in " +
                         "progress: [application-id] %s", applicationId);
-                log.error(message);
+                log.error(logMessage);
                 throw new RuntimeException(message);
             }
 
             ApplicationBuilder.handleApplicationRemoval(applicationId);
-            log.info(String.format("Application deleted successfully: [application-id] %s", applicationId));
+            log.info(String.format("Application deleted successfully: [tenant-id] %d [application-uuid] %s " +
+                            "[application-id] %s", applicationContext.getTenantId(),
+                    applicationContext.getApplicationUuid(), applicationId));
         } catch (Exception e) {
             String message = String.format("Could not delete application: [application-id] %s", applicationId);
             log.error(message, e);
@@ -722,12 +743,13 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Adding cartridge group: [group-name] %s", servicegroup.getUuid()));
+            log.info(String.format("Adding cartridge group: [tenant-id] %d [group-uuid] %s [group-name] %s",
+                    servicegroup.getTenantId(), servicegroup.getUuid(), servicegroup.getName()));
         }
 
-        String groupName = servicegroup.getUuid();
-        if (RegistryManager.getInstance().serviceGroupExist(groupName)) {
-            throw new InvalidServiceGroupException("Cartridge group with the name " + groupName + " already exists.");
+        String groupUuid = servicegroup.getUuid();
+        if (RegistryManager.getInstance().serviceGroupExist(groupUuid)) {
+            throw new InvalidServiceGroupException("Cartridge group already exists.");
         }
 
         if (log.isDebugEnabled()) {
@@ -751,7 +773,7 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         if (dependencies != null) {
             String[] startupOrders = dependencies.getStartupOrders();
-            AutoscalerUtil.validateStartupOrders(groupName, startupOrders);
+            AutoscalerUtil.validateStartupOrders(groupUuid, startupOrders);
 
             if (log.isDebugEnabled()) {
                 log.debug("StartupOrders " + Arrays.toString(startupOrders));
@@ -764,7 +786,7 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             }
 
             String[] scalingDependents = dependencies.getScalingDependants();
-            AutoscalerUtil.validateScalingDependencies(groupName, scalingDependents);
+            AutoscalerUtil.validateScalingDependencies(groupUuid, scalingDependents);
 
             if (log.isDebugEnabled()) {
                 log.debug("ScalingDependent " + Arrays.toString(scalingDependents));
@@ -779,7 +801,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         RegistryManager.getInstance().persistServiceGroup(servicegroup);
         if (log.isInfoEnabled()) {
-            log.info(String.format("Cartridge group successfully added: [group-name] %s", servicegroup.getUuid()));
+            log.info(String.format("Cartridge group successfully added: [tenant-id] %d [group-uuid] %s [group-name] %s",
+                    servicegroup.getTenantId(), servicegroup.getUuid(), servicegroup.getName()));
         }
         return true;
     }
@@ -793,13 +816,13 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         }
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Updating cartridge group: [group-name] %s", cartridgeGroup.getUuid()));
+            log.info(String.format("Updating cartridge group: [tenant-id] %d [group-uuid] %s [group-name] %s",
+                    cartridgeGroup.getTenantId(), cartridgeGroup.getUuid(), cartridgeGroup.getName()));
         }
 
         String groupName = cartridgeGroup.getUuid();
         if (!RegistryManager.getInstance().serviceGroupExist(groupName)) {
-            throw new InvalidServiceGroupException(String.format("Cartridge group does not exist: [cartridge-group] %s",
-                    cartridgeGroup.getUuid()));
+            throw new InvalidServiceGroupException("Cartridge group does not exist.");
         }
 
         Dependencies dependencies = cartridgeGroup.getDependencies();
@@ -835,13 +858,13 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             RegistryManager.getInstance().updateServiceGroup(cartridgeGroup);
         } catch (org.wso2.carbon.registry.core.exceptions.RegistryException e) {
             String message = (String.format("Cannot update cartridge group: [group-name] %s",
-                    cartridgeGroup.getUuid()));
+                    cartridgeGroup.getName()));
             throw new RuntimeException(message, e);
         }
 
-
         if (log.isInfoEnabled()) {
-            log.info(String.format("Cartridge group successfully updated: [group-name] %s", cartridgeGroup.getUuid()));
+            log.info(String.format("Cartridge group successfully updated: [tenant-id] %d [group-uuid] %s [group-name] %s",
+                    cartridgeGroup.getTenantId(), cartridgeGroup.getUuid(), cartridgeGroup.getName()));
         }
         return true;
     }
@@ -991,7 +1014,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         AutoscalerUtil.validateApplicationPolicy(applicationPolicy);
 
         if (log.isInfoEnabled()) {
-            log.info("Adding application policy: [application-policy-id] " + applicationPolicy.getUuid());
+            log.info(String.format("Adding application policy: [tenant-id] %d [application-policy-uuid] %s " +
+                    "[application-policy-id] %s", applicationPolicy.getTenantId(), applicationPolicy.getUuid(),
+                    applicationPolicy.getId()));
         }
         if (log.isDebugEnabled()) {
             log.debug("Application policy definition: " + applicationPolicy.toString());
@@ -1002,16 +1027,22 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 (applicationPolicy.getId(), applicationPolicy.getTenantId());
         if (isExist) {
             String message = "Application policy already exists: [application-policy-id] " + applicationPolicyId;
-            log.error(message);
+            String logMessage = String.format("Application policy already exists: [tenant-id] %d " +
+                    "[application-policy-uuid] %s [application-policy-id] %s", applicationPolicy.getTenantId(),
+                    applicationPolicy.getUuid(), applicationPolicy.getId());
+            log.error(logMessage);
             throw new ApplicationPolicyAlreadyExistsException(message);
         }
 
-        String applicationPolicyUuid1 = applicationPolicy.getUuid();
-        if (PolicyManager.getInstance().getApplicationPolicyByUuid(applicationPolicyUuid1) != null && PolicyManager
-                .getInstance().getApplicationPolicyByUuid(applicationPolicyUuid1).getTenantId() == applicationPolicy
+        String applicationPolicyUuid = applicationPolicy.getUuid();
+        if (PolicyManager.getInstance().getApplicationPolicyByUuid(applicationPolicyUuid) != null && PolicyManager
+                .getInstance().getApplicationPolicyByUuid(applicationPolicyUuid).getTenantId() == applicationPolicy
                 .getTenantId()) {
-            String message = "Application policy already exists: [application-policy-uuid] " + applicationPolicyUuid1;
-            log.error(message);
+            String message = "Application policy already exists: [application-policy-id] " + applicationPolicyId;
+            String logMessage = String.format("Application policy already exists: [tenant-id] %d " +
+                            "[application-policy-uuid] %s [application-policy-id] %s", applicationPolicy.getTenantId(),
+                    applicationPolicy.getUuid(), applicationPolicy.getId());
+            log.error(logMessage);
             throw new ApplicationPolicyAlreadyExistsException(message);
         }
 
@@ -1057,8 +1088,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         if (removableApplicationPolicy(applicationPolicyId)) {
             return PolicyManager.getInstance().removeApplicationPolicy(applicationPolicyId);
         } else {
-            throw new UnremovablePolicyException("This application policy cannot be removed, since it is used in " +
-                    "applications.");
+            throw new UnremovablePolicyException(String.format("Application policy cannot be removed, " +
+                    "since it is used in applications: [application-policy-id] %s", applicationPolicyId));
         }
     }
 
@@ -1132,13 +1163,15 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 					if (networkPartitions != null) {
 						for (int i = 0; i < networkPartitions.length; i++) {
 							if (networkPartitions[i].equals(networkPartitionId)) {
-								String message = String.format("Cannot remove the network partition: " +
-								                               "[network-partition-id] %s since it is used in " +
-								                               "application: [application-uuid] %s [application-id] %s",
-								                               networkPartitionId,
-								                               applicationContext.getApplicationUuid(),
-								                               applicationContext.getApplicationId());
-								log.error(message);
+								String logMessage = String.format("Cannot remove the network partition since it is used" +
+                                                " in application: [tenant-id] %d [network-partition-id] %s " +
+                                                "[application-uuid] %s [application-id] %s", tenantId,
+                                        networkPartitionId, applicationContext.getApplicationUuid(),
+                                        applicationContext.getApplicationId());
+                                String message = String.format("Cannot remove the network partition since it is " +
+                                                "used in application: [network-partition-id] %s [application-id] %s",
+                                        networkPartitionId, applicationContext.getApplicationId());
+								log.error(logMessage);
 								throw new PartitionValidationException(message);
 							}
 						}
@@ -1229,7 +1262,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         validateDeploymentPolicy(deploymentPolicy);
 
         if (log.isInfoEnabled()) {
-            log.info("Adding deployment policy: [deployment-policy-id] " + deploymentPolicy.getUuid());
+            log.info(String.format("Adding deployment policy: [tenant-id] %d [deployment-policy-uuid] %s " +
+                    "[deployment-policy-id] %s ",deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
+                    deploymentPolicy.getId()));
         }
         if (log.isDebugEnabled()) {
             log.debug("Deployment policy definition: " + deploymentPolicy.toString());
@@ -1237,16 +1272,24 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         String deploymentPolicyUuid = deploymentPolicy.getUuid();
         if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyUuid) != null) {
-            String message = "Deployment policy already exists: [deployment-policy-uuid] " + deploymentPolicyUuid;
-            log.error(message);
+            String logMessage = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid]" +
+                            " %s [deployment-policy-id] %s ",deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
+                    deploymentPolicy.getId());
+            String message = String.format("Deployment policy already exists: [deployment-policy-id] %s ",
+                    deploymentPolicy.getId());
+            log.error(logMessage);
             throw new DeploymentPolicyAlreadyExistsException(message);
         }
 
         String deploymentPolicyId = deploymentPolicy.getId();
         if (PolicyManager.getInstance().getDeploymentPolicyById(deploymentPolicyId) != null && PolicyManager
                 .getInstance().getDeploymentPolicyById(deploymentPolicyId).getTenantId() == deploymentPolicy.getTenantId()) {
-            String message = "Deployment policy already exists: [deployment-policy-id] " + deploymentPolicyId;
-            log.error(message);
+            String logMessage = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid]" +
+                            " %s [deployment-policy-id] %s ",deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
+                    deploymentPolicy.getId());
+            String message = String.format("Deployment policy already exists: [deployment-policy-id] %s ",
+                    deploymentPolicy.getId());
+            log.error(logMessage);
             throw new DeploymentPolicyAlreadyExistsException(message);
         }
 
@@ -1254,7 +1297,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         PolicyManager.getInstance().addDeploymentPolicy(deploymentPolicy);
 
         if (log.isInfoEnabled()) {
-            log.info("Successfully added deployment policy: [deployment-policy-uuid] " + deploymentPolicyUuid);
+            log.info(String.format("Successfully added deployment policy: [tenant-id] %d [deployment-policy-uuid]" +
+                            " %s [deployment-policy-id] %s ",deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
+                    deploymentPolicy.getId()));
         }
         return true;
     }
@@ -1284,10 +1329,13 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         // deployment policy should contain at least one network partition reference
         if (null == deploymentPolicy.getNetworkPartitionRefs() || deploymentPolicy.getNetworkPartitionRefs().length == 0) {
-            String msg = String.format("Deployment policy does not have any network partition references: " +
-                    "[deployment-policy-uuid] %s [deployment-policy-id] %s", deploymentPolicyUuid, deploymentPolicyId);
-            log.error(msg);
-            throw new InvalidDeploymentPolicyException(msg);
+            String logMessage = String.format("Deployment policy does not have any network partition references: " +
+                    "[tenant-id] %d [deployment-policy-uuid] %s [deployment-policy-id] %s",
+                    deploymentPolicy.getTenantId(), deploymentPolicyUuid, deploymentPolicyId);
+            String message = String.format("Deployment policy does not have any network partition references: " +
+                    "[deployment-policy-id] %s", deploymentPolicyId);
+            log.error(logMessage);
+            throw new InvalidDeploymentPolicyException(message);
         }
 
         // validate each network partition references
@@ -1296,10 +1344,13 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             //String networkPartitionUuid = networkPartitionRef.getUuid();
             String networkPartitionId = networkPartitionRef.getId();
             if (StringUtils.isBlank(networkPartitionId)) {
-                String msg = String.format("Network partition id is blank: [deployment-policy-uuid] %s " +
-                                "[deployment-policy-id] %s", deploymentPolicyUuid, deploymentPolicyId);
-                log.error(msg);
-                throw new InvalidDeploymentPolicyException(msg);
+                String message = String.format("Network partition id is blank: [deployment-policy-id] %s",
+                        deploymentPolicyId);
+                String logMessage = String.format("Network partition id is blank: [tenant-id] " +
+                        "%d [deployment-policy-uuid] %s [deployment-policy-id] %s", deploymentPolicy.getTenantId(),
+                        deploymentPolicyUuid, deploymentPolicyId);
+                log.error(logMessage);
+                throw new InvalidDeploymentPolicyException(message);
             }
 
             // network partitions should be already added
@@ -1314,60 +1365,81 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 }
             }
             if (networkPartitionForTenant == null) {
-                String msg = String.format("Network partition is not found: [deployment-policy-uuid] %s " +
-                                "[deployment-policy-id] %s [network-partition-id] %s", deploymentPolicyUuid,
-                        deploymentPolicyId, networkPartitionId);
-                log.error(msg);
-                throw new InvalidDeploymentPolicyException(msg);
+                String logMessage = String.format("Network partition not found: [tenant-id] %d " +
+                                "[deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-id] %s",
+                        deploymentPolicy.getTenantId(), deploymentPolicyUuid, deploymentPolicyId, networkPartitionId);
+                String message = String.format("Network partition not found: [deployment-policy-id] %s " +
+                                "[network-partition-id] %s", deploymentPolicyId, networkPartitionId);
+                log.error(logMessage);
+                throw new InvalidDeploymentPolicyException(message);
             }
 
             // network partition - partition id should be already added
             for (PartitionRef partitionRef : networkPartitionRef.getPartitionRefs()) {
-                String partitionId = partitionRef.getUuid();
+                String partitionUuid = partitionRef.getUuid();
                 boolean isPartitionFound = false;
 
                 for (Partition partition : networkPartitionForTenant.getPartitions()) {
-                    if (partition.getUuid().equals(partitionId)) {
+                    if (partition.getUuid().equals(partitionUuid)) {
                         isPartitionFound = true;
                     }
                 }
-                if (isPartitionFound == false) {
-                    String msg = String.format("Partition Id is not found: [deployment-policy-id] %s " +
-                                    "[network-partition-id] %s [partition-id] %s",
-                            deploymentPolicyId, networkPartitionId, partitionId);
-                    log.error(msg);
-                    throw new InvalidDeploymentPolicyException(msg);
+                if (!isPartitionFound) {
+                    String logMessage = String.format("Partition not found: [tenant-id] " +
+                                    "%d [deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-id] " +
+                                    "%s [network=partition-uuid] %s [partition-id] %s ",
+                            deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(), deploymentPolicyId,
+                            networkPartitionRef.getUuid(), networkPartitionId, partitionRef.getId());
+                    String message = String.format("Partition not found: [deployment-policy-id] %s " +
+                                    "[network-partition-id] %s [partition-id] %s ", deploymentPolicyId,
+                            networkPartitionId, partitionRef.getId());
+                    log.error(logMessage);
+                    throw new InvalidDeploymentPolicyException(message);
                 }
             }
 
             // partition algorithm can't be null or empty
             String partitionAlgorithm = networkPartitionRef.getPartitionAlgo();
             if (StringUtils.isBlank(partitionAlgorithm)) {
-                String msg = String.format("Partition algorithm is blank: [deployment-policy-id] %s " +
+                String logMessage = String.format("Partition algorithm is blank: [tenant-id] %d " +
+                                "[deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-uuid] %s " +
+                                "[network-partition-id] %s [partition-algorithm] %s",
+                        deploymentPolicy.getTenantId(), deploymentPolicyUuid, deploymentPolicyId,
+                        networkPartitionRef.getUuid(), networkPartitionId, partitionAlgorithm);
+                String message = String.format("Partition algorithm is blank: [deployment-policy-id] %s " +
                                 "[network-partition-id] %s [partition-algorithm] %s",
                         deploymentPolicyId, networkPartitionId, partitionAlgorithm);
-                log.error(msg);
-                throw new InvalidDeploymentPolicyException(msg);
+                log.error(logMessage);
+                throw new InvalidDeploymentPolicyException(message);
             }
 
             // partition algorithm should be either one-after-another or round-robin
             if ((!StratosConstants.PARTITION_ROUND_ROBIN_ALGORITHM_ID.equals(partitionAlgorithm))
                     && (!StratosConstants.PARTITION_ONE_AFTER_ANOTHER_ALGORITHM_ID.equals(partitionAlgorithm))) {
-                String msg = String.format("Partition algorithm is not valid: [deployment-policy-id] %s " +
+                String logMessage = String.format("Partition algorithm is not valid: [tenant-id] %d " +
+                                "[deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-uuid] %s " +
+                                "[network-partition-id] %s [partition-algorithm] %s", deploymentPolicy.getTenantId(),
+                        deploymentPolicyUuid, deploymentPolicyId, networkPartitionRef.getUuid(), networkPartitionId,
+                        partitionAlgorithm);
+                String message = String.format("Partition algorithm is not valid: [deployment-policy-id] %s " +
                                 "[network-partition-id] %s [partition-algorithm] %s",
                         deploymentPolicyId, networkPartitionId, partitionAlgorithm);
-                log.error(msg);
-                throw new InvalidDeploymentPolicyException(msg);
+                log.error(logMessage);
+                throw new InvalidDeploymentPolicyException(message);
             }
 
             // a network partition reference should contain at least one partition reference
             PartitionRef[] partitions = networkPartitionRef.getPartitionRefs();
             if (null == partitions || partitions.length == 0) {
-                String msg = String.format("Network partition does not have any partition references: " +
+                String logMessage = String.format("Network partition does not have any partition references: " +
+                                "[tenant-id] %d [deployment-policy-uuid] %s [deployment-policy-id] %s " +
+                                "[network-partition-uuid] %s [network-partition-id] %s ", deploymentPolicy.getTenantId(),
+                        deploymentPolicyUuid, deploymentPolicyId, networkPartitionRef.getUuid(), networkPartitionId);
+                String message = String.format("Network partition does not have any partition references: " +
                                 "[deployment-policy-id] %s [network-partition-id] %s", deploymentPolicyId,
                         networkPartitionId);
-                log.error(msg);
-                throw new InvalidDeploymentPolicyException(msg);
+                log.error(logMessage);
+                throw new InvalidDeploymentPolicyException(message);
             }
         }
     }
@@ -1379,16 +1451,21 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         validateDeploymentPolicy(deploymentPolicy);
 
         if (log.isInfoEnabled()) {
-            log.info("Updating deployment policy: [deployment-policy-id] " + deploymentPolicy.getUuid());
+            log.info(String.format("Updating deployment policy: [tenant-id] %d [deployment-policy-uuid] %s " +
+                            "[deployment-policy-id] %s", deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
+                    deploymentPolicy.getId()));
         }
         if (log.isDebugEnabled()) {
             log.debug("Updating Deployment policy definition: " + deploymentPolicy.toString());
         }
 
-        String deploymentPolicyID = deploymentPolicy.getUuid();
-        if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyID) == null) {
-            String message = "Deployment policy not exists: [deployment-policy-id] " + deploymentPolicyID;
-            log.error(message);
+        String deploymentPolicyUuid = deploymentPolicy.getUuid();
+        if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyUuid) == null) {
+            String logMessage = String.format("Deployment policy not exists: [tenant-id] %d [deployment-policy-uuid] " +
+                    "%s [deployment-policy-id] %s", deploymentPolicy.getTenantId(), deploymentPolicyUuid,
+                    deploymentPolicy.getId());
+            String message = "Deployment policy not exists: [deployment-policy-id] " + deploymentPolicy.getId();
+            log.error(logMessage);
             throw new DeploymentPolicyNotExistsException(message);
         }
 
@@ -1397,7 +1474,9 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         updateClusterMonitors(deploymentPolicy);
 
         if (log.isInfoEnabled()) {
-            log.info("Successfully updated deployment policy: [deployment-policy-id] " + deploymentPolicyID);
+            log.info(String.format("Successfully updated deployment policy: [tenant-id] %d [deployment-policy-uuid] " +
+                            "%s [deployment-policy-id] %s", deploymentPolicy.getTenantId(), deploymentPolicyUuid,
+                    deploymentPolicy.getId()));
         }
         return true;
     }
@@ -1418,19 +1497,19 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                     } catch (RemoteException e) {
 
                         String message = "Connection to cloud controller failed, Cluster monitor update failed for" +
-                                " [deployment-policy] " + deploymentPolicy.getUuid();
+                                " [deployment-policy] " + deploymentPolicy.getId();
                         log.error(message);
                         throw new CloudControllerConnectionException(message, e);
                     } catch (CloudControllerServiceInvalidPartitionExceptionException e) {
 
                         String message = "Invalid partition, Cluster monitor update failed for [deployment-policy] "
-                                + deploymentPolicy.getUuid();
+                                + deploymentPolicy.getId();
                         log.error(message);
                         throw new InvalidDeploymentPolicyException(message, e);
                     } catch (CloudControllerServiceInvalidCartridgeTypeExceptionException e) {
 
                         String message = "Invalid cartridge type, Cluster monitor update failed for [deployment-policy] "
-                                + deploymentPolicy.getUuid() + " [cartridge] "
+                                + deploymentPolicy.getId() + " [cartridge] "
                                 + clusterMonitor.getClusterContext().getServiceId();
                         log.error(message);
                         throw new InvalidDeploymentPolicyException(message, e);
@@ -1505,24 +1584,24 @@ public class AutoscalerServiceImpl implements AutoscalerService {
     }
 
     @Override
-    public boolean removeDeployementPolicy(String deploymentPolicyID) throws DeploymentPolicyNotExistsException,
+    public boolean removeDeployementPolicy(String deploymentPolicyId) throws DeploymentPolicyNotExistsException,
             UnremovablePolicyException {
         if (log.isInfoEnabled()) {
-            log.info("Removing deployment policy: [deployment-policy_id] " + deploymentPolicyID);
+            log.info("Removing deployment policy: [deployment-policy_id] " + deploymentPolicyId);
         }
-        if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyID) == null) {
-            String message = "Deployment policy not exists: [deployment-policy-id] " + deploymentPolicyID;
+        if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyId) == null) {
+            String message = "Deployment policy not exists: [deployment-policy-id] " + deploymentPolicyId;
             log.error(message);
             throw new DeploymentPolicyNotExistsException(message);
         }
-        if (removableDeploymentPolicy(deploymentPolicyID)) {
-            PolicyManager.getInstance().removeDeploymentPolicy(deploymentPolicyID);
+        if (removableDeploymentPolicy(deploymentPolicyId)) {
+            PolicyManager.getInstance().removeDeploymentPolicy(deploymentPolicyId);
         } else {
             throw new UnremovablePolicyException("This deployment policy cannot be removed, since it is used in an " +
                     "application.");
         }
         if (log.isInfoEnabled()) {
-            log.info("Successfully removed deployment policy: [deployment_policy_id] " + deploymentPolicyID);
+            log.info("Successfully removed deployment policy: [deployment_policy_id] " + deploymentPolicyId);
         }
         return true;
     }

http://git-wip-us.apache.org/repos/asf/stratos/blob/e873b944/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
index ff1c4a8..32be807 100644
--- a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
+++ b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
@@ -969,13 +969,9 @@ public class StratosApiV41 extends AbstractApi {
                     ResponseMessageBean.ERROR, backendErrorMessage)).build();
         } catch (AutoscalerServiceApplicationPolicyAlreadyExistsExceptionException e) {
             return Response.status(Response.Status.CONFLICT).entity(new ResponseMessageBean(
-                    ResponseMessageBean.ERROR, "Application policy already exists")).build();
-
-        } catch (RestAPIException e) {
-            throw e;
+                    ResponseMessageBean.ERROR, String.format("Application policy already exists: " +
+                            "[application-policy-id] %s", applicationPolicyId))).build();
         }
-
-
     }
 
     /**
@@ -1463,7 +1459,8 @@ public class StratosApiV41 extends AbstractApi {
                     ResponseMessageBean.ERROR, "Provided Autoscaling policy is invalid")).build();
         } catch (AutoscalerServiceAutoScalingPolicyAlreadyExistExceptionException e) {
             return Response.status(Response.Status.CONFLICT).entity(new ResponseMessageBean(
-                    ResponseMessageBean.ERROR, "Autoscaling policy already exists")).build();
+                    ResponseMessageBean.ERROR, String.format("Autoscaling policy already exists " +
+                    "[autoscaling-policy-id] %s", autoscalingPolicyId))).build();
         } catch (RestAPIException e) {
             throw e;
         }

http://git-wip-us.apache.org/repos/asf/stratos/blob/e873b944/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 d1cad44..ddb4f88 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
@@ -3007,7 +3007,7 @@ public class StratosApiV41Utils {
                         .getNetworkPartitionByTenant(networkPartitionReferenceBean.getId(), tenantId);
 
                 if (networkPartition == null) {
-                    String message = String.format("Network partition not found: for [deployment-policy-id] %s" +
+                    String message = String.format("Network partition not found: for [deployment-policy-id] %s " +
                             "[network-partition-id] %s" , deploymentPolicyDefinitionBean.getId(),
                             networkPartitionReferenceBean.getId());
                     throw new RestAPIException(message);


[5/6] stratos git commit: Updating logs to display uuid and tenantId

Posted by ga...@apache.org.
Updating logs to display uuid and tenantId


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

Branch: refs/heads/tenant-isolation
Commit: eb0d28f4e2bc6d86b4ce54124e9c40ac6a046722
Parents: b228f11
Author: Dinithi <di...@wso2.com>
Authored: Fri Aug 21 10:21:39 2015 +0530
Committer: Dinithi <di...@wso2.com>
Committed: Fri Aug 21 10:21:39 2015 +0530

----------------------------------------------------------------------
 .../autoscaler/pojo/policy/PolicyManager.java   |  105 +-
 .../services/impl/AutoscalerServiceImpl.java    |  102 +-
 .../impl/CloudControllerServiceImpl.java        |  219 ++--
 .../rest/endpoint/api/StratosApiV41.java        |    7 +-
 .../rest/endpoint/api/StratosApiV41Utils.java   |    8 +-
 .../src/main/resources/AutoscalerService.wsdl   |  396 +++----
 .../main/resources/CloudControllerService.wsdl  | 1044 +++++++++---------
 7 files changed, 956 insertions(+), 925 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/pojo/policy/PolicyManager.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/pojo/policy/PolicyManager.java b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/pojo/policy/PolicyManager.java
index 1d15c1b..957386b 100644
--- a/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/pojo/policy/PolicyManager.java
+++ b/components/org.apache.stratos.autoscaler/src/main/java/org/apache/stratos/autoscaler/pojo/policy/PolicyManager.java
@@ -83,8 +83,9 @@ public class PolicyManager {
     // Add the policy to information model and persist.
     public boolean addAutoscalePolicy(AutoscalePolicy policy) throws AutoScalingPolicyAlreadyExistException {
         if (log.isInfoEnabled()) {
-            log.info(String.format("Adding autoscaling policy: [autoscaling policy-uuid] %s [autoscaling policy-id] " +
-                    "%s", policy.getUuid(), policy.getId()));
+            log.info(String.format("Adding autoscaling policy: [tenant-id] %d [autoscaling policy-uuid] %s " +
+                    "[autoscaling policy-id] " +
+                    "%s", policy.getTenantId(), policy.getUuid(), policy.getId()));
         }
         if (StringUtils.isEmpty(policy.getUuid())) {
             throw new AutoScalerException("Autoscaling policy id cannot be empty");
@@ -92,9 +93,9 @@ public class PolicyManager {
         this.addASPolicyToInformationModel(policy);
         RegistryManager.getInstance().persistAutoscalerPolicy(policy);
         if (log.isInfoEnabled()) {
-            log.info(String.format("Autoscaling policy: [autoscaling-policy-uuid] %s [autoscaling-policy-id] %s added" +
-                            " successfully",
-                    policy.getUuid(), policy.getId()));
+            log.info(String.format("Autoscaling policy: [tenant-id] %d [autoscaling-policy-uuid] %s " +
+                    "[autoscaling-policy-id] %s added successfully", policy.getTenantId(), policy.getUuid(),
+                    policy.getId()));
         }
         return true;
     }
@@ -106,8 +107,8 @@ public class PolicyManager {
         this.updateASPolicyInInformationModel(policy);
         RegistryManager.getInstance().persistAutoscalerPolicy(policy);
         if (log.isInfoEnabled()) {
-            log.info(String.format("Autoscaling policy updated successfully: [autoscaling policy-uuid] %s " +
-                            "[autoscaling policy-id] %s", policy.getUuid(), policy.getId()));
+            log.info(String.format("Autoscaling policy updated successfully: [tenant-id] %d [autoscaling policy-uuid]" +
+                    " %s [autoscaling policy-id] %s", policy.getTenantId(), policy.getUuid(), policy.getId()));
         }
         return true;
     }
@@ -136,8 +137,8 @@ public class PolicyManager {
         RegistryManager.getInstance().persistDeploymentPolicy(policy);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Deployment policy is added successfully: [deployment-policy-id] %s",
-                    policy.getUuid()));
+            log.info(String.format("Deployment policy added successfully: [tenant-id] %d [deployment-policy-uuid] %s " +
+                            "[deployment-policy-id] %s", policy.getTenantId(), policy.getUuid(), policy.getId()));
         }
     }
 
@@ -151,12 +152,15 @@ public class PolicyManager {
             throws InvalidDeploymentPolicyException {
         if (!deploymentPolicyListMap.containsKey(deploymentPolicy.getUuid())) {
             if (log.isDebugEnabled()) {
-                log.debug("Adding deployment policy: " + deploymentPolicy.getUuid());
+                log.debug(String.format("Adding deployment policy [tenant-id] %d [deployment-policy-uuid] %s " +
+                                "deployment-policy-id] %s: ", deploymentPolicy.getTenantId(),
+                        deploymentPolicy.getUuid(), deploymentPolicy.getId()));
             }
             deploymentPolicyListMap.put(deploymentPolicy.getUuid(), deploymentPolicy);
         } else {
-            String errMsg = "Specified deployment policy [" +
-                    deploymentPolicy.getUuid() + "] already exists";
+            String errMsg = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid] " +
+                            "%s [deployment-policy-id] %s", deploymentPolicy.getTenantId(),
+                    deploymentPolicy.getUuid(), deploymentPolicy.getId());
             log.error(errMsg);
             throw new InvalidDeploymentPolicyException(errMsg);
         }
@@ -169,7 +173,9 @@ public class PolicyManager {
         this.updateDeploymentPolicyInInformationModel(policy);
         RegistryManager.getInstance().persistDeploymentPolicy(policy);
         if (log.isInfoEnabled()) {
-            log.info(String.format("Deployment policy is updated successfully: [id] %s", policy.getUuid()));
+            log.info(String.format("Deployment policy updated successfully: [tenant-id] %d [deployment-policy-uuid] " +
+                            "%s [deployment-policy-id] %s", policy.getTenantId(),
+                    policy.getUuid(), policy.getId()));
         }
         return true;
     }
@@ -185,7 +191,7 @@ public class PolicyManager {
         RegistryManager.getInstance().removeDeploymentPolicy(deploymentPolicyId);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Deployment policy is removed successfully: [deployment-policy-id] %s",
+            log.info(String.format("Deployment policy removed successfully: [deployment-policy-id] %s",
                     deploymentPolicyId));
         }
     }
@@ -193,11 +199,15 @@ public class PolicyManager {
     public void addASPolicyToInformationModel(AutoscalePolicy asPolicy) throws AutoScalingPolicyAlreadyExistException {
         if (!autoscalePolicyListMap.containsKey(asPolicy.getUuid())) {
             if (log.isDebugEnabled()) {
-                log.debug("Adding autoscaling policy: " + asPolicy.getUuid());
+                log.debug(String.format("Adding autoscaling policy: [tenant-id] %d [autoscaling-policy-uuid] " +
+                        "%s " +
+                        "[autoscaling-policy-id] %s", asPolicy.getTenantId(), asPolicy.getUuid(), asPolicy.getId()));
             }
             autoscalePolicyListMap.put(asPolicy.getUuid(), asPolicy);
         } else {
-            String errMsg = "Specified autoscaling policy [" + asPolicy.getUuid() + "] already exists";
+            String errMsg = String.format("Specified autoscaling policy already exists: [tenant-id] %d " +
+                    "[autoscaling-policy-uuid] %s [autoscaling-policy-id] %s", asPolicy.getTenantId(),
+                    asPolicy.getUuid(), asPolicy.getId());
             log.error(errMsg);
             throw new AutoScalingPolicyAlreadyExistException(errMsg);
         }
@@ -206,7 +216,9 @@ public class PolicyManager {
     public void updateASPolicyInInformationModel(AutoscalePolicy asPolicy) throws InvalidPolicyException {
         if (autoscalePolicyListMap.containsKey(asPolicy.getUuid())) {
             if (log.isDebugEnabled()) {
-                log.debug("Updating autoscaling policy: " + asPolicy.getUuid());
+                log.debug(String.format("Updating autoscaling policy: [tenant-id] %d [autoscaling-policy-uuid] %s " +
+                                "[autoscaling-policy-id] %s", asPolicy.getTenantId(), asPolicy.getUuid(),
+                        asPolicy.getId()));
             }
             autoscalePolicyListMap.put(asPolicy.getUuid(), asPolicy);
         }
@@ -215,20 +227,22 @@ public class PolicyManager {
     public void updateDeploymentPolicyInInformationModel(DeploymentPolicy deploymentPolicy) throws InvalidPolicyException {
         if (deploymentPolicyListMap.containsKey(deploymentPolicy.getUuid())) {
             if (log.isDebugEnabled()) {
-                log.debug("Updating deployment policy: " + deploymentPolicy.getUuid());
+                log.debug(String.format("Updating deployment policy: [tenant-id] %d [deployment-policy-uuid] " +
+                                "%s [deployment-policy-id] %s", deploymentPolicy.getTenantId(),
+                        deploymentPolicy.getUuid(), deploymentPolicy.getId()));
             }
             deploymentPolicyListMap.put(deploymentPolicy.getUuid(), deploymentPolicy);
         }
     }
 
-    public void removeASPolicyInInformationModel(String policyID) throws PolicyDoesNotExistException {
-        if (autoscalePolicyListMap.containsKey(policyID)) {
+    public void removeASPolicyInInformationModel(String policyId) throws PolicyDoesNotExistException {
+        if (autoscalePolicyListMap.containsKey(policyId)) {
             if (log.isDebugEnabled()) {
-                log.debug("Updating autoscaling policy: " + policyID);
+                log.debug("Removing autoscaling policy: [autoscaling-policy-id] " + policyId);
             }
-            autoscalePolicyListMap.remove(policyID);
+            autoscalePolicyListMap.remove(policyId);
         } else {
-            throw new PolicyDoesNotExistException("No such policy ID [" + policyID + "] exists");
+            throw new PolicyDoesNotExistException("No such policy exists: [autoscaling-policy-id] " + policyId);
         }
     }
 
@@ -239,7 +253,8 @@ public class PolicyManager {
             }
             applicationPolicyListMap.remove(applicationPolicyId);
         } else {
-            throw new InvalidPolicyException(String.format("Application policy not found: [application-policy-id] %s", applicationPolicyId));
+            throw new InvalidPolicyException(String.format("Application policy not found: [application-policy-id] " +
+                    "%s", applicationPolicyId));
         }
     }
 
@@ -303,11 +318,13 @@ public class PolicyManager {
         }
         if (!deploymentPolicyListMap.containsKey(policy.getUuid())) {
             if (log.isDebugEnabled()) {
-                log.debug("Adding deployment policy: [deployment-policy-id] " + policy.getUuid());
+                log.debug(String.format("Adding deployment policy: [tenant-id] %d [deployment-policy-uuid] %s " +
+                        "[deployment-policy-id] %s ", policy.getTenantId(), policy.getUuid(), policy.getId()));
             }
             deploymentPolicyListMap.put(policy.getUuid(), policy);
         } else {
-            String errMsg = "Deployment policy already exists: [deployment-policy-id] " + policy.getUuid();
+            String errMsg = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid] " +
+                    "%s [deployment-policy-id] %s ", policy.getTenantId(), policy.getUuid(), policy.getId());
             log.error(errMsg);
         }
     }
@@ -383,20 +400,21 @@ public class PolicyManager {
         return deploymentPolicy;
     }
 
-
     public void addApplicationPolicy(ApplicationPolicy applicationPolicy) throws InvalidApplicationPolicyException {
-        String applicationPolicyId = applicationPolicy.getUuid();
+        String applicationPolicyUuid = applicationPolicy.getUuid();
         if (log.isInfoEnabled()) {
-            log.info(String.format("Adding application policy : [application-policy-id] %s", applicationPolicyId));
+            log.info(String.format("Adding application policy : [tenant-id] %d  [application-policy-uuid] %s " +
+                    "[application-policy-id] %s", applicationPolicy.getTenantId(), applicationPolicyUuid,
+                    applicationPolicy.getId()));
         }
         this.addApplicationPolicyToInformationModel(applicationPolicy);
         RegistryManager.getInstance().persistApplicationPolicy(applicationPolicy);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Application policy is added successfully: [application-policy-id] %s",
-                            applicationPolicyId));
+            log.info(String.format("Application policy added successfully: [tenant-id] %d [application-policy-uuid] %s " +
+                            "[application-policy-id] %s", applicationPolicy.getTenantId(), applicationPolicyUuid,
+                    applicationPolicy.getId()));
         }
-
     }
 
     public boolean removeApplicationPolicy(String applicationPolicyId) throws InvalidPolicyException {
@@ -406,21 +424,26 @@ public class PolicyManager {
         this.removeApplicationPolicyInInformationModel(applicationPolicyId);
         RegistryManager.getInstance().removeApplicationPolicy(applicationPolicyId);
         if (log.isInfoEnabled()) {
-            log.info(String.format("Application policy is removed successfully: [id] %s", applicationPolicyId));
+            log.info(String.format("Application policy removed successfully: [application-policy-id] %s",
+                    applicationPolicyId));
         }
         return true;
     }
 
     public void addApplicationPolicyToInformationModel(ApplicationPolicy applicationPolicy)
             throws InvalidApplicationPolicyException {
-        String applicationPolicyId = applicationPolicy.getUuid();
-        if (!applicationPolicyListMap.containsKey(applicationPolicyId)) {
+        String applicationPolicyUuid = applicationPolicy.getUuid();
+        if (!applicationPolicyListMap.containsKey(applicationPolicyUuid)) {
             if (log.isDebugEnabled()) {
-                log.debug("Adding application policy : " + applicationPolicyId);
+                log.debug(String.format("Adding application policy: [tenant-id] %d  [application-policy-uuid] %s " +
+                                "[application-policy-id] %s", applicationPolicy.getTenantId(), applicationPolicyUuid,
+                        applicationPolicy.getId()));
             }
-            applicationPolicyListMap.put(applicationPolicyId, applicationPolicy);
+            applicationPolicyListMap.put(applicationPolicyUuid, applicationPolicy);
         } else {
-            String errMsg = "Application policy already exists : " + applicationPolicyId;
+            String errMsg = String.format("Application policy already exists : [tenant-id] %d  " +
+                            "[application-policy-uuid] %s [application-policy-id] %s",
+                    applicationPolicy.getTenantId(), applicationPolicyUuid, applicationPolicy.getId());
             log.error(errMsg);
             throw new InvalidApplicationPolicyException(errMsg);
         }
@@ -456,7 +479,9 @@ public class PolicyManager {
     public void updateApplicationPolicyInInformationModel(ApplicationPolicy applicationPolicy) {
         if (applicationPolicyListMap.containsKey(applicationPolicy.getUuid())) {
             if (log.isDebugEnabled()) {
-                log.debug("Updating application policy: " + applicationPolicy.getUuid());
+                log.debug(String.format("Updating application policy: [tenant-id] %d  [application-policy-uuid] %s " +
+                                "[application-policy-id] %s", applicationPolicy.getTenantId(), applicationPolicy.getUuid(),
+                        applicationPolicy.getId()));
             }
             applicationPolicyListMap.put(applicationPolicy.getUuid(), applicationPolicy);
         }
@@ -469,7 +494,7 @@ public class PolicyManager {
         this.updateApplicationPolicyInInformationModel(applicationPolicy);
         RegistryManager.getInstance().persistApplicationPolicy(applicationPolicy);
         if (log.isInfoEnabled()) {
-            log.info(String.format("Application policy is updated successfully: [id] %s", applicationPolicy.getUuid()));
+            log.info(String.format("Application policyupdated successfully: [id] %s", applicationPolicy.getUuid()));
         }
         return true;
     }

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/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 db9a305..e5fd50d 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
@@ -109,12 +109,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         String autoscalePolicyId = autoscalePolicy.getId();
         if (PolicyManager.getInstance().getAutoscalePolicyById(autoscalePolicyId) != null && PolicyManager
                 .getInstance().getAutoscalePolicyById(autoscalePolicyId).getTenantId() == autoscalePolicy.getTenantId()) {
-            String logMessage = String.format("Autoscaling policy already exists: [tenant-id] %d " +
+            String message = String.format("Autoscaling policy already exists: [tenant-id] %d " +
                     "[autoscaling-policy-uuid] %s [autoscaling-policy-id] %s", autoscalePolicy.getTenantId(),
                     autoscalePolicy.getUuid(), autoscalePolicyId);
-            String message = String.format("Autoscaling policy already exists: [autoscaling-policy-id] %s",
-                    autoscalePolicyId);
-            log.error(logMessage);
+            log.error(message);
             throw new AutoScalingPolicyAlreadyExistException(message);
         }
         return PolicyManager.getInstance().addAutoscalePolicy(autoscalePolicy);
@@ -405,9 +403,8 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 applicationContext.setStatus(ApplicationContext.STATUS_CREATED);
                 AutoscalerContext.getInstance().updateApplicationContext(applicationContext);
             }
-            String logMessage = String.format("Application deployment failed: [application-uuid] %s ", applicationUuid);
-            String message = String.format("Application deployment failed: [application-id] %s", applicationUuid);
-            log.error(logMessage, e);
+            String message = String.format("Application deployment failed: [application-uuid] %s ", applicationUuid);
+            log.error(message, e);
             throw new RuntimeException(message, e);
         }
     }
@@ -650,11 +647,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             }
 
             if (!applicationContext.getStatus().equals(ApplicationContext.STATUS_DEPLOYED)) {
-                String logMessage = String.format("Application is not deployed: [tenant-id] %d " +
+                String message = String.format("Application is not deployed: [tenant-id] %d " +
                         "[application-uuid] %s [application-id] %s", applicationContext.getTenantId(),
                         applicationContext.getApplicationUuid(), applicationId);
-                String message = String.format("Application is not deployed: [application-id] %s", applicationId);
-                log.error(logMessage);
+                log.error(message);
                 throw new RuntimeException(message);
             }
             applicationContext.setStatus(ApplicationContext.STATUS_UNDEPLOYING);
@@ -697,12 +693,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             }
 
             if (application.getInstanceContextCount() > 0) {
-                String logMessage = String.format("Application cannot be deleted, undeployment process is still in " +
+                String message = String.format("Application cannot be deleted, undeployment process is still in " +
                                 "progress: [tenant-id] %d [application-uuid] %s [application-id] %s",
                         applicationContext.getTenantId(), applicationContext.getApplicationUuid(), applicationId);
-                String message = String.format("Application cannot be deleted, undeployment process is still in " +
-                        "progress: [application-id] %s", applicationId);
-                log.error(logMessage);
+                log.error(message);
                 throw new RuntimeException(message);
             }
 
@@ -1026,11 +1020,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         boolean isExist = PolicyManager.getInstance().checkApplicationPolicyInTenant
                 (applicationPolicy.getId(), applicationPolicy.getTenantId());
         if (isExist) {
-            String message = "Application policy already exists: [application-policy-id] " + applicationPolicyId;
-            String logMessage = String.format("Application policy already exists: [tenant-id] %d " +
+            String message = String.format("Application policy already exists: [tenant-id] %d " +
                     "[application-policy-uuid] %s [application-policy-id] %s", applicationPolicy.getTenantId(),
                     applicationPolicy.getUuid(), applicationPolicy.getId());
-            log.error(logMessage);
+            log.error(message);
             throw new ApplicationPolicyAlreadyExistsException(message);
         }
 
@@ -1038,11 +1031,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
         if (PolicyManager.getInstance().getApplicationPolicyByUuid(applicationPolicyUuid) != null && PolicyManager
                 .getInstance().getApplicationPolicyByUuid(applicationPolicyUuid).getTenantId() == applicationPolicy
                 .getTenantId()) {
-            String message = "Application policy already exists: [application-policy-id] " + applicationPolicyId;
-            String logMessage = String.format("Application policy already exists: [tenant-id] %d " +
+            String message = String.format("Application policy already exists: [tenant-id] %d " +
                             "[application-policy-uuid] %s [application-policy-id] %s", applicationPolicy.getTenantId(),
                     applicationPolicy.getUuid(), applicationPolicy.getId());
-            log.error(logMessage);
+            log.error(message);
             throw new ApplicationPolicyAlreadyExistsException(message);
         }
 
@@ -1163,15 +1155,12 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 					if (networkPartitions != null) {
 						for (int i = 0; i < networkPartitions.length; i++) {
 							if (networkPartitions[i].equals(networkPartitionId)) {
-								String logMessage = String.format("Cannot remove the network partition since it is used" +
+								String message = String.format("Cannot remove the network partition since it is used" +
                                                 " in application: [tenant-id] %d [network-partition-id] %s " +
                                                 "[application-uuid] %s [application-id] %s", tenantId,
                                         networkPartitionId, applicationContext.getApplicationUuid(),
                                         applicationContext.getApplicationId());
-                                String message = String.format("Cannot remove the network partition since it is " +
-                                                "used in application: [network-partition-id] %s [application-id] %s",
-                                        networkPartitionId, applicationContext.getApplicationId());
-								log.error(logMessage);
+								log.error(message);
 								throw new PartitionValidationException(message);
 							}
 						}
@@ -1272,24 +1261,20 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         String deploymentPolicyUuid = deploymentPolicy.getUuid();
         if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyUuid) != null) {
-            String logMessage = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid]" +
+            String message = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid]" +
                             " %s [deployment-policy-id] %s ",deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
                     deploymentPolicy.getId());
-            String message = String.format("Deployment policy already exists: [deployment-policy-id] %s ",
-                    deploymentPolicy.getId());
-            log.error(logMessage);
+            log.error(message);
             throw new DeploymentPolicyAlreadyExistsException(message);
         }
 
         String deploymentPolicyId = deploymentPolicy.getId();
         if (PolicyManager.getInstance().getDeploymentPolicyById(deploymentPolicyId) != null && PolicyManager
                 .getInstance().getDeploymentPolicyById(deploymentPolicyId).getTenantId() == deploymentPolicy.getTenantId()) {
-            String logMessage = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid]" +
+            String message = String.format("Deployment policy already exists: [tenant-id] %d [deployment-policy-uuid]" +
                             " %s [deployment-policy-id] %s ",deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(),
                     deploymentPolicy.getId());
-            String message = String.format("Deployment policy already exists: [deployment-policy-id] %s ",
-                    deploymentPolicy.getId());
-            log.error(logMessage);
+            log.error(message);
             throw new DeploymentPolicyAlreadyExistsException(message);
         }
 
@@ -1329,12 +1314,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         // deployment policy should contain at least one network partition reference
         if (null == deploymentPolicy.getNetworkPartitionRefs() || deploymentPolicy.getNetworkPartitionRefs().length == 0) {
-            String logMessage = String.format("Deployment policy does not have any network partition references: " +
+            String message = String.format("Deployment policy does not have any network partition references: " +
                     "[tenant-id] %d [deployment-policy-uuid] %s [deployment-policy-id] %s",
                     deploymentPolicy.getTenantId(), deploymentPolicyUuid, deploymentPolicyId);
-            String message = String.format("Deployment policy does not have any network partition references: " +
-                    "[deployment-policy-id] %s", deploymentPolicyId);
-            log.error(logMessage);
+            log.error(message);
             throw new InvalidDeploymentPolicyException(message);
         }
 
@@ -1344,12 +1327,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             //String networkPartitionUuid = networkPartitionRef.getUuid();
             String networkPartitionId = networkPartitionRef.getId();
             if (StringUtils.isBlank(networkPartitionId)) {
-                String message = String.format("Network partition id is blank: [deployment-policy-id] %s",
-                        deploymentPolicyId);
-                String logMessage = String.format("Network partition id is blank: [tenant-id] " +
+                String message = String.format("Network partition id is blank: [tenant-id] " +
                         "%d [deployment-policy-uuid] %s [deployment-policy-id] %s", deploymentPolicy.getTenantId(),
                         deploymentPolicyUuid, deploymentPolicyId);
-                log.error(logMessage);
+                log.error(message);
                 throw new InvalidDeploymentPolicyException(message);
             }
 
@@ -1365,12 +1346,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                 }
             }
             if (networkPartitionForTenant == null) {
-                String logMessage = String.format("Network partition not found: [tenant-id] %d " +
+                String message = String.format("Network partition not found: [tenant-id] %d " +
                                 "[deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-id] %s",
                         deploymentPolicy.getTenantId(), deploymentPolicyUuid, deploymentPolicyId, networkPartitionId);
-                String message = String.format("Network partition not found: [deployment-policy-id] %s " +
-                                "[network-partition-id] %s", deploymentPolicyId, networkPartitionId);
-                log.error(logMessage);
+                log.error(message);
                 throw new InvalidDeploymentPolicyException(message);
             }
 
@@ -1385,15 +1364,12 @@ public class AutoscalerServiceImpl implements AutoscalerService {
                     }
                 }
                 if (!isPartitionFound) {
-                    String logMessage = String.format("Partition not found: [tenant-id] " +
+                    String message = String.format("Partition not found: [tenant-id] " +
                                     "%d [deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-id] " +
                                     "%s [network=partition-uuid] %s [partition-id] %s ",
                             deploymentPolicy.getTenantId(), deploymentPolicy.getUuid(), deploymentPolicyId,
                             networkPartitionRef.getUuid(), networkPartitionId, partitionRef.getId());
-                    String message = String.format("Partition not found: [deployment-policy-id] %s " +
-                                    "[network-partition-id] %s [partition-id] %s ", deploymentPolicyId,
-                            networkPartitionId, partitionRef.getId());
-                    log.error(logMessage);
+                    log.error(message);
                     throw new InvalidDeploymentPolicyException(message);
                 }
             }
@@ -1401,44 +1377,35 @@ public class AutoscalerServiceImpl implements AutoscalerService {
             // partition algorithm can't be null or empty
             String partitionAlgorithm = networkPartitionRef.getPartitionAlgo();
             if (StringUtils.isBlank(partitionAlgorithm)) {
-                String logMessage = String.format("Partition algorithm is blank: [tenant-id] %d " +
+                String message = String.format("Partition algorithm is blank: [tenant-id] %d " +
                                 "[deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-uuid] %s " +
                                 "[network-partition-id] %s [partition-algorithm] %s",
                         deploymentPolicy.getTenantId(), deploymentPolicyUuid, deploymentPolicyId,
                         networkPartitionRef.getUuid(), networkPartitionId, partitionAlgorithm);
-                String message = String.format("Partition algorithm is blank: [deployment-policy-id] %s " +
-                                "[network-partition-id] %s [partition-algorithm] %s",
-                        deploymentPolicyId, networkPartitionId, partitionAlgorithm);
-                log.error(logMessage);
+                log.error(message);
                 throw new InvalidDeploymentPolicyException(message);
             }
 
             // partition algorithm should be either one-after-another or round-robin
             if ((!StratosConstants.PARTITION_ROUND_ROBIN_ALGORITHM_ID.equals(partitionAlgorithm))
                     && (!StratosConstants.PARTITION_ONE_AFTER_ANOTHER_ALGORITHM_ID.equals(partitionAlgorithm))) {
-                String logMessage = String.format("Partition algorithm is not valid: [tenant-id] %d " +
+                String message = String.format("Partition algorithm is not valid: [tenant-id] %d " +
                                 "[deployment-policy-uuid] %s [deployment-policy-id] %s [network-partition-uuid] %s " +
                                 "[network-partition-id] %s [partition-algorithm] %s", deploymentPolicy.getTenantId(),
                         deploymentPolicyUuid, deploymentPolicyId, networkPartitionRef.getUuid(), networkPartitionId,
                         partitionAlgorithm);
-                String message = String.format("Partition algorithm is not valid: [deployment-policy-id] %s " +
-                                "[network-partition-id] %s [partition-algorithm] %s",
-                        deploymentPolicyId, networkPartitionId, partitionAlgorithm);
-                log.error(logMessage);
+                log.error(message);
                 throw new InvalidDeploymentPolicyException(message);
             }
 
             // a network partition reference should contain at least one partition reference
             PartitionRef[] partitions = networkPartitionRef.getPartitionRefs();
             if (null == partitions || partitions.length == 0) {
-                String logMessage = String.format("Network partition does not have any partition references: " +
+                String message = String.format("Network partition does not have any partition references: " +
                                 "[tenant-id] %d [deployment-policy-uuid] %s [deployment-policy-id] %s " +
                                 "[network-partition-uuid] %s [network-partition-id] %s ", deploymentPolicy.getTenantId(),
                         deploymentPolicyUuid, deploymentPolicyId, networkPartitionRef.getUuid(), networkPartitionId);
-                String message = String.format("Network partition does not have any partition references: " +
-                                "[deployment-policy-id] %s [network-partition-id] %s", deploymentPolicyId,
-                        networkPartitionId);
-                log.error(logMessage);
+                log.error(message);
                 throw new InvalidDeploymentPolicyException(message);
             }
         }
@@ -1461,11 +1428,10 @@ public class AutoscalerServiceImpl implements AutoscalerService {
 
         String deploymentPolicyUuid = deploymentPolicy.getUuid();
         if (PolicyManager.getInstance().getDeploymentPolicy(deploymentPolicyUuid) == null) {
-            String logMessage = String.format("Deployment policy not exists: [tenant-id] %d [deployment-policy-uuid] " +
+            String message = String.format("Deployment policy not exists: [tenant-id] %d [deployment-policy-uuid] " +
                     "%s [deployment-policy-id] %s", deploymentPolicy.getTenantId(), deploymentPolicyUuid,
                     deploymentPolicy.getId());
-            String message = "Deployment policy not exists: [deployment-policy-id] " + deploymentPolicy.getId();
-            log.error(logMessage);
+            log.error(message);
             throw new DeploymentPolicyNotExistsException(message);
         }
 

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/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 96bb38c..4c12f60 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
@@ -38,7 +38,6 @@ import org.apache.stratos.common.Property;
 import org.apache.stratos.common.domain.LoadBalancingIPType;
 import org.apache.stratos.common.threading.StratosThreadPool;
 import org.apache.stratos.messaging.domain.topology.*;
-import org.wso2.carbon.context.PrivilegedCarbonContext;
 
 import java.net.MalformedURLException;
 import java.net.URL;
@@ -63,7 +62,6 @@ public class CloudControllerServiceImpl implements CloudControllerService {
 
     private CloudControllerContext cloudControllerContext = CloudControllerContext.getInstance();
     private ExecutorService executorService;
-    private int tenantId = PrivilegedCarbonContext.getThreadLocalCarbonContext().getTenantId();
     public CloudControllerServiceImpl() {
         executorService = StratosThreadPool.getExecutorService("cloud.controller.instance.manager.thread.pool", 50);
 
@@ -77,9 +75,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         handleNullObject(cartridgeConfig.getUuid(), "Cartridge definition UUID is null");
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Adding cartridge: [cartridge-uuid] %s [cartridge-type] %s [tenant id] %d ",
-                    cartridgeConfig.getUuid(), cartridgeConfig.getType(),
-                    cartridgeConfig.getTenantId()));
+            log.info(String.format("Adding cartridge: [tenant id] %d [cartridge-uuid] %s [cartridge-type] %s ",
+                    cartridgeConfig.getTenantId(), cartridgeConfig.getUuid(), cartridgeConfig.getType()));
         }
         if (log.isDebugEnabled()) {
             log.debug("Cartridge definition: " + cartridgeConfig.toString());
@@ -88,9 +85,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         try {
             CloudControllerUtil.extractIaaSProvidersFromCartridge(cartridgeConfig);
         } catch (Exception e) {
-            String message = String.format("Invalid cartridge definition: [cartridge-uuid] %s [cartridge-type] %s",
-                    " [tenant-id] ", cartridgeConfig.getUuid(), cartridgeConfig.getType(),
-                    cartridgeConfig.getTenantId());
+            String message = String.format("Invalid cartridge definition: " +
+                            "[cartridge-type] %s", cartridgeConfig.getType());
             log.error(message, e);
             throw new InvalidCartridgeDefinitionException(message, e);
         }
@@ -98,9 +94,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         String cartridgeUuid = cartridgeConfig.getUuid();
         Cartridge existingCartridge = cloudControllerContext.getCartridge(cartridgeUuid);
         if (existingCartridge != null) {
-            String message = String.format(
-                    "Cartridge already exists: [cartridge-uuid] %s [cartridge-type] %s [tenant id] %d ", cartridgeUuid,
-                    existingCartridge.getType(), existingCartridge.getTenantId());
+            String message = String.format("Cartridge already exists: [tenant id] %d [cartridge-uuid] %s " +
+                            "[cartridge-type] %s ", existingCartridge.getTenantId(), cartridgeUuid,
+                    existingCartridge.getType());
             log.error(message);
             throw new CartridgeAlreadyExistsException(message);
         }
@@ -115,8 +111,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         TopologyBuilder.handleServiceCreated(cartridgeList);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Successfully added cartridge: [cartridge-uuid] %s [cartridge-type] %s [tenant-id] %d ",
-                    cartridgeUuid, cartridgeConfig.getType(), cartridgeConfig.getTenantId()));
+            log.info(String.format("Successfully added cartridge: [tenant-id] %d [cartridge-uuid] %s [cartridge-type]" +
+                            " %s", cartridgeConfig.getTenantId(), cartridgeUuid, cartridgeConfig.getType()));
         }
         return true;
     }
@@ -129,7 +125,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         handleNullObject(cartridge, "Cartridge definition is null");
 
         if (log.isInfoEnabled()) {
-            log.info("Updating cartridge: [cartridge-type] " + cartridge.getType());
+            log.info(String.format("Updating cartridge: [tenant-id] %d [cartridge-uuid] %s [cartridge-type]" +
+                    " %s", cartridge.getTenantId(), cartridge.getUuid(), cartridge.getType()));
         }
         if (log.isDebugEnabled()) {
             log.debug("Cartridge definition: " + cartridge.toString());
@@ -152,7 +149,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             }
             copyIaasProviders(cartridge, cartridgeToBeRemoved);
         } else {
-            throw new CartridgeDefinitionNotExistsException("This cartridge definition not exists");
+            throw new CartridgeDefinitionNotExistsException("Cartridge definition not exists: [cartridge-type] " +
+                    cartridge.getType());
         }
 
         // Add cartridge to the cloud controller context and persist
@@ -161,7 +159,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         // transaction ends
 
         if (log.isInfoEnabled()) {
-            log.info("Successfully updated cartridge: [cartridge-type] " + cartridgeUuid);
+            log.info(String.format("Successfully updated cartridge: tenant-id] %d [cartridge-uuid] %s " +
+                    "[cartridge-type] %s", cartridge.getTenantId(), cartridge.getUuid(), cartridge.getType()));
         }
         return true;
     }
@@ -200,8 +199,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         removeCartridgeFromTopology(cartridge);
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Successfully removed cartridge: [cartridge-uuid] %s [cartridge-type] %s " +
-                    "[tenant-id] %d", cartridge.getUuid(), cartridge.getType(), cartridge.getTenantId()));
+            log.info(String.format("Successfully removed cartridge: [tenant-id] %d [cartridge-uuid] %s " +
+                    "[cartridge-type] %s", cartridge.getTenantId(), cartridge.getUuid(), cartridge.getType()));
         }
         return true;
     }
@@ -220,13 +219,13 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 CloudControllerContext.getInstance().persist();
 
                 if (log.isInfoEnabled()) {
-                    log.info(String.format("Successfully removed cartridge: [cartridge-uuid] %s [cartridge-type] %s " +
-                            "[tenant-id] %d", cartridge.getUuid(), cartridge.getType(), cartridge.getTenantId()));
+                    log.info(String.format("Successfully removed cartridge: [tenant-id] %d [cartridge-uuid] %s " +
+                            "[cartridge-type] %s", cartridge.getTenantId(), cartridge.getUuid(), cartridge.getType()));
                 }
                 return cartridge;
             }
         }
-        String msg = "Cartridge not found: [cartridge-type] " + cartridgeUuid;
+        String msg = "Cartridge not found: [cartridge-uuid] " + cartridgeUuid;
         log.error(msg);
         throw new InvalidCartridgeTypeException(msg);
     }
@@ -253,7 +252,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
 
     public boolean removeServiceGroup(String name) throws InvalidServiceGroupException {
         if (log.isDebugEnabled()) {
-            log.debug("CloudControllerServiceImpl:removeServiceGroup: " + name);
+            log.debug("Removing service group: [service-group-name] " + name);
         }
 
         ServiceGroup serviceGroup = null;
@@ -264,7 +263,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             if (CloudControllerContext.getInstance().getServiceGroups().remove(serviceGroup)) {
                 CloudControllerContext.getInstance().persist();
                 if (log.isInfoEnabled()) {
-                    log.info("Successfully removed the cartridge group: [group-name] " + serviceGroup);
+                    log.info(String.format("Successfully removed the cartridge group:  [service-group-name] %s", name));
                 }
                 return true;
             }
@@ -299,7 +298,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
     public String[] getServiceGroupSubGroups(String name) throws InvalidServiceGroupException {
         ServiceGroup serviceGroup = this.getServiceGroup(name);
         if (serviceGroup == null) {
-            throw new InvalidServiceGroupException("Invalid cartridge group: [group-name] " + serviceGroup);
+            throw new InvalidServiceGroupException("Invalid cartridge group: [group-name] " + name);
         }
 
         return serviceGroup.getSubGroups();
@@ -311,7 +310,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
     public String[] getServiceGroupCartridges(String name) throws InvalidServiceGroupException {
         ServiceGroup serviceGroup = this.getServiceGroup(name);
         if (serviceGroup == null) {
-            throw new InvalidServiceGroupException("Invalid cartridge group: [group-name] " + serviceGroup);
+            throw new InvalidServiceGroupException("Invalid cartridge group: [group-name] " + name);
         }
         String[] cs = serviceGroup.getCartridges();
         return cs;
@@ -321,7 +320,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
     public Dependencies getServiceGroupDependencies(String name) throws InvalidServiceGroupException {
         ServiceGroup serviceGroup = this.getServiceGroup(name);
         if (serviceGroup == null) {
-            throw new InvalidServiceGroupException("Invalid cartridge group: [group-name] " + serviceGroup);
+            throw new InvalidServiceGroupException("Invalid cartridge group: [group-name] " + name);
         }
         return serviceGroup.getDependencies();
     }
@@ -489,6 +488,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         MemberContext memberContext = new MemberContext(
                 applicationId, cartridgeType, instanceContext.getClusterId(), memberId);
 
+
         memberContext.setClusterInstanceId(instanceContext.getClusterInstanceId());
         memberContext.setNetworkPartitionId(instanceContext.getNetworkPartitionId());
         memberContext.setPartition(cloudControllerContext.getNetworkPartition(instanceContext.getNetworkPartitionId()).
@@ -896,7 +896,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                         CloudControllerUtil.sleep(1000);
                     }
 
-                    log.info(String.format("Unregistration of service cluster: [cluster-id] %s [application-id]",
+                    log.info(String.format("Unregistration of service cluster: [cluster-id] %s [application-id] %s",
                             clusterId_, ctxt.getApplicationUuid()));
                     deleteVolumes(ctxt);
                     onClusterRemoval(clusterId_);
@@ -929,8 +929,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                                         } catch (Exception ignore) {
                                             if (log.isErrorEnabled()) {
                                                 log.error((String.format("Error while deleting volume [id] %s " +
-                                                                "[application-id]", volume.getId(), ctxt.getApplicationUuid())),
-                                                        ignore);
+                                                                "[application-id] %s", volume.getId(),
+                                                                ctxt.getApplicationUuid())), ignore);
                                             }
                                         }
                                     }
@@ -980,7 +980,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
 
             Cartridge cartridge = CloudControllerContext.getInstance().getCartridge(cartridgeUuid);
             if (cartridge == null) {
-                String msg = "Cartridge not found: " + cartridgeUuid;
+                String msg = "Cartridge not found: [cartridge-uuid] " + cartridgeUuid;
                 log.error(msg);
                 throw new InvalidCartridgeTypeException(msg);
             }
@@ -1020,8 +1020,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                     CloudControllerContext.getInstance().addToCartridgeTypeToPartitionIdMap(cartridgeUuid, partitionId);
 
                     if (log.isDebugEnabled()) {
-                        log.debug("Partition " + partitionId + " added to the cache against cartridge: " +
-                                "[cartridge-uuid] " + cartridgeUuid);
+                        log.debug(String.format("Partition %s added to the cache against " +
+                                "cartridge: [tenant-id] %d [cartridge-uuid] %s [cartridge-type] %s", partitionId,
+                                cartridge.getTenantId(), cartridgeUuid, cartridge.getType()));
                     }
                 } catch (Exception e) {
                     String message = "Could not cache partitions against the cartridge: [cartridge-uuid] " + cartridgeUuid;
@@ -1037,8 +1038,10 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             // persist data
             CloudControllerContext.getInstance().persist();
 
-            log.info("All partitions [" + CloudControllerUtil.getPartitionIds(networkPartition.getPartitions()) + "]" +
-                    " were validated successfully, against the cartridge: " + cartridgeUuid);
+            log.info(String.format("All partitions [%s] were validated successfully, " +
+                            "against the cartridge: [tenant-id] %d [cartridge-uuid] %s [cartridge-type] %s",
+                    CloudControllerUtil.getPartitionIds(networkPartition.getPartitions()), cartridge.getTenantId(),
+                    cartridgeUuid, cartridge.getType()));
 
             return true;
         } finally {
@@ -1061,9 +1064,10 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         handleNullObject(partition, "Partition validation failed. Partition is null.");
 
         String provider = partition.getProvider();
-        String partitionId = partition.getUuid();
+        String partitionUuid = partition.getUuid();
 
-        handleNullObject(provider, "Partition [" + partitionId + "] validation failed. Partition provider is null.");
+        handleNullObject(provider, String.format("Partition validation failed. Partition provider is null. " +
+                "[partition-uuid] %s [partition-id] %s ", partitionUuid, partition.getId()));
         IaasProvider iaasProvider = CloudControllerConfig.getInstance().getIaasProvider(provider);
 
         return CloudControllerServiceUtil.validatePartition(partition, iaasProvider);
@@ -1245,7 +1249,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
 
         try {
             if (CloudControllerContext.getInstance().getKubernetesCluster(kubernetesCluster.getClusterUuid()) != null) {
-                throw new KubernetesClusterAlreadyExistsException("Kubernetes cluster already exists");
+                throw new KubernetesClusterAlreadyExistsException("Kubernetes cluster already exists: " +
+                        "[kubernetes-cluster] " + kubernetesCluster.getClusterId());
             }
         } catch (NonExistingKubernetesClusterException ignore) {
         }
@@ -1254,8 +1259,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             lock = CloudControllerContext.getInstance().acquireKubernetesClusterWriteLock();
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Adding kubernetes cluster: [kubernetes-cluster-id] %s",
-                        kubernetesCluster.getClusterUuid()));
+                log.info(String.format("Adding kubernetes cluster: [tenant-id] %d [kubernetes-cluster-uuid] %s " +
+                                "[kubernetes-cluster-id] %s", kubernetesCluster.getTenantId(),
+                        kubernetesCluster.getClusterUuid(), kubernetesCluster.getClusterId()));
             }
             CloudControllerUtil.validateKubernetesCluster(kubernetesCluster);
 
@@ -1264,8 +1270,10 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             CloudControllerContext.getInstance().persist();
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Kubernetes cluster added successfully: [kubernetes-cluster-id] %s",
-                        kubernetesCluster.getClusterUuid()));
+                log.info(String.format("Kubernetes cluster added successfully: [tenant-id] %d " +
+                                "[kubernetes-cluster-uuid] %s [kubernetes-cluster-id] %s",
+                        kubernetesCluster.getTenantId(), kubernetesCluster.getClusterUuid(),
+                        kubernetesCluster.getClusterId()));
             }
             return true;
         } catch (Exception e) {
@@ -1287,8 +1295,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             lock = CloudControllerContext.getInstance().acquireKubernetesClusterWriteLock();
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Updating kubernetes cluster: [kubernetes-cluster-id] %s",
-                        kubernetesCluster.getClusterUuid()));
+                log.info(String.format("Updating kubernetes cluster: [tenant-id] %d [kubernetes-cluster-uuid] %s " +
+                                "[kubernetes-cluster-id] %s", kubernetesCluster.getTenantId(),
+                        kubernetesCluster.getClusterUuid(), kubernetesCluster.getClusterId()));
             }
             CloudControllerUtil.validateKubernetesCluster(kubernetesCluster);
 
@@ -1297,8 +1306,10 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             CloudControllerContext.getInstance().persist();
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Kubernetes cluster updated successfully: [kubernetes-cluster-id] %s",
-                        kubernetesCluster.getClusterUuid()));
+                log.info(String.format("Kubernetes cluster updated successfully: [tenant-id] %d " +
+                                "[kubernetes-cluster-uuid] %s [kubernetes-cluster-id] %s",
+                        kubernetesCluster.getTenantId(), kubernetesCluster.getClusterUuid(),
+                        kubernetesCluster.getClusterId()));
             }
             return true;
         } catch (Exception e) {
@@ -1337,7 +1348,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 kubernetesHostArrayList = new ArrayList<KubernetesHost>();
             } else {
                 if (CloudControllerContext.getInstance().kubernetesHostExists(kubernetesHost.getHostId())) {
-                    throw new InvalidKubernetesHostException("Kubernetes host already exists: [hostname] " +
+                    throw new InvalidKubernetesHostException("Kubernetes host already exists: [kubernetes-host-id] " +
                             kubernetesHost.getHostId());
                 }
                 kubernetesHostArrayList = new
@@ -1351,7 +1362,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             CloudControllerContext.getInstance().persist();
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Kubernetes host added successfully: [id] %s", kubernetesCluster.getClusterUuid()));
+                log.info(String.format("Kubernetes host added successfully: [kubernetes-cluster-id] %s " +
+                                "[kubernetes-host-id] %s", kubernetesCluster.getClusterUuid(), kubernetesHost.getHostId()));
             }
 
             return true;
@@ -1381,7 +1393,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             CloudControllerContext.getInstance().removeKubernetesCluster(groupUuid);
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Kubernetes cluster removed successfully: [id] %s", groupUuid));
+                log.info(String.format("Kubernetes cluster removed successfully: [kubernetes-cluster-uuid] %s",
+                        groupUuid));
             }
 
             CloudControllerContext.getInstance().persist();
@@ -1412,7 +1425,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
 
                 // Kubernetes master cannot be removed
                 if (kubernetesClusterStored.getKubernetesMaster().getHostId().equals(kubernetesHostId)) {
-                    throw new NonExistingKubernetesHostException("Kubernetes master is not allowed to be removed [id] " + kubernetesHostId);
+                    throw new NonExistingKubernetesHostException("Kubernetes master is not allowed to be removed " +
+                            "[kubernetes-host-id] " + kubernetesHostId);
                 }
 
                 List<KubernetesHost> kubernetesHostList = new ArrayList<KubernetesHost>();
@@ -1423,7 +1437,8 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 }
                 // member count will be equal only when host object was not found
                 if (kubernetesHostList.size() == kubernetesClusterStored.getKubernetesHosts().length) {
-                    throw new NonExistingKubernetesHostException("Kubernetes host not found for [id] " + kubernetesHostId);
+                    throw new NonExistingKubernetesHostException("Kubernetes host not found for [kubernetes-host-id] " +
+                            "" + kubernetesHostId);
                 }
                 KubernetesHost[] kubernetesHostsArray = new KubernetesHost[kubernetesHostList.size()];
                 kubernetesHostList.toArray(kubernetesHostsArray);
@@ -1432,7 +1447,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 kubernetesClusterStored.setKubernetesHosts(kubernetesHostsArray);
 
                 if (log.isInfoEnabled()) {
-                    log.info(String.format("Kubernetes host removed successfully: [id] %s", kubernetesHostId));
+                    log.info(String.format("Kubernetes host removed successfully: [kubernetes-host-id] %s", kubernetesHostId));
                 }
 
                 CloudControllerContext.getInstance().persist();
@@ -1490,7 +1505,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             lock = CloudControllerContext.getInstance().acquireKubernetesClusterWriteLock();
             CloudControllerUtil.validateKubernetesHost(kubernetesHost);
             if (log.isInfoEnabled()) {
-                log.info("Updating Kubernetes Host: " + kubernetesHost);
+                log.info("Updating Kubernetes Host: [kubernetes-host-id] " + kubernetesHost);
             }
 
             try {
@@ -1502,7 +1517,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                         kubernetesHosts[i] = kubernetesHost;
 
                         if (log.isInfoEnabled()) {
-                            log.info(String.format("Kubernetes host updated successfully: [id] %s", kubernetesHost.getHostId()));
+                            log.info(String.format("Kubernetes host updated successfully: [kubernetes-host-id] %s", kubernetesHost.getHostId()));
                         }
 
                         CloudControllerContext.getInstance().updateKubernetesCluster(kubernetesClusterStored);
@@ -1518,7 +1533,7 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 CloudControllerContext.getInstance().releaseWriteLock(lock);
             }
         }
-        throw new NonExistingKubernetesHostException("Kubernetes host not found [id] " + kubernetesHost.getHostId());
+        throw new NonExistingKubernetesHostException("Kubernetes host not found [kubernetes-host-id] " + kubernetesHost.getHostId());
     }
 
     @Override
@@ -1530,15 +1545,21 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         handleNullObject(networkPartition.getUuid(), "Network Partition Id is null");
 
         if (log.isInfoEnabled()) {
-            log.info(String.format("Adding network partition: [network-partition-uuid] %s",
-                    networkPartition.getUuid()));
+            log.info(String.format("Adding network partition: [tenant-id] %d [network-partition-uuid] %s " +
+                            "[network-partition-id] %s", networkPartition.getTenantId(), networkPartition.getUuid(),
+                    networkPartition.getId()));
         }
 
         String networkPartitionUuid = networkPartition.getUuid();
         if (cloudControllerContext.getNetworkPartition(networkPartitionUuid) != null) {
-            String message = "Network partition already exists: [network-partition-uuid] " + networkPartitionUuid +
-                    "[network-partition-id] " + networkPartition.getId();
-            log.error(message);
+            String logMessage = String.format("Network partition already exists: [tenant-id] %d " +
+                            "[network-partition-uuid]" +
+                            " %s [network-partition-id] %s", networkPartition.getTenantId(), networkPartition.getUuid(),
+                    networkPartition.getId());
+            String message = String.format("Network partition already exists: [network-partition-id] %s",
+                    networkPartition.getId());
+
+            log.error(logMessage);
             throw new NetworkPartitionAlreadyExistsException(message);
         }
 
@@ -1546,8 +1567,13 @@ public class CloudControllerServiceImpl implements CloudControllerService {
 
         if (cloudControllerContext.getNetworkPartitionForTenant(networkPartitionId,
                 networkPartition.getTenantId()) != null) {
-            String message = "Network partition already exists: [network-partition-id] " + networkPartitionId;
-            log.error(message);
+            String logMessage = String.format("Network partition already exists: [tenant-id] %d " +
+                            "[network-partition-uuid]" +
+                            " %s [network-partition-id] %s", networkPartition.getTenantId(), networkPartition.getUuid(),
+                    networkPartition.getId());
+            String message = String.format("Network partition already exists: [network-partition-id] %s",
+                    networkPartition.getId());
+            log.error(logMessage);
             throw new NetworkPartitionAlreadyExistsException(message);
         }
 
@@ -1555,9 +1581,10 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             for (Partition partition : networkPartition.getPartitions()) {
                 if (partition != null) {
                     if (log.isInfoEnabled()) {
-                        log.info(String.format("Validating partition: [network-partition-uuid] %s " +
-                                        "[network-partition-id] %s [partition-id] %s", networkPartitionUuid,
-                                networkPartition.getId(), partition.getUuid()));
+                        log.info(String.format("Validating partition: [tenant-id] %d[network-partition-uuid] %s " +
+                                        "[network-partition-id] %s [partition-id] %s",
+                                networkPartition.getTenantId(), networkPartitionUuid, networkPartition.getId(),
+                                partition.getUuid()));
                     }
                     // Overwrites partition provider with network partition provider
                     partition.setProvider(networkPartition.getProvider());
@@ -1566,22 +1593,24 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                     } catch (InvalidPartitionException e) {
                         //Following message is shown to the end user in all the the API clients(GUI/CLI/Rest API)
                         throw new InvalidNetworkPartitionException(String.format("Network partition " +
-                                        "[network-partition-uuid] %s [network-partition-id] %s , " +
+                                        "[tenant-id] %d [network-partition-uuid] %s [network-partition-id] %s , " +
                                         "is invalid since the partition %s is invalid",
-                                networkPartition.getUuid(), networkPartition.getId(), partition.getUuid()), e);
+                                networkPartition.getTenantId(), networkPartition.getUuid(), networkPartition.getId(),
+                                partition.getUuid()), e);
                     }
                     if (log.isInfoEnabled()) {
-                        log.info(String.format("Partition validated successfully: [network-partition-uuid] %s " +
-                                        "[network-partition-id] %s [partition-id] %s", networkPartition.getUuid(),
-                                networkPartition.getId(), partition.getUuid()));
+                        log.info(String.format("Partition validated successfully: [tenant-id] %d " +
+                                        "[network-partition-uuid] %s [network-partition-id] %s [partition-id] %s",
+                                networkPartition.getTenantId(), networkPartition.getUuid(), networkPartition.getId(),
+                                partition.getUuid()));
                     }
                 }
             }
         } else {
             //Following message is shown to the end user in all the the API clients(GUI/CLI/Rest API)
-            throw new InvalidNetworkPartitionException(String.format("Network partition [network-partition-uuid] %s " +
-                            "[network-partition-id] %s, doesn't not have any partitions ", networkPartition.getUuid(),
-                    networkPartition.getId()));
+            throw new InvalidNetworkPartitionException(String.format("Network partition [tenant-id] %d " +
+                            "[network-partition-uuid] %s [network-partition-id] %s, doesn't not have any partitions ",
+                    networkPartition.getTenantId(), networkPartition.getUuid(), networkPartition.getId()));
         }
 
         // adding network partition to CC-Context
@@ -1589,8 +1618,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         // persisting CC-Context
         CloudControllerContext.getInstance().persist();
         if (log.isInfoEnabled()) {
-            log.info(String.format("Network partition added successfully: [network-partition-uuid] %s " +
-                    "[network-partition-id] %s", networkPartition.getUuid(),networkPartition.getId()));
+            log.info(String.format("Network partition added successfully: [tenant-id] %d [network-partition-uuid] %s " +
+                    "[network-partition-id] %s", networkPartition.getTenantId(), networkPartition.getUuid(),
+                    networkPartition.getId()));
         }
         return true;
     }
@@ -1607,13 +1637,15 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 String networkPartitionUuid = networkPartition.getUuid();
 
                 if (log.isInfoEnabled()) {
-                    log.info(String.format("Removing network partition: [network-partition-uuid] %s " +
-                            "[network-partition-id] %s", networkPartitionUuid, networkPartitionId));
+                    log.info(String.format("Removing network partition: [tenant-id] %d [network-partition-uuid] %s " +
+                            "[network-partition-id] %s", networkPartition.getTenantId(), networkPartitionUuid,
+                            networkPartitionId));
                 }
                 handleNullObject(networkPartitionId, "Network Partition Id is null");
 
                 if (networkPartitionUuid == null) {
-                    String message = String.format("Network partition not found:[network-partition-id] %s", networkPartitionId);
+                    String message = String.format("Network partition not found: [network-partition-id] %s",
+                            networkPartitionId);
                     log.error(message);
                     throw new NetworkPartitionNotExistsException(message);
                 }
@@ -1622,8 +1654,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 // persisting CC-Context
                 CloudControllerContext.getInstance().persist();
                 if (log.isInfoEnabled()) {
-                    log.info(String.format("Network partition removed successfully: [network-partition-uuid] %s " +
-                            "[network-partition-id] %s", networkPartitionUuid, networkPartitionId));
+                    log.info(String.format("Network partition removed successfully: [tenant-id] %d " +
+                            "[network-partition-uuid] %s [network-partition-id] %s", networkPartition.getTenantId(),
+                            networkPartitionUuid, networkPartitionId));
                 }
             } else {
                 String message = String.format("Network partition not found: [network-partition-id] %s",
@@ -1650,14 +1683,17 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             handleNullObject(networkPartition.getUuid(), "Network Partition Id is null");
 
             if (log.isInfoEnabled()) {
-                log.info(String.format("Updating network partition: [network-partition-id] %s", networkPartition.getUuid()));
+                log.info(String.format("Updating network partition: [tenant-id] %d [network-partition-uuid] %s " +
+                                "[network-partition-id] %s", networkPartition.getTenantId(),
+                        networkPartition.getUuid(), networkPartition.getId()));
             }
 
             String networkPartitionId = networkPartition.getId();
             String networkPartitionUuid = networkPartition.getUuid();
             if (cloudControllerContext.getNetworkPartition(networkPartitionUuid) == null) {
-                String message = String.format("Network partition not found: [network-partition-uuid] %s " +
-                        "[network-partition-id] %s", networkPartitionUuid, networkPartitionId);
+                String message = String.format("Network partition not found: [tenant-id] %d [network-partition-uuid] %s " +
+                                "[network-partition-id] %s", networkPartition.getTenantId(),
+                        networkPartition.getUuid(), networkPartition.getId());
                 log.error(message);
                 throw new NetworkPartitionNotExistsException(message);
             }
@@ -1666,17 +1702,19 @@ public class CloudControllerServiceImpl implements CloudControllerService {
                 for (Partition partition : networkPartition.getPartitions()) {
                     if (partition != null) {
                         if (log.isInfoEnabled()) {
-                            log.info(String.format("Validating partition: [network-partition-uuid] %s " +
-                                            "[network-partition-id] %s [partition-id] %s", networkPartitionUuid,
-                                    networkPartitionId, partition.getUuid()));
+                            log.info(String.format("Validating partition: [tenant-id] %d [network-partition-uuid] %s" +
+                                            "[network-partition-id] %s [partition-uuid] %s [partition-id] %s ",
+                                    networkPartition.getTenantId(), networkPartitionUuid, networkPartitionId,
+                                    partition.getUuid(), partition.getId()));
                         }
                         // Overwrites partition provider with network partition provider
                         partition.setProvider(networkPartition.getProvider());
                         validatePartition(partition);
                         if (log.isInfoEnabled()) {
-                            log.info(String.format("Partition validated successfully: [network-partition-uuid] %s " +
-                                            "[network-partition-uuid] %s [partition-id] %s", networkPartitionUuid,
-                                    networkPartitionId, partition.getUuid()));
+                            log.info(String.format("Partition validated successfully: [tenant-id] %d " +
+                                            "[network-partition-uuid] %s [network-partition-id] %s [partition-uuid] " +
+                                            "%s [partition-id] %s ", networkPartition.getTenantId(),
+                                    networkPartitionUuid, networkPartitionId, partition.getUuid(), partition.getId()));
                         }
                     }
                 }
@@ -1687,8 +1725,9 @@ public class CloudControllerServiceImpl implements CloudControllerService {
             // persisting CC-Context
             CloudControllerContext.getInstance().persist();
             if (log.isInfoEnabled()) {
-                log.info(String.format("Network partition updated successfully: [network-partition-uuid] %s " +
-                        "[network-partition-id] %s", networkPartitionUuid, networkPartitionId));
+                log.info(String.format("Network partition updated successfully: [tenant-id] %d [network-partition-uuid] %s " +
+                                "[network-partition-id] %s", networkPartition.getTenantId(),
+                        networkPartition.getUuid(), networkPartition.getId()));
             }
             return true;
         } catch (Exception e) {

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
index 32be807..ec1a17c 100644
--- a/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
+++ b/components/org.apache.stratos.rest.endpoint/src/main/java/org/apache/stratos/rest/endpoint/api/StratosApiV41.java
@@ -303,8 +303,7 @@ public class StratosApiV41 extends AbstractApi {
             //Ignore this since this is valid(cartridge is does not exist) when adding the cartridge for first time
         }
         if (cartridgeBean != null) {
-            String msg = String.format("Cartridge already exists: [tenant-id] %d [cartridge-uuid] %s [cartridge-type] %s ",
-                    tenantId, cartridgeUuid, cartridgeType);
+            String msg = String.format("Cartridge already exists: [cartridge-type] %s ", cartridgeType);
             log.warn(msg);
             return Response.status(Response.Status.CONFLICT)
                     .entity(new ResponseMessageBean(ResponseMessageBean.ERROR, msg)).build();
@@ -499,8 +498,8 @@ public class StratosApiV41 extends AbstractApi {
         groupBean = StratosApiV41Utils.getServiceGroupDefinition(cartridgeGroupBean.getName(), carbonContext.getTenantId());
 
         if (groupBean != null) {
-            String msg = String.format("Cartridge already exists: [tenant-id] %d [cartridge-uuid] %s [cartridge-type]" +
-                    "%s", tenantId, cartrideGroupUuid, cartridgeGroupBean.getName());
+            String msg = String.format("Cartridge group already exists: [cartridge-group-name] %s",
+                    cartridgeGroupBean.getName());
             log.warn(msg);
             return Response.status(Response.Status.CONFLICT)
                     .entity(new ResponseMessageBean(ResponseMessageBean.ERROR, msg)).build();

http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/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 ddb4f88..5c9f3f0 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
@@ -284,17 +284,19 @@ public class StratosApiV41Utils {
 
         // Validate whether cartridge can be removed
         if (!smServiceClient.canCartridgeBeRemoved(cartridge.getUuid())) {
-            String message = String.format("Cannot remove cartridge : [tenant-id] %d [cartridge-uuid] %s " +
+            String logMessage = String.format("Cannot remove cartridge : [tenant-id] %d [cartridge-uuid] %s " +
                             "[cartridge-type] %s since it is used in another cartridge group or an application",
                     tenantId, cartridge.getUuid(), cartridgeType);
-            log.error(message);
+            String message = String.format("Cannot remove cartridge :n[cartridge-type] %s since it is used in another" +
+                            " cartridge group or an application", cartridgeType);
+            log.error(logMessage);
             throw new RestAPIException(message);
         }
         cloudControllerServiceClient.removeCartridge(cartridge.getUuid());
 
         if (log.isInfoEnabled()) {
             log.info(String.format("Successfully removed cartridge: [tenant-id] %d [cartridge-uuid] %s " +
-                    "[cartridge-type] %s from tenant: ", tenantId, cartridge.getUuid(), cartridgeType));
+                    "[cartridge-type] %s", tenantId, cartridge.getUuid(), cartridgeType));
         }
     }
 


[3/6] stratos git commit: Updating logs to display uuid and tenantId

Posted by ga...@apache.org.
http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/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 cf3a864..c967572 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,858 +1,858 @@
-<?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:ax25="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:ax21="http://domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax22="http://common.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">
+<?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:ax29="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd" xmlns:ax213="http://topology.domain.messaging.stratos.apache.org/xsd" xmlns:ax26="http://exception.controller.cloud.stratos.apache.org/xsd" xmlns:ax24="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://domain.controller.cloud.stratos.apache.org/xsd"/>
+        <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://kubernetes.domain.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:element name="getNetworkPartitionUuid">
+            <xs:import namespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd"/>
+            <xs:element name="CloudControllerServiceInvalidCartridgeDefinitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax21:InvalidCartridgeDefinitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionUuidResponse">
+            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax21:InvalidIaasProviderException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getPartitionsByNetworkPartition">
+            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax21:CartridgeDefinitionNotExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getPartitionsByNetworkPartitionResponse">
+            <xs:element name="updateCartridge">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:Partition"/>
+                        <xs:element minOccurs="0" name="cartridge" nillable="true" type="ax26:Cartridge"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
+            <xs:element name="updateCartridgeResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax25:NonExistingKubernetesClusterException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesCluster">
+            <xs:element name="CloudControllerServiceInvalidCartridgeTypeException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="groupUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax21:InvalidCartridgeTypeException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesClusterResponse">
+            <xs:element name="removeCartridge">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="cartridgeUuid" nillable="true" type="xs:string"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="removeCartridgeResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
+            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax25:NonExistingKubernetesHostException"/>
+                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax21:InvalidServiceGroupException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesHost">
+            <xs:element name="addServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax26:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeKubernetesHostResponse">
+            <xs:element name="addServiceGroupResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesMasterException">
+            <xs:element name="removeServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesMasterException" nillable="true" type="ax25:InvalidKubernetesMasterException"/>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNonExistingKubernetesMasterException">
+            <xs:element name="removeServiceGroupResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NonExistingKubernetesMasterException" nillable="true" type="ax25:NonExistingKubernetesMasterException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesMaster">
+            <xs:element name="getServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax29:KubernetesMaster"/>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesMasterResponse">
+            <xs:element name="getServiceGroupResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNetworkPartitionAlreadyExistsException">
+            <xs:element name="getServiceGroupSubGroups">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NetworkPartitionAlreadyExistsException" nillable="true" type="ax25:NetworkPartitionAlreadyExistsException"/>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidNetworkPartitionException">
+            <xs:element name="getServiceGroupSubGroupsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidNetworkPartitionException" nillable="true" type="ax25:InvalidNetworkPartitionException"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addNetworkPartition">
+            <xs:element name="getServiceGroupCartridges">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax24:NetworkPartition"/>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addNetworkPartitionResponse">
+            <xs:element name="getServiceGroupCartridgesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceNetworkPartitionNotExistsException">
+            <xs:element name="getServiceGroupDependencies">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="NetworkPartitionNotExistsException" nillable="true" type="ax25:NetworkPartitionNotExistsException"/>
+                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeNetworkPartition">
+            <xs:element name="getServiceGroupDependenciesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:Dependencies"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeNetworkPartitionResponse">
+            <xs:element name="CloudControllerServiceInvalidPartitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax21:InvalidPartitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateNetworkPartition">
+            <xs:element name="validatePartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax24:NetworkPartition"/>
+                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax26:Partition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateNetworkPartitionResponse">
+            <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="getNetworkPartitions">
+            <xs:element name="validateDeploymentPolicyNetworkPartition">
                 <xs:complexType>
-                    <xs:sequence/>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="cartridgeUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="networkPartitionUuid" nillable="true" type="xs:string"/>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionsResponse">
+            <xs:element name="validateDeploymentPolicyNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:NetworkPartition"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionsByTenant">
+            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax21:CartridgeNotFoundException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionsByTenantResponse">
+            <xs:element name="registerService">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:NetworkPartition"/>
+                        <xs:element minOccurs="0" name="registrant" nillable="true" type="ax26:Registrant"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartition">
+            <xs:element name="registerServiceResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionResponse">
+            <xs:element name="CloudControllerServiceCloudControllerException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:NetworkPartition"/>
+                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax21:CloudControllerException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgesByTenant">
+            <xs:element name="startInstances">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax26:InstanceContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgesByTenantResponse">
+            <xs:element name="startInstancesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:Cartridge"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:MemberContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionByTenant">
+            <xs:element name="CloudControllerServiceInvalidMemberException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax21:InvalidMemberException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getNetworkPartitionByTenantResponse">
+            <xs:element name="terminateInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:NetworkPartition"/>
+                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeNotFoundException">
+            <xs:element name="terminateInstanceResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax25:CartridgeNotFoundException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidIaasProviderException">
+            <xs:element name="terminateInstanceForcefully">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidIaasProviderException" nillable="true" type="ax25:InvalidIaasProviderException"/>
+                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCloudControllerException">
+            <xs:element name="terminateInstanceForcefullyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CloudControllerException" nillable="true" type="ax25:CloudControllerException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstance">
+            <xs:element name="CloudControllerServiceInvalidClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax24:InstanceContext"/>
+                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax21:InvalidClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstanceResponse">
+            <xs:element name="terminateInstances">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:MemberContext"/>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getIaasProviders">
+            <xs:element name="terminateInstancesResponse">
                 <xs:complexType>
-                    <xs:sequence/>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                    </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getIaasProvidersResponse">
+            <xs:element name="updateClusterStatus">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
+                        <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="CloudControllerServiceInvalidCartridgeDefinitionException">
+            <xs:element name="updateClusterStatusResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeDefinitionException" nillable="true" type="ax25:InvalidCartridgeDefinitionException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
+            <xs:element name="CloudControllerServiceUnregisteredClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax25:CartridgeAlreadyExistsException"/>
+                        <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax21:UnregisteredClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addCartridge">
+            <xs:element name="unregisterService">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax24:Cartridge"/>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addCartridgeResponse">
+            <xs:element name="unregisterServiceResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceCartridgeDefinitionNotExistsException">
+            <xs:element name="getCartridgeByTenant">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeDefinitionNotExistsException" nillable="true" type="ax25:CartridgeDefinitionNotExistsException"/>
+                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridge">
+            <xs:element name="getCartridgeByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridge" nillable="true" type="ax24:Cartridge"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:Cartridge"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateCartridgeResponse">
+            <xs:element name="getCartridges">
+                <xs:complexType>
+                    <xs:sequence/>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getCartridgesResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <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="getClusterContext">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidCartridgeTypeException" nillable="true" type="ax25:InvalidCartridgeTypeException"/>
+                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeCartridge">
+            <xs:element name="getClusterContextResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ClusterContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeCartridgeResponse">
+            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax21:ApplicationClusterRegistrationException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidServiceGroupException">
+            <xs:element name="createApplicationClusters">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax25:InvalidServiceGroupException"/>
+                        <xs:element minOccurs="0" name="appUuid" 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="addServiceGroup">
+            <xs:element name="createApplicationClustersResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax24:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addServiceGroupResponse">
+            <xs:element name="CloudControllerServiceClusterInstanceCreationException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="ClusterInstanceCreationException" nillable="true" type="ax21:ClusterInstanceCreationException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeServiceGroup">
+            <xs:element name="createClusterInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="serviceUuid" 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="networkPartitionUuid" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="removeServiceGroupResponse">
+            <xs:element name="createClusterInstanceResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroup">
+            <xs:element name="getKubernetesClusters">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="getKubernetesClustersResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:ServiceGroup"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupSubGroups">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesClusterException" nillable="true" type="ax21:NonExistingKubernetesClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupSubGroupsResponse">
+            <xs:element name="getKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="kubernetesClusterUuid" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupCartridges">
+            <xs:element name="getKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupCartridgesResponse">
+            <xs:element name="getKubernetesClusterByTenant">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupDependencies">
+            <xs:element name="getKubernetesClusterByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupDependenciesResponse">
+            <xs:element name="getMasterForKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:Dependencies"/>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidPartitionException">
+            <xs:element name="getMasterForKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidPartitionException" nillable="true" type="ax25:InvalidPartitionException"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax213:KubernetesMaster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validateDeploymentPolicyNetworkPartition">
+            <xs:element name="getHostsForKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeUuid" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="networkPartitionUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validateDeploymentPolicyNetworkPartitionResponse">
+            <xs:element name="getHostsForKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax213:KubernetesHost"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validatePartition">
+            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="partition" nillable="true" type="ax24:Partition"/>
+                        <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax21:InvalidKubernetesClusterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="validatePartitionResponse">
+            <xs:element name="CloudControllerServiceKubernetesClusterAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="KubernetesClusterAlreadyExistsException" nillable="true" type="ax21:KubernetesClusterAlreadyExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="registerService">
+            <xs:element name="addKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="registrant" nillable="true" type="ax24:Registrant"/>
+                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="registerServiceResponse">
+            <xs:element name="addKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstances">
+            <xs:element name="updateKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="instanceContexts" nillable="true" type="ax24:InstanceContext"/>
+                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax213:KubernetesCluster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="startInstancesResponse">
+            <xs:element name="updateKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:MemberContext"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidMemberException">
+            <xs:element name="CloudControllerServiceInvalidKubernetesHostException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidMemberException" nillable="true" type="ax25:InvalidMemberException"/>
+                        <xs:element minOccurs="0" name="InvalidKubernetesHostException" nillable="true" type="ax21:InvalidKubernetesHostException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstance">
+            <xs:element name="addKubernetesHost">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="groupUuid" 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="terminateInstanceResponse">
+            <xs:element name="addKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstanceForcefully">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesHostException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="memberId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesHostException" nillable="true" type="ax21:NonExistingKubernetesHostException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstanceForcefullyResponse">
+            <xs:element name="updateKubernetesHost">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax213:KubernetesHost"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidClusterException">
+            <xs:element name="updateKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidClusterException" nillable="true" type="ax25:InvalidClusterException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstances">
+            <xs:element name="removeKubernetesCluster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="groupUuid" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="terminateInstancesResponse">
+            <xs:element name="removeKubernetesClusterResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateClusterStatus">
+            <xs:element name="removeKubernetesHost">
                 <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:element minOccurs="0" name="kubernetesHostId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateClusterStatusResponse">
+            <xs:element name="removeKubernetesHostResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceUnregisteredClusterException">
+            <xs:element name="CloudControllerServiceInvalidKubernetesMasterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="UnregisteredClusterException" nillable="true" type="ax25:UnregisteredClusterException"/>
+                        <xs:element minOccurs="0" name="InvalidKubernetesMasterException" nillable="true" type="ax21:InvalidKubernetesMasterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="unregisterService">
+            <xs:element name="CloudControllerServiceNonExistingKubernetesMasterException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="NonExistingKubernetesMasterException" nillable="true" type="ax21:NonExistingKubernetesMasterException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="unregisterServiceResponse">
+            <xs:element name="updateKubernetesMaster">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax213:KubernetesMaster"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridge">
+            <xs:element name="updateKubernetesMasterResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgeResponse">
+            <xs:element name="CloudControllerServiceNetworkPartitionAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:Cartridge"/>
+                        <xs:element minOccurs="0" name="NetworkPartitionAlreadyExistsException" nillable="true" type="ax21:NetworkPartitionAlreadyExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgeByTenant">
+            <xs:element name="CloudControllerServiceInvalidNetworkPartitionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                        <xs:element minOccurs="0" name="InvalidNetworkPartitionException" nillable="true" type="ax21:InvalidNetworkPartitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridgeByTenantResponse">
+            <xs:element name="addNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:Cartridge"/>
+                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getCartridges">
-                <xs:complexType>
-                    <xs:sequence/>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getCartridgesResponse">
+            <xs:element name="addNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getClusterContext">
+            <xs:element name="CloudControllerServiceNetworkPartitionNotExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="NetworkPartitionNotExistsException" nillable="true" type="ax21:NetworkPartitionNotExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getClusterContextResponse">
+            <xs:element name="removeNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:ClusterContext"/>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceApplicationClusterRegistrationException">
+            <xs:element name="removeNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="ApplicationClusterRegistrationException" nillable="true" type="ax25:ApplicationClusterRegistrationException"/>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="createApplicationClusters">
+            <xs:element name="updateNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="appUuid" nillable="true" type="xs:string"/>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="appClustersContexts" nillable="true" type="ax24:ApplicationClusterContext"/>
+                        <xs:element minOccurs="0" name="networkPartition" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="createApplicationClustersResponse">
+            <xs:element name="updateNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceClusterInstanceCreationException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="ClusterInstanceCreationException" nillable="true" type="ax25:ClusterInstanceCreationException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="createClusterInstance">
+            <xs:element name="getNetworkPartitions">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="serviceUuid" 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="networkPartitionUuid" nillable="true" type="xs:string"/>
-                    </xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="createClusterInstanceResponse">
+            <xs:element name="getNetworkPartitionsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusters">
+            <xs:element name="getNetworkPartitionsByTenant">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClustersResponse">
+            <xs:element name="getNetworkPartitionsByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesCluster">
+            <xs:element name="getNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterUuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="networkPartitionUuid" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusterResponse">
+            <xs:element name="getNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusterByTenant">
+            <xs:element name="getCartridgesByTenant">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                         <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getKubernetesClusterByTenantResponse">
+            <xs:element name="getCartridgesByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:Cartridge"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getMasterForKubernetesCluster">
+            <xs:element name="getNetworkPartitionByTenant">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getMasterForKubernetesClusterResponse">
+            <xs:element name="getNetworkPartitionByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:KubernetesMaster"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:NetworkPartition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getHostsForKubernetesCluster">
+            <xs:element name="startInstance">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="instanceContext" nillable="true" type="ax26:InstanceContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getHostsForKubernetesClusterResponse">
+            <xs:element name="startInstanceResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:KubernetesHost"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:MemberContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesClusterException">
+            <xs:element name="getNetworkPartitionUuid">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesClusterException" nillable="true" type="ax25:InvalidKubernetesClusterException"/>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceKubernetesClusterAlreadyExistsException">
+            <xs:element name="getNetworkPartitionUuidResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="KubernetesClusterAlreadyExistsException" nillable="true" type="ax25:KubernetesClusterAlreadyExistsException"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesCluster">
+            <xs:element name="getPartitionsByNetworkPartition">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax29:KubernetesCluster"/>
+                        <xs:element minOccurs="0" name="networkPartitionId" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesClusterResponse">
+            <xs:element name="getPartitionsByNetworkPartitionResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:Partition"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesCluster">
+            <xs:element name="getIaasProviders">
                 <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesCluster" nillable="true" type="ax29:KubernetesCluster"/>
-                    </xs:sequence>
+                    <xs:sequence/>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesClusterResponse">
+            <xs:element name="getIaasProvidersResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="CloudControllerServiceInvalidKubernetesHostException">
+            <xs:element name="CloudControllerServiceCartridgeAlreadyExistsException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidKubernetesHostException" nillable="true" type="ax25:InvalidKubernetesHostException"/>
+                        <xs:element minOccurs="0" name="CartridgeAlreadyExistsException" nillable="true" type="ax21:CartridgeAlreadyExistsException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesHost">
+            <xs:element name="addCartridge">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="groupUuid" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax29:KubernetesHost"/>
+                        <xs:element minOccurs="0" name="cartridgeConfig" nillable="true" type="ax26:Cartridge"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="addKubernetesHostResponse">
+            <xs:element name="addCartridgeResponse">
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="return" type="xs:boolean"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesHost">
+            <xs:element name="getCartridge">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="kubernetesHost" nillable="true" type="ax29:KubernetesHost"/>
+                        <xs:element minOccurs="0" name="cartridgeUuid" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="updateKubernetesHostResponse">
+            <xs:element name="getCartridgeResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:Cartridge"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -871,7 +871,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="ax22:Property"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax24:Property"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Property">
@@ -882,49 +882,41 @@
             </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://exception.controller.cloud.stratos.apache.org/xsd">
-            <xs:complexType name="NonExistingKubernetesClusterException">
+            <xs:complexType name="InvalidCartridgeDefinitionException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NonExistingKubernetesHostException">
+            <xs:complexType name="InvalidIaasProviderException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidKubernetesMasterException">
+            <xs:complexType name="CartridgeDefinitionNotExistsException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NonExistingKubernetesMasterException">
+            <xs:complexType name="InvalidCartridgeTypeException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NetworkPartitionAlreadyExistsException">
+            <xs:complexType name="InvalidServiceGroupException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidNetworkPartitionException">
+            <xs:complexType name="InvalidPartitionException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="NetworkPartitionNotExistsException">
-                <xs:sequence/>
-            </xs:complexType>
             <xs:complexType name="CartridgeNotFoundException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidIaasProviderException">
-                <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">
@@ -932,120 +924,113 @@
                     </xs:extension>
                 </xs:complexContent>
             </xs:complexType>
-            <xs:complexType name="InvalidCartridgeDefinitionException">
+            <xs:complexType name="InvalidMemberException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="CartridgeAlreadyExistsException">
-                <xs:sequence/>
-            </xs:complexType>
-            <xs:complexType name="CartridgeDefinitionNotExistsException">
+            <xs:complexType name="InvalidClusterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidCartridgeTypeException">
+            <xs:complexType name="UnregisteredClusterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </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:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidPartitionException">
+            <xs:complexType name="ClusterInstanceCreationException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidMemberException">
+            <xs:complexType name="NonExistingKubernetesClusterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidClusterException">
+            <xs:complexType name="InvalidKubernetesClusterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="UnregisteredClusterException">
+            <xs:complexType name="KubernetesClusterAlreadyExistsException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="ApplicationClusterRegistrationException">
+            <xs:complexType name="InvalidKubernetesHostException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="ClusterInstanceCreationException">
+            <xs:complexType name="NonExistingKubernetesHostException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidKubernetesClusterException">
+            <xs:complexType name="InvalidKubernetesMasterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="KubernetesClusterAlreadyExistsException">
+            <xs:complexType name="NonExistingKubernetesMasterException">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="InvalidKubernetesHostException">
+            <xs:complexType name="NetworkPartitionAlreadyExistsException">
                 <xs:sequence>
                     <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="InvalidNetworkPartitionException">
                 <xs:sequence>
-                    <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="value" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
-            <xs:complexType name="LoadBalancingIPType">
-                <xs:complexContent>
-                    <xs:extension base="xs:Enum">
-                        <xs:sequence/>
-                    </xs:extension>
-                </xs:complexContent>
+            <xs:complexType name="NetworkPartitionNotExistsException">
+                <xs:sequence/>
+            </xs:complexType>
+            <xs:complexType name="CartridgeAlreadyExistsException">
+                <xs:sequence/>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax28="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://kubernetes.domain.controller.cloud.stratos.apache.org/xsd">
+        <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="KubernetesCluster">
+                <xs:sequence>
+                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
+                    <xs:element minOccurs="0" name="clusterUuid" 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:element minOccurs="0" name="tenantId" type="xs:int"/>
+                </xs:sequence>
+            </xs:complexType>
             <xs:complexType name="KubernetesHost">
                 <xs:sequence>
                     <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="ax28:Properties"/>
+                    <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="ax27:KubernetesHost">
+                    <xs:extension base="ax211:KubernetesHost">
                         <xs:sequence/>
                     </xs:extension>
                 </xs:complexContent>
             </xs:complexType>
-            <xs:complexType name="KubernetesCluster">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="clusterUuid" 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="ax27:KubernetesHost"/>
-                    <xs:element minOccurs="0" name="kubernetesMaster" nillable="true" type="ax27:KubernetesMaster"/>
-                    <xs:element minOccurs="0" name="portRange" nillable="true" type="ax27:PortRange"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax28:Properties"/>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                </xs:sequence>
-            </xs:complexType>
             <xs:complexType name="PortRange">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="lower" type="xs:int"/>
@@ -1053,37 +1038,27 @@
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax211="http://domain.common.stratos.apache.org/xsd" xmlns:ax23="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="Partition">
+        <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="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="partitionMax" type="xs:int"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
-                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                    <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
+                    <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="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="partitionAlgo" nillable="true" type="xs:string"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="partitions" nillable="true" type="ax21:Partition"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
-                    <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                    <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
-                </xs:sequence>
+            <xs:complexType name="LoadBalancingIPType">
+                <xs:complexContent>
+                    <xs:extension base="xs:Enum">
+                        <xs:sequence/>
+                    </xs:extension>
+                </xs:complexContent>
             </xs:complexType>
+        </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="Cartridge">
                 <xs:sequence>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="appTypeMappings" nillable="true" type="ax21:AppType"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="appTypeMappings" nillable="true" type="ax23:AppType"/>
                     <xs:element minOccurs="0" name="baseDir" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="category" nillable="true" type="xs:string"/>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="deploymentDirs" nillable="true" type="xs:string"/>
@@ -1091,14 +1066,14 @@
                     <xs:element minOccurs="0" name="displayName" nillable="true" type="xs:string"/>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="exportingProperties" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="hostName" nillable="true" type="xs:string"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="iaasConfigs" nillable="true" type="ax21:IaasConfig"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="iaasConfigs" nillable="true" type="ax23:IaasConfig"/>
                     <xs:element minOccurs="0" name="isPublic" type="xs:boolean"/>
                     <xs:element minOccurs="0" name="loadBalancingIPType" nillable="true" type="xs:string"/>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="metadataKeys" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="multiTenant" type="xs:boolean"/>
-                    <xs:element minOccurs="0" name="persistence" nillable="true" type="ax21:Persistence"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="portMappings" nillable="true" type="ax21:PortMapping"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
+                    <xs:element minOccurs="0" name="persistence" nillable="true" type="ax23:Persistence"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="portMappings" nillable="true" type="ax23:PortMapping"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25:Properties"/>
                     <xs:element minOccurs="0" name="provider" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     <xs:element minOccurs="0" name="tenantPartitions" nillable="true" type="xs:string"/>
@@ -1120,29 +1095,29 @@
                     <xs:element minOccurs="0" name="identity" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="imageId" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="networkInterfaces" nillable="true" type="ax21:NetworkInterfaces"/>
+                    <xs:element minOccurs="0" name="networkInterfaces" nillable="true" type="ax23:NetworkInterfaces"/>
                     <xs:element minOccurs="0" name="payload" nillable="true" type="xs:base64Binary"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25:Properties"/>


<TRUNCATED>

[2/6] stratos git commit: Merge branch 'tenant-isolation' of https://github.com/apache/stratos into tenant-isolation-v1

Posted by ga...@apache.org.
Merge branch 'tenant-isolation' of https://github.com/apache/stratos into tenant-isolation-v1


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

Branch: refs/heads/tenant-isolation
Commit: b228f115576337dd48d027f68ae34b7e178bd0f4
Parents: e873b94 7575faa
Author: Dinithi <di...@wso2.com>
Authored: Thu Aug 20 12:34:51 2015 +0530
Committer: Dinithi <di...@wso2.com>
Committed: Thu Aug 20 12:34:51 2015 +0530

----------------------------------------------------------------------
 .../client/AutoscalerCloudControllerClient.java |   16 +-
 .../autoscaler/rule/RuleTasksDelegator.java     |   48 +-
 .../publisher/HealthStatisticsNotifier.java     |   10 +-
 .../messaging/topology/TopologyBuilder.java     | 1434 +++++++++---------
 .../impl/CloudControllerServiceImpl.java        |    6 +-
 .../impl/CloudControllerServiceUtil.java        |   15 +-
 .../services/impl/InstanceCreator.java          |   17 +-
 .../publisher/BAMUsageDataPublisher.java        |   44 +-
 .../util/CloudControllerConstants.java          |    4 +
 .../common/constants/StratosConstants.java      |    8 +-
 .../publisher/HealthStatisticsPublisher.java    |    3 +-
 .../publisher/InFlightRequestPublisher.java     |    4 +-
 .../publisher/StatisticsPublisherType.java      |    2 +-
 .../publisher/ThriftClientConfig.java           |   81 +
 .../publisher/ThriftClientConfigParser.java     |  139 ++
 .../statistics/publisher/ThriftClientInfo.java  |   63 +
 .../publisher/ThriftStatisticsPublisher.java    |  115 ++
 .../publisher/wso2/cep/ThriftClientConfig.java  |   81 -
 .../wso2/cep/ThriftClientConfigParser.java      |  139 --
 .../publisher/wso2/cep/ThriftClientInfo.java    |   63 -
 .../cep/WSO2CEPHealthStatisticsPublisher.java   |   29 +-
 .../cep/WSO2CEPInFlightRequestPublisher.java    |   28 +-
 .../wso2/cep/WSO2CEPStatisticsPublisher.java    |  114 --
 .../test/ThriftClientConfigParserTest.java      |   13 +-
 .../LoadBalancerStatisticsNotifier.java         |    3 +-
 .../publisher/MockHealthStatisticsNotifier.java |    3 +
 .../modules/healthstatspublisher/healthstats.py |    7 +-
 .../HealthStatsEventFormatter.xml               |   30 +
 .../eventformatters/RIFEventFormatter.xml       |   31 +
 .../DASDefaultWSO2EventOutputAdaptor.xml        |   29 +
 .../streamdefinitions/stream-manager-config.xml |  486 +++---
 extensions/das/README.md                        |   10 +
 .../CloudControllerEventReceiver.xml            |   29 +
 .../eventreceivers/HealthStatsEventReceiver.xml |   29 +
 .../eventreceivers/RIFEventReceiver.xml         |   29 +
 .../eventsink/cartridge_agent_health_stats.xml  |   85 ++
 .../artifacts/eventsink/in_flight_requests.xml  |   64 +
 .../org_apache_stratos_cloud_controller.xml     |  211 +++
 .../cartridge_agent_health_stats_1.0.0.json     |   40 +
 .../eventstreams/in_flight_requests_1.0.0.json  |   28 +
 ...g.apache.stratos.cloud.controller_1.0.0.json |  112 ++
 extensions/das/artifacts/sparkscript/CCEvent    |   18 +
 extensions/das/pom.xml                          |   40 +
 extensions/das/spark-udf/pom.xml                |   36 +
 .../das/extension/spark/udf/TimeUDF.java        |   49 +
 extensions/pom.xml                              |    4 +-
 .../src/main/conf/drools/dependent-scaling.drl  |    4 +-
 .../src/main/conf/drools/mincheck.drl           |    5 +-
 .../src/main/conf/drools/scaling.drl            |    7 +-
 49 files changed, 2441 insertions(+), 1424 deletions(-)
----------------------------------------------------------------------



[6/6] stratos git commit: Merge branch 'tenant-isolation-v1' of https://github.com/dinithis/stratos into tenant-isolation

Posted by ga...@apache.org.
Merge branch 'tenant-isolation-v1' of https://github.com/dinithis/stratos into tenant-isolation


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

Branch: refs/heads/tenant-isolation
Commit: a776ca196482f6d5042bb820dedc97f795e769e4
Parents: 2f2debf eb0d28f
Author: gayangunarathne <ga...@wso2.com>
Authored: Fri Aug 21 10:28:35 2015 +0530
Committer: gayangunarathne <ga...@wso2.com>
Committed: Fri Aug 21 10:28:35 2015 +0530

----------------------------------------------------------------------
 .../autoscaler/pojo/policy/PolicyManager.java   |  105 +-
 .../services/impl/AutoscalerServiceImpl.java    |  269 +++--
 .../impl/CloudControllerServiceImpl.java        |  219 ++--
 .../rest/endpoint/api/StratosApiV41.java        |   18 +-
 .../rest/endpoint/api/StratosApiV41Utils.java   |   10 +-
 .../src/main/resources/AutoscalerService.wsdl   |  396 +++----
 .../main/resources/CloudControllerService.wsdl  | 1044 +++++++++---------
 7 files changed, 1084 insertions(+), 977 deletions(-)
----------------------------------------------------------------------



[4/6] stratos git commit: Updating logs to display uuid and tenantId

Posted by ga...@apache.org.
http://git-wip-us.apache.org/repos/asf/stratos/blob/eb0d28f4/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 1be6af2..224ca3c 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,4 +1,4 @@
-<?xml version="1.0" encoding="UTF-8"?><wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax27="http://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:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax216="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax22="http://common.stratos.apache.org/xsd" xmlns:ax227="http://partition.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax220="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax212="http://partition.common.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax223="http://rmi.java/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xml
 ns:ax211="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax224="http://io.java/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">
+<?xml version="1.0" encoding="UTF-8"?><wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ax29="http://exception.autoscaler.stratos.apache.org/xsd" xmlns:ax27="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns="http://impl.services.autoscaler.stratos.apache.org" xmlns:ax23="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax24="http://common.stratos.apache.org/xsd" xmlns:ax21="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:ax216="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax227="http://partition.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax220="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ax212="http://partition.common.stratos.apache.org/xsd" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:ax223="http://rmi.java/xsd" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xml
 ns:ax211="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax224="http://io.java/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 xmlns:ax225="http://io.java/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://rmi.java/xsd">
             <xs:import namespace="http://io.java/xsd"/>
@@ -34,18 +34,18 @@
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax23="http://common.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://pojo.applications.autoscaler.stratos.apache.org/xsd">
+        <xs:schema xmlns:ax25="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 minOccurs="0" name="applicationId" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="applicationUuid" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="components" nillable="true" type="ax21:ComponentContext"/>
+                    <xs:element minOccurs="0" name="components" nillable="true" type="ax23: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="properties" nillable="true" type="ax25: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"/>
@@ -54,10 +54,10 @@
             </xs:complexType>
             <xs:complexType name="ComponentContext">
                 <xs:sequence>
-                    <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:element maxOccurs="unbounded" minOccurs="0" name="applicationClusterContexts" nillable="true" type="ax23:ApplicationClusterContext"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax23:CartridgeContext"/>
+                    <xs:element minOccurs="0" name="dependencyContext" nillable="true" type="ax23:DependencyContext"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax23:GroupContext"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ApplicationClusterContext">
@@ -69,8 +69,8 @@
                     <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="persistenceContext" nillable="true" type="ax21:PersistenceContext"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
+                    <xs:element minOccurs="0" name="persistenceContext" nillable="true" type="ax23:PersistenceContext"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25: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>
@@ -78,7 +78,7 @@
             <xs:complexType name="PersistenceContext">
                 <xs:sequence>
                     <xs:element minOccurs="0" name="persistenceRequired" type="xs:boolean"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax21:VolumeContext"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="volumes" nillable="true" type="ax23:VolumeContext"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="VolumeContext">
@@ -97,7 +97,7 @@
                 <xs:sequence>
                     <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="subscribableInfoContext" nillable="true" type="ax23:SubscribableInfoContext"/>
                     <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     <xs:element minOccurs="0" name="type" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
@@ -106,7 +106,7 @@
             <xs:complexType name="SubscribableInfoContext">
                 <xs:sequence>
                     <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="artifactRepositoryContext" nillable="true" type="ax23:ArtifactRepositoryContext"/>
                     <xs:element minOccurs="0" name="autoscalingPolicy" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="autoscalingPolicyUuid" nillable="true" type="xs:string"/>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="dependencyAliases" nillable="true" type="xs:string"/>
@@ -114,8 +114,8 @@
                     <xs:element minOccurs="0" name="deploymentPolicyUuid" 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="persistenceContext" nillable="true" type="ax21:PersistenceContext"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax23:Properties"/>
+                    <xs:element minOccurs="0" name="persistenceContext" nillable="true" type="ax23:PersistenceContext"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax25:Properties"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="ArtifactRepositoryContext">
@@ -137,10 +137,10 @@
             <xs:complexType name="GroupContext">
                 <xs:sequence>
                     <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 maxOccurs="unbounded" minOccurs="0" name="cartridgeContexts" nillable="true" type="ax23:CartridgeContext"/>
                     <xs:element minOccurs="0" name="deploymentPolicy" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="deploymentPolicyUuid" nillable="true" type="xs:string"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax21:GroupContext"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groupContexts" nillable="true" type="ax23:GroupContext"/>
                     <xs:element minOccurs="0" name="groupMaxInstances" type="xs:int"/>
                     <xs:element minOccurs="0" name="groupMinInstances" type="xs:int"/>
                     <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
@@ -153,8 +153,8 @@
             <xs:complexType name="ServiceGroup">
                 <xs:sequence>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="cartridges" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax29:Dependencies"/>
-                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax29:ServiceGroup"/>
+                    <xs:element minOccurs="0" name="dependencies" nillable="true" type="ax21:Dependencies"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="groups" nillable="true" type="ax21:ServiceGroup"/>
                     <xs:element minOccurs="0" name="name" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
@@ -168,17 +168,31 @@
                 </xs:sequence>
             </xs:complexType>
         </xs:schema>
-        <xs:schema xmlns:ax28="http://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://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax218="http://common.stratos.apache.org/xsd" xmlns:ax221="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax226="http://rmi.java/xsd" xmlns:ax228="http://partition.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://pojo.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
+        <xs:schema xmlns:ax28="http://application.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax26="http://pojo.applications.autoscaler.stratos.apache.org/xsd" xmlns:ax217="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax22="http://pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax218="http://common.stratos.apache.org/xsd" xmlns:ax221="http://policy.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax226="http://rmi.java/xsd" xmlns:ax228="http://partition.exception.autoscaler.stratos.apache.org/xsd" xmlns:ax215="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd" xmlns:ax210="http://exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.services.autoscaler.stratos.apache.org">
+            <xs:import namespace="http://pojo.autoscaler.stratos.apache.org/xsd"/>
             <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://exception.autoscaler.stratos.apache.org/xsd"/>
-            <xs:import namespace="http://pojo.autoscaler.stratos.apache.org/xsd"/>
             <xs:import namespace="http://deployment.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
             <xs:import namespace="http://autoscale.policy.pojo.autoscaler.stratos.apache.org/xsd"/>
             <xs:import namespace="http://common.stratos.apache.org/xsd"/>
             <xs:import namespace="http://policy.exception.autoscaler.stratos.apache.org/xsd"/>
             <xs:import namespace="http://rmi.java/xsd"/>
             <xs:import namespace="http://partition.exception.autoscaler.stratos.apache.org/xsd"/>
+            <xs:element name="getServiceGroup">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="uuid" 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="ax21:ServiceGroup"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
             <xs:element name="getApplications">
                 <xs:complexType>
                     <xs:sequence/>
@@ -187,35 +201,35 @@
             <xs:element name="getApplicationsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26: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:element minOccurs="0" name="ApplicationDefinitionException" nillable="true" type="ax27:ApplicationDefinitionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="AutoscalerServiceCartridgeGroupNotFoundException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeGroupNotFoundException" nillable="true" type="ax27:CartridgeGroupNotFoundException"/>
+                        <xs:element minOccurs="0" name="CartridgeGroupNotFoundException" nillable="true" type="ax29:CartridgeGroupNotFoundException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="AutoscalerServiceCartridgeNotFoundException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax27:CartridgeNotFoundException"/>
+                        <xs:element minOccurs="0" name="CartridgeNotFoundException" nillable="true" type="ax29:CartridgeNotFoundException"/>
                     </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:element minOccurs="0" name="applicationContext" nillable="true" type="ax26:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -226,17 +240,17 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroup">
+            <xs:element name="getDeploymentPolicy">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="deploymentPolicyId" nillable="true" type="xs:string"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="getServiceGroupResponse">
+            <xs:element name="getDeploymentPolicyResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -250,21 +264,7 @@
             <xs:element name="getApplicationResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicyId" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPolicyResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -285,7 +285,7 @@
             <xs:element name="AutoscalerServiceInvalidArgumentException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax27:InvalidArgumentException"/>
+                        <xs:element minOccurs="0" name="InvalidArgumentException" nillable="true" type="ax29:InvalidArgumentException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -293,7 +293,7 @@
                 <xs:complexType>
                     <xs:sequence>
                         <xs:element minOccurs="0" name="clusterId" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax22:Properties"/>
+                        <xs:element minOccurs="0" name="properties" nillable="true" type="ax24:Properties"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -318,75 +318,6 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
-            <xs:element name="AutoscalerServiceDeploymentPolicyNotExistsException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax220:DeploymentPolicyNotExistsException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="AutoscalerServiceUnremovablePolicyException">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="UnremovablePolicyException" nillable="true" type="ax220:UnremovablePolicyException"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeDeployementPolicy">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="removeDeployementPolicyResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPolicyForTenant">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPolicyForTenantResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPolicies">
-                <xs:complexType>
-                    <xs:sequence/>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPoliciesResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPoliciesByTenant">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDeploymentPoliciesByTenantResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
             <xs:element name="getAutoScalingPolicies">
                 <xs:complexType>
                     <xs:sequence/>
@@ -416,7 +347,7 @@
             <xs:element name="AutoscalerServiceAutoScalingPolicyAlreadyExistException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="AutoScalingPolicyAlreadyExistException" nillable="true" type="ax27:AutoScalingPolicyAlreadyExistException"/>
+                        <xs:element minOccurs="0" name="AutoScalingPolicyAlreadyExistException" nillable="true" type="ax29:AutoScalingPolicyAlreadyExistException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -455,6 +386,13 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+            <xs:element name="AutoscalerServiceUnremovablePolicyException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="UnremovablePolicyException" nillable="true" type="ax220:UnremovablePolicyException"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
             <xs:element name="AutoscalerServicePolicyDoesNotExistException">
                 <xs:complexType>
                     <xs:sequence>
@@ -494,7 +432,7 @@
             <xs:element name="updateApplication">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax24:ApplicationContext"/>
+                        <xs:element minOccurs="0" name="applicationContext" nillable="true" type="ax26:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -516,7 +454,7 @@
             <xs:element name="getApplicationByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax26:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -545,7 +483,7 @@
             <xs:element name="getApplicationsByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax24:ApplicationContext"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax26:ApplicationContext"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -596,14 +534,14 @@
             <xs:element name="AutoscalerServiceInvalidServiceGroupException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax25:InvalidServiceGroupException"/>
+                        <xs:element minOccurs="0" name="InvalidServiceGroupException" nillable="true" type="ax27:InvalidServiceGroupException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
             <xs:element name="addServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax29:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="servicegroup" nillable="true" type="ax21:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -617,7 +555,7 @@
             <xs:element name="updateServiceGroup">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeGroup" nillable="true" type="ax29:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="cartridgeGroup" nillable="true" type="ax21:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -653,7 +591,7 @@
             <xs:element name="getServiceGroupByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="return" nillable="true" type="ax29:ServiceGroup"/>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax21:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -690,7 +628,7 @@
             <xs:element name="AutoscalerServiceAutoScalerException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax27:AutoScalerException"/>
+                        <xs:element minOccurs="0" name="AutoScalerException" nillable="true" type="ax29:AutoScalerException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -702,7 +640,7 @@
             <xs:element name="getServiceGroupsResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:ServiceGroup"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax21:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -716,7 +654,7 @@
             <xs:element name="getServiceGroupsByTenantResponse">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax29:ServiceGroup"/>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax21:ServiceGroup"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -772,7 +710,7 @@
             <xs:element name="AutoscalerServiceInvalidApplicationPolicyException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="InvalidApplicationPolicyException" nillable="true" type="ax25:InvalidApplicationPolicyException"/>
+                        <xs:element minOccurs="0" name="InvalidApplicationPolicyException" nillable="true" type="ax27:InvalidApplicationPolicyException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -923,10 +861,17 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+            <xs:element name="AutoscalerServiceDeploymentPolicyNotExistsException">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="DeploymentPolicyNotExistsException" nillable="true" type="ax220:DeploymentPolicyNotExistsException"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
             <xs:element name="AutoscalerServiceCloudControllerConnectionException">
                 <xs:complexType>
                     <xs:sequence>
-                        <xs:element minOccurs="0" name="CloudControllerConnectionException" nillable="true" type="ax27:CloudControllerConnectionException"/>
+                        <xs:element minOccurs="0" name="CloudControllerConnectionException" nillable="true" type="ax29:CloudControllerConnectionException"/>
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
@@ -944,6 +889,61 @@
                     </xs:sequence>
                 </xs:complexType>
             </xs:element>
+            <xs:element name="removeDeployementPolicy">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="deploymentPolicyId" nillable="true" type="xs:string"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="removeDeployementPolicyResponse">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="return" type="xs:boolean"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getDeploymentPolicyForTenant">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="deploymentPolicyID" nillable="true" type="xs:string"/>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getDeploymentPolicyForTenantResponse">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getDeploymentPolicies">
+                <xs:complexType>
+                    <xs:sequence/>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getDeploymentPoliciesResponse">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getDeploymentPoliciesByTenant">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
+            <xs:element name="getDeploymentPoliciesByTenantResponse">
+                <xs:complexType>
+                    <xs:sequence>
+                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="ax215:DeploymentPolicy"/>
+                    </xs:sequence>
+                </xs:complexType>
+            </xs:element>
             <xs:element name="getApplicationPolicy">
                 <xs:complexType>
                     <xs:sequence>
@@ -978,7 +978,7 @@
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionGroups" nillable="true" type="xs:string"/>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitions" nillable="true" type="xs:string"/>
                     <xs:element maxOccurs="unbounded" minOccurs="0" name="networkPartitionsUuid" nillable="true" type="xs:string"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax22:Properties"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax24:Properties"/>
                     <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
                 </xs:sequence>
@@ -1000,7 +1000,7 @@
                     <xs:element minOccurs="0" name="id" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="kubernetesClusterId" nillable="true" type="xs:string"/>
                     <xs:element minOccurs="0" name="partitionMax" type="xs:int"/>
-                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax22:Properties"/>
+                    <xs:element minOccurs="0" name="properties" nillable="true" type="ax24:Properties"/>
                     <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
                     <xs:element minOccurs="0" name="uuid" nillable="true" type="xs:string"/>
                 </xs:sequence>
@@ -1026,7 +1026,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="ax22:Property"/>
+                    <xs:element maxOccurs="unbounded" minOccurs="0" name="properties" nillable="true" type="ax24:Property"/>
                 </xs:sequence>
             </xs:complexType>
             <xs:complexType name="Property">
@@ -1045,24 +1045,21 @@
         </xs:schema>
         <xs:schema xmlns:ax222="http://exception.autoscaler.stratos.apache.org/xsd" attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://policy.exception.autoscaler.stratos.apache.org/xsd">
             <xs:import namespace="http://exception.autoscaler.stratos.apache.org/xsd"/>
-            <xs:complexType name="DeploymentPolicyNotExistsException">
-                <xs:sequence/>
+            <xs:complexType name="InvalidPolicyException">
+                <xs:sequence>
+                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
+                </xs:sequence>
             </xs:complexType>
             <xs:complexType name="UnremovablePolicyException">
                 <xs:complexContent>
-                    <xs:extension base="ax27:AutoScalerException">
+                    <xs:extension base="ax29:AutoScalerException">
                         <xs:sequence/>
                     </xs:extension>
                 </xs:complexContent>
             </xs:complexType>
-            <xs:complexType name="InvalidPolicyException">
-                <xs:sequence>
-                    <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
-                </xs:sequence>
-            </xs:complexType>
             <xs:complexType name="PolicyDoesNotExistException">
                 <xs:complexContent>
-                    <xs:extension base="ax27:AutoScalerException">
+                    <xs:extension base="ax29:AutoScalerException">
                         <xs:sequence/>
                     </xs:extension>
                 </xs:complexContent>
@@ -1083,6 +1080,9 @@
             <xs:complexType name="DeploymentPolicyAlreadyExistsException">
                 <xs:sequence/>
             </xs:complexType>
+            <xs:complexType name="DeploymentPolicyNotExistsException">
+                <xs:sequence/>
+            </xs:complexType>
         </xs:schema>
         <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://io.java/xsd">
             <xs:complexType name="IOException">
@@ -1105,6 +1105,9 @@
                     <xs:element minOccurs="0" name="message" nillable="true" type="xs:string"/>
                 </xs:sequence>
             </xs:complexType>
+            <xs:complexType name="AutoScalingPolicyAlreadyExistException">
+                <xs:sequence/>
+            </xs:complexType>
             <xs:complexType name="AutoScalerException">
                 <xs:complexContent>
                     <xs:extension base="xs:RuntimeException">
@@ -1112,9 +1115,6 @@
                     </xs:extension>
                 </xs:complexContent>
             </xs:complexType>
-            <xs:complexType name="AutoScalingPolicyAlreadyExistException">
-                <xs:sequence/>
-            </xs:complexType>
             <xs:complexType name="CloudControllerConnectionException">
                 <xs:sequence/>
             </xs:complexType>
@@ -1132,6 +1132,12 @@
     <wsdl:message name="getAutoScalingPoliciesResponse">
         <wsdl:part name="parameters" element="ns:getAutoScalingPoliciesResponse"/>
     </wsdl:message>
+    <wsdl:message name="getDeploymentPoliciesRequest">
+        <wsdl:part name="parameters" element="ns:getDeploymentPolicies"/>
+    </wsdl:message>
+    <wsdl:message name="getDeploymentPoliciesResponse">
+        <wsdl:part name="parameters" element="ns:getDeploymentPoliciesResponse"/>
+    </wsdl:message>
     <wsdl:message name="addApplicationPolicyRequest">
         <wsdl:part name="parameters" element="ns:addApplicationPolicy"/>
     </wsdl:message>
@@ -1147,12 +1153,6 @@
     <wsdl:message name="AutoscalerServiceApplicationPolicyAlreadyExistsException">
         <wsdl:part name="parameters" element="ns:AutoscalerServiceApplicationPolicyAlreadyExistsException"/>
     </wsdl:message>
-    <wsdl:message name="getDeploymentPoliciesRequest">
-        <wsdl:part name="parameters" element="ns:getDeploymentPolicies"/>
-    </wsdl:message>
-    <wsdl:message name="getDeploymentPoliciesResponse">
-        <wsdl:part name="parameters" element="ns:getDeploymentPoliciesResponse"/>
-    </wsdl:message>
     <wsdl:message name="removeAutoScalingPolicyRequest">
         <wsdl:part name="parameters" element="ns:removeAutoScalingPolicy"/>
     </wsdl:message>
@@ -1318,18 +1318,18 @@
     <wsdl:message name="getApplicationPolicyByTenantResponse">
         <wsdl:part name="parameters" element="ns:getApplicationPolicyByTenantResponse"/>
     </wsdl:message>
-    <wsdl:message name="getAutoscalingPolicyForTenantRequest">
-        <wsdl:part name="parameters" element="ns:getAutoscalingPolicyForTenant"/>
-    </wsdl:message>
-    <wsdl:message name="getAutoscalingPolicyForTenantResponse">
-        <wsdl:part name="parameters" element="ns:getAutoscalingPolicyForTenantResponse"/>
-    </wsdl:message>
     <wsdl:message name="getDeploymentPolicyForTenantRequest">
         <wsdl:part name="parameters" element="ns:getDeploymentPolicyForTenant"/>
     </wsdl:message>
     <wsdl:message name="getDeploymentPolicyForTenantResponse">
         <wsdl:part name="parameters" element="ns:getDeploymentPolicyForTenantResponse"/>
     </wsdl:message>
+    <wsdl:message name="getAutoscalingPolicyForTenantRequest">
+        <wsdl:part name="parameters" element="ns:getAutoscalingPolicyForTenant"/>
+    </wsdl:message>
+    <wsdl:message name="getAutoscalingPolicyForTenantResponse">
+        <wsdl:part name="parameters" element="ns:getAutoscalingPolicyForTenantResponse"/>
+    </wsdl:message>
     <wsdl:message name="getDeploymentPolicyByTenantRequest">
         <wsdl:part name="parameters" element="ns:getDeploymentPolicyByTenant"/>
     </wsdl:message>
@@ -1462,6 +1462,10 @@
             <wsdl:input message="ns:getAutoScalingPoliciesRequest" wsaw:Action="urn:getAutoScalingPolicies"/>
             <wsdl:output message="ns:getAutoScalingPoliciesResponse" wsaw:Action="urn:getAutoScalingPoliciesResponse"/>
         </wsdl:operation>
+        <wsdl:operation name="getDeploymentPolicies">
+            <wsdl:input message="ns:getDeploymentPoliciesRequest" wsaw:Action="urn:getDeploymentPolicies"/>
+            <wsdl:output message="ns:getDeploymentPoliciesResponse" wsaw:Action="urn:getDeploymentPoliciesResponse"/>
+        </wsdl:operation>
         <wsdl:operation name="addApplicationPolicy">
             <wsdl:input message="ns:addApplicationPolicyRequest" wsaw:Action="urn:addApplicationPolicy"/>
             <wsdl:output message="ns:addApplicationPolicyResponse" wsaw:Action="urn:addApplicationPolicyResponse"/>
@@ -1469,10 +1473,6 @@
             <wsdl:fault message="ns:AutoscalerServiceInvalidApplicationPolicyException" name="AutoscalerServiceInvalidApplicationPolicyException" wsaw:Action="urn:addApplicationPolicyAutoscalerServiceInvalidApplicationPolicyException"/>
             <wsdl:fault message="ns:AutoscalerServiceApplicationPolicyAlreadyExistsException" name="AutoscalerServiceApplicationPolicyAlreadyExistsException" wsaw:Action="urn:addApplicationPolicyAutoscalerServiceApplicationPolicyAlreadyExistsException"/>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicies">
-            <wsdl:input message="ns:getDeploymentPoliciesRequest" wsaw:Action="urn:getDeploymentPolicies"/>
-            <wsdl:output message="ns:getDeploymentPoliciesResponse" wsaw:Action="urn:getDeploymentPoliciesResponse"/>
-        </wsdl:operation>
         <wsdl:operation name="removeAutoScalingPolicy">
             <wsdl:input message="ns:removeAutoScalingPolicyRequest" wsaw:Action="urn:removeAutoScalingPolicy"/>
             <wsdl:output message="ns:removeAutoScalingPolicyResponse" wsaw:Action="urn:removeAutoScalingPolicyResponse"/>
@@ -1580,14 +1580,14 @@
             <wsdl:input message="ns:getApplicationPolicyByTenantRequest" wsaw:Action="urn:getApplicationPolicyByTenant"/>
             <wsdl:output message="ns:getApplicationPolicyByTenantResponse" wsaw:Action="urn:getApplicationPolicyByTenantResponse"/>
         </wsdl:operation>
-        <wsdl:operation name="getAutoscalingPolicyForTenant">
-            <wsdl:input message="ns:getAutoscalingPolicyForTenantRequest" wsaw:Action="urn:getAutoscalingPolicyForTenant"/>
-            <wsdl:output message="ns:getAutoscalingPolicyForTenantResponse" wsaw:Action="urn:getAutoscalingPolicyForTenantResponse"/>
-        </wsdl:operation>
         <wsdl:operation name="getDeploymentPolicyForTenant">
             <wsdl:input message="ns:getDeploymentPolicyForTenantRequest" wsaw:Action="urn:getDeploymentPolicyForTenant"/>
             <wsdl:output message="ns:getDeploymentPolicyForTenantResponse" wsaw:Action="urn:getDeploymentPolicyForTenantResponse"/>
         </wsdl:operation>
+        <wsdl:operation name="getAutoscalingPolicyForTenant">
+            <wsdl:input message="ns:getAutoscalingPolicyForTenantRequest" wsaw:Action="urn:getAutoscalingPolicyForTenant"/>
+            <wsdl:output message="ns:getAutoscalingPolicyForTenantResponse" wsaw:Action="urn:getAutoscalingPolicyForTenantResponse"/>
+        </wsdl:operation>
         <wsdl:operation name="getDeploymentPolicyByTenant">
             <wsdl:input message="ns:getDeploymentPolicyByTenantRequest" wsaw:Action="urn:getDeploymentPolicyByTenant"/>
             <wsdl:output message="ns:getDeploymentPolicyByTenantResponse" wsaw:Action="urn:getDeploymentPolicyByTenantResponse"/>
@@ -1696,15 +1696,6 @@
                 <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicies">
-            <soap:operation soapAction="urn:getDeploymentPolicies" style="document"/>
-            <wsdl:input>
-                <soap:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
         <wsdl:operation name="addApplicationPolicy">
             <soap:operation soapAction="urn:addApplicationPolicy" style="document"/>
             <wsdl:input>
@@ -1723,6 +1714,15 @@
                 <soap:fault use="literal" name="AutoscalerServiceInvalidApplicationPolicyException"/>
             </wsdl:fault>
         </wsdl:operation>
+        <wsdl:operation name="getDeploymentPolicies">
+            <soap:operation soapAction="urn:getDeploymentPolicies" style="document"/>
+            <wsdl:input>
+                <soap:body use="literal"/>
+            </wsdl:input>
+            <wsdl:output>
+                <soap:body use="literal"/>
+            </wsdl:output>
+        </wsdl:operation>
         <wsdl:operation name="removeAutoScalingPolicy">
             <soap:operation soapAction="urn:removeAutoScalingPolicy" style="document"/>
             <wsdl:input>
@@ -1975,8 +1975,8 @@
                 <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicyForTenant">
-            <soap:operation soapAction="urn:getDeploymentPolicyForTenant" style="document"/>
+        <wsdl:operation name="getAutoscalingPolicyForTenant">
+            <soap:operation soapAction="urn:getAutoscalingPolicyForTenant" style="document"/>
             <wsdl:input>
                 <soap:body use="literal"/>
             </wsdl:input>
@@ -1984,8 +1984,8 @@
                 <soap:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getAutoscalingPolicyForTenant">
-            <soap:operation soapAction="urn:getAutoscalingPolicyForTenant" style="document"/>
+        <wsdl:operation name="getDeploymentPolicyForTenant">
+            <soap:operation soapAction="urn:getDeploymentPolicyForTenant" style="document"/>
             <wsdl:input>
                 <soap:body use="literal"/>
             </wsdl:input>
@@ -2224,15 +2224,6 @@
                 <soap12:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicies">
-            <soap12:operation soapAction="urn:getDeploymentPolicies" style="document"/>
-            <wsdl:input>
-                <soap12:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap12:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
         <wsdl:operation name="addApplicationPolicy">
             <soap12:operation soapAction="urn:addApplicationPolicy" style="document"/>
             <wsdl:input>
@@ -2251,6 +2242,15 @@
                 <soap12:fault use="literal" name="AutoscalerServiceInvalidApplicationPolicyException"/>
             </wsdl:fault>
         </wsdl:operation>
+        <wsdl:operation name="getDeploymentPolicies">
+            <soap12:operation soapAction="urn:getDeploymentPolicies" style="document"/>
+            <wsdl:input>
+                <soap12:body use="literal"/>
+            </wsdl:input>
+            <wsdl:output>
+                <soap12:body use="literal"/>
+            </wsdl:output>
+        </wsdl:operation>
         <wsdl:operation name="removeAutoScalingPolicy">
             <soap12:operation soapAction="urn:removeAutoScalingPolicy" style="document"/>
             <wsdl:input>
@@ -2503,8 +2503,8 @@
                 <soap12:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicyForTenant">
-            <soap12:operation soapAction="urn:getDeploymentPolicyForTenant" style="document"/>
+        <wsdl:operation name="getAutoscalingPolicyForTenant">
+            <soap12:operation soapAction="urn:getAutoscalingPolicyForTenant" style="document"/>
             <wsdl:input>
                 <soap12:body use="literal"/>
             </wsdl:input>
@@ -2512,8 +2512,8 @@
                 <soap12:body use="literal"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getAutoscalingPolicyForTenant">
-            <soap12:operation soapAction="urn:getAutoscalingPolicyForTenant" style="document"/>
+        <wsdl:operation name="getDeploymentPolicyForTenant">
+            <soap12:operation soapAction="urn:getDeploymentPolicyForTenant" style="document"/>
             <wsdl:input>
                 <soap12:body use="literal"/>
             </wsdl:input>
@@ -2752,8 +2752,8 @@
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicies">
-            <http:operation location="getDeploymentPolicies"/>
+        <wsdl:operation name="addApplicationPolicy">
+            <http:operation location="addApplicationPolicy"/>
             <wsdl:input>
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:input>
@@ -2761,8 +2761,8 @@
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="addApplicationPolicy">
-            <http:operation location="addApplicationPolicy"/>
+        <wsdl:operation name="getDeploymentPolicies">
+            <http:operation location="getDeploymentPolicies"/>
             <wsdl:input>
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:input>
@@ -2977,8 +2977,8 @@
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getDeploymentPolicyForTenant">
-            <http:operation location="getDeploymentPolicyForTenant"/>
+        <wsdl:operation name="getAutoscalingPolicyForTenant">
+            <http:operation location="getAutoscalingPolicyForTenant"/>
             <wsdl:input>
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:input>
@@ -2986,8 +2986,8 @@
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:output>
         </wsdl:operation>
-        <wsdl:operation name="getAutoscalingPolicyForTenant">
-            <http:operation location="getAutoscalingPolicyForTenant"/>
+        <wsdl:operation name="getDeploymentPolicyForTenant">
+            <http:operation location="getDeploymentPolicyForTenant"/>
             <wsdl:input>
                 <mime:content type="text/xml" part="parameters"/>
             </wsdl:input>