You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by im...@apache.org on 2014/12/14 06:45:10 UTC

[6/7] stratos git commit: Moving rest api domain model to stratos common component to be reused by the cli

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/autoscale/RequestsInFlight.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/autoscale/RequestsInFlight.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/autoscale/RequestsInFlight.java
deleted file mode 100644
index 4d7bb2c..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/autoscale/RequestsInFlight.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.cli.beans.autoscaler.policy.autoscale;
-
-public class RequestsInFlight {
-
-    public float average;
-
-    public float secondDerivative;
-
-    public float gradient;
-
-    public float scaleDownMarginOfGradient;
-
-    public float scaleDownMarginOfSecondDerivative;
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/deployment/DeploymentPolicy.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/deployment/DeploymentPolicy.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/deployment/DeploymentPolicy.java
deleted file mode 100644
index abcc3f3..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/autoscaler/policy/deployment/DeploymentPolicy.java
+++ /dev/null
@@ -1,78 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.autoscaler.policy.deployment;
-
-import org.apache.stratos.cli.beans.autoscaler.partition.NetworkPartition;
-import org.apache.stratos.cli.beans.autoscaler.partition.Partition;
-
-import java.util.List;
-
-public class DeploymentPolicy {
-    private String id;
-    
-    private String description;
-    
-    private boolean isPublic;
-
-     //partition groups
-     private List<NetworkPartition> networkPartition;
-
-    //partitions
-    private List<Partition> partition;  
-
-    public String getId() {
-        return id;
-    }
-
-    public void setId(String id) {
-        this.id = id;
-    }
-
-    public List<NetworkPartition> getNetworkPartition() {
-        return networkPartition;
-    }
-
-    public void setNetworkPartition(List<NetworkPartition> networkPartition) {
-        this.networkPartition = networkPartition;
-    }
-
-    public List<Partition> getPartition() {
-        return partition;
-    }
-
-    public void setPartition(List<Partition> partition) {
-        this.partition = partition;
-    }
-    
-    public boolean getIsPublic() {
-        return isPublic;
-    }
-
-    public void setIsPublic(boolean isPublic) {
-        this.isPublic = isPublic;
-    }
-    
-    public String getDescription() {
-        return description;
-    }
-
-    public void setDescription(String description) {
-        this.description = description;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/Cartridge.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/Cartridge.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/Cartridge.java
deleted file mode 100644
index 671ddb1..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/Cartridge.java
+++ /dev/null
@@ -1,274 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one 
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY 
- * KIND, either express or implied.  See the License for the 
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.cli.beans.cartridge;
-
-import javax.xml.bind.annotation.XmlRootElement;
-import java.util.Arrays;
-
-
-@XmlRootElement
-public class Cartridge implements Comparable<Cartridge> {
-
-    private String displayName;
-    private String description;
-    private boolean isPublic;
-    private String cartridgeAlias;
-    private String cartridgeType;
-    private int activeInstances;
-    private String status;
-    private String ip;
-    private String password;
-    private String provider;
-    private String version;
-    private boolean multiTenant;
-    private String hostName;
-    private String policy;
-    private String policyDescription;
-    private String repoURL;
-    private String dbUserName;
-    private String mappedDomain;
-    private String dbHost;
-    private String publicIp;
-    private String lbClusterId;
-    private boolean loadBalancer;
-
-    private String[] accessURLs;
-    private PortMapping[] portMappings;
-    private String serviceGroup;
-
-    public String getDisplayName() {
-        return displayName;
-    }
-
-    public void setDisplayName(String displayName) {
-        this.displayName = displayName;
-    }
-
-    public String getDescription() {
-        return description;
-    }
-
-    public void setDescription(String description) {
-        this.description = description;
-    }
-
-    public String getCartridgeAlias() {
-        return cartridgeAlias;
-    }
-
-    public void setCartridgeAlias(String cartridgeAlias) {
-        this.cartridgeAlias = cartridgeAlias;
-    }
-
-    public String getCartridgeType() {
-        return cartridgeType;
-    }
-
-    public void setCartridgeType(String cartridgeType) {
-        this.cartridgeType = cartridgeType;
-    }
-
-    public int getActiveInstances() {
-        return activeInstances;
-    }
-
-    public void setActiveInstances(int activeInstances) {
-        this.activeInstances = activeInstances;
-    }
-
-    public String getStatus() {
-        return status;
-    }
-
-    public void setStatus(String status) {
-        this.status = status;
-    }
-
-    public String getIp() {
-        return ip;
-    }
-
-    public void setIp(String ip) {
-        this.ip = ip;
-    }
-
-    public String getPassword() {
-        return password;
-    }
-
-    public void setPassword(String password) {
-        this.password = password;
-    }
-
-    public String getProvider() {
-        return provider;
-    }
-
-    public void setProvider(String provider) {
-        this.provider = provider;
-    }
-
-    public String getVersion() {
-        return version;
-    }
-
-    public void setVersion(String version) {
-        this.version = version;
-    }
-
-    public boolean isMultiTenant() {
-        return multiTenant;
-    }
-
-    public void setMultiTenant(boolean multiTenant) {
-        this.multiTenant = multiTenant;
-    }
-
-    public String getHostName() {
-        return hostName;
-    }
-
-    public void setHostName(String hostName) {
-        this.hostName = hostName;
-    }
-
-    public String getPolicy() {
-        return policy;
-    }
-
-    public void setPolicy(String policy) {
-        this.policy = policy;
-    }
-
-    public String getPolicyDescription() {
-        return policyDescription;
-    }
-
-    public void setPolicyDescription(String policyDescription) {
-        this.policyDescription = policyDescription;
-    }
-
-    public String getRepoURL() {
-        return repoURL;
-    }
-
-    public void setRepoURL(String repoURL) {
-        this.repoURL = repoURL;
-    }
-
-    public String getDbUserName() {
-        return dbUserName;
-    }
-
-    public String[] getAccessURLs() {
-        return accessURLs;
-    }
-
-    public void setAccessURLs(String[] accessURLs) {
-        if(accessURLs == null) {
-            this.accessURLs = new String[0];
-        } else {
-            this.accessURLs = Arrays.copyOf(accessURLs, accessURLs.length);
-        }
-    }
-
-    public void setDbUserName(String dbUserName) {
-        this.dbUserName = dbUserName;
-    }
-
-    public String getMappedDomain() {
-        return mappedDomain;
-    }
-
-    public void setMappedDomain(String mappedDomain) {
-        this.mappedDomain = mappedDomain;
-    }
-    
-    public PortMapping[] getPortMappings() {
-		return portMappings;
-	}
-
-	public void setPortMappings(PortMapping[] portMappings) {
-        if(portMappings == null) {
-            this.portMappings = new PortMapping[0];
-        } else {
-            this.portMappings = Arrays.copyOf(portMappings, portMappings.length);
-        }
-	}
-	
-	public String getDbHost() {
-		return dbHost;
-	}
-
-	public void setDbHost(String dbHost) {
-		this.dbHost = dbHost;
-	}
-	
-	public String getPublicIp() {
-		return publicIp;
-	}
-
-	public void setPublicIp(String publicIp) {
-		this.publicIp = publicIp;
-	}
-
-	public int compareTo(Cartridge o) {
-        int compare = 0;
-        if (cartridgeAlias != null && o.cartridgeAlias != null) {
-            compare = cartridgeAlias.compareTo(o.cartridgeAlias);
-        }
-        if (compare == 0 && cartridgeType != null && o.cartridgeType != null) {
-            compare = cartridgeType.compareTo(o.cartridgeType);
-        }
-        return compare;
-    }
-
-    public String getLbClusterId() {
-        return lbClusterId;
-    }
-
-    public void setLbClusterId(String lbClusterId) {
-        this.lbClusterId = lbClusterId;
-    }
-
-    public boolean isLoadBalancer() {
-        return loadBalancer;
-    }
-
-    public void setLoadBalancer(boolean isLoadBalancer) {
-        this.loadBalancer = isLoadBalancer;
-    }
-
-    public boolean getIsPublic() {
-        return isPublic;
-    }
-
-    public void setIsPublic(boolean isPublic) {
-        this.isPublic = isPublic;
-    }
-    
-    public String getServiceGroup() {
-        return serviceGroup;
-    }
-
-    public void setServiceGroup(String serviceGroup) {
-        this.serviceGroup = serviceGroup;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/CartridgeInfoBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/CartridgeInfoBean.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/CartridgeInfoBean.java
deleted file mode 100644
index 9e23120..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/CartridgeInfoBean.java
+++ /dev/null
@@ -1,151 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.cartridge;
-
-import javax.xml.bind.annotation.XmlRootElement;
-
-@XmlRootElement
-public class CartridgeInfoBean {
-    String cartridgeType;
-    String alias;
-    String policy;
-    String repoURL;
-    String repoUsername;
-    String repoPassword;
-    private String autoscalePolicy;
-    private String deploymentPolicy;
-    private String size;
-    private String volumeId;
-    boolean privateRepo;
-    private boolean removeOnTermination;
-    private boolean persistanceRequired;
-    private boolean commitsEnabled;
-
-    public String getCartridgeType() {
-        return cartridgeType;
-    }
-
-    public void setCartridgeType(String cartridgeType) {
-        this.cartridgeType = cartridgeType;
-    }
-
-    public String getAlias() {
-        return alias;
-    }
-
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-
-    public String getPolicy() {
-        return policy;
-    }
-
-    public void setPolicy(String policy) {
-        this.policy = policy;
-    }
-
-    public String getRepoURL() {
-        return repoURL;
-    }
-
-    public void setRepoURL(String repoURL) {
-        this.repoURL = repoURL;
-    }
-
-    public boolean isPrivateRepo() {
-        return privateRepo;
-    }
-
-    public void setPrivateRepo(boolean privateRepo) {
-        this.privateRepo = privateRepo;
-    }
-
-    public String getRepoUsername() {
-        return repoUsername;
-    }
-
-    public void setRepoUsername(String repoUsername) {
-        this.repoUsername = repoUsername;
-    }
-
-    public String getRepoPassword() {
-        return repoPassword;
-    }
-
-    public void setRepoPassword(String repoPassword) {
-        this.repoPassword = repoPassword;
-    }
-
-    public String getAutoscalePolicy() {
-        return autoscalePolicy;
-    }
-
-    public void setAutoscalePolicy(String autoscalePolicy) {
-        this.autoscalePolicy = autoscalePolicy;
-    }
-
-    public String getDeploymentPolicy() {
-        return deploymentPolicy;
-    }
-
-    public void setDeploymentPolicy(String deploymentPolicy) {
-        this.deploymentPolicy = deploymentPolicy;
-    }
-
-    public String getSize() {
-        return size;
-    }
-
-    public void setSize(String size) {
-        this.size = size;
-    }
-
-    public boolean isRemoveOnTermination() {
-        return removeOnTermination;
-    }
-
-    public void setRemoveOnTermination(boolean removeOnTermination) {
-        this.removeOnTermination = removeOnTermination;
-    }
-
-    public boolean isPersistanceRequired() {
-        return persistanceRequired;
-    }
-
-    public void setPersistanceRequired(boolean persistanceRequired) {
-        this.persistanceRequired = persistanceRequired;
-    }
-
-	public boolean isCommitsEnabled() {
-		return commitsEnabled;
-	}
-
-	public void setCommitsEnabled(boolean commitsEnabled) {
-		this.commitsEnabled = commitsEnabled;
-	}
-
-    public String getVolumeId() {
-        return volumeId;
-    }
-
-    public void setVolumeId(String volumeId) {
-        this.volumeId = volumeId;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/PortMapping.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/PortMapping.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/PortMapping.java
deleted file mode 100644
index 136f22f..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/PortMapping.java
+++ /dev/null
@@ -1,68 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one 
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY 
- * KIND, either express or implied.  See the License for the 
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.stratos.cli.beans.cartridge;
-
-import javax.xml.bind.annotation.XmlRootElement;
-
-@XmlRootElement
-public class PortMapping {
-
-	private String protocol;
-	private String port;
-	private String proxyPort;
-	
-	public PortMapping(){
-		
-	}
-	
-	public PortMapping(String protocol, String port, String proxyPort){
-		this.protocol = protocol;
-		this.port = port;
-		this.proxyPort = proxyPort;
-	}
-
-	public String getProtocol() {
-    	return protocol;
-    }
-
-	public void setProtocol(String protocol) {
-    	this.protocol = protocol;
-    }
-
-	public String getPort() {
-    	return port;
-    }
-
-	public void setPort(String port) {
-    	this.port = port;
-    }
-
-	public String getProxyPort() {
-    	return proxyPort;
-    }
-
-	public void setProxyPort(String proxyPort) {
-    	this.proxyPort = proxyPort;
-    }
-
-    public String toString () {
-
-        return "Protocol: " + protocol + ", Port: " + port + ", Proxy Port: " + proxyPort;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/ServiceDefinitionBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/ServiceDefinitionBean.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/ServiceDefinitionBean.java
deleted file mode 100644
index 656f411..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/cartridge/ServiceDefinitionBean.java
+++ /dev/null
@@ -1,95 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.cli.beans.cartridge;
-
-public class ServiceDefinitionBean {
-    private String serviceName;
-    private boolean isPublic;
-    private String cartridgeType;
-    private String deploymentPolicyName;
-    private String autoscalingPolicyName;
-    private String clusterDomain;
-    private String clusterSubDomain;
-    private String tenantRange;
-
-    public String getServiceName() {
-        return serviceName;
-    }
-
-    public void setServiceName(String serviceName) {
-        this.serviceName = serviceName;
-    }
-
-    public String getCartridgeType() {
-        return cartridgeType;
-    }
-
-    public void setCartridgeType(String cartridgeType) {
-        this.cartridgeType = cartridgeType;
-    }
-
-    public String getDeploymentPolicyName() {
-        return deploymentPolicyName;
-    }
-
-    public void setDeploymentPolicyName(String deploymentPolicyName) {
-        this.deploymentPolicyName = deploymentPolicyName;
-    }
-
-    public String getAutoscalingPolicyName() {
-        return autoscalingPolicyName;
-    }
-
-    public void setAutoscalingPolicyName(String autoscalingPolicyName) {
-        this.autoscalingPolicyName = autoscalingPolicyName;
-    }
-
-    public String getClusterDomain() {
-        return clusterDomain;
-    }
-
-    public void setClusterDomain(String clusterDomain) {
-        this.clusterDomain = clusterDomain;
-    }
-
-    public String getClusterSubDomain() {
-        return clusterSubDomain;
-    }
-
-    public void setClusterSubDomain(String clusterSubDomain) {
-        this.clusterSubDomain = clusterSubDomain;
-    }
-
-    public String getTenantRange() {
-        return tenantRange;
-    }
-
-    public void setTenantRange(String tenantRange) {
-        this.tenantRange = tenantRange;
-    }
-    
-    public boolean getIsPublic() {
-        return isPublic;
-    }
-
-    public void setIsPublic(boolean isPublic) {
-        this.isPublic = isPublic;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Application.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Application.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Application.java
deleted file mode 100644
index e014eac..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Application.java
+++ /dev/null
@@ -1,70 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.grouping.applications;
-
-import java.util.ArrayList;
-import java.util.List;
-
-public class Application
-{
-    private String id;
-    private String tenantDomain;
-    private String tenantAdminUsername;
-    public List<Group> groups = null;
-    public List<Cluster> clusters = null;
-    private List<Instance> instances;
-
-    public Application(){
-        this.groups = new ArrayList<Group>();
-        this.clusters = new ArrayList<Cluster>();
-    }
-    public void addGroup(Group groupBean) {
-        this.groups.add(groupBean);
-    }
-
-    public void setId(String id) {
-        this.id = id;
-    }
-
-    public void setTenantDomain(String tenantDomain) {
-        this.tenantDomain = tenantDomain;
-    }
-
-    public void setTenantAdminUsername(String tenantAdminUsername) {
-        this.tenantAdminUsername = tenantAdminUsername;
-    }
-
-    public String getId() {
-        return id;
-    }
-
-    public String getTenantDomain() {
-        return tenantDomain;
-    }
-
-    public String getTenantAdminUsername() {
-        return tenantAdminUsername;
-    }
-    public List<Instance> getInstances() {
-        return instances;
-    }
-    public void setInstances(List<Instance> instances) {
-        this.instances = instances;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Cluster.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Cluster.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Cluster.java
deleted file mode 100644
index eea8f08..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Cluster.java
+++ /dev/null
@@ -1,56 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.grouping.applications;
-
-import java.util.List;
-
-public class Cluster {
-    public String alias;
-
-    public String serviceName;
-
-    public String clusterId;
-
-    public List<Member> member;
-
-    public String tenantRange;
-
-    public List<String> hostNames;
-
-    public boolean isLbCluster;
-
-    public List<Property> property;
-
-    private List<Instance> instances;
-
-    public List<Instance> getInstances() {
-        return instances;
-    }
-
-    public void setInstances(List<Instance> instances) {
-        this.instances = instances;
-    }
-
-    @Override
-    public String toString() {
-        return "Cluster [serviceName=" + serviceName + ", clusterId=" + clusterId + ", member=" + member
-                + ", tenantRange=" + tenantRange + ", hostNames=" + hostNames + ", isLbCluster=" + isLbCluster
-                + ", property=" + property + "]";
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Group.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Group.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Group.java
deleted file mode 100644
index bfc4615..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Group.java
+++ /dev/null
@@ -1,92 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.grouping.applications;
-
-import java.util.ArrayList;
-import java.util.List;
-
-public class Group
-{
-    private List<Group> subGroups = null;
-    private List<Cluster> clusters = null;
-    private String alias;
-    private String deploymentPolicy;
-    private String autoScalingPolicy;
-    private List<Instance> instances;
-
-    public Group(){
-        this.setClusters(new ArrayList<Cluster>());
-        this.setSubGroups(new ArrayList<Group>());
-    }
-
-    public void addGroup(Group groupBean){
-        getSubGroups().add(groupBean);
-    }
-    public void addCluster(Cluster cluster){
-        getClusters().add(cluster);
-    }
-
-    public List<Group> getSubGroups() {
-        return subGroups;
-    }
-
-    public void setSubGroups(List<Group> subGroups) {
-        this.subGroups = subGroups;
-    }
-
-    public List<Cluster> getClusters() {
-        return clusters;
-    }
-
-    public void setClusters(List<Cluster> clusters) {
-        this.clusters = clusters;
-    }
-
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-
-    public void setDeploymentPolicy(String deploymentPolicy) {
-        this.deploymentPolicy = deploymentPolicy;
-    }
-
-    public void setAutoScalingPolicy(String autoScalingPolicy) {
-        this.autoScalingPolicy = autoScalingPolicy;
-    }
-
-    public String getAlias() {
-        return alias;
-    }
-
-    public String getDeploymentPolicy() {
-        return deploymentPolicy;
-    }
-
-    public String getAutoScalingPolicy() {
-        return autoScalingPolicy;
-    }
-
-    public List<Instance> getInstances() {
-        return instances;
-    }
-
-    public void setInstances(List<Instance> instances) {
-        this.instances = instances;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Instance.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Instance.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Instance.java
deleted file mode 100644
index decea07..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Instance.java
+++ /dev/null
@@ -1,26 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.cli.beans.grouping.applications;
-
-public class Instance {
-    public String status;
-
-    public String instanceId;
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Member.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Member.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Member.java
deleted file mode 100644
index 0cbb087..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Member.java
+++ /dev/null
@@ -1,130 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.grouping.applications;
-
-public class Member
-{
-    private String networkPartitionId;
-
-    private String memberPublicIp;
-
-    private String status;
-
-    private Property[] property;
-
-    private String memberId;
-
-    private String partitionId;
-
-    private String clusterId;
-
-    private String memberIp;
-
-    private String serviceName;
-
-    public String getNetworkPartitionId ()
-    {
-        return networkPartitionId;
-    }
-
-    public void setNetworkPartitionId (String networkPartitionId)
-    {
-        this.networkPartitionId = networkPartitionId;
-    }
-
-    public String getMemberPublicIp ()
-    {
-        return memberPublicIp;
-    }
-
-    public void setMemberPublicIp (String memberPublicIp)
-    {
-        this.memberPublicIp = memberPublicIp;
-    }
-
-    public String getStatus ()
-    {
-        return status;
-    }
-
-    public void setStatus (String status)
-    {
-        this.status = status;
-    }
-
-    public Property[] getProperty ()
-    {
-        return property;
-    }
-
-    public void setProperty (Property[] property)
-    {
-        this.property = property;
-    }
-
-    public String getMemberId ()
-    {
-        return memberId;
-    }
-
-    public void setMemberId (String memberId)
-    {
-        this.memberId = memberId;
-    }
-
-    public String getPartitionId ()
-    {
-        return partitionId;
-    }
-
-    public void setPartitionId (String partitionId)
-    {
-        this.partitionId = partitionId;
-    }
-
-    public String getClusterId ()
-    {
-        return clusterId;
-    }
-
-    public void setClusterId (String clusterId)
-    {
-        this.clusterId = clusterId;
-    }
-
-    public String getMemberIp ()
-    {
-        return memberIp;
-    }
-
-    public void setMemberIp (String memberIp)
-    {
-        this.memberIp = memberIp;
-    }
-
-    public String getServiceName ()
-    {
-        return serviceName;
-    }
-
-    public void setServiceName (String serviceName)
-    {
-        this.serviceName = serviceName;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Property.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Property.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Property.java
deleted file mode 100644
index cd7dda3..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/Property.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.grouping.applications;
-
-public class Property
-{
-    private String name;
-
-    private String value;
-
-    public String getName ()
-    {
-        return name;
-    }
-
-    public void setName (String name)
-    {
-        this.name = name;
-    }
-
-    public String getValue ()
-    {
-        return value;
-    }
-
-    public void setValue (String value)
-    {
-        this.value = value;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/SubGroup.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/SubGroup.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/SubGroup.java
deleted file mode 100644
index d3567eb..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/applications/SubGroup.java
+++ /dev/null
@@ -1,70 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.beans.grouping.applications;
-
-public class SubGroup
-{
-    private String deploymentPolicy;
-
-    private Cluster cluster;
-
-    private String alias;
-
-    private String autoScalingPolicy;
-
-    public String getDeploymentPolicy ()
-    {
-        return deploymentPolicy;
-    }
-
-    public void setDeploymentPolicy (String deploymentPolicy)
-    {
-        this.deploymentPolicy = deploymentPolicy;
-    }
-
-    public Cluster getCluster()
-    {
-        return cluster;
-    }
-
-    public void setCluster(Cluster cluster)
-    {
-        this.cluster = cluster;
-    }
-
-    public String getAlias ()
-    {
-        return alias;
-    }
-
-    public void setAlias (String alias)
-    {
-        this.alias = alias;
-    }
-
-    public String getAutoScalingPolicy ()
-    {
-        return autoScalingPolicy;
-    }
-
-    public void setAutoScalingPolicy (String autoScalingPolicy)
-    {
-        this.autoScalingPolicy = autoScalingPolicy;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/Dependencies.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/Dependencies.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/Dependencies.java
deleted file mode 100644
index 6364e4b..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/Dependencies.java
+++ /dev/null
@@ -1,46 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.stratos.cli.beans.grouping.serviceGroups;
-
-public class Dependencies
-{
-    private String terminationBehaviour;
-
-    private String[] startupOrders;
-
-    public String getTerminationBehaviour ()
-    {
-        return terminationBehaviour;
-    }
-
-    public void setTerminationBehaviour (String terminationBehaviour)
-    {
-        this.terminationBehaviour = terminationBehaviour;
-    }
-
-    public String[] getStartupOrders ()
-    {
-        return startupOrders;
-    }
-
-    public void setStartupOrders (String[] startupOrders)
-    {
-        this.startupOrders = startupOrders;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupBean.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupBean.java
deleted file mode 100644
index b7dcafb..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupBean.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.stratos.cli.beans.grouping.serviceGroups;
-
-public class ServiceGroupBean {
-    private ServiceGroupDefinition serviceGroup;
-
-    public ServiceGroupDefinition getServiceGroupDefinition ()
-    {
-        return serviceGroup;
-    }
-
-    public void setServiceGroupDefinition (ServiceGroupDefinition serviceGroupDefinition)
-    {
-        this.serviceGroup = serviceGroupDefinition;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupDefinition.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupDefinition.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupDefinition.java
deleted file mode 100644
index 71eb544..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/grouping/serviceGroups/ServiceGroupDefinition.java
+++ /dev/null
@@ -1,70 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.stratos.cli.beans.grouping.serviceGroups;
-
-public class ServiceGroupDefinition
-{
-    private Dependencies dependencies;
-
-    private String name;
-
-    private String[] subGroups;
-
-    private String[] cartridges;
-
-    public Dependencies getDependencies ()
-    {
-        return dependencies;
-    }
-
-    public void setDependencies (Dependencies dependencies)
-    {
-        this.dependencies = dependencies;
-    }
-
-    public String getName ()
-    {
-        return name;
-    }
-
-    public void setName (String name)
-    {
-        this.name = name;
-    }
-
-    public String[] getSubGroups ()
-    {
-        return subGroups;
-    }
-
-    public void setSubGroups (String[] subGroups)
-    {
-        this.subGroups = subGroups;
-    }
-
-    public String[] getCartridges ()
-    {
-        return cartridges;
-    }
-
-    public void setCartridges (String[] cartridges)
-    {
-        this.cartridges = cartridges;
-    }
-}

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

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesGroupList.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesGroupList.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesGroupList.java
deleted file mode 100644
index 4ca23b5..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesGroupList.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-
-package org.apache.stratos.cli.beans.kubernetes;
-
-import java.util.ArrayList;
-
-/**
- * Kubernetes group list.
- */
-public class KubernetesGroupList {
-    private ArrayList<KubernetesGroup> kubernetesGroup;
-
-    public ArrayList<KubernetesGroup> getKubernetesGroup() {
-        return kubernetesGroup;
-    }
-
-    public void setKubernetesGroup(ArrayList<KubernetesGroup> kubernetesGroup) {
-        this.kubernetesGroup = kubernetesGroup;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHost.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHost.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHost.java
deleted file mode 100644
index 06e7311..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHost.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-
-package org.apache.stratos.cli.beans.kubernetes;
-
-/**
- * Kubernetes host.
- */
-public class KubernetesHost {
-    private String hostId;
-    private String hostname;
-    private String hostIpAddress;
-
-    public String getHostId() {
-        return hostId;
-    }
-
-    public void setHostId(String hostId) {
-        this.hostId = hostId;
-    }
-
-    public String getHostname() {
-        return hostname;
-    }
-
-    public void setHostname(String hostname) {
-        this.hostname = hostname;
-    }
-
-    public String getHostIpAddress() {
-        return hostIpAddress;
-    }
-
-    public void setHostIpAddress(String hostIpAddress) {
-        this.hostIpAddress = hostIpAddress;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHostList.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHostList.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHostList.java
deleted file mode 100644
index 029b21d..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/kubernetes/KubernetesHostList.java
+++ /dev/null
@@ -1,37 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-
-package org.apache.stratos.cli.beans.kubernetes;
-
-import java.util.ArrayList;
-
-/**
- * Kubernetes group list.
- */
-public class KubernetesHostList {
-    private ArrayList<KubernetesHost> kubernetesHost;
-
-    public ArrayList<KubernetesHost> getKubernetesHost() {
-        return kubernetesHost;
-    }
-
-    public void setKubernetesHost(ArrayList<KubernetesHost> kubernetesHost) {
-        this.kubernetesHost = kubernetesHost;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Cluster.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Cluster.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Cluster.java
deleted file mode 100644
index 065841c..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Cluster.java
+++ /dev/null
@@ -1,116 +0,0 @@
-package org.apache.stratos.cli.beans.topology;
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-
-import java.util.List;
-import java.util.Properties;
-
-import org.apache.stratos.cli.beans.autoscaler.partition.PropertyBean;
-
-public class Cluster {
-    private String serviceName;
-
-    private String clusterId;
-
-    private List<Member> member;
-
-    private String tenantRange;
-
-    private List<String> hostNames;
-
-    private boolean isLbCluster;
-    
-    private List<PropertyBean> property;
-
-    public String getServiceName() {
-        return serviceName;
-    }
-
-    public void setServiceName(String serviceName) {
-        this.serviceName = serviceName;
-    }
-
-    public String getClusterId() {
-        return clusterId;
-    }
-
-    public void setClusterId(String clusterId) {
-        this.clusterId = clusterId;
-    }
-
-    public List<Member> getMember() {
-        return member;
-    }
-
-    public void addMember(Member member) {
-       this.member.add(member);
-    }
-
-    public void removeMember(Member member) {
-       this.member.remove(member);
-    }
-
-    public void setMember(List<Member> member) {
-        this.member = member;
-    }
-
-    public String getTenantRange() {
-        return tenantRange;
-    }
-
-    public void setTenantRange(String tenantRange) {
-        this.tenantRange = tenantRange;
-    }
-
-    public List<String> getHostNames() {
-        return hostNames;
-    }
-
-    public void setHostNames(List<String> hostNames) {
-        this.hostNames = hostNames;
-    }
-
-    public void addHostNames(String hostName) {
-        this.hostNames.add(hostName);
-    }
-
-    public void removeHostNames(String hostName) {
-        this.hostNames.remove(hostName);
-    }
-
-    public boolean isLbCluster() {
-        return isLbCluster;
-    }
-
-    public void setLbCluster(boolean lbCluster) {
-        isLbCluster = lbCluster;
-    }
-
-    public List<PropertyBean> getProperty() {
-        return property;
-    }
-
-    public void setProperty(List<PropertyBean> property) {
-        this.property = property;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Member.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Member.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Member.java
deleted file mode 100644
index 897e7b3..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Member.java
+++ /dev/null
@@ -1,123 +0,0 @@
-package org.apache.stratos.cli.beans.topology;
-
-import java.util.List;
-import java.util.Properties;
-
-import org.apache.stratos.cli.beans.autoscaler.partition.PropertyBean;
-
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-
-public class Member {
-    private String serviceName;
-    private String clusterId;
-    private String networkPartitionId;
-    private String partitionId;
-    private String memberId;
-
-    private String status;
-    private String memberIp;
-    private String lbClusterId;
-    private String memberPublicIp;
-    private List<PropertyBean> property;
-
-    public String getServiceName() {
-        return serviceName;
-    }
-
-    public void setServiceName(String serviceName) {
-        this.serviceName = serviceName;
-    }
-
-    public String getClusterId() {
-        return clusterId;
-    }
-
-    public void setClusterId(String clusterId) {
-        this.clusterId = clusterId;
-    }
-
-    public String getNetworkPartitionId() {
-        return networkPartitionId;
-    }
-
-    public void setNetworkPartitionId(String networkPartitionId) {
-        this.networkPartitionId = networkPartitionId;
-    }
-
-    public String getPartitionId() {
-        return partitionId;
-    }
-
-    public void setPartitionId(String partitionId) {
-        this.partitionId = partitionId;
-    }
-
-    public String getMemberId() {
-        return memberId;
-    }
-
-    public void setMemberId(String memberId) {
-        this.memberId = memberId;
-    }
-
-    public String getStatus() {
-        return status;
-    }
-
-    public void setStatus(String status) {
-        this.status = status;
-    }
-
-    public String getMemberIp() {
-        return memberIp;
-    }
-
-    public void setMemberIp(String memberIp) {
-        this.memberIp = memberIp;
-    }
-
-    public String getLbClusterId() {
-        return lbClusterId;
-    }
-
-    public void setLbClusterId(String lbClusterId) {
-        this.lbClusterId = lbClusterId;
-    }
-
-	public String getMemberPublicIp() {
-		return memberPublicIp;
-	}
-
-	public void setMemberPublicIp(String memberPublicIp) {
-		this.memberPublicIp = memberPublicIp;
-	}
-
-    public List<PropertyBean> getProperty() {
-        return property;
-    }
-
-    public void setProperty(List<PropertyBean> property) {
-        this.property = property;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/MemberStatus.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/MemberStatus.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/MemberStatus.java
deleted file mode 100644
index 6535ff9..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/MemberStatus.java
+++ /dev/null
@@ -1,26 +0,0 @@
-package org.apache.stratos.cli.beans.topology;
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-
-public enum MemberStatus {
-     Created, Starting, Activated, Suspended, ReadyToShutDown, ShuttingDown, Terminated
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Port.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Port.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Port.java
deleted file mode 100644
index 398c3cd..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/beans/topology/Port.java
+++ /dev/null
@@ -1,64 +0,0 @@
-package org.apache.stratos.cli.beans.topology;
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
-*/
-
-
-public class Port {
-    private static final long serialVersionUID = -2530288421360188256L;
-    private String protocol;
-    private int value;
-    private int proxy;
-
-    public Port(String protocol, int value, int proxy) {
-        setProtocol(protocol);
-        setValue(value);
-        setProxy(proxy);
-    }
-
-    public String getProtocol() {
-        return protocol;
-    }
-
-    public void setProtocol(String protocol) {
-        this.protocol = protocol;
-    }
-
-    public int getValue() {
-        return value;
-    }
-
-    public void setValue(int value) {
-        this.value = value;
-    }
-
-    public int getProxy() {
-        return proxy;
-    }
-
-    public void setProxy(int proxy) {
-        this.proxy = proxy;
-    }
-
-    @Override
-    public String toString() {
-        return "Port [protocol=" + protocol + ", value=" + value + ", proxy=" + proxy + "]";
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/DescribePartitionCommand.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/DescribePartitionCommand.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/DescribePartitionCommand.java
deleted file mode 100644
index 3709f4d..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/DescribePartitionCommand.java
+++ /dev/null
@@ -1,70 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.commands;
-
-import org.apache.commons.cli.Options;
-import org.apache.stratos.cli.Command;
-import org.apache.stratos.cli.RestCommandLineService;
-import org.apache.stratos.cli.StratosCommandContext;
-import org.apache.stratos.cli.exception.CommandException;
-import org.apache.stratos.cli.utils.CliConstants;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public class DescribePartitionCommand implements Command<StratosCommandContext> {
-    private static final Logger logger = LoggerFactory.getLogger(DescribePartitionCommand.class);
-
-    @Override
-    public String getName() {
-        return CliConstants.DESCRIBE_PARTITION;
-    }
-
-    @Override
-    public String getDescription() {
-        return "Describing the partition";
-    }
-
-    @Override
-    public String getArgumentSyntax() {
-        return "[Id]";
-    }
-
-    @Override
-    public Options getOptions() {
-        return null;
-    }
-
-    @Override
-    public int execute(StratosCommandContext context, String[] args) throws CommandException {
-        if (logger.isDebugEnabled()) {
-			logger.debug("Executing {} command...", getName());
-		}
-		if (args != null && args.length == 1) {
-			String id = args[0];
-			if (logger.isDebugEnabled()) {
-				logger.debug("Getting Partition info {}", id);
-			}
-			 RestCommandLineService.getInstance().describePartition(id);
-			return CliConstants.COMMAND_SUCCESSFULL;
-		} else {
-			context.getStratosApplication().printUsage(getName());
-			return CliConstants.COMMAND_FAILED;
-		}
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/ListCartridgeSubscriptionsCommand.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/ListCartridgeSubscriptionsCommand.java b/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/ListCartridgeSubscriptionsCommand.java
deleted file mode 100644
index 01ff583..0000000
--- a/components/org.apache.stratos.cli/src/main/java/org/apache/stratos/cli/commands/ListCartridgeSubscriptionsCommand.java
+++ /dev/null
@@ -1,120 +0,0 @@
-/**
- *  Licensed to the Apache Software Foundation (ASF) under one
- *  or more contributor license agreements.  See the NOTICE file
- *  distributed with this work for additional information
- *  regarding copyright ownership.  The ASF licenses this file
- *  to you under the Apache License, Version 2.0 (the
- *  "License"); you may not use this file except in compliance
- *  with the License.  You may obtain a copy of the License at
-
- *  http://www.apache.org/licenses/LICENSE-2.0
-
- *  Unless required by applicable law or agreed to in writing,
- *  software distributed under the License is distributed on an
- *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- *  KIND, either express or implied.  See the License for the
- *  specific language governing permissions and limitations
- *  under the License.
- */
-package org.apache.stratos.cli.commands;
-
-import org.apache.commons.cli.CommandLine;
-import org.apache.commons.cli.CommandLineParser;
-import org.apache.commons.cli.GnuParser;
-import org.apache.commons.cli.Option;
-import org.apache.commons.cli.Options;
-import org.apache.commons.cli.ParseException;
-import org.apache.stratos.cli.RestCommandLineService;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.apache.stratos.cli.Command;
-import org.apache.stratos.cli.StratosCommandContext;
-import org.apache.stratos.cli.exception.CommandException;
-import org.apache.stratos.cli.utils.CliConstants;
-
-@Deprecated
-public class ListCartridgeSubscriptionsCommand implements Command<StratosCommandContext> {
-
-	private static final Logger logger = LoggerFactory.getLogger(ListCartridgeSubscriptionsCommand.class);
-	
-	private final Options options;
-
-	public ListCartridgeSubscriptionsCommand() {
-		options = constructOptions();
-	}
-	
-	/**
-	 * Construct Options.
-	 * 
-	 * @return Options expected from command-line.
-	 */
-	private Options constructOptions() {
-		final Options options = new Options();
-		Option fullOption = new Option(CliConstants.FULL_OPTION, CliConstants.FULL_LONG_OPTION, false,
-				"Display extra details");
-		options.addOption(fullOption);
-		return options;
-	}
-
-	public String getName() {
-		return "list-cartridge-subscriptions";
-	}
-
-	public String getDescription() {
-		return "List cartridge subscriptions";
-	}
-
-	public String getArgumentSyntax() {
-		return null;
-	}
-
-	public int execute(StratosCommandContext context, String[] args) throws CommandException {
-		if (logger.isDebugEnabled()) {
-			logger.debug("Executing {} command...", getName());
-		}
-		if (args == null || args.length == 0) {
-            RestCommandLineService.getInstance().listCartridgeSubscriptions(false);
-			//CommandLineService.getInstance().listCartridgeSubscriptions(false);
-			return CliConstants.COMMAND_SUCCESSFULL;
-		} else if (args != null && args.length > 0) {
-			String[] remainingArgs = null;
-			boolean full = false;
-			final CommandLineParser parser = new GnuParser();
-			CommandLine commandLine;
-			try {
-				commandLine = parser.parse(options, args);
-				remainingArgs = commandLine.getArgs();
-				if (!(remainingArgs == null || remainingArgs.length == 0)) {
-					context.getStratosApplication().printUsage(getName());
-					return CliConstants.COMMAND_FAILED;
-				}
-
-				if (commandLine.hasOption(CliConstants.FULL_OPTION)) {
-					if (logger.isTraceEnabled()) {
-						logger.trace("Full option is passed");
-					}
-					full = true;
-				}
-				if (logger.isDebugEnabled()) {
-					logger.debug("Listing subscribed cartridges, Full Option: {}", full);
-				}
-                RestCommandLineService.getInstance().listCartridgeSubscriptions(full);
-				return CliConstants.COMMAND_SUCCESSFULL;
-			} catch (ParseException e) {
-				if (logger.isErrorEnabled()) {
-					logger.error("Error parsing arguments", e);
-				}
-				System.out.println(e.getMessage());
-				return CliConstants.COMMAND_FAILED;
-			}
-		} else {
-			context.getStratosApplication().printUsage(getName());
-			return CliConstants.COMMAND_FAILED;
-		}
-	}
-
-	public Options getOptions() {
-		return options;
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/ApplicationBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/ApplicationBean.java b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/ApplicationBean.java
new file mode 100644
index 0000000..7eb94e5
--- /dev/null
+++ b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/ApplicationBean.java
@@ -0,0 +1,75 @@
+package org.apache.stratos.common.beans;
+
+import org.apache.stratos.common.beans.topology.Cluster;
+import org.apache.stratos.common.beans.topology.Instance;
+
+import javax.xml.bind.annotation.XmlRootElement;
+
+import java.util.ArrayList;
+import java.util.List;
+
+@XmlRootElement(name="applications")
+public class ApplicationBean {
+    private String id;
+    private String tenantDomain;
+    private String tenantAdminUsername;
+    private List<GroupBean> groups = null;
+    private List<Cluster> clusters = null;
+    private List<Instance> instances;
+
+
+    public ApplicationBean(){
+        this.setGroups(new ArrayList<GroupBean>());
+        this.setClusters(new ArrayList<Cluster>());
+    }
+    public void addGroup(GroupBean groupBean) {
+        this.getGroups().add(groupBean);
+    }
+
+    public void setId(String id) {
+        this.id = id;
+    }
+
+    public void setTenantDomain(String tenantDomain) {
+        this.tenantDomain = tenantDomain;
+    }
+
+    public void setTenantAdminUsername(String tenantAdminUsername) {
+        this.tenantAdminUsername = tenantAdminUsername;
+    }
+
+    public String getId() {
+        return id;
+    }
+
+    public String getTenantDomain() {
+        return tenantDomain;
+    }
+
+    public String getTenantAdminUsername() {
+        return tenantAdminUsername;
+    }
+	public List<Instance> getInstances() {
+		return instances;
+	}
+	public void setInstances(List<Instance> instances) {
+		this.instances = instances;
+	}
+
+
+    public List<GroupBean> getGroups() {
+        return groups;
+    }
+
+    public void setGroups(List<GroupBean> groups) {
+        this.groups = groups;
+    }
+
+    public List<Cluster> getClusters() {
+        return clusters;
+    }
+
+    public void setClusters(List<Cluster> clusters) {
+        this.clusters = clusters;
+    }
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/CartridgeInfoBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/CartridgeInfoBean.java b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/CartridgeInfoBean.java
new file mode 100644
index 0000000..0d3af03
--- /dev/null
+++ b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/CartridgeInfoBean.java
@@ -0,0 +1,167 @@
+/**
+ *  Licensed to the Apache Software Foundation (ASF) under one
+ *  or more contributor license agreements.  See the NOTICE file
+ *  distributed with this work for additional information
+ *  regarding copyright ownership.  The ASF licenses this file
+ *  to you under the Apache License, Version 2.0 (the
+ *  "License"); you may not use this file except in compliance
+ *  with the License.  You may obtain a copy of the License at
+
+ *  http://www.apache.org/licenses/LICENSE-2.0
+
+ *  Unless required by applicable law or agreed to in writing,
+ *  software distributed under the License is distributed on an
+ *  "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ *  KIND, either express or implied.  See the License for the
+ *  specific language governing permissions and limitations
+ *  under the License.
+ */
+package org.apache.stratos.common.beans;
+
+import org.apache.stratos.common.beans.cartridge.definition.PersistenceBean;
+import org.apache.stratos.common.beans.cartridge.definition.PropertyBean;
+import javax.xml.bind.annotation.XmlRootElement;
+import java.util.ArrayList;
+import java.util.List;
+
+@XmlRootElement
+public class CartridgeInfoBean {
+    String cartridgeType;
+    String alias;
+    String autoscalePolicy;
+    String deploymentPolicy;
+    String repoURL;
+    boolean privateRepo;
+    String repoUsername;
+    String repoPassword;
+    String dataCartridgeType;
+    String dataCartridgeAlias;
+    boolean commitsEnabled;
+
+    private String serviceGroup;
+
+    private PersistenceBean persistence;
+
+    private List<PropertyBean> property;
+
+    private List<String> domains;
+
+    public CartridgeInfoBean() {
+        this.domains = new ArrayList<String>();
+    }
+
+    public String getCartridgeType() {
+        return cartridgeType;
+    }
+
+    public void setCartridgeType(String cartridgeType) {
+        this.cartridgeType = cartridgeType;
+    }
+
+    public String getAlias() {
+        return alias;
+    }
+
+    public void setAlias(String alias) {
+        this.alias = alias;
+    }
+
+    public String getAutoscalePolicy() {
+        return autoscalePolicy;
+    }
+
+    public void setAutoscalePolicy(String autoscalePolicy) {
+        this.autoscalePolicy = autoscalePolicy;
+    }
+
+    public String getRepoURL() {
+        return repoURL;
+    }
+
+    public void setRepoURL(String repoURL) {
+        this.repoURL = repoURL;
+    }
+
+    public boolean isPrivateRepo() {
+        return privateRepo;
+    }
+
+    public void setPrivateRepo(boolean privateRepo) {
+        this.privateRepo = privateRepo;
+    }
+
+    public String getRepoUsername() {
+        return repoUsername;
+    }
+
+    public void setRepoUsername(String repoUsername) {
+        this.repoUsername = repoUsername;
+    }
+
+    public String getRepoPassword() {
+        return repoPassword;
+    }
+
+    public void setRepoPassword(String repoPassword) {
+        this.repoPassword = repoPassword;
+    }
+
+    public String getDataCartridgeType() {
+        return dataCartridgeType;
+    }
+
+    public void setDataCartridgeType(String dataCartridgeType) {
+        this.dataCartridgeType = dataCartridgeType;
+    }
+
+    public String getDataCartridgeAlias() {
+        return dataCartridgeAlias;
+    }
+
+    public void setDataCartridgeAlias(String dataCartridgeAlias) {
+        this.dataCartridgeAlias = dataCartridgeAlias;
+    }
+
+    public String getDeploymentPolicy() {
+        return deploymentPolicy;
+    }
+
+    public void setDeploymentPolicy(String deploymentPolicy) {
+        this.deploymentPolicy = deploymentPolicy;
+    }
+
+    public boolean isCommitsEnabled() {
+		return commitsEnabled;
+	}
+
+	public void setCommitsEnabled(boolean commitsEnabled) {
+		this.commitsEnabled = commitsEnabled;
+	}
+
+	public String getServiceGroup() {
+		return serviceGroup;
+	}
+
+	public void setServiceGroup(String serviceGroup) {
+		this.serviceGroup = serviceGroup;
+	}
+
+    public PersistenceBean getPersistence() {
+        return persistence;
+    }
+
+    public void setPersistence(PersistenceBean persistence) {
+        this.persistence = persistence;
+    }
+
+    public List<PropertyBean> getProperty() {
+        return property;
+    }
+
+    public void setProperty(List<PropertyBean> property) {
+        this.property = property;
+    }
+    public List<String> getDomains() { return domains; }
+
+    public void setDomains(List<String> domains) { this.domains = domains; }
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/Error.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/Error.java b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/Error.java
new file mode 100644
index 0000000..568c7e0
--- /dev/null
+++ b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/Error.java
@@ -0,0 +1,45 @@
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+package org.apache.stratos.common.beans;
+
+import javax.xml.bind.annotation.XmlRootElement;
+
+@XmlRootElement(name = "error")
+public class Error {
+    private int errorCode;
+    private String errorMessage;
+
+    public int getErrorCode() {
+        return errorCode;
+    }
+
+    public void setErrorCode(int errorCode) {
+        this.errorCode = errorCode;
+    }
+
+    public String getErrorMessage() {
+        return errorMessage;
+    }
+
+    public void setErrorMessage(String errorMessage) {
+        this.errorMessage = errorMessage;
+    }
+}

http://git-wip-us.apache.org/repos/asf/stratos/blob/df2d6e6c/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/GroupBean.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/GroupBean.java b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/GroupBean.java
new file mode 100644
index 0000000..7ed3cd4
--- /dev/null
+++ b/components/org.apache.stratos.common/src/main/java/org/apache/stratos/common/beans/GroupBean.java
@@ -0,0 +1,99 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *  http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.stratos.common.beans;
+
+import org.apache.stratos.common.beans.topology.Cluster;
+import org.apache.stratos.common.beans.topology.Instance;
+
+import javax.xml.bind.annotation.XmlRootElement;
+
+import java.util.ArrayList;
+import java.util.List;
+
+@XmlRootElement(name="groups")
+public class GroupBean {
+    private List<GroupBean> subGroups = null;
+    private List<Cluster> clusters = null;
+    private String alias;
+    private String deploymentPolicy;
+    private String autoScalingPolicy;
+    private List<Instance> instances; 
+
+    public GroupBean(){
+        this.setClusters(new ArrayList<Cluster>());
+        this.setSubGroups(new ArrayList<GroupBean>());
+    }
+
+    public void addGroup(GroupBean groupBean){
+        getSubGroups().add(groupBean);
+    }
+    public void addCluster(Cluster cluster){
+        getClusters().add(cluster);
+    }
+
+    public List<GroupBean> getSubGroups() {
+        return subGroups;
+    }
+
+    public void setSubGroups(List<GroupBean> subGroups) {
+        this.subGroups = subGroups;
+    }
+
+    public List<Cluster> getClusters() {
+        return clusters;
+    }
+
+    public void setClusters(List<Cluster> clusters) {
+        this.clusters = clusters;
+    }
+
+    public void setAlias(String alias) {
+        this.alias = alias;
+    }
+
+    public void setDeploymentPolicy(String deploymentPolicy) {
+        this.deploymentPolicy = deploymentPolicy;
+    }
+
+    public void setAutoScalingPolicy(String autoScalingPolicy) {
+        this.autoScalingPolicy = autoScalingPolicy;
+    }
+
+    public String getAlias() {
+        return alias;
+    }
+
+    public String getDeploymentPolicy() {
+        return deploymentPolicy;
+    }
+
+    public String getAutoScalingPolicy() {
+        return autoScalingPolicy;
+    }
+
+	public List<Instance> getInstances() {
+		return instances;
+	}
+
+	public void setInstances(List<Instance> instances) {
+		this.instances = instances;
+	}
+    
+    
+}