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 10:51:30 UTC

[3/3] git commit: including the messaging feature in SM

including the messaging feature in SM


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

Branch: refs/heads/master
Commit: 24086e311e9e999ad734c5f44684c661ee97020b
Parents: d19a6c2
Author: Isuru <is...@apache.org>
Authored: Wed Jan 8 09:43:47 2014 +0000
Committer: Isuru <is...@apache.org>
Committed: Wed Jan 8 09:43:47 2014 +0000

----------------------------------------------------------------------
 .../org.apache.stratos.adc.topology.mgt/pom.xml | 134 -----------
 .../mgt/exception/TopologyMgtException.java     |  38 ----
 .../mgt/internal/TopologyMgtDSComponent.java    |  95 --------
 .../mgt/service/TopologyManagementService.java  |  72 ------
 .../impl/TopologyManagementServiceImpl.java     |  89 --------
 .../mgt/serviceobjects/DomainContext.java       |  93 --------
 .../adc/topology/mgt/util/ConfigHolder.java     | 147 -------------
 .../topology/mgt/util/TopologyConstants.java    |  28 ---
 .../src/main/resources/META-INF/services.xml    |  31 ---
 components/pom.xml                              |   1 -
 .../pom.xml                                     |  83 -------
 .../org.apache.stratos.manager.feature/pom.xml  |   9 +-
 features/manager/stratos-mgt/pom.xml            |   1 -
 .../modules/p2-profile-gen/pom.xml              |   8 +
 .../pom.xml                                     | 116 ----------
 .../src/main/resources/TopologyMgtService.wsdl  | 220 -------------------
 service-stubs/pom.xml                           |   1 -
 17 files changed, 9 insertions(+), 1157 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/pom.xml
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/pom.xml b/components/org.apache.stratos.adc.topology.mgt/pom.xml
deleted file mode 100644
index 2efaa3a..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/pom.xml
+++ /dev/null
@@ -1,134 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
-       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.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-    <parent>
-        <groupId>org.apache.stratos</groupId>
-        <artifactId>stratos-components-parent</artifactId>
-        <version>4.0.0-SNAPSHOT</version>
-    </parent>
-
-    <modelVersion>4.0.0</modelVersion>
-    <groupId>org.apache.stratos</groupId>
-    <artifactId>org.apache.stratos.adc.topology.mgt</artifactId>
-    <packaging>bundle</packaging>
-    <name>Apache Stratos - Topology Management</name>
-    <url>http://apache.org</url>
-    
-    <dependencies>
-        <!-- <dependency>
-            <groupId>org.wso2.carbon</groupId>
-            <artifactId>org.wso2.carbon.mediation.initializer</artifactId>
-            <version>${wso2carbon.version}</version>
-        </dependency> -->
-        <!-- <dependency>
-            <groupId>org.wso2.carbon</groupId>
-            <artifactId>org.wso2.carbon.mediation.dependency.mgt</artifactId>
-            <version>${wso2carbon.version}</version>
-        </dependency> -->
-        <dependency>
-            <groupId>org.apache.synapse</groupId>
-            <artifactId>synapse-core</artifactId>
-            <version>${synapse.core.version}</version>
-        </dependency>
-         <dependency>
-            <groupId>org.apache.axis2.wso2</groupId>
-            <artifactId>axis2</artifactId>
-            <version>1.6.1.wso2v9</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.axis2</groupId>
-            <artifactId>axis2-kernel</artifactId>
-            <version>${axis2.kernel.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.wso2.carbon</groupId>
-            <artifactId>org.wso2.carbon.logging</artifactId>
-	    <version>${wso2carbon.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.wso2.carbon</groupId>
-            <artifactId>org.wso2.carbon.utils</artifactId>
-            <version>${wso2carbon.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.wso2.carbon</groupId>
-            <artifactId>org.wso2.carbon.core</artifactId>
-            <version>${wso2carbon.version}</version>
-        </dependency>
-        <dependency>
-            <groupId>org.wso2.carbon</groupId>
-            <artifactId>org.wso2.carbon.ntask.core</artifactId>
-	    <version>${wso2carbon.version}</version>
-        </dependency>
-        <dependency>
-                <groupId>org.wso2.andes.wso2</groupId>
-                <artifactId>andes-client</artifactId>
-                <version>0.13.wso2v3</version>
-            </dependency>
-        <dependency>
-                <groupId>org.apache.geronimo.specs.wso2</groupId>
-                <artifactId>geronimo-jms_1.1_spec</artifactId>
-                <version>${orbit.version.geronimo-jms_1.1_spec}</version>
-            </dependency>
-        <dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.messaging</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-    </dependencies>
-
-    <build>
-        <plugins>
-
-            <plugin>
-                <groupId>org.apache.felix</groupId>
-                <artifactId>maven-scr-plugin</artifactId>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.felix</groupId>
-                <artifactId>maven-bundle-plugin</artifactId>
-
-                <extensions>true</extensions>
-                <configuration>
-                    <instructions>
-                        <Bundle-SymbolicName>${project.artifactId}</Bundle-SymbolicName>
-                        <Bundle-Name>${project.artifactId}</Bundle-Name>
-                        <!-- <Private-Package>
-                        	org.wso2.carbon.stratos.topology.mgt.service.impl.*
-                        </Private-Package> -->
-                        <Export-Package>
-                            org.apache.stratos.adc.topology.mgt.subscriber.*,
-                            org.apache.stratos.adc.topology.mgt.service.*,
-                            org.apache.stratos.adc.topology.mgt.group.mgt.*,
-							org.apache.stratos.adc.topology.mgt.serviceobjects.*
-                        </Export-Package>
-                        <Import-Package>
-                            org.wso2.carbon.registry.core.service; version=1.0.1,
-                            *;resolution:=optional
-                        </Import-Package>
-                        <DynamicImport-Package>*</DynamicImport-Package>
-                    </instructions>
-                </configuration>
-            </plugin>
-        </plugins>
-    </build>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/exception/TopologyMgtException.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/exception/TopologyMgtException.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/exception/TopologyMgtException.java
deleted file mode 100644
index 024eeb4..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/exception/TopologyMgtException.java
+++ /dev/null
@@ -1,38 +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.topology.mgt.exception;
-
-public class TopologyMgtException extends RuntimeException {
-
-    private static final long serialVersionUID = -663839410798538370L;
-
-    public TopologyMgtException(String msg) {
-        super(msg);
-    }
-
-    public TopologyMgtException(String msg, Throwable cause) {
-        super(msg, cause);
-    }
-
-    public TopologyMgtException(Throwable cause) {
-        super(cause);
-    }
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/internal/TopologyMgtDSComponent.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/internal/TopologyMgtDSComponent.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/internal/TopologyMgtDSComponent.java
deleted file mode 100644
index b4573d0..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/internal/TopologyMgtDSComponent.java
+++ /dev/null
@@ -1,95 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one 
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY 
- * KIND, either express or implied.  See the License for the 
- * specific language governing permissions and limitations
- * under the License.
- */
-
-package org.apache.stratos.adc.topology.mgt.internal;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.adc.topology.mgt.service.TopologyManagementService;
-import org.apache.stratos.adc.topology.mgt.service.impl.TopologyManagementServiceImpl;
-import org.apache.stratos.adc.topology.mgt.util.ConfigHolder;
-import org.apache.stratos.messaging.broker.subscribe.TopicSubscriber;
-import org.apache.stratos.messaging.message.receiver.topology.TopologyEventMessageDelegator;
-import org.apache.stratos.messaging.message.receiver.topology.TopologyEventMessageListener;
-import org.apache.stratos.messaging.util.Constants;
-import org.osgi.framework.BundleContext;
-import org.osgi.service.component.ComponentContext;
-import org.wso2.carbon.ntask.core.service.TaskService;
-import org.wso2.carbon.utils.ConfigurationContextService;
-
-/**
- * @scr.component name="topology.mgt.service" immediate="true"
- * @scr.reference name="configuration.context.service"
- * interface="org.wso2.carbon.utils.ConfigurationContextService" cardinality="1..1"
- * policy="dynamic" bind="setConfigurationContextService" unbind="unsetConfigurationContextService"
- * @scr.reference name="ntask.component" interface="org.wso2.carbon.ntask.core.service.TaskService"
- * cardinality="1..1" policy="dynamic" bind="setTaskService" unbind="unsetTaskService"
- */
-public class TopologyMgtDSComponent {
-
-    private static final Log log = LogFactory.getLog(TopologyMgtDSComponent.class);
-
-    protected void activate(ComponentContext ctxt) {
-		try {
-            // Start topic subscriber thread
-            TopicSubscriber topicSubscriber = new TopicSubscriber(Constants.TOPOLOGY_TOPIC);
-            topicSubscriber.setMessageListener(new TopologyEventMessageListener());
-            Thread subscriberThread = new Thread(topicSubscriber);
-            subscriberThread.start();
-            if (log.isDebugEnabled()) {
-                log.debug("Topology event message receiver thread started");
-            }
-
-            // Start topology message receiver thread
-            Thread receiverThread = new Thread(new TopologyEventMessageDelegator());
-            receiverThread.start();
-            if (log.isDebugEnabled()) {
-                log.debug("Topology message processor thread started");
-            }
-
-			BundleContext bundleContext = ctxt.getBundleContext();
-			bundleContext.registerService(
-					TopologyManagementService.class.getName(),
-					new TopologyManagementServiceImpl(), null);
-
-			log.debug("******* Topology Mgt Service bundle is activated ******* ");
-		} catch (Throwable e) {
-            log.error("******* Topology Mgt Service Service bundle is failed to activate ****", e);
-        }
-    }
-
-    protected void deactivate(ComponentContext context) {}
-
-    protected void setConfigurationContextService(ConfigurationContextService cfgCtxService) {
-        ConfigHolder.getInstance().setAxisConfiguration(
-                cfgCtxService.getServerConfigContext().getAxisConfiguration());
-    }
-
-    protected void unsetConfigurationContextService(ConfigurationContextService cfgCtxService) {
-        ConfigHolder.getInstance().setAxisConfiguration(null);
-    }
-    
-    protected void setTaskService(TaskService taskService) {
-        ConfigHolder.getInstance().setTaskService(taskService);
-    }
-
-    protected void unsetTaskService(TaskService taskService) {
-        ConfigHolder.getInstance().setTaskService(null);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/TopologyManagementService.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/TopologyManagementService.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/TopologyManagementService.java
deleted file mode 100644
index 55f69ed..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/TopologyManagementService.java
+++ /dev/null
@@ -1,72 +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.topology.mgt.service;
-
-import org.apache.stratos.adc.topology.mgt.serviceobjects.DomainContext;
-
-/**
- * This exposes details regarding up-to-date topology
- *
- */
-public interface TopologyManagementService {
-
-	/**
-	 * Provide service cluster domains corresponds to the given information.
-	 * @param cartridgeType cartridge type
-	 * @param tenantId tenant id
-	 * @return String array of service cluster domains
-	 */
-	String[] getDomains(String cartridgeType, int tenantId);
-
-	/**
-	 * Provide service cluster sub domains corresponds to the given information.
-	 * @param cartridgeType cartridge type
-	 * @param tenantId tenant id
-	 * @return String array of service cluster sub domains
-	 */
-	String[] getSubDomains(String cartridgeType, int tenantId);
-
-//	/**
-//	 * Provide public IPs corresponds to the given information.
-//	 * @param cartridgeType cartridge type
-//	 * @param tenantId tenant id
-//	 * @return String array of public IPs
-//	 */
-//	String[] getActiveIPs(String cartridgeType, int tenantId);
-	
-	/**
-	 * Provide public IPs corresponds to the given information.
-	 * @param cartridgeType cartridge type
-	 * @param domain service cluster domain
-	 * @param subDomain service cluster sub domain
-	 * @return String array of public IPs
-	 */
-	String[] getActiveIPs(String cartridgeType, String domain, String subDomain);
-	
-	/**
-	 * Provide domains and the relevant subdomains corresponding to the given information
-	 * 
-	 * @param cartridgeType cartridge type
-	 * @param tenantId tenant id
-	 * @return DomainContext instances array of domains and sub domains 
-	 */
-	DomainContext[] getDomainsAndSubdomains (String cartridgeType, int tenantId);
-	
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/impl/TopologyManagementServiceImpl.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/impl/TopologyManagementServiceImpl.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/impl/TopologyManagementServiceImpl.java
deleted file mode 100644
index c623e3c..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/service/impl/TopologyManagementServiceImpl.java
+++ /dev/null
@@ -1,89 +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.topology.mgt.service.impl;
-
-import org.apache.stratos.adc.topology.mgt.service.TopologyManagementService;
-import org.apache.stratos.adc.topology.mgt.serviceobjects.DomainContext;
-import org.apache.stratos.messaging.domain.topology.Cluster;
-import org.apache.stratos.messaging.domain.topology.Member;
-import org.apache.stratos.messaging.domain.topology.Service;
-import org.apache.stratos.messaging.message.receiver.topology.TopologyManager;
-
-import java.util.ArrayList;
-import java.util.List;
-
-public class TopologyManagementServiceImpl implements TopologyManagementService {
-
-    public String[] getDomains(String cartridgeType, int tenantId) {
-        List<String> domains = new ArrayList<String>();
-        try {
-            TopologyManager.acquireReadLock();
-            for (Service service : TopologyManager.getTopology().getServices()) {
-                for (Cluster cluster : service.getClusters()) {
-                    domains.add(cluster.getClusterId());
-                }
-            }
-        } finally {
-            TopologyManager.releaseReadLock();
-        }
-        return domains.toArray(new String[domains.size()]);
-    }
-
-    public String[] getSubDomains(String cartridgeType, int tenantId) {
-        List<String> subDomains = new ArrayList<String>();
-        // TODO Should be able to remove
-        return subDomains.toArray(new String[subDomains.size()]);
-    }
-
-    public String[] getActiveIPs(String cartridgeType, String domain, String subDomain) {
-        List<String> publicIps = new ArrayList<String>();
-
-        if (domain == null || subDomain == null) {
-            return new String[0];
-        }
-
-        try {
-            TopologyManager.acquireReadLock();
-            for (Service service : TopologyManager.getTopology().getServices()) {
-                for (Cluster cluster : service.getClusters()) {
-                    if (domain.equals(cluster.getClusterId())) {
-                        for (Member member : cluster.getMembers()) {
-                            if (member.isActive()) {
-                                publicIps.add(member.getMemberIp());
-                            }
-                        }
-                    }
-                }
-            }
-        } finally {
-            TopologyManager.releaseReadLock();
-        }
-        return publicIps.toArray(new String[publicIps.size()]);
-    }
-
-    /* (non-Javadoc)
-     * @see org.wso2.carbon.stratos.topology.mgt.service.TopologyManagementService#getDomainsAndSubdomains(java.lang.String, int)
-     */
-    public DomainContext[] getDomainsAndSubdomains(String cartridgeType, int tenantId) {
-        List<DomainContext> domainContexts = new ArrayList<DomainContext>();
-        // TODO Should be able to remove
-        return domainContexts.toArray(new DomainContext[domainContexts.size()]);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/serviceobjects/DomainContext.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/serviceobjects/DomainContext.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/serviceobjects/DomainContext.java
deleted file mode 100644
index 912a527..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/serviceobjects/DomainContext.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.adc.topology.mgt.serviceobjects;
-
-/**
- * Class to hold domain and subdomain details
- *
- */
-public class DomainContext {
-    
-    private String domain;
-    private String subDomain;
-    
-    /**
-     * Constructor
-     * 
-     * @param domain domain name
-     * @param subDomain subdomain name
-     */
-    public DomainContext (String domain, String subDomain) {
-        this.domain = domain;
-        this.subDomain = subDomain;
-    }
-
-    /**
-     * Returns the domain 
-     * 
-     * @return the domain
-     */
-    public String getDomain() {
-        return domain;
-    }
-
-    /**
-     * Returns the sub domain
-     * 
-     * @return the subDomain
-     */
-    public String getSubDomain() {
-        return subDomain;
-    }
-    
-    /**
-     * Overridden equals method
-     */
-    public boolean equals (Object object) {
-        if (object == null) 
-            return false;
-        if (object == this)  
-            return true;
-        if (!(object instanceof DomainContext))
-            return false;
-        
-        DomainContext domainCtx = (DomainContext)object;
-        if(this.getDomain().equals(domainCtx.getDomain()) &&
-                this.getSubDomain().equals(domainCtx.getSubDomain()))
-            return true;
-        else
-            return false;
-    }
-    
-    /**
-     * Overridden hashCode method
-     */
-    public int hashCode () {
-        int domainHash = 0;
-        int subDomainHash = 0;
-        
-        if(domain != null)
-            domainHash = domain.hashCode();
-        if(subDomain != null)
-            subDomainHash = subDomain.hashCode();
-        
-        return domainHash + subDomainHash;
-    }
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/ConfigHolder.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/ConfigHolder.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/ConfigHolder.java
deleted file mode 100644
index e04308d..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/ConfigHolder.java
+++ /dev/null
@@ -1,147 +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.topology.mgt.util;
-
-import org.apache.axis2.context.ConfigurationContext;
-import org.apache.axis2.engine.AxisConfiguration;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.adc.topology.mgt.exception.TopologyMgtException;
-import org.apache.synapse.config.SynapseConfiguration;
-import org.wso2.carbon.ntask.core.service.TaskService;
-import org.wso2.carbon.registry.core.session.UserRegistry;
-import org.wso2.carbon.user.core.service.RealmService;
-
-import java.util.concurrent.BlockingQueue;
-import java.util.concurrent.LinkedBlockingQueue;
-
-/**
- * Singleton data holder
- */
-public class ConfigHolder {
-
-    private static ConfigHolder instance;
-    private static final Log log = LogFactory.getLog(ConfigHolder.class);
-
-    private SynapseConfiguration synapseConfiguration;
-    private ConfigurationContext configCtxt;
-    private AxisConfiguration axisConfiguration;
-    private UserRegistry configRegistry;
-    private UserRegistry governanceRegistry;
-    private TaskService taskService;
-    private BlockingQueue sharedTopologyDiffQueue = new LinkedBlockingQueue();
-    private String previousMessage;
-
-    public RealmService getRealmService() {
-        return realmService;
-    }
-
-    public void setRealmService(RealmService realmService) {
-        this.realmService = realmService;
-    }
-
-    private RealmService realmService;
-
-    private ConfigHolder() {
-    }
-
-    public static ConfigHolder getInstance() {
-        if (instance == null) {
-            instance = new ConfigHolder();
-        }
-        return instance;
-    }
-
-    public SynapseConfiguration getSynapseConfiguration() throws TopologyMgtException{
-        assertNull("SynapseConfiguration", synapseConfiguration);
-        return synapseConfiguration;
-    }
-
-    public void setSynapseConfiguration(SynapseConfiguration synapseConfiguration) {
-        this.synapseConfiguration = synapseConfiguration;
-    }
-
-    public AxisConfiguration getAxisConfiguration() throws TopologyMgtException {
-        assertNull("AxisConfiguration", axisConfiguration);
-        return axisConfiguration;
-    }
-
-    public void setAxisConfiguration(AxisConfiguration axisConfiguration) {
-        this.axisConfiguration = axisConfiguration;
-    }
-
-    public UserRegistry getConfigRegistry() throws TopologyMgtException {
-        assertNull("Registry", configRegistry);
-        return configRegistry;
-    }
-
-    public void setConfigRegistry(UserRegistry configRegistry) {
-        this.configRegistry = configRegistry;
-    }
-
-    private void assertNull(String name, Object object) throws TopologyMgtException {
-        if (object == null) {
-            String message = name + " reference in the proxy admin config holder is null";
-            log.error(message);
-            throw new TopologyMgtException(message);
-        }
-    }
-
-    public UserRegistry getGovernanceRegistry() {
-        return governanceRegistry;
-    }
-
-    public void setGovernanceRegistry(UserRegistry governanceRegistry) {
-        this.governanceRegistry = governanceRegistry;
-    }
-
-    public ConfigurationContext getConfigCtxt() {
-        return configCtxt;
-    }
-
-    public void setConfigCtxt(ConfigurationContext configCtxt) {
-        this.configCtxt = configCtxt;
-    }
-    
-    public TaskService getTaskService() {
-        return taskService;
-    }
-
-    public void setTaskService(TaskService taskService) {
-        this.taskService = taskService;
-    }
-
-    public BlockingQueue getSharedTopologyDiffQueue() {
-	    return sharedTopologyDiffQueue;
-    }
-
-	public void setSharedTopologyDiffQueue(BlockingQueue sharedTopologyDiffQueue) {
-	    this.sharedTopologyDiffQueue = sharedTopologyDiffQueue;
-    }
-
-	public String getPreviousMessage() {
-	    return previousMessage;
-    }
-
-	public void setPreviousMessage(String previousMessage) {
-	    this.previousMessage = previousMessage;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/TopologyConstants.java
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/TopologyConstants.java b/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/TopologyConstants.java
deleted file mode 100644
index 9960513..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/java/org/apache/stratos/adc/topology/mgt/util/TopologyConstants.java
+++ /dev/null
@@ -1,28 +0,0 @@
-package org.apache.stratos.adc.topology.mgt.util;
-/*
- *
- * 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 TopologyConstants {
-    public static final String TOPOLOGY_SYNC_CRON = "1 * * * * ? *";
-	public static final String TOPOLOGY_SYNC_TASK_NAME = "TopologySubscriberTaskOfADC";
-	public static final String TOPOLOGY_SYNC_TASK_TYPE = "TOPOLOGY_SUBSCRIBER_TASK";
-}

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/org.apache.stratos.adc.topology.mgt/src/main/resources/META-INF/services.xml
----------------------------------------------------------------------
diff --git a/components/org.apache.stratos.adc.topology.mgt/src/main/resources/META-INF/services.xml b/components/org.apache.stratos.adc.topology.mgt/src/main/resources/META-INF/services.xml
deleted file mode 100644
index 050ca74..0000000
--- a/components/org.apache.stratos.adc.topology.mgt/src/main/resources/META-INF/services.xml
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version='1.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.
-
--->
-
-<serviceGroup>
-    <service name="TopologyMgtService" scope="application">
-        <parameter name="ServiceClass">org.apache.stratos.adc.topology.mgt.service.impl.TopologyManagementServiceImpl</parameter>
-        <messageReceivers>
-        <messageReceiver mep="http://www.w3.org/ns/wsdl/in-only" class="org.apache.axis2.rpc.receivers.RPCInOnlyMessageReceiver"/>
-        <messageReceiver mep="http://www.w3.org/ns/wsdl/in-out" class="org.apache.axis2.rpc.receivers.RPCMessageReceiver"/>
-    </messageReceivers>
-    </service>
-</serviceGroup> 

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/components/pom.xml
----------------------------------------------------------------------
diff --git a/components/pom.xml b/components/pom.xml
index 2b46617..f8e8284 100644
--- a/components/pom.xml
+++ b/components/pom.xml
@@ -45,7 +45,6 @@
         <!-- CC -->
         <module>org.apache.stratos.cloud.controller</module>
         <!-- SM -->
-        <!--module>org.apache.stratos.adc.topology.mgt</module-->
         <module>org.apache.stratos.manager</module>
         <module>org.apache.stratos.deployment</module>
         <!-- CLI -->

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/features/manager/stratos-mgt/org.apache.stratos.adc.topology.mgt.feature/pom.xml
----------------------------------------------------------------------
diff --git a/features/manager/stratos-mgt/org.apache.stratos.adc.topology.mgt.feature/pom.xml b/features/manager/stratos-mgt/org.apache.stratos.adc.topology.mgt.feature/pom.xml
deleted file mode 100644
index ef77e17..0000000
--- a/features/manager/stratos-mgt/org.apache.stratos.adc.topology.mgt.feature/pom.xml
+++ /dev/null
@@ -1,83 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
-       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.
--->
-
-<project xmlns="http://maven.apache.org/POM/4.0.0"
-         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-    <parent>
-        <groupId>org.apache.stratos</groupId>
-        <artifactId>stratos-mgt-parent-feature</artifactId>
-        <version>4.0.0-SNAPSHOT</version>
-    </parent>
-
-    <modelVersion>4.0.0</modelVersion>
-    <artifactId>org.apache.stratos.adc.topology.mgt.feature</artifactId>
-    <packaging>pom</packaging>
-    <name>Apache Stratos - ADC Topology Management Feature</name>
-    <url>http://apache.org</url>
-    <description>This feature contains the bundles required for Topology Management in ADC</description>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.adc.topology.mgt</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-	<dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.messaging</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-    </dependencies>
-
-    <build>
-        <plugins>
-            <plugin>
-                <groupId>org.wso2.maven</groupId>
-                <artifactId>carbon-p2-plugin</artifactId>
-                <version>${carbon.p2.plugin.version}</version>
-                <executions>
-                    <execution>
-                        <id>p2-feature-generation</id>
-                        <phase>package</phase>
-                        <goals>
-                            <goal>p2-feature-gen</goal>
-                        </goals>
-                        <configuration>
-                            <id>org.apache.stratos.adc.topology.mgt</id>
-                            <propertiesFile>../../etc/feature.properties</propertiesFile>
-                            <adviceFile>
-                                <properties>
-                                    <propertyDef>org.wso2.carbon.p2.category.type:server</propertyDef>
-                                    <propertyDef>org.eclipse.equinox.p2.type.group:false</propertyDef>
-                                </properties>
-                            </adviceFile>
-                            <bundles>
-                                <bundleDef>org.apache.stratos:org.apache.stratos.adc.topology.mgt:${project.version}</bundleDef>
-                                <bundleDef>org.apache.stratos:org.apache.stratos.messaging:${project.version}</bundleDef>
-                            </bundles>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-        </plugins>
-    </build>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/features/manager/stratos-mgt/org.apache.stratos.manager.feature/pom.xml
----------------------------------------------------------------------
diff --git a/features/manager/stratos-mgt/org.apache.stratos.manager.feature/pom.xml b/features/manager/stratos-mgt/org.apache.stratos.manager.feature/pom.xml
index 4e9d515..17bc780 100644
--- a/features/manager/stratos-mgt/org.apache.stratos.manager.feature/pom.xml
+++ b/features/manager/stratos-mgt/org.apache.stratos.manager.feature/pom.xml
@@ -41,13 +41,7 @@
             <artifactId>org.apache.stratos.manager.server.feature</artifactId>
             <version>${project.version}</version>
             <type>zip</type>
-            </dependency>
-        <dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.adc.topology.mgt.feature</artifactId>
-            <version>${project.version}</version>
-            <type>zip</type>
-            </dependency>
+        </dependency>
     </dependencies>
 
     <build>
@@ -68,7 +62,6 @@
                             <propertiesFile>../../../../etc/feature.properties</propertiesFile>
                             <includedFeatures>
                                 <includedFeatureDef>org.apache.stratos:org.apache.stratos.manager.server.feature:${project.version}</includedFeatureDef>
-				<includedFeatureDef>org.apache.stratos:org.apache.stratos.adc.topology.mgt.feature:${project.version}</includedFeatureDef>
                             </includedFeatures>
                         </configuration>
                     </execution>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/features/manager/stratos-mgt/pom.xml
----------------------------------------------------------------------
diff --git a/features/manager/stratos-mgt/pom.xml b/features/manager/stratos-mgt/pom.xml
index cde9aaa..0a8a57a 100644
--- a/features/manager/stratos-mgt/pom.xml
+++ b/features/manager/stratos-mgt/pom.xml
@@ -35,7 +35,6 @@
 
     <modules>
         <module>org.apache.stratos.manager.server.feature</module>
-        <!--module>org.apache.stratos.adc.topology.mgt.feature</module-->
         <module>org.apache.stratos.manager.feature</module>
     </modules>
 

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/products/stratos-manager/modules/p2-profile-gen/pom.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/modules/p2-profile-gen/pom.xml b/products/stratos-manager/modules/p2-profile-gen/pom.xml
index 649c896..69c7060 100644
--- a/products/stratos-manager/modules/p2-profile-gen/pom.xml
+++ b/products/stratos-manager/modules/p2-profile-gen/pom.xml
@@ -269,6 +269,10 @@
                                 <featureArtifactDef>
                                     org.wso2.store:org.wso2.store.feature:1.0.0
                                 </featureArtifactDef>
+				<featureArtifactDef>
+                                    org.apache.stratos:org.apache.stratos.messaging.feature:${project.version}
+                                </featureArtifactDef>
+
 			</featureArtifacts>
         	</configuration>
         	</execution>
@@ -446,6 +450,10 @@
                                     <id>org.apache.stratos.rest.endpoint.feature.group</id>
                                     <version>${project.version}</version>
                                 </feature>
+				<feature>
+                                    <id>org.apache.stratos.messaging.feature.group</id>
+                                    <version>${project.version}</version>
+                                </feature>
 				 <feature>
                                     <id>org.wso2.carbon.identity.authenticator.saml2.sso.ui.feature.group</id>
                                     <version>${wso2carbon.version}</version>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/pom.xml
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/pom.xml b/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/pom.xml
deleted file mode 100644
index 7de412b..0000000
--- a/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/pom.xml
+++ /dev/null
@@ -1,116 +0,0 @@
-<?xml version="1.0" encoding="utf-8"?>
-<!--
-  ~ 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.
-  -->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-    <parent>
-        <groupId>org.apache.stratos</groupId>
-        <artifactId>stratos-service-stubs-parent</artifactId>
-        <version>4.0.0-SNAPSHOT</version>
-    </parent>
-
-    <modelVersion>4.0.0</modelVersion>
-    <artifactId>org.apache.stratos.adc.topologymgt.service.stub</artifactId>
-    <packaging>bundle</packaging>
-    <name>Apache Stratos - Topology Management Service Stub</name>
-    <url>http://apache.org</url>
-
-    <build>
-        <plugins>            
-            <plugin>
-                <groupId>org.apache.maven.plugins</groupId>
-                <artifactId>maven-antrun-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>source-code-generation</id>
-                        <phase>process-resources</phase>
-                        <goals>
-                            <goal>run</goal>
-                        </goals>
-                        <configuration>
-                            <tasks>
-                                <java classname="org.apache.axis2.wsdl.WSDL2Java" fork="true">
-                                    <arg line="-uri src/main/resources/TopologyMgtService.wsdl -u -uw -o target/generated-code -p org.apache.stratos.topology.mgt"/>
-                                    <classpath refid="maven.dependency.classpath"/>
-                                    <classpath refid="maven.compile.classpath"/>
-                                    <classpath refid="maven.runtime.classpath"/>
-                                </java>
-                            </tasks>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-            <plugin>
-                <groupId>org.codehaus.mojo</groupId>
-                <artifactId>build-helper-maven-plugin</artifactId>
-                <executions>
-                    <execution>
-                        <id>add-source</id>
-                        <phase>generate-sources</phase>
-                        <goals>
-                            <goal>add-source</goal>
-                        </goals>
-                        <configuration>
-                            <sources>
-                                <source>
-                                    target/generated-code/src
-                                </source>
-                            </sources>
-                        </configuration>
-                    </execution>
-                </executions>
-            </plugin>
-            <plugin>
-                <groupId>org.apache.felix</groupId>
-                <artifactId>maven-bundle-plugin</artifactId>
-                
-                <extensions>true</extensions>
-                <configuration>
-                    <instructions>
-                        <Bundle-SymbolicName>${project.artifactId}</Bundle-SymbolicName>
-                        <Bundle-Name>${project.artifactId}</Bundle-Name>
-                        <Export-Package>
-                            org.apache.stratos.topology.mgt.service.impl.*; version=${project.version},
-                            org.apache.stratos.topology.mgt.*; version=${project.version}
-                        </Export-Package>
-                        <Import-Package>
-                            *;resolution:=optional
-                        </Import-Package>
-                    </instructions>
-                </configuration>
-            </plugin>
-        </plugins>
-    </build>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.axis2.wso2</groupId>
-            <artifactId>axis2</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.axis2.wso2</groupId>
-            <artifactId>axis2-client</artifactId>
-        </dependency>
-        <dependency>
-            <groupId>wsdl4j.wso2</groupId>
-            <artifactId>wsdl4j</artifactId>
-        </dependency>
-    </dependencies>
-
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/src/main/resources/TopologyMgtService.wsdl
----------------------------------------------------------------------
diff --git a/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/src/main/resources/TopologyMgtService.wsdl b/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/src/main/resources/TopologyMgtService.wsdl
deleted file mode 100644
index 6b2475f..0000000
--- a/service-stubs/org.apache.stratos.adc.topologymgt.service.stub/src/main/resources/TopologyMgtService.wsdl
+++ /dev/null
@@ -1,220 +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.
-  -->
-
-<wsdl:definitions xmlns:wsdl="http://schemas.xmlsoap.org/wsdl/" xmlns:ns1="http://org.apache.axis2/xsd" xmlns:ns="http://impl.service.mgt.topology.stratos.apache.org" xmlns:wsaw="http://www.w3.org/2006/05/addressing/wsdl" xmlns:http="http://schemas.xmlsoap.org/wsdl/http/" xmlns:xs="http://www.w3.org/2001/XMLSchema" xmlns:soap="http://schemas.xmlsoap.org/wsdl/soap/" xmlns:mime="http://schemas.xmlsoap.org/wsdl/mime/" xmlns:soap12="http://schemas.xmlsoap.org/wsdl/soap12/" targetNamespace="http://impl.service.mgt.topology.stratos.apache.org">
-    <wsdl:documentation>TopologyMgtService</wsdl:documentation>
-    <wsdl:types>
-        <xs:schema attributeFormDefault="qualified" elementFormDefault="qualified" targetNamespace="http://impl.service.mgt.topology.stratos.apache.org">
-            <xs:element name="getSubDomains">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getSubDomainsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDomains">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="tenantId" type="xs:int"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getDomainsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getActiveIPs">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element minOccurs="0" name="cartridgeType" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="domain" nillable="true" type="xs:string"/>
-                        <xs:element minOccurs="0" name="subDomain" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-            <xs:element name="getActiveIPsResponse">
-                <xs:complexType>
-                    <xs:sequence>
-                        <xs:element maxOccurs="unbounded" minOccurs="0" name="return" nillable="true" type="xs:string"/>
-                    </xs:sequence>
-                </xs:complexType>
-            </xs:element>
-        </xs:schema>
-    </wsdl:types>
-    <wsdl:message name="getSubDomainsRequest">
-        <wsdl:part name="parameters" element="ns:getSubDomains"/>
-    </wsdl:message>
-    <wsdl:message name="getSubDomainsResponse">
-        <wsdl:part name="parameters" element="ns:getSubDomainsResponse"/>
-    </wsdl:message>
-    <wsdl:message name="getActiveIPsRequest">
-        <wsdl:part name="parameters" element="ns:getActiveIPs"/>
-    </wsdl:message>
-    <wsdl:message name="getActiveIPsResponse">
-        <wsdl:part name="parameters" element="ns:getActiveIPsResponse"/>
-    </wsdl:message>
-    <wsdl:message name="getDomainsRequest">
-        <wsdl:part name="parameters" element="ns:getDomains"/>
-    </wsdl:message>
-    <wsdl:message name="getDomainsResponse">
-        <wsdl:part name="parameters" element="ns:getDomainsResponse"/>
-    </wsdl:message>
-    <wsdl:portType name="TopologyMgtServicePortType">
-        <wsdl:operation name="getSubDomains">
-            <wsdl:input message="ns:getSubDomainsRequest" wsaw:Action="urn:getSubDomains"/>
-            <wsdl:output message="ns:getSubDomainsResponse" wsaw:Action="urn:getSubDomainsResponse"/>
-        </wsdl:operation>
-        <wsdl:operation name="getActiveIPs">
-            <wsdl:input message="ns:getActiveIPsRequest" wsaw:Action="urn:getActiveIPs"/>
-            <wsdl:output message="ns:getActiveIPsResponse" wsaw:Action="urn:getActiveIPsResponse"/>
-        </wsdl:operation>
-        <wsdl:operation name="getDomains">
-            <wsdl:input message="ns:getDomainsRequest" wsaw:Action="urn:getDomains"/>
-            <wsdl:output message="ns:getDomainsResponse" wsaw:Action="urn:getDomainsResponse"/>
-        </wsdl:operation>
-    </wsdl:portType>
-    <wsdl:binding name="TopologyMgtServiceSoap11Binding" type="ns:TopologyMgtServicePortType">
-        <soap:binding transport="http://schemas.xmlsoap.org/soap/http" style="document"/>
-        <wsdl:operation name="getSubDomains">
-            <soap:operation soapAction="urn:getSubDomains" style="document"/>
-            <wsdl:input>
-                <soap:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
-        <wsdl:operation name="getActiveIPs">
-            <soap:operation soapAction="urn:getActiveIPs" style="document"/>
-            <wsdl:input>
-                <soap:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
-        <wsdl:operation name="getDomains">
-            <soap:operation soapAction="urn:getDomains" style="document"/>
-            <wsdl:input>
-                <soap:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
-    </wsdl:binding>
-    <wsdl:binding name="TopologyMgtServiceSoap12Binding" type="ns:TopologyMgtServicePortType">
-        <soap12:binding transport="http://schemas.xmlsoap.org/soap/http" style="document"/>
-        <wsdl:operation name="getSubDomains">
-            <soap12:operation soapAction="urn:getSubDomains" style="document"/>
-            <wsdl:input>
-                <soap12:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap12:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
-        <wsdl:operation name="getActiveIPs">
-            <soap12:operation soapAction="urn:getActiveIPs" style="document"/>
-            <wsdl:input>
-                <soap12:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap12:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
-        <wsdl:operation name="getDomains">
-            <soap12:operation soapAction="urn:getDomains" style="document"/>
-            <wsdl:input>
-                <soap12:body use="literal"/>
-            </wsdl:input>
-            <wsdl:output>
-                <soap12:body use="literal"/>
-            </wsdl:output>
-        </wsdl:operation>
-    </wsdl:binding>
-    <wsdl:binding name="TopologyMgtServiceHttpBinding" type="ns:TopologyMgtServicePortType">
-        <http:binding verb="POST"/>
-        <wsdl:operation name="getSubDomains">
-            <http:operation location="getSubDomains"/>
-            <wsdl:input>
-                <mime:content type="text/xml" part="parameters"/>
-            </wsdl:input>
-            <wsdl:output>
-                <mime:content type="text/xml" part="parameters"/>
-            </wsdl:output>
-        </wsdl:operation>
-        <wsdl:operation name="getActiveIPs">
-            <http:operation location="getActiveIPs"/>
-            <wsdl:input>
-                <mime:content type="text/xml" part="parameters"/>
-            </wsdl:input>
-            <wsdl:output>
-                <mime:content type="text/xml" part="parameters"/>
-            </wsdl:output>
-        </wsdl:operation>
-        <wsdl:operation name="getDomains">
-            <http:operation location="getDomains"/>
-            <wsdl:input>
-                <mime:content type="text/xml" part="parameters"/>
-            </wsdl:input>
-            <wsdl:output>
-                <mime:content type="text/xml" part="parameters"/>
-            </wsdl:output>
-        </wsdl:operation>
-    </wsdl:binding>
-    <wsdl:service name="TopologyMgtService">
-        <wsdl:port name="TopologyMgtServiceHttpSoap11Endpoint" binding="ns:TopologyMgtServiceSoap11Binding">
-            <soap:address location="http://192.168.16.22:9765/services/TopologyMgtService.TopologyMgtServiceHttpSoap11Endpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceHttpsSoap11Endpoint" binding="ns:TopologyMgtServiceSoap11Binding">
-            <soap:address location="https://192.168.16.22:9445/services/TopologyMgtService.TopologyMgtServiceHttpsSoap11Endpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceLocalSoap11Endpoint" binding="ns:TopologyMgtServiceSoap11Binding">
-            <soap:address location="local:///services/TopologyMgtService.TopologyMgtServiceLocalSoap11Endpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceHttpsSoap12Endpoint" binding="ns:TopologyMgtServiceSoap12Binding">
-            <soap12:address location="https://192.168.16.22:9445/services/TopologyMgtService.TopologyMgtServiceHttpsSoap12Endpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceHttpSoap12Endpoint" binding="ns:TopologyMgtServiceSoap12Binding">
-            <soap12:address location="http://192.168.16.22:9765/services/TopologyMgtService.TopologyMgtServiceHttpSoap12Endpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceLocalSoap12Endpoint" binding="ns:TopologyMgtServiceSoap12Binding">
-            <soap12:address location="local:///services/TopologyMgtService.TopologyMgtServiceLocalSoap12Endpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceHttpsEndpoint" binding="ns:TopologyMgtServiceHttpBinding">
-            <http:address location="https://192.168.16.22:9445/services/TopologyMgtService.TopologyMgtServiceHttpsEndpoint/"/>
-        </wsdl:port>
-        <wsdl:port name="TopologyMgtServiceHttpEndpoint" binding="ns:TopologyMgtServiceHttpBinding">
-            <http:address location="http://192.168.16.22:9765/services/TopologyMgtService.TopologyMgtServiceHttpEndpoint/"/>
-        </wsdl:port>
-    </wsdl:service>
-</wsdl:definitions>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/24086e31/service-stubs/pom.xml
----------------------------------------------------------------------
diff --git a/service-stubs/pom.xml b/service-stubs/pom.xml
index 093e6c3..a0dbdb0 100644
--- a/service-stubs/pom.xml
+++ b/service-stubs/pom.xml
@@ -51,7 +51,6 @@
         <module>org.apache.stratos.tenant.register.gapp.stub</module>
         <module>org.apache.stratos.redirector.servlet.stub</module>
         <module>org.apache.stratos.adc.reponotification.service.stub</module>
-        <!--module>org.apache.stratos.adc.topologymgt.service.stub</module-->
         <module>org.apache.stratos.billing.mgt.stub</module>
         <module>org.apache.stratos.throttle.stub</module>
         <module>org.apache.stratos.usage.meteringqueryds.stub</module>