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/04/04 08:20:04 UTC

[26/33] Removed autoscaler, cloud-controller and stratos-manager products

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/datasources.properties
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/datasources.properties b/products/cloud-controller/modules/distribution/src/main/conf/datasources.properties
deleted file mode 100644
index 0cf8cdb..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/datasources.properties
+++ /dev/null
@@ -1,58 +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.
-#
-
-################################################################################
-## DataSources Configuration
-################################################################################
-#synapse.datasources=lookupds,reportds
-#synapse.datasources.icFactory=com.sun.jndi.rmi.registry.RegistryContextFactory
-#synapse.datasources.providerPort=2199
-## If following property is present , then assumes that there is an external JNDI provider and will not start a RMI registry
-##synapse.datasources.providerUrl=rmi://localhost:2199
-#
-#synapse.datasources.lookupds.registry=Memory
-#synapse.datasources.lookupds.type=BasicDataSource
-#synapse.datasources.lookupds.driverClassName=org.apache.derby.jdbc.ClientDriver
-#synapse.datasources.lookupds.url=jdbc:derby://localhost:1527/lookupdb;create=false
-## Optionally you can specifiy a specific password provider implementation which overrides any globally configured provider
-#synapse.datasources.lookupds.secretProvider=org.apache.synapse.commons.security.secret.handler.SharedSecretCallbackHandler
-#synapse.datasources.lookupds.username=esb
-## Depending on the password provider used, you may have to use an encrypted password here!
-#synapse.datasources.lookupds.password=esb
-#synapse.datasources.lookupds.dsName=lookupdb
-#synapse.datasources.lookupds.maxActive=100
-#synapse.datasources.lookupds.maxIdle=20
-#synapse.datasources.lookupds.maxWait=10000
-#
-#synapse.datasources.reportds.registry=JNDI
-#synapse.datasources.reportds.type=PerUserPoolDataSource
-#synapse.datasources.reportds.cpdsadapter.factory=org.apache.commons.dbcp.cpdsadapter.DriverAdapterCPDS
-#synapse.datasources.reportds.cpdsadapter.className=org.apache.commons.dbcp.cpdsadapter.DriverAdapterCPDS
-#synapse.datasources.reportds.cpdsadapter.name=cpds
-#synapse.datasources.reportds.dsName=reportdb
-#synapse.datasources.reportds.driverClassName=org.apache.derby.jdbc.ClientDriver
-#synapse.datasources.reportds.url=jdbc:derby://localhost:1527/reportdb;create=false
-## Optionally you can specifiy a specific password provider implementation which overrides any globally configured provider
-#synapse.datasources.reportds.secretProvider=org.apache.synapse.commons.security.secret.handler.SharedSecretCallbackHandler
-#synapse.datasources.reportds.username=esb
-## Depending on the password provider used, you may have to use an encrypted password here!
-#synapse.datasources.reportds.password=esb
-#synapse.datasources.reportds.maxActive=100
-#synapse.datasources.reportds.maxIdle=20
-#synapse.datasources.reportds.maxWait=10000
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/embedded-ldap.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/embedded-ldap.xml b/products/cloud-controller/modules/distribution/src/main/conf/embedded-ldap.xml
deleted file mode 100644
index 144628e..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/embedded-ldap.xml
+++ /dev/null
@@ -1,165 +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.
-  -->
-
-<!--
-	All carbon based products comes with a LDAP user store.
-	For this we use an embedded LDAP in carbon based products.
-	This file contains necessary configurations to control the behavior of embedded LDAP.
-	You may use this file to enable, disable LDAP server, configure connection admin password, etc ...
-	In addition to embedded-ldap server configurations this file also has Kerberos KDC (Key Distribution Center)
-	specific configurations.
--->
-
-<EmbeddedLDAPConfig>
-
-  <!--
-	LDAP server configurations
-	==========================
-	This section contains LDAP server specific configurations.
-
-	Property                Usage
-	=======                 ====
-	enable                  If true the embedded LDAP server will start when server starts up.
-				            Else embedded LDAP server will not start. Thus user has to use a different
-				            user store.
-	instanceid              An id given to the LDAP server instance.
-	connectionPassword      The password of the admin. (uid=admin,ou=system)
-	workingDirectory        Location where LDAP will store its schema files.
-	AdminEntryObjectClass   Object class which encapsulate attributes needed by claims.
-	allowAnonymousAccess    Should allow users to access LDAP server without credentials. Default false.
-	accessControlEnabled    Should access control be enabled among partitions. Default true.
-	saslHostName            Default host name to be used in SASL (Simple Authentication and Security Layer).
-				            This property comes from apacheds implementation itself.
-	saslPrincipalName       Default SASL principal name. Again this property also comes from apacheds implementation
-				            itself.
-  -->
-  <EmbeddedLDAP>
-    <Property name="enable">false</Property>
-    <Property name="port">${Ports.EmbeddedLDAP.LDAPServerPort}</Property>
-    <Property name="instanceId">default</Property>
-    <Property name="connectionPassword">admin</Property>
-    <Property name="workingDirectory">.</Property>
-    <Property name="AdminEntryObjectClass">wso2Person</Property>
-    <Property name="allowAnonymousAccess">false</Property>
-    <Property name="accessControlEnabled">true</Property>
-    <Property name="denormalizeOpAttrsEnabled">false</Property>
-    <Property name="maxPDUSize">2000000</Property>
-    <Property name="saslHostName">localhost</Property>
-    <Property name="saslPrincipalName">ldap/localhost@EXAMPLE.COM</Property>
-  </EmbeddedLDAP>
-
-  <!--
-	Default partition configurations
-	================================
-	When embedded LDAP server starts for the first time it will create a default partition.
-	Following properties configure values for the default partition.
-
-	Property                        Usage
-	=======                         =====
-	id                              Each partition is given an id. The id given to the default paritition.
-	realm                           Realm is the place where we store user principals and service principals.
-                                        The name of the realm for default partition.
-	kdcPassword                     This parameter is used when KDC (Key Distribution Center) is enabled. In apacheds
-                                        KDC also has a server principal. This defines a password for KDC server principal.
-	ldapServerPrinciplePassword     If LDAP server is also defined as a server principal, this will be the password.
-
-  -->
-  <DefaultPartition>
-    <Property name="id">root</Property>
-    <Property name="realm">wso2.org</Property>
-    <Property name="kdcPassword">secret</Property>
-    <Property name="ldapServerPrinciplePassword">randall</Property>
-  </DefaultPartition>
-
-  <!--
-	Default partition admin configurations
-	======================================
-	In a multi-tenant scenario each tenant will have a separate partition. Thus tenant admin will be the partition admin.
-	Following configurations define admin attributes for above created default partition.
-
-	Property            Usage
-	========            =====
-	uid                 UID attribute for partition admin.
-	commonName          The cn attribute for admin
-	lastName            The sn attribute for admin
-	email               The email attribute for admin
-	passwordType        The password hashing mechanism. Following hashing mechanisms are available, "SHA", "MD5".
-                        "Plaintext" is also a valid value. If KDC is enabled password type will be enforced to be
-                        plain text.
-  -->
-  <PartitionAdmin>
-    <Property name="uid">admin</Property>
-    <Property name="firstName">admin</Property>
-    <Property name="lastName">admin</Property>
-    <Property name="email">admin@wso2.com</Property>
-    <Property name="password">admin</Property>
-    <Property name="passwordType">SHA</Property>
-  </PartitionAdmin>
-
-  <!--
-	Default partition admin's group configuration
-	=============================================
-	Embedded LDAP is capable of keeping group information also.
-	If LDAP groups are enabled in user store (usr-mgt.xml) group information will be
-	recorded in a separate sub-context. Following configuration defines the group
-	properties.
-
-	Property                Usage
-	=======                 =====
-	adminRoleName		    The name of the role/group that admin should be included.
-	groupNameAttribute	    The attribute which group name will be recorded.
-	memberNameAttribute	    The attribute which memebers are recorded.
-  -->
-  <PartitionAdminGroup>
-    <Property name="adminRoleName">admin</Property>
-    <Property name="groupNameAttribute">cn</Property>
-    <Property name="memberNameAttribute">member</Property>
-  </PartitionAdminGroup>
-
-    <!--
-      KDC configurations
-      =================
-      Following configurations are applicable to KDC server. Generally, the KDC is only enabled in
-      Identity Server. You may enable KDC server if you wish to do so. But if you dont have any Kerberos specific
-      programs, it is recommended to disable KDC server.
-
-      Property                          Usage
-      =======                           =====
-      name                              Name given to default KDC server.
-      enabled                           If true a KDC server will start when starting LDAP server.
-                                          Else a KDC server will not start with a LDAP server.
-      protocol                          Default protocol to be used in KDC communication. Default is UDP.
-      maximumTicketLifeTime             The maximum life time of a ticket issued by the KDC.
-      maximumRenewableLifeTime          Life time which a ticket can be used by renewing it several times.
-      preAuthenticationTimeStampEnabled Pre-authentication is a feature in latest Kerberos protocol.
-                                          This property says whether to enable it or disable it.
-    -->
-  <KDCServer>
-    <Property name="name">defaultKDC</Property>
-    <Property name="enabled">false</Property>
-    <Property name="protocol">UDP</Property>
-    <Property name="host">localhost</Property>
-    <Property name="port">${Ports.EmbeddedLDAP.KDCServerPort}</Property>
-    <Property name="maximumTicketLifeTime">8640000</Property>
-    <Property name="maximumRenewableLifeTime">604800000</Property>
-    <Property name="preAuthenticationTimeStampEnabled">true</Property>
-  </KDCServer>
-
-</EmbeddedLDAPConfig>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/event-broker.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/event-broker.xml b/products/cloud-controller/modules/distribution/src/main/conf/event-broker.xml
deleted file mode 100644
index 5f27759..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/event-broker.xml
+++ /dev/null
@@ -1,66 +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.
-
--->
-
-<!--
-this is the configuration file for the carbon event broker component. this configuration file configures the various subsystems of the event
-broker compoent and parameters.
--->
-<eventBrokerConfig xmlns="http://wso2.org/carbon/event/broker">
-    <eventBroker name="carbonEventBroker" class = "org.wso2.carbon.event.core.internal.CarbonEventBrokerFactory">
-         <!-- topic manager implemenation class.-->
-        <topicManager name="TopicManager" class="org.wso2.carbon.event.core.internal.topic.registry.RegisistryTopicManagerFactory">
-            <!-- root node of the topic tree -->
-            <topicStoragePath>event/topics</topicStoragePath>
-        </topicManager>
-        <!-- subscriptionmnager implementaion. subscription manager persits the
-        subscriptions at the registry.  users can configure the topics root node and the topicIndex path -->
-        <subscriptionManager name="subscriptionManager"
-                             class="org.wso2.carbon.event.core.internal.subscription.registry.RegistrySubscriptionManagerFactory">
-            <topicStoragePath>event/topics</topicStoragePath>
-            <indexStoragePath>event/topicIndex</indexStoragePath>
-        </subscriptionManager>
-
-        <!-- delivary manager inmplementation. delivary manager does actual delivary part of the event broker -->
-        <deliveryManager name="deliveryManager"
-                         class="org.wso2.carbon.event.core.internal.delivery.jms.QpidJMSDeliveryManagerFactory"
-                         type="local">
-           <!--  <remoteMessageBroker>
-                <hostName>localhost</hostName>
-                <servicePort>9443</servicePort>
-                <webContext>/</webContext>
-                <userName>admin</userName>
-                <password>admin</password>
-                <qpidPort>5672</qpidPort>
-                <clientID>clientID</clientID>
-                <virtualHostName>carbon</virtualHostName>
-            </remoteMessageBroker> -->
-        </deliveryManager>
-
-         <!-- when publising an event event broker uses a seperate thread pool with an executor. following parameters configure different parameters of that -->
-        <eventPublisher>
-            <minSpareThreads>5</minSpareThreads>
-            <maxThreads>50</maxThreads>
-            <maxQueuedRequests>1000</maxQueuedRequests>
-            <keepAliveTime>1000</keepAliveTime>
-        </eventPublisher>
-    </eventBroker>
-</eventBrokerConfig>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/jaas.conf
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/jaas.conf b/products/cloud-controller/modules/distribution/src/main/conf/jaas.conf
deleted file mode 100644
index b560cba..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/jaas.conf
+++ /dev/null
@@ -1,30 +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.
-#
-
-Server {
-       org.apache.zookeeper.server.auth.DigestLoginModule required
-       user_super="admin"
-       user_admin="admin";
-};
-Client {
-       org.apache.zookeeper.server.auth.DigestLoginModule required
-       username="admin"
-       password="admin";
-};

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/jndi.properties
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/jndi.properties b/products/cloud-controller/modules/distribution/src/main/conf/jndi.properties
deleted file mode 100644
index e4b3f0e..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/jndi.properties
+++ /dev/null
@@ -1,24 +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
-connectionfactory.topicConnectionfactory=amqp://admin:admin@carbon/carbon?brokerlist='tcp://localhost:5677'
-java.naming.factory.initial=org.wso2.andes.jndi.PropertiesFileInitialContextFactory

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/log4j.properties
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/log4j.properties b/products/cloud-controller/modules/distribution/src/main/conf/log4j.properties
deleted file mode 100644
index 0af25b5..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/log4j.properties
+++ /dev/null
@@ -1,193 +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.
-#
-
-#
-# This is the log4j configuration file used by Cloud Controller.
-#
-
-log4j.rootLogger=INFO, CARBON_CONSOLE, CARBON_LOGFILE, CARBON_MEMORY, CARBON_SYS_LOG
-
-log4j.logger.AUDIT_LOG=INFO, AUDIT_LOGFILE
-log4j.logger.org.apache.axis2.wsdl.codegen.writer.PrettyPrinter=ERROR
-log4j.logger.org.apache.axis2.clustering=INFO
-log4j.logger.org.apache=INFO
-log4j.logger.org.apache.catalina=WARN
-log4j.logger.org.apache.tomcat=WARN
-log4j.logger.org.wso2.carbon.apacheds=WARN
-log4j.logger.org.apache.directory.server.ldap=WARN
-log4j.logger.org.apache.directory.server.core.event=WARN
-log4j.logger.com.atomikos=INFO,ATOMIKOS
-log4j.logger.org.quartz=WARN
-log4j.logger.org.apache.jackrabbit.webdav=WARN
-log4j.logger.org.apache.juddi=ERROR
-log4j.logger.org.apache.commons.digester.Digester=WARN
-log4j.logger.org.apache.jasper.compiler.TldLocationsCache=WARN
-log4j.logger.org.apache.qpid=WARN
-log4j.logger.org.apache.qpid.server.Main=INFO
-log4j.logger.qpid.message=WARN
-log4j.logger.qpid.message.broker.listening=INFO
-log4j.logger.org.apache.tiles=WARN
-log4j.logger.org.apache.commons.httpclient=ERROR
-log4j.logger.org.apache.coyote=WARN
-log4j.logger.org.apache.solr=ERROR
-log4j.logger.org.infinispan=WARN
-log4j.logger.org.jgroups=ERROR
-log4j.logger.me.prettyprint.cassandra.hector.TimingLogger=ERROR
-log4j.logger.org.wso2=INFO
-log4j.logger.org.apache.axis2.enterprise=FATAL, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.opensaml.xml=WARN, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.directory.shared.ldap=WARN, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.directory.server.ldap.handlers=WARN, CARBON_LOGFILE, CARBON_MEMORY 
-
-# Following are to remove false error messages from startup (IS)
-log4j.logger.org.apache.directory.shared.ldap.entry.DefaultServerAttribute=FATAL, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.directory.server.core.DefaultDirectoryService=ERROR, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.directory.shared.ldap.ldif.LdifReader=ERROR, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.directory.server.ldap.LdapProtocolHandler=ERROR, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.directory.server.core=ERROR, CARBON_LOGFILE, CARBON_MEMORY
-
-# Hive logging configuration
-log4j.logger.DataNucleus=ERROR
-log4j.logger.Datastore=ERROR
-log4j.logger.Datastore.Schema=ERROR
-log4j.logger.JPOX.Datastore=ERROR
-log4j.logger.JPOX.Plugin=ERROR
-log4j.logger.JPOX.MetaData=ERROR
-log4j.logger.JPOX.Query=ERROR
-log4j.logger.JPOX.General=ERROR
-log4j.logger.JPOX.Enhancer=ERROR
-log4j.logger.org.apache.hadoop.hive=WARN
-log4j.logger.hive=WARN
-log4j.logger.ExecMapper=WARN
-log4j.logger.ExecReducer=WARN
-
-# Apache Stratos logging configuration
-log4j.logger.org.apache.stratos.cloud.controller=INFO
-log4j.logger.org.apache.stratos.messaging=INFO
-
-# Cassandra logging configuration
-log4j.logger.org.apache.cassandra.db=WARN
-log4j.logger.org.apache.cassandra.service=WARN
-log4j.logger.org.apache.cassandra.thrift=WARN
-log4j.logger.org.apache.cassandra.io.sstable=WARN
-log4j.logger.org.apache.cassandra.utils=WARN
-#log4j.logger.org.apache.cassandra.io.sstable=WARN
-#log4j.logger.org.apache.cassandra.io.sstable=WARN
-
-# Andes logging configuration
-log4j.logger.org.wso2.andes.server.handler.ConnectionStartOkMethodHandler=WARN
-log4j.logger.org.wso2.andes.server.handler.ChannelOpenHandler=WARN
-log4j.logger.org.wso2.andes.server.handler.ChannelCloseHandler=WARN
-log4j.logger.org.wso2.andes.server.AMQChannel=WARN
-log4j.logger.org.wso2.andes.server.handler.ConnectionCloseMethodHandler=WARN
-log4j.logger.org.wso2.andes.server.handler.QueueDeclareHandler=WARN
-log4j.logger.org.wso2.andes.server.handler.QueueBindHandler=WARN
-log4j.logger.org.wso2.andes.server.virtualhost.VirtualHostConfigRecoveryHandler=WARN
-log4j.logger.trace.messages=TRACE,CARBON_TRACE_LOGFILE
-
-log4j.additivity.org.apache.axis2.clustering=false
-log4j.additivity.com.atomikos=false
-
-# CARBON_CONSOLE is set to be a ConsoleAppender using a PatternLayout.
-log4j.appender.CARBON_CONSOLE=org.apache.log4j.ConsoleAppender
-log4j.appender.CARBON_CONSOLE.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-# ConversionPattern will be overridden by the configuration setting in the DB
-log4j.appender.CARBON_CONSOLE.layout.ConversionPattern=[%d] %P%5p {%c} - %x %m%n
-log4j.appender.CARBON_CONSOLE.layout.TenantPattern=%U%@%D[%T]
-log4j.appender.CARBON_CONSOLE.threshold=DEBUG
-
-# The memory appender for logging
-log4j.appender.CARBON_MEMORY=org.wso2.carbon.logging.appender.CarbonMemoryAppender
-log4j.appender.CARBON_MEMORY.bufferSize=2000
-log4j.appender.CARBON_MEMORY.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-# ConversionPattern will be overridden by the configuration setting in the DB
-log4j.appender.CARBON_MEMORY.layout.ConversionPattern=TID: [%T] [%S] [%d] %P%5p {%c} - %x %m {%c}%n
-log4j.appender.CARBON_MEMORY.layout.TenantPattern=%U%@%D [%T] [%S]
-log4j.appender.CARBON_MEMORY.columnList=%T,%S,%A,%d,%c,%p,%m,%H,%I,%Stacktrace
-log4j.appender.CARBON_MEMORY.threshold=DEBUG
-
-# CARBON_LOGFILE is set to be a DailyRollingFileAppender using a PatternLayout.
-log4j.appender.CARBON_LOGFILE=org.apache.log4j.DailyRollingFileAppender
-# Log file will be overridden by the configuration setting in the DB
-# This path should be relative to WSO2 Carbon Home
-log4j.appender.CARBON_LOGFILE.File=${carbon.home}/repository/logs/${instance.log}/wso2carbon${instance.log}.log
-log4j.appender.CARBON_LOGFILE.Append=true
-log4j.appender.CARBON_LOGFILE.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-# ConversionPattern will be overridden by the configuration setting in the DB
-log4j.appender.CARBON_LOGFILE.layout.ConversionPattern=TID: [%T] [%S] [%d] %P%5p {%c} - %x %m {%c}%n
-log4j.appender.CARBON_LOGFILE.layout.TenantPattern=%U%@%D [%T] [%S]
-log4j.appender.CARBON_LOGFILE.threshold=DEBUG
-
-log4j.appender.CARBON_SYS_LOG = org.apache.log4j.net.SyslogAppender
-log4j.appender.CARBON_SYS_LOG.layout=org.apache.log4j.PatternLayout
-log4j.appender.CARBON_SYS_LOG.layout.ConversionPattern=[%d] %5p {%c} - %x %m {%c}%n
-log4j.appender.CARBON_SYS_LOG.SyslogHost=localhost
-log4j.appender.CARBON_SYS_LOG.Facility=USER
-log4j.appender.CARBON_SYS_LOG.threshold=DEBUG
-
-# CASSANDRA is set to be a CassandraAppender using a PatternLayout to send logs to cassandra keyspace
-log4j.appender.CASSANDRA=org.wso2.carbon.logging.appender.LogEventAppender
-log4j.appender.CASSANDRA.keyspace=LogEntry
-log4j.appender.CASSANDRA.colFamily=logs
-log4j.appender.CASSANDRA.url=localhost:9160
-log4j.appender.CASSANDRA.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-log4j.appender.CASSANDRA.columnList=%T,%S,%A,%d,%c,%p,%m,%H,%Stacktrace
-
-# LOGEVENT is set to be a LogEventAppender using a PatternLayout to send logs to LOGEVENT 
-log4j.appender.LOGEVENT=org.wso2.carbon.logging.appender.LogEventAppender
-log4j.appender.LOGEVENT.url=tcp://10.100.3.103:7611
-log4j.appender.LOGEVENT.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-log4j.appender.LOGEVENT.columnList=%T,%S,%A,%d,%c,%p,%m,%H,%I,%Stacktrace
-log4j.appender.LOGEVENT.userName=admin
-log4j.appender.LOGEVENT.password=admin
-
-# Appender config to CARBON_TRACE_LOGFILE
-log4j.appender.CARBON_TRACE_LOGFILE=org.apache.log4j.DailyRollingFileAppender
-log4j.appender.CARBON_TRACE_LOGFILE.File=${carbon.home}/repository/logs/${instance.log}/wso2carbon-trace-messages${instance.log}.log
-log4j.appender.CARBON_TRACE_LOGFILE.Append=true
-log4j.appender.CARBON_TRACE_LOGFILE.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-log4j.appender.CARBON_TRACE_LOGFILE.layout.ConversionPattern=[%d] %P%5p {%c} - %x %m {%c}%n
-log4j.appender.CARBON_TRACE_LOGFILE.layout.TenantPattern=%U%@%D [%T] [%S]
-log4j.appender.CARBON_TRACE_LOGFILE.threshold=TRACE
-log4j.additivity.trace.messages=false
-
-# Appender config to AUDIT_LOGFILE
-log4j.appender.AUDIT_LOGFILE=org.apache.log4j.DailyRollingFileAppender
-log4j.appender.AUDIT_LOGFILE.File=${carbon.home}/repository/logs/audit.log
-log4j.appender.AUDIT_LOGFILE.Append=true
-log4j.appender.AUDIT_LOGFILE.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-log4j.appender.AUDIT_LOGFILE.layout.ConversionPattern=[%d] %P%5p - %x %m %n
-log4j.appender.AUDIT_LOGFILE.layout.TenantPattern=%U%@%D [%T] [%S]
-log4j.appender.AUDIT_LOGFILE.threshold=INFO
-log4j.additivity.AUDIT_LOG=false
-
-# Appender config to send Atomikos transaction logs to new log file tm.out.
-log4j.appender.ATOMIKOS = org.apache.log4j.RollingFileAppender
-log4j.appender.ATOMIKOS.File = repository/logs/tm.out
-log4j.appender.ATOMIKOS.Append = true
-log4j.appender.ATOMIKOS.layout = org.apache.log4j.PatternLayout
-log4j.appender.ATOMIKOS.layout.ConversionPattern=%p %t %c - %m%n
-
-# This file is used to override the default logger settings, and is used to remove unwanted logs from Shindig appearing on the console.
-
-# Specification of Handler used by Console Logger
-handlers=java.util.logging.ConsoleHandler
-
-# Replacing default INFO level with SEVERE
-java.util.logging.ConsoleHandler.level=SEVERE

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/rule-component.conf
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/rule-component.conf b/products/cloud-controller/modules/distribution/src/main/conf/rule-component.conf
deleted file mode 100644
index 6652551..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/rule-component.conf
+++ /dev/null
@@ -1,21 +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.
--->
-<RuleServer>
-    <RuleEngineProvider class="org.wso2.carbon.rule.engine.jsr94.JSR94BackendRuntimeFactory"/>
-</RuleServer>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/registry.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/registry.xml b/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/registry.xml
deleted file mode 100644
index f259c7a..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/registry.xml
+++ /dev/null
@@ -1,26 +0,0 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<!--
-  ~ 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.
-  -->
-
-<!-- Registry declaration of the WSO2 ESB -->
-<registry xmlns="http://ws.apache.org/ns/synapse" provider="org.wso2.carbon.mediation.registry.WSO2Registry">
-    <!--all resources loaded from the URL registry would be
-    cached for this number of milliseconds -->
-    <parameter name="cachableDuration">15000</parameter>
-</registry>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/errorHandler.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/errorHandler.xml b/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/errorHandler.xml
deleted file mode 100644
index 8621bee..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/errorHandler.xml
+++ /dev/null
@@ -1,31 +0,0 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<!--
-  ~ 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.
-  -->
-    <sequence name="errorHandler" xmlns="http://ws.apache.org/ns/synapse">
-	<log level="full">
-        	<property name="MESSAGE" value="Executing default 'fault' sequence"/>
-        	<property name="ERROR_CODE" expression="get-property('ERROR_CODE')"/>
-        	<property name="ERROR_MESSAGE" expression="get-property('ERROR_MESSAGE')"/>
-    	</log>
-        <makefault response="true">
-            <code value="tns:Receiver" xmlns:tns="http://www.w3.org/2003/05/soap-envelope"/>
-            <reason value="COULDN'T SEND THE MESSAGE TO THE SERVER."/>
-        </makefault>
-        <send/>
-    </sequence>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/fault.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/fault.xml b/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/fault.xml
deleted file mode 100644
index 9d2d8f7..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/fault.xml
+++ /dev/null
@@ -1,76 +0,0 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<!--
-  ~ 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.
-  -->
-
-<!-- Default fault sequence shipped with the Apache Synapse -->
-<sequence xmlns="http://ws.apache.org/ns/synapse" name="fault">
-
-    <!-- Log the message at the full log level with the ERROR_MESSAGE and the ERROR_CODE-->
-    <!-- log level="full">
-        <property name="MESSAGE" value="Executing default 'fault' sequence"/>
-        <property name="ERROR_CODE" expression="get-property('ERROR_CODE')"/>
-        <property name="ERROR_MESSAGE" expression="get-property('ERROR_MESSAGE')"/>
-    </log -->
-
-    <!-- Drops the messages by default if there is a fault -->
-    <script language="js"><![CDATA[
-        mc.setPayloadXML(
-           <{mc.getProperty("SERVICENAME")}Response xmlns="org.wso2.gateway">
-            <Timestamp>{new Date()}</Timestamp>
-            <Ack>Failure</Ack>
-            <Errors>
-             <ShortMessage>Gateway Error</ShortMessage>
-             <LongMessage>{mc.getProperty("ERROR_MESSAGE")}</LongMessage>
-             <ErrorCode>500</ErrorCode>
-             <SeverityCode>Error</SeverityCode>
-             <ErrorClassification>RequestError</ErrorClassification>
-            </Errors>
-            <ServiceName>{mc.getProperty("SERVICENAME")}</ServiceName>
-            <ResponseCode>{mc.getProperty("HTTP_SC")}</ResponseCode>
-            <ContentType>{mc.getProperty("Content-Type")}</ContentType>
-            <Version>1.5.1</Version>
-           </{mc.getProperty("SERVICENAME")}Response>
-        );
-      ]]></script>
-    <switch source="get-property('ERROR_CODE')">
-        <case regex="101504">   <!-- TIMEOUT ERROR -->
-            <property name="HTTP_SC" value="504" scope="axis2"/>
-            <sequence key="seq_timeout"/>
-        </case>
-        <case regex="303001">
-            <property name="HTTP_SC" value="503" scope="axis2"/>
-            <sequence key="seq_endpoint_down"/>
-        </case>
-        <case regex="111503">
-            <property name="HTTP_SC" value="503" scope="axis2"/>
-            <sequence key="seq_endpoint_down"/>
-        </case>
-        <default>
-            <property name="HTTP_SC" value="500" scope="axis2"/>
-        </default>
-    </switch>
-    <property name="NO_ENTITY_BODY" scope="axis2" action="remove"/>
-    <header name="To" action="remove"/>
-    <property name="RESPONSE" value="true"/>
-    <property name="messageType" value="text/xml" scope="axis2"/>
-    <property name="ContentType" value="text/xml" scope="axis2"/>
-
-    <send/>
-
-</sequence>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/main.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/main.xml b/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/main.xml
deleted file mode 100644
index c4dbf5b..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/sequences/main.xml
+++ /dev/null
@@ -1,110 +0,0 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<!--
-  ~ 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.
-  -->
-
-<!-- Default main sequence shipped with the WSO2 ESB -->
-<sequence xmlns="http://ws.apache.org/ns/synapse" name="main" onError="fault">
-    <description>The main sequence for the message mediation</description>
-
-    <in>
-        <property name="REQUEST_HOST_HEADER" expression="$trp:host" scope="axis2"/>
-        <property name="SERVICE_PREFIX" expression="$axis2:SERVICE_PREFIX"/>
-        <send>
-            <!--endpoint name="sdlbEndpoint">
-                <session type="http">-->
-                    <!-- Session timout is 15mins-->
-                    <!--sessionTimeout>900000</sessionTimeout>
-                </session>
-                <serviceDynamicLoadbalance failover="true"
-                                           algorithm="org.apache.synapse.endpoints.algorithms.RoundRobin"
-                                           configuration="$system:loadbalancer.xml"/>
-            </endpoint>
-            -->
-	          <!--endpoint name="tenantAwareLBEndpoint">
-                <class name ="org.wso2.carbon.lb.endpoint.endpoint.TenantAwareLoadBalanceEndpoint">
-                     <parameter name="algorithm"> org.apache.synapse.endpoints.algorithms.RoundRobin</parameter>
-                     <parameter name="configuration">$system:loadbalancer.conf</parameter>
-                     <parameter name="failover">true</parameter>          
-                     <parameter name="sessionTimeout">900000</parameter>
-  	            </class>
- 	          </endpoint-->
-        </send>
-        <drop/>
-    </in>
-
-    <out>
-        <!-- Handling status codes: 301, 302 Redirection -->
-        <filter source="$trp:Location" regex=".+">
-            <property name="LB_SP_Host" expression="$ctx:SERVICE_PREFIX"
-                      pattern="(^http.?://\b)(.*):(\d*)(.*)" group="2"/>
-
-            <property name="LB_Location_Protocol" expression="$trp:Location"
-                      pattern="(^http.?://\b)(.*):(\d*)(.*)" group="1"/>
-            <property name="LB_Location_Host" expression="$trp:Location"
-                      pattern="(^http.?://\b)(.*):(\d*)(.*)" group="2"/>
-            <property name="LB_Location_Path" expression="$trp:Location"
-                      pattern="(^http.?://\b)(.*):(\d*)(.*)" group="4"/>
-
-            <!--<log level="custom">
-               <property name="ameera-ocation" expression="$trp:Location"/>
-               <property name="ameera-sprefix" expression="$ctx:SERVICE_PREFIX"/>
-           </log>-->
-
-            <filter xpath="fn:lower-case($ctx:LB_SP_Host)=fn:lower-case($ctx:LB_Location_Host)">
-                <then>
-                    <switch source="fn:lower-case($ctx:LB_Location_Protocol)">
-                        <case regex="https://">
-                            <property name="Location"
-                                      expression="fn:concat($ctx:LB_Location_Protocol,$ctx:LB_REQUEST_HOST,$ctx:LB_Location_Path)"
-                                      scope="transport"/>
-                        </case>
-                        <case regex="http://">
-                            <property name="Location"
-                                      expression="fn:concat($ctx:LB_Location_Protocol,$ctx:LB_REQUEST_HOST,$ctx:LB_Location_Path)"
-                                      scope="transport"/>
-                        </case>
-                    </switch>
-                </then>
-
-                <else>
-                    <filter xpath="$ctx:LB_REQUEST_HOST=fn:lower-case($ctx:LB_Location_Host)">
-                        <switch source="fn:lower-case($ctx:LB_Location_Protocol)">
-                            <case regex="https://">
-                                <property name="Location"
-                                          expression="fn:concat($ctx:LB_Location_Protocol,$ctx:LB_REQUEST_HOST,$ctx:LB_Location_Path)"
-                                          scope="transport"/>
-                            </case>
-                            <case regex="http://">
-                                <property name="Location"
-                                          expression="fn:concat($ctx:LB_Location_Protocol,$ctx:LB_REQUEST_HOST,$ctx:LB_Location_Path)"
-                                          scope="transport"/>
-                            </case>
-                        </switch>
-                    </filter>
-                </else>
-            </filter>
-        </filter>
-
-        <!-- Send the messages where they have been sent (i.e. implicit To EPR) -->
-        <property name="messageType" value="text/html" scope="axis2"/>
-        <send/>
-        <drop/>
-    </out>
-
-</sequence>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/synapse.xml
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/synapse.xml b/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/synapse.xml
deleted file mode 100755
index d8ad52d..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/synapse-configs/default/synapse.xml
+++ /dev/null
@@ -1,25 +0,0 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<!--
-  ~ 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.
-  -->
-
-<!-- The default synapse configuration shipped with the WSO2 Elastic  Load Balancer
- -->
-
-<definitions xmlns="http://ws.apache.org/ns/synapse">
-</definitions>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/synapse.properties
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/synapse.properties b/products/cloud-controller/modules/distribution/src/main/conf/synapse.properties
deleted file mode 100755
index c3cbdb4..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/synapse.properties
+++ /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.
-#
-
-#synapse.threads.core = 20
-#synapse.threads.max = 100
-#synapse.threads.keepalive = 5
-#synapse.threads.qlen = 10
-#synapse.threads.group = synapse-thread-group
-#synapse.threads.idprefix = SynapseWorker
-
-synapse.sal.endpoints.sesssion.timeout.default=600000
-
-#In memory statistics cleaning state 
-statistics.clean.enable=false
-
-# Dependency tracking Synapse observer
-# Comment out to disable dependency management
-synapse.observers=org.wso2.carbon.mediation.dependency.mgt.DependencyTracker
-
-# User defined wsdlLocator/Schema Resolver Implementations.
-# synapse.wsdl.resolver=org.wso2.carbon.mediation.initializer.RegistryWSDLLocator
-# synapse.schema.resolver=org.wso2.carbon.mediation.initializer.RegistryXmlSchemaURIResolver
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/cloud-controller/modules/distribution/src/main/conf/zoo.cfg
----------------------------------------------------------------------
diff --git a/products/cloud-controller/modules/distribution/src/main/conf/zoo.cfg b/products/cloud-controller/modules/distribution/src/main/conf/zoo.cfg
deleted file mode 100644
index 57927f2..0000000
--- a/products/cloud-controller/modules/distribution/src/main/conf/zoo.cfg
+++ /dev/null
@@ -1,3 +0,0 @@
-tickTime=2000
-dataDir=repository/data/zookeeper
-clientPort=2182