You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by is...@apache.org on 2014/11/02 11:13:02 UTC

[3/4] more refactoring

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/application/payload/PayloadFactory.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/application/payload/PayloadFactory.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/application/payload/PayloadFactory.java
deleted file mode 100755
index 2b3ea8b..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/application/payload/PayloadFactory.java
+++ /dev/null
@@ -1,59 +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.cloud.controller.application.payload;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.cloud.controller.exception.ApplicationDefinitionException;
-
-
-public class PayloadFactory {
-
-	private static Log log = LogFactory.getLog(PayloadFactory.class);
-
-    /**
-     * Creates and returns a PayloadData instance
-     *
-     * @param cartridgeProvider Cartridge provider
-     * @param cartridgeType Cartridge type
-     * @param basicPayloadData BasicPayloadData instance
-     * @return Payload subscription
-     */
-	public static PayloadData getPayloadDataInstance(String cartridgeProvider, String cartridgeType,
-                                                     BasicPayloadData basicPayloadData)
-            throws ApplicationDefinitionException {
-
-        PayloadData payloadData = null;
-
-        //TODO: fix after adding the property Category to Cartridge Definition
-        if (cartridgeProvider.equals("data")) {
-            payloadData = new DataCartridgePayloadData(basicPayloadData);
-        } else {
-            payloadData = new FrameworkCartridgePayloadData(basicPayloadData);
-        }
-
-        if(payloadData == null) {
-            throw new ApplicationDefinitionException("Unable to find matching payload for cartridge type " + cartridgeType +
-                    ", provider " + cartridgeProvider);
-        }
-
-        return payloadData;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/impl/CloudControllerServiceImpl.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/impl/CloudControllerServiceImpl.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/impl/CloudControllerServiceImpl.java
index ca2cc1e..a914946 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/impl/CloudControllerServiceImpl.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/impl/CloudControllerServiceImpl.java
@@ -24,17 +24,14 @@ import com.google.common.net.InetAddresses;
 import org.apache.commons.lang.StringUtils;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.cloud.controller.application.parser.DefaultApplicationParser;
 import org.apache.stratos.cloud.controller.concurrent.PartitionValidatorCallable;
 import org.apache.stratos.cloud.controller.concurrent.ThreadExecutor;
 import org.apache.stratos.cloud.controller.deployment.partition.Partition;
 import org.apache.stratos.cloud.controller.exception.*;
-import org.apache.stratos.cloud.controller.interfaces.ApplicationParser;
 import org.apache.stratos.cloud.controller.interfaces.CloudControllerService;
 import org.apache.stratos.cloud.controller.interfaces.Iaas;
 import org.apache.stratos.cloud.controller.persist.Deserializer;
 import org.apache.stratos.cloud.controller.pojo.*;
-import org.apache.stratos.cloud.controller.pojo.application.ApplicationContext;
 import org.apache.stratos.cloud.controller.publisher.CartridgeInstanceDataPublisher;
 import org.apache.stratos.cloud.controller.registry.RegistryManager;
 import org.apache.stratos.cloud.controller.runtime.FasterLookUpDataHolder;
@@ -42,7 +39,6 @@ import org.apache.stratos.cloud.controller.topology.TopologyBuilder;
 import org.apache.stratos.cloud.controller.util.CloudControllerConstants;
 import org.apache.stratos.cloud.controller.util.CloudControllerUtil;
 import org.apache.stratos.cloud.controller.validate.interfaces.PartitionValidator;
-import org.apache.stratos.messaging.domain.applications.Application;
 import org.apache.stratos.messaging.domain.topology.MemberStatus;
 import org.apache.stratos.messaging.util.Constants;
 import org.jclouds.compute.ComputeService;
@@ -1391,29 +1387,29 @@ public class CloudControllerServiceImpl implements CloudControllerService {
         return dataHolder.getClusterContext(clusterId);
     }
 
-    public void deployApplicationDefinition (ApplicationContext applicationContext) throws ApplicationDefinitionException {
-
-        ApplicationParser applicationParser = new DefaultApplicationParser();
-        Application application = applicationParser.parse(applicationContext);
-
-        // Create a Cluster Context obj. for each of the Clusters in the Application
-        for (ApplicationClusterContext applicationClusterContext : applicationParser.getApplicationClusterContexts()) {
-            dataHolder.addClusterContext(new ClusterContext(applicationClusterContext.getClusterId(),
-                    applicationClusterContext.getCartridgeType(), applicationClusterContext.getTextPayload(),
-                    applicationClusterContext.getHostName(), applicationClusterContext.isLbCluster()));
-        }
-
-        /*TopologyBuilder.handleApplicationDeployed(application, applicationParser.getApplicationClusterContexts(),
-                applicationParser.getPayloadData());
-*/
-        persist();
-    }
-
-    @Override
-    public void unDeployApplicationDefinition(String applicationId, int tenantId, String tenantDomain) throws ApplicationDefinitionException {
-
-        //TopologyBuilder.handleApplicationUndeployed(applicationId);
-    }
+//    public void deployApplicationDefinition (ApplicationContext applicationContext) throws ApplicationDefinitionException {
+//
+//        ApplicationParser applicationParser = new DefaultApplicationParser();
+//        Application application = applicationParser.parse(applicationContext);
+//
+//        // Create a Cluster Context obj. for each of the Clusters in the Application
+//        for (ApplicationClusterContext applicationClusterContext : applicationParser.getApplicationClusterContexts()) {
+//            dataHolder.addClusterContext(new ClusterContext(applicationClusterContext.getClusterId(),
+//                    applicationClusterContext.getCartridgeType(), applicationClusterContext.getTextPayload(),
+//                    applicationClusterContext.getHostName(), applicationClusterContext.isLbCluster()));
+//        }
+//
+//        /*TopologyBuilder.handleApplicationDeployed(application, applicationParser.getApplicationClusterContexts(),
+//                applicationParser.getPayloadData());
+//*/
+//        persist();
+//    }
+//
+//    @Override
+//    public void unDeployApplicationDefinition(String applicationId, int tenantId, String tenantDomain) throws ApplicationDefinitionException {
+//
+//        //TopologyBuilder.handleApplicationUndeployed(applicationId);
+//    }
 
 }
 

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/ApplicationParser.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/ApplicationParser.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/ApplicationParser.java
deleted file mode 100644
index 33e98f9..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/ApplicationParser.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.cloud.controller.interfaces;
-
-import org.apache.stratos.cloud.controller.exception.ApplicationDefinitionException;
-import org.apache.stratos.cloud.controller.pojo.ApplicationClusterContext;
-import org.apache.stratos.cloud.controller.pojo.payload.MetaDataHolder;
-import org.apache.stratos.messaging.domain.applications.Application;
-
-import java.util.Set;
-
-public interface ApplicationParser {
-
-    /**
-     * Parses the Application Definition
-     *
-     * @param obj Object with the Application Definition. An Object is used here since there can be
-     *            significant changes between the way composite Applications are defined in different
-     *            conventions
-     * @return Application structure denoting the parsed Application
-     * @throws ApplicationDefinitionException If the Application Definition is invalid
-     */
-    public Application parse (Object obj) throws ApplicationDefinitionException;
-
-    /**
-     * Returns a set of ApplicationClusterContext which will comprise of cluster related information
-     * extracted from the Application definition
-     *
-     * @return  Set of ApplicationClusterContext objects
-     * @throws ApplicationDefinitionException if any error occurs
-     */
-    public Set<ApplicationClusterContext> getApplicationClusterContexts() throws ApplicationDefinitionException;
-
-    // TODO: remove
-    public Set<MetaDataHolder> getPayloadData () throws ApplicationDefinitionException;
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/CloudControllerService.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/CloudControllerService.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/CloudControllerService.java
index 5301b14..016e98e 100644
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/CloudControllerService.java
+++ b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/interfaces/CloudControllerService.java
@@ -21,7 +21,6 @@ package org.apache.stratos.cloud.controller.interfaces;
 import org.apache.stratos.cloud.controller.deployment.partition.Partition;
 import org.apache.stratos.cloud.controller.exception.*;
 import org.apache.stratos.cloud.controller.pojo.*;
-import org.apache.stratos.cloud.controller.pojo.application.ApplicationContext;
 
 /**
  * This API provides a way to communicate with underline
@@ -168,20 +167,4 @@ public interface CloudControllerService {
      */
     public ClusterContext getClusterContext (String clusterId);
 
-    /**
-     * deploys an Application Definition
-     *
-     * @param applicationContext {@link org.apache.stratos.cloud.controller.pojo.application.ApplicationContext} object
-     * @throws ApplicationDefinitionException if an error is encountered
-     */
-    public void deployApplicationDefinition (ApplicationContext applicationContext) throws ApplicationDefinitionException;
-
-    /**
-     * undeploys an Application Definition
-     *
-     * @param applicationId Id of the Application to be undeployed
-     * @throws ApplicationDefinitionException if an error is encountered
-     */
-    public void unDeployApplicationDefinition (String applicationId, int tenantId, String tenantDomain) throws ApplicationDefinitionException;
-
 }

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ApplicationContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ApplicationContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ApplicationContext.java
deleted file mode 100644
index 3a8af44..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ApplicationContext.java
+++ /dev/null
@@ -1,93 +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.cloud.controller.pojo.application;
-
-public class ApplicationContext {
-
-    private int tenantId;
-
-    private String tenantDomain;
-
-    private String teantAdminUsername;
-
-    private String applicationId;
-
-    private String alias;
-
-    private ComponentContext componentContext;
-
-    private SubscribableInfoContext[] subscribableInfoContexts;
-
-    public String getApplicationId() {
-        return applicationId;
-    }
-
-    public void setApplicationId(String applicationId) {
-        this.applicationId = applicationId;
-    }
-
-    public String getAlias() {
-        return alias;
-    }
-
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-
-    public ComponentContext getComponents() {
-        return componentContext;
-    }
-
-    public void setComponents(ComponentContext componentContext) {
-        this.componentContext = componentContext;
-    }
-
-    public SubscribableInfoContext[] getSubscribableInfoContext() {
-        return subscribableInfoContexts;
-    }
-
-    public void setSubscribableInfoContext(SubscribableInfoContext[] subscribableInfoContexts) {
-        this.subscribableInfoContexts = subscribableInfoContexts;
-    }
-
-    public int getTenantId() {
-        return tenantId;
-    }
-
-    public void setTenantId(int tenantId) {
-        this.tenantId = tenantId;
-    }
-
-    public String getTenantDomain() {
-        return tenantDomain;
-    }
-
-    public void setTenantDomain(String tenantDomain) {
-        this.tenantDomain = tenantDomain;
-    }
-
-    public String getTeantAdminUsername() {
-        return teantAdminUsername;
-    }
-
-    public void setTeantAdminUsername(String teantAdminUsername) {
-        this.teantAdminUsername = teantAdminUsername;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ComponentContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ComponentContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ComponentContext.java
deleted file mode 100644
index d1a13a5..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/ComponentContext.java
+++ /dev/null
@@ -1,54 +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.cloud.controller.pojo.application;
-
-public class ComponentContext {
-
-    private GroupContext[] groupContexts;
-
-    private SubscribableContext[] subscribableContexts;
-
-    private DependencyContext dependencyContext;
-
-
-    public GroupContext[] getGroupContexts() {
-        return groupContexts;
-    }
-
-    public void setGroupContexts(GroupContext[] groupContexts) {
-        this.groupContexts = groupContexts;
-    }
-
-    public SubscribableContext[] getSubscribableContexts() {
-        return subscribableContexts;
-    }
-
-    public void setSubscribableContexts(SubscribableContext[] subscribableContexts) {
-        this.subscribableContexts = subscribableContexts;
-    }
-
-    public DependencyContext getDependencyContext() {
-        return dependencyContext;
-    }
-
-    public void setDependencyContext(DependencyContext dependencyContext) {
-        this.dependencyContext = dependencyContext;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/DependencyContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/DependencyContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/DependencyContext.java
deleted file mode 100644
index a99dcb0..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/DependencyContext.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.cloud.controller.pojo.application;
-
-
-public class DependencyContext {
-    
-    private String [] startupOrdersContexts;
-
-    private String terminationBehaviour;
-
-    public String getTerminationBehaviour() {
-        return terminationBehaviour;
-    }
-
-    public void setTerminationBehaviour(String terminationBehaviour) {
-        this.terminationBehaviour = terminationBehaviour;
-    }
-
-	public String [] getStartupOrdersContexts() {
-		return startupOrdersContexts;
-	}
-
-	public void setStartupOrdersContexts(String [] startupOrdersContexts) {
-		this.startupOrdersContexts = startupOrdersContexts;
-	}
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/GroupContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/GroupContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/GroupContext.java
deleted file mode 100644
index fda4bec..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/GroupContext.java
+++ /dev/null
@@ -1,84 +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.cloud.controller.pojo.application;
-
-public class GroupContext {
-
-    private String name;
-
-    private String alias;
-
-    private String deploymentPolicy;
-
-    private String autoscalingPolicy;
-
-    private SubscribableContext[] subscribableContexts;
-
-    private GroupContext[] groupContexts;
-
-
-    public String getName() {
-        return name;
-    }
-
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    public String getAlias() {
-        return alias;
-    }
-
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-
-    public String getDeploymentPolicy() {
-        return deploymentPolicy;
-    }
-
-    public void setDeploymentPolicy(String deploymentPolicy) {
-        this.deploymentPolicy = deploymentPolicy;
-    }
-
-    public String getAutoscalingPolicy() {
-        return autoscalingPolicy;
-    }
-
-    public void setAutoscalingPolicy(String autoscalingPolicy) {
-        this.autoscalingPolicy = autoscalingPolicy;
-    }
-
-    public SubscribableContext[] getSubscribableContexts() {
-        return subscribableContexts;
-    }
-
-    public void setSubscribableContexts(SubscribableContext[] subscribableContexts) {
-        this.subscribableContexts = subscribableContexts;
-    }
-
-    public GroupContext[] getGroupContexts() {
-        return groupContexts;
-    }
-
-    public void setGroupContexts(GroupContext[] groupContexts) {
-        this.groupContexts = groupContexts;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableContext.java
deleted file mode 100644
index 6f7f4bc..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableContext.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.cloud.controller.pojo.application;
-
-public class SubscribableContext {
-
-    private String type;
-
-    private String alias;
-
-
-    public String getType() {
-        return type;
-    }
-
-    public void setType(String type) {
-        this.type = type;
-    }
-
-    public String getAlias() {
-        return alias;
-    }
-
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableInfoContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableInfoContext.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableInfoContext.java
deleted file mode 100644
index 5f75a7c..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/application/SubscribableInfoContext.java
+++ /dev/null
@@ -1,103 +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.cloud.controller.pojo.application;
-
-public class SubscribableInfoContext {
-
-    private String alias;
-
-    private String deploymentPolicy;
-
-    private String autoscalingPolicy;
-
-    private String repoUrl;
-
-    private boolean privateRepo;
-
-    private String repoUsername;
-
-    private String repoPassword;
-
-    private String[] dependencyAliases;
-
-    public String getAlias() {
-        return alias;
-    }
-
-    public void setAlias(String alias) {
-        this.alias = alias;
-    }
-
-    public String getDeploymentPolicy() {
-        return deploymentPolicy;
-    }
-
-    public void setDeploymentPolicy(String deploymentPolicy) {
-        this.deploymentPolicy = deploymentPolicy;
-    }
-
-    public String getAutoscalingPolicy() {
-        return autoscalingPolicy;
-    }
-
-    public void setAutoscalingPolicy(String autoscalingPolicy) {
-        this.autoscalingPolicy = autoscalingPolicy;
-    }
-
-    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[] getDependencyAliases() {
-        return dependencyAliases;
-    }
-
-    public void setDependencyAliases(String[] dependencyAliases) {
-        this.dependencyAliases = dependencyAliases;
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/572cbe32/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/payload/MetaDataHolder.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/payload/MetaDataHolder.java b/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/payload/MetaDataHolder.java
deleted file mode 100644
index 3db9f71..0000000
--- a/components/org.apache.stratos.cloud.controller/src/main/java/org/apache/stratos/cloud/controller/pojo/payload/MetaDataHolder.java
+++ /dev/null
@@ -1,99 +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.cloud.controller.pojo.payload;
-
-import java.util.Properties;
-
-/**
- * Holds payload/meta data related to a cluster
- */
-
-public class MetaDataHolder {
-
-    private String appId;
-
-    private String groupName;
-
-    private String clusterId;
-
-    private Properties properties;
-
-    public MetaDataHolder (String appId, String clusterId) {
-
-        this.appId = appId;
-        this.clusterId = clusterId;
-    }
-
-    public MetaDataHolder(String appId, String groupName, String clusterId) {
-
-        this.appId = appId;
-        this.groupName = groupName;
-        this.clusterId = clusterId;
-    }
-
-    public String getAppId() {
-        return appId;
-    }
-
-    public String getGroupName() {
-        return groupName;
-    }
-
-    public String getClusterId() {
-        return clusterId;
-    }
-
-    public boolean equals(Object other) {
-
-        if(other == null || !(other instanceof MetaDataHolder)) {
-            return false;
-        }
-
-        if(this == other) {
-            return true;
-        }
-
-        MetaDataHolder that = (MetaDataHolder)other;
-
-        if (this.groupName == null || that.groupName == null) {
-            return this.appId.equals(that.appId) && this.clusterId.equals(that.clusterId);
-        } else {
-            return this.appId.equals(that.appId) && this.groupName.equals(that.groupName) &&
-                    this.clusterId.equals(that.clusterId);
-        }
-    }
-
-    public int hashCode () {
-
-        if (this.getGroupName() == null) {
-            return this.appId.hashCode() + this.clusterId.hashCode();
-        } else {
-            return this.appId.hashCode() + this.groupName.hashCode() + this.clusterId.hashCode();
-        }
-    }
-
-    public Properties getProperties() {
-        return properties;
-    }
-
-    public void setProperties(Properties properties) {
-        this.properties = properties;
-    }
-}