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:00 UTC

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

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/embedded-ldap.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/embedded-ldap.xml b/products/stratos-manager/conf/embedded-ldap.xml
deleted file mode 100644
index 144628e..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/event-broker.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/event-broker.xml b/products/stratos-manager/conf/event-broker.xml
deleted file mode 100644
index 296c7cd..0000000
--- a/products/stratos-manager/conf/event-broker.xml
+++ /dev/null
@@ -1,63 +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 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/stratos-manager/conf/features-dashboard.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/features-dashboard.xml b/products/stratos-manager/conf/features-dashboard.xml
deleted file mode 100755
index 4b6887e..0000000
--- a/products/stratos-manager/conf/features-dashboard.xml
+++ /dev/null
@@ -1,93 +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.
-  -->
-
-<data>
-	<service name="Cloud Services" link="" key="manager">
-		<story title="Metering">
-			<story-content>Metering measures levels of resource utilization, such
-				as network bandwidth usage and
-				data storage volume, consumed by the
-				cloud services subscribers, aka
-				tenants.
-				Resource utilization's
-				(bandwidth and storage usage) are measured on the fly
-				and the
-				measured data is stored for summarizing and analyzing.
-			</story-content>
-			<story-links>
-				<link url="/carbon/tenant-usage/tenant_usage.jsp">Go to Metering....</link>
-				<link url="/carbon/tenant-usage/docs/userguide.html">Read more (docs)...</link>
-			</story-links>
-		</story>
-		<story title="Account Management">
-			<story-content>Account management allows a tenant to update and
-				validate contact information,
-				update the usage plan, validate the
-				account and even de-activate the
-				account.
-            </story-content>
-			<story-links>
-				<link url="/carbon/account-mgt/account_mgt.jsp">Manage Account...</link>
-				<link url="/carbon/account-mgt/docs/userguide.html">Read more (docs)...</link>
-			</story-links>
-		</story>
-		<story title="Users and Roles">
-			<story-content>You can add users and define your own roles for a
-				tenant. The permission model is
-				role based. So a tenant admin can
-				define what actions a role can perform
-				by
-				configuring permissions for
-				that role.</story-content>
-			<story-links>
-				<link url="/carbon/userstore/index.jsp">Manage users/roles...</link>
-				<link url="/carbon/userstore/docs/userguide.html">Read more (docs)...</link>
-			</story-links>
-		</story>
-	</service>
-	<service name="Stratos Controller" link="" key="sc">
-		<story title="Multi-Tenant Cartridges">
-			<story-content>Stratos Cartridges, hosting WSO2 multi-tenant middleware 
-				services delivers multi-tenancy within each Cartridge instance 
-				where teams may define multiple tenants per Cartridge.
-			</story-content>
-			<story-links>
-				<link url="/carbon/cartridge-mgt/available_cartridges.jsp?item=available_multitenant_cartridges">Available Multi-Tenant Cartridges</link>
-			</story-links>
-		</story>
-		<story title="Single-Tenant Cartridges">
-			<story-content>Stratos Cartridges provide process-level isolation and 
-				instance-level dedicated tenancy with single-tenant containers and frameworks.
-			</story-content>
-			<story-links>
-				<link url="/carbon/cartridge-mgt/available_cartridges.jsp?item=available_singletenant_cartridges">Available Single-Tenant Cartridges</link>
-			</story-links>
-		</story>
-		<story title="Subscribed Cartridges">
-			<story-content>The tenant user can see all details of the Subscribed Cartridges such as
-				the status and the number of running instances at the moment.
-			</story-content>
-			<story-links>
-				<link url="/carbon/cartridge-mgt/subscribed_cartridges.jsp">Subscribed Cartridges</link>
-			</story-links>
-		</story>
-	</service>
-</data>
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/identity.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/identity.xml b/products/stratos-manager/conf/identity.xml
deleted file mode 100755
index 1a20f09..0000000
--- a/products/stratos-manager/conf/identity.xml
+++ /dev/null
@@ -1,108 +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.
-  -->
-
-<Server xmlns="http://wso2.org/projects/carbon/carbon.xml">
-
-	<OpenIDServerUrl>https://localhost:9443/openidserver</OpenIDServerUrl>
-
-	<OpenIDUserPattern>https://localhost:9443/openid/</OpenIDUserPattern>
-
-     <JDBCPersistenceManager>
-        <DataSource>
-        	<!-- Include a data source name (jndiConfigName) from the set of data sources defined in master-datasources.xml -->
-        	<Name>jdbc/WSO2CarbonDB</Name>
-    	</DataSource>
-		<!-- If the identity database is created from another place and if it is required to skip schema initialization during the server start up, set the following
-		 property to "true". -->
-		<!-- <SkipDBSchemaCreation>false</SkipDBSchemaCreation> -->
-    </JDBCPersistenceManager>
-
-	<!--
-      Security configurations
-    -->
-	<Security>
-		<UserTrustedRPStore>
-			<Location>${carbon.home}/repository/resources/security/userRP.jks</Location>
-			<!-- Keystore type (JKS/PKCS12 etc.)-->
-			<Type>JKS</Type>
-			<!-- Keystore password-->
-			<Password>wso2carbon</Password>
-			<!-- Private Key password-->
-			<KeyPassword>wso2carbon</KeyPassword>
-		</UserTrustedRPStore>
-
-		<!--
-			The directory under which all other KeyStore files will be stored
-		-->
-		<KeyStoresDir>${carbon.home}/conf/keystores</KeyStoresDir>
-	</Security>
-
-	<Identity>
-		<IssuerPolicy>SelfAndManaged</IssuerPolicy>
-		<TokenValidationPolicy>CertValidate</TokenValidationPolicy>
-		<BlackList></BlackList>
-		<WhiteList></WhiteList>
-		<System>
-			<KeyStore></KeyStore>
-			<StorePass></StorePass>
-		</System>
-	</Identity>
-
-	<OAuth>
-		<RequestTokenUrl>https://localhost:9443/oauth/request-token</RequestTokenUrl>
-		<AccessTokenUrl>https://localhost:9443/oauth/access-token</AccessTokenUrl>
-		<AuthorizeUrl>https://localhost:9443/oauth/authorize-url</AuthorizeUrl>
-		<!-- Default validity period for Authorization Code in seconds -->
-		<AuthorizationCodeDefaultValidityPeriod>300</AuthorizationCodeDefaultValidityPeriod>
-		<!-- Default validity period for Access Token in seconds -->
-		<AccessTokenDefaultValidityPeriod>3600</AccessTokenDefaultValidityPeriod>
-		<!-- Timestamp skew in seconds -->
-		<TimestampSkew>300</TimestampSkew>
-		<!-- Enable OAuth caching. This cache has the replication support. -->
-		<EnableOAuthCache>true</EnableOAuthCache>
-		<!-- Configure the security measures needs to be done prior to store the token in the database,
-		such as hashing, encrypting, etc.-->
-		<TokenPersistencePreprocessor>org.wso2.carbon.identity.oauth.preprocessor.PlainTextTokenPersistencePreprocessor</TokenPersistencePreprocessor>
-		<!-- Supported Response Types -->
-		<SupportedResponseTypes>token,code</SupportedResponseTypes>
-		<!-- Supported Grant Types -->
-		<SupportedGrantTypes>authorization_code,password,refresh_token,client_credentials</SupportedGrantTypes>
-		<OAuthCallbackHandlers>		
-				<OAuthCallbackHandler Class="org.wso2.carbon.identity.oauth.callback.DefaultCallbackHandler"/>
-		</OAuthCallbackHandlers>
-	</OAuth>
-
-	<MultifactorAuthentication>
-		<XMPPSettings>
-			<XMPPConfig>
-				<XMPPProvider>gtalk</XMPPProvider>
-				<XMPPServer>talk.google.com</XMPPServer>
-				<XMPPPort>5222</XMPPPort>
-				<XMPPExt>gmail.com</XMPPExt>
-				<XMPPUserName>multifactor1@gmail.com</XMPPUserName>
-				<XMPPPassword>wso2carbon</XMPPPassword>
-			</XMPPConfig>
-		</XMPPSettings>
-	</MultifactorAuthentication>
-
-    	<SSOService>
-    	    <IdentityProviderURL>https://localhost:9443/samlsso</IdentityProviderURL>
-    	</SSOService>
-</Server>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/jaas.conf
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/jaas.conf b/products/stratos-manager/conf/jaas.conf
deleted file mode 100644
index b560cba..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/jndi.properties
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/jndi.properties b/products/stratos-manager/conf/jndi.properties
deleted file mode 100644
index e4b3f0e..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/loadbalancer.conf
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/loadbalancer.conf b/products/stratos-manager/conf/loadbalancer.conf
deleted file mode 100644
index e97eb77..0000000
--- a/products/stratos-manager/conf/loadbalancer.conf
+++ /dev/null
@@ -1,49 +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.
-#
-
-services {
-    # default parameter values to be used in all services
-    defaults {
-        # minimum number of service instances required. WSO2 ELB will make sure that this much of instances
-        # are maintained in the system all the time, of course only when autoscaling is enabled.
-        min_app_instances       1;
-        # maximum number of service instances that will be load balanced by this ELB.
-        max_app_instances       5;
-        # you need to calibrate autoscaling parameters before start using. Please go through following blog post
-        # http://nirmalfdo.blogspot.com/2013/01/scale-up-early-scale-down-slowly.html
-        max_requests_per_second   5;
-        alarming_upper_rate 0.7;
-        alarming_lower_rate 0.2;
-        scale_down_factor 0.25;
-        rounds_to_average       2;
-        message_expiry_time     60000;
-    }
-    
-    identity {
-        hosts                   identity.aaaa.cloud-test.wso2.com;
-        domains   {
-            wso2.identity.aaaa.domain {
-                tenant_range    *;
-            }
-            
-        }
-    }
-    
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/log4j.properties
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/log4j.properties b/products/stratos-manager/conf/log4j.properties
deleted file mode 100755
index da8fa3c..0000000
--- a/products/stratos-manager/conf/log4j.properties
+++ /dev/null
@@ -1,169 +0,0 @@
-#
-# Copyright 2009 WSO2, Inc. (http://wso2.com)
-#
-# Licensed 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 WSO2 Carbon
-#
-# IMPORTANT : Please do not remove or change the names of any
-# of the Appenders defined here. The layout pattern & log file
-# can be changed using the WSO2 Carbon Management Console, and those
-# settings will override the settings in this file.
-#
-
-log4j.rootLogger=INFO, CARBON_CONSOLE, CARBON_LOGFILE, CARBON_MEMORY
-
-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.stratos.rest.endpoint=INFO,CARBON_CONSOLE, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.stratos.manager=INFO,CARBON_CONSOLE
-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 Related Log configurations
-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
-log4j.logger.net.sf.ehcache.config.ConfigurationFactory=ERROR
-
-log4j.logger.trace.messages=TRACE,CARBON_TRACE_LOGFILE
-
-log4j.additivity.org.apache.axis2.clustering=false
-log4j.additivity.com.atomikos=false
-log4j.additivity.org.apache=false
-
-# CARBON_CONSOLE is set to be a ConsoleAppender using a PatternLayout.
-log4j.appender.CARBON_CONSOLE=org.wso2.carbon.logging.appenders.CarbonConsoleAppender
-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.wso2.carbon.logging.appenders.CarbonDailyRollingFileAppender
-# 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
-
-# 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://localhost:7611
-log4j.appender.LOGEVENT.layout=org.wso2.carbon.utils.logging.TenantAwarePatternLayout
-log4j.appender.LOGEVENT.columnList=%T,%S,%A,%d,%c,%p,%m,%I,%Stacktrace
-log4j.appender.LOGEVENT.userName=admin
-log4j.appender.LOGEVENT.password=admin
-log4j.appender.LOGEVENT.processingLimit=1000
-log4j.appender.LOGEVENT.maxTolerableConsecutiveFailure=20
-
-# 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/stratos-manager/conf/metering-config-non-manager.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/metering-config-non-manager.xml b/products/stratos-manager/conf/metering-config-non-manager.xml
deleted file mode 100755
index 6f642a3..0000000
--- a/products/stratos-manager/conf/metering-config-non-manager.xml
+++ /dev/null
@@ -1,104 +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.
-  -->
-<meteringConfig xmlns="http://wso2.com/carbon/multitenancy/metering/config">
-    <tasks>
-        <task service="org.apache.stratos.metering.agent.task.PerRegistryRequestTask">
-            <preHandlers>
-                <handler service="org.apache.stratos.metering.agent.handlers.ValidationInfoRetriever">
-                </handler>
-                <handler service="org.apache.stratos.metering.agent.handlers.RegistryActionValidator">
-                </handler>
-            </preHandlers>
-            <postHandlers>
-                <handler service="org.apache.stratos.metering.agent.handlers.RemoteTaskInvoker"
-                        async="true" frequency="1"><!-- trigger per each request-->
-                    <parameter name="taskServiceUrl">https://localhost:9443/services/</parameter>
-                    <parameter name="userName">admin</parameter>
-                    <parameter name="password">admin</parameter>
-                    <parameter name="taskName">org.apache.stratos.metering.manager.task.PerRegistryRequestRemoteTask</parameter>
-                </handler>
-            </postHandlers>
-        </task>
-        <task service="org.apache.stratos.metering.agent.task.PerUserAddRequestTask">
-            <preHandlers>
-                <handler service="org.apache.stratos.metering.agent.handlers.RemoteTaskInvoker"
-                        async="false" frequency="1"><!-- trigger per each request-->
-                    <parameter name="taskServiceUrl">https://localhost:9443/services/</parameter>
-                    <parameter name="userName">admin</parameter>
-                    <parameter name="password">admin</parameter>
-                    <parameter name="taskName">org.apache.stratos.metering.manager.task.PerUserAddRequestRemoteTask</parameter>
-                </handler>
-                <handler service="org.apache.stratos.metering.agent.handlers.ValidationInfoRetriever">
-                </handler>
-                <handler service="org.apache.stratos.metering.agent.handlers.AddUserActionValidator">
-                </handler>
-            </preHandlers>
-        </task>
-        <task service="org.apache.stratos.metering.manager.task.PerRegistryRequestRemoteTask">
-            <postHandlers>
-                <handler service="org.apache.stratos.metering.agent.handlers.ValidationInfoRetriever">
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.DBContentVolumeRetriever"><!-- trigger per each registry request-->
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.BandwidthDataRetriever" async="true" frequency="5"><!-- trigger per 5 registry request-->
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.BandwidthDataStorer">
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.BillingDataRetriever"><!-- trigger per each registry request-->
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.RuleInvoker">
-                    <parameter name="rule-file">restriction-rules.drl</parameter>
-                </handler>
-                <handler service="org.apache.stratos.metering.agent.handlers.ValidationInfoStorer">
-                </handler>
-            </postHandlers>
-        </task>
-        <task service="org.apache.stratos.metering.manager.task.PerUserAddRequestRemoteTask">
-            <postHandlers>
-                <handler service="org.apache.stratos.metering.manager.handlers.UsersCountRetriever"><!-- trigger per each user add request-->
-                </handler>
-                <handler service="org.apache.stratos.metering.agent.handlers.ValidationInfoRetriever">
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.BillingDataRetriever"><!-- trigger per each user add request-->
-                </handler>
-                <handler service="org.apache.stratos.metering.manager.handlers.RuleInvoker">
-                    <parameter name="rule-file">restriction-rules.drl</parameter>
-                </handler>
-                <handler service="org.apache.stratos.metering.agent.handlers.ValidationInfoStorer">
-                </handler>
-            </postHandlers>
-        </task>
-        <!-- to be implemented -->
-        <!--
-        <task service="org.apache.stratos.metering.manager.task.ScheduledTask">
-            <parameters>
-                <parameter name="period">1Month</parameter>
-                <parameter name="dayToTriggerOn">1</parameter>
-                <parameter name="hourToTriggerOn">0</parameter>
-                <parameter name="timeZone">GMT-8:00</parameter>
-            </parameters>
-            <hanldlers>
-                <handler service="org.apache.stratos.metering.manager.handler.RuleInvoker">
-                    <parameter name="rule-file">restriction-rules.drl</parameter>
-                </handler>
-            </handlers>
-        </task>
-        -->
-    </tasks>
-</meteringConfig>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/multitenancy-billing-rules.drl
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/multitenancy-billing-rules.drl b/products/stratos-manager/conf/multitenancy-billing-rules.drl
deleted file mode 100755
index 20a45c6..0000000
--- a/products/stratos-manager/conf/multitenancy-billing-rules.drl
+++ /dev/null
@@ -1,53 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-import org.wso2.carbon.billing.core.dataobjects.*;
-import org.wso2.carbon.billing.mgt.dataobjects.*;
-
-
-rule smallSubscription
-when
-$item: MultitenancyPackage(name == "SMB")
-$subItem: Item(parent == $item && name == "subscription")
-then
-$subItem.setCost(new Cash("$100"));
-$subItem.setCreditLimit(new Cash("$200"));
-end
-
-
-rule mediumSubscription
-when
-$item: MultitenancyPackage(name == "Professional")
-$subItem: Item(parent == $item && name == "subscription")
-then
-$subItem.setCost(new Cash("$500"));
-$subItem.setCreditLimit(new Cash("$1000"));
-end
-
-
-rule largeSubscription
-when
-$item: MultitenancyPackage(name == "Enterprise")
-$subItem: Item(parent == $item && name == "subscription")
-then
-$subItem.setCost(new Cash("$2000"));
-$subItem.setCreditLimit(new Cash("$4000"));
-end
-
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/nhttp.properties
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/nhttp.properties b/products/stratos-manager/conf/nhttp.properties
deleted file mode 100644
index 40c3bfc..0000000
--- a/products/stratos-manager/conf/nhttp.properties
+++ /dev/null
@@ -1,42 +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 file contains the configuration parameters used by the Non-blocking HTTP transport
-
-#http.socket.timeout=60000
-#nhttp_buffer_size=8192
-#http.tcp.nodelay=1
-#http.connection.stalecheck=0
-
-# Uncomment the following property for an AIX based deployment
-#http.nio.interest-ops-queueing=true
-
-# HTTP Sender thread pool parameters
-#snd_t_core=20
-#snd_t_max=100
-#snd_alive_sec=5
-#snd_qlen=-1
-#snd_io_threads=2
-
-# HTTP Listener thread pool parameters
-#lst_t_core=20
-#lst_t_max=100
-#lst_alive_sec=5
-#lst_qlen=-1
-#lst_io_threads=2

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/passthru-http.properties
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/passthru-http.properties b/products/stratos-manager/conf/passthru-http.properties
deleted file mode 100644
index 21cd1ab..0000000
--- a/products/stratos-manager/conf/passthru-http.properties
+++ /dev/null
@@ -1,34 +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 file contains the configuration parameters used by the Pass-through HTTP transport
-
-## Pass-through HTTP transport specific tuning parameters 
-#worker_pool_size_core=40
-#worker_pool_size_max=200
-#worker_thread_keepalive_sec=60
-#worker_pool_queue_length=-1
-#io_threads_per_reactor=2
-#io_buffer_size=8192
-#http.max.connection.per.host.port=32767
-
-## Other parameters
-#http.user.agent.preserve=false
-#http.server.preserve=true
-#http.connection.disable.keepalive=false

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/rule-component.conf
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/rule-component.conf b/products/stratos-manager/conf/rule-component.conf
deleted file mode 100644
index 7ee068e..0000000
--- a/products/stratos-manager/conf/rule-component.conf
+++ /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.
--->
-
-<RuleServer>
-    <RuleEngineProvider class="org.wso2.carbon.rule.engine.jsr94.JSR94BackendRuntimeFactory"/>
-</RuleServer>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/samples-desc.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/samples-desc.xml b/products/stratos-manager/conf/samples-desc.xml
deleted file mode 100755
index 580f9b0..0000000
--- a/products/stratos-manager/conf/samples-desc.xml
+++ /dev/null
@@ -1,33 +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.
-  -->
-<samples xmlns="http://wso2.com/stratos/samples">
-    <sample name="Shopping Cart">
-        <cloudServices>
-            <cloudService name="Application Server"/>
-            <!--cloudService name="WSO2 Stratos Governance"/>
-            <cloudService name="WSO2 Stratos Application Server"/>
-            <cloudService name="WSO2 Stratos Gadget Server"/>
-            <cloudService name="WSO2 Stratos Mashup Server"/>
-            <cloudService name="WSO2 Stratos Enterprise Service Bus"/>
-            <cloudService name="WSO2 Stratos Data Services Server"/>
-            <cloudService name="WSO2 Stratos Business Process Server"/-->
-        </cloudServices>
-	<fileName>GlobalShoppingCartSample-${shoppingcart.global.version}</fileName>
-    </sample>
-</samples>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/sso-idp-config.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/sso-idp-config.xml b/products/stratos-manager/conf/sso-idp-config.xml
deleted file mode 100644
index a9846c9..0000000
--- a/products/stratos-manager/conf/sso-idp-config.xml
+++ /dev/null
@@ -1,38 +0,0 @@
-<!--
- ~ Copyright (c) 2005-2010, WSO2 Inc. (http://www.wso2.org) All Rights Reserved.
- ~
- ~ WSO2 Inc. 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.
- -->
-<SSOIdentityProviderConfig>
-    <ServiceProviders>
-        <ServiceProvider>
-            <Issuer>console</Issuer>
-            <AssertionConsumerService>https://localhost:9443/console/controllers/acs.jag</AssertionConsumerService>
-            <UseFullyQualifiedUsernameInNameID>true</UseFullyQualifiedUsernameInNameID>
-            <SignResponse>true</SignResponse>
-            <SignAssertion>true</SignAssertion>
-            <EnableAttributeProfile>true</EnableAttributeProfile>
-            <IncludeAttributeByDefault>true</IncludeAttributeByDefault>
-            <Claims>
-                <Claim>http://wso2.org/claims/role</Claim>
-            </Claims>
-            <EnableAudienceRestriction>true</EnableAudienceRestriction>
-            <AudiencesList>
-                <Audience>https://localhost:9445/oauth2/token</Audience>
-            </AudiencesList>
-            <ConsumingServiceIndex>123456</ConsumingServiceIndex>
-        </ServiceProvider>
-    </ServiceProviders>
-</SSOIdentityProviderConfig>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/status-monitor-config.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/status-monitor-config.xml b/products/stratos-manager/conf/status-monitor-config.xml
deleted file mode 100755
index 91bf5a3..0000000
--- a/products/stratos-manager/conf/status-monitor-config.xml
+++ /dev/null
@@ -1,53 +0,0 @@
-<!--
-  ~ Licensed to the Apache Software Foundation (ASF) under one
-  ~ or more contributor license agreements.  See the NOTICE file
-  ~ distributed with this work for additional information
-  ~ regarding copyright ownership.  The ASF licenses this file
-  ~ to you under the Apache License, Version 2.0 (the
-  ~ "License"); you may not use this file except in compliance
-  ~ with the License.  You may obtain a copy of the License at
-  ~
-  ~     http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing,
-  ~ software distributed under the License is distributed on an
-  ~ "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-  ~ KIND, either express or implied.  See the License for the
-  ~ specific language governing permissions and limitations
-  ~ under the License.
-  -->
-
-<!-- 
-     Defines the database and related params that to be used for the services status
-     monitoring. Status Monitor Agent writes to the database defined here, and the 
-     Status Monitor reads it. 
-  -->
-
-<serviceStatusConfig xmlns="http://wso2.com/carbon/status/monitor/config">
-   <authConfig>
-        <jksLocation>../../repository/resources/security/wso2carbon.jks</jksLocation> <!--location to the jks file-->
-
-        <!--The tenant credentials that to be used to login to the Stratos 
-	services. Make sure the correct credentials are given to avoid 
-	false positives.-->
-        <userName>admin@wso2-heartbeat-checker.org</userName>
-        <password>password</password>
-        <tenantDomain>wso2-heartbeat-checker.org</tenantDomain>
-   </authConfig>
-
-   <platformSample>
-        <!--The tenant that has the webapps and services to monitor. 
-	This can of course be the same tenant given above as tenantDomain-->
-        <tenantDomain>wso2.org</tenantDomain>
-    </platformSample>
-
-   <dbConfig>
-        <url>jdbc:mysql://localhost:3306/stratos_status</url>
-        <userName>monitor</userName>
-        <password>monitor</password>
-        <driverName>com.mysql.jdbc.Driver</driverName>
-        <maxActive>80</maxActive>
-        <maxWait>60000</maxWait>
-        <minIdle>5</minIdle>
-    </dbConfig>
-</serviceStatusConfig>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/stratos-datasources.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/stratos-datasources.xml b/products/stratos-manager/conf/stratos-datasources.xml
deleted file mode 100755
index 4969870..0000000
--- a/products/stratos-manager/conf/stratos-datasources.xml
+++ /dev/null
@@ -1,69 +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 xmlns:svns="http://org.wso2.securevault/configuration">
-  
-    <providers>
-        <provider>org.wso2.carbon.ndatasource.rdbms.RDBMSDataSourceReader</provider>
-    </providers>
-  
-    <datasources>
-		<datasource>
-            <name>WSO2BillingDS</name>
-            <description>The datasource used for registry and user manager</description>
-            <jndiConfig>
-                <name>jdbc/WSO2BillingDS</name>
-            </jndiConfig>
-            <definition type="RDBMS">
-                <configuration>
-                    <url>jdbc:h2:repository/database/WSO2BILLING_DB;DB_CLOSE_ON_EXIT=FALSE</url>
-                    <username>wso2carbon</username>
-                    <password>wso2carbon</password>
-                    <driverClassName>org.h2.Driver</driverClassName>
-                    <maxActive>50</maxActive>
-                    <maxWait>60000</maxWait>
-                    <testOnBorrow>true</testOnBorrow>
-                    <validationQuery>SELECT 1</validationQuery>
-                    <validationInterval>30000</validationInterval>
-                </configuration>
-            </definition>
-        </datasource>
-
-	<datasource>
-            <name>WSO2S2DS</name>
-            <description>The datasource used for s2</description>
-            <jndiConfig>
-                <name>jdbc/WSO2S2DS</name>
-            </jndiConfig>
-            <definition type="RDBMS">
-                <configuration>
-                    <url>jdbc:h2:repository/database/WSO2S2_DB;DB_CLOSE_ON_EXIT=FALSE</url>
-                    <username>wso2carbon</username>
-                    <password>wso2carbon</password>
-                    <driverClassName>org.h2.Driver</driverClassName>
-                    <maxActive>50</maxActive>
-                    <maxWait>60000</maxWait>
-                    <testOnBorrow>true</testOnBorrow>
-                    <validationQuery>SELECT 1</validationQuery>
-                    <validationInterval>30000</validationInterval>
-                </configuration>
-            </definition>
-        </datasource>
-      </datasources>
-</datasources-configuration>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/eae721e7/products/stratos-manager/conf/synapse-configs/default/registry.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/synapse-configs/default/registry.xml b/products/stratos-manager/conf/synapse-configs/default/registry.xml
deleted file mode 100644
index f259c7a..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/synapse-configs/default/sequences/errorHandler.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/synapse-configs/default/sequences/errorHandler.xml b/products/stratos-manager/conf/synapse-configs/default/sequences/errorHandler.xml
deleted file mode 100644
index 8621bee..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/synapse-configs/default/sequences/fault.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/synapse-configs/default/sequences/fault.xml b/products/stratos-manager/conf/synapse-configs/default/sequences/fault.xml
deleted file mode 100644
index 9d2d8f7..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/synapse-configs/default/sequences/main.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/synapse-configs/default/sequences/main.xml b/products/stratos-manager/conf/synapse-configs/default/sequences/main.xml
deleted file mode 100644
index c4dbf5b..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/synapse-configs/default/synapse.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/synapse-configs/default/synapse.xml b/products/stratos-manager/conf/synapse-configs/default/synapse.xml
deleted file mode 100755
index d8ad52d..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/synapse.properties
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/synapse.properties b/products/stratos-manager/conf/synapse.properties
deleted file mode 100755
index c3cbdb4..0000000
--- a/products/stratos-manager/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/stratos-manager/conf/temp-artifacts/carbon/module.xml
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/temp-artifacts/carbon/module.xml b/products/stratos-manager/conf/temp-artifacts/carbon/module.xml
deleted file mode 100644
index 2cb5634..0000000
--- a/products/stratos-manager/conf/temp-artifacts/carbon/module.xml
+++ /dev/null
@@ -1,69 +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.
-
--->
-
-<module name="carbon" xmlns="http://wso2.org/projects/jaggery/module.xml">
-    <!-- scripts -->
-    <script>
-        <name>osgi</name>
-        <path>scripts/server/osgi.js</path>
-    </script>
-    <script>
-        <name>tenant</name>
-        <path>scripts/server/tenant.js</path>
-    </script>
-    <script>
-        <name>server</name>
-        <path>scripts/server/server.js</path>
-    </script>
-    <script>
-        <name>config</name>
-        <path>scripts/server/config.js</path>
-    </script>
-    <script>
-        <name>user</name>
-        <path>scripts/user/user.js</path>
-    </script>
-    <script>
-        <name>registry</name>
-        <path>scripts/registry/registry.js</path>
-    </script>
-    <script>
-        <name>registry-osgi</name>
-        <path>scripts/registry/registry-osgi.js</path>
-    </script>
-    <script>
-        <name>artifacts</name>
-        <path>scripts/registry/artifacts.js</path>
-    </script>
-    <script>
-        <name>space</name>
-        <path>scripts/user/space.js</path>
-    </script>
-    <script>
-        <name>registry-space</name>
-        <path>scripts/user/registry-space.js</path>
-    </script>
-    <script>
-        <name>user-manager</name>
-        <path>scripts/user/user-manager.js</path>
-    </script>
-</module>