You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by ga...@apache.org on 2015/09/01 17:16:56 UTC

[4/4] stratos git commit: Remove integration test under python cartridge agent as this is already exist in module folder

Remove integration test under python cartridge agent as this is already exist in module folder


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

Branch: refs/heads/master
Commit: bf76be91f2b9a77d991a3c2ba210fc21ff1e7ec3
Parents: 2ee9873
Author: gayangunarathne <ga...@wso2.com>
Authored: Tue Sep 1 20:36:50 2015 +0530
Committer: gayangunarathne <ga...@wso2.com>
Committed: Tue Sep 1 20:36:50 2015 +0530

----------------------------------------------------------------------
 .../python-cartridge-agent/integration/pom.xml  | 161 ------
 .../python.cartridge.agent/test/ADCTest.java    | 239 --------
 .../test/DataPublisherTestUtil.java             |  46 --
 .../test/PythonCartridgeAgentTest.java          | 578 -------------------
 .../test/ThriftTestServer.java                  | 213 -------
 .../test/resources/common/client-truststore.jks | Bin 37935 -> 0 bytes
 .../resources/common/data-bridge-config.xml     |  75 ---
 .../src/test/resources/common/log4j.properties  |  41 --
 .../common/stratos-health-stream-def.json       |   1 -
 .../resources/common/thrift-agent-config.xml    |  64 --
 .../src/test/resources/common/wso2carbon.jks    | Bin 33260 -> 0 bytes
 .../src/test/resources/pca-testing1.xml         |  29 -
 .../src/test/resources/pca-testing2.xml         |  29 -
 .../src/test/resources/suite-1/agent.conf       |  46 --
 .../src/test/resources/suite-1/jndi.properties  |  22 -
 .../src/test/resources/suite-1/logging.ini      |  52 --
 .../resources/suite-1/payload/launch-params     |   1 -
 .../src/test/resources/suite-2/agent.conf       |  46 --
 .../src/test/resources/suite-2/jndi.properties  |  22 -
 .../src/test/resources/suite-2/logging.ini      |  52 --
 .../resources/suite-2/payload/launch-params     |  18 -
 .../test-conf/integration-test.properties       |  27 -
 22 files changed, 1762 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/pom.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/pom.xml b/products/python-cartridge-agent/integration/pom.xml
deleted file mode 100755
index ae6f5e1..0000000
--- a/products/python-cartridge-agent/integration/pom.xml
+++ /dev/null
@@ -1,161 +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.
-  -->
-
-<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">
-    <modelVersion>4.0.0</modelVersion>
-    <parent>
-        <groupId>org.apache.stratos</groupId>
-        <artifactId>python-cartridge-agent-parent</artifactId>
-        <version>4.1.2</version>
-    </parent>
-
-    <artifactId>python-agent-integration</artifactId>
-    <packaging>jar</packaging>
-    <name>Python Cartridge Agent - Integration Tests</name>
-
-    <build>
-        <resources>
-            <resource>
-                <directory>src/test/resources/test-conf</directory>
-                <filtering>true</filtering>
-            </resource>
-        </resources>
-    </build>
-
-    <profiles>
-        <profile>
-            <id>default</id>
-            <activation>
-                <activeByDefault>true</activeByDefault>
-            </activation>
-            <build>
-                <plugins>
-                    <plugin>
-                        <groupId>org.apache.maven.plugins</groupId>
-                        <artifactId>maven-surefire-plugin</artifactId>
-                        <configuration>
-                            <excludes>
-                                <exclude>**/*</exclude>
-                            </excludes>
-                        </configuration>
-                    </plugin>
-                </plugins>
-            </build>
-        </profile>
-        <profile>
-            <id>live</id>
-            <build>
-                <resources>
-                    <resource>
-                        <directory>src/test/resources/test-conf</directory>
-                        <filtering>true</filtering>
-                    </resource>
-                </resources>
-                <plugins>
-                    <plugin>
-                        <groupId>org.apache.maven.plugins</groupId>
-                        <artifactId>maven-surefire-plugin</artifactId>
-                        <inherited>false</inherited>
-                        <configuration>
-                            <suiteXmlFiles>
-                                <suiteXmlFile>src/test/resources/pca-testing1.xml</suiteXmlFile>
-                            </suiteXmlFiles>
-                            <workingDirectory>${basedir}/target</workingDirectory>
-                        </configuration>
-                    </plugin>
-                    <plugin>
-                        <groupId>org.apache.maven.plugins</groupId>
-                        <artifactId>maven-jar-plugin</artifactId>
-                        <executions>
-                            <execution>
-                                <goals>
-                                    <goal>test-jar</goal>
-                                </goals>
-                            </execution>
-                        </executions>
-                    </plugin>
-                    <plugin>
-                        <groupId>org.apache.maven.plugins</groupId>
-                        <artifactId>maven-dependency-plugin</artifactId>
-                    </plugin>
-                </plugins>
-            </build>
-        </profile>
-    </profiles>
-
-    <dependencies>
-        <dependency>
-            <groupId>org.apache.commons</groupId>
-            <artifactId>commons-exec</artifactId>
-            <version>1.0.1</version>
-        </dependency>
-        <!--dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.common</artifactId>
-            <version>${project.version}</version>
-        </dependency-->
-        <dependency>
-            <groupId>org.testng</groupId>
-            <artifactId>testng</artifactId>
-            <version>6.1.1</version>
-        </dependency>
-        <!--dependency>
-            <groupId>org.apache.axis2.wso2</groupId>
-            <artifactId>axis2-client</artifactId>
-            <version>${axis2.wso2.version}</version>
-        </dependency-->
-        <!--dependency>
-            <groupId>org.apache.httpcomponents.wso2</groupId>
-            <artifactId>httpcore</artifactId>
-            <version>4.3.0.wso2v1</version>
-        </dependency-->
-        <!--dependency>
-            <groupId>org.apache.httpcomponents.wso2</groupId>
-            <artifactId>httpclient</artifactId>
-            <version>4.2.5.wso2v1</version>
-        </dependency-->
-        <!--dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.mock.iaas.client</artifactId>
-            <version>${project.version}</version>
-            <scope>test</scope>
-        </dependency-->
-        <!--dependency>
-            <groupId>org.wso2.andes.wso2</groupId>
-            <artifactId>andes-client</artifactId>
-            <version>0.13.wso2v8</version>
-        </dependency-->
-        <dependency>
-            <groupId>org.apache.activemq</groupId>
-            <artifactId>activemq-all</artifactId>
-            <version>5.10.0</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.activemq</groupId>
-            <artifactId>activemq-mqtt</artifactId>
-            <version>5.10.0</version>
-        </dependency>
-        <dependency>
-            <groupId>org.apache.stratos</groupId>
-            <artifactId>org.apache.stratos.messaging</artifactId>
-            <version>${project.version}</version>
-        </dependency>
-    </dependencies>
-</project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ADCTest.java
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ADCTest.java b/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ADCTest.java
deleted file mode 100755
index 0b9d406..0000000
--- a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ADCTest.java
+++ /dev/null
@@ -1,239 +0,0 @@
-package org.apache.stratos.python.cartridge.agent.test;/*
- * 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 ADCTest {
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.common.domain.LoadBalancingIPType;
-import org.apache.stratos.messaging.domain.topology.*;
-import org.apache.stratos.messaging.event.instance.notifier.ArtifactUpdatedEvent;
-import org.apache.stratos.messaging.event.topology.CompleteTopologyEvent;
-import org.apache.stratos.messaging.event.topology.MemberInitializedEvent;
-import org.testng.annotations.AfterSuite;
-import org.testng.annotations.BeforeSuite;
-import org.testng.annotations.Test;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Properties;
-import java.util.UUID;
-
-import static junit.framework.Assert.assertTrue;
-
-public class ADCTest extends PythonAgentTestManager {
-    private static final Log log = LogFactory.getLog(ADCTest.class);
-    private static final int ADC_TIMEOUT = 180000;
-    private static final String SUITE_NAME = "suite-2";
-    private static final String APPLICATION_PATH = "/tmp/pca-test-suite-2";
-    private static final String CLUSTER_ID = "tomcat.domain";
-    private static final String DEPLOYMENT_POLICY_NAME = "deployment-policy-2";
-    private static final String AUTOSCALING_POLICY_NAME = "autoscaling-policy-2";
-    private static final String APP_ID = "application-2";
-    private static final String MEMBER_ID = "tomcat.member-1";
-    private static final String CLUSTER_INSTANCE_ID = "cluster-1-instance-1";
-    private static final String NETWORK_PARTITION_ID = "network-partition-1";
-    private static final String PARTITION_ID = "partition-1";
-    private static final String TENANT_ID = "-1234";
-    private static final String SERVICE_NAME = "tomcat";
-
-    private boolean hasADCTestCompleted = false;
-
-    @BeforeSuite
-    public void setupADCTest() {
-        // Set jndi.properties.dir system property for initializing event publishers and receivers
-        System.setProperty("jndi.properties.dir", getResourcesPath(SUITE_NAME));
-
-        // start Python agent with configurations provided in resource path
-        setup(SUITE_NAME);
-
-        // Simulate server socket
-        startServerSocket(8080);
-    }
-
-    /**
-     * TearDown method for test method testPythonCartridgeAgent
-     */
-    @AfterSuite
-    public void tearDownADCTest() {
-        // TODO: app path is duplicated in Java test and payload
-        tearDown(APPLICATION_PATH);
-    }
-
-
-    @Test(timeOut = ADC_TIMEOUT)
-    public void testADC() {
-        startCommunicatorThread();
-        assertAgentActivation();
-        Thread adcTestThread = new Thread(new Runnable() {
-            @Override
-            public void run() {
-                log.info("Running ADC Test thread...");
-                // Send artifact updated event
-                publishEvent(getArtifactUpdatedEventForPrivateRepo());
-                log.info("Publishing artifact updated event for repo: " +
-                        getArtifactUpdatedEventForPrivateRepo().getRepoURL());
-
-                List<String> outputLines = new ArrayList<String>();
-                while (!outputStream.isClosed() && !hasADCTestCompleted) {
-                    List<String> newLines = getNewLines(outputLines, outputStream.toString());
-                    if (newLines.size() > 0) {
-                        for (String line : newLines) {
-                            if (line.contains("Git clone executed")) {
-                                log.info("Agent has completed git clone. Asserting the operation...");
-                                assertRepoClone(getArtifactUpdatedEventForPrivateRepo());
-                                File file = new File(APPLICATION_PATH + "/pca-live-" + UUID.randomUUID());
-                                try {
-                                    file.createNewFile();
-                                }
-                                catch (IOException e) {
-                                    log.error("Could not create file", e);
-                                }
-                            }
-                            if (line.contains("Pushed artifacts for tenant")) {
-                                log.info("ADC Test completed");
-                                hasADCTestCompleted = true;
-                            }
-                        }
-                    }
-                    sleep(1000);
-                }
-            }
-        });
-        adcTestThread.start();
-
-        while (!hasADCTestCompleted) {
-            // wait until the instance activated event is received.
-            sleep(1000);
-        }
-    }
-
-    private void assertAgentActivation() {
-        Thread startupTestThread = new Thread(new Runnable() {
-            @Override
-            public void run() {
-                while (!eventReceiverInitiated) {
-                    sleep(1000);
-                }
-                List<String> outputLines = new ArrayList<String>();
-                while (!outputStream.isClosed()) {
-                    List<String> newLines = getNewLines(outputLines, outputStream.toString());
-                    if (newLines.size() > 0) {
-                        for (String line : newLines) {
-                            if (line.contains("Subscribed to 'topology/#'")) {
-                                sleep(2000);
-                                // Send complete topology event
-                                log.info("Publishing complete topology event...");
-                                Topology topology = createTestTopology();
-                                CompleteTopologyEvent completeTopologyEvent = new CompleteTopologyEvent(topology);
-                                publishEvent(completeTopologyEvent);
-                                log.info("Complete topology event published");
-
-                                // Publish member initialized event
-                                log.info("Publishing member initialized event...");
-                                MemberInitializedEvent memberInitializedEvent = new MemberInitializedEvent(
-                                        SERVICE_NAME, CLUSTER_ID, CLUSTER_INSTANCE_ID, MEMBER_ID, NETWORK_PARTITION_ID,
-                                        PARTITION_ID
-                                );
-                                publishEvent(memberInitializedEvent);
-                                log.info("Member initialized event published");
-                            }
-
-                            // Send artifact updated event to activate the instance first
-                            if (line.contains("Artifact repository found")) {
-                                publishEvent(getArtifactUpdatedEventForPrivateRepo());
-                                log.info("Artifact updated event published");
-                            }
-                            log.info(line);
-                        }
-                    }
-                    sleep(1000);
-                }
-            }
-        });
-        startupTestThread.start();
-
-        while (!instanceStarted || !instanceActivated) {
-            // wait until the instance activated event is received.
-            // this will assert whether instance got activated within timeout period; no need for explicit assertions
-            sleep(2000);
-        }
-    }
-
-    private void assertRepoClone(ArtifactUpdatedEvent artifactUpdatedEvent) {
-        File file = new File(APPLICATION_PATH + "/README.text");
-        assertTrue("Git clone failed for repo [url] " + artifactUpdatedEvent.getRepoURL(),
-                file.exists());
-    }
-
-
-    public static ArtifactUpdatedEvent getArtifactUpdatedEventForPublicRepo() {
-        ArtifactUpdatedEvent publicRepoEvent = createTestArtifactUpdatedEvent();
-        publicRepoEvent.setRepoURL("https://bitbucket.org/testapache2211/opentestrepo1.git");
-        return publicRepoEvent;
-    }
-
-    public static ArtifactUpdatedEvent getArtifactUpdatedEventForPrivateRepo() {
-        ArtifactUpdatedEvent privateRepoEvent = createTestArtifactUpdatedEvent();
-        privateRepoEvent.setRepoURL("https://bitbucket.org/testapache2211/testrepo.git");
-        privateRepoEvent.setRepoUserName("testapache2211");
-        privateRepoEvent.setRepoPassword("RExPDGa4GkPJj4kJDzSROQ==");
-        return privateRepoEvent;
-    }
-
-    private static ArtifactUpdatedEvent createTestArtifactUpdatedEvent() {
-        ArtifactUpdatedEvent artifactUpdatedEvent = new ArtifactUpdatedEvent();
-        artifactUpdatedEvent.setClusterId(CLUSTER_ID);
-        artifactUpdatedEvent.setTenantId(TENANT_ID);
-        return artifactUpdatedEvent;
-    }
-
-    /**
-     * Create test topology
-     *
-     * @return
-     */
-    private Topology createTestTopology() {
-        Topology topology = new Topology();
-        Service service = new Service(SERVICE_NAME, ServiceType.SingleTenant);
-        topology.addService(service);
-
-        Cluster cluster = new Cluster(service.getServiceName(), CLUSTER_ID, DEPLOYMENT_POLICY_NAME,
-                AUTOSCALING_POLICY_NAME, APP_ID);
-        service.addCluster(cluster);
-
-        Member member = new Member(service.getServiceName(), cluster.getClusterId(), MEMBER_ID,
-                CLUSTER_INSTANCE_ID, NETWORK_PARTITION_ID, PARTITION_ID, LoadBalancingIPType.Private,
-                System.currentTimeMillis());
-
-        member.setDefaultPrivateIP("10.0.0.1");
-        member.setDefaultPublicIP("20.0.0.1");
-        Properties properties = new Properties();
-        properties.setProperty("prop1", "value1");
-        member.setProperties(properties);
-        member.setStatus(MemberStatus.Created);
-        cluster.addMember(member);
-
-        return topology;
-    }
-
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/DataPublisherTestUtil.java
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/DataPublisherTestUtil.java b/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/DataPublisherTestUtil.java
deleted file mode 100644
index 7f1d985..0000000
--- a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/DataPublisherTestUtil.java
+++ /dev/null
@@ -1,46 +0,0 @@
-package org.apache.stratos.python.cartridge.agent.test;/*
- * Licensed to the Apache Software Foundation (ASF) under one 
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY 
- * KIND, either express or implied.  See the License for the 
- * specific language governing permissions and limitations
- * under the License.
- */
-
-import java.io.File;
-
-public class DataPublisherTestUtil {
-    public static final String LOCAL_HOST = "localhost";
-
-    public static void setTrustStoreParams() {
-        String trustStore = PythonAgentTestManager.getResourcesPath("common");
-        System.setProperty("javax.net.ssl.trustStore", trustStore + File.separator + "client-truststore.jks");
-        System.setProperty("javax.net.ssl.trustStorePassword", "wso2carbon");
-    }
-
-    public static void setKeyStoreParams() {
-        String keyStore = PythonAgentTestManager.getResourcesPath("common");
-        System.setProperty("Security.KeyStore.Location", keyStore + File.separator + "wso2carbon.jks");
-        System.setProperty("Security.KeyStore.Password", "wso2carbon");
-    }
-
-    public static String getDataAgentConfigPath() {
-        String filePath = PythonAgentTestManager.getResourcesPath("common");
-        return filePath + File.separator + "data-agent-config.xml";
-    }
-
-    public static String getDataBridgeConfigPath() {
-        String filePath = PythonAgentTestManager.getResourcesPath("common");
-        return filePath + File.separator + "data-bridge-config.xml";
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/PythonCartridgeAgentTest.java
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/PythonCartridgeAgentTest.java b/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/PythonCartridgeAgentTest.java
deleted file mode 100755
index 93f4c1e..0000000
--- a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/PythonCartridgeAgentTest.java
+++ /dev/null
@@ -1,578 +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.python.cartridge.agent.test;
-
-import org.apache.activemq.broker.BrokerService;
-import org.apache.commons.exec.*;
-import org.apache.commons.io.FileUtils;
-import org.apache.commons.io.output.ByteArrayOutputStream;
-import org.apache.commons.lang.StringUtils;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.stratos.common.domain.LoadBalancingIPType;
-import org.apache.stratos.common.threading.StratosThreadPool;
-import org.apache.stratos.messaging.broker.publish.EventPublisher;
-import org.apache.stratos.messaging.broker.publish.EventPublisherPool;
-import org.apache.stratos.messaging.domain.topology.*;
-import org.apache.stratos.messaging.event.Event;
-import org.apache.stratos.messaging.event.instance.notifier.ArtifactUpdatedEvent;
-import org.apache.stratos.messaging.event.topology.CompleteTopologyEvent;
-import org.apache.stratos.messaging.event.topology.MemberInitializedEvent;
-import org.apache.stratos.messaging.listener.instance.status.InstanceActivatedEventListener;
-import org.apache.stratos.messaging.listener.instance.status.InstanceStartedEventListener;
-import org.apache.stratos.messaging.message.receiver.instance.status.InstanceStatusEventReceiver;
-import org.apache.stratos.messaging.message.receiver.topology.TopologyEventReceiver;
-import org.apache.stratos.messaging.util.MessagingUtil;
-import org.testng.annotations.AfterSuite;
-import org.testng.annotations.BeforeSuite;
-import org.testng.annotations.Test;
-
-import java.io.*;
-import java.net.ServerSocket;
-import java.util.*;
-import java.util.concurrent.ExecutorService;
-import java.util.zip.ZipEntry;
-import java.util.zip.ZipInputStream;
-
-import static junit.framework.Assert.assertTrue;
-
-public class PythonCartridgeAgentTest {
-
-    private static final Log log = LogFactory.getLog(PythonCartridgeAgentTest.class);
-    private static final String RESOURCES_PATH = "/suite-1";
-    private static final String NEW_LINE = System.getProperty("line.separator");
-    //    private static final long TIMEOUT = 1440000;
-    private static final long TIMEOUT = 120000;
-    private static final String CLUSTER_ID = "php.php.domain";
-    private static final String DEPLOYMENT_POLICY_NAME = "deployment-policy-1";
-    private static final String AUTOSCALING_POLICY_NAME = "autoscaling-policy-1";
-    private static final String APP_ID = "application-1";
-    private static final String MEMBER_ID = "php.member-1";
-    private static final String CLUSTER_INSTANCE_ID = "cluster-1-instance-1";
-    private static final String NETWORK_PARTITION_ID = "network-partition-1";
-    private static final String PARTITION_ID = "partition-1";
-    private static final String TENANT_ID = "-1234";
-    private static final String SERVICE_NAME = "php";
-    public static final String SOURCE_PATH = "/tmp/stratos-pca-test-app-path/";
-
-    private static List<ServerSocket> serverSocketList;
-    private static Map<String, Executor> executorList;
-
-    private boolean instanceStarted;
-    private boolean instanceActivated;
-    private ByteArrayOutputStreamLocal outputStream;
-    private boolean eventReceiverInitiated = false;
-    private TopologyEventReceiver topologyEventReceiver;
-    private InstanceStatusEventReceiver instanceStatusEventReceiver;
-    private BrokerService broker = new BrokerService();
-    private static final UUID PYTHON_AGENT_DIR_NAME = UUID.randomUUID();
-
-    private static final String ACTIVEMQ_AMQP_BIND_ADDRESS = "activemq.amqp.bind.address";
-    private static final String ACTIVEMQ_MQTT_BIND_ADDRESS = "activemq.mqtt.bind.address";
-    private static final String CEP_PORT = "cep.port";
-    private static final String DISTRIBUTION_NAME = "distribution.name";
-
-    private int cepPort;
-    private String amqpBindAddress;
-    private String mqttBindAddress;
-    private String distributionName;
-    private Properties integrationProperties;
-
-    public PythonCartridgeAgentTest() {
-        if (integrationProperties == null) {
-            integrationProperties = new Properties();
-            try {
-                integrationProperties
-                        .load(PythonCartridgeAgentTest.class.getResourceAsStream("/integration-test.properties"));
-                distributionName = integrationProperties.getProperty(DISTRIBUTION_NAME);
-                amqpBindAddress = integrationProperties.getProperty(ACTIVEMQ_AMQP_BIND_ADDRESS);
-                mqttBindAddress = integrationProperties.getProperty(ACTIVEMQ_MQTT_BIND_ADDRESS);
-                cepPort = Integer.parseInt(integrationProperties.getProperty(CEP_PORT));
-                log.info("PCA integration properties: " + integrationProperties.toString());
-            }
-            catch (IOException e) {
-                log.error("Error loading integration-test.properties file from classpath. Please make sure that file " +
-                        "exists in classpath.", e);
-            }
-        }
-    }
-
-    /**
-     * Setup method for test class
-     */
-    @BeforeSuite
-    public static void oneTimeSetUp() {
-        // Set jndi.properties.dir system property for initializing event publishers and receivers
-        System.setProperty("jndi.properties.dir", getResourcesPath());
-    }
-
-    /**
-     * Setup method for test method testPythonCartridgeAgent
-     */
-    @BeforeSuite
-    public void setup() {
-        serverSocketList = new ArrayList<ServerSocket>();
-        executorList = new HashMap<String, Executor>();
-        try {
-            broker.addConnector(amqpBindAddress);
-            broker.addConnector(mqttBindAddress);
-            broker.setBrokerName("testBroker");
-            broker.setDataDirectory(
-                    PythonCartridgeAgentTest.class.getResource("/").getPath() + "/../" + PYTHON_AGENT_DIR_NAME +
-                            "/activemq-data");
-            broker.start();
-            log.info("Broker service started!");
-        }
-        catch (Exception e) {
-            log.error("Error while setting up broker service", e);
-        }
-        if (!this.eventReceiverInitiated) {
-            ExecutorService executorService = StratosThreadPool.getExecutorService("TEST_THREAD_POOL", 15);
-            topologyEventReceiver = new TopologyEventReceiver();
-            topologyEventReceiver.setExecutorService(executorService);
-            topologyEventReceiver.execute();
-
-            instanceStatusEventReceiver = new InstanceStatusEventReceiver();
-            instanceStatusEventReceiver.setExecutorService(executorService);
-            instanceStatusEventReceiver.execute();
-
-            this.instanceStarted = false;
-            instanceStatusEventReceiver.addEventListener(new InstanceStartedEventListener() {
-                @Override
-                protected void onEvent(Event event) {
-                    log.info("Instance started event received");
-                    instanceStarted = true;
-                }
-            });
-
-            this.instanceActivated = false;
-            instanceStatusEventReceiver.addEventListener(new InstanceActivatedEventListener() {
-                @Override
-                protected void onEvent(Event event) {
-                    log.info("Instance activated event received");
-                    instanceActivated = true;
-                }
-            });
-
-            this.eventReceiverInitiated = true;
-        }
-        // Simulate CEP server socket
-        startServerSocket(cepPort);
-        String agentPath = setupPythonAgent();
-        log.info("Python agent working directory name: " + PYTHON_AGENT_DIR_NAME);
-        log.info("Starting python cartridge agent...");
-        this.outputStream = executeCommand("python " + agentPath + "/agent.py > " +
-                PythonCartridgeAgentTest.class.getResource(File.separator).getPath() + "/../" + PYTHON_AGENT_DIR_NAME +
-                "/cartridge-agent.log");
-    }
-
-    /**
-     * TearDown method for test method testPythonCartridgeAgent
-     */
-    @AfterSuite
-    public void tearDown() {
-        for (Map.Entry<String, Executor> entry : executorList.entrySet()) {
-            try {
-                String commandText = entry.getKey();
-                Executor executor = entry.getValue();
-                ExecuteWatchdog watchdog = executor.getWatchdog();
-                if (watchdog != null) {
-                    log.info("Terminating process: " + commandText);
-                    watchdog.destroyProcess();
-                }
-            }
-            catch (Exception ignore) {
-            }
-        }
-        for (ServerSocket serverSocket : serverSocketList) {
-            try {
-                log.info("Stopping socket server: " + serverSocket.getLocalSocketAddress());
-                serverSocket.close();
-            }
-            catch (IOException ignore) {
-            }
-        }
-
-        try {
-            log.info("Deleting source checkout folder...");
-            FileUtils.deleteDirectory(new File(SOURCE_PATH));
-        }
-        catch (Exception ignore) {
-
-        }
-
-        this.instanceStatusEventReceiver.terminate();
-        this.topologyEventReceiver.terminate();
-
-        this.instanceActivated = false;
-        this.instanceStarted = false;
-        try {
-            broker.stop();
-        }
-        catch (Exception e) {
-            log.error("Error while stopping the broker service", e);
-        }
-    }
-
-
-    /**
-     * This method returns a collection of {@link org.apache.stratos.messaging.event.instance.notifier.ArtifactUpdatedEvent}
-     * objects as parameters to the test
-     *
-     * @return
-     */
-
-    public static ArrayList<ArtifactUpdatedEvent> getArtifactUpdatedEventsAsParams() {
-        ArtifactUpdatedEvent publicRepoEvent = createTestArtifactUpdatedEvent();
-
-        ArtifactUpdatedEvent privateRepoEvent = createTestArtifactUpdatedEvent();
-        privateRepoEvent.setRepoURL("https://bitbucket.org/testapache2211/testrepo.git");
-        privateRepoEvent.setRepoUserName("testapache2211");
-        privateRepoEvent.setRepoPassword("RExPDGa4GkPJj4kJDzSROQ==");
-
-        ArtifactUpdatedEvent privateRepoEvent2 = createTestArtifactUpdatedEvent();
-        privateRepoEvent2.setRepoURL("https://testapache2211@bitbucket.org/testapache2211/testrepo.git");
-        privateRepoEvent2.setRepoUserName("testapache2211");
-        privateRepoEvent2.setRepoPassword("iF7qT+BKKPE3PGV1TeDsJA==");
-
-        ArrayList<ArtifactUpdatedEvent> list = new ArrayList<ArtifactUpdatedEvent>();
-        list.add(privateRepoEvent);
-        list.add(privateRepoEvent2);
-        list.add(publicRepoEvent);
-        return list;
-    }
-
-    /**
-     * Creates an {@link org.apache.stratos.messaging.event.instance.notifier.ArtifactUpdatedEvent} object with a public
-     * repository URL
-     *
-     * @return
-     */
-    private static ArtifactUpdatedEvent createTestArtifactUpdatedEvent() {
-        ArtifactUpdatedEvent publicRepoEvent = new ArtifactUpdatedEvent();
-        publicRepoEvent.setClusterId(CLUSTER_ID);
-        publicRepoEvent.setTenantId(TENANT_ID);
-        publicRepoEvent.setRepoURL("https://bitbucket.org/testapache2211/opentestrepo1.git");
-        publicRepoEvent.setCommitEnabled(true);
-        return publicRepoEvent;
-    }
-
-    @Test(timeOut = TIMEOUT)
-    public void testPythonCartridgeAgent() {
-        Thread communicatorThread = new Thread(new Runnable() {
-            @Override
-            public void run() {
-                List<String> outputLines = new ArrayList<String>();
-                while (!outputStream.isClosed()) {
-                    List<String> newLines = getNewLines(outputLines, outputStream.toString());
-                    if (newLines.size() > 0) {
-                        for (String line : newLines) {
-                            if (line.contains("Subscribed to 'topology/#'")) {
-                                sleep(1000);
-                                // Send complete topology event
-                                log.info("Publishing complete topology event...");
-                                Topology topology = createTestTopology();
-                                CompleteTopologyEvent completeTopologyEvent = new CompleteTopologyEvent(topology);
-                                publishEvent(completeTopologyEvent);
-                                log.info("Complete topology event published");
-
-                                sleep(3000);
-                                // Publish member initialized event
-                                log.info("Publishing member initialized event...");
-                                MemberInitializedEvent memberInitializedEvent = new MemberInitializedEvent(
-                                        SERVICE_NAME, CLUSTER_ID, CLUSTER_INSTANCE_ID, MEMBER_ID, NETWORK_PARTITION_ID,
-                                        PARTITION_ID
-                                );
-                                publishEvent(memberInitializedEvent);
-                                log.info("Member initialized event published");
-
-                                // Simulate server socket
-                                startServerSocket(8080);
-                            }
-                            if (line.contains("Artifact repository found")) {
-                                // Send artifact updated event
-                                ArrayList<ArtifactUpdatedEvent> list = getArtifactUpdatedEventsAsParams();
-                                for (ArtifactUpdatedEvent artifactUpdatedEvent : list) {
-                                    publishEvent(artifactUpdatedEvent);
-                                }
-                            }
-
-                            if (line.contains("Exception in thread") || line.contains("ERROR")) {
-                                //throw new RuntimeException(line);
-                            }
-                            log.info(line);
-                        }
-                    }
-                    sleep(100);
-                }
-            }
-        });
-
-        communicatorThread.start();
-
-        while (!instanceActivated) {
-            // wait until the instance activated event is received.
-            sleep(2000);
-        }
-
-        assertTrue("Instance started event was not received", instanceStarted);
-        assertTrue("Instance activated event was not received", instanceActivated);
-    }
-
-    /**
-     * Publish messaging event
-     *
-     * @param event
-     */
-    private void publishEvent(Event event) {
-        String topicName = MessagingUtil.getMessageTopicName(event);
-        EventPublisher eventPublisher = EventPublisherPool.getPublisher(topicName);
-        eventPublisher.publish(event);
-    }
-
-    /**
-     * Start server socket
-     *
-     * @param port
-     */
-    private void startServerSocket(final int port) {
-        Thread socketThread = new Thread(new Runnable() {
-            @Override
-            public void run() {
-                try {
-                    ServerSocket serverSocket = new ServerSocket(port);
-                    serverSocketList.add(serverSocket);
-                    log.info("Server socket started on port: " + port);
-                    serverSocket.accept();
-                }
-                catch (IOException e) {
-                    String message = "Could not start server socket: [port] " + port;
-                    log.error(message, e);
-                    throw new RuntimeException(message, e);
-                }
-            }
-        });
-        socketThread.start();
-    }
-
-    /**
-     * Create test topology
-     *
-     * @return
-     */
-    private Topology createTestTopology() {
-        Topology topology = new Topology();
-        Service service = new Service(SERVICE_NAME, ServiceType.SingleTenant);
-        topology.addService(service);
-
-        Cluster cluster = new Cluster(service.getServiceName(), CLUSTER_ID, DEPLOYMENT_POLICY_NAME,
-                AUTOSCALING_POLICY_NAME, APP_ID);
-        service.addCluster(cluster);
-
-        Member member = new Member(service.getServiceName(), cluster.getClusterId(), MEMBER_ID,
-                CLUSTER_INSTANCE_ID, NETWORK_PARTITION_ID, PARTITION_ID, LoadBalancingIPType.Private,
-                System.currentTimeMillis());
-
-        member.setDefaultPrivateIP("10.0.0.1");
-        member.setDefaultPublicIP("20.0.0.1");
-        Properties properties = new Properties();
-        properties.setProperty("prop1", "value1");
-        member.setProperties(properties);
-        member.setStatus(MemberStatus.Created);
-        cluster.addMember(member);
-
-        return topology;
-    }
-
-    /**
-     * Return new lines found in the output
-     *
-     * @param currentOutputLines current output lines
-     * @param output             output
-     * @return
-     */
-    private List<String> getNewLines(List<String> currentOutputLines, String output) {
-        List<String> newLines = new ArrayList<String>();
-
-        if (StringUtils.isNotBlank(output)) {
-            String[] lines = output.split(NEW_LINE);
-            for (String line : lines) {
-                if (!currentOutputLines.contains(line)) {
-                    currentOutputLines.add(line);
-                    newLines.add(line);
-                }
-            }
-        }
-        return newLines;
-    }
-
-    public static String getResourcesPath() {
-        return PythonCartridgeAgentTest.class.getResource("/").getPath() + "/../../src/test/resources" + RESOURCES_PATH;
-    }
-
-    /**
-     * Sleep current thread
-     *
-     * @param time
-     */
-    private void sleep(long time) {
-        try {
-            Thread.sleep(time);
-        }
-        catch (InterruptedException ignore) {
-        }
-    }
-
-    /**
-     * Copy python agent distribution to a new folder, extract it and copy sample configuration files
-     *
-     * @return
-     */
-    private String setupPythonAgent() {
-        try {
-            log.info("Setting up python cartridge agent...");
-
-
-            String srcAgentPath = PythonCartridgeAgentTest.class.getResource("/").getPath() +
-                    "/../../../distribution/target/" + distributionName + ".zip";
-            String unzipDestPath =
-                    PythonCartridgeAgentTest.class.getResource("/").getPath() + "/../" + PYTHON_AGENT_DIR_NAME + "/";
-            //FileUtils.copyFile(new File(srcAgentPath), new File(destAgentPath));
-            unzip(srcAgentPath, unzipDestPath);
-            String destAgentPath = PythonCartridgeAgentTest.class.getResource("/").getPath() + "/../" +
-                    PYTHON_AGENT_DIR_NAME + "/" + distributionName;
-
-            String srcAgentConfPath = getResourcesPath() + "/agent.conf";
-            String destAgentConfPath = destAgentPath + "/agent.conf";
-            FileUtils.copyFile(new File(srcAgentConfPath), new File(destAgentConfPath));
-
-            String srcLoggingIniPath = getResourcesPath() + "/logging.ini";
-            String destLoggingIniPath = destAgentPath + "/logging.ini";
-            FileUtils.copyFile(new File(srcLoggingIniPath), new File(destLoggingIniPath));
-
-            String srcPayloadPath = getResourcesPath() + "/payload";
-            String destPayloadPath = destAgentPath + "/payload";
-            FileUtils.copyDirectory(new File(srcPayloadPath), new File(destPayloadPath));
-
-            log.info("Changing extension scripts permissions");
-            File extensionsPath = new File(destAgentPath + "/extensions/bash");
-            File[] extensions = extensionsPath.listFiles();
-            for (File extension : extensions) {
-                extension.setExecutable(true);
-            }
-
-            log.info("Python cartridge agent setup completed");
-
-            return destAgentPath;
-        }
-        catch (Exception e) {
-            String message = "Could not copy cartridge agent distribution";
-            log.error(message, e);
-            throw new RuntimeException(message, e);
-        }
-    }
-
-    public void unzip(String zipFilePath, String destDirectory) throws IOException {
-        File destDir = new File(destDirectory);
-        if (!destDir.exists()) {
-            destDir.mkdir();
-        }
-        ZipInputStream zipIn = new ZipInputStream(new FileInputStream(zipFilePath));
-        ZipEntry entry = zipIn.getNextEntry();
-        // iterates over entries in the zip file
-        while (entry != null) {
-            String filePath = destDirectory + File.separator + entry.getName();
-            if (!entry.isDirectory()) {
-                // if the entry is a file, extracts it
-                extractFile(zipIn, filePath);
-            } else {
-                // if the entry is a directory, make the directory
-                File dir = new File(filePath);
-                dir.mkdir();
-            }
-            zipIn.closeEntry();
-            entry = zipIn.getNextEntry();
-        }
-        zipIn.close();
-    }
-
-    private void extractFile(ZipInputStream zipIn, String filePath) throws IOException {
-        BufferedOutputStream bos = new BufferedOutputStream(new FileOutputStream(filePath));
-        byte[] bytesIn = new byte[4096];
-        int read = 0;
-        while ((read = zipIn.read(bytesIn)) != -1) {
-            bos.write(bytesIn, 0, read);
-        }
-        bos.close();
-    }
-
-    /**
-     * Execute shell command
-     *
-     * @param commandText
-     */
-    private ByteArrayOutputStreamLocal executeCommand(final String commandText) {
-        final ByteArrayOutputStreamLocal outputStream = new ByteArrayOutputStreamLocal();
-        try {
-            CommandLine commandline = CommandLine.parse(commandText);
-            DefaultExecutor exec = new DefaultExecutor();
-            PumpStreamHandler streamHandler = new PumpStreamHandler(outputStream);
-            exec.setWorkingDirectory(new File(
-                    PythonCartridgeAgentTest.class.getResource("/").getPath() + "/../" + PYTHON_AGENT_DIR_NAME));
-            exec.setStreamHandler(streamHandler);
-            ExecuteWatchdog watchdog = new ExecuteWatchdog(TIMEOUT);
-            exec.setWatchdog(watchdog);
-            exec.execute(commandline, new ExecuteResultHandler() {
-                @Override
-                public void onProcessComplete(int i) {
-                    log.info(commandText + " process completed");
-                }
-
-                @Override
-                public void onProcessFailed(ExecuteException e) {
-                    log.error(commandText + " process failed", e);
-                }
-            });
-            executorList.put(commandText, exec);
-            return outputStream;
-        }
-        catch (Exception e) {
-            log.error(outputStream.toString(), e);
-            throw new RuntimeException(e);
-        }
-    }
-
-    /**
-     * Implements ByteArrayOutputStream.isClosed() method
-     */
-    private class ByteArrayOutputStreamLocal extends ByteArrayOutputStream {
-        private boolean closed;
-
-        @Override
-        public void close() throws IOException {
-            super.close();
-            closed = true;
-        }
-
-        public boolean isClosed() {
-            return closed;
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ThriftTestServer.java
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ThriftTestServer.java b/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ThriftTestServer.java
deleted file mode 100644
index aaa9ba0..0000000
--- a/products/python-cartridge-agent/integration/src/test/java/org/apache/stratos/python.cartridge.agent/test/ThriftTestServer.java
+++ /dev/null
@@ -1,213 +0,0 @@
-package org.apache.stratos.python.cartridge.agent.test;/*
- * Licensed to the Apache Software Foundation (ASF) under one 
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- * 
- *  http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY 
- * KIND, either express or implied.  See the License for the 
- * specific language governing permissions and limitations
- * under the License.
- */
-
-import org.apache.log4j.Logger;
-import org.wso2.carbon.databridge.commons.Credentials;
-import org.wso2.carbon.databridge.commons.Event;
-import org.wso2.carbon.databridge.commons.StreamDefinition;
-import org.wso2.carbon.databridge.commons.exception.MalformedStreamDefinitionException;
-import org.wso2.carbon.databridge.commons.utils.EventDefinitionConverterUtils;
-import org.wso2.carbon.databridge.core.AgentCallback;
-import org.wso2.carbon.databridge.core.DataBridge;
-import org.wso2.carbon.databridge.core.Utils.AgentSession;
-import org.wso2.carbon.databridge.core.definitionstore.InMemoryStreamDefinitionStore;
-import org.wso2.carbon.databridge.core.exception.DataBridgeException;
-import org.wso2.carbon.databridge.core.exception.StreamDefinitionStoreException;
-import org.wso2.carbon.databridge.core.internal.authentication.AuthenticationHandler;
-import org.wso2.carbon.databridge.receiver.thrift.ThriftDataReceiver;
-import org.wso2.carbon.user.api.UserStoreException;
-
-import java.net.SocketException;
-import java.util.List;
-import java.util.concurrent.atomic.AtomicInteger;
-
-public class ThriftTestServer {
-    Logger log = Logger.getLogger(ThriftTestServer.class);
-    ThriftDataReceiver thriftDataReceiver;
-    InMemoryStreamDefinitionStore streamDefinitionStore;
-    AtomicInteger numberOfEventsReceived;
-    RestarterThread restarterThread;
-
-    public void startTestServer() throws DataBridgeException, InterruptedException {
-        ThriftTestServer thriftTestServer = new ThriftTestServer();
-        thriftTestServer.start(7611);
-        Thread.sleep(100000000);
-        thriftTestServer.stop();
-    }
-
-
-    public void addStreamDefinition(StreamDefinition streamDefinition, int tenantId)
-            throws StreamDefinitionStoreException {
-        streamDefinitionStore.saveStreamDefinitionToStore(streamDefinition, tenantId);
-    }
-
-    public void addStreamDefinition(String streamDefinitionStr, int tenantId)
-            throws StreamDefinitionStoreException, MalformedStreamDefinitionException {
-        StreamDefinition streamDefinition = EventDefinitionConverterUtils.convertFromJson(streamDefinitionStr);
-        getStreamDefinitionStore().saveStreamDefinitionToStore(streamDefinition, tenantId);
-    }
-
-    private InMemoryStreamDefinitionStore getStreamDefinitionStore() {
-        if (streamDefinitionStore == null) {
-            streamDefinitionStore = new InMemoryStreamDefinitionStore();
-        }
-        return streamDefinitionStore;
-    }
-
-    public void start(int receiverPort) throws DataBridgeException {
-        DataPublisherTestUtil.setKeyStoreParams();
-        streamDefinitionStore = getStreamDefinitionStore();
-        numberOfEventsReceived = new AtomicInteger(0);
-        DataBridge databridge = new DataBridge(new AuthenticationHandler() {
-            @Override
-            public boolean authenticate(String userName,
-                                        String password) {
-                log.info("Thrift authentication returning true");
-                return true;// allays authenticate to true
-
-            }
-
-            @Override
-            public String getTenantDomain(String userName) {
-                return "admin";
-            }
-
-            @Override
-            public int getTenantId(String tenantDomain) throws UserStoreException {
-                return -1234;
-            }
-
-            @Override
-            public void initContext(AgentSession agentSession) {
-                //To change body of implemented methods use File | Settings | File Templates.
-                log.info("Initializing Thrift agent context");
-            }
-
-            @Override
-            public void destroyContext(AgentSession agentSession) {
-
-            }
-        }, streamDefinitionStore, DataPublisherTestUtil.getDataBridgeConfigPath());
-
-        thriftDataReceiver = new ThriftDataReceiver(receiverPort, databridge);
-
-        databridge.subscribe(new AgentCallback() {
-            int totalSize = 0;
-
-            public void definedStream(StreamDefinition streamDefinition,
-                                      int tenantId) {
-                log.info("StreamDefinition " + streamDefinition);
-            }
-
-            @Override
-            public void removeStream(StreamDefinition streamDefinition, int tenantId) {
-                log.info("StreamDefinition remove " + streamDefinition);
-            }
-
-            @Override
-            public void receive(List<Event> eventList, Credentials credentials) {
-                numberOfEventsReceived.addAndGet(eventList.size());
-                log.info("Received events : " + numberOfEventsReceived);
-//                log.info("eventListSize=" + eventList.size() + " eventList " + eventList + " for username " + credentials.getUsername());
-            }
-
-        });
-
-        String address = "localhost";
-        log.info("Test Server starting on " + address);
-        thriftDataReceiver.start(address);
-        log.info("Test Server Started");
-    }
-
-    public int getNumberOfEventsReceived() {
-        if (numberOfEventsReceived != null) {
-            return numberOfEventsReceived.get();
-        } else {
-            return 0;
-        }
-    }
-
-    public void resetReceivedEvents() {
-        numberOfEventsReceived.set(0);
-    }
-
-    public void stop() {
-        thriftDataReceiver.stop();
-        log.info("Test Server Stopped");
-    }
-
-    public void stopAndStartDuration(int port, long stopAfterTimeMilliSeconds, long startAfterTimeMS)
-            throws SocketException, DataBridgeException {
-        restarterThread = new RestarterThread(port, stopAfterTimeMilliSeconds, startAfterTimeMS);
-        Thread thread = new Thread(restarterThread);
-        thread.start();
-    }
-
-    public int getEventsReceivedBeforeLastRestart() {
-        return restarterThread.eventReceived;
-    }
-
-
-    class RestarterThread implements Runnable {
-        int eventReceived;
-        int port;
-
-        long stopAfterTimeMilliSeconds;
-        long startAfterTimeMS;
-
-        RestarterThread(int port, long stopAfterTime, long startAfterTime) {
-            this.port = port;
-            stopAfterTimeMilliSeconds = stopAfterTime;
-            startAfterTimeMS = startAfterTime;
-        }
-
-        @Override
-        public void run() {
-            try {
-                Thread.sleep(stopAfterTimeMilliSeconds);
-            }
-            catch (InterruptedException e) {
-            }
-            if (thriftDataReceiver != null) {
-                thriftDataReceiver.stop();
-            }
-
-            eventReceived = getNumberOfEventsReceived();
-
-            log.info("Number of events received in server shutdown :" + eventReceived);
-            try {
-                Thread.sleep(startAfterTimeMS);
-            }
-            catch (InterruptedException e) {
-            }
-
-            try {
-                if (thriftDataReceiver != null) {
-                    thriftDataReceiver.start(DataPublisherTestUtil.LOCAL_HOST);
-                } else {
-                    start(port);
-                }
-            }
-            catch (DataBridgeException e) {
-                log.error(e);
-            }
-
-        }
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/common/client-truststore.jks
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/common/client-truststore.jks b/products/python-cartridge-agent/integration/src/test/resources/common/client-truststore.jks
deleted file mode 100644
index 2d22c24..0000000
Binary files a/products/python-cartridge-agent/integration/src/test/resources/common/client-truststore.jks and /dev/null differ

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/common/data-bridge-config.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/common/data-bridge-config.xml b/products/python-cartridge-agent/integration/src/test/resources/common/data-bridge-config.xml
deleted file mode 100644
index 13ca54c..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/common/data-bridge-config.xml
+++ /dev/null
@@ -1,75 +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.
-  -->
-
-<dataBridgeConfiguration>
-
-    <workerThreads>10</workerThreads>
-    <eventBufferCapacity>10000</eventBufferCapacity>
-    <clientTimeoutMin>30</clientTimeoutMin>
-
-    <dataReceiver name="Thrift">
-        <config name="tcpPort">7611</config>
-        <config name="sslPort">7711</config>
-    </dataReceiver>
-
-    <dataReceiver name="Binary">
-        <config name="tcpPort">9611</config>
-        <config name="sslPort">9711</config>
-        <config name="sslReceiverThreadPoolSize">100</config>
-        <config name="tcpReceiverThreadPoolSize">100</config>
-    </dataReceiver>
-
-    <!--<streamDefinitions>
-        <streamDefinition>
-            {
-             'name':'org.wso2.esb.MediatorStatistics',
-             'version':'1.3.0',
-             'nickName': 'Stock Quote Information',
-             'description': 'Some Desc',
-             'metaData':[
-             {'name':'ipAdd','type':'STRING'}
-             ],
-             'payloadData':[
-             {'name':'symbol','type':'STRING'},
-             {'name':'price','type':'DOUBLE'},
-             {'name':'volume','type':'INT'},
-             {'name':'max','type':'DOUBLE'},
-             {'name':'min','type':'Double'}
-             ]
-            }
-        </streamDefinition>
-        <streamDefinition domainName="wso2">
-            {
-             'name':'org.wso2.esb.MediatorStatistics',
-             'version':'1.3.4',
-             'nickName': 'Stock Quote Information',
-             'description': 'Some Other Desc',
-             'metaData':[
-             {'name':'ipAdd','type':'STRING'}
-             ],
-             'payloadData':[
-             {'name':'symbol','type':'STRING'},
-             {'name':'price','type':'DOUBLE'},
-             {'name':'volume','type':'INT'}
-             ]
-            }
-        </streamDefinition>
-    </streamDefinitions>-->
-
-</dataBridgeConfiguration>

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/common/log4j.properties
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/common/log4j.properties b/products/python-cartridge-agent/integration/src/test/resources/common/log4j.properties
deleted file mode 100755
index c0c6e78..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/common/log4j.properties
+++ /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.
-#
-
-# Set root logger level and appenders
-log4j.rootLogger=INFO, CONSOLE_APPENDER, FILE_APPENDER
-
-# CONSOLE_APPENDER is set to be a ConsoleAppender.
-log4j.appender.CONSOLE_APPENDER=org.apache.log4j.ConsoleAppender
-
-# The standard error log where all the warnings, errors and fatal errors will be logged
-log4j.appender.FILE_APPENDER=org.apache.log4j.FileAppender
-log4j.appender.FILE_APPENDER.File=cartridge-agent.log
-log4j.appender.FILE_APPENDER.layout=org.apache.log4j.PatternLayout
-log4j.appender.FILE_APPENDER.layout.ConversionPattern=%d{ISO8601} [%X{ip}-%X{host}] [%t] %5p %c{1} %m%n
-log4j.appender.FILE_APPENDER.threshold=DEBUG
-
-# CONSOLE_APPENDER uses PatternLayout.
-log4j.appender.CONSOLE_APPENDER.layout=org.apache.log4j.PatternLayout
-log4j.appender.CONSOLE_APPENDER.layout.ConversionPattern=[%d{ISO8601}] %5p - [%c{1}] %m%n
-
-log4j.logger.org.apache.stratos.cartridge.agent=INFO
-log4j.logger.org.apache.stratos.messaging=INFO
-log4j.logger.org.apache.stratos.common.util=DEBUG
-log4j.logger.org.wso2.andes.client=ERROR
-log4j.logger.org.apache.activemq.jndi.ActiveMQInitialContextFactory=ERROR
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/common/stratos-health-stream-def.json
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/common/stratos-health-stream-def.json b/products/python-cartridge-agent/integration/src/test/resources/common/stratos-health-stream-def.json
deleted file mode 100644
index 4d36c19..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/common/stratos-health-stream-def.json
+++ /dev/null
@@ -1 +0,0 @@
-{"name":"cartridge_agent_health_stats","version":"1.0.0","nickName":"agent health stats","description":"agent health stats","payloadData":[{"name":"cluster_id", "type": "STRING"},{"name":"cluster_instance_id", "type": "STRING"},{"name":"network_partition_id", "type": "STRING"},{"name":"member_id", "type": "STRING"},{"name":"partition_id", "type": "STRING"},{"name":"health_description", "type": "STRING"},{"name":"value", "type": "DOUBLE"}]}

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/common/thrift-agent-config.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/common/thrift-agent-config.xml b/products/python-cartridge-agent/integration/src/test/resources/common/thrift-agent-config.xml
deleted file mode 100644
index dbb2ba3..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/common/thrift-agent-config.xml
+++ /dev/null
@@ -1,64 +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.
-  -->
-
-<DataAgentsConfiguration>
-    <Agent>
-        <Name>Thrift</Name>
-        <DataEndpointClass>org.wso2.carbon.databridge.agent.endpoint.thrift.ThriftDataEndpoint</DataEndpointClass>
-        <!--<TrustSore>src/main/resources/client-truststore.jks</TrustSore>-->
-        <!--<TrustSorePassword>wso2carbon</TrustSorePassword>-->
-        <QueueSize>32768</QueueSize>
-        <BatchSize>200</BatchSize>
-        <CorePoolSize>5</CorePoolSize>
-        <MaxPoolSize>10</MaxPoolSize>
-        <SocketTimeoutMS>30000</SocketTimeoutMS>
-        <KeepAliveTimeInPool>20</KeepAliveTimeInPool>
-        <ReconnectionInterval>30</ReconnectionInterval>
-        <MaxTransportPoolSize>250</MaxTransportPoolSize>
-        <MaxIdleConnections>250</MaxIdleConnections>
-        <EvictionTimePeriod>5500</EvictionTimePeriod>
-        <MinIdleTimeInPool>5000</MinIdleTimeInPool>
-        <SecureMaxTransportPoolSize>250</SecureMaxTransportPoolSize>
-        <SecureMaxIdleConnections>250</SecureMaxIdleConnections>
-        <SecureEvictionTimePeriod>5500</SecureEvictionTimePeriod>
-        <SecureMinIdleTimeInPool>5000</SecureMinIdleTimeInPool>
-    </Agent>
-
-    <Agent>
-        <Name>Binary</Name>
-        <DataEndpointClass>org.wso2.carbon.databridge.agent.endpoint.binary.BinaryDataEndpoint</DataEndpointClass>
-        <!--<TrustSore>src/main/resources/client-truststore.jks</TrustSore>-->
-        <!--<TrustSorePassword>wso2carbon</TrustSorePassword>-->
-        <QueueSize>32768</QueueSize>
-        <BatchSize>200</BatchSize>
-        <CorePoolSize>5</CorePoolSize>
-        <MaxPoolSize>10</MaxPoolSize>
-        <SocketTimeoutMS>30000</SocketTimeoutMS>
-        <KeepAliveTimeInPool>20</KeepAliveTimeInPool>
-        <ReconnectionInterval>30</ReconnectionInterval>
-        <MaxTransportPoolSize>250</MaxTransportPoolSize>
-        <MaxIdleConnections>250</MaxIdleConnections>
-        <EvictionTimePeriod>5500</EvictionTimePeriod>
-        <MinIdleTimeInPool>5000</MinIdleTimeInPool>
-        <SecureMaxTransportPoolSize>250</SecureMaxTransportPoolSize>
-        <SecureMaxIdleConnections>250</SecureMaxIdleConnections>
-        <SecureEvictionTimePeriod>5500</SecureEvictionTimePeriod>
-        <SecureMinIdleTimeInPool>5000</SecureMinIdleTimeInPool>
-    </Agent>
-</DataAgentsConfiguration>

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/common/wso2carbon.jks
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/common/wso2carbon.jks b/products/python-cartridge-agent/integration/src/test/resources/common/wso2carbon.jks
deleted file mode 100644
index 7942c53..0000000
Binary files a/products/python-cartridge-agent/integration/src/test/resources/common/wso2carbon.jks and /dev/null differ

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/pca-testing1.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/pca-testing1.xml b/products/python-cartridge-agent/integration/src/test/resources/pca-testing1.xml
deleted file mode 100755
index a13f950..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/pca-testing1.xml
+++ /dev/null
@@ -1,29 +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.
-  -->
-
-<!DOCTYPE suite SYSTEM "http://testng.org/testng-1.0.dtd" >
-
-<suite name="PythonCartridgeAgentIntegrationSuite1">
-    <test name="PCATest">
-        <classes>
-            <class name="org.apache.stratos.python.cartridge.agent.test.PythonCartridgeAgentTest"/>
-        </classes>
-    </test>
-</suite>

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/pca-testing2.xml
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/pca-testing2.xml b/products/python-cartridge-agent/integration/src/test/resources/pca-testing2.xml
deleted file mode 100755
index c292953..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/pca-testing2.xml
+++ /dev/null
@@ -1,29 +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.
-  -->
-
-<!DOCTYPE suite SYSTEM "http://testng.org/testng-1.0.dtd" >
-
-<suite name="PythonCartridgeAgentIntegrationSuite2">
-    <test name="PCATest">
-        <classes>
-            <class name="org.apache.stratos.python.cartridge.agent.test.ADCTest"/>
-        </classes>
-    </test>
-</suite>

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-1/agent.conf
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-1/agent.conf b/products/python-cartridge-agent/integration/src/test/resources/suite-1/agent.conf
deleted file mode 100755
index 136433d..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-1/agent.conf
+++ /dev/null
@@ -1,46 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-
-[agent]
-mb.ip                                 =localhost
-mb.port                               =1885
-listen.address                        =localhost
-thrift.receiver.ip                    =localhost
-thrift.receiver.port                  =7712
-thrift.server.admin.username          =admin
-thrift.server.admin.password          =admin
-cep.stats.publisher.enabled           =true
-lb.private.ip                         =
-lb.public.ip                          =
-enable.artifact.update                =true
-auto.commit                           =false
-auto.checkout                         =true
-artifact.update.interval              =15
-artifact.clone.retries                =5
-artifact.clone.interval               =10
-port.check.timeout                    =600000
-enable.data.publisher                 =false
-monitoring.server.ip                  =localhost
-monitoring.server.port                =7612
-monitoring.server.secure.port         =7712
-monitoring.server.admin.username      =admin
-monitoring.server.admin.password      =admin
-#log.file.paths                        =/home/chamilad/dev/wso2esb-4.8.1/repository/logs/wso2carbon.log
-log.file.paths                        =/tmp/agent.screen.log
-metadata.service.url                  =https://localhost:9443
-super.tenant.repository.path          =/repository/deployment/server/
-tenant.repository.path                =/repository/tenants/
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-1/jndi.properties
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-1/jndi.properties b/products/python-cartridge-agent/integration/src/test/resources/suite-1/jndi.properties
deleted file mode 100755
index beefe3c..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-1/jndi.properties
+++ /dev/null
@@ -1,22 +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.
-#
-
-connectionfactoryName=TopicConnectionFactory
-java.naming.provider.url=tcp://localhost:61617
-java.naming.factory.initial=org.apache.activemq.jndi.ActiveMQInitialContextFactory

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-1/logging.ini
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-1/logging.ini b/products/python-cartridge-agent/integration/src/test/resources/suite-1/logging.ini
deleted file mode 100755
index 15cad9b..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-1/logging.ini
+++ /dev/null
@@ -1,52 +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.
-
-
-[formatters]
-keys=default
-
-[formatter_default]
-format=[%(asctime)s] %(levelname)s {%(filename)s:%(funcName)s} - %(message)s
-class=logging.Formatter
-
-[handlers]
-keys=console, error_file, log_file
-
-[handler_console]
-class=logging.StreamHandler
-formatter=default
-args=tuple()
-
-[handler_log_file]
-class=logging.FileHandler
-level=DEBUG
-formatter=default
-args=("agent.log", "w")
-
-[handler_error_file]
-class=logging.FileHandler
-level=ERROR
-formatter=default
-args=("error.log", "w")
-
-[loggers]
-keys=root
-
-[logger_root]
-level=DEBUG
-formatter=default
-handlers=console,error_file,log_file
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-1/payload/launch-params
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-1/payload/launch-params b/products/python-cartridge-agent/integration/src/test/resources/suite-1/payload/launch-params
deleted file mode 100755
index 165508e..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-1/payload/launch-params
+++ /dev/null
@@ -1 +0,0 @@
-APPLICATION_ID=single_group_v1,APPLICATION_PATH=/tmp/tomcat/webapps,BASH=/bin/bash,BASHOPTS=cmdhist:complete_fullquote:extquote:force_fignore:hostcomplete:interactive_comments:progcomp:promptvars:sourcepath,BASH_ALIASES=(),BASH_ARGC=(),BASH_ARGV=(),BASH_CMDS=(),BASH_LINENO=([0]="0"),BASH_SOURCE=([0]="/usr/local/bin/populate-user-data.sh"),BASH_VERSINFO=([0]="4" [1]="3" [2]="30" [3]="1" [4]="release" [5]="x86_64-pc-linux-gnu"),BASH_VERSION='4.3.30(1)-release',CARTRIDGE_ALIAS=mytomcat,CARTRIDGE_KEY=PUjpXCLujDhYr5A6,CATALINA_HOME=/opt/tomcat,CEP_IP=54.179.197.243,CEP_PORT=7711,CLUSTER_ID=php.php.domain,CLUSTER_INSTANCE_ID=single_group_v1-1,DEPENDENCY_CLUSTER_IDS=myphp.php.domain,DEPLOYMENT=default,DIRSTACK=(),EUID=0,GROUPS=(),GROUP_NAME=null,HOME=/root,HOSTNAME=mytomcat-tomcat-domain3bd3cd47-b95d-475a-aa11-3e3ddc089d49,HOSTTYPE=x86_64,HOST_NAME=mytomcat.tomcat.stratos.org,IFS=' 	,',INSTANCE_ID=null,INTERNAL=false,JAVA_HOME=/opt/jdk1.7.0_67,KUBERNETES_CLUSTER_ID=kubernetes-cluster-1,KUB
 ERNETES_PORT=tcp://10.100.0.2:443,KUBERNETES_PORT_443_TCP=tcp://10.100.0.2:443,KUBERNETES_PORT_443_TCP_ADDR=10.100.0.2,KUBERNETES_PORT_443_TCP_PORT=443,KUBERNETES_PORT_443_TCP_PROTO=tcp,KUBERNETES_RO_PORT=tcp://10.100.0.1:80,KUBERNETES_RO_PORT_80_TCP=tcp://10.100.0.1:80,KUBERNETES_RO_PORT_80_TCP_ADDR=10.100.0.1,KUBERNETES_RO_PORT_80_TCP_PORT=80,KUBERNETES_RO_PORT_80_TCP_PROTO=tcp,KUBERNETES_RO_SERVICE_HOST=10.100.0.1,KUBERNETES_RO_SERVICE_PORT=80,KUBERNETES_SERVICE_HOST=10.100.0.2,KUBERNETES_SERVICE_PORT=443,LB_CLUSTER_ID=null,LOG_LEVEL=DEBUG,MACHTYPE=x86_64-pc-linux-gnu,MB_IP=54.179.197.243,MB_PORT=1883,MEMBER_ID=php.member-1,MIN_COUNT=1,MULTITENANT=false,MYPHP_PHP_DOMAIN_1_PORT=tcp://10.100.171.218:4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP=tcp://10.100.171.218:4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_ADDR=10.100.171.218,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_PORT=4500,MYPHP_PHP_DOMAIN_1_PORT_4500_TCP_PROTO=tcp,MYPHP_PHP_DOMAIN_1_SERVICE_HOST=10.100.171.218,MYPHP_PHP_DOMAIN_1_SERVICE_PORT=4500,
 MYTOMCAT_TOMCAT_DOMAIN_1_PORT=tcp://10.100.16.250:4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP=tcp://10.100.16.250:4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_ADDR=10.100.16.250,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_PORT=4500,MYTOMCAT_TOMCAT_DOMAIN_1_PORT_4500_TCP_PROTO=tcp,MYTOMCAT_TOMCAT_DOMAIN_1_SERVICE_HOST=10.100.16.250,MYTOMCAT_TOMCAT_DOMAIN_1_SERVICE_PORT=4500,NETWORK_PARTITION_ID=network-partition-1,OPTERR=1,OPTIND=1,OSTYPE=linux-gnu,PARTITION_ID=partition-1,PATH=/usr/local/sbin:/usr/local/bin:/usr/sbin:/usr/bin:/sbin:/bin,PIPESTATUS=([0]="0"),PORTS=8080,POSIXLY_CORRECT=y,PPID=14,PRIMARY=false,PROVIDER=apache,PS4='+ ',PUPPET_DNS_AVAILABLE=null,PUPPET_ENV=false,PUPPET_HOSTNAME=puppet.apache.stratos.org,PUPPET_IP=127.0.0.1,PWD=/opt,REPO_URL=https://github.com/imesh/stratos-tomcat-applications.git,SERVICE_NAME=php,SHELL=/bin/bash,SHELLOPTS=braceexpand:hashall:interactive-comments:posix,SHLVL=2,TENANT_ID=-1234,TENANT_RANGE='*',TERM=dumb,TOKEN=eyJhbGciOiJSUzI1NiJ9.eyJleHAiOi04NzI
 0ODEyNDEsInN1YiI6ImFkbWluIiwiYXpwIjoid3I5SllVaDNtTXd6bVhHVllqWmVIWnhCV2xFYSIsImFwcElkIjoic2luZ2xlX2dyb3VwX3YxIiwiYXVkIjpbIndyOUpZVWgzbU13em1YR1ZZalplSFp4QldsRWEiXSwiaXNzIjoiaHR0cHM6XC9cL2xvY2FsaG9zdDo5NDQzXC9vYXV0aDJlbmRwb2ludHNcL3Rva2VuIiwiaWF0IjotODcyNDgwMjQwfQ.OSa1gIXUT9amhk1YEU02Yc3JtUYqanzrXh5K1YyvRXcpSiY2Ccn2BfJO0hILF5UooRcGBihzfX3979NRcvGwcUDUvOUJ0eaGPmxFZYbu0nr3xD8lhAO3fa1QYsKAvMnMdwyu2uSgSp6R6EUdVleiwlabUoDsuEcKGkIAn_VQvG0,UID=0,_=posix,LVS_VIRTUAL_IP=192.168.0.40|255.255.255.0
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-2/agent.conf
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-2/agent.conf b/products/python-cartridge-agent/integration/src/test/resources/suite-2/agent.conf
deleted file mode 100755
index 136433d..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-2/agent.conf
+++ /dev/null
@@ -1,46 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-
-[agent]
-mb.ip                                 =localhost
-mb.port                               =1885
-listen.address                        =localhost
-thrift.receiver.ip                    =localhost
-thrift.receiver.port                  =7712
-thrift.server.admin.username          =admin
-thrift.server.admin.password          =admin
-cep.stats.publisher.enabled           =true
-lb.private.ip                         =
-lb.public.ip                          =
-enable.artifact.update                =true
-auto.commit                           =false
-auto.checkout                         =true
-artifact.update.interval              =15
-artifact.clone.retries                =5
-artifact.clone.interval               =10
-port.check.timeout                    =600000
-enable.data.publisher                 =false
-monitoring.server.ip                  =localhost
-monitoring.server.port                =7612
-monitoring.server.secure.port         =7712
-monitoring.server.admin.username      =admin
-monitoring.server.admin.password      =admin
-#log.file.paths                        =/home/chamilad/dev/wso2esb-4.8.1/repository/logs/wso2carbon.log
-log.file.paths                        =/tmp/agent.screen.log
-metadata.service.url                  =https://localhost:9443
-super.tenant.repository.path          =/repository/deployment/server/
-tenant.repository.path                =/repository/tenants/
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-2/jndi.properties
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-2/jndi.properties b/products/python-cartridge-agent/integration/src/test/resources/suite-2/jndi.properties
deleted file mode 100755
index beefe3c..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-2/jndi.properties
+++ /dev/null
@@ -1,22 +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.
-#
-
-connectionfactoryName=TopicConnectionFactory
-java.naming.provider.url=tcp://localhost:61617
-java.naming.factory.initial=org.apache.activemq.jndi.ActiveMQInitialContextFactory

http://git-wip-us.apache.org/repos/asf/stratos/blob/bf76be91/products/python-cartridge-agent/integration/src/test/resources/suite-2/logging.ini
----------------------------------------------------------------------
diff --git a/products/python-cartridge-agent/integration/src/test/resources/suite-2/logging.ini b/products/python-cartridge-agent/integration/src/test/resources/suite-2/logging.ini
deleted file mode 100755
index 15cad9b..0000000
--- a/products/python-cartridge-agent/integration/src/test/resources/suite-2/logging.ini
+++ /dev/null
@@ -1,52 +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.
-
-
-[formatters]
-keys=default
-
-[formatter_default]
-format=[%(asctime)s] %(levelname)s {%(filename)s:%(funcName)s} - %(message)s
-class=logging.Formatter
-
-[handlers]
-keys=console, error_file, log_file
-
-[handler_console]
-class=logging.StreamHandler
-formatter=default
-args=tuple()
-
-[handler_log_file]
-class=logging.FileHandler
-level=DEBUG
-formatter=default
-args=("agent.log", "w")
-
-[handler_error_file]
-class=logging.FileHandler
-level=ERROR
-formatter=default
-args=("error.log", "w")
-
-[loggers]
-keys=root
-
-[logger_root]
-level=DEBUG
-formatter=default
-handlers=console,error_file,log_file
\ No newline at end of file