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/01/08 06:51:32 UTC

[21/46] git commit: renamed adc.mgt to manager

renamed adc.mgt to manager


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

Branch: refs/heads/master
Commit: 9f74f29c7b3e9d5f8094bc1a20d22965e37ec767
Parents: 73326f9
Author: Isuru <is...@wso2.com>
Authored: Tue Jan 7 21:32:42 2014 +0530
Committer: Isuru <is...@apache.org>
Committed: Tue Jan 7 16:46:28 2014 +0000

----------------------------------------------------------------------
 components/org.apache.stratos.adc.mgt/pom.xml   |   18 +-
 .../adc/mgt/client/AutoscalerServiceClient.java |  308 ----
 .../adc/mgt/client/CartridgeAgentClient.java    |   44 -
 .../client/CloudControllerServiceClient.java    |  171 ---
 .../stratos/adc/mgt/client/RegistryClient.java  |  109 --
 .../CartridgeSubscriptionConnector.java         |   45 -
 .../CartridgeSubscriptionConnectorFactory.java  |   41 -
 .../DataCartridgeSubscriptionConnector.java     |   92 --
 .../adc/mgt/custom/domain/RegistryManager.java  |  109 --
 .../adc/mgt/dao/CartridgeSubscriptionInfo.java  |  200 ---
 .../org/apache/stratos/adc/mgt/dao/Cluster.java |   77 -
 .../stratos/adc/mgt/dao/DataCartridge.java      |   62 -
 .../apache/stratos/adc/mgt/dao/PortMapping.java |   59 -
 .../adc/mgt/dao/RepositoryCredentials.java      |   48 -
 .../stratos/adc/mgt/deploy/service/Service.java |  138 --
 .../service/ServiceDeploymentManager.java       |  330 ----
 .../service/multitenant/MultiTenantService.java |   53 -
 .../apache/stratos/adc/mgt/dns/DNSManager.java  |   89 --
 .../org/apache/stratos/adc/mgt/dto/AppRepo.java |   88 --
 .../apache/stratos/adc/mgt/dto/Cartridge.java   |  202 ---
 .../stratos/adc/mgt/dto/CartridgeDetail.java    |   22 -
 .../adc/mgt/dto/CartridgeInformation.java       |   22 -
 .../stratos/adc/mgt/dto/CartridgeWrapper.java   |   52 -
 .../org/apache/stratos/adc/mgt/dto/Policy.java  |  148 --
 .../stratos/adc/mgt/dto/PolicyDefinition.java   |   83 --
 .../adc/mgt/dto/RepositoryInformation.java      |   46 -
 .../stratos/adc/mgt/dto/SubscriptionInfo.java   |   48 -
 .../stratos/adc/mgt/exception/ADCException.java |   49 -
 .../exception/AlreadySubscribedException.java   |   48 -
 .../exception/DomainMappingExistsException.java |   48 -
 .../DuplicateCartridgeAliasException.java       |   56 -
 .../InvalidCartridgeAliasException.java         |   67 -
 .../exception/InvalidRepositoryException.java   |   35 -
 .../mgt/exception/NotSubscribedException.java   |   49 -
 .../exception/PersistenceManagerException.java  |   49 -
 .../adc/mgt/exception/PolicyException.java      |   41 -
 .../RepositoryCredentialsRequiredException.java |   40 -
 .../exception/RepositoryRequiredException.java  |   40 -
 .../exception/RepositoryTransportException.java |   40 -
 .../UnregisteredCartridgeException.java         |   48 -
 .../internal/ADCManagementServerComponent.java  |  188 ---
 .../stratos/adc/mgt/internal/DataHolder.java    |   91 --
 .../adc/mgt/internal/HostingConstants.java      |   40 -
 .../internal/HostingManagementActivator.java    |   63 -
 .../mgt/internal/ServiceReferenceHolder.java    |   51 -
 .../mgt/listener/InstanceStatusListener.java    |   92 --
 .../adc/mgt/listener/TenantStatusListner.java   |   42 -
 .../adc/mgt/lookup/ClusterIdToSubscription.java |   59 -
 .../adc/mgt/lookup/LookupDataHolder.java        |  151 --
 .../adc/mgt/lookup/SubscriptionContext.java     |  131 --
 .../lookup/TenantIdToSubscriptionContext.java   |   64 -
 .../manager/CartridgeSubscriptionManager.java   |  628 --------
 .../ApplicationCartridgePayloadData.java        |   27 -
 .../adc/mgt/payload/BasicPayloadData.java       |  224 ---
 .../stratos/adc/mgt/payload/CarbonPayload.java  |   43 -
 .../mgt/payload/DataCartridgePayloadData.java   |   27 -
 .../stratos/adc/mgt/payload/DataPayload.java    |   40 -
 .../payload/FramewrokCartridgePayloadData.java  |   27 -
 .../LoadBalancerCartridgePayloadData.java       |   27 -
 .../adc/mgt/payload/NonCarbonPayload.java       |  125 --
 .../apache/stratos/adc/mgt/payload/Payload.java |  224 ---
 .../stratos/adc/mgt/payload/PayloadArg.java     |  194 ---
 .../stratos/adc/mgt/payload/PayloadData.java    |   74 -
 .../stratos/adc/mgt/payload/PayloadFactory.java |   60 -
 .../DatabaseBasedPersistenceManager.java        | 1408 ------------------
 .../adc/mgt/persistence/PersistenceManager.java |   92 --
 .../RegistryBasedPersistenceManager.java        |  567 -------
 .../mgt/publisher/ArtifactUpdatePublisher.java  |   65 -
 .../adc/mgt/publisher/TenantEventPublisher.java |  114 --
 .../TenantSynchronizerTaskScheduler.java        |   76 -
 .../mgt/publisher/TenantSynzhronizerTask.java   |   94 --
 .../adc/mgt/registry/RegistryManager.java       |  337 -----
 .../stratos/adc/mgt/repository/Repository.java  |   78 -
 .../DataInsertionAndRetrievalManager.java       |  349 -----
 .../service/ApplicationManagementService.java   |  679 ---------
 .../InstanceInformationManagementService.java   |   58 -
 .../mgt/service/RepoNotificationService.java    |  127 --
 .../adc/mgt/service/RepositoryInfoBean.java     |   98 --
 .../stratos/adc/mgt/subscriber/Subscriber.java  |   68 -
 .../ApplicationCartridgeSubscription.java       |   50 -
 .../mgt/subscription/CartridgeSubscription.java |  467 ------
 .../subscription/CartridgeSubscription_old.java |  431 ------
 .../subscription/DataCartridgeSubscription.java |  117 --
 .../DataCartridgeSubscription_old.java          |  127 --
 .../FrameworkCartridgeSubscription.java         |   43 -
 .../subscription/LBCartridgeSubscription.java   |   53 -
 .../MultiTenantCartridgeSubscription.java       |  134 --
 .../SingleTenantCartridgeSubscription.java      |  136 --
 .../cache/CartridgeInstanceCache.java           |  119 --
 .../cache/CartridgeInstanceCacheKey.java        |   59 -
 .../factory/CartridgeSubscriptionFactory.java   |   89 --
 .../ServiceDeploymentMultiTenantBehaviour.java  |  109 --
 .../SubscriptionMultiTenantBehaviour.java       |  110 --
 .../SubscriptionSingleTenantBehaviour.java      |   97 --
 .../tenancy/SubscriptionTenancyBehaviour.java   |   43 -
 .../utils/CartridgeSubscriptionUtils.java       |  172 ---
 .../model/TopologyClusterInformationModel.java  |  502 -------
 .../StratosManagerTopologyReceiver.java         |  310 ----
 .../mgt/utils/ApplicationManagementUtil.java    | 1102 --------------
 .../stratos/adc/mgt/utils/CartridgeAppType.java |   44 -
 .../mgt/utils/CartridgeConfigFileReader.java    |   62 -
 .../adc/mgt/utils/CartridgeConstants.java       |   95 --
 .../stratos/adc/mgt/utils/CartridgeDomain.java  |  146 --
 .../stratos/adc/mgt/utils/Deserializer.java     |   52 -
 .../stratos/adc/mgt/utils/DomainInfo.java       |   43 -
 .../adc/mgt/utils/PersistenceManager.java       |  892 -----------
 .../stratos/adc/mgt/utils/PolicyHolder.java     |  292 ----
 .../adc/mgt/utils/RepoPasswordMgtUtil.java      |  117 --
 .../adc/mgt/utils/RepositoryCreator.java        |  286 ----
 .../adc/mgt/utils/RepositoryFactory.java        |  131 --
 .../stratos/adc/mgt/utils/Serializer.java       |  104 --
 .../stratos/adc/mgt/utils/StratosDBUtils.java   |  213 ---
 .../mgt/utils/SynchronizeRepositoryRequest.java |  146 --
 .../manager/client/AutoscalerServiceClient.java |  308 ++++
 .../manager/client/CartridgeAgentClient.java    |   44 +
 .../client/CloudControllerServiceClient.java    |  171 +++
 .../stratos/manager/client/RegistryClient.java  |  109 ++
 .../CartridgeSubscriptionConnector.java         |   45 +
 .../CartridgeSubscriptionConnectorFactory.java  |   41 +
 .../DataCartridgeSubscriptionConnector.java     |   92 ++
 .../manager/dao/CartridgeSubscriptionInfo.java  |  200 +++
 .../org/apache/stratos/manager/dao/Cluster.java |   77 +
 .../stratos/manager/dao/DataCartridge.java      |   62 +
 .../apache/stratos/manager/dao/PortMapping.java |   59 +
 .../manager/dao/RepositoryCredentials.java      |   48 +
 .../apache/stratos/manager/dns/DNSManager.java  |   89 ++
 .../stratos/manager/domain/RegistryManager.java |  109 ++
 .../org/apache/stratos/manager/dto/AppRepo.java |   88 ++
 .../apache/stratos/manager/dto/Cartridge.java   |  202 +++
 .../stratos/manager/dto/CartridgeDetail.java    |   22 +
 .../manager/dto/CartridgeInformation.java       |   22 +
 .../stratos/manager/dto/CartridgeWrapper.java   |   52 +
 .../org/apache/stratos/manager/dto/Policy.java  |  148 ++
 .../stratos/manager/dto/PolicyDefinition.java   |   83 ++
 .../manager/dto/RepositoryInformation.java      |   46 +
 .../stratos/manager/dto/SubscriptionInfo.java   |   48 +
 .../stratos/manager/exception/ADCException.java |   49 +
 .../exception/AlreadySubscribedException.java   |   48 +
 .../exception/DomainMappingExistsException.java |   48 +
 .../DuplicateCartridgeAliasException.java       |   56 +
 .../InvalidCartridgeAliasException.java         |   67 +
 .../exception/InvalidRepositoryException.java   |   35 +
 .../exception/NotSubscribedException.java       |   49 +
 .../exception/PersistenceManagerException.java  |   49 +
 .../manager/exception/PolicyException.java      |   41 +
 .../RepositoryCredentialsRequiredException.java |   40 +
 .../exception/RepositoryRequiredException.java  |   40 +
 .../exception/RepositoryTransportException.java |   40 +
 .../UnregisteredCartridgeException.java         |   48 +
 .../internal/ADCManagementServerComponent.java  |  188 +++
 .../stratos/manager/internal/DataHolder.java    |   91 ++
 .../manager/internal/HostingConstants.java      |   40 +
 .../internal/HostingManagementActivator.java    |   63 +
 .../internal/ServiceReferenceHolder.java        |   51 +
 .../listener/InstanceStatusListener.java        |   92 ++
 .../manager/listener/TenantStatusListner.java   |   42 +
 .../manager/lookup/ClusterIdToSubscription.java |   59 +
 .../manager/lookup/LookupDataHolder.java        |  151 ++
 .../manager/lookup/SubscriptionContext.java     |  131 ++
 .../lookup/TenantIdToSubscriptionContext.java   |   64 +
 .../manager/CartridgeSubscriptionManager.java   |  628 ++++++++
 .../ApplicationCartridgePayloadData.java        |   27 +
 .../manager/payload/BasicPayloadData.java       |  224 +++
 .../stratos/manager/payload/CarbonPayload.java  |   43 +
 .../payload/DataCartridgePayloadData.java       |   27 +
 .../stratos/manager/payload/DataPayload.java    |   40 +
 .../payload/FramewrokCartridgePayloadData.java  |   27 +
 .../LoadBalancerCartridgePayloadData.java       |   27 +
 .../manager/payload/NonCarbonPayload.java       |  125 ++
 .../apache/stratos/manager/payload/Payload.java |  224 +++
 .../stratos/manager/payload/PayloadArg.java     |  194 +++
 .../stratos/manager/payload/PayloadData.java    |   74 +
 .../stratos/manager/payload/PayloadFactory.java |   60 +
 .../DatabaseBasedPersistenceManager.java        | 1408 ++++++++++++++++++
 .../manager/persistence/PersistenceManager.java |   92 ++
 .../RegistryBasedPersistenceManager.java        |  567 +++++++
 .../publisher/ArtifactUpdatePublisher.java      |   65 +
 .../manager/publisher/TenantEventPublisher.java |  114 ++
 .../TenantSynchronizerTaskScheduler.java        |   76 +
 .../publisher/TenantSynzhronizerTask.java       |   94 ++
 .../manager/registry/RegistryManager.java       |  337 +++++
 .../stratos/manager/repository/Repository.java  |   78 +
 .../DataInsertionAndRetrievalManager.java       |  349 +++++
 .../service/ApplicationManagementService.java   |  679 +++++++++
 .../InstanceInformationManagementService.java   |   58 +
 .../service/RepoNotificationService.java        |  127 ++
 .../manager/service/RepositoryInfoBean.java     |   98 ++
 .../apache/stratos/manager/service/Service.java |  138 ++
 .../service/ServiceDeploymentManager.java       |  330 ++++
 .../service/multitenant/MultiTenantService.java |   53 +
 .../stratos/manager/subscriber/Subscriber.java  |   68 +
 .../ApplicationCartridgeSubscription.java       |   50 +
 .../subscription/CartridgeSubscription.java     |  467 ++++++
 .../subscription/CartridgeSubscription_old.java |  431 ++++++
 .../subscription/DataCartridgeSubscription.java |  117 ++
 .../DataCartridgeSubscription_old.java          |  127 ++
 .../FrameworkCartridgeSubscription.java         |   43 +
 .../subscription/LBCartridgeSubscription.java   |   53 +
 .../MultiTenantCartridgeSubscription.java       |  134 ++
 .../SingleTenantCartridgeSubscription.java      |  136 ++
 .../cache/CartridgeInstanceCache.java           |  119 ++
 .../cache/CartridgeInstanceCacheKey.java        |   59 +
 .../factory/CartridgeSubscriptionFactory.java   |   89 ++
 .../ServiceDeploymentMultiTenantBehaviour.java  |  109 ++
 .../SubscriptionMultiTenantBehaviour.java       |  110 ++
 .../SubscriptionSingleTenantBehaviour.java      |   97 ++
 .../tenancy/SubscriptionTenancyBehaviour.java   |   43 +
 .../utils/CartridgeSubscriptionUtils.java       |  172 +++
 .../model/TopologyClusterInformationModel.java  |  502 +++++++
 .../StratosManagerTopologyReceiver.java         |  310 ++++
 .../utils/ApplicationManagementUtil.java        | 1102 ++++++++++++++
 .../stratos/manager/utils/CartridgeAppType.java |   44 +
 .../utils/CartridgeConfigFileReader.java        |   62 +
 .../manager/utils/CartridgeConstants.java       |   95 ++
 .../stratos/manager/utils/CartridgeDomain.java  |  146 ++
 .../stratos/manager/utils/Deserializer.java     |   52 +
 .../stratos/manager/utils/DomainInfo.java       |   43 +
 .../manager/utils/PersistenceManager.java       |  892 +++++++++++
 .../stratos/manager/utils/PolicyHolder.java     |  292 ++++
 .../manager/utils/RepoPasswordMgtUtil.java      |  108 ++
 .../manager/utils/RepositoryCreator.java        |  286 ++++
 .../manager/utils/RepositoryFactory.java        |  131 ++
 .../stratos/manager/utils/Serializer.java       |  104 ++
 .../stratos/manager/utils/StratosDBUtils.java   |  213 +++
 .../utils/SynchronizeRepositoryRequest.java     |  138 ++
 .../src/main/resources/META-INF/services.xml    |    8 +-
 .../adc/mgt/test/CartridgeSubscriptionTest.java |   85 --
 .../stratos/adc/mgt/test/PayloadTest.java       |  196 ---
 .../stratos/adc/mgt/test/PolicyHolderTest.java  |   84 --
 .../manager/test/CartridgeSubscriptionTest.java |   85 ++
 .../stratos/manager/test/PayloadTest.java       |  196 +++
 .../stratos/manager/test/PolicyHolderTest.java  |   84 ++
 232 files changed, 17452 insertions(+), 17469 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/pom.xml
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/pom.xml b/components/org.apache.stratos.adc.mgt/pom.xml
index 1fd70fa..9623048 100644
--- a/components/org.apache.stratos.adc.mgt/pom.xml
+++ b/components/org.apache.stratos.adc.mgt/pom.xml
@@ -28,10 +28,10 @@
 	</parent>
 
 	<modelVersion>4.0.0</modelVersion>
-	<artifactId>org.apache.stratos.adc.mgt</artifactId>
+	<artifactId>org.apache.stratos.manager</artifactId>
 	<packaging>bundle</packaging>
-	<name>Apache Stratos - ADC BE</name>
-	<description>BE functionalities of ADC</description>
+	<name>Apache Stratos Manager BE</name>
+	<description>BE functionalities of SM</description>
 	<url>http://apache.org</url>
 
 	<dependencies>
@@ -128,14 +128,14 @@
 						<Bundle-SymbolicName>${project.artifactId}</Bundle-SymbolicName>
 						<Bundle-Name>${project.artifactId}</Bundle-Name>
 						<!--Bundle-Activator>
-							org.apache.stratos.adc.mgt.internal.HostingManagementActivator
+							org.apache.stratos.manager.internal.HostingManagementActivator
                                                 </Bundle-Activator-->
-						<Private-Package>org.apache.stratos.adc.mgt.internal.*</Private-Package>
+						<Private-Package>org.apache.stratos.manager.internal.*</Private-Package>
 						<Export-Package>
-							org.apache.stratos.adc.mgt.utils*,
-							org.apache.stratos.adc.mgt.service.*,
-							org.apache.stratos.adc.mgt.*
-                        			</Export-Package>
+                            org.apache.stratos.manager.utils*,
+                            org.apache.stratos.manager.service.*,
+                            org.apache.stratos.manager.*
+                        </Export-Package>
 						<Import-Package>
 							org.apache.axis2.*; version="1.6.1-wso2v10",
 							org.apache.axiom.*; version="${axiom.osgi.version.range}",

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/AutoscalerServiceClient.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/AutoscalerServiceClient.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/AutoscalerServiceClient.java
deleted file mode 100644
index 4fe2d62..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/AutoscalerServiceClient.java
+++ /dev/null
@@ -1,308 +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.adc.mgt.client;
-
-import org.apache.axis2.AxisFault;
-import org.apache.axis2.context.ConfigurationContext;
-import org.apache.axis2.transport.http.HTTPConstants;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.adc.mgt.exception.ADCException;
-import org.apache.stratos.adc.mgt.internal.DataHolder;
-import org.apache.stratos.adc.mgt.utils.CartridgeConstants;
-import org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy;
-import org.apache.stratos.autoscaler.policy.model.AutoscalePolicy;
-import org.apache.stratos.autoscaler.stub.AutoScalerServiceNonExistingLBExceptionException;
-import org.apache.stratos.autoscaler.stub.AutoScalerServiceStub;
-import org.apache.stratos.cloud.controller.deployment.partition.Partition;
-
-import java.rmi.RemoteException;
-
-public class AutoscalerServiceClient {
-
-    private AutoScalerServiceStub stub;
-
-    private static final Log log = LogFactory.getLog(AutoscalerServiceClient.class);
-    private static volatile AutoscalerServiceClient serviceClient;
-
-    public AutoscalerServiceClient(String epr) throws AxisFault {
-    	
-    	
-    	
-    	String autosclaerSocketTimeout =
-    		System.getProperty(CartridgeConstants.AUTOSCALER_SOCKET_TIMEOUT) == null ? "300000": System.getProperty(CartridgeConstants.AUTOSCALER_SOCKET_TIMEOUT);
-		String autosclaerConnectionTimeout = 
-			System.getProperty(CartridgeConstants.AUTOSCALER_CONNECTION_TIMEOUT) == null ? "300000" : System.getProperty(CartridgeConstants.AUTOSCALER_CONNECTION_TIMEOUT) ;
-    	
-        ConfigurationContext clientConfigContext = DataHolder.getClientConfigContext();
-        try {
-            stub = new AutoScalerServiceStub(clientConfigContext, epr);
-            stub._getServiceClient().getOptions().setProperty(HTTPConstants.SO_TIMEOUT, new Integer(autosclaerSocketTimeout));
-			stub._getServiceClient().getOptions().setProperty(HTTPConstants.CONNECTION_TIMEOUT, new Integer(autosclaerConnectionTimeout));
-
-        } catch (AxisFault axisFault) {
-            String msg = "Failed to initiate autoscaler service client. " + axisFault.getMessage();
-            log.error(msg, axisFault);
-            throw new AxisFault(msg, axisFault);
-        }
-    }
-
-    public static AutoscalerServiceClient getServiceClient() throws AxisFault {
-        if (serviceClient == null) {
-            synchronized (AutoscalerServiceClient.class) {
-                if (serviceClient == null) {
-                    serviceClient = new AutoscalerServiceClient(System.getProperty(CartridgeConstants.AUTOSCALER_SERVICE_URL));
-                }
-            }
-        }
-        return serviceClient;
-    }
-
-    public org.apache.stratos.cloud.controller.deployment.partition.Partition[] getAvailablePartitions ()
-            throws Exception {
-
-        org.apache.stratos.cloud.controller.deployment.partition.Partition[] partitions;
-        try {
-            partitions = stub.getAllAvailablePartitions();
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return partitions;
-    }
-
-    public org.apache.stratos.cloud.controller.deployment.partition.Partition getPartition (String partitionId)
-            throws Exception{
-
-        org.apache.stratos.cloud.controller.deployment.partition.Partition partition;
-        try {
-            partition = stub.getPartition(partitionId);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return partition;
-    }
-
-    public org.apache.stratos.cloud.controller.deployment.partition.Partition [] getPartitionsOfGroup (String deploymentPolicyId,
-                                                                                            String partitionGroupId)
-            throws Exception{
-
-        org.apache.stratos.cloud.controller.deployment.partition.Partition[] partitions;
-        try {
-            partitions = stub.getPartitionsOfGroup(deploymentPolicyId, partitionGroupId);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return partitions;
-    }
-    
-    public org.apache.stratos.cloud.controller.deployment.partition.Partition[]
-        getPartitionsOfDeploymentPolicy(String deploymentPolicyId) throws Exception {
-
-        org.apache.stratos.cloud.controller.deployment.partition.Partition[] partitions;
-        try {
-            partitions = stub.getPartitionsOfDeploymentPolicy(deploymentPolicyId);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return partitions;
-    }
-
-    public org.apache.stratos.autoscaler.partition.PartitionGroup [] getPartitionGroups (String deploymentPolicyId)
-            throws Exception{
-
-        org.apache.stratos.autoscaler.partition.PartitionGroup [] partitionGroups;
-        try {
-            partitionGroups = stub.getPartitionGroups(deploymentPolicyId);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return partitionGroups;
-    }
-
-    public org.apache.stratos.autoscaler.policy.model.AutoscalePolicy[] getAutoScalePolicies ()
-            throws Exception {
-
-        org.apache.stratos.autoscaler.policy.model.AutoscalePolicy[] autoscalePolicies;
-        try {
-            autoscalePolicies = stub.getAllAutoScalingPolicy();
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return autoscalePolicies;
-    }
-
-    public org.apache.stratos.autoscaler.policy.model.AutoscalePolicy getAutoScalePolicy (String autoscalingPolicyId)
-            throws Exception {
-
-        org.apache.stratos.autoscaler.policy.model.AutoscalePolicy autoscalePolicy;
-        try {
-            autoscalePolicy = stub.getAutoscalingPolicy(autoscalingPolicyId);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available partitions";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return autoscalePolicy;
-    }
-
-    public org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy [] getDeploymentPolicies()
-            throws Exception {
-
-        org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy[] deploymentPolicies;
-        try {
-            deploymentPolicies = stub.getAllDeploymentPolicies();
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available deployment policies";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return deploymentPolicies;
-    }
-
-    public org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy [] getDeploymentPolicies(String cartridgeType)
-            throws Exception {
-
-        org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy[] deploymentPolicies;
-        try {
-            deploymentPolicies = stub.getValidDeploymentPoliciesforCartridge(cartridgeType);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available deployment policies";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return deploymentPolicies;
-    }
-    
-    public void checkLBExistenceAgainstPolicy(String clusterId, String deploymentPolicyId) throws ADCException {
-        try {
-            stub.checkLBExistenceAgainstPolicy(clusterId, deploymentPolicyId);
-        } catch (RemoteException e) {
-            String errorMsg = "Error connecting to Auto-scaler Service.";
-            log.error(errorMsg, e);
-            throw new ADCException(errorMsg, e);
-        } catch (AutoScalerServiceNonExistingLBExceptionException e) {
-            String errorMsg = "LB Cluster doesn't exist. Cluster id: "+clusterId;
-            log.error(errorMsg, e);
-            throw new ADCException(errorMsg, e);
-        }
-    }
-    
-    public boolean checkDefaultLBExistenceAgainstPolicy(String deploymentPolicyId) throws ADCException {
-        try {
-            return stub.checkDefaultLBExistenceAgainstPolicy(deploymentPolicyId);
-        } catch (RemoteException e) {
-            String errorMsg = "Error connecting to Auto-scaler Service.";
-            log.error(errorMsg, e);
-            throw new ADCException(errorMsg, e);
-        }
-    }
-    
-    public boolean checkServiceLBExistenceAgainstPolicy(String serviceName, String deploymentPolicyId) throws ADCException {
-        try {
-            return stub.checkServiceLBExistenceAgainstPolicy(serviceName, deploymentPolicyId);
-        } catch (RemoteException e) {
-            String errorMsg = "Error connecting to Auto-scaler Service.";
-            log.error(errorMsg, e);
-            throw new ADCException(errorMsg, e);
-        }
-    }
-
-    public org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy getDeploymentPolicy (String deploymentPolicyId)
-            throws Exception {
-
-        org.apache.stratos.autoscaler.deployment.policy.DeploymentPolicy deploymentPolicy;
-        try {
-            deploymentPolicy = stub.getDeploymentPolicy(deploymentPolicyId);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in getting available deployment policies";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-
-        return deploymentPolicy;
-    }
-
-    public boolean deployDeploymentPolicy (DeploymentPolicy deploymentPolicy) throws Exception {
-
-        try {
-            return stub.addDeploymentPolicy(deploymentPolicy);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in deploying new deployment policy definition";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-    }
-
-    public boolean deployAutoscalingPolicy (AutoscalePolicy autoScalePolicy) throws Exception {
-
-        try {
-            return stub.addAutoScalingPolicy(autoScalePolicy);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in deploying new autoscaling policy definition";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-    }
-
-    public boolean deployPartition (Partition partition) throws Exception {
-
-        try {
-            return stub.addPartition(partition);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in deploying new partition definition";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CartridgeAgentClient.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CartridgeAgentClient.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CartridgeAgentClient.java
deleted file mode 100644
index 4fb1db8..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CartridgeAgentClient.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.adc.mgt.client;
-//
-//import org.apache.axis2.AxisFault;
-//import org.apache.axis2.context.ConfigurationContext;
-//import org.apache.commons.logging.Log;
-//import org.apache.commons.logging.LogFactory;
-//import org.apache.stratos.adc.mgt.internal.DataHolder;
-//import org.apache.stratos.cartridge.agent.stub.CartridgeAgentServiceStub;
-//
-//public class CartridgeAgentClient {
-//
-//	private static final Log log = LogFactory.getLog(CartridgeAgentClient.class);
-//	CartridgeAgentServiceStub stub = null;
-//	public CartridgeAgentClient(String epr) throws AxisFault {
-//	  ConfigurationContext clientConfigContext = DataHolder.getClientConfigContext();
-//	  stub = new CartridgeAgentServiceStub(clientConfigContext, epr);
-//    }
-//
-//	public void unregister(String domain, String subDomain, String hostName) throws Exception {
-//        if(log.isInfoEnabled()) {
-//		    log.info("Unregistering cartridge agent client...");
-//        }
-//		stub.unregister(domain, subDomain, hostName);
-//	}
-//}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CloudControllerServiceClient.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CloudControllerServiceClient.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CloudControllerServiceClient.java
deleted file mode 100644
index 3105c10..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/CloudControllerServiceClient.java
+++ /dev/null
@@ -1,171 +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.adc.mgt.client;
-
-import org.apache.axis2.AxisFault;
-import org.apache.axis2.context.ConfigurationContext;
-import org.apache.axis2.transport.http.HTTPConstants;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.adc.mgt.exception.UnregisteredCartridgeException;
-import org.apache.stratos.adc.mgt.internal.DataHolder;
-import org.apache.stratos.adc.mgt.utils.CartridgeConstants;
-import org.apache.stratos.cloud.controller.pojo.CartridgeConfig;
-import org.apache.stratos.cloud.controller.pojo.CartridgeInfo;
-import org.apache.stratos.cloud.controller.pojo.Properties;
-import org.apache.stratos.cloud.controller.pojo.Registrant;
-import org.apache.stratos.cloud.controller.stub.CloudControllerServiceIllegalArgumentExceptionException;
-import org.apache.stratos.cloud.controller.stub.CloudControllerServiceStub;
-import org.apache.stratos.cloud.controller.stub.CloudControllerServiceUnregisteredCartridgeExceptionException;
-import org.apache.stratos.cloud.controller.pojo.Property;
-
-import java.rmi.RemoteException;
-import java.util.Iterator;
-
-public class CloudControllerServiceClient {
-
-	private CloudControllerServiceStub stub;
-
-	private static final Log log = LogFactory.getLog(CloudControllerServiceClient.class);
-    private static volatile CloudControllerServiceClient serviceClient;
-
-	public CloudControllerServiceClient(String epr) throws AxisFault {
-
-		String ccSocketTimeout = 
-			System.getProperty(CartridgeConstants.CC_SOCKET_TIMEOUT) == null ? "300000" : System.getProperty(CartridgeConstants.CC_SOCKET_TIMEOUT);
-		String ccConnectionTimeout = 
-			System.getProperty(CartridgeConstants.CC_CONNECTION_TIMEOUT) == null ? "300000" : System.getProperty(CartridgeConstants.CC_CONNECTION_TIMEOUT);
-		
-		ConfigurationContext clientConfigContext = DataHolder.getClientConfigContext();
-		try {
-			stub = new CloudControllerServiceStub(clientConfigContext, epr);
-			stub._getServiceClient().getOptions().setProperty(HTTPConstants.SO_TIMEOUT, new Integer(ccSocketTimeout));
-			stub._getServiceClient().getOptions().setProperty(HTTPConstants.CONNECTION_TIMEOUT, new Integer(ccConnectionTimeout));
-
-		} catch (AxisFault axisFault) {
-			String msg = "Failed to initiate AutoscalerService client. " + axisFault.getMessage();
-			log.error(msg, axisFault);
-			throw new AxisFault(msg, axisFault);
-		}
-
-	}
-
-    public static CloudControllerServiceClient getServiceClient() throws AxisFault {
-        if (serviceClient == null) {
-            synchronized (CloudControllerServiceClient.class) {
-                if (serviceClient == null) {
-                    serviceClient = new CloudControllerServiceClient(
-                            System.getProperty(CartridgeConstants.CLOUD_CONTROLLER_SERVICE_URL));
-                }
-            }
-        }
-        return serviceClient;
-    }
-
-    public void deployCartridgeDefinition (CartridgeConfig cartridgeConfig)
-            throws Exception {
-
-        try {
-            stub.deployCartridgeDefinition(cartridgeConfig);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in deploying cartridge definition";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-    }
-
-    public void unDeployCartridgeDefinition (String cartridgeType)
-            throws Exception {
-
-        try {
-            stub.undeployCartridgeDefinition(cartridgeType);
-
-        } catch (RemoteException e) {
-            String errorMsg = "Error in deploying cartridge definition";
-            log.error(errorMsg, e);
-            throw new Exception(errorMsg, e);
-        }
-    }
-
-	public boolean register(String clusterId, String cartridgeType,
-	                        String payload, String tenantRange,
-                            String hostName, Properties properties,
-                            String autoscalorPolicyName, String deploymentPolicyName) throws RemoteException,
-                            CloudControllerServiceUnregisteredCartridgeExceptionException, 
-                            CloudControllerServiceIllegalArgumentExceptionException {		
-	    Registrant registrant = new Registrant();
-	    registrant.setClusterId(clusterId);
-	    registrant.setCartridgeType(cartridgeType);
-	    registrant.setTenantRange(tenantRange);
-	    registrant.setHostName(hostName);
-	    registrant.setProperties(properties);
-	    registrant.setPayload(payload);
-	    registrant.setAutoScalerPolicyName(autoscalorPolicyName);
-        registrant.setDeploymentPolicyName(deploymentPolicyName);
-		return stub.registerService(registrant);
-
-	}
-
-    @SuppressWarnings("unused")
-    private org.apache.stratos.cloud.controller.pojo.Properties
-        extractProperties(java.util.Properties properties) {
-        org.apache.stratos.cloud.controller.pojo.Properties props =
-                                                                 new org.apache.stratos.cloud.controller.pojo.Properties();
-        if (properties != null) {
-
-            for (Iterator iterator = properties.keySet().iterator(); iterator.hasNext();) {
-                String key = (String) iterator.next();
-                String value = properties.getProperty(key);
-
-                Property prop = new Property();
-                prop.setName(key);
-                prop.setValue(value);
-
-                props.addProperties(prop);
-
-            }
-        }
-        return props;
-    }
-
-    public void terminateAllInstances(String clusterId) throws Exception {
-		stub.terminateAllInstances(clusterId);
-	}
-
-	public String[] getRegisteredCartridges() throws Exception {
-		return stub.getRegisteredCartridges();
-	}
-
-    public CartridgeInfo getCartridgeInfo(String cartridgeType) throws UnregisteredCartridgeException, Exception {
-		try {
-			return stub.getCartridgeInfo(cartridgeType);
-		} catch (RemoteException e) {
-			throw e;
-		} catch (CloudControllerServiceUnregisteredCartridgeExceptionException e) {
-			throw new UnregisteredCartridgeException("Not a registered cartridge " + cartridgeType, cartridgeType, e);
-		}
-	}
-	
-	public void unregisterService(String clusterId) throws Exception {
-	    stub.unregisterService(clusterId);
-	}
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/RegistryClient.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/RegistryClient.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/RegistryClient.java
deleted file mode 100644
index 25c9b75..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/client/RegistryClient.java
+++ /dev/null
@@ -1,109 +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.adc.mgt.client;
-//
-//import org.apache.axis2.context.ConfigurationContext;
-//import org.apache.axis2.context.ConfigurationContextFactory;
-//import org.wso2.carbon.registry.core.Collection;
-//import org.wso2.carbon.registry.core.Registry;
-//import org.wso2.carbon.registry.core.Resource;
-//import org.wso2.carbon.registry.core.exceptions.RegistryException;
-//import org.wso2.carbon.registry.ws.client.registry.WSRegistryServiceClient;
-//
-//import java.util.ArrayList;
-//import java.util.List;
-//
-//public class RegistryClient {
-//
-//	// url where the repository is running its services interface
-//	private static String backendURL = "http://localhost:9763/services/";
-//	private static ConfigurationContext configContext = null;
-//
-//	// configuration locations used to bootstrap axis2
-//	private static String axis2Repo =
-//	                                  "/home/wso2/Desktop/HP-demo-packs-with-video/cartridge/wso2stratos-cartridge-1.0.0-SNAPSHOT/repository/conf/axis2";
-//	private static String axis2Conf =
-//	                                  "/home/wso2/Desktop/HP-demo-packs-with-video/cartridge/wso2stratos-cartridge-1.0.0-SNAPSHOT/repository/conf/axis2/axis2_client.xml";
-//	private static String serverURL = "https://localhost:9443/services/";
-//
-//	public RegistryClient() {
-//		// TODO Auto-generated constructor stub
-//	}
-//
-//	private static WSRegistryServiceClient initialize() throws Exception {
-//		// set these properties, this is used for authentication over https to
-//		// the registry
-//		// if you have a newer version, you can update the keystore by copying
-//		// it from
-//		// the security directory of the repository
-//		System.setProperty("javax.net.ssl.trustStore", "wso2carbon.jks");
-//		System.setProperty("javax.net.ssl.trustStorePassword", "wso2carbon");
-//		System.setProperty("javax.net.ssl.trustStoreType", "JKS");
-//
-//		configContext =
-//		                ConfigurationContextFactory.createConfigurationContextFromFileSystem(axis2Repo,
-//		                                                                                     axis2Conf);
-//		return new WSRegistryServiceClient(serverURL, "admin", "admin", backendURL, configContext);
-//	}
-//
-//	public static void addKey(String keyName, String content) throws Exception {
-//		Registry registry = initialize();
-//
-//		// get the governance folder
-//		Resource governanceFolder = registry.get("/_system/governance");
-//		System.out.println("Folder description: " + governanceFolder.getDescription());
-//		Resource r1 = registry.newResource();
-//		String path = "/_system/governance/" + keyName;
-//		r1.setContent(content);
-//		registry.put(path, r1);
-//
-//		/*
-//		 * List<Resource> paths = getServicePath(registry,
-//		 * "/_system/governance/trunk/services");
-//		 *
-//		 * for (Resource service : paths) { // we've got all the services here
-//		 *
-//		 * Properties props = service.getProperties(); for (Object prop :
-//		 * props.keySet()) { System.out.println(prop + " - " + props.get(prop));
-//		 * }
-//		 *
-//		 * Association[] associations =
-//		 * registry.getAssociations(service.getPath(), "Documentation"); for
-//		 * (Association association : associations) {
-//		 * System.out.println(association.getAssociationType()); } }
-//		 */
-//	}
-//
-//	private static List<Resource> getServicePath(Registry registry, String servicesResource)
-//	                                                                                        throws RegistryException {
-//		List<Resource> result = new ArrayList<Resource>();
-//		Resource resource = registry.get(servicesResource);
-//
-//		if (resource instanceof Collection) {
-//			Object content = resource.getContent();
-//			for (Object path : (Object[]) content) {
-//				result.addAll(getServicePath(registry, (String) path));
-//			}
-//		} else if (resource instanceof Resource) {
-//			result.add(resource);
-//		}
-//		return result;
-//	}
-//}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnector.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnector.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnector.java
deleted file mode 100644
index 63ea720..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnector.java
+++ /dev/null
@@ -1,45 +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.adc.mgt.connector;
-
-import org.apache.stratos.adc.mgt.exception.ADCException;
-import org.apache.stratos.adc.mgt.subscription.CartridgeSubscription;
-
-import java.util.Properties;
-
-public abstract class CartridgeSubscriptionConnector {
-
-    /**
-     * Connects two CartridgeSubscription instances
-     *
-     * @param cartridgeSubscription CartridgeSubscription subscription
-     * @param connectingCartridgeSubscription CartridgeSubscription subscription that is connecting with cartridgeSubscription
-     *
-     * @return Custom properties for the connection as a key value set
-     * @throws ADCException in case of an error
-     */
-    public abstract Properties createConnection (CartridgeSubscription cartridgeSubscription,
-                                                 CartridgeSubscription connectingCartridgeSubscription)
-            throws ADCException;
-
-    public abstract Properties teminateConnection (CartridgeSubscription cartridgeSubscription,
-                                                   CartridgeSubscription connectedCartridgeSubscription)
-            throws ADCException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnectorFactory.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnectorFactory.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnectorFactory.java
deleted file mode 100644
index bc31c0f..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/CartridgeSubscriptionConnectorFactory.java
+++ /dev/null
@@ -1,41 +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.adc.mgt.connector;
-
-import org.apache.stratos.adc.mgt.connector.data.DataCartridgeSubscriptionConnector;
-import org.apache.stratos.adc.mgt.exception.ADCException;
-
-public class CartridgeSubscriptionConnectorFactory {
-
-    public static CartridgeSubscriptionConnector getCartridgeInstanceConnector (String type) throws ADCException {
-
-        CartridgeSubscriptionConnector cartridgeSubscriptionConnector = null;
-
-        if(type.equals("mysql")) {
-            cartridgeSubscriptionConnector = new DataCartridgeSubscriptionConnector();
-        }
-
-        if(cartridgeSubscriptionConnector == null) {
-            throw new ADCException("Unable to find matching CartridgeSubscriptionConnector for " + type);
-        }
-
-        return cartridgeSubscriptionConnector;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/data/DataCartridgeSubscriptionConnector.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/data/DataCartridgeSubscriptionConnector.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/data/DataCartridgeSubscriptionConnector.java
deleted file mode 100644
index cc3d687..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/connector/data/DataCartridgeSubscriptionConnector.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.adc.mgt.connector.data;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.adc.mgt.connector.CartridgeSubscriptionConnector;
-import org.apache.stratos.adc.mgt.dto.Cartridge;
-import org.apache.stratos.adc.mgt.exception.ADCException;
-import org.apache.stratos.adc.mgt.exception.NotSubscribedException;
-import org.apache.stratos.adc.mgt.subscription.CartridgeSubscription;
-import org.apache.stratos.adc.mgt.utils.ApplicationManagementUtil;
-import org.apache.stratos.adc.mgt.utils.CartridgeConstants;
-
-import java.util.Properties;
-
-public class DataCartridgeSubscriptionConnector extends CartridgeSubscriptionConnector {
-
-    private static Log log = LogFactory.getLog(DataCartridgeSubscriptionConnector.class);
-
-    @Override
-    public Properties createConnection(CartridgeSubscription cartridgeSubscription,
-                                       CartridgeSubscription connectingCartridgeSubscription) throws ADCException {
-
-        //TODO: change the logic to do with topology information
-        log.info("Retrieving cartridge information for connecting ... alias : " +
-                connectingCartridgeSubscription.getAlias() + ", Type: " + connectingCartridgeSubscription.getType());
-
-        Properties connectionProperties = new Properties();
-
-        int maxAttempts = Integer.parseInt(System.getProperty(CartridgeConstants.MAX_ATTEMPTS, "50"));
-        int attempts = 0;
-        while (attempts < maxAttempts) {
-            attempts++;
-            Cartridge cartridge = null;
-            try {
-                cartridge = ApplicationManagementUtil.getCartridgeInfo(
-                        connectingCartridgeSubscription.getAlias(),
-                        connectingCartridgeSubscription.getSubscriber().getTenantDomain());
-
-            } catch (NotSubscribedException e) {
-                // This cannot happen here.
-            }
-            if (cartridge != null) {
-                /*if (!cartridge.getStatus().equals("ACTIVE")) {
-                    try {
-                        Thread.sleep(3000);
-                    } catch (InterruptedException ignore) {
-                    }
-                } else {
-                    connectionProperties.setProperty("MYSQL_HOST", cartridge.getIp());
-                    connectionProperties.setProperty("MYSQL_USER", cartridge.getDbUserName());
-                    connectionProperties.setProperty("MYSQL_PASSWORD", cartridge.getPassword());
-                    log.info("Connection information retrieved for " + cartridgeSubscription + " and " +
-                            connectingCartridgeSubscription);
-                    break;
-                }*/
-            }
-
-            if(attempts == maxAttempts) {
-                String errorMsg = "Failed to connect " + cartridgeSubscription + " and " + connectingCartridgeSubscription;
-                log.error(errorMsg);
-                throw  new ADCException(errorMsg);
-            }
-        }
-
-        return connectionProperties;
-    }
-
-    @Override
-    public Properties teminateConnection(CartridgeSubscription cartridgeSubscription,
-                                         CartridgeSubscription connectedCartridgeSubscription) throws ADCException {
-        return null;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/custom/domain/RegistryManager.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/custom/domain/RegistryManager.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/custom/domain/RegistryManager.java
deleted file mode 100644
index 6eb28f3..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/custom/domain/RegistryManager.java
+++ /dev/null
@@ -1,109 +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.adc.mgt.custom.domain;
-//
-//import org.apache.commons.logging.Log;
-//import org.apache.commons.logging.LogFactory;
-//import org.apache.stratos.adc.mgt.exception.ADCException;
-//import org.apache.stratos.adc.mgt.exception.DomainMappingExistsException;
-//import org.apache.stratos.adc.mgt.internal.DataHolder;
-//import org.apache.stratos.adc.mgt.utils.CartridgeConstants;
-//import org.wso2.carbon.registry.core.Collection;
-//import org.wso2.carbon.registry.core.Registry;
-//import org.wso2.carbon.registry.core.Resource;
-//import org.wso2.carbon.registry.core.exceptions.RegistryException;
-//
-//public class RegistryManager {
-//	private static Log log = LogFactory.getLog(RegistryManager.class);
-//	private static Registry registry = DataHolder.getRegistryService();
-//
-//	public RegistryManager() {
-//		try {
-//			if (!registry.resourceExists(CartridgeConstants.DomainMappingInfo.HOSTINFO)) {
-//				registry.put(CartridgeConstants.DomainMappingInfo.HOSTINFO,
-//				                    registry.newCollection());
-//			}
-//		} catch (RegistryException e) {
-//			String msg =
-//			             "Error while accessing registry or initializing domain mapping registry path\n";
-//			log.error(msg + e.getMessage());
-//		}
-//	}
-//
-//	/**
-//    *
-//    */
-//    public void addDomainMappingToRegistry(String hostName, String actualHost)
-//            throws ADCException, RegistryException, DomainMappingExistsException {
-//        try {
-//            registry.beginTransaction();
-//            Resource hostResource = registry.newResource();
-//            hostResource.addProperty(CartridgeConstants.DomainMappingInfo.ACTUAL_HOST, actualHost);
-//            if (!registry.resourceExists(CartridgeConstants.DomainMappingInfo.HOSTINFO +
-//                                                hostName)) {
-//                registry.put(CartridgeConstants.DomainMappingInfo.HOSTINFO + hostName,
-//                                    hostResource);
-//            } else {
-//                registry.rollbackTransaction();
-//                String msg = "Requested domain is already taken!";
-//                log.error(msg);
-//                throw new DomainMappingExistsException(msg, hostName);
-//            }
-//            registry.commitTransaction();
-//        } catch (RegistryException e) {
-//            registry.rollbackTransaction();
-//            throw e;
-//        }
-//    }
-//
-//
-//    /**
-//        *
-//        */
-//   	public void removeDomainMappingFromRegistry(String actualHost) throws Exception {
-//   		try {
-//               registry.beginTransaction();
-//                String hostResourcePath = CartridgeConstants.DomainMappingInfo.HOSTINFO;
-//                if (registry.resourceExists(hostResourcePath)) {
-//                    Resource hostResource = registry.get(hostResourcePath);
-//                    Collection hostInfoCollection;
-//                    if(hostResource instanceof Collection){
-//                        hostInfoCollection = (Collection) hostResource;
-//                    } else {
-//                        throw new Exception("Resource is not a collection " + hostResourcePath );
-//                    }
-//                    String[] paths = hostInfoCollection.getChildren();
-//                    for (String path: paths){
-//                        Resource domainMapping = registry.get(path);
-//                        String actualHostInRegistry = domainMapping.getProperty(CartridgeConstants.DomainMappingInfo.ACTUAL_HOST);
-//                        if(actualHostInRegistry != null && actualHost.equalsIgnoreCase(actualHostInRegistry)){
-//                            registry.delete(path);
-//                        }
-//                    }
-//                }
-//                registry.commitTransaction();
-//   		} catch (RegistryException e) {
-//   			registry.rollbackTransaction();
-//   			log.error("Unable to remove the mapping", e);
-//   			throw e;
-//   		}
-//   	}
-//
-//}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/CartridgeSubscriptionInfo.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/CartridgeSubscriptionInfo.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/CartridgeSubscriptionInfo.java
deleted file mode 100644
index 6addf8a..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/CartridgeSubscriptionInfo.java
+++ /dev/null
@@ -1,200 +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.adc.mgt.dao;
-
-import org.apache.stratos.adc.mgt.repository.Repository;
-
-import java.util.List;
-
-public class CartridgeSubscriptionInfo {
-
-	private int subscriptionId;
-	private int tenantId;
-	private String cartridge;
-	private String provider;
-	private String hostName;
-	private String policy;
-	private List<PortMapping> portMappings;
-	private String clusterDomain;
-	private String clusterSubdomain;
-	private Repository repository;
-	private String state;
-	private String alias;
-	private String tenantDomain;
-	private DataCartridge dataCartridge;
-	private String baseDirectory;
-	private String mappedDomain;
-	private String mgtClusterDomain;
-	private String mgtClusterSubDomain;
-	private String subscriptionKey;
-
-	public int getSubscriptionId() {
-		return subscriptionId;
-	}
-
-	public void setSubscriptionId(int subscriptionId) {
-		this.subscriptionId = subscriptionId;
-	}
-
-	public int getTenantId() {
-		return tenantId;
-	}
-
-	public void setTenantId(int tenantId) {
-		this.tenantId = tenantId;
-	}
-
-	public String getCartridge() {
-		return cartridge;
-	}
-
-	public void setCartridge(String cartridge) {
-		this.cartridge = cartridge;
-	}
-
-	public String getProvider() {
-		return provider;
-	}
-
-	public void setProvider(String provider) {
-		this.provider = provider;
-	}
-
-	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 List<PortMapping> getPortMappings() {
-		return portMappings;
-	}
-
-	public void setPortMappings(List<PortMapping> portMappings) {
-		this.portMappings = portMappings;
-	}
-
-	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 Repository getRepository() {
-		return repository;
-	}
-
-	public void setRepository(Repository repository) {
-		this.repository = repository;
-	}
-
-	public String getState() {
-		return state;
-	}
-
-	public void setState(String state) {
-		this.state = state;
-	}
-
-	public String getAlias() {
-		return alias;
-	}
-
-	public void setAlias(String alias) {
-		this.alias = alias;
-	}
-
-	public String getTenantDomain() {
-		return tenantDomain;
-	}
-
-	public void setTenantDomain(String tenantDomain) {
-		this.tenantDomain = tenantDomain;
-	}
-
-	public DataCartridge getDataCartridge() {
-		return dataCartridge;
-	}
-
-	public void setDataCartridge(DataCartridge dataCartridge) {
-		this.dataCartridge = dataCartridge;
-	}
-
-	public String getBaseDirectory() {
-		return baseDirectory;
-	}
-
-	public void setBaseDirectory(String baseDirectory) {
-		this.baseDirectory = baseDirectory;
-	}
-
-	public String getMappedDomain() {
-		return mappedDomain;
-	}
-
-	public void setMappedDomain(String mappedDomain) {
-		this.mappedDomain = mappedDomain;
-	}
-
-	public String getMgtClusterDomain() {
-		return mgtClusterDomain;
-	}
-
-	public void setMgtClusterDomain(String mgtClusterDomain) {
-		this.mgtClusterDomain = mgtClusterDomain;
-	}
-
-	public String getMgtClusterSubDomain() {
-		return mgtClusterSubDomain;
-	}
-
-	public void setMgtClusterSubDomain(String mgtClusterSubDomain) {
-		this.mgtClusterSubDomain = mgtClusterSubDomain;
-	}
-
-	public String getSubscriptionKey() {
-		return subscriptionKey;
-	}
-
-	public void setSubscriptionKey(String subscriptionKey) {
-		this.subscriptionKey = subscriptionKey;
-	}	
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/Cluster.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/Cluster.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/Cluster.java
deleted file mode 100644
index 18f6f37..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/Cluster.java
+++ /dev/null
@@ -1,77 +0,0 @@
-package org.apache.stratos.adc.mgt.dao;
-
-import java.io.Serializable;
-
-public class Cluster implements Serializable {
-
-    private int id;
-    private String clusterDomain;
-    private String clusterSubDomain;
-    private String mgtClusterDomain;
-    private String mgtClusterSubDomain;
-    private String hostName;
-    private String serviceStatus;
-
-    public Cluster() {
-    }
-
-    public String getHostName() {
-        return hostName;
-    }
-
-    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 getMgtClusterDomain() {
-        return mgtClusterDomain;
-    }
-
-    public void setMgtClusterDomain(String mgtClusterDomain) {
-        this.mgtClusterDomain = mgtClusterDomain;
-    }
-
-    public String getMgtClusterSubDomain() {
-        return mgtClusterSubDomain;
-    }
-
-    public void setMgtClusterSubDomain(String mgtClusterSubDomain) {
-        this.mgtClusterSubDomain = mgtClusterSubDomain;
-    }
-
-    public void setHostName(String hostName) {
-        this.hostName = hostName;
-    }
-
-    public int getId() {
-        return id;
-    }
-
-    public void setId(int id) {
-        this.id = id;
-    }
-
-    public String getServiceStatus() {
-        return serviceStatus;
-    }
-
-    public void setServiceStatus(String serviceStatus) {
-        this.serviceStatus = serviceStatus;
-    }
-
-    public String toString () {
-        return clusterDomain;
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/DataCartridge.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/DataCartridge.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/DataCartridge.java
deleted file mode 100644
index 25ace7a..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/DataCartridge.java
+++ /dev/null
@@ -1,62 +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.adc.mgt.dao;
-
-public class DataCartridge {
-
-	private int id;
-	private String dataCartridgeType;
-    private String host;
-	private String userName;
-	private String password;
-
-	public int getId() {
-    	return id;
-    }
-	public void setId(int id) {
-    	this.id = id;
-    }
-	public String getDataCartridgeType() {
-    	return dataCartridgeType;
-    }
-	public void setDataCartridgeType(String dataCartridgeType) {
-    	this.dataCartridgeType = dataCartridgeType;
-    }
-	public String getUserName() {
-    	return userName;
-    }
-	public void setUserName(String userName) {
-    	this.userName = userName;
-    }
-	public String getPassword() {
-    	return password;
-    }
-	public void setPassword(String password) {
-    	this.password = password;
-    }
-
-    public String getHost() {
-        return host;
-    }
-
-    public void setHost(String host) {
-        this.host = host;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/PortMapping.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/PortMapping.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/PortMapping.java
deleted file mode 100644
index d0346ec..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/PortMapping.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.adc.mgt.dao;
-
-public class PortMapping {
-	private int id;
-	private String type;
-	private String primaryPort;
-	private String proxyPort;
-
-	public int getId() {
-		return id;
-	}
-
-	public void setId(int id) {
-		this.id = id;
-	}
-
-	public String getType() {
-		return type;
-	}
-
-	public void setType(String type) {
-		this.type = type;
-	}
-
-	public String getPrimaryPort() {
-		return primaryPort;
-	}
-
-	public void setPrimaryPort(String primaryPort) {
-		this.primaryPort = primaryPort;
-	}
-
-	public String getProxyPort() {
-		return proxyPort;
-	}
-
-	public void setProxyPort(String proxyPort) {
-		this.proxyPort = proxyPort;
-	}
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/RepositoryCredentials.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/RepositoryCredentials.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/RepositoryCredentials.java
deleted file mode 100644
index 7fba8d0..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/dao/RepositoryCredentials.java
+++ /dev/null
@@ -1,48 +0,0 @@
-package org.apache.stratos.adc.mgt.dao;
-/*
- *
- * 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 RepositoryCredentials {
-
-	private String url;
-	private String userName;
-	private String password;
-	public String getUrl() {
-    	return url;
-    }
-	public void setUrl(String url) {
-    	this.url = url;
-    }
-	public String getUserName() {
-    	return userName;
-    }
-	public void setUserName(String userName) {
-    	this.userName = userName;
-    }
-	public String getPassword() {
-    	return password;
-    }
-	public void setPassword(String password) {
-    	this.password = password;
-    }
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/9f74f29c/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/deploy/service/Service.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/deploy/service/Service.java b/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/deploy/service/Service.java
deleted file mode 100644
index d5b6597..0000000
--- a/components/org.apache.stratos.adc.mgt/src/main/java/org/apache/stratos/adc/mgt/deploy/service/Service.java
+++ /dev/null
@@ -1,138 +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.adc.mgt.deploy.service;
-
-import org.apache.stratos.adc.mgt.exception.ADCException;
-import org.apache.stratos.adc.mgt.exception.UnregisteredCartridgeException;
-import org.apache.stratos.adc.mgt.payload.PayloadData;
-import org.apache.stratos.adc.mgt.subscription.utils.CartridgeSubscriptionUtils;
-import org.apache.stratos.cloud.controller.pojo.CartridgeInfo;
-
-import java.io.Serializable;
-
-public abstract class Service implements Serializable {
-
-    private String type;
-    private String autoscalingPolicyName;
-    private String deploymentPolicyName;
-    private String tenantRange;
-    private String clusterId;
-    private String hostName;
-    private int tenantId;
-    private String subscriptionKey;
-    private CartridgeInfo cartridgeInfo;
-    private PayloadData payloadData;
-
-    public Service (String type, String autoscalingPolicyName, String deploymentPolicyName, int tenantId, CartridgeInfo cartridgeInfo,
-    		String tenantRange) {
-
-        this.type = type;
-        this.autoscalingPolicyName = autoscalingPolicyName;
-        this.deploymentPolicyName = deploymentPolicyName;
-        this.tenantId = tenantId;
-        this.cartridgeInfo = cartridgeInfo;
-        this.tenantRange = tenantRange;
-        this.subscriptionKey = CartridgeSubscriptionUtils.generateSubscriptionKey();
-    }
-
-    public abstract void deploy () throws ADCException, UnregisteredCartridgeException;
-
-    public abstract void undeploy (String clusterId) throws ADCException;
-
-    public String getType() {
-        return type;
-    }
-
-    public void setType(String type) {
-        this.type = type;
-    }
-
-    public String getAutoscalingPolicyName() {
-        return autoscalingPolicyName;
-    }
-
-    public void setAutoscalingPolicyName(String autoscalingPolicyName) {
-        this.autoscalingPolicyName = autoscalingPolicyName;
-    }
-
-    public String getDeploymentPolicyName() {
-        return deploymentPolicyName;
-    }
-
-    public void setDeploymentPolicyName(String deploymentPolicyName) {
-        this.deploymentPolicyName = deploymentPolicyName;
-    }
-
-    public String getTenantRange() {
-        return tenantRange;
-    }
-
-    public void setTenantRange(String tenantRange) {
-        this.tenantRange = tenantRange;
-    }
-
-    public String getClusterId() {
-        return clusterId;
-    }
-
-    public void setClusterId(String clusterId) {
-        this.clusterId = clusterId;
-    }
-
-    public String getHostName() {
-        return hostName;
-    }
-
-    public void setHostName(String hostName) {
-        this.hostName = hostName;
-    }
-
-    public int getTenantId() {
-        return tenantId;
-    }
-
-    public void setTenantId(int tenantId) {
-        this.tenantId = tenantId;
-    }
-
-    public CartridgeInfo getCartridgeInfo() {
-        return cartridgeInfo;
-    }
-
-    public void setCartridgeInfo(CartridgeInfo cartridgeInfo) {
-        this.cartridgeInfo = cartridgeInfo;
-    }
-
-    public String getSubscriptionKey() {
-        return subscriptionKey;
-    }
-
-    public void setSubscriptionKey(String subscriptionKey) {
-        this.subscriptionKey = subscriptionKey;
-    }
-
-    public PayloadData getPayloadData() {
-        return payloadData;
-    }
-
-    public void setPayloadData(PayloadData payloadData) {
-        this.payloadData = payloadData;
-    }
-}