You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by ud...@apache.org on 2014/03/31 13:52:03 UTC

[1/8] git commit: removing stratos componets installation puppet. fixing STRATOS-528

Repository: incubator-stratos
Updated Branches:
  refs/heads/master 348fc626f -> 15e535332


removing stratos componets installation puppet. fixing STRATOS-528


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

Branch: refs/heads/master
Commit: 141bcefa67658372f8cf7b06f213b30e11afa3f8
Parents: 60b2f3f
Author: Udara Liyanage <ud...@wso2.com>
Authored: Fri Mar 28 14:01:00 2014 -0400
Committer: Udara Liyanage <ud...@wso2.com>
Committed: Fri Mar 28 14:01:00 2014 -0400

----------------------------------------------------------------------
 tools/puppet3/manifests/nodes.pp | 30 ------------------------------
 1 file changed, 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/141bcefa/tools/puppet3/manifests/nodes.pp
----------------------------------------------------------------------
diff --git a/tools/puppet3/manifests/nodes.pp b/tools/puppet3/manifests/nodes.pp
index d07deef..5a6b20b 100644
--- a/tools/puppet3/manifests/nodes.pp
+++ b/tools/puppet3/manifests/nodes.pp
@@ -93,33 +93,3 @@ node /wordpress/ inherits base {
   class {'mysql':}
 
 }
-
-# stratos components related nodes
-# not supported in alpha version.
-node 'autoscaler.wso2.com' inherits base {
-  require java
-  class {'autoscaler': maintenance_mode => 'norestart',}
-}
-
-node 'cc.wso2.com' inherits base {
-  require java
-  class {'cc': maintenance_mode   => 'norestart',}
-}
-
-node 'cep.wso2.com' inherits base {
-  require java
-  class {'cep': maintenance_mode   => 'norestart',}
-}
-
-
-node 'mb.wso2.com' inherits base {
-  require java
-  class {'messagebroker': maintenance_mode   => 'norestart',}
-}
-
-node 'sc.wso2.com' inherits base {
-  require java
-  class {'manager': maintenance_mode   => 'norestart',}
-}
-
-


[4/8] Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos

Posted by ud...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/ce69655b/tools/puppet3/manifests/nodes.pp
----------------------------------------------------------------------


[6/8] removing invalid scripts for creating cartridges

Posted by ud...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/ec2/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/ec2/stratos-init.sh b/tools/cartridge-create/init-scripts/php/ec2/stratos-init.sh
deleted file mode 100644
index aab01ad..0000000
--- a/tools/cartridge-create/init-scripts/php/ec2/stratos-init.sh
+++ /dev/null
@@ -1,304 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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 script will be called from /etc/rc.local when the cartridge
-# instance is spawned. It will initiate all the tasks that needs to 
-# be run to bring the cartridge instance to operational state.
-
-export LOG=/var/log/stratos-cartridge.log
-instance_path=/opt
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-RETRY_COUNT=30
-SLEEP_DURATION=3
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    wget http://169.254.169.254/latest/user-data -O ${instance_path}/payload/payload.zip    
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/payload.zip
-    echo "unzippeddd..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-
-fi
-
-
-echo ---------------------------- >> $LOG
-echo "getting public ip from metadata service" >> $LOG
-
-wget http://169.254.169.254/latest/meta-data/public-ipv4
-files="`cat public-ipv4`"
-if [[ -z ${files} ]]; then
-    echo "getting public ip" >> $LOG
-    for i in {1..30}
-    do
-      rm -f ./public-ipv4
-      wget http://169.254.169.254/latest/meta-data/public-ipv4
-      files="`cat public-ipv4`"
-      if [ -z $files ]; then
-          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-          sleep $SLEEP_DURATION
-      else
-          echo "Public ip assigned" >> $LOG
-          break
-      fi
-    done
-
-    if [ -z $files ]; then
-      echo "Public ip is not yet assigned. So exit" >> $LOG
-      exit 0
-    fi
-    for x in $files
-    do
-        PUBLIC_IP="$x"
-    done
-
-
-else 
-   PUBLIC_IP="$files"
-fi
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.pem /etc/ssl/certs/ssl-cert-snakeoil.pem
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.key /etc/ssl/private/ssl-cert-snakeoil.key
-echo "Restarting apache..." >> $LOG
-
-/etc/init.d/apache2 restart
-
-echo "Apache restarted..." >> $LOG
-
-
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS}, BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-mkdir -p  /etc/agent/conf
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://service.agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-	  <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "          <remoteHost>${PUBLIC_IP}</remoteHost>
-           <service>${SERVICE}</service>
-	   <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-echo "Creating repoinfo request  " >> $LOG
-echo "TENANT_ID and SERVICE ${TENANT_ID} and ${SERVICE} " >> $LOG
-set -- "${HOST_NAME}" 
-IFS="."; declare -a Array=($*)
-ALIAS="${Array[0]}"
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:xsd=\"http://org.apache.axis2/xsd\">
-   <soapenv:Header/>
-   <soapenv:Body>
-      <xsd:getRepositoryCredentials>
-         <xsd:tenantId>${TENANT_ID}</xsd:tenantId>
-         <xsd:cartridgeType>${SERVICE}</xsd:cartridgeType>
-         <xsd:alias>${ALIAS}</xsd:alias>
-      </xsd:getRepositoryCredentials>
-   </soapenv:Body>
-</soapenv:Envelope>" > /opt/repoinforequest.xml
-
-echo "Repoinfo request created " >> $LOG
-
-echo "Private Key....Copying to .ssh  " >> $LOG
-
-cp ${instance_path}/payload/id_rsa /root/.ssh/id_rsa
-chmod 0600 /root/.ssh/id_rsa
-echo "StrictHostKeyChecking no" >> /root/.ssh/config
-
-
-
-
-#echo "Getting repo username password from repoInfoService" >> $LOG
-#curl -X POST -H "Content-Type: text/xml" -d @/etc/agent/conf/request.xml --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Git repo sync" >> $LOG
-
-# If repo is available do a git pull, else clone
-echo "#!/bin/bash
-if [ -d \"${APP_PATH}/.git\" ]; then
-    cd ${APP_PATH}
-    
-    curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-   git config --global --bool --add http.sslVerify false
-   sudo git pull
-   rm ~/.netrc
-   sudo rm /root/.netrc
-
-    sudo chown -R www-data:www-data ${APP_PATH}/www
-    if [ -f \"${APP_PATH}/sql/alter.sql\" ]; then
-    	mysql -h ${MYSQL_HOST} -u ${MYSQL_USER} -p${MYSQL_PASSWORD} < ${APP_PATH}/sql/alter.sql
-    fi
-else
-    sudo rm -f ${APP_PATH}/index.html
-   curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-   git config --global --bool --add http.sslVerify false
-   sudo git clone \${repo} ${APP_PATH}
-   rm ~/.netrc
-   sudo rm /root/.netrc
- 
-
-    if [ -f \"${APP_PATH}/sql/init.sql\" ]; then
-        mysql -h ${MYSQL_HOST} -u ${MYSQL_USER} -p${MYSQL_PASSWORD} < ${APP_PATH}/sql/init.sql
-    fi
-    echo \"SetEnv STRATOS_MYSQL_USER ${MYSQL_USER}
-    SetEnv STRATOS_MYSQL_HOST ${MYSQL_HOST}
-    SetEnv STRATOS_MYSQL_PASSWORD ${MYSQL_PASSWORD}
-    \" > /tmp/.htaccess
-    sudo mv /tmp/.htaccess ${APP_PATH}/
-    sudo chown -R www-data:www-data ${APP_PATH}/www
-    
-
-
-fi" > /opt/git.sh
-echo "File created.." >> $LOG
-chmod 755 /opt/git.sh
-
-
-
-while true
-do
-var=`nc -z localhost 80; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 80 is available" >> $LOG
-       break
-   else
-       echo "port 80 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-while true
-do
-var=`nc -z localhost 443; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 443 is available" >> $LOG
-       break
-   else
-       echo "port 443 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-
-echo "Sending register request to Cartridge agent service" >> $LOG
-
-curl -X POST -H "Content-Type: text/xml" -H "SOAPAction: urn:register" -d @/etc/agent/conf/request.xml -k --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Registered cartridge..." >> $LOG
-
-echo "running git clone........" >> $LOG
-su - ubuntu /opt/git.sh
-
-
-echo "setting up logging conf" >> $LOG
-
-
-echo "host:     ${BAM_IP}
-thriftPort:     ${BAM_PORT}
-
-#cartridge configs
-cartridgeAlias:  ${CARTRIDGE_ALIAS}
-tenantName:      ${HOST_NAME}
-tenantId:        ${TENANT_ID}
-localIP:         ${PUBLIC_IP}" > /opt/cartridge_data_publisher_1.0.2/conf/data_publisher.conf
-
-
-
-echo "started loggin ........."
-cd /opt/cartridge_data_publisher_1.0.2/dist/Debug/GNU-Linux-x86/
-nohup ./cartridge_data_publisher_1.0.2 /var/log/apache2/access.log /var/log/apache2/error.log >> /var/log/startos-data-publisher.log  &
-
-
-
-
-
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/get-launch-params.rb b/tools/cartridge-create/init-scripts/php/get-launch-params.rb
deleted file mode 100644
index c6368ca..0000000
--- a/tools/cartridge-create/init-scripts/php/get-launch-params.rb
+++ /dev/null
@@ -1,55 +0,0 @@
-#! /usr/bin/ruby
-#
-#
-# 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.
-#
-#
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/openstack/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/openstack/get-launch-params.rb b/tools/cartridge-create/init-scripts/php/openstack/get-launch-params.rb
deleted file mode 100644
index c6368ca..0000000
--- a/tools/cartridge-create/init-scripts/php/openstack/get-launch-params.rb
+++ /dev/null
@@ -1,55 +0,0 @@
-#! /usr/bin/ruby
-#
-#
-# 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.
-#
-#
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/openstack/healthcheck.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/openstack/healthcheck.sh b/tools/cartridge-create/init-scripts/php/openstack/healthcheck.sh
deleted file mode 100644
index 4194608..0000000
--- a/tools/cartridge-create/init-scripts/php/openstack/healthcheck.sh
+++ /dev/null
@@ -1,30 +0,0 @@
-#!/bin/bash
-#
-#
-# 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.
-#
-#
-
-var=`nc -z localhost 80; echo $?`;
-if [ $var -eq 0 ]
-then
-    echo "port 80 is available" > /dev/null 2>&1
-else
-    echo "port 80 is not available" > /dev/null 2>&1
-    /etc/init.d/apache2 restart
-fi

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/openstack/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/openstack/stratos-init.sh b/tools/cartridge-create/init-scripts/php/openstack/stratos-init.sh
deleted file mode 100755
index 503790f..0000000
--- a/tools/cartridge-create/init-scripts/php/openstack/stratos-init.sh
+++ /dev/null
@@ -1,293 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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 script will be called from /etc/rc.local when the cartridge
-# instance is spawned. It will initiate all the tasks that needs to 
-# be run to bring the cartridge instance to operational state.
-
-export LOG=/var/log/stratos-cartridge.log
-instance_path=/var/lib/cloud/instance
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-RETRY_COUNT=30
-SLEEP_DURATION=3
-ACCESSLOG="/var/log/apache2/access.log"
-ERRORLOG="/var/log/apache2/error.log"
-
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    cp ${instance_path}/user-data.txt ${instance_path}/payload/user-data.zip
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/user-data.zip
-    echo "unzippeddd..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-
-fi
-
-
-echo ---------------------------- >> $LOG
-echo "getting public ip from metadata service" >> $LOG
-
-wget http://169.254.169.254/latest/meta-data/public-ipv4
-files="`cat public-ipv4`"
-if [[ -z ${files} ]]; then
-    echo "getting public ip" >> $LOG
-    for i in {1..30}
-    do
-      rm -f ./public-ipv4
-      wget http://169.254.169.254/latest/meta-data/public-ipv4
-      files="`cat public-ipv4`"
-      if [ -z $files ]; then
-          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-          sleep $SLEEP_DURATION
-      else
-          echo "Public ip assigned" >> $LOG
-          break
-      fi
-    done
-
-    if [ -z $files ]; then
-      echo "Public ip is not yet assigned. So exit" >> $LOG
-      exit 0
-    fi
-    for x in $files
-    do
-        PUBLIC_IP="$x"
-    done
-
-
-else 
-   PUBLIC_IP="$files"
-fi
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.pem /etc/ssl/certs/ssl-cert-snakeoil.pem
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.key /etc/ssl/private/ssl-cert-snakeoil.key
-echo "Restarting apache..." >> $LOG
-
-/etc/init.d/apache2 restart
-
-echo "Apache restarted..." >> $LOG
-
-
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS}, BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-mkdir -p  /etc/agent/conf
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://service.agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-	  <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "          <remoteHost>${PUBLIC_IP}</remoteHost>
-           <service>${SERVICE}</service>
-	   <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-echo "Creating repoinfo request  " >> $LOG
-echo "TENANT_ID and SERVICE ${TENANT_ID} and ${SERVICE} " >> $LOG
-set -- "${HOST_NAME}" 
-IFS="."; declare -a Array=($*)
-ALIAS="${Array[0]}"
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:xsd=\"http://org.apache.axis2/xsd\">
-   <soapenv:Header/>
-   <soapenv:Body>
-      <xsd:getRepositoryCredentials>
-         <xsd:tenantId>${TENANT_ID}</xsd:tenantId>
-         <xsd:cartridgeType>${SERVICE}</xsd:cartridgeType>
-         <xsd:alias>${ALIAS}</xsd:alias>
-      </xsd:getRepositoryCredentials>
-   </soapenv:Body>
-</soapenv:Envelope>" > /opt/repoinforequest.xml
-
-echo "Repoinfo request created " >> $LOG
-
-
-echo "Git repo sync" >> $LOG
-
-# If repo is available do a git pull, else clone
-echo "#!/bin/bash
-if [ -d \"${APP_PATH}/.git\" ]; then
-    cd ${APP_PATH}
-
-    curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-   git config --global --bool --add http.sslVerify false
-   sudo git pull
-   rm ~/.netrc
-   sudo rm /root/.netrc
-
-    sudo chown -R www-data:www-data ${APP_PATH}/www
-    if [ -f \"${APP_PATH}/sql/alter.sql\" ]; then
-    	mysql -h ${MYSQL_HOST} -u ${MYSQL_USER} -p${MYSQL_PASSWORD} < ${APP_PATH}/sql/alter.sql
-    fi
-else
-    sudo rm -f ${APP_PATH}/index.html
-   curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-   git config --global --bool --add http.sslVerify false
-   sudo git clone \${repo} ${APP_PATH}
-   rm ~/.netrc
-   sudo rm /root/.netrc
- 
-
-    if [ -f \"${APP_PATH}/sql/init.sql\" ]; then
-        mysql -h ${MYSQL_HOST} -u ${MYSQL_USER} -p${MYSQL_PASSWORD} < ${APP_PATH}/sql/init.sql
-    fi
-    echo \"SetEnv STRATOS_MYSQL_USER ${MYSQL_USER}
-    SetEnv STRATOS_MYSQL_HOST ${MYSQL_HOST}
-    SetEnv STRATOS_MYSQL_PASSWORD ${MYSQL_PASSWORD}
-    \" > /tmp/.htaccess
-    sudo mv /tmp/.htaccess ${APP_PATH}/
-    sudo chown -R www-data:www-data ${APP_PATH}/www
-    
-
-
-fi" > /opt/git.sh
-echo "File created.." >> $LOG
-chmod 755 /opt/git.sh
-
-
-
-while true
-do
-var=`nc -z localhost 80; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 80 is available" >> $LOG
-       break
-   else
-       echo "port 80 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-while true
-do
-var=`nc -z localhost 443; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 443 is available" >> $LOG
-       break
-   else
-       echo "port 443 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-
-echo "Sending register request to Cartridge agent service" >> $LOG
-
-curl -X POST -H "Content-Type: text/xml" -H "SOAPAction: urn:register" -d @/etc/agent/conf/request.xml -k --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Registered cartridge..." >> $LOG
-
-echo "running git clone........" >> $LOG
-su - ubuntu /opt/git.sh
-
-
-echo "setting up logging conf" >> $LOG
-
-
-echo "host:     ${BAM_IP}
-thriftPort:     ${BAM_PORT}
-
-#cartridge configs
-cartridgeAlias:  ${SERVICE}
-tenantName:      ${HOST_NAME}
-tenantId:      ${TENANT_ID}
-localIP:         ${PUBLIC_IP}" > /opt/cartridge_data_publisher_1.0.2/conf/data_publisher.conf
-
-
-echo "started loggin ........."
-cd /opt/cartridge_data_publisher_1.0.2/dist/Debug/GNU-Linux-x86/
-nohup ./cartridge_data_publisher_1.0.2 ${ACCESSLOG} ${ERRORLOG} 2>&1> /dev/null &
-
-echo "logging started........."
-
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/php
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/php b/tools/cartridge-create/init-scripts/php/php
deleted file mode 100644
index 9fe5339..0000000
--- a/tools/cartridge-create/init-scripts/php/php
+++ /dev/null
@@ -1,49 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#
-#  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.
-#
-# ----------------------------------------------------------------------------
-
-INSTANCE=$1
-INSTANCE_USER=$2
-KEY=$3
-SOFTWARE=$4
-
-SCP="scp -i ./$KEY"
-SSH="ssh -i ./$KEY"
-
-$SCP ./openstack/wso2-cartridge-init.sh $INSTANCE_USER@$INSTANCE:
-$SCP ./php.ctrg $INSTANCE_USER@$INSTANCE:
-$SCP ./openstack/get-launch-params.rb $INSTANCE_USER@$INSTANCE:
-$SCP ./cc/ssl-cert-snakeoil.pem $INSTANCE_USER@$INSTANCE:
-$SCP ./cc/ssl-cert-snakeoil.key $INSTANCE_USER@$INSTANCE:
-$SCP ./ $INSTANCE_USER@$INSTANCE:
-$SCP ./thrift-0.8.0.tar.gz $INSTANCE_USER@$INSTANCE:
-$SCP ./default $INSTANCE_USER@$INSTANCE:
-$SCP ./default-ssl $INSTANCE_USER@$INSTANCE:
-
-# Copy additional software
-arr=$(echo $SOFTWARE | tr ":" "\n")
-for x in $arr
-do
-   $SCP $x $INSTANCE_USER@$INSTANCE:
-done
-
-# Execute the cartridge creation process in the remoter server
-$SSH $INSTANCE_USER@$INSTANCE "sudo chmod 755 ./php.ctrg;sudo ./php.ctrg"

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/php.ctrg
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/php.ctrg b/tools/cartridge-create/init-scripts/php/php.ctrg
deleted file mode 100644
index cbaf639..0000000
--- a/tools/cartridge-create/init-scripts/php/php.ctrg
+++ /dev/null
@@ -1,65 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#
-#  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.
-#
-# ----------------------------------------------------------------------------
-
-    mv ./wso2-cartridge-init.sh /opt/
-    mv ./get-launch-params.rb /opt/
-    mv ./ssl-cert-snakeoil.pem /etc/ssl/certs/
-    mv ./ssl-cert-snakeoil.key /etc/ssl/private/
-    mv ./cartridge_data_publisher_1.0.2.zip /opt/
-    mv ./thrift-0.8.0.tar.gz /opt/
-    mv ./*.tar.gz /opt/
-    mv ./*.zip /opt/
-    cp -f ./default /etc/apache2/sites-available/
-    cp -f ./default-ssl /etc/apache2/sites-available/
-    rm ./default
-    rm ./default-ssl
-    
-
-	apt-get update
-	# Next, all the packages.
-	
-	apt-get install -y \
-	nano zip build-essential mysql-client apache2 php5 php5-cli libapache2-mod-php5 php5-gd php5-mysql php-db php-pear \
-	php5-curl curl wget php5-ldap php5-adodb mailutils php5-imap php5-intl php5-sqlite php5-xmlrpc php5-xsl \
-	openssl ssl-cert ldap-utils php5-mcrypt mcrypt ufw fail2ban git libboost-all-dev ruby xml-twig-tools
-
-    # Install the thrift library
-    tar -zxf /opt/thrift-0.8.0.tar.gz -C/opt
-    cd /opt/thrift-0.8.0
-    ./configure --libdir=/usr/lib;make;make install
-    cd /opt
-    unzip cartridge_data_publisher_1.0.2.zip
-    cd /opt/cartridge_data_publisher_1.0.2
-    make
-
-
-	# Enable HTTPS:
-	a2enmod ssl
-	a2ensite default-ssl	
-
-    echo "#!/bin/bash -e
-chmod 755 /opt/wso2-cartridge-init.sh
-/opt/wso2-cartridge-init.sh > /var/log/wso2-cartridge-init.log
-exit 0
-    " > /etc/rc.local
-
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/thrift-0.8.0.tar.gz
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/thrift-0.8.0.tar.gz b/tools/cartridge-create/init-scripts/php/thrift-0.8.0.tar.gz
deleted file mode 100644
index 46a1a23..0000000
Binary files a/tools/cartridge-create/init-scripts/php/thrift-0.8.0.tar.gz and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/wso2.pem
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/wso2.pem b/tools/cartridge-create/init-scripts/php/wso2.pem
deleted file mode 100644
index f4260f9..0000000
--- a/tools/cartridge-create/init-scripts/php/wso2.pem
+++ /dev/null
@@ -1,16 +0,0 @@
------BEGIN RSA PRIVATE KEY-----
-MIICXQIBAAKBgQCp31ZRD9kPwKoxW3sh+4x2IfldCKEfHbo18LhvOnGPJcNzqHDy
-6WWxpxPAHNAMyvrAv+hUfX4fwSRctieTim0N+fTr+mRP0q4HHhEkvEmxoXs4Y7lz
-jrh5vhMBZBAXsSurHVp2Bpie1xyjW+ksuAziT2gw6KvipjJiGTjuLTnLmQIDAQAB
-AoGAMFvtNbx+PbbKfKyfXChBb2vykmKfg70xwqNZzghkRa0pfCaKqQx6r91xiPJq
-5Alw4yh+2nazThTs5hvRHnZ83tPFxKyekrOdFpFEwAdibmvM3ckfAmUqJErteFhp
-o524O37kWpzwBgk1rxwLHVxyoscVHF8vWSjk9jzvdor9XbUCQQDdPp+F/X5qQLZw
-xaYyHrWmLkRnFRaxxmiOQmvAxYKybMp0Ei8euy+wKHiNPBVPxn143hrag7a2GKIn
-hq6LwoiHAkEAxI7GYK47woZJHI6rjskjxT+DBNKjTmoDZVTa4KrWUVY1NfTC+/jI
-Ajm3cQ1QYnGEYyvlczgD3jvRdDtjJjGy3wJAV4JnkpX7pIdIIj7rR7PB4aM3Rxae
-TV7PCEXZXPxCf9RsF5EBtkQPzruTQznarB00j9Q6BuhGIqyHpt6st3cQjQJBAKtf
-oG7i+o+b7VrMuZ+Al4N+4Ijv7hqMK/HJjhycVsgL1dD5Wpe+TQRDtkEHTrLGLpsY
-xrEygYzdsr0YmlXOtxkCQQC46OoYuk/bZhp1gnFNtWXp73ZESphNOC/FovNKu5Os
-fbxKoqUbosXAi6wxuU1L+eojN0UNx98xyKjG/lyUog/m
------END RSA PRIVATE KEY-----
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/x.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/x.sh b/tools/cartridge-create/init-scripts/php/x.sh
deleted file mode 100644
index 1f42589..0000000
--- a/tools/cartridge-create/init-scripts/php/x.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/bin/bash
-#
-#
-# 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.
-#
-#
-LOG=/tmp/me.log
-CARTRIDGE_AGENT_EPR="http://localhost/me.html"
-echo "Sending register request to Cartridge agent service\n" > $LOG
-for i in {1..2}
-do
-    #curl --write-out "%{http_code}\n" --silent --output /dev/null $CARTRIDGE_AGENT_EPR
-    curl -X POST -H "Content-Type: text/xml" -d @/tmp/request.xml --silent --output /dev/null "$CARTRIDGE_AGENT_EPR"
-    ret=$?
-    echo "return value:$ret" > $LOG
-    if [[ $ret -eq 2  ]]; then
-        echo "[curl] Failed to initialize" >> $LOG
-    fi
-    if [[ $ret -eq 5 || $ret -eq 6 || $ret -eq 7  ]]; then
-        echo "[curl] Resolving host failed" >> $LOG
-    fi
-    if [[ $ret -eq 28 ]]; then
-        echo "[curl] Operation timeout" >> $LOG
-    fi
-    if [[ $ret -eq 55 || $ret -eq 56 ]]; then
-        echo "[curl] Failed sending/receiving network data" >> $LOG
-    fi
-    if [[ $ret -eq 28 ]]; then
-        echo "Operation timeout" >> $LOG
-    fi
-done
-if [[ $ret -gt 0 ]]; then
-    echo "Sending cluster join message failed. So shutdown instance and exit" >> $LOG
-    exit 0
-fi

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/y.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/y.sh b/tools/cartridge-create/init-scripts/php/y.sh
deleted file mode 100644
index a786460..0000000
--- a/tools/cartridge-create/init-scripts/php/y.sh
+++ /dev/null
@@ -1,32 +0,0 @@
-#!/bin/bash
-#
-#
-# 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.
-#
-#
-LOG=/tmp/me.log
-CARTRIDGE_AGENT_EPR="http://localhost/me.html"
-echo "Sending register request to Cartridge agent service\n" > $LOG
-for i in {1..1}
-do
-    ret=`curl --write-out "%{http_code}\n" --silent --output /dev/null $CARTRIDGE_AGENT_EPR`
-    echo "return value:$ret" > $LOG
-    #if [[ $ret -eq 2  ]]; then
-    #    echo "[curl] Failed to initialize" >> $LOG
-    #fi
-done

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/get-launch-params.rb b/tools/cartridge-create/init-scripts/tomcat/get-launch-params.rb
deleted file mode 100644
index 0948d6a..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/get-launch-params.rb
+++ /dev/null
@@ -1,53 +0,0 @@
-#! /usr/bin/ruby
-# ----------------------------------------------------------------------------
-# 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.
-# ----------------------------------------------------------------------------
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/openstack/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/openstack/get-launch-params.rb b/tools/cartridge-create/init-scripts/tomcat/openstack/get-launch-params.rb
deleted file mode 100644
index c6368ca..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/openstack/get-launch-params.rb
+++ /dev/null
@@ -1,55 +0,0 @@
-#! /usr/bin/ruby
-#
-#
-# 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.
-#
-#
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/openstack/healthcheck.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/openstack/healthcheck.sh b/tools/cartridge-create/init-scripts/tomcat/openstack/healthcheck.sh
deleted file mode 100644
index 27ab926..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/openstack/healthcheck.sh
+++ /dev/null
@@ -1,30 +0,0 @@
-#!/bin/bash
-#
-#
-# 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.
-#
-#
-
-var=`nc -z localhost 8080; echo $?`;
-if [ $var -eq 0 ]
-then
-    echo "port 8080 is available" > /dev/null 2>&1
-else
-    echo "port 8080 is not available" > /dev/null 2>&1
-    /etc/init.d/apache2 restart
-fi

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/openstack/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/openstack/stratos-init.sh b/tools/cartridge-create/init-scripts/tomcat/openstack/stratos-init.sh
deleted file mode 100755
index ba30b44..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/openstack/stratos-init.sh
+++ /dev/null
@@ -1,289 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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 script will be called from /etc/rc.local when the cartridge
-# instance is spawned. It will initiate all the tasks that needs to 
-# be run to bring the cartridge instance to operational state.
-
-export LOG=/var/log/stratos-cartridge.log
-instance_path=/var/lib/cloud/instance
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-RETRY_COUNT=30
-SLEEP_DURATION=3
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    cp ${instance_path}/user-data.txt ${instance_path}/payload/user-data.zip
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/user-data.zip
-    echo "unzippeddd..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-
-fi
-
-
-echo ---------------------------- >> $LOG
-echo "getting public ip from metadata service" >> $LOG
-
-wget http://169.254.169.254/latest/meta-data/public-ipv4
-files="`cat public-ipv4`"
-if [[ -z ${files} ]]; then
-    echo "getting public ip" >> $LOG
-    for i in {1..30}
-    do
-      rm -f ./public-ipv4
-      wget http://169.254.169.254/latest/meta-data/public-ipv4
-      files="`cat public-ipv4`"
-      if [ -z $files ]; then
-          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-          sleep $SLEEP_DURATION
-      else
-          echo "Public ip assigned" >> $LOG
-          break
-      fi
-    done
-
-    if [ -z $files ]; then
-      echo "Public ip is not yet assigned. So exit" >> $LOG
-      exit 0
-    fi
-    for x in $files
-    do
-        PUBLIC_IP="$x"
-    done
-
-
-else 
-   PUBLIC_IP="$files"
-fi
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-
-echo "Restarting apache..." >> $LOG
-
-/etc/init.d/apache2 restart
-
-echo "Apache restarted..." >> $LOG
-
-
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS}, BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-mkdir -p  /etc/agent/conf
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://service.agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-	  <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "          <remoteHost>${PUBLIC_IP}</remoteHost>
-           <service>${SERVICE}</service>
-	   <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-echo "Creating repoinfo request  " >> $LOG
-echo "TENANT_ID and SERVICE ${TENANT_ID} and ${SERVICE} " >> $LOG
-set -- "${HOST_NAME}" 
-IFS="."; declare -a Array=($*)
-ALIAS="${Array[0]}"
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:xsd=\"http://org.apache.axis2/xsd\">
-   <soapenv:Header/>
-   <soapenv:Body>
-      <xsd:getRepositoryCredentials>
-         <xsd:tenantId>${TENANT_ID}</xsd:tenantId>
-         <xsd:cartridgeType>${SERVICE}</xsd:cartridgeType>
-         <xsd:alias>${ALIAS}</xsd:alias>
-      </xsd:getRepositoryCredentials>
-   </soapenv:Body>
-</soapenv:Envelope>" > /opt/repoinforequest.xml
-
-echo "Repoinfo request created " >> $LOG
-
-echo "Private Key....Copying to .ssh  " >> $LOG
-
-cp ${instance_path}/payload/id_rsa /root/.ssh/id_rsa
-chmod 0600 /root/.ssh/id_rsa
-echo "StrictHostKeyChecking no" >> /root/.ssh/config
-
-
-
-
-#echo "Getting repo username password from repoInfoService" >> $LOG
-#curl -X POST -H "Content-Type: text/xml" -d @/etc/agent/conf/request.xml --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Git repo sync" >> $LOG
-
-# If repo is available do a git pull, else clone
-
-echo "#!/bin/bash
-if [ -d \"${APP_PATH}/.git\" ]; then
-    cd ${APP_PATH}
-
-    curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-   git config --global --bool --add http.sslVerify false
-   sudo git pull
-   rm ~/.netrc
-   sudo rm /root/.netrc
-
-else
-   curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-    git config --global --bool --add http.sslVerify false
-    cd ${APP_PATH}
-    sudo mv ROOT ../
-    sudo git clone \${repo} ${APP_PATH}
-    sudo mv ../ROOT .
-   rm ~/.netrc
-   sudo rm /root/.netrc
- 
-
-fi" > /opt/git.sh
-echo "File created.." >> $LOG
-chmod 755 /opt/git.sh
-                       
-
-
-while true
-do
-var=`nc -z localhost 8080; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 8080 is available" >> $LOG
-       break
-   else
-       echo "port 8080 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-while true
-do
-var=`nc -z localhost 8443; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 8443 is available" >> $LOG
-       break
-   else
-       echo "port 8443 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-
-echo "Sending register request to Cartridge agent service" >> $LOG
-
-curl -X POST -H "Content-Type: text/xml" -H "SOAPAction: urn:register" -d @/etc/agent/conf/request.xml -k --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Registered cartridge..." >> $LOG
-
-echo "running git clone........" >> $LOG
-su - ubuntu /opt/git.sh
-
-
-echo "setting up logging conf" >> $LOG
-
-
-echo "host:     ${BAM_IP}
-thriftPort:     ${BAM_PORT}
-
-#cartridge configs
-cartridgeAlias:  ${CARTRIDGE_ALIAS}
-tenantName:      ${HOST_NAME}
-tenantId:        ${TENANT_ID}
-localIP:         ${PUBLIC_IP}" > /opt/cartridge_data_publisher_1.0.2/conf/data_publisher.conf
-
-
-
-echo "started loggin ........."
-cd /opt/cartridge_data_publisher_1.0.2/dist/Debug/GNU-Linux-x86/
-nohup ./cartridge_data_publisher_1.0.2 /var/lib/tomcat7/logs/catalina.out >> /var/log/stratos-data-publisher.log  &
-
-echo "logging started........."
-
-
-# ========================== // End of script ===========================================================
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/payload/README
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/payload/README b/tools/cartridge-create/init-scripts/tomcat/payload/README
deleted file mode 100644
index 0e6c864..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/payload/README
+++ /dev/null
@@ -1,21 +0,0 @@
-This folder is a sample payload sent to a php instance when it is created.
-
-
-Replace the values in launch_params file with correct values of your environment.
-
-Now pack this payload as payload.zip and pass this when creating php instances.
-
-
-Following is the /etc/rc.local file of the php instance
-
-#!/bin/sh -e
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-
-By the time rc.local file is invokded in the newly created tomcat instance, the payload is already
-passed to the instance and reside in /var/lib/cloud/instance/payload
-
-You can see that rc.local invoke the wso2-openstack-init.sh script in the payload.
-
-
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/payload/launch-params
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/payload/launch-params b/tools/cartridge-create/init-scripts/tomcat/payload/launch-params
deleted file mode 100644
index 70eda77..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/payload/launch-params
+++ /dev/null
@@ -1,18 +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.
-
-TENANT=1,SVNPASS=g,SVNURL=http://11.0.0.1:80/svn,APP=tomcat7

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/stratos-init.sh b/tools/cartridge-create/init-scripts/tomcat/stratos-init.sh
deleted file mode 100644
index 0495b7b..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/stratos-init.sh
+++ /dev/null
@@ -1,274 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-
-
-export LOG=/var/log/stratos-init.log
-instance_path=/opt
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-RETRY_COUNT=30
-SLEEP_DURATION=3
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    wget http://169.254.169.254/latest/user-data -O ${instance_path}/payload/payload.zip    
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/payload.zip
-    echo "unzippeddd..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-
-fi
-
-
-echo ---------------------------- >> $LOG
-echo "getting public ip from metadata service" >> $LOG
-
-wget http://169.254.169.254/latest/meta-data/public-ipv4
-files="`cat public-ipv4`"
-if [[ -z ${files} ]]; then
-    echo "getting public ip" >> $LOG
-    for i in {1..30}
-    do
-      rm -f ./public-ipv4
-      wget http://169.254.169.254/latest/meta-data/public-ipv4
-      files="`cat public-ipv4`"
-      if [ -z $files ]; then
-          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-          sleep $SLEEP_DURATION
-      else
-          echo "Public ip assigned" >> $LOG
-          break
-      fi
-    done
-
-    if [ -z $files ]; then
-      echo "Public ip is not yet assigned. So exit" >> $LOG
-      exit 0
-    fi
-    for x in $files
-    do
-        PUBLIC_IP="$x"
-    done
-
-
-else 
-   PUBLIC_IP="$files"
-fi
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-
-echo "Restarting apache..." >> $LOG
-
-/etc/init.d/apache2 restart
-
-echo "Apache restarted..." >> $LOG
-
-
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS}, BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-mkdir -p  /etc/agent/conf
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://service.agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-	  <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "          <remoteHost>${PUBLIC_IP}</remoteHost>
-           <service>${SERVICE}</service>
-	   <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-echo "Creating repoinfo request  " >> $LOG
-echo "TENANT_ID and SERVICE ${TENANT_ID} and ${SERVICE} " >> $LOG
-set -- "${HOST_NAME}" 
-IFS="."; declare -a Array=($*)
-ALIAS="${Array[0]}"
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:xsd=\"http://org.apache.axis2/xsd\">
-   <soapenv:Header/>
-   <soapenv:Body>
-      <xsd:getRepositoryCredentials>
-         <xsd:tenantId>${TENANT_ID}</xsd:tenantId>
-         <xsd:cartridgeType>${SERVICE}</xsd:cartridgeType>
-         <xsd:alias>${ALIAS}</xsd:alias>
-      </xsd:getRepositoryCredentials>
-   </soapenv:Body>
-</soapenv:Envelope>" > /opt/repoinforequest.xml
-
-echo "Repoinfo request created " >> $LOG
-
-echo "Private Key....Copying to .ssh  " >> $LOG
-
-cp ${instance_path}/payload/id_rsa /root/.ssh/id_rsa
-chmod 0600 /root/.ssh/id_rsa
-echo "StrictHostKeyChecking no" >> /root/.ssh/config
-
-
-
-
-#echo "Getting repo username password from repoInfoService" >> $LOG
-#curl -X POST -H "Content-Type: text/xml" -d @/etc/agent/conf/request.xml --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Git repo sync" >> $LOG
-
-# If repo is available do a git pull, else clone
-
-echo "#!/bin/bash
-if [ -d \"${APP_PATH}/.git\" ]; then
-    cd ${APP_PATH}
-    
-    curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-   git config --global --bool --add http.sslVerify false
-   sudo git pull
-   rm ~/.netrc
-   sudo rm /root/.netrc
-
-else
-   curl -X POST -H \"Content-Type: text/xml\" -H \"SOAPAction: urn:getRepositoryCredentials\" -d @/opt/repoinforequest.xml --silent  \"${REPO_INFO_EPR}\" --insecure > /tmp/git.xml
-   sed '1,5d' /tmp/git.xml > /tmp/git1.xml
-   sed '2d' /tmp/git1.xml > /tmp/git.xml
-   username=\`xml_grep 'ax29:userName' /tmp/git.xml --text_only\`
-   password=\`xml_grep 'ax29:password' /tmp/git.xml --text_only\`
-   repo=\`xml_grep 'ax29:url' /tmp/git.xml --text_only\`
-   rm /tmp/git1.xml
-   rm /tmp/git.xml
-   url=\`echo \$repo |sed 's/http.*\/\///g' |sed 's/\:.*//g' |sed 's/\/.*//g'\`
-   echo \"machine \${url} login \${username} password \${password}\" > ~/.netrc
-   sudo echo \"machine \${url} login \${username} password \${password}\" > /root/.netrc
-   chmod 600 ~/.netrc
-   sudo chmod 600 /root/.netrc
-    git config --global --bool --add http.sslVerify false
-    cd ${APP_PATH}
-    sudo mv ROOT ../
-    sudo git clone \${repo} ${APP_PATH}
-    sudo mv ../ROOT .
-   rm ~/.netrc
-   sudo rm /root/.netrc
- 
-
-fi" > /opt/git.sh
-echo "File created.." >> $LOG
-chmod 755 /opt/git.sh
-                       
-
-
-while true
-do
-var=`nc -z localhost 8080; echo $?`;
-if [ $var -eq 0 ]
-   then
-       echo "port 8080 is available" >> $LOG
-       break
-   else
-       echo "port 8080 is not available" >> $LOG
-   fi
-   sleep 1
-done
-
-
-
-
-
-echo "Sending register request to Cartridge agent service" >> $LOG
-
-curl -X POST -H "Content-Type: text/xml" -H "SOAPAction: urn:register" -d @/etc/agent/conf/request.xml -k --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-echo "Registered cartridge..." >> $LOG
-
-echo "running git clone........" >> $LOG
-su - ubuntu /opt/git.sh
-
-
-echo "setting up logging conf" >> $LOG
-
-
-echo "host:     ${BAM_IP}
-thriftPort:     ${BAM_PORT}
-
-#cartridge configs
-cartridgeAlias:  ${CARTRIDGE_ALIAS}
-tenantName:      ${HOST_NAME}
-tenantId:        ${TENANT_ID}
-localIP:         ${PUBLIC_IP}" > /opt/cartridge_data_publisher_1.0.2/conf/data_publisher.conf
-
-
-
-echo "started loggin ........."
-cd /opt/cartridge_data_publisher_1.0.2/dist/Debug/GNU-Linux-x86/
-nohup ./cartridge_data_publisher_1.0.2 /var/lib/tomcat7/logs/catalina.out >> /var/log/stratos-data-publisher.log  &
-
-
-
-
-
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/tomcat/stratos.pem
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/tomcat/stratos.pem b/tools/cartridge-create/init-scripts/tomcat/stratos.pem
deleted file mode 100644
index f4260f9..0000000
--- a/tools/cartridge-create/init-scripts/tomcat/stratos.pem
+++ /dev/null
@@ -1,16 +0,0 @@
------BEGIN RSA PRIVATE KEY-----
-MIICXQIBAAKBgQCp31ZRD9kPwKoxW3sh+4x2IfldCKEfHbo18LhvOnGPJcNzqHDy
-6WWxpxPAHNAMyvrAv+hUfX4fwSRctieTim0N+fTr+mRP0q4HHhEkvEmxoXs4Y7lz
-jrh5vhMBZBAXsSurHVp2Bpie1xyjW+ksuAziT2gw6KvipjJiGTjuLTnLmQIDAQAB
-AoGAMFvtNbx+PbbKfKyfXChBb2vykmKfg70xwqNZzghkRa0pfCaKqQx6r91xiPJq
-5Alw4yh+2nazThTs5hvRHnZ83tPFxKyekrOdFpFEwAdibmvM3ckfAmUqJErteFhp
-o524O37kWpzwBgk1rxwLHVxyoscVHF8vWSjk9jzvdor9XbUCQQDdPp+F/X5qQLZw
-xaYyHrWmLkRnFRaxxmiOQmvAxYKybMp0Ei8euy+wKHiNPBVPxn143hrag7a2GKIn
-hq6LwoiHAkEAxI7GYK47woZJHI6rjskjxT+DBNKjTmoDZVTa4KrWUVY1NfTC+/jI
-Ajm3cQ1QYnGEYyvlczgD3jvRdDtjJjGy3wJAV4JnkpX7pIdIIj7rR7PB4aM3Rxae
-TV7PCEXZXPxCf9RsF5EBtkQPzruTQznarB00j9Q6BuhGIqyHpt6st3cQjQJBAKtf
-oG7i+o+b7VrMuZ+Al4N+4Ijv7hqMK/HJjhycVsgL1dD5Wpe+TQRDtkEHTrLGLpsY
-xrEygYzdsr0YmlXOtxkCQQC46OoYuk/bZhp1gnFNtWXp73ZESphNOC/FovNKu5Os
-fbxKoqUbosXAi6wxuU1L+eojN0UNx98xyKjG/lyUog/m
------END RSA PRIVATE KEY-----
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/stratos-image
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/stratos-image b/tools/cartridge-create/stratos-image
deleted file mode 100755
index e11e5de..0000000
--- a/tools/cartridge-create/stratos-image
+++ /dev/null
@@ -1,100 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-# ----------------------------------------------------------------------------
-
-
-# Die on any error:
-set -e
-
-# This script will create an cartridge image from a running virtual machine instance in Openstack using a given cartridge template. Then it will be
-# uploaded into the Glance Server. This script should be executed after logging into the Openstack controller with a valid user account that can
-# upload images to the glance server.
-
-vm_instance_ip=""
-cartridge_template=""
-vm_instance_user=""
-vm_instance_private_key=""
-software=""
-function help {
-    echo ""
-    echo "    This script  will upload the cartridge template execution file into the remote virtual machine from"
-    echo "            which you need to create the image, and execute it. At the end of the execution, image is ready for"
-    echo "            upload"
-    echo "    Usage for action create:"
-    echo ""
-    echo "    stratos-image -s <software> create <ip/hostname of the virtual machine> <cartridge template> <vm instance user> <vm instance private key>"
-    echo ""
-    echo "    -s : Softwared to be copied to the new image, separated by colon(:). Default is none. These will be"
-    echo "         copied into the /opt folder of the instance"
-    echo "    <ip/hostname of the virtual machine> : ip or hostname of the virtual machine using which image will be created from"
-    echo "    <cartridge template> : Template for the new image"
-    echo "    <vm instance user> : User name of the instance from which you need to create the image"
-    echo "    <vm instance private key> : Name of the private key of the user for logging into the virtual machine instance."
-    echo "            Copy the private key to init_scripts/<cartridge template> (e.g., init_scripts/php) folder"
-    echo ""
-}
-
-function image_validate {
-
-if [[ -z $vm_instance_ip || -z $cartridge_template || -z $vm_instance_user || -z $vm_instance_private_key ]]; then
-    help
-    exit 1
-fi
-
-}
-
-while getopts s: opts
-do
-  case $opts in
-    s)
-        software=${OPTARG}
-        ;;
-    *)
-        help
-        exit 1
-        ;;
-  esac
-done
-shift $((OPTIND-1))
-
-vm_instance_ip=$1
-echo $vm_instance_ip
-cartridge_template=$2
-echo $cartridge_template
-vm_instance_user=$3
-vm_instance_private_key=$4
-
-image_validate
-
-echo "Install from cartridge_template $cartridge_template"
-pushd ./init_scripts/$cartridge_template
-chmod 755 ./$cartridge_template
-./$cartridge_template $vm_instance_ip $vm_instance_user $vm_instance_private_key $software
-popd
-echo "Installed from cartridge_template $cartridge_template"
-echo "Now upload the image by using Openstack nova command"
-echo "nova image-create <vm instance id> <image name>"
-echo "where"
-echo "<vm instance id> is the id of the virtual machine instance from which you need to create the image"
-echo "<image name> is the name you wish to give for your new cartridge image"
-
-
-echo "Done"
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/stratos-image-local
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/stratos-image-local b/tools/cartridge-create/stratos-image-local
deleted file mode 100755
index 816fd92..0000000
--- a/tools/cartridge-create/stratos-image-local
+++ /dev/null
@@ -1,310 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-# ----------------------------------------------------------------------------
-
-
-# Die on any error:
-set -e
-
-work_dir=""
-new_image=""
-image_root="/tmp"
-image_template="default"
-software=""
-new_image_size="" #In GB
-action=""
-original_image=""
-image_type="qcow2"
-
-function help {
-    echo "Usage: stratos-image-local [optional arguments] <action> <mandatory arguments>"
-    echo "    Action can be one of the following"
-    echo "        create : Mount the base image and customize it according to the given arguments"
-    echo "        pack : Archive the newly created image and unmount the base image"
-    echo ""
-    echo "    Mandatory and optional arguments depend on the action. Following is the list of usages for each action"
-    echo ""
-    echo "    Usage for action create:"
-    echo "        stratos-image-local -r <image root> -t <image template> -s <software> -n <new image size(just enter number without G suffix)> "
-    echo "                            create <path to original image>"
-    echo ""
-    echo "            -r : Image root - This is where the base image is mounted. Default is /tmp"
-    echo "            -t : Template for the new image. Default is no template"
-    echo "            -s : Softwared to be copied to the new image, separated by colon(:). Default is none"
-    echo "            -n : Image size of the new image in GB(just enter number without G suffix). Default is the size of the base image"
-    echo "            -v : Image type. This is one of qcow2 or row. Default is qcow2"
-    echo ""
-    echo "    Usage for action pack:"
-    echo "        stratos-image-local -r <image root> -t <image template> pack <new image archive name in tar.gz format>"
-    echo ""
-    echo "            -r : Image root - This is where the base image is mounted. Default is /tmp"
-    echo "            -t : Template for the new image. Default is no template"
-    echo "            -v : Image type. This is one of qcow2 or row. Default is qcow2"
-    echo ""
-    echo "    Usage for action mount:"
-    echo "        stratos-image-local -r <image root> -t <image template> -n <new image size(just enter number without G suffix)> mount <path to original image>"
-    echo ""
-    echo "            -r : Image root - This is where the base image is mounted. Default is /tmp"
-    echo "            -t : Template for the new image. Default is no template"
-    echo "            -n : Resize the image to this size in GB(just enter number wihout G suffix) before mounting. Default is the size of the base image"
-    echo "            -v : Image type. This is one of qcow2 or row. Default is qcow2"
-    echo ""
-    echo "    eg:sudo ./stratos-image-local -r /tmp/ -n 8 mount /opt/lxc/precise-server-carbon-cloudimg-amd64-disk1.img"
-    echo ""
-    echo "    Usage for action unmount:"
-    echo "        stratos-image-local -r <image root> -t <image template>  unmount"
-    echo ""
-    echo "            -r : Image root - This is where the base image is mounted. Default is /tmp"
-    echo "            -t : Template for the new image. Default is no template"
-    echo "            -v : Image type. This is one of qcow2 or row. Default is qcow2"
-    echo ""
-    echo "    eg:sudo ./stratos-image-local -r /tmp unmount"
-}
-
-function image_validate {
-
-if [[ ( -z $action || ( -n $action && $action == "help" ) ) ]]; then
-    help
-    exit 1
-fi
-
-if [[ ( -z $action || ( -n $action && !( $action == "create" || $action == "pack" || $action == "mount" || $action == "unmount" ) ) ) ]]; then
-        echo "Mandatory parameter action with value create or pack should be provided"
-        echo "    create : Mount the base image and customize it according to the given arguments"
-        echo "    pack : Archive the newly created image and unmount the base image"
-        echo ""
-        exit 1
-    fi
-
-if [[ ( -n $action && $action == "create" && -z $original_image ) ]]; then
-        echo "Usage:"
-        echo "    stratos-image-local -r <image root> -t <image template> -s <software> -n <new image size(just enter number without G suffix)> -v <image type> create <path to original image>"
-        echo ""
-        echo "        -r : Image root - This is where the base image is mounted. Default is /tmp"
-        echo "        -t : Template for the new image. Default is no template"
-        echo "        -s : Softwared to be copied to the new image, separated by colon(:). Default is none"
-        echo "        -n : Image size of the new image in GB. Default is the size of the base image"
-        echo "        -v : Image type. qcow2 or raw. Default is qcow2"
-        echo ""
-        exit 1
-fi
-
-if [[ ( -n $action && $action == "pack" && -z $new_image ) ]]; then
-        echo "Usage:"
-        echo "    stratos-image-local -r <image root> -t <image template> pack <new image archive name in tar.gz format>"
-        echo ""
-        echo "        -r : Image root - This is where the base image is mounted. Default is /tmp"
-        echo "        -t : Template for the new image. Default is no template"
-        echo "        -v : Image type. qcow2 or raw. Default is qcow2"
-        echo ""
-        exit 1
-fi
-
-if [[ ( -n $action && $action == "mount" && -z $original_image ) ]]; then
-        echo "Usage:"
-        echo "    stratos-image-local -r <image root> -t <image template> -n <new image size(just enter number without G suffix)> -v <image type> mount <path to original image>"
-        echo ""
-        echo "        -r : Image root - This is where the base image is mounted. Default is /tmp"
-        echo "        -t : Template for the new image. Default is no template"
-        echo "        -n : Resize the image to this size in GB(just enter number without G suffix) before mounting. Default is the size of the base image"
-        echo "        -v : Image type. qcow2 or raw. Default is qcow2"
-        echo ""
-        echo "    eg:sudo ./stratos-image-local -r /tmp/ -n 8 mount /opt/lxc/precise-server-carbon-cloudimg-amd64-disk1.img"
-        exit 1
-fi
-
-}
-
-# Make sure the user is running as root.
-if [ "$UID" -ne "0" ]; then
-	echo ; echo "  You must be root to run $0.  (Try running 'sudo bash' first.)" ; echo 
-	exit 69
-fi
-
-while getopts r:t:s:n:v: opts
-do
-  case $opts in
-    r)
-        image_root=${OPTARG}
-        ;;
-    t)
-        image_template=${OPTARG}
-        ;;
-    s)
-        software=${OPTARG}
-        ;;
-    n)
-        new_image_size=${OPTARG}
-        ;;
-    v)
-        image_type=${OPTARG}
-        ;;
-    *)
-        help
-        exit 1
-        ;;
-  esac
-done
-shift $((OPTIND-1))
-action=$1
-if [[ $action == "create" ]]; then
-    original_image=$2
-elif [[ $action == "pack" ]]; then
-    new_image=$2
-elif [[ $action == "mount" ]]; then
-    original_image=$2
-fi
-
-image_validate
-
-work_dir="$image_root/$image_template"
-img_dir="$work_dir/image"
-
-if [[ $action == "create" || $action == "mount" ]]; then
-    if [ $image_type = "qcow2" ]; then
-        let "new_image_size=$new_image_size*1024*1024*1024"
-        new_image_size=$new_image_size
-        echo "qcow2 new_image_size:$new_image_size"
-    else
-        new_image_size=$new_image_size"G"
-        echo "raw new_image_size:$new_image_size"
-    fi
-fi
-
-if [[ $action == "create" ]]; then
-
-    if [ -d ./$work_dir ]; then
-        rm -rf ./$work_dir
-    fi
-
-    mkdir -p $work_dir
-
-    if [ ! -d $img_dir ]; then
-        mkdir -p $img_dir
-    fi
-
-    pushd $img_dir
-    type=`echo $original_image|awk -F . '{print $NF}'`
-    if [[ $type == "zip" ]]; then
-        zip -rq $original_image
-    elif [[ $type == "gz" || $type == "tgz" ]]; then
-        tar -zxf $original_image
-    else
-        cp -f $original_image ./
-    fi
-    popd
-    echo $img_dir
-    image_image=`ls $img_dir/*.img`
-    echo $image_image
-    if [ -z $new_image_size ]; then
-        echo "Image will not be resized since new image size is not provided"
-    else
-        echo "Resizing the original image"
-        if [ $image_type = "qcow2" ]; then
-            qemu-img resize $image_image $new_image_size
-        else
-            fsck.ext3 -f $image_image
-            e2fsck -f $image_image
-            resize2fs $image_image $new_image_size
-        fi
-    fi
-
-    echo "Mount the original image"
-    ./image_action.sh action=mount image-template=$image_template image-root=$image_root image-image=$image_image image-type=$image_type
-    echo "Original image mounted"
-    read
-
-    if [[ !( $image_template == "default" ) ]]; then
-    	echo "Customizing the original image"
-    	./image_action.sh action=create image-template=$image_template image-root=$image_root software=$software image-type=$image_type
-    fi
-
-fi
-
-if [[ $action == "pack" ]]; then
-    echo "Archiving the new image"
-    pushd $work_dir/image
-    type=`echo $new_image|awk -F . '{print $NF}'`
-    if [[ $type == "zip" ]]; then
-        zip -rq $new_image ./*
-    elif [[ $type == "gz" || $type == "tgz" ]]; then
-        tar -zcf $new_image ./*
-    elif [[ $type == "img" ]]; then
-        mv *.img $new_image
-    fi
-
-    popd
-    echo "Unmounting"
-    ./image_action.sh action=unmount image-template=$image_template image-root=$image_root image-type=$image_type
-fi
-
-if [[ $action == "mount" ]]; then
-    if [ -d ./$work_dir ]; then
-        rm -rf ./$work_dir
-    fi
-
-    mkdir -p $work_dir
-
-    if [ ! -d $img_dir ]; then
-        mkdir -p $img_dir
-    fi
-
-    pushd $img_dir
-    type=`echo $original_image|awk -F . '{print $NF}'`
-    if [[ $type == "zip" ]]; then
-        zip -rq $original_image
-    elif [[ $type == "gz" || $type == "tgz" ]]; then
-        tar -zxf $original_image
-    else
-        cp -f $original_image ./
-    fi
-    popd
-    echo $img_dir
-    image_image=`ls $img_dir/*.img`
-    echo $image_image
-
-    if [ -z $new_image_size ]; then
-        echo "Image will not be resized since new image size is not provided"
-    else
-        echo "Resizing the original image"
-        if [ $image_type = "qcow2" ]; then
-            qemu-img resize $image_image $new_image_size
-        else
-            echo "image:"$image_image
-            fsck.ext3 -f $image_image
-            e2fsck -f $image_image
-            resize2fs $image_image $new_image_size
-        fi
-    fi
-
-    echo "Mount the image"
-    ./image_action.sh action=mount image-template=$image_template image-root=$image_root image-image=$image_image image-type=$image_type
-    echo "Mounted the image"
-fi
-
-if [[ $action == "unmount" ]]; then
-    echo "Unmount the image"
-
-    ./image_action.sh action=unmount image-template=$image_template image-root=$image_root image-type=$image_type
-    echo "Unmounted the image"
-fi
-
-echo "Done"
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/uploadimg.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/uploadimg.sh b/tools/cartridge-create/uploadimg.sh
deleted file mode 100755
index 2afec21..0000000
--- a/tools/cartridge-create/uploadimg.sh
+++ /dev/null
@@ -1,32 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-# ----------------------------------------------------------------------------
-
-
-ip=$1
-imagename=$2
-userrc=$3
-mysqlpass=$4
-source ./$userrc
-ret=`mysql -u root -p$mysqlpass nova -e "select i.uuid from instances i, fixed_ips x, floating_ips f where i.id=x.instance_id and x.id=f.fixed_ip_id and f.address='$ip' and i.vm_state='ACTIVE'"`
-tok_str=(`echo $ret | tr '.' ' '`)
-id=${tok_str[1]}
-echo $id > /tmp/test
-nova image-create $id $imagename


[5/8] git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos

Posted by ud...@apache.org.
Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos


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

Branch: refs/heads/master
Commit: ce69655b7e7595fa35f86c38898e34e8711e5275
Parents: c4d5b16 cf15bd6
Author: Udara Liyanage <ud...@wso2.com>
Authored: Mon Mar 31 16:50:40 2014 -0400
Committer: Udara Liyanage <ud...@wso2.com>
Committed: Mon Mar 31 16:50:40 2014 -0400

----------------------------------------------------------------------
 .gitignore                                      |   3 +
 .../stratos/autoscaler/AutoscalerContext.java   |   8 +-
 .../health/AutoscalerHealthStatReceiver.java    |  44 +-
 .../topology/AutoscalerTopologyReceiver.java    | 127 ++-
 .../agent/util/CartridgeAgentUtils.java         |   2 +-
 components/org.apache.stratos.cli/pom.xml       |   8 +-
 .../stratos/cli/RestCommandLineService.java     |  12 +-
 .../org.apache.stratos.cloud.controller/pom.xml |   6 +-
 .../TopologySynchronizerTaskScheduler.java      |  91 +-
 .../console/data/cartridge_deployments.json     |  10 -
 .../console/data/cartridges.json                |  35 -
 .../console/data/clusters.json                  | 122 ---
 .../console/data/config_status.json             |   4 -
 .../console/data/dashboard.json                 | 197 ----
 .../console/data/elbs.json                      |  20 -
 .../console/data/lbs.json                       |  10 -
 .../console/data/mt_service_deployments.json    |  10 -
 .../console/data/mycartridges.json              |  35 -
 .../console/data/node_mem_cpu.json              | 114 ---
 .../console/data/partition_deployments.json     |  22 -
 .../console/data/policy_deployments.json        |  10 -
 .../console/data/tenants.json                   |  19 -
 .../console/themes/theme1/pages/index.hbs       |   2 -
 .../console/themes/theme1/pages/plain.hbs       |   1 -
 .../themes/theme1/renderers/cartridges.js       |   4 +-
 .../renderers/configure_stratos_wizard.js       |   2 +
 .../themes/theme1/ui/custom-fonts/Read Me.txt   |   5 -
 .../theme1/ui/custom-fonts/fonts/stratos.eot    | Bin 6660 -> 0 bytes
 .../theme1/ui/custom-fonts/fonts/stratos.svg    |  21 -
 .../theme1/ui/custom-fonts/fonts/stratos.ttf    | Bin 6496 -> 0 bytes
 .../theme1/ui/custom-fonts/fonts/stratos.woff   | Bin 6572 -> 0 bytes
 .../theme1/ui/custom-fonts/selection.json       | 268 ------
 .../themes/theme1/ui/custom-fonts/style.css     |  61 --
 .../console/themes/theme1/ui/js/main.js         |   1 -
 .../vendor/modernizr-2.6.2-respond-1.1.0.min.js |  11 -
 .../themes/theme1/ui/js/vendor/raphael-min.js   |  11 -
 .../console/util/utility.jag                    |   4 +-
 .../model/TopologyClusterInformationModel.java  |   9 +
 .../StratosManagerTopologyReceiver.java         |  36 +-
 .../CompleteTopologyMessageProcessor.java       | 138 +--
 .../rest/endpoint/services/ServiceUtils.java    |   6 +-
 .../rest/endpoint/services/StratosAdmin.java    |   4 +-
 .../openstack-nova/1.7.1-stratos/README.txt     |   3 +
 .../apis/openstack-nova/1.7.1-stratos/pom.xml   | 143 +++
 .../jclouds/openstack/nova/v2_0/NovaApi.java    | 208 +++++
 .../openstack/nova/v2_0/NovaApiMetadata.java    | 125 +++
 .../openstack/nova/v2_0/NovaAsyncApi.java       | 214 +++++
 .../v2_0/binders/BindKeyPairToJsonPayload.java  |  47 +
 .../v2_0/binders/BindMetadataToJsonPayload.java |  47 +
 .../BindSecurityGroupRuleToJsonPayload.java     |  71 ++
 .../nova/v2_0/compute/NovaComputeService.java   | 183 ++++
 .../v2_0/compute/NovaComputeServiceAdapter.java | 288 ++++++
 .../config/NovaComputeServiceContextModule.java | 286 ++++++
 .../compute/extensions/NovaImageExtension.java  | 140 +++
 .../extensions/NovaSecurityGroupExtension.java  | 373 ++++++++
 .../AllocateAndAddFloatingIpToNode.java         | 112 +++
 .../functions/CreateSecurityGroupIfNeeded.java  |  93 ++
 .../functions/FlavorInZoneToHardware.java       |  60 ++
 .../compute/functions/ImageInZoneToImage.java   |  70 ++
 .../functions/ImageToOperatingSystem.java       | 128 +++
 .../NovaSecurityGroupInZoneToSecurityGroup.java |  75 ++
 .../NovaSecurityGroupToSecurityGroup.java       |  69 ++
 .../functions/OrphanedGroupsByZoneId.java       |  77 ++
 .../RemoveFloatingIpFromNodeAndDeallocate.java  |  74 ++
 .../SecurityGroupRuleToIpPermission.java        |  99 ++
 .../functions/ServerInZoneToNodeMetadata.java   | 199 ++++
 .../compute/loaders/CreateUniqueKeyPair.java    |  79 ++
 .../loaders/FindSecurityGroupOrCreate.java      |  86 ++
 .../loaders/LoadFloatingIpsForInstance.java     |  63 ++
 .../compute/options/NovaTemplateOptions.java    | 649 +++++++++++++
 .../predicates/AllNodesInGroupTerminated.java   |  56 ++
 ...desWithGroupEncodedIntoNameThenAddToSet.java | 165 ++++
 .../nova/v2_0/config/NovaParserModule.java      | 159 ++++
 .../nova/v2_0/config/NovaProperties.java        |  43 +
 .../nova/v2_0/config/NovaRestClientModule.java  | 191 ++++
 .../openstack/nova/v2_0/domain/Address.java     | 138 +++
 .../openstack/nova/v2_0/domain/BackupType.java  |  41 +
 .../openstack/nova/v2_0/domain/Flavor.java      | 211 +++++
 .../openstack/nova/v2_0/domain/FloatingIP.java  | 173 ++++
 .../openstack/nova/v2_0/domain/Host.java        | 127 +++
 .../nova/v2_0/domain/HostAggregate.java         | 250 +++++
 .../nova/v2_0/domain/HostResourceUsage.java     | 180 ++++
 .../openstack/nova/v2_0/domain/Image.java       | 303 +++++++
 .../openstack/nova/v2_0/domain/Ingress.java     | 160 ++++
 .../openstack/nova/v2_0/domain/KeyPair.java     | 189 ++++
 .../openstack/nova/v2_0/domain/Network.java     | 173 ++++
 .../openstack/nova/v2_0/domain/Quota.java       | 356 ++++++++
 .../openstack/nova/v2_0/domain/QuotaClass.java  |  62 ++
 .../openstack/nova/v2_0/domain/RebootType.java  |  35 +
 .../nova/v2_0/domain/SecurityGroup.java         | 188 ++++
 .../nova/v2_0/domain/SecurityGroupRule.java     | 174 ++++
 .../openstack/nova/v2_0/domain/Server.java      | 476 ++++++++++
 .../nova/v2_0/domain/ServerCreated.java         | 127 +++
 .../v2_0/domain/ServerExtendedAttributes.java   | 156 ++++
 .../nova/v2_0/domain/ServerExtendedStatus.java  | 155 ++++
 .../v2_0/domain/ServerWithSecurityGroups.java   | 128 +++
 .../nova/v2_0/domain/SimpleServerUsage.java     | 312 +++++++
 .../nova/v2_0/domain/SimpleTenantUsage.java     | 245 +++++
 .../nova/v2_0/domain/TenantIdAndName.java       | 127 +++
 .../nova/v2_0/domain/VirtualInterface.java      | 128 +++
 .../openstack/nova/v2_0/domain/Volume.java      | 346 +++++++
 .../nova/v2_0/domain/VolumeAttachment.java      | 172 ++++
 .../nova/v2_0/domain/VolumeSnapshot.java        | 239 +++++
 .../openstack/nova/v2_0/domain/VolumeType.java  | 192 ++++
 .../domain/zonescoped/AvailabilityZone.java     |  73 ++
 .../v2_0/domain/zonescoped/FlavorInZone.java    |  46 +
 .../v2_0/domain/zonescoped/ImageInZone.java     |  46 +
 .../domain/zonescoped/SecurityGroupInZone.java  |  46 +
 .../v2_0/domain/zonescoped/ServerInZone.java    |  46 +
 .../nova/v2_0/domain/zonescoped/ZoneAndId.java  |  86 ++
 .../v2_0/domain/zonescoped/ZoneAndName.java     | 111 +++
 .../ZoneSecurityGroupNameAndPorts.java          |  62 ++
 .../nova/v2_0/domain/zonescoped/ZoneState.java  |  61 ++
 .../v2_0/extensions/AvailabilityZoneAPI.java    |  40 +
 .../extensions/AvailabilityZoneAsyncApi.java    |  58 ++
 .../v2_0/extensions/ExtensionNamespaces.java    | 110 +++
 .../v2_0/extensions/FlavorExtraSpecsApi.java    |  77 ++
 .../extensions/FlavorExtraSpecsAsyncApi.java    | 118 +++
 .../nova/v2_0/extensions/FloatingIPApi.java     |  98 ++
 .../v2_0/extensions/FloatingIPAsyncApi.java     | 145 +++
 .../v2_0/extensions/HostAdministrationApi.java  | 103 +++
 .../extensions/HostAdministrationAsyncApi.java  | 157 ++++
 .../nova/v2_0/extensions/HostAggregateApi.java  |  87 ++
 .../v2_0/extensions/HostAggregateAsyncApi.java  | 161 ++++
 .../nova/v2_0/extensions/KeyPairApi.java        |  65 ++
 .../nova/v2_0/extensions/KeyPairAsyncApi.java   | 101 +++
 .../nova/v2_0/extensions/QuotaApi.java          |  57 ++
 .../nova/v2_0/extensions/QuotaAsyncApi.java     |  89 ++
 .../nova/v2_0/extensions/QuotaClassApi.java     |  51 ++
 .../v2_0/extensions/QuotaClassAsyncApi.java     |  78 ++
 .../nova/v2_0/extensions/SecurityGroupApi.java  |  89 ++
 .../v2_0/extensions/SecurityGroupAsyncApi.java  | 152 ++++
 .../nova/v2_0/extensions/ServerAdminApi.java    | 120 +++
 .../v2_0/extensions/ServerAdminAsyncApi.java    | 175 ++++
 .../extensions/ServerWithSecurityGroupsApi.java |  49 +
 .../ServerWithSecurityGroupsAsyncApi.java       |  62 ++
 .../v2_0/extensions/SimpleTenantUsageApi.java   |  50 +
 .../extensions/SimpleTenantUsageAsyncApi.java   |  77 ++
 .../v2_0/extensions/VirtualInterfaceApi.java    |  43 +
 .../extensions/VirtualInterfaceAsyncApi.java    |  59 ++
 .../nova/v2_0/extensions/VolumeApi.java         | 147 +++
 .../nova/v2_0/extensions/VolumeAsyncApi.java    | 254 ++++++
 .../v2_0/extensions/VolumeAttachmentApi.java    |  87 ++
 .../extensions/VolumeAttachmentAsyncApi.java    | 107 +++
 .../nova/v2_0/extensions/VolumeTypeApi.java     | 101 +++
 .../v2_0/extensions/VolumeTypeAsyncApi.java     | 161 ++++
 .../openstack/nova/v2_0/features/FlavorApi.java |  78 ++
 .../nova/v2_0/features/FlavorAsyncApi.java      | 144 +++
 .../openstack/nova/v2_0/features/ImageApi.java  | 142 +++
 .../nova/v2_0/features/ImageAsyncApi.java       | 206 +++++
 .../openstack/nova/v2_0/features/ServerApi.java | 276 ++++++
 .../nova/v2_0/features/ServerAsyncApi.java      | 356 ++++++++
 .../functions/FieldValueResponseParsers.java    | 105 +++
 .../nova/v2_0/functions/OverLimitParser.java    |  92 ++
 .../ParseImageIdFromLocationHeader.java         |  39 +
 .../internal/OnlyMetadataValueOrNull.java       |  63 ++
 .../functions/internal/ParseDiagnostics.java    |  47 +
 .../functions/internal/ParseFlavorDetails.java  |  94 ++
 .../v2_0/functions/internal/ParseFlavors.java   |  96 ++
 .../functions/internal/ParseImageDetails.java   |  95 ++
 .../v2_0/functions/internal/ParseImages.java    |  96 ++
 .../v2_0/functions/internal/ParseKeyPairs.java  |  64 ++
 .../functions/internal/ParseServerDetails.java  |  94 ++
 .../v2_0/functions/internal/ParseServers.java   |  96 ++
 .../nova/v2_0/handlers/NovaErrorHandler.java    | 129 +++
 .../options/CreateBackupOfServerOptions.java    | 105 +++
 .../nova/v2_0/options/CreateServerOptions.java  | 557 ++++++++++++
 .../nova/v2_0/options/CreateVolumeOptions.java  | 220 +++++
 .../options/CreateVolumeSnapshotOptions.java    | 138 +++
 .../v2_0/options/CreateVolumeTypeOptions.java   | 101 +++
 .../nova/v2_0/options/ListOptions.java          | 107 +++
 .../nova/v2_0/options/RebuildServerOptions.java | 142 +++
 .../FindSecurityGroupWithNameAndReturnTrue.java |  84 ++
 .../nova/v2_0/predicates/ImagePredicates.java   |  55 ++
 .../nova/v2_0/predicates/KeyPairPredicates.java |  77 ++
 .../predicates/SecurityGroupPredicates.java     | 213 +++++
 .../services/org.jclouds.apis.ApiMetadata       |   1 +
 ...tKeyAndTenantIdAuthenticationExpectTest.java |  75 ++
 ...antNamePropertyAuthenticationExpectTest.java |  75 ++
 ...KeyAndSecretKeyAuthenticationExpectTest.java |  69 ++
 .../nova/v2_0/EndpointIdIsRandomExpectTest.java |  72 ++
 .../nova/v2_0/NovaApiMetadataTest.java          |  32 +
 .../v2_0/PasswordAuthenticationExpectTest.java  |  60 ++
 ...dAuthenticationWithTenantNameExpectTest.java |  69 ++
 .../NovaComputeServiceAdapterExpectTest.java    | 321 +++++++
 .../compute/NovaComputeServiceExpectTest.java   | 382 ++++++++
 .../compute/NovaComputeServiceLiveTest.java     |  96 ++
 .../NovaImageExtensionExpectTest.java           |  92 ++
 .../extensions/NovaImageExtensionLiveTest.java  |  43 +
 .../NovaSecurityGroupExtensionExpectTest.java   | 433 +++++++++
 .../NovaSecurityGroupExtensionLiveTest.java     |  35 +
 ...llocateAndAddFloatingIpToNodeExpectTest.java | 133 +++
 .../functions/FlavorInZoneToHardwareTest.java   |  90 ++
 .../functions/ImageInZoneToImageTest.java       |  95 ++
 .../functions/ImageToOperatingSystemTest.java   | 192 ++++
 ...aSecurityGroupInZoneToSecurityGroupTest.java |  94 ++
 .../NovaSecurityGroupToSecurityGroupTest.java   | 155 ++++
 .../functions/OrphanedGroupsByZoneIdTest.java   |  96 ++
 .../SecurityGroupRuleToIpPermissionTest.java    |  81 ++
 .../ServerInZoneToNodeMetadataTest.java         | 311 +++++++
 .../loaders/CreateUniqueKeyPairTest.java        | 111 +++
 .../loaders/FindSecurityGroupOrCreateTest.java  | 144 +++
 .../loaders/LoadFloatingIpsForInstanceTest.java | 108 +++
 .../options/NovaTemplateOptionsTest.java        | 263 ++++++
 .../extensions/AdminActionsApiExpectTest.java   | 350 +++++++
 .../extensions/AdminActionsApiLiveTest.java     | 195 ++++
 .../AvailabilityZoneApiExpectTest.java          |  64 ++
 .../AvailabilityZonesApiLiveTest.java           |  45 +
 .../FlavorExtraSpecsApiExpectTest.java          | 142 +++
 .../extensions/FlavorExtraSpecsApiLiveTest.java | 123 +++
 .../extensions/FloatingIPApiExpectTest.java     | 191 ++++
 .../v2_0/extensions/FloatingIPApiLiveTest.java  | 171 ++++
 .../HostAdministrationApiExpectTest.java        | 241 +++++
 .../HostAdministrationApiLiveTest.java          | 116 +++
 .../extensions/HostAggregateApiExpectTest.java  | 179 ++++
 .../extensions/HostAggregateApiLiveTest.java    | 148 +++
 .../v2_0/extensions/KeyPairApiExpectTest.java   | 142 +++
 .../v2_0/extensions/KeyPairApiLiveTest.java     |  76 ++
 .../v2_0/extensions/QuotaApiExpectTest.java     | 125 +++
 .../nova/v2_0/extensions/QuotaApiLiveTest.java  | 100 ++
 .../extensions/QuotaClassApiExpectTest.java     | 105 +++
 .../v2_0/extensions/QuotaClassApiLiveTest.java  |  73 ++
 .../extensions/SecurityGroupApiExpectTest.java  | 235 +++++
 .../extensions/SecurityGroupApiLiveTest.java    | 100 ++
 .../ServerWithSecurityGroupsApiExpectTest.java  |  63 ++
 .../ServerWithSecurityGroupsApiLiveTest.java    |  80 ++
 .../SimpleTenantUsageApiExpectTest.java         |  99 ++
 .../SimpleTenantUsageApiLiveTest.java           |  51 ++
 .../VirtualInterfaceApiExpectTest.java          |  64 ++
 .../extensions/VirtualInterfaceApiLiveTest.java |  68 ++
 .../v2_0/extensions/VolumeApiExpectTest.java    | 460 ++++++++++
 .../nova/v2_0/extensions/VolumeApiLiveTest.java | 274 ++++++
 .../VolumeAttachmentApiExpectTest.java          | 168 ++++
 .../extensions/VolumeAttachmentApiLiveTest.java | 156 ++++
 .../extensions/VolumeTypeApiExpectTest.java     | 259 ++++++
 .../v2_0/extensions/VolumeTypeApiLiveTest.java  | 126 +++
 .../v2_0/features/ExtensionApiExpectTest.java   | 115 +++
 .../v2_0/features/ExtensionApiLiveTest.java     |  84 ++
 .../nova/v2_0/features/FlavorApiExpectTest.java | 164 ++++
 .../nova/v2_0/features/FlavorApiLiveTest.java   | 105 +++
 .../nova/v2_0/features/ImageApiExpectTest.java  | 377 ++++++++
 .../nova/v2_0/features/ImageApiLiveTest.java    | 101 +++
 .../nova/v2_0/features/ServerApiExpectTest.java | 746 +++++++++++++++
 .../nova/v2_0/features/ServerApiLiveTest.java   | 206 +++++
 .../CreateSecurityGroupIfNeededTest.java        | 168 ++++
 ...ityGroupWithNameAndReturnTrueExpectTest.java | 102 +++
 .../v2_0/functions/InternalURLLiveTest.java     |  64 ++
 .../v2_0/handlers/NovaErrorHandlerTest.java     | 225 +++++
 .../v2_0/internal/BaseNovaApiExpectTest.java    |  28 +
 .../nova/v2_0/internal/BaseNovaApiLiveTest.java | 120 +++
 ...BaseNovaComputeServiceContextExpectTest.java |  87 ++
 .../BaseNovaComputeServiceExpectTest.java       |  35 +
 .../nova/v2_0/internal/BaseNovaExpectTest.java  |  84 ++
 ...eComputeServiceTypicalSecurityGroupTest.java |  76 ++
 .../nova/v2_0/parse/ParseCreateFlavorTest.java  |  58 ++
 .../nova/v2_0/parse/ParseCreatedServerTest.java |  80 ++
 .../parse/ParseExtensionListNormalTest.java     |  76 ++
 .../nova/v2_0/parse/ParseExtensionListTest.java |  88 ++
 .../nova/v2_0/parse/ParseExtensionTest.java     |  71 ++
 .../nova/v2_0/parse/ParseFlavorListTest.java    |  85 ++
 .../nova/v2_0/parse/ParseFlavorTest.java        |  70 ++
 .../v2_0/parse/ParseFloatingIPListTest.java     |  59 ++
 .../nova/v2_0/parse/ParseFloatingIPTest.java    |  53 ++
 .../nova/v2_0/parse/ParseImageListTest.java     |  85 ++
 .../nova/v2_0/parse/ParseImageTest.java         |  98 ++
 .../nova/v2_0/parse/ParseKeyPairListTest.java   |  68 ++
 .../nova/v2_0/parse/ParseKeyPairTest.java       |  61 ++
 .../nova/v2_0/parse/ParseMetadataItemTest.java  |  58 ++
 .../nova/v2_0/parse/ParseMetadataListTest.java  |  63 ++
 .../v2_0/parse/ParseMetadataUpdateTest.java     |  64 ++
 .../v2_0/parse/ParseSecurityGroupListTest.java  |  72 ++
 .../nova/v2_0/parse/ParseSecurityGroupTest.java |  69 ++
 .../v2_0/parse/ParseServerDetailsEssexTest.java | 170 ++++
 .../nova/v2_0/parse/ParseServerDiagnostics.java |  57 ++
 .../nova/v2_0/parse/ParseServerListTest.java    |  85 ++
 .../nova/v2_0/parse/ParseServerTest.java        | 117 +++
 .../parse/ParseServerWithAllExtensionsTest.java | 104 +++
 .../ParseServerWithInternetAddressesTest.java   |  99 ++
 ...ublicIpsInPrivateAddressBlockExpectTest.java |  99 ++
 .../v2_0/predicates/ImagePredicatesTest.java    |  44 +
 .../predicates/SecurityGroupPredicatesTest.java | 129 +++
 .../src/test/resources/attachment_details.json  |   1 +
 .../src/test/resources/attachment_list.json     |   1 +
 .../src/test/resources/extension_details.json   |  21 +
 .../src/test/resources/extension_list.json      |  42 +
 .../src/test/resources/extension_list_full.json | 281 ++++++
 .../test/resources/extension_list_normal.json   |  31 +
 .../resources/extension_list_openstack.json     | 115 +++
 .../src/test/resources/flavor_details.json      |  19 +
 .../src/test/resources/flavor_list.json         |  32 +
 .../src/test/resources/flavor_list_detail.json  |   1 +
 .../resources/flavor_list_detail_openstack.json |  83 ++
 .../src/test/resources/flavor_new.json          |  10 +
 .../src/test/resources/floatingip_details.json  |   9 +
 .../src/test/resources/floatingip_list.json     |  16 +
 .../1.7.1-stratos/src/test/resources/host.json  |   1 +
 .../test/resources/host_aggregate_details.json  |   1 +
 .../src/test/resources/host_aggregate_list.json |   1 +
 .../host_aggregate_with_host_details.json       |   1 +
 .../src/test/resources/hosts_list.json          |   1 +
 .../src/test/resources/image_active.json        |  41 +
 .../src/test/resources/image_details.json       |  41 +
 .../src/test/resources/image_list.json          |  32 +
 .../src/test/resources/image_list_detail.json   |   1 +
 .../image_list_detail_imageextension.json       | 121 +++
 .../resources/image_list_detail_openstack.json  |  81 ++
 .../src/test/resources/keypair_created.json     |   9 +
 .../keypair_created_computeservice.json         |   9 +
 .../src/test/resources/keypair_list.json        |  18 +
 .../test/resources/listAvailabilityZones.json   |  11 +
 .../src/test/resources/metadata_item.json       |   5 +
 .../src/test/resources/metadata_list.json       |   6 +
 .../src/test/resources/metadata_updated.json    |   7 +
 .../src/test/resources/new_server.json          |  41 +
 .../resources/new_server_disk_config_auto.json  |  42 +
 .../new_server_disk_config_manual.json          |  42 +
 .../src/test/resources/new_server_in_zone.json  |  41 +
 .../resources/new_server_networks_response.json |  42 +
 .../test/resources/new_server_no_adminpass.json |  40 +
 .../resources/new_server_nova_networks.json     |  41 +
 .../src/test/resources/quota_class.json         |  15 +
 .../src/test/resources/quotas.json              |  15 +
 .../test/resources/securitygroup_created.json   |   9 +
 .../test/resources/securitygroup_details.json   |  34 +
 ...itygroup_details_computeservice_typical.json |  51 ++
 .../securitygroup_details_extension.json        |  34 +
 ...securitygroup_details_extension_norules.json |  10 +
 .../resources/securitygroup_details_port22.json |  19 +
 .../src/test/resources/securitygroup_list.json  |  51 ++
 ...oup_list_details_computeservice_typical.json |  53 ++
 .../resources/securitygroup_list_extension.json |  51 ++
 .../resources/securitygrouprule_created.json    |  12 +
 .../securitygrouprule_created_cidr.json         |  13 +
 .../securitygrouprule_created_group.json        |  14 +
 .../src/test/resources/server_details.json      |  86 ++
 .../test/resources/server_details_devstack.json |  44 +
 .../resources/server_details_openstack.json     |  46 +
 .../src/test/resources/server_diagnostics.json  |  17 +
 .../src/test/resources/server_list.json         |  32 +
 .../src/test/resources/server_list_details.json |  79 ++
 .../resources/server_list_details_essex.json    | 152 ++++
 .../resources/server_public_ip_in_private.json  |  51 ++
 .../resources/server_with_security_groups.json  |   1 +
 .../server_with_security_groups_extension.json  |   1 +
 .../src/test/resources/simple_tenant_usage.json |   1 +
 .../test/resources/simple_tenant_usages.json    |   1 +
 .../src/test/resources/snapshot_details.json    |   1 +
 .../src/test/resources/snapshot_list.json       |   1 +
 .../test/resources/snapshot_list_detail.json    |   1 +
 .../test/resources/virtual_interfaces_list.json |   1 +
 .../src/test/resources/volume_details.json      |   1 +
 .../src/test/resources/volume_list.json         |   1 +
 .../src/test/resources/volume_list_detail.json  |   1 +
 .../src/test/resources/volume_type.json         |   9 +
 .../test/resources/volume_type_extra_specs.json |   1 +
 .../src/test/resources/volume_type_list.json    |   1 +
 .../apis/vcloud/1.7.1-stratos/README.txt        |   6 +
 .../jclouds/apis/vcloud/1.7.1-stratos/pom.xml   | 129 +++
 .../vcloud/TaskInErrorStateException.java       |  39 +
 .../vcloud/TaskStillRunningException.java       |  39 +
 .../main/java/org/jclouds/vcloud/VCloudApi.java |  91 ++
 .../org/jclouds/vcloud/VCloudApiMetadata.java   | 103 +++
 .../org/jclouds/vcloud/VCloudMediaType.java     | 221 +++++
 .../jclouds/vcloud/VCloudResponseException.java |  69 ++
 .../java/org/jclouds/vcloud/VCloudToken.java    |  37 +
 .../org/jclouds/vcloud/VCloudVersionsApi.java   |  38 +
 .../binders/BindCPUCountToXmlPayload.java       |  79 ++
 .../BindCaptureVAppParamsToXmlPayload.java      | 124 +++
 .../binders/BindCatalogItemToXmlPayload.java    | 126 +++
 .../binders/BindCloneParamsToXmlPayload.java    | 133 +++
 .../BindCloneVAppParamsToXmlPayload.java        |  65 ++
 ...BindCloneVAppTemplateParamsToXmlPayload.java |  60 ++
 .../BindDeployVAppParamsToXmlPayload.java       |  42 +
 ...ndGuestCustomizationSectionToXmlPayload.java | 112 +++
 ...stantiateVAppTemplateParamsToXmlPayload.java | 221 +++++
 .../vcloud/binders/BindMemoryToXmlPayload.java  |  80 ++
 ...indNetworkConnectionSectionToXmlPayload.java | 106 +++
 .../vcloud/binders/BindParamsToXmlPayload.java  |  81 ++
 .../BindUndeployVAppParamsToXmlPayload.java     |  42 +
 .../OrgNameAndCatalogNameToEndpoint.java        |  79 ++
 .../binders/OrgNameAndVDCNameToEndpoint.java    |  78 ++
 .../OrgNameCatalogNameItemNameToEndpoint.java   |  77 ++
 ...meCatalogNameVAppTemplateNameToEndpoint.java |  90 ++
 .../OrgNameVDCNameNetworkNameToEndpoint.java    |  54 ++
 ...NameVDCNameResourceEntityNameToEndpoint.java |  54 ++
 .../OrgNameVDCNameResourceNameToEndpoint.java   |  81 ++
 .../VCloudComputeServiceContextModule.java      |  39 +
 .../VCloudComputeServiceDependenciesModule.java | 154 ++++
 .../functions/FindLocationForResource.java      |  69 ++
 .../compute/functions/HardwareForVApp.java      |  71 ++
 .../functions/HardwareForVAppTemplate.java      |  84 ++
 .../compute/functions/ImageForVAppTemplate.java |  82 ++
 .../compute/functions/VAppToNodeMetadata.java   | 112 +++
 ...dHardwareBuilderFromResourceAllocations.java |  43 +
 ...EnvelopeOrThrowIllegalArgumentException.java |  77 ++
 .../internal/VCloudTemplateBuilderImpl.java     |  48 +
 .../compute/options/VCloudTemplateOptions.java  | 350 +++++++
 ...edIntoNameThenCustomizeDeployAndPowerOn.java | 302 +++++++
 ...etworkConfigurationForNetworkAndOptions.java |  80 ++
 .../strategy/VCloudComputeServiceAdapter.java   | 263 ++++++
 .../vcloud/compute/util/VCloudComputeUtils.java | 116 +++
 .../vcloud/config/DefaultCatalogForOrg.java     |  63 ++
 .../vcloud/config/DefaultNetworkForVDC.java     |  65 ++
 .../vcloud/config/DefaultOrgForUser.java        |  58 ++
 .../vcloud/config/DefaultTasksListForOrg.java   |  53 ++
 .../config/DefaultVCloudReferencesModule.java   | 165 ++++
 .../jclouds/vcloud/config/DefaultVDCForOrg.java |  63 ++
 .../vcloud/config/VCloudHttpApiModule.java      | 538 +++++++++++
 .../jclouds/vcloud/domain/AllocationModel.java  |  70 ++
 .../org/jclouds/vcloud/domain/Capacity.java     | 108 +++
 .../java/org/jclouds/vcloud/domain/Catalog.java |  69 ++
 .../org/jclouds/vcloud/domain/CatalogItem.java  |  37 +
 .../domain/GuestCustomizationSection.java       | 440 +++++++++
 .../domain/InstantiateVAppTemplateParams.java   |  96 ++
 .../vcloud/domain/NetworkConnection.java        | 233 +++++
 .../vcloud/domain/NetworkConnectionSection.java | 218 +++++
 .../java/org/jclouds/vcloud/domain/Org.java     |  86 ++
 .../jclouds/vcloud/domain/ReferenceType.java    |  55 ++
 .../java/org/jclouds/vcloud/domain/Status.java  | 246 +++++
 .../java/org/jclouds/vcloud/domain/Task.java    |  72 ++
 .../org/jclouds/vcloud/domain/TaskStatus.java   |  71 ++
 .../org/jclouds/vcloud/domain/TasksList.java    |  37 +
 .../java/org/jclouds/vcloud/domain/VApp.java    |  87 ++
 .../org/jclouds/vcloud/domain/VAppTemplate.java |  97 ++
 .../org/jclouds/vcloud/domain/VCloudError.java  | 123 +++
 .../jclouds/vcloud/domain/VCloudSession.java    |  29 +
 .../java/org/jclouds/vcloud/domain/VDC.java     | 146 +++
 .../org/jclouds/vcloud/domain/VDCStatus.java    |  57 ++
 .../main/java/org/jclouds/vcloud/domain/Vm.java | 108 +++
 .../vcloud/domain/internal/CatalogImpl.java     | 193 ++++
 .../vcloud/domain/internal/CatalogItemImpl.java | 111 +++
 .../vcloud/domain/internal/ErrorImpl.java       | 119 +++
 .../jclouds/vcloud/domain/internal/OrgImpl.java | 171 ++++
 .../domain/internal/ReferenceTypeImpl.java      | 103 +++
 .../vcloud/domain/internal/TaskImpl.java        | 165 ++++
 .../vcloud/domain/internal/TasksListImpl.java   |  81 ++
 .../vcloud/domain/internal/VAppImpl.java        | 166 ++++
 .../domain/internal/VAppTemplateImpl.java       | 205 +++++
 .../jclouds/vcloud/domain/internal/VDCImpl.java | 292 ++++++
 .../jclouds/vcloud/domain/internal/VmImpl.java  | 217 +++++
 .../vcloud/domain/network/DhcpService.java      | 106 +++
 .../jclouds/vcloud/domain/network/Features.java |  95 ++
 .../vcloud/domain/network/FenceMode.java        |  70 ++
 .../vcloud/domain/network/FirewallService.java  |  86 ++
 .../domain/network/IpAddressAllocationMode.java |  52 ++
 .../jclouds/vcloud/domain/network/IpRange.java  |  76 ++
 .../jclouds/vcloud/domain/network/IpScope.java  | 170 ++++
 .../vcloud/domain/network/NatService.java       | 115 +++
 .../vcloud/domain/network/NetworkConfig.java    | 167 ++++
 .../vcloud/domain/network/OrgNetwork.java       | 121 +++
 .../domain/network/firewall/FirewallPolicy.java |  54 ++
 .../network/firewall/FirewallProtocols.java     |  73 ++
 .../domain/network/firewall/FirewallRule.java   | 125 +++
 .../domain/network/internal/OrgNetworkImpl.java | 202 +++++
 .../vcloud/domain/network/nat/NatPolicy.java    |  54 ++
 .../vcloud/domain/network/nat/NatProtocol.java  |  48 +
 .../vcloud/domain/network/nat/NatRule.java      |  35 +
 .../vcloud/domain/network/nat/NatType.java      |  61 ++
 .../domain/network/nat/rules/MappingMode.java   |  54 ++
 .../network/nat/rules/OneToOneVmRule.java       | 110 +++
 .../network/nat/rules/PortForwardingRule.java   | 111 +++
 .../vcloud/domain/network/nat/rules/VmRule.java | 128 +++
 .../EditableResourceAllocationSettingData.java  | 302 +++++++
 .../vcloud/domain/ovf/VCloudHardDisk.java       | 330 +++++++
 .../vcloud/domain/ovf/VCloudNetworkAdapter.java | 332 +++++++
 .../vcloud/domain/ovf/VCloudNetworkSection.java |  80 ++
 .../ovf/VCloudOperatingSystemSection.java       | 118 +++
 .../ovf/VCloudVirtualHardwareSection.java       | 179 ++++
 .../org/jclouds/vcloud/endpoints/Catalog.java   |  37 +
 .../org/jclouds/vcloud/endpoints/Network.java   |  37 +
 .../java/org/jclouds/vcloud/endpoints/Org.java  |  37 +
 .../org/jclouds/vcloud/endpoints/OrgList.java   |  37 +
 .../org/jclouds/vcloud/endpoints/TasksList.java |  37 +
 .../jclouds/vcloud/endpoints/VCloudLogin.java   |  38 +
 .../java/org/jclouds/vcloud/endpoints/VDC.java  |  37 +
 .../org/jclouds/vcloud/features/CatalogApi.java | 144 +++
 .../org/jclouds/vcloud/features/NetworkApi.java |  61 ++
 .../org/jclouds/vcloud/features/OrgApi.java     |  86 ++
 .../org/jclouds/vcloud/features/TaskApi.java    |  82 ++
 .../org/jclouds/vcloud/features/VAppApi.java    | 261 ++++++
 .../vcloud/features/VAppTemplateApi.java        | 180 ++++
 .../org/jclouds/vcloud/features/VDCApi.java     |  73 ++
 .../java/org/jclouds/vcloud/features/VmApi.java | 295 ++++++
 ...ddVCloudAuthorizationAndCookieToRequest.java |  63 ++
 .../vcloud/functions/CatalogItemsInCatalog.java |  64 ++
 .../vcloud/functions/CatalogItemsInOrg.java     |  57 ++
 .../jclouds/vcloud/functions/CatalogsInOrg.java |  73 ++
 .../functions/DefaultNetworkNameInTemplate.java |  47 +
 .../jclouds/vcloud/functions/NetworksInOrg.java |  57 ++
 .../vcloud/functions/OrgNameToEndpoint.java     |  57 ++
 .../functions/OrgNameToTasksListEndpoint.java   |  62 ++
 .../vcloud/functions/OrgsForLocations.java      |  73 ++
 .../jclouds/vcloud/functions/OrgsForNames.java  |  56 ++
 .../ParseLoginResponseFromHeaders.java          | 105 +++
 .../functions/VAppTemplatesForCatalogItems.java |  66 ++
 .../vcloud/functions/VAppTemplatesInOrg.java    |  65 ++
 .../org/jclouds/vcloud/functions/VDCsInOrg.java |  57 ++
 .../ParseVCloudErrorFromHttpResponse.java       | 121 +++
 .../http/filters/VCloudBasicAuthentication.java |  58 ++
 .../http/filters/VCloudSupportedVersions.java   |  35 +
 .../jclouds/vcloud/internal/VCloudLoginApi.java |  44 +
 .../org/jclouds/vcloud/loaders/OVFLoader.java   |  47 +
 .../vcloud/loaders/VAppTemplateLoader.java      |  47 +
 .../org/jclouds/vcloud/location/DefaultVDC.java |  74 ++
 .../location/OrgAndVDCToLocationSupplier.java   |  93 ++
 .../vcloud/options/CaptureVAppOptions.java      |  51 ++
 .../vcloud/options/CatalogItemOptions.java      |  77 ++
 .../jclouds/vcloud/options/CloneOptions.java    |  53 ++
 .../vcloud/options/CloneVAppOptions.java        |  88 ++
 .../options/CloneVAppTemplateOptions.java       |  42 +
 .../options/InstantiateVAppTemplateOptions.java | 178 ++++
 .../jclouds/vcloud/predicates/TaskSuccess.java  |  65 ++
 .../vcloud/reference/VCloudConstants.java       |  51 ++
 .../jclouds/vcloud/reference/package-info.java  |  21 +
 ...thNameMatchingConfigurationKeyOrDefault.java |  99 ++
 .../vcloud/suppliers/VAppTemplatesSupplier.java |  86 ++
 .../java/org/jclouds/vcloud/util/Utils.java     |  71 ++
 .../org/jclouds/vcloud/util/VCloudUtils.java    |  67 ++
 .../org/jclouds/vcloud/xml/CatalogHandler.java  | 104 +++
 .../jclouds/vcloud/xml/CatalogItemHandler.java  |  81 ++
 .../org/jclouds/vcloud/xml/ErrorHandler.java    |  45 +
 .../xml/GuestCustomizationSectionHandler.java   | 137 +++
 .../vcloud/xml/NetworkConnectionHandler.java    |  87 ++
 .../xml/NetworkConnectionSectionHandler.java    | 103 +++
 .../java/org/jclouds/vcloud/xml/OrgHandler.java | 112 +++
 .../org/jclouds/vcloud/xml/OrgListHandler.java  |  54 ++
 .../jclouds/vcloud/xml/OrgNetworkHandler.java   | 325 +++++++
 .../vcloud/xml/SupportedVersionsHandler.java    |  60 ++
 .../org/jclouds/vcloud/xml/TaskHandler.java     | 128 +++
 .../jclouds/vcloud/xml/TasksListHandler.java    |  74 ++
 .../org/jclouds/vcloud/xml/VAppHandler.java     | 151 ++++
 .../jclouds/vcloud/xml/VAppTemplateHandler.java | 152 ++++
 .../xml/VCloudVirtualHardwareHandler.java       |  72 ++
 .../java/org/jclouds/vcloud/xml/VDCHandler.java | 167 ++++
 .../java/org/jclouds/vcloud/xml/VmHandler.java  | 178 ++++
 .../xml/ovf/VCloudNetworkSectionHandler.java    |  69 ++
 .../xml/ovf/VCloudOperatingSystemHandler.java   |  81 ++
 ...oudResourceAllocationSettingDataHandler.java |  89 ++
 .../services/org.jclouds.apis.ApiMetadata       |   1 +
 .../jclouds/vcloud/VCloudApiMetadataTest.java   |  32 +
 .../java/org/jclouds/vcloud/VCloudApiTest.java  |  64 ++
 .../vcloud/VCloudSessionRefreshLiveTest.java    |  41 +
 .../jclouds/vcloud/VCloudVersionsApiTest.java   |  69 ++
 .../BindCatalogItemToXmlPayloadTest.java        |  53 ++
 .../BindCloneVAppParamsToXmlPayloadTest.java    |  81 ++
 ...CloneVAppTemplateParamsToXmlPayloadTest.java |  89 ++
 .../BindDeployVAppParamsToXmlPayloadTest.java   |  61 ++
 ...tiateVAppTemplateParamsToXmlPayloadTest.java | 179 ++++
 ...etworkConnectionSectionToXmlPayloadTest.java |  68 ++
 .../BindUndeployVAppParamsToXmlPayloadTest.java |  61 ++
 .../BaseVCloudComputeServiceExpectTest.java     | 160 ++++
 .../compute/VCloudComputeServiceLiveTest.java   |  54 ++
 .../functions/FindLocationForResourceTest.java  |  64 ++
 .../functions/ListImagesInVCloudExpectTest.java |  89 ++
 .../functions/VAppToNodeMetadataTest.java       | 228 +++++
 .../options/VCloudTemplateOptionsTest.java      | 197 ++++
 ...ThenCustomizeDeployAndPowerOnExpectTest.java | 171 ++++
 .../VCloudComputeServiceAdapterTest.java        |  89 ++
 .../vcloud/features/CatalogApiLiveTest.java     |  53 ++
 .../jclouds/vcloud/features/CatalogApiTest.java | 131 +++
 .../vcloud/features/NetworkApiLiveTest.java     |  29 +
 .../jclouds/vcloud/features/NetworkApiTest.java |  75 ++
 .../jclouds/vcloud/features/OrgApiLiveTest.java |  42 +
 .../org/jclouds/vcloud/features/OrgApiTest.java |  91 ++
 .../vcloud/features/TaskApiLiveTest.java        |  29 +
 .../jclouds/vcloud/features/TaskApiTest.java    | 108 +++
 .../vcloud/features/VAppApiLiveTest.java        |  53 ++
 .../jclouds/vcloud/features/VAppApiTest.java    | 315 +++++++
 .../features/VAppTemplateApiLiveTest.java       | 168 ++++
 .../vcloud/features/VAppTemplateApiTest.java    | 238 +++++
 .../jclouds/vcloud/features/VDCApiLiveTest.java |  29 +
 .../org/jclouds/vcloud/features/VDCApiTest.java | 102 +++
 .../jclouds/vcloud/features/VmApiLiveTest.java  | 163 ++++
 .../org/jclouds/vcloud/features/VmApiTest.java  | 320 +++++++
 ...loudAuthorizationAndCookieToRequestTest.java |  55 ++
 .../ParseLoginResponseFromHeadersTest.java      | 147 +++
 .../ParseVCloudErrorFromHttpResponseTest.java   |  96 ++
 .../vcloud/internal/BasePayloadTest.java        |  51 ++
 .../vcloud/internal/BaseVCloudApiLiveTest.java  |  59 ++
 .../vcloud/internal/BaseVCloudApiTest.java      | 272 ++++++
 .../vcloud/internal/VCloudLoginApiTest.java     |  97 ++
 .../InstantiateVAppTemplateOptionsTest.java     |  74 ++
 ...meMatchingConfigurationKeyOrDefaultTest.java | 115 +++
 .../org/jclouds/vcloud/utils/TestUtils.java     |  32 +
 .../jclouds/vcloud/xml/CatalogHandlerTest.java  | 135 +++
 .../vcloud/xml/CatalogItemHandlerTest.java      |  86 ++
 .../GuestCustomizationSectionHandlerTest.java   |  75 ++
 .../xml/NetworkConnectionHandlerTest.java       |  57 ++
 .../NetworkConnectionSectionHandlerTest.java    |  63 ++
 .../org/jclouds/vcloud/xml/OrgHandlerTest.java  | 124 +++
 .../jclouds/vcloud/xml/OrgListHandlerTest.java  |  57 ++
 .../vcloud/xml/OrgNetworkHandlerTest.java       | 104 +++
 .../xml/SupportedVersionsHandlerTest.java       |  53 ++
 .../org/jclouds/vcloud/xml/TaskHandlerTest.java | 135 +++
 .../vcloud/xml/TasksListHandlerTest.java        |  82 ++
 .../org/jclouds/vcloud/xml/VAppHandlerTest.java |  77 ++
 .../vcloud/xml/VAppTemplateHandlerTest.java     | 164 ++++
 .../org/jclouds/vcloud/xml/VDCHandlerTest.java  | 136 +++
 .../org/jclouds/vcloud/xml/VmHandlerTest.java   |  79 ++
 ...VCloudOperatingSystemSectionHandlerTest.java |  61 ++
 ...VCloudVirtualHardwareSectionHandlerTest.java | 153 ++++
 .../src/test/resources/captureVApp-default.xml  |   1 +
 .../src/test/resources/captureVApp.xml          |   1 +
 .../src/test/resources/catalog-blank.xml        |   7 +
 .../src/test/resources/catalog-hosting.xml      |  25 +
 .../src/test/resources/catalog.xml              |  27 +
 .../src/test/resources/catalog1.0-vcd15.xml     |   9 +
 ...alogItem-carrenza-with-default-namespace.xml |   8 +
 ...talogItem-carrenza-with-vcloud-namespace.xml |   8 +
 .../src/test/resources/catalogItem-hosting.xml  |  14 +
 .../test/resources/catalogItem-terremark.xml    |  16 +
 .../src/test/resources/catalogItem1.0-vcd15.xml |   8 +
 .../src/test/resources/copyVApp-default.xml     |   1 +
 .../src/test/resources/copyVApp.xml             |   1 +
 .../test/resources/copyVAppTemplate-default.xml |   1 +
 .../src/test/resources/copyVAppTemplate.xml     |   1 +
 .../src/test/resources/cpuItem.xml              |   1 +
 .../src/test/resources/guestCustomization.xml   |  23 +
 .../resources/guestCustomizationSection.xml     |   3 +
 .../src/test/resources/instantiatedvapp.xml     |  13 +
 .../instantiationparams-description.xml         |   1 +
 .../resources/instantiationparams-network.xml   |   1 +
 .../src/test/resources/instantiationparams.xml  |   1 +
 .../1.7.1-stratos/src/test/resources/log4j.xml  | 151 ++++
 .../src/test/resources/memoryItem.xml           |   1 +
 .../src/test/resources/moveVApp.xml             |   1 +
 .../src/test/resources/moveVAppTemplate.xml     |   1 +
 .../src/test/resources/networkconnection.xml    |   7 +
 .../test/resources/networkconnectionsection.xml |  18 +
 .../src/test/resources/org-1.0.xml              |  24 +
 .../src/test/resources/org-hosting.xml          |  12 +
 .../src/test/resources/org-savvis.xml           |  13 +
 .../1.7.1-stratos/src/test/resources/org.xml    |   5 +
 .../src/test/resources/org1.0-vcd15.xml         |  11 +
 .../src/test/resources/orgList1.0-vcd15.xml     |   4 +
 .../src/test/resources/orglist-savvis.xml       |   3 +
 .../src/test/resources/orglist.xml              |   3 +
 .../src/test/resources/orgnetwork-bridged.xml   |  20 +
 .../src/test/resources/orgnetwork-isolated.xml  |  31 +
 .../1.7.1-stratos/src/test/resources/os.xml     |  11 +
 .../src/test/resources/ovf-multi-vm.xml         | 285 ++++++
 .../src/test/resources/ovf-ubuntu64.xml         | 148 +++
 .../src/test/resources/task-1.0.xml             |   9 +
 .../src/test/resources/task-error.xml           |   9 +
 .../src/test/resources/task-hosting.xml         |  12 +
 .../src/test/resources/task-self.xml            |  11 +
 .../src/test/resources/task-vcd15.xml           |   5 +
 .../1.7.1-stratos/src/test/resources/task.xml   |   8 +
 .../src/test/resources/taskslist-hosting.xml    |  14 +
 .../src/test/resources/taskslist.xml            |  27 +
 .../resources/template1.0-vcd15-multi-vm.xml    |  68 ++
 .../src/test/resources/template1.0-vcd15.xml    |  72 ++
 .../src/test/resources/vAppTemplate-copying.xml |  41 +
 .../src/test/resources/vAppTemplate.xml         | 143 +++
 .../vAppTemplate1.0-vcd15_withNewlines.xml      | 109 +++
 .../src/test/resources/vapp-hosting.xml         | 235 +++++
 .../src/test/resources/vapp-none.xml            | 237 +++++
 .../src/test/resources/vapp-pool.xml            | 227 +++++
 .../src/test/resources/vapp-rhel-off-static.xml | 325 +++++++
 .../src/test/resources/vapp-ubuntu-off-dhcp.xml | 213 +++++
 .../src/test/resources/vapp-unresolved.xml      |  21 +
 .../src/test/resources/vapp-win-off-static.xml  | 219 +++++
 .../src/test/resources/vdc-1.0.xml              |  49 +
 .../src/test/resources/vdc-hosting.xml          |  60 ++
 .../src/test/resources/vdc-nonet.xml            |  22 +
 .../1.7.1-stratos/src/test/resources/vdc.xml    |  36 +
 .../src/test/resources/vdc1.0-vcd15.xml         |  47 +
 .../src/test/resources/versions-vcd15.xml       | 906 +++++++++++++++++++
 .../src/test/resources/versions.xml             |   7 +
 .../test/resources/virtualhardwaresection.xml   | 118 +++
 .../src/test/resources/vm-rhel-off-static.xml   | 197 ++++
 .../openstack-nova/1.7.1-stratos/README.txt     |   3 -
 .../openstack-nova/1.7.1-stratos/pom.xml        | 143 ---
 .../jclouds/openstack/nova/v2_0/NovaApi.java    | 208 -----
 .../openstack/nova/v2_0/NovaApiMetadata.java    | 125 ---
 .../openstack/nova/v2_0/NovaAsyncApi.java       | 214 -----
 .../v2_0/binders/BindKeyPairToJsonPayload.java  |  47 -
 .../v2_0/binders/BindMetadataToJsonPayload.java |  47 -
 .../BindSecurityGroupRuleToJsonPayload.java     |  71 --
 .../nova/v2_0/compute/NovaComputeService.java   | 183 ----
 .../v2_0/compute/NovaComputeServiceAdapter.java | 288 ------
 .../config/NovaComputeServiceContextModule.java | 286 ------
 .../compute/extensions/NovaImageExtension.java  | 140 ---
 .../extensions/NovaSecurityGroupExtension.java  | 373 --------
 .../AllocateAndAddFloatingIpToNode.java         | 112 ---
 .../functions/CreateSecurityGroupIfNeeded.java  |  93 --
 .../functions/FlavorInZoneToHardware.java       |  60 --
 .../compute/functions/ImageInZoneToImage.java   |  70 --
 .../functions/ImageToOperatingSystem.java       | 128 ---
 .../NovaSecurityGroupInZoneToSecurityGroup.java |  75 --
 .../NovaSecurityGroupToSecurityGroup.java       |  69 --
 .../functions/OrphanedGroupsByZoneId.java       |  77 --
 .../RemoveFloatingIpFromNodeAndDeallocate.java  |  74 --
 .../SecurityGroupRuleToIpPermission.java        |  99 --
 .../functions/ServerInZoneToNodeMetadata.java   | 199 ----
 .../compute/loaders/CreateUniqueKeyPair.java    |  79 --
 .../loaders/FindSecurityGroupOrCreate.java      |  86 --
 .../loaders/LoadFloatingIpsForInstance.java     |  63 --
 .../compute/options/NovaTemplateOptions.java    | 649 -------------
 .../predicates/AllNodesInGroupTerminated.java   |  56 --
 ...desWithGroupEncodedIntoNameThenAddToSet.java | 165 ----
 .../nova/v2_0/config/NovaParserModule.java      | 159 ----
 .../nova/v2_0/config/NovaProperties.java        |  43 -
 .../nova/v2_0/config/NovaRestClientModule.java  | 191 ----
 .../openstack/nova/v2_0/domain/Address.java     | 138 ---
 .../openstack/nova/v2_0/domain/BackupType.java  |  41 -
 .../openstack/nova/v2_0/domain/Flavor.java      | 211 -----
 .../openstack/nova/v2_0/domain/FloatingIP.java  | 173 ----
 .../openstack/nova/v2_0/domain/Host.java        | 127 ---
 .../nova/v2_0/domain/HostAggregate.java         | 250 -----
 .../nova/v2_0/domain/HostResourceUsage.java     | 180 ----
 .../openstack/nova/v2_0/domain/Image.java       | 303 -------
 .../openstack/nova/v2_0/domain/Ingress.java     | 160 ----
 .../openstack/nova/v2_0/domain/KeyPair.java     | 189 ----
 .../openstack/nova/v2_0/domain/Network.java     | 173 ----
 .../openstack/nova/v2_0/domain/Quota.java       | 356 --------
 .../openstack/nova/v2_0/domain/QuotaClass.java  |  62 --
 .../openstack/nova/v2_0/domain/RebootType.java  |  35 -
 .../nova/v2_0/domain/SecurityGroup.java         | 188 ----
 .../nova/v2_0/domain/SecurityGroupRule.java     | 174 ----
 .../openstack/nova/v2_0/domain/Server.java      | 476 ----------
 .../nova/v2_0/domain/ServerCreated.java         | 127 ---
 .../v2_0/domain/ServerExtendedAttributes.java   | 156 ----
 .../nova/v2_0/domain/ServerExtendedStatus.java  | 155 ----
 .../v2_0/domain/ServerWithSecurityGroups.java   | 128 ---
 .../nova/v2_0/domain/SimpleServerUsage.java     | 312 -------
 .../nova/v2_0/domain/SimpleTenantUsage.java     | 245 -----
 .../nova/v2_0/domain/TenantIdAndName.java       | 127 ---
 .../nova/v2_0/domain/VirtualInterface.java      | 128 ---
 .../openstack/nova/v2_0/domain/Volume.java      | 346 -------
 .../nova/v2_0/domain/VolumeAttachment.java      | 172 ----
 .../nova/v2_0/domain/VolumeSnapshot.java        | 239 -----
 .../openstack/nova/v2_0/domain/VolumeType.java  | 192 ----
 .../domain/zonescoped/AvailabilityZone.java     |  73 --
 .../v2_0/domain/zonescoped/FlavorInZone.java    |  46 -
 .../v2_0/domain/zonescoped/ImageInZone.java     |  46 -
 .../domain/zonescoped/SecurityGroupInZone.java  |  46 -
 .../v2_0/domain/zonescoped/ServerInZone.java    |  46 -
 .../nova/v2_0/domain/zonescoped/ZoneAndId.java  |  86 --
 .../v2_0/domain/zonescoped/ZoneAndName.java     | 111 ---
 .../ZoneSecurityGroupNameAndPorts.java          |  62 --
 .../nova/v2_0/domain/zonescoped/ZoneState.java  |  61 --
 .../v2_0/extensions/AvailabilityZoneAPI.java    |  40 -
 .../extensions/AvailabilityZoneAsyncApi.java    |  58 --
 .../v2_0/extensions/ExtensionNamespaces.java    | 110 ---
 .../v2_0/extensions/FlavorExtraSpecsApi.java    |  77 --
 .../extensions/FlavorExtraSpecsAsyncApi.java    | 118 ---
 .../nova/v2_0/extensions/FloatingIPApi.java     |  98 --
 .../v2_0/extensions/FloatingIPAsyncApi.java     | 145 ---
 .../v2_0/extensions/HostAdministrationApi.java  | 103 ---
 .../extensions/HostAdministrationAsyncApi.java  | 157 ----
 .../nova/v2_0/extensions/HostAggregateApi.java  |  87 --
 .../v2_0/extensions/HostAggregateAsyncApi.java  | 161 ----
 .../nova/v2_0/extensions/KeyPairApi.java        |  65 --
 .../nova/v2_0/extensions/KeyPairAsyncApi.java   | 101 ---
 .../nova/v2_0/extensions/QuotaApi.java          |  57 --
 .../nova/v2_0/extensions/QuotaAsyncApi.java     |  89 --
 .../nova/v2_0/extensions/QuotaClassApi.java     |  51 --
 .../v2_0/extensions/QuotaClassAsyncApi.java     |  78 --
 .../nova/v2_0/extensions/SecurityGroupApi.java  |  89 --
 .../v2_0/extensions/SecurityGroupAsyncApi.java  | 152 ----
 .../nova/v2_0/extensions/ServerAdminApi.java    | 120 ---
 .../v2_0/extensions/ServerAdminAsyncApi.java    | 175 ----
 .../extensions/ServerWithSecurityGroupsApi.java |  49 -
 .../ServerWithSecurityGroupsAsyncApi.java       |  62 --
 .../v2_0/extensions/SimpleTenantUsageApi.java   |  50 -
 .../extensions/SimpleTenantUsageAsyncApi.java   |  77 --
 .../v2_0/extensions/VirtualInterfaceApi.java    |  43 -
 .../extensions/VirtualInterfaceAsyncApi.java    |  59 --
 .../nova/v2_0/extensions/VolumeApi.java         | 147 ---
 .../nova/v2_0/extensions/VolumeAsyncApi.java    | 254 ------
 .../v2_0/extensions/VolumeAttachmentApi.java    |  87 --
 .../extensions/VolumeAttachmentAsyncApi.java    | 107 ---
 .../nova/v2_0/extensions/VolumeTypeApi.java     | 101 ---
 .../v2_0/extensions/VolumeTypeAsyncApi.java     | 161 ----
 .../openstack/nova/v2_0/features/FlavorApi.java |  78 --
 .../nova/v2_0/features/FlavorAsyncApi.java      | 144 ---
 .../openstack/nova/v2_0/features/ImageApi.java  | 142 ---
 .../nova/v2_0/features/ImageAsyncApi.java       | 206 -----
 .../openstack/nova/v2_0/features/ServerApi.java | 276 ------
 .../nova/v2_0/features/ServerAsyncApi.java      | 356 --------
 .../functions/FieldValueResponseParsers.java    | 105 ---
 .../nova/v2_0/functions/OverLimitParser.java    |  92 --
 .../ParseImageIdFromLocationHeader.java         |  39 -
 .../internal/OnlyMetadataValueOrNull.java       |  63 --
 .../functions/internal/ParseDiagnostics.java    |  47 -
 .../functions/internal/ParseFlavorDetails.java  |  94 --
 .../v2_0/functions/internal/ParseFlavors.java   |  96 --
 .../functions/internal/ParseImageDetails.java   |  95 --
 .../v2_0/functions/internal/ParseImages.java    |  96 --
 .../v2_0/functions/internal/ParseKeyPairs.java  |  64 --
 .../functions/internal/ParseServerDetails.java  |  94 --
 .../v2_0/functions/internal/ParseServers.java   |  96 --
 .../nova/v2_0/handlers/NovaErrorHandler.java    | 129 ---
 .../options/CreateBackupOfServerOptions.java    | 105 ---
 .../nova/v2_0/options/CreateServerOptions.java  | 557 ------------
 .../nova/v2_0/options/CreateVolumeOptions.java  | 220 -----
 .../options/CreateVolumeSnapshotOptions.java    | 138 ---
 .../v2_0/options/CreateVolumeTypeOptions.java   | 101 ---
 .../nova/v2_0/options/ListOptions.java          | 107 ---
 .../nova/v2_0/options/RebuildServerOptions.java | 142 ---
 .../FindSecurityGroupWithNameAndReturnTrue.java |  84 --
 .../nova/v2_0/predicates/ImagePredicates.java   |  55 --
 .../nova/v2_0/predicates/KeyPairPredicates.java |  77 --
 .../predicates/SecurityGroupPredicates.java     | 213 -----
 .../services/org.jclouds.apis.ApiMetadata       |   1 -
 ...tKeyAndTenantIdAuthenticationExpectTest.java |  75 --
 ...antNamePropertyAuthenticationExpectTest.java |  75 --
 ...KeyAndSecretKeyAuthenticationExpectTest.java |  69 --
 .../nova/v2_0/EndpointIdIsRandomExpectTest.java |  72 --
 .../nova/v2_0/NovaApiMetadataTest.java          |  32 -
 .../v2_0/PasswordAuthenticationExpectTest.java  |  60 --
 ...dAuthenticationWithTenantNameExpectTest.java |  69 --
 .../NovaComputeServiceAdapterExpectTest.java    | 321 -------
 .../compute/NovaComputeServiceExpectTest.java   | 382 --------
 .../compute/NovaComputeServiceLiveTest.java     |  96 --
 .../NovaImageExtensionExpectTest.java           |  92 --
 .../extensions/NovaImageExtensionLiveTest.java  |  43 -
 .../NovaSecurityGroupExtensionExpectTest.java   | 433 ---------
 .../NovaSecurityGroupExtensionLiveTest.java     |  35 -
 ...llocateAndAddFloatingIpToNodeExpectTest.java | 133 ---
 .../functions/FlavorInZoneToHardwareTest.java   |  90 --
 .../functions/ImageInZoneToImageTest.java       |  95 --
 .../functions/ImageToOperatingSystemTest.java   | 192 ----
 ...aSecurityGroupInZoneToSecurityGroupTest.java |  94 --
 .../NovaSecurityGroupToSecurityGroupTest.java   | 155 ----
 .../functions/OrphanedGroupsByZoneIdTest.java   |  96 --
 .../SecurityGroupRuleToIpPermissionTest.java    |  81 --
 .../ServerInZoneToNodeMetadataTest.java         | 311 -------
 .../loaders/CreateUniqueKeyPairTest.java        | 111 ---
 .../loaders/FindSecurityGroupOrCreateTest.java  | 144 ---
 .../loaders/LoadFloatingIpsForInstanceTest.java | 108 ---
 .../options/NovaTemplateOptionsTest.java        | 263 ------
 .../extensions/AdminActionsApiExpectTest.java   | 350 -------
 .../extensions/AdminActionsApiLiveTest.java     | 195 ----
 .../AvailabilityZoneApiExpectTest.java          |  64 --
 .../AvailabilityZonesApiLiveTest.java           |  45 -
 .../FlavorExtraSpecsApiExpectTest.java          | 142 ---
 .../extensions/FlavorExtraSpecsApiLiveTest.java | 123 ---
 .../extensions/FloatingIPApiExpectTest.java     | 191 ----
 .../v2_0/extensions/FloatingIPApiLiveTest.java  | 171 ----
 .../HostAdministrationApiExpectTest.java        | 241 -----
 .../HostAdministrationApiLiveTest.java          | 116 ---
 .../extensions/HostAggregateApiExpectTest.java  | 179 ----
 .../extensions/HostAggregateApiLiveTest.java    | 148 ---
 .../v2_0/extensions/KeyPairApiExpectTest.java   | 142 ---
 .../v2_0/extensions/KeyPairApiLiveTest.java     |  76 --
 .../v2_0/extensions/QuotaApiExpectTest.java     | 125 ---
 .../nova/v2_0/extensions/QuotaApiLiveTest.java  | 100 --
 .../extensions/QuotaClassApiExpectTest.java     | 105 ---
 .../v2_0/extensions/QuotaClassApiLiveTest.java  |  73 --
 .../extensions/SecurityGroupApiExpectTest.java  | 235 -----
 .../extensions/SecurityGroupApiLiveTest.java    | 100 --
 .../ServerWithSecurityGroupsApiExpectTest.java  |  63 --
 .../ServerWithSecurityGroupsApiLiveTest.java    |  80 --
 .../SimpleTenantUsageApiExpectTest.java         |  99 --
 .../SimpleTenantUsageApiLiveTest.java           |  51 --
 .../VirtualInterfaceApiExpectTest.java          |  64 --
 .../extensions/VirtualInterfaceApiLiveTest.java |  68 --
 .../v2_0/extensions/VolumeApiExpectTest.java    | 460 ----------
 .../nova/v2_0/extensions/VolumeApiLiveTest.java | 274 ------
 .../VolumeAttachmentApiExpectTest.java          | 168 ----
 .../extensions/VolumeAttachmentApiLiveTest.java | 156 ----
 .../extensions/VolumeTypeApiExpectTest.java     | 259 ------
 .../v2_0/extensions/VolumeTypeApiLiveTest.java  | 126 ---
 .../v2_0/features/ExtensionApiExpectTest.java   | 115 ---
 .../v2_0/features/ExtensionApiLiveTest.java     |  84 --
 .../nova/v2_0/features/FlavorApiExpectTest.java | 164 ----
 .../nova/v2_0/features/FlavorApiLiveTest.java   | 105 ---
 .../nova/v2_0/features/ImageApiExpectTest.java  | 377 --------
 .../nova/v2_0/features/ImageApiLiveTest.java    | 101 ---
 .../nova/v2_0/features/ServerApiExpectTest.java | 746 ---------------
 .../nova/v2_0/features/ServerApiLiveTest.java   | 206 -----
 .../CreateSecurityGroupIfNeededTest.java        | 168 ----
 ...ityGroupWithNameAndReturnTrueExpectTest.java | 102 ---
 .../v2_0/functions/InternalURLLiveTest.java     |  64 --
 .../v2_0/handlers/NovaErrorHandlerTest.java     | 225 -----
 .../v2_0/internal/BaseNovaApiExpectTest.java    |  28 -
 .../nova/v2_0/internal/BaseNovaApiLiveTest.java | 120 ---
 ...BaseNovaComputeServiceContextExpectTest.java |  87 --
 .../BaseNovaComputeServiceExpectTest.java       |  35 -
 .../nova/v2_0/internal/BaseNovaExpectTest.java  |  84 --
 ...eComputeServiceTypicalSecurityGroupTest.java |  76 --
 .../nova/v2_0/parse/ParseCreateFlavorTest.java  |  58 --
 .../nova/v2_0/parse/ParseCreatedServerTest.java |  80 --
 .../parse/ParseExtensionListNormalTest.java     |  76 --
 .../nova/v2_0/parse/ParseExtensionListTest.java |  88 --
 .../nova/v2_0/parse/ParseExtensionTest.java     |  71 --
 .../nova/v2_0/parse/ParseFlavorListTest.java    |  85 --
 .../nova/v2_0/parse/ParseFlavorTest.java        |  70 --
 .../v2_0/parse/ParseFloatingIPListTest.java     |  59 --
 .../nova/v2_0/parse/ParseFloatingIPTest.java    |  53 --
 .../nova/v2_0/parse/ParseImageListTest.java     |  85 --
 .../nova/v2_0/parse/ParseImageTest.java         |  98 --
 .../nova/v2_0/parse/ParseKeyPairListTest.java   |  68 --
 .../nova/v2_0/parse/ParseKeyPairTest.java       |  61 --
 .../nova/v2_0/parse/ParseMetadataItemTest.java  |  58 --
 .../nova/v2_0/parse/ParseMetadataListTest.java  |  63 --
 .../v2_0/parse/ParseMetadataUpdateTest.java     |  64 --
 .../v2_0/parse/ParseSecurityGroupListTest.java  |  72 --
 .../nova/v2_0/parse/ParseSecurityGroupTest.java |  69 --
 .../v2_0/parse/ParseServerDetailsEssexTest.java | 170 ----
 .../nova/v2_0/parse/ParseServerDiagnostics.java |  57 --
 .../nova/v2_0/parse/ParseServerListTest.java    |  85 --
 .../nova/v2_0/parse/ParseServerTest.java        | 117 ---
 .../parse/ParseServerWithAllExtensionsTest.java | 104 ---
 .../ParseServerWithInternetAddressesTest.java   |  99 --
 ...ublicIpsInPrivateAddressBlockExpectTest.java |  99 --
 .../v2_0/predicates/ImagePredicatesTest.java    |  44 -
 .../predicates/SecurityGroupPredicatesTest.java | 129 ---
 .../src/test/resources/attachment_details.json  |   1 -
 .../src/test/resources/attachment_list.json     |   1 -
 .../src/test/resources/extension_details.json   |  21 -
 .../src/test/resources/extension_list.json      |  42 -
 .../src/test/resources/extension_list_full.json | 281 ------
 .../test/resources/extension_list_normal.json   |  31 -
 .../resources/extension_list_openstack.json     | 115 ---
 .../src/test/resources/flavor_details.json      |  19 -
 .../src/test/resources/flavor_list.json         |  32 -
 .../src/test/resources/flavor_list_detail.json  |   1 -
 .../resources/flavor_list_detail_openstack.json |  83 --
 .../src/test/resources/flavor_new.json          |  10 -
 .../src/test/resources/floatingip_details.json  |   9 -
 .../src/test/resources/floatingip_list.json     |  16 -
 .../1.7.1-stratos/src/test/resources/host.json  |   1 -
 .../test/resources/host_aggregate_details.json  |   1 -
 .../src/test/resources/host_aggregate_list.json |   1 -
 .../host_aggregate_with_host_details.json       |   1 -
 .../src/test/resources/hosts_list.json          |   1 -
 .../src/test/resources/image_active.json        |  41 -
 .../src/test/resources/image_details.json       |  41 -
 .../src/test/resources/image_list.json          |  32 -
 .../src/test/resources/image_list_detail.json   |   1 -
 .../image_list_detail_imageextension.json       | 121 ---
 .../resources/image_list_detail_openstack.json  |  81 --
 .../src/test/resources/keypair_created.json     |   9 -
 .../keypair_created_computeservice.json         |   9 -
 .../src/test/resources/keypair_list.json        |  18 -
 .../test/resources/listAvailabilityZones.json   |  11 -
 .../src/test/resources/metadata_item.json       |   5 -
 .../src/test/resources/metadata_list.json       |   6 -
 .../src/test/resources/metadata_updated.json    |   7 -
 .../src/test/resources/new_server.json          |  41 -
 .../resources/new_server_disk_config_auto.json  |  42 -
 .../new_server_disk_config_manual.json          |  42 -
 .../src/test/resources/new_server_in_zone.json  |  41 -
 .../resources/new_server_networks_response.json |  42 -
 .../test/resources/new_server_no_adminpass.json |  40 -
 .../resources/new_server_nova_networks.json     |  41 -
 .../src/test/resources/quota_class.json         |  15 -
 .../src/test/resources/quotas.json              |  15 -
 .../test/resources/securitygroup_created.json   |   9 -
 .../test/resources/securitygroup_details.json   |  34 -
 ...itygroup_details_computeservice_typical.json |  51 --
 .../securitygroup_details_extension.json        |  34 -
 ...securitygroup_details_extension_norules.json |  10 -
 .../resources/securitygroup_details_port22.json |  19 -
 .../src/test/resources/securitygroup_list.json  |  51 --
 ...oup_list_details_computeservice_typical.json |  53 --
 .../resources/securitygroup_list_extension.json |  51 --
 .../resources/securitygrouprule_created.json    |  12 -
 .../securitygrouprule_created_cidr.json         |  13 -
 .../securitygrouprule_created_group.json        |  14 -
 .../src/test/resources/server_details.json      |  86 --
 .../test/resources/server_details_devstack.json |  44 -
 .../resources/server_details_openstack.json     |  46 -
 .../src/test/resources/server_diagnostics.json  |  17 -
 .../src/test/resources/server_list.json         |  32 -
 .../src/test/resources/server_list_details.json |  79 --
 .../resources/server_list_details_essex.json    | 152 ----
 .../resources/server_public_ip_in_private.json  |  51 --
 .../resources/server_with_security_groups.json  |   1 -
 .../server_with_security_groups_extension.json  |   1 -
 .../src/test/resources/simple_tenant_usage.json |   1 -
 .../test/resources/simple_tenant_usages.json    |   1 -
 .../src/test/resources/snapshot_details.json    |   1 -
 .../src/test/resources/snapshot_list.json       |   1 -
 .../test/resources/snapshot_list_detail.json    |   1 -
 .../test/resources/virtual_interfaces_list.json |   1 -
 .../src/test/resources/volume_details.json      |   1 -
 .../src/test/resources/volume_list.json         |   1 -
 .../src/test/resources/volume_list_detail.json  |   1 -
 .../src/test/resources/volume_type.json         |   9 -
 .../test/resources/volume_type_extra_specs.json |   1 -
 .../src/test/resources/volume_type_list.json    |   1 -
 .../provider/aws-ec2/1.7.1-stratos/pom.xml      |  29 +-
 .../org/jclouds/aws/ec2/AWSEC2ApiMetadata.java  |   2 +-
 .../BindLaunchSpecificationToFormParams.java    |  13 +-
 .../aws/ec2/compute/AWSEC2TemplateOptions.java  |  59 +-
 .../AWSEC2CreateNodesInGroupThenAddToSet.java   |  39 +-
 ...curityGroupsAsNeededAndReturnRunOptions.java |  16 +-
 .../aws/ec2/domain/AWSRunningInstance.java      |  29 +-
 .../aws/ec2/domain/LaunchSpecification.java     |  43 +-
 .../aws/ec2/options/AWSRunInstancesOptions.java |  27 +-
 .../aws/ec2/xml/LaunchSpecificationHandler.java |  20 +-
 .../features/PlacementGroupApiExpectTest.java   |   4 +-
 .../ec2/features/SpotInstanceApiExpectTest.java |   4 +-
 ...InstanceRequestToAWSRunningInstanceTest.java |   4 +-
 .../src/test/resources/describe_instances_1.xml |   2 +-
 .../src/test/resources/describe_instances_2.xml |   2 +-
 .../src/test/resources/describe_instances_3.xml |   2 +-
 .../resources/describe_instances_latest.xml     |   2 +-
 .../resources/describe_instances_pending.xml    |   2 +-
 .../resources/describe_security_groups_vpc.xml  |   2 +-
 .../test/resources/describe_spot_instance.xml   |   2 +-
 .../describe_spot_instance_requests.xml         |   2 +-
 .../resources/describe_spot_instance_tags.xml   |   2 +-
 .../resources/describe_spot_instances_1.xml     |   2 +-
 .../resources/describe_spot_price_history.xml   |   2 +-
 .../resources/request_spot_instances-ebs.xml    |   2 +-
 .../test/resources/request_spot_instances.xml   |   2 +-
 .../src/test/resources/run_instances_1.xml      |   2 +-
 .../jclouds/vcloud/1.7.1-stratos/README.txt     |   6 -
 .../jclouds/vcloud/1.7.1-stratos/pom.xml        | 129 ---
 .../vcloud/TaskInErrorStateException.java       |  39 -
 .../vcloud/TaskStillRunningException.java       |  39 -
 .../main/java/org/jclouds/vcloud/VCloudApi.java |  91 --
 .../org/jclouds/vcloud/VCloudApiMetadata.java   | 103 ---
 .../org/jclouds/vcloud/VCloudMediaType.java     | 221 -----
 .../jclouds/vcloud/VCloudResponseException.java |  69 --
 .../java/org/jclouds/vcloud/VCloudToken.java    |  37 -
 .../org/jclouds/vcloud/VCloudVersionsApi.java   |  38 -
 .../binders/BindCPUCountToXmlPayload.java       |  79 --
 .../BindCaptureVAppParamsToXmlPayload.java      | 124 ---
 .../binders/BindCatalogItemToXmlPayload.java    | 126 ---
 .../binders/BindCloneParamsToXmlPayload.java    | 133 ---
 .../BindCloneVAppParamsToXmlPayload.java        |  65 --
 ...BindCloneVAppTemplateParamsToXmlPayload.java |  60 --
 .../BindDeployVAppParamsToXmlPayload.java       |  42 -
 ...ndGuestCustomizationSectionToXmlPayload.java | 112 ---
 ...stantiateVAppTemplateParamsToXmlPayload.java | 221 -----
 .../vcloud/binders/BindMemoryToXmlPayload.java  |  80 --
 ...indNetworkConnectionSectionToXmlPayload.java | 106 ---
 .../vcloud/binders/BindParamsToXmlPayload.java  |  81 --
 .../BindUndeployVAppParamsToXmlPayload.java     |  42 -
 .../OrgNameAndCatalogNameToEndpoint.java        |  79 --
 .../binders/OrgNameAndVDCNameToEndpoint.java    |  78 --
 .../OrgNameCatalogNameItemNameToEndpoint.java   |  77 --
 ...meCatalogNameVAppTemplateNameToEndpoint.java |  90 --
 .../OrgNameVDCNameNetworkNameToEndpoint.java    |  54 --
 ...NameVDCNameResourceEntityNameToEndpoint.java |  54 --
 .../OrgNameVDCNameResourceNameToEndpoint.java   |  81 --
 .../VCloudComputeServiceContextModule.java      |  39 -
 .../VCloudComputeServiceDependenciesModule.java | 154 ----
 .../functions/FindLocationForResource.java      |  69 --
 .../compute/functions/HardwareForVApp.java      |  71 --
 .../functions/HardwareForVAppTemplate.java      |  84 --
 .../compute/functions/ImageForVAppTemplate.java |  82 --
 .../compute/functions/VAppToNodeMetadata.java   | 112 ---
 ...dHardwareBuilderFromResourceAllocations.java |  43 -
 ...EnvelopeOrThrowIllegalArgumentException.java |  77 --
 .../internal/VCloudTemplateBuilderImpl.java     |  48 -
 .../compute/options/VCloudTemplateOptions.java  | 350 -------
 ...edIntoNameThenCustomizeDeployAndPowerOn.java | 302 -------
 ...etworkConfigurationForNetworkAndOptions.java |  80 --
 .../strategy/VCloudComputeServiceAdapter.java   | 263 ------
 .../vcloud/compute/util/VCloudComputeUtils.java | 116 ---
 .../vcloud/config/DefaultCatalogForOrg.java     |  63 --
 .../vcloud/config/DefaultNetworkForVDC.java     |  65 --
 .../vcloud/config/DefaultOrgForUser.java        |  58 --
 .../vcloud/config/DefaultTasksListForOrg.java   |  53 --
 .../config/DefaultVCloudReferencesModule.java   | 165 ----
 .../jclouds/vcloud/config/DefaultVDCForOrg.java |  63 --
 .../vcloud/config/VCloudHttpApiModule.java      | 538 -----------
 .../jclouds/vcloud/domain/AllocationModel.java  |  70 --
 .../org/jclouds/vcloud/domain/Capacity.java     | 108 ---
 .../java/org/jclouds/vcloud/domain/Catalog.java |  69 --
 .../org/jclouds/vcloud/domain/CatalogItem.java  |  37 -
 .../domain/GuestCustomizationSection.java       | 440 ---------
 .../domain/InstantiateVAppTemplateParams.java   |  96 --
 .../vcloud/domain/NetworkConnection.java        | 233 -----
 .../vcloud/domain/NetworkConnectionSection.java | 218 -----
 .../java/org/jclouds/vcloud/domain/Org.java     |  86 --
 .../jclouds/vcloud/domain/ReferenceType.java    |  55 --
 .../java/org/jclouds/vcloud/domain/Status.java  | 246 -----
 .../java/org/jclouds/vcloud/domain/Task.java    |  72 --
 .../org/jclouds/vcloud/domain/TaskStatus.java   |  71 --
 .../org/jclouds/vcloud/domain/TasksList.java    |  37 -
 .../java/org/jclouds/vcloud/domain/VApp.java    |  87 --
 .../org/jclouds/vcloud/domain/VAppTemplate.java |  97 --
 .../org/jclouds/vcloud/domain/VCloudError.java  | 123 ---
 .../jclouds/vcloud/domain/VCloudSession.java    |  29 -
 .../java/org/jclouds/vcloud/domain/VDC.java     | 146 ---
 .../org/jclouds/vcloud/domain/VDCStatus.java    |  57 --
 .../main/java/org/jclouds/vcloud/domain/Vm.java | 108 ---
 .../vcloud/domain/internal/CatalogImpl.java     | 193 ----
 .../vcloud/domain/internal/CatalogItemImpl.java | 111 ---
 .../vcloud/domain/internal/ErrorImpl.java       | 119 ---
 .../jclouds/vcloud/domain/internal/OrgImpl.java | 171 ----
 .../domain/internal/ReferenceTypeImpl.java      | 103 ---
 .../vcloud/domain/internal/TaskImpl.java        | 165 ----
 .../vcloud/domain/internal/TasksListImpl.java   |  81 --
 .../vcloud/domain/internal/VAppImpl.java        | 166 ----
 .../domain/internal/VAppTemplateImpl.java       | 205 -----
 .../jclouds/vcloud/domain/internal/VDCImpl.java | 292 ------
 .../jclouds/vcloud/domain/internal/VmImpl.java  | 217 -----
 .../vcloud/domain/network/DhcpService.java      | 106 ---
 .../jclouds/vcloud/domain/network/Features.java |  95 --
 .../vcloud/domain/network/FenceMode.java        |  70 --
 .../vcloud/domain/network/FirewallService.java  |  86 --
 .../domain/network/IpAddressAllocationMode.java |  52 --
 .../jclouds/vcloud/domain/network/IpRange.java  |  76 --
 .../jclouds/vcloud/domain/network/IpScope.java  | 170 ----
 .../vcloud/domain/network/NatService.java       | 115 ---
 .../vcloud/domain/network/NetworkConfig.java    | 167 ----
 .../vcloud/domain/network/OrgNetwork.java       | 121 ---
 .../domain/network/firewall/FirewallPolicy.java |  54 --
 .../network/firewall/FirewallProtocols.java     |  73 --
 .../domain/network/firewall/FirewallRule.java   | 125 ---
 .../domain/network/internal/OrgNetworkImpl.java | 202 -----
 .../vcloud/domain/network/nat/NatPolicy.java    |  54 --
 .../vcloud/domain/network/nat/NatProtocol.java  |  48 -
 .../vcloud/domain/network/nat/NatRule.java      |  35 -
 .../vcloud/domain/network/nat/NatType.java      |  61 --
 .../domain/network/nat/rules/MappingMode.java   |  54 --
 .../network/nat/rules/OneToOneVmRule.java       | 110 ---
 .../network/nat/rules/PortForwardingRule.java   | 111 ---
 .../vcloud/domain/network/nat/rules/VmRule.java | 128 ---
 .../EditableResourceAllocationSettingData.java  | 302 -------
 .../vcloud/domain/ovf/VCloudHardDisk.java       | 330 -------
 .../vcloud/domain/ovf/VCloudNetworkAdapter.java | 332 -------
 .../vcloud/domain/ovf/VCloudNetworkSection.java |  80 --
 .../ovf/VCloudOperatingSystemSection.java       | 118 ---
 .../ovf/VCloudVirtualHardwareSection.java       | 179 ----
 .../org/jclouds/vcloud/endpoints/Catalog.java   |  37 -
 .../org/jclouds/vcloud/endpoints/Network.java   |  37 -
 .../java/org/jclouds/vcloud/endpoints/Org.java  |  37 -
 .../org/jclouds/vcloud/endpoints/OrgList.java   |  37 -
 .../org/jclouds/vcloud/endpoints/TasksList.java |  37 -
 .../jclouds/vcloud/endpoints/VCloudLogin.java   |  38 -
 .../java/org/jclouds/vcloud/endpoints/VDC.java  |  37 -
 .../org/jclouds/vcloud/features/CatalogApi.java | 144 ---
 .../org/jclouds/vcloud/features/NetworkApi.java |  61 --
 .../org/jclouds/vcloud/features/OrgApi.java     |  86 --
 .../org/jclouds/vcloud/features/TaskApi.java    |  82 --
 .../org/jclouds/vcloud/features/VAppApi.java    | 261 ------
 .../vcloud/features/VAppTemplateApi.java        | 180 ----
 .../org/jclouds/vcloud/features/VDCApi.java     |  73 --
 .../java/org/jclouds/vcloud/features/VmApi.java | 295 ------
 ...ddVCloudAuthorizationAndCookieToRequest.java |  63 --
 .../vcloud/functions/CatalogItemsInCatalog.java |  64 --
 .../vcloud/functions/CatalogItemsInOrg.java     |  57 --
 .../jclouds/vcloud/functions/CatalogsInOrg.java |  73 --
 .../functions/DefaultNetworkNameInTemplate.java |  47 -
 .../jclouds/vcloud/functions/NetworksInOrg.java |  57 --
 .../vcloud/functions/OrgNameToEndpoint.java     |  57 --
 .../functions/OrgNameToTasksListEndpoint.java   |  62 --
 .../vcloud/functions/OrgsForLocations.java      |  73 --
 .../jclouds/vcloud/functions/OrgsForNames.java  |  56 --
 .../ParseLoginResponseFromHeaders.java          | 105 ---
 .../functions/VAppTemplatesForCatalogItems.java |  66 --
 .../vcloud/functions/VAppTemplatesInOrg.java    |  65 --
 .../org/jclouds/vcloud/functions/VDCsInOrg.java |  57 --
 .../ParseVCloudErrorFromHttpResponse.java       | 121 ---
 .../http/filters/VCloudBasicAuthentication.java |  58 --
 .../http/filters/VCloudSupportedVersions.java   |  35 -
 .../jclouds/vcloud/internal/VCloudLoginApi.java |  44 -
 .../org/jclouds/vcloud/loaders/OVFLoader.java   |  47 -
 .../vcloud/loaders/VAppTemplateLoader.java      |  47 -
 .../org/jclouds/vcloud/location/DefaultVDC.java |  74 --
 .../location/OrgAndVDCToLocationSupplier.java   |  93 --
 .../vcloud/options/CaptureVAppOptions.java      |  51 --
 .../vcloud/options/CatalogItemOptions.java      |  77 --
 .../jclouds/vcloud/options/CloneOptions.java    |  53 --
 .../vcloud/options/CloneVAppOptions.java        |  88 --
 .../options/CloneVAppTemplateOptions.java       |  42 -
 .../options/InstantiateVAppTemplateOptions.java | 178 ----
 .../jclouds/vcloud/predicates/TaskSuccess.java  |  65 --
 .../vcloud/reference/VCloudConstants.java       |  51 --
 .../jclouds/vcloud/reference/package-info.java  |  21 -
 ...thNameMatchingConfigurationKeyOrDefault.java |  99 --
 .../vcloud/suppliers/VAppTemplatesSupplier.java |  86 --
 .../java/org/jclouds/vcloud/util/Utils.java     |  71 --
 .../org/jclouds/vcloud/util/VCloudUtils.java    |  67 --
 .../org/jclouds/vcloud/xml/CatalogHandler.java  | 104 ---
 .../jclouds/vcloud/xml/CatalogItemHandler.java  |  81 --
 .../org/jclouds/vcloud/xml/ErrorHandler.java    |  45 -
 .../xml/GuestCustomizationSectionHandler.java   | 137 ---
 .../vcloud/xml/NetworkConnectionHandler.java    |  87 --
 .../xml/NetworkConnectionSectionHandler.java    | 103 ---
 .../java/org/jclouds/vcloud/xml/OrgHandler.java | 112 ---
 .../org/jclouds/vcloud/xml/OrgListHandler.java  |  54 --
 .../jclouds/vcloud/xml/OrgNetworkHandler.java   | 325 -------
 .../vcloud/xml/SupportedVersionsHandler.java    |  60 --
 .../org/jclouds/vcloud/xml/TaskHandler.java     | 128 ---
 .../jclouds/vcloud/xml/TasksListHandler.java    |  74 --
 .../org/jclouds/vcloud/xml/VAppHandler.java     | 151 ----
 .../jclouds/vcloud/xml/VAppTemplateHandler.java | 152 ----
 .../xml/VCloudVirtualHardwareHandler.java       |  72 --
 .../java/org/jclouds/vcloud/xml/VDCHandler.java | 167 ----
 .../java/org/jclouds/vcloud/xml/VmHandler.java  | 178 ----
 .../xml/ovf/VCloudNetworkSectionHandler.java    |  69 --
 .../xml/ovf/VCloudOperatingSystemHandler.java   |  81 --
 ...oudResourceAllocationSettingDataHandler.java |  89 --
 .../services/org.jclouds.apis.ApiMetadata       |   1 -
 .../jclouds/vcloud/VCloudApiMetadataTest.java   |  32 -
 .../java/org/jclouds/vcloud/VCloudApiTest.java  |  64 --
 .../vcloud/VCloudSessionRefreshLiveTest.java    |  41 -
 .../jclouds/vcloud/VCloudVersionsApiTest.java   |  69 --
 .../BindCatalogItemToXmlPayloadTest.java        |  53 --
 .../BindCloneVAppParamsToXmlPayloadTest.java    |  81 --
 ...CloneVAppTemplateParamsToXmlPayloadTest.java |  89 --
 .../BindDeployVAppParamsToXmlPayloadTest.java   |  61 --
 ...tiateVAppTemplateParamsToXmlPayloadTest.java | 179 ----
 ...etworkConnectionSectionToXmlPayloadTest.java |  68 --
 .../BindUndeployVAppParamsToXmlPayloadTest.java |  61 --
 .../BaseVCloudComputeServiceExpectTest.java     | 160 ----
 .../compute/VCloudComputeServiceLiveTest.java   |  54 --
 .../functions/FindLocationForResourceTest.java  |  64 --
 .../functions/ListImagesInVCloudExpectTest.java |  89 --
 .../functions/VAppToNodeMetadataTest.java       | 228 -----
 .../options/VCloudTemplateOptionsTest.java      | 197 ----
 ...ThenCustomizeDeployAndPowerOnExpectTest.java | 171 ----
 .../VCloudComputeServiceAdapterTest.java        |  89 --
 .../vcloud/features/CatalogApiLiveTest.java     |  53 --
 .../jclouds/vcloud/features/CatalogApiTest.java | 131 ---
 .../vcloud/features/NetworkApiLiveTest.java     |  29 -
 .../jclouds/vcloud/features/NetworkApiTest.java |  75 --
 .../jclouds/vcloud/features/OrgApiLiveTest.java |  42 -
 .../org/jclouds/vcloud/features/OrgApiTest.java |  91 --
 .../vcloud/features/TaskApiLiveTest.java        |  29 -
 .../jclouds/vcloud/features/TaskApiTest.java    | 108 ---
 .../vcloud/features/VAppApiLiveTest.java        |  53 --
 .../jclouds/vcloud/features/VAppApiTest.java    | 315 -------
 .../features/VAppTemplateApiLiveTest.java       | 168 ----
 .../vcloud/features/VAppTemplateApiTest.java    | 238 -----
 .../jclouds/vcloud/features/VDCApiLiveTest.java |  29 -
 .../org/jclouds/vcloud/features/VDCApiTest.java | 102 ---
 .../jclouds/vcloud/features/VmApiLiveTest.java  | 163 ----
 .../org/jclouds/vcloud/features/VmApiTest.java  | 320 -------
 ...loudAuthorizationAndCookieToRequestTest.java |  55 --
 .../ParseLoginResponseFromHeadersTest.java      | 147 ---
 .../ParseVCloudErrorFromHttpResponseTest.java   |  96 --
 .../vcloud/internal/BasePayloadTest.java        |  51 --
 .../vcloud/internal/BaseVCloudApiLiveTest.java  |  59 --
 .../vcloud/internal/BaseVCloudApiTest.java      | 272 ------
 .../vcloud/internal/VCloudLoginApiTest.java     |  97 --
 .../InstantiateVAppTemplateOptionsTest.java     |  74 --
 ...meMatchingConfigurationKeyOrDefaultTest.java | 115 ---
 .../org/jclouds/vcloud/utils/TestUtils.java     |  32 -
 .../jclouds/vcloud/xml/CatalogHandlerTest.java  | 135 ---
 .../vcloud/xml/CatalogItemHandlerTest.java      |  86 --
 .../GuestCustomizationSectionHandlerTest.java   |  75 --
 .../xml/NetworkConnectionHandlerTest.java       |  57 --
 .../NetworkConnectionSectionHandlerTest.java    |  63 --
 .../org/jclouds/vcloud/xml/OrgHandlerTest.java  | 124 ---
 .../jclouds/vcloud/xml/OrgListHandlerTest.java  |  57 --
 .../vcloud/xml/OrgNetworkHandlerTest.java       | 104 ---
 .../xml/SupportedVersionsHandlerTest.java       |  53 --
 .../org/jclouds/vcloud/xml/TaskHandlerTest.java | 135 ---
 .../vcloud/xml/TasksListHandlerTest.java        |  82 --
 .../org/jclouds/vcloud/xml/VAppHandlerTest.java |  77 --
 .../vcloud/xml/VAppTemplateHandlerTest.java     | 164 ----
 .../org/jclouds/vcloud/xml/VDCHandlerTest.java  | 136 ---
 .../org/jclouds/vcloud/xml/VmHandlerTest.java   |  79 --
 ...VCloudOperatingSystemSectionHandlerTest.java |  61 --
 ...VCloudVirtualHardwareSectionHandlerTest.java | 153 ----
 .../src/test/resources/captureVApp-default.xml  |   1 -
 .../src/test/resources/captureVApp.xml          |   1 -
 .../src/test/resources/catalog-blank.xml        |   7 -
 .../src/test/resources/catalog-hosting.xml      |  25 -
 .../src/test/resources/catalog.xml              |  27 -
 .../src/test/resources/catalog1.0-vcd15.xml     |   9 -
 ...alogItem-carrenza-with-default-namespace.xml |   8 -
 ...talogItem-carrenza-with-vcloud-namespace.xml |   8 -
 .../src/test/resources/catalogItem-hosting.xml  |  14 -
 .../test/resources/catalogItem-terremark.xml    |  16 -
 .../src/test/resources/catalogItem1.0-vcd15.xml |   8 -
 .../src/test/resources/copyVApp-default.xml     |   1 -
 .../src/test/resources/copyVApp.xml             |   1 -
 .../test/resources/copyVAppTemplate-default.xml |   1 -
 .../src/test/resources/copyVAppTemplate.xml     |   1 -
 .../src/test/resources/cpuItem.xml              |   1 -
 .../src/test/resources/guestCustomization.xml   |  23 -
 .../resources/guestCustomizationSection.xml     |   3 -
 .../src/test/resources/instantiatedvapp.xml     |  13 -
 .../instantiationparams-description.xml         |   1 -
 .../resources/instantiationparams-network.xml   |   1 -
 .../src/test/resources/instantiationparams.xml  |   1 -
 .../1.7.1-stratos/src/test/resources/log4j.xml  | 151 ----
 .../src/test/resources/memoryItem.xml           |   1 -
 .../src/test/resources/moveVApp.xml             |   1 -
 .../src/test/resources/moveVAppTemplate.xml     |   1 -
 .../src/test/resources/networkconnection.xml    |   7 -
 .../test/resources/networkconnectionsection.xml |  18 -
 .../src/test/resources/org-1.0.xml              |  24 -
 .../src/test/resources/org-hosting.xml          |  12 -
 .../src/test/resources/org-savvis.xml           |  13 -
 .../1.7.1-stratos/src/test/resources/org.xml    |   5 -
 .../src/test/resources/org1.0-vcd15.xml         |  11 -
 .../src/test/resources/orgList1.0-vcd15.xml     |   4 -
 .../src/test/resources/orglist-savvis.xml       |   3 -
 .../src/test/resources/orglist.xml              |   3 -
 .../src/test/resources/orgnetwork-bridged.xml   |  20 -
 .../src/test/resources/orgnetwork-isolated.xml  |  31 -
 .../1.7.1-stratos/src/test/resources/os.xml     |  11 -
 .../src/test/resources/ovf-multi-vm.xml         | 285 ------
 .../src/test/resources/ovf-ubuntu64.xml         | 148 ---
 .../src/test/resources/task-1.0.xml             |   9 -
 .../src/test/resources/task-error.xml           |   9 -
 .../src/test/resources/task-hosting.xml         |  12 -
 .../src/test/resources/task-self.xml            |  11 -
 .../src/test/resources/task-vcd15.xml           |   5 -
 .../1.7.1-stratos/src/test/resources/task.xml   |   8 -
 .../src/test/resources/taskslist-hosting.xml    |  14 -
 .../src/test/resources/taskslist.xml            |  27 -
 .../resources/template1.0-vcd15-multi-vm.xml    |  68 --
 .../src/test/resources/template1.0-vcd15.xml    |  72 --
 .../src/test/resources/vAppTemplate-copying.xml |  41 -
 .../src/test/resources/vAppTemplate.xml         | 143 ---
 .../vAppTemplate1.0-vcd15_withNewlines.xml      | 109 ---
 .../src/test/resources/vapp-hosting.xml         | 235 -----
 .../src/test/resources/vapp-none.xml            | 237 -----
 .../src/test/resources/vapp-pool.xml            | 227 -----
 .../src/test/resources/vapp-rhel-off-static.xml | 325 -------
 .../src/test/resources/vapp-ubuntu-off-dhcp.xml | 213 -----
 .../src/test/resources/vapp-unresolved.xml      |  21 -
 .../src/test/resources/vapp-win-off-static.xml  | 219 -----
 .../src/test/resources/vdc-1.0.xml              |  49 -
 .../src/test/resources/vdc-hosting.xml          |  60 --
 .../src/test/resources/vdc-nonet.xml            |  22 -
 .../1.7.1-stratos/src/test/resources/vdc.xml    |  36 -
 .../src/test/resources/vdc1.0-vcd15.xml         |  47 -
 .../src/test/resources/versions-vcd15.xml       | 906 -------------------
 .../src/test/resources/versions.xml             |   7 -
 .../test/resources/virtualhardwaresection.xml   | 118 ---
 .../src/test/resources/vm-rhel-off-static.xml   | 197 ----
 dependencies/pom.xml                            |   4 +-
 .../HealthStatisticsEventBuilder.xml            |  21 +
 .../InstanceStatusStatisticsBuilder.xml         |  21 +
 .../LoadBalancerStatisticsEventBuilder.xml      |  21 +
 .../AverageInFlightRequestsEventFormatter.xml   |  21 +
 .../AverageLoadAverageEventFormatter.xml        |  21 +
 .../AverageMemoryConsumptionEventFormatter.xml  |  21 +
 .../FaultMessageEventFormatter.xml              |  21 +
 .../GradientInFlightRequestsEventFormatter.xml  |  21 +
 .../GradientLoadAverageEventFormatter.xml       |  21 +
 .../GradientMemoryConsumptionEventFormatter.xml |  21 +
 .../MemberAverageLoadAverageEventFormatter.xml  |  21 +
 ...erAverageMemoryConsumptionEventFormatter.xml |  21 +
 .../MemberGradientLoadAverageEventFormatter.xml |  21 +
 ...rGradientMemoryConsumptionEventFormatter.xml |  21 +
 ...econdDerivativeLoadAverageEventFormatter.xml |  21 +
 ...erivativeMemoryConsumptionEventFormatter.xml |  21 +
 ...DerivativeInFlightRequestsEventFormatter.xml |  21 +
 ...econdDerivativeLoadAverageEventFormatter.xml |  21 +
 ...erivativeMemoryConsumptionEventFormatter.xml |  21 +
 .../executionplans/AverageHeathRequest.xml      |  21 +
 .../AverageInFlightRequestsFinder.xml           |  21 +
 .../executionplans/GradientOfHealthRequest.xml  |  21 +
 .../GradientOfRequestsInFlightFinder.xml        |  21 +
 .../SecondDerivativeOfHealthRequest.xml         |  21 +
 ...SecondDerivativeOfRequestsInFlightFinder.xml |  21 +
 .../DefaultWSO2EventInputAdaptor.xml            |  21 +
 .../DefaultWSO2EventOutputAdaptor.xml           |  21 +
 .../outputeventadaptors/JMSOutputAdaptor.xml    |  25 +-
 .../streamdefinitions/stream-manager-config.xml |  22 +
 .../main/resources/conf/cloud-controller.xml    |   1 -
 .../distribution/src/main/conf/log4j.properties |  22 +
 products/stratos/modules/integration/pom.xml    |   4 +-
 products/stratos/modules/p2-profile-gen/pom.xml |  36 +-
 products/stratos/pom.xml                        |   2 +-
 tools/puppet/agent/etc/rc.local                 |  26 -
 tools/puppet/agent/root/bin/ec2_init.sh         | 149 ---
 tools/puppet/agent/ruby/stratos_sendinfo.rb     |  30 -
 .../puppet/etc/puppet/files/cartridge-agent.sh  | 117 ---
 tools/puppet/etc/puppet/files/environment       |  22 -
 .../etc/puppet/files/get-launch-params.rb       |  54 --
 tools/puppet/etc/puppet/fileserver.conf         |  35 -
 tools/puppet/manifests/classes/apt.pp           |  43 -
 tools/puppet/manifests/classes/hosts.pp         |  29 -
 tools/puppet/manifests/classes/java.pp          |  65 --
 tools/puppet/manifests/classes/lb_cartridge.pp  | 139 ---
 tools/puppet/manifests/classes/mcollective.pp   |  84 --
 tools/puppet/manifests/classes/mysql.pp         | 122 ---
 tools/puppet/manifests/classes/php_cartridge.pp | 148 ---
 tools/puppet/manifests/classes/ssh.pp           |  61 --
 tools/puppet/manifests/classes/stratos.pp       |  93 --
 tools/puppet/manifests/classes/system_config.pp |  77 --
 tools/puppet/manifests/nodes.pp                 | 135 ---
 .../puppet/manifests/nodes.pp.sample.multinode  | 107 ---
 .../puppet/manifests/nodes.pp.sample.singlenode | 112 ---
 tools/puppet/manifests/site.pp                  |  23 -
 tools/puppet/modules/agent/LICENSE              |  16 -
 tools/puppet/modules/agent/manifests/init.pp    |  76 --
 .../modules/agent/manifests/initialize.pp       |  63 --
 .../modules/agent/manifests/push_templates.pp   |  31 -
 tools/puppet/modules/agent/manifests/start.pp   |  31 -
 .../modules/agent/templates/bin/stratos.sh.erb  |  44 -
 .../conf/templates/jndi.properties.template.erb |  26 -
 .../templates/extensions/addons/_mysql.erb      |  21 -
 .../templates/extensions/addons/_nodejs.erb     |   4 -
 .../agent/templates/extensions/addons/_php.erb  |   1 -
 .../extensions/artifacts-updated.sh.erb         |  33 -
 .../agent/templates/extensions/clean.sh.erb     |  28 -
 .../extensions/instance-activated.sh.erb        |  28 -
 .../extensions/instance-started.sh.erb          |  33 -
 .../templates/extensions/start-servers.sh.erb   |  31 -
 tools/puppet/modules/apt/files/90forceyes       |  23 -
 tools/puppet/modules/autoscaler/LICENSE         |  16 -
 .../autoscaler/files/configs/bin/stratos.sh     | 298 ------
 .../modules/autoscaler/manifests/clean.pp       |  50 -
 .../modules/autoscaler/manifests/deploy.pp      |  47 -
 .../puppet/modules/autoscaler/manifests/init.pp | 102 ---
 .../modules/autoscaler/manifests/initialize.pp  |  64 --
 .../modules/autoscaler/manifests/params.pp      |  43 -
 .../autoscaler/manifests/push_templates.pp      |  31 -
 .../modules/autoscaler/manifests/start.pp       |  33 -
 .../templates/conf/autoscaler.xml.erb           |  42 -
 .../templates/conf/axis2/axis2.xml.erb          | 701 --------------
 .../autoscaler/templates/conf/carbon.xml.erb    | 625 -------------
 .../templates/conf/jndi.properties.erb          |   4 -
 tools/puppet/modules/cc/LICENSE                 |  16 -
 tools/puppet/modules/cc/manifests/clean.pp      |  49 -
 tools/puppet/modules/cc/manifests/deploy.pp     |  47 -
 tools/puppet/modules/cc/manifests/init.pp       | 102 ---
 tools/puppet/modules/cc/manifests/initialize.pp |  63 --
 tools/puppet/modules/cc/manifests/params.pp     |  71 --
 .../modules/cc/manifests/push_templates.pp      |  31 -
 tools/puppet/modules/cc/manifests/start.pp      |  32 -
 .../cc/templates/conf/axis2/axis2.xml.erb       | 703 --------------
 .../modules/cc/templates/conf/carbon.xml.erb    | 625 -------------
 .../cc/templates/conf/cloud-controller.xml.erb  |  61 --
 .../cc/templates/conf/cloud-controller/_ec2.erb |  13 -
 .../conf/cloud-controller/_openstack.erb        |  14 -
 .../cc/templates/conf/jndi.properties.erb       |   4 -
 tools/puppet/modules/cep/LICENSE                |  13 -
 .../modules/cep/files/configs/bin/wso2server.sh | 304 -------
 .../dropins/activemq_client_5.8.0_1.0.0.jar     | Bin 1032400 -> 0 bytes
 .../dropins/andes_client_0.13.wso2v8_1.0.0.jar  | Bin 1854829 -> 0 bytes
 ...che.stratos.cep.extension-1.0.0-SNAPSHOT.jar | Bin 16495 -> 0 bytes
 .../repository/conf/siddhi/siddhi.extension     |   3 -
 .../repository/conf/stream-manager-config.xml   | 269 ------
 .../HealthStatisticsEventBuilder.xml            |  10 -
 .../InstanceStatusStatisticsBuilder.xml         |  10 -
 .../LoadBalancerStatisticsEventBuilder.xml      |  10 -
 .../AverageInFlightRequestsEventFormatter.xml   |  11 -
 .../AverageLoadAverageEventFormatter.xml        |  11 -
 .../AverageMemoryConsumptionEventFormatter.xml  |  11 -
 .../FaultMessageEventFormatter.xml              |  11 -
 .../GradientInFlightRequestsEventFormatter.xml  |  11 -
 .../GradientLoadAverageEventFormatter.xml       |  11 -
 .../GradientMemoryConsumptionEventFormatter.xml |  11 -
 .../MemberAverageLoadAverageEventFormatter.xml  |  11 -
 ...erAverageMemoryConsumptionEventFormatter.xml |  11 -
 .../MemberGradientLoadAverageEventFormatter.xml |  11 -
 ...rGradientMemoryConsumptionEventFormatter.xml |  11 -
 ...econdDerivativeLoadAverageEventFormatter.xml |  11 -
 ...erivativeMemoryConsumptionEventFormatter.xml |  11 -
 ...DerivativeInFlightRequestsEventFormatter.xml |  11 -
 ...econdDerivativeLoadAverageEventFormatter.xml |  11 -
 ...erivativeMemoryConsumptionEventFormatter.xml |  11 -
 .../executionplans/AverageHeathRequest.xml      |  29 -
 .../AverageInFlightRequestsFinder.xml           |  19 -
 .../executionplans/GradientOfHealthRequest.xml  |  30 -
 .../GradientOfRequestsInFlightFinder.xml        |  18 -
 .../SecondDerivativeOfHealthRequest.xml         |  27 -
 ...SecondDerivativeOfRequestsInFlightFinder.xml |  19 -
 .../DefaultWSO2EventInputAdaptor.xml            |   3 -
 .../DefaultWSO2EventOutputAdaptor.xml           |   8 -
 .../outputeventadaptors/JMSOutputAdaptor.xml    |   8 -
 tools/puppet/modules/cep/manifests/clean.pp     |  45 -
 tools/puppet/modules/cep/manifests/deploy.pp    |  43 -
 tools/puppet/modules/cep/manifests/init.pp      | 101 ---
 .../puppet/modules/cep/manifests/initialize.pp  |  59 --
 tools/puppet/modules/cep/manifests/params.pp    |  69 --
 .../modules/cep/manifests/push_templates.pp     |  26 -
 tools/puppet/modules/cep/manifests/start.pp     |  27 -
 .../cep/templates/conf/axis2/axis2.xml.erb      | 698 --------------
 .../modules/cep/templates/conf/carbon.xml.erb   | 609 -------------
 .../cep/templates/conf/jndi.properties.erb      |  32 -
 .../JMSOutputAdaptor.xml.erb                    |   8 -
 .../modules/commons/files/bin/puppet_init.sh    |  53 --
 .../modules/commons/files/bin/sign_jars.sh      |  39 -
 .../configs/bin/native/wrapper-linux-x86-32     | Bin 111027 -> 0 bytes
 .../commons/files/configs/lib/home/favicon.ico  | Bin 1150 -> 0 bytes
 tools/puppet/modules/commons/files/environment  |  23 -
 tools/puppet/modules/haproxy/LICENSE            |  16 -
 tools/puppet/modules/haproxy/manifests/init.pp  |  71 --
 .../modules/haproxy/manifests/initialize.pp     |  64 --
 .../modules/haproxy/manifests/push_templates.pp |  31 -
 tools/puppet/modules/haproxy/manifests/start.pp |  31 -
 .../templates/bin/haproxy-extension.sh.erb      |  48 -
 .../haproxy/templates/conf/jndi.properties.erb  |  23 -
 .../java/files/jars/copy_java_patches_here      |  22 -
 .../java/files/jdk-7u7-linux-x64.tar.gz.file    |  22 -
 tools/puppet/modules/lb/LICENSE                 |  16 -
 tools/puppet/modules/lb/manifests/clean.pp      |  50 -
 tools/puppet/modules/lb/manifests/deploy.pp     |  48 -
 tools/puppet/modules/lb/manifests/init.pp       |  95 --
 tools/puppet/modules/lb/manifests/initialize.pp |  64 --
 tools/puppet/modules/lb/manifests/params.pp     |  43 -
 .../modules/lb/manifests/push_templates.pp      |  31 -
 tools/puppet/modules/lb/manifests/start.pp      |  32 -
 .../lb/templates/conf/axis2/axis2.xml.erb       | 527 -----------
 .../lb/templates/conf/loadbalancer.conf.erb     | 142 ---
 tools/puppet/modules/manager/LICENSE            |  16 -
 tools/puppet/modules/manager/README             |   3 -
 .../lib/copy_mysql-connector-jar_here           |   0
 tools/puppet/modules/manager/manifests/clean.pp |  49 -
 .../puppet/modules/manager/manifests/deploy.pp  |  48 -
 tools/puppet/modules/manager/manifests/init.pp  | 104 ---
 .../modules/manager/manifests/initialize.pp     |  63 --
 .../puppet/modules/manager/manifests/params.pp  |  46 -
 .../modules/manager/manifests/push_templates.pp |  31 -
 tools/puppet/modules/manager/manifests/start.pp |  33 -
 .../manager/templates/conf/axis2/axis2.xml.erb  | 702 --------------
 .../manager/templates/conf/carbon.xml.erb       | 625 -------------
 .../conf/cartridge-config.properties.erb        |  73 --
 .../conf/datasources/master-datasources.xml.erb |  27 -
 .../datasources/stratos-datasources.xml.erb     |  66 --
 .../manager/templates/conf/jndi.properties.erb  |   4 -
 tools/puppet/modules/messagebroker/LICENSE      |  13 -
 .../files/configs/bin/wso2server.sh             | 300 ------
 .../modules/messagebroker/manifests/clean.pp    |  45 -
 .../modules/messagebroker/manifests/deploy.pp   |  43 -
 .../modules/messagebroker/manifests/init.pp     |  99 --
 .../messagebroker/manifests/initialize.pp       |  59 --
 .../modules/messagebroker/manifests/params.pp   |  66 --
 .../messagebroker/manifests/push_templates.pp   |  26 -
 .../modules/messagebroker/manifests/start.pp    |  27 -
 .../templates/conf/axis2/axis2.xml.erb          | 719 ---------------
 .../messagebroker/templates/conf/carbon.xml.erb | 583 ------------
 tools/puppet/templates/load-balancer/.erb       |   0
 .../php_cartridge/etc/apache2/apache2.conf.erb  | 256 ------
 .../etc/apache2/sites-available/default-ssl.erb | 195 ----
 .../etc/apache2/sites-available/default.erb     |  64 --
 tools/puppet3/auth.conf                         |  17 +
 tools/puppet3/autosign.conf                     |  16 +
 tools/puppet3/fileserver.conf                   |  17 +
 tools/puppet3/manifests/nodes.pp                |  32 +-
 tools/puppet3/manifests/site.pp                 |  17 +
 tools/puppet3/modules/agent/files/README.txt    |  12 +
 tools/puppet3/modules/agent/manifests/init.pp   |  17 +
 .../modules/agent/manifests/initialize.pp       |  45 +-
 .../modules/agent/manifests/push_templates.pp   |  33 +-
 tools/puppet3/modules/agent/manifests/start.pp  |  33 +-
 .../modules/agent/templates/bin/stratos.sh.erb  |   8 +-
 .../templates/extensions/addons/_mysql.erb      |  17 +
 .../agent/templates/extensions/addons/_ruby.erb |  17 +
 tools/puppet3/modules/autoscaler/LICENSE        |  13 -
 .../autoscaler/files/configs/bin/stratos.sh     | 298 ------
 .../configs/repository/conf/autoscaler.xml      |  34 -
 .../modules/autoscaler/manifests/clean.pp       |  45 -
 .../modules/autoscaler/manifests/deploy.pp      |  43 -
 .../modules/autoscaler/manifests/init.pp        |  97 --
 .../modules/autoscaler/manifests/initialize.pp  |  59 --
 .../modules/autoscaler/manifests/params.pp      |  66 --
 .../autoscaler/manifests/push_templates.pp      |  26 -
 .../modules/autoscaler/manifests/start.pp       |  27 -
 .../templates/conf/autoscaler.xml.erb           |  39 -
 .../templates/conf/axis2/axis2.xml.erb          | 701 --------------
 .../autoscaler/templates/conf/carbon.xml.erb    | 625 -------------
 .../templates/conf/jndi.properties.erb          |   4 -
 .../economy-autoscale.xml.erb                   |  26 -
 .../economy-deployment.xml.erb                  |  23 -
 .../server/partitions/partitions.xml.erb        |  19 -
 tools/puppet3/modules/cc/LICENSE                |  13 -
 .../modules/cc/files/configs/bin/stratos.sh     | 299 ------
 .../repository/conf/cloud-controller.xml        |  81 --
 ....stratos.cloud.controller_4.0.0.SNAPSHOT.jar | Bin 183364 -> 0 bytes
 tools/puppet3/modules/cc/manifests/clean.pp     |  45 -
 tools/puppet3/modules/cc/manifests/deploy.pp    |  43 -
 tools/puppet3/modules/cc/manifests/init.pp      |  96 --
 .../puppet3/modules/cc/manifests/initialize.pp  |  59 --
 tools/puppet3/modules/cc/manifests/params.pp    |  66 --
 .../modules/cc/manifests/push_templates.pp      |  26 -
 tools/puppet3/modules/cc/manifests/start.pp     |  27 -
 .../cc/templates/conf/axis2/axis2.xml.erb       | 703 --------------
 .../modules/cc/templates/conf/carbon.xml.erb    | 625 -------------
 .../cc/templates/conf/jndi.properties.erb       |   4 -
 tools/puppet3/modules/cep/LICENSE               |  13 -
 .../modules/cep/files/configs/bin/wso2server.sh | 304 -------
 .../dropins/activemq_client_5.8.0_1.0.0.jar     | Bin 1032400 -> 0 bytes
 .../dropins/andes_client_0.13.wso2v8_1.0.0.jar  | Bin 1854829 -> 0 bytes
 ...che.stratos.cep.extension-1.0.0-SNAPSHOT.jar | Bin 16495 -> 0 bytes
 .../repository/conf/siddhi/siddhi.extension     |   3 -
 .../repository/conf/stream-manager-config.xml   | 177 ----
 .../HealthStatisticsEventBuilder.xml            |  10 -
 .../InstanceStatusStatisticsBuilder.xml         |  10 -
 .../LoadBalancerStatisticsEventBuilder.xml      |  10 -
 .../AverageInFlightRequestsEventFormatter.xml   |  11 -
 .../AverageLoadAverageEventFormatter.xml        |  11 -
 .../AverageMemoryConsumptionEventFormatter.xml  |  11 -
 .../FaultMessageEventFormatter.xml              |  11 -
 .../GradientInFlightRequestsEventFormatter.xml  |  11 -
 .../GradientLoadAverageEventFormatter.xml       |  11 -
 .../GradientMemoryConsumptionEventFormatter.xml |  11 -
 .../MemberAverageLoadAverageEventFormatter.xml  |  11 -
 ...erAverageMemoryConsumptionEventFormatter.xml |  11 -
 .../MemberGradientLoadAverageEventFormatter.xml |  11 -
 ...rGradientMemoryConsumptionEventFormatter.xml |  11 -
 ...econdDerivativeLoadAverageEventFormatter.xml |  11 -
 ...erivativeMemoryConsumptionEventFormatter.xml |  11 -
 ...DerivativeInFlightRequestsEventFormatter.xml |  11 -
 ...econdDerivativeLoadAverageEventFormatter.xml |  11 -
 ...erivativeMemoryConsumptionEventFormatter.xml |  11 -
 .../executionplans/AverageHeathRequest.xml      |  29 -
 .../AverageInFlightRequestsFinder.xml           |  19 -
 .../executionplans/GradientOfHealthRequest.xml  |  30 -
 .../GradientOfRequestsInFlightFinder.xml        |  18 -
 .../SecondDerivativeOfHealthRequest.xml         |  27 -
 ...SecondDerivativeOfRequestsInFlightFinder.xml |  19 -
 .../DefaultWSO2EventInputAdaptor.xml            |   3 -
 .../DefaultWSO2EventOutputAdaptor.xml           |   8 -
 .../outputeventadaptors/JMSOutputAdaptor.xml    |   8 -
 .../streamdefinitions/stream-manager-config.xml | 269 ------
 tools/puppet3/modules/cep/manifests/clean.pp    |  45 -
 tools/puppet3/modules/cep/manifests/deploy.pp   |  43 -
 tools/puppet3/modules/cep/manifests/init.pp     | 101 ---
 .../puppet3/modules/cep/manifests/initialize.pp |  59 --
 tools/puppet3/modules/cep/manifests/params.pp   |  69 --
 .../modules/cep/manifests/push_templates.pp     |  26 -
 tools/puppet3/modules/cep/manifests/start.pp    |  27 -
 .../cep/templates/conf/axis2/axis2.xml.erb      | 698 --------------
 .../modules/cep/templates/conf/carbon.xml.erb   | 609 -------------
 .../cep/templates/conf/jndi.properties.erb      |  32 -
 .../JMSOutputAdaptor.xml.erb                    |   8 -
 tools/puppet3/modules/java/manifests/init.pp    |  17 +
 .../modules/java/templates/java_home.sh.erb     |  17 +
 tools/puppet3/modules/lb/files/README.txt       |  12 +
 tools/puppet3/modules/lb/manifests/clean.pp     |  33 +-
 tools/puppet3/modules/lb/manifests/deploy.pp    |  33 +-
 tools/puppet3/modules/lb/manifests/init.pp      |  33 +-
 .../puppet3/modules/lb/manifests/initialize.pp  |  43 +-
 tools/puppet3/modules/lb/manifests/params.pp    |  33 +-
 .../modules/lb/manifests/push_templates.pp      |  33 +-
 tools/puppet3/modules/lb/manifests/start.pp     |  33 +-
 tools/puppet3/modules/manager/LICENSE           |  13 -
 .../manager/files/configs/bin/stratos.sh        | 301 ------
 .../lib/mysql-connector-java-5.1.26-bin.jar     | Bin 855948 -> 0 bytes
 .../repository/conf/cartridge-config.properties |  63 --
 .../conf/datasources/master-datasources.xml     |  27 -
 .../conf/datasources/stratos-datasources.xml    |  66 --
 .../repository/conf/stratos-datasources.xml     |  66 --
 .../puppet3/modules/manager/manifests/clean.pp  |  45 -
 .../puppet3/modules/manager/manifests/deploy.pp |  43 -
 tools/puppet3/modules/manager/manifests/init.pp |  99 --
 .../modules/manager/manifests/initialize.pp     |  59 --
 .../puppet3/modules/manager/manifests/params.pp |  66 --
 .../modules/manager/manifests/push_templates.pp |  26 -
 .../puppet3/modules/manager/manifests/start.pp  |  27 -
 .../manager/templates/conf/axis2/axis2.xml.erb  | 702 --------------
 .../manager/templates/conf/carbon.xml.erb       | 625 -------------
 .../conf/cartridge-config.properties.erb        |  73 --
 .../conf/datasources/master-datasources.xml.erb |  27 -
 .../datasources/stratos-datasources.xml.erb     |  66 --
 .../manager/templates/conf/jndi.properties.erb  |   4 -
 tools/puppet3/modules/messagebroker/LICENSE     |  13 -
 .../files/configs/bin/wso2server.sh             | 300 ------
 .../modules/messagebroker/manifests/clean.pp    |  45 -
 .../modules/messagebroker/manifests/deploy.pp   |  43 -
 .../modules/messagebroker/manifests/init.pp     |  99 --
 .../messagebroker/manifests/initialize.pp       |  59 --
 .../modules/messagebroker/manifests/params.pp   |  66 --
 .../messagebroker/manifests/push_templates.pp   |  26 -
 .../modules/messagebroker/manifests/start.pp    |  27 -
 .../templates/conf/axis2/axis2.xml.erb          | 719 ---------------
 .../messagebroker/templates/conf/carbon.xml.erb | 583 ------------
 tools/puppet3/modules/mysql/manifests/init.pp   |  17 +
 .../modules/mysql/templates/000-default.erb     |  17 +
 .../puppet3/modules/mysql/templates/my.cnf.erb  |  17 +
 .../modules/mysql/templates/phpMyAdmin.conf.erb |  17 +
 tools/puppet3/modules/nodejs/manifests/init.pp  |  17 +
 .../modules/php/lib/facter/stratos_facts.rb     |  17 +
 .../puppet3/modules/php/manifests/init.pp.cent  |  17 +
 tools/puppet3/modules/php/manifests/init.pp.deb |  17 +
 tools/puppet3/modules/php/manifests/init.pp.rpm |  17 +
 .../modules/php/templates/httpd/httpd.conf.erb  |  17 +
 tools/puppet3/modules/ruby/manifests/init.pp    |  17 +
 .../modules/ruby/templates/ruby-start.sh.erb    |  18 +
 tools/puppet3/modules/tomcat/manifests/init.pp  |  17 +
 .../puppet3/modules/wordpress/manifests/init.pp |  17 +
 .../wordpress/templates/httpd/httpd.conf.erb    |  17 +
 tools/puppet3/puppet.conf                       |  17 +
 tools/stratos-installer/conf/stratos-setup.conf | 139 +--
 .../repository/conf/activemq/jndi.properties    |  28 +
 .../config/all/repository/conf/autoscaler.xml   |  39 +
 .../repository/conf/cartridge-config.properties |  28 +
 .../all/repository/conf/cloud-controller.xml    |  89 ++
 .../conf/datasources/master-datasources.xml     | 129 +++
 .../conf/datasources/stratos-datasources.xml    |  51 ++
 .../config/all/repository/conf/jndi.properties  |  32 +
 .../cc/repository/conf/cloud-controller.xml     |   1 -
 tools/stratos-installer/demo.sh                 | 190 ++++
 tools/stratos-installer/stratos-clean.sh        | 104 +++
 tools/stratos-installer/stratos-ec2.sh          |  49 +-
 tools/stratos-installer/stratos-openstack.sh    |  37 +-
 tools/stratos-installer/stratos-setup.sh        | 811 ++++++++---------
 .../stratos-installer/stratos-start-servers.sh  |  72 +-
 tools/stratos-installer/stratos-vcloud.sh       |  37 +-
 tools/templates/json/autoscale-policy.json      |  28 -
 tools/templates/json/cartridge.json             |  49 -
 tools/templates/json/deployment-policy.json     |  16 -
 .../templates/json/load-balancer-cartridge.json |  67 --
 tools/templates/json/partition.json             |  14 -
 tools/templates/json/subscribe.json             |  12 -
 1697 files changed, 67190 insertions(+), 92592 deletions(-)
----------------------------------------------------------------------



[7/8] git commit: removing invalid scripts for creating cartridges

Posted by ud...@apache.org.
removing invalid scripts for creating cartridges


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

Branch: refs/heads/master
Commit: 89983ecc30019c9a9edb8c8051044486a19d1a75
Parents: ce69655
Author: Udara Liyanage <ud...@wso2.com>
Authored: Mon Mar 31 17:16:44 2014 -0400
Committer: Udara Liyanage <ud...@wso2.com>
Committed: Mon Mar 31 17:16:44 2014 -0400

----------------------------------------------------------------------
 tools/cartridge-create/README                   |  50 ---
 tools/cartridge-create/configure-software       | 383 -------------------
 tools/cartridge-create/create-kvm-image.sh      |  24 --
 tools/cartridge-create/image-action.sh          | 165 --------
 .../init-scripts/default/default                |  43 ---
 .../init-scripts/default/default.ctrg           |  51 ---
 .../init-scripts/default/get-launch-params.rb   |  55 ---
 .../default/stratos-openstack-init.sh           |  57 ---
 .../init-scripts/default/stratos.pem            |  16 -
 .../init-scripts/mysql/ec2/get-launch-params.rb |  51 ---
 .../init-scripts/mysql/ec2/healthcheck.sh       |  32 --
 .../init-scripts/mysql/ec2/stratos-init.sh      | 152 --------
 .../init-scripts/mysql/get-launch-params.rb     |  55 ---
 tools/cartridge-create/init-scripts/mysql/mysql |  46 ---
 .../init-scripts/mysql/mysql.ctrg               |  58 ---
 .../mysql/openstack/get-launch-params.rb        |  55 ---
 .../init-scripts/mysql/openstack/healthcheck.sh |  30 --
 .../mysql/openstack/stratos-init.sh             | 165 --------
 .../init-scripts/mysql/stratos.pem              |  16 -
 .../init-scripts/mysql/vcloud/stratos-init.sh   | 152 --------
 .../php/cartridge-data-publisher-1.0.2.zip      | Bin 2832200 -> 0 bytes
 tools/cartridge-create/init-scripts/php/default |  59 ---
 .../init-scripts/php/default-ssl                | 190 ---------
 .../init-scripts/php/ec2/get-launch-params.rb   |  54 ---
 .../init-scripts/php/ec2/healthcheck.sh         |  32 --
 .../init-scripts/php/ec2/stratos-init.sh        | 304 ---------------
 .../init-scripts/php/get-launch-params.rb       |  55 ---
 .../php/openstack/get-launch-params.rb          |  55 ---
 .../init-scripts/php/openstack/healthcheck.sh   |  30 --
 .../init-scripts/php/openstack/stratos-init.sh  | 293 --------------
 tools/cartridge-create/init-scripts/php/php     |  49 ---
 .../cartridge-create/init-scripts/php/php.ctrg  |  65 ----
 .../init-scripts/php/thrift-0.8.0.tar.gz        | Bin 2379006 -> 0 bytes
 .../cartridge-create/init-scripts/php/wso2.pem  |  16 -
 tools/cartridge-create/init-scripts/php/x.sh    |  50 ---
 tools/cartridge-create/init-scripts/php/y.sh    |  32 --
 .../init-scripts/tomcat/get-launch-params.rb    |  53 ---
 .../tomcat/openstack/get-launch-params.rb       |  55 ---
 .../tomcat/openstack/healthcheck.sh             |  30 --
 .../tomcat/openstack/stratos-init.sh            | 289 --------------
 .../init-scripts/tomcat/payload/README          |  21 -
 .../init-scripts/tomcat/payload/launch-params   |  18 -
 .../init-scripts/tomcat/stratos-init.sh         | 274 -------------
 .../init-scripts/tomcat/stratos.pem             |  16 -
 tools/cartridge-create/stratos-image            | 100 -----
 tools/cartridge-create/stratos-image-local      | 310 ---------------
 tools/cartridge-create/uploadimg.sh             |  32 --
 47 files changed, 4138 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/README
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/README b/tools/cartridge-create/README
deleted file mode 100644
index 883fe48..0000000
--- a/tools/cartridge-create/README
+++ /dev/null
@@ -1,50 +0,0 @@
-This folder contain utilities to create customized images from the already running openstack instances.
-The main utility is a CLI tool called stratos-image.
-Pre-requisites:
-
-You need the private or public(floating)ip of the openstack instance from which you need to create the image. Also you need a username
-for that instance and a private key to access that instance. Copy the private key to init_scripts/<template> (e.g., init_scripts/php) folder.
-
-You need a file with the following information regarding the Openstack environment and copy that file into the current folder.
-When uploading the image you need the variables in the file exported to the environment. 
-Normally when you install the Openstack you get this file generated. Please refer to your Openstack installation documents 
-on how to get the information in this file.
-
-----------------------------------------------------------
-NOVA_API_HOST=192.168.16.20
-GLANCE_API_HOST=192.168.16.20
-KEYSTONE_API_HOST=192.168.16.20
-
-NOVA_REGION="nova"
-
-export NOVA_USERNAME=demo
-export NOVA_PROJECT_ID=demo
-export NOVA_PASSWORD=openstack
-export NOVA_API_KEY=openstack
-export NOVA_REGION_NAME=$NOVA_REGION
-export NOVA_URL="http://$NOVA_API_HOST:5000/v2.0/"
-export NOVA_VERSION="1.1"
-
-export OS_USERNAME=demo
-export OS_PASSWORD=openstack
-export OS_TENANT_ID=7434d33c18e04e60a6751922773fbe2d
-export OS_AUTH_URL="http://$KEYSTONE_API_HOST:5000/v2.0/"
-export OS_AUTH_STRATEGY="keystone"
-
-export EC2_URL="http://$NOVA_API_HOST:8773/services/Cloud"
-export EC2_ACCESS_KEY="8b742fee68c6464198517242828adb82"
-export EC2_SECRET_KEY="279a7f28c8a54d5db8e27524f648a7d3"
-export S3_URL="http://$GLANCE_API_HOST:3333"
-
-----------------------------------------------------------
-
-For help on how to execute stratos-image execute.
-./stratos-image help
-
-Following is an example of create and upload the image for php cartridge
-
-./stratos-image create 192.168.16.129 php ubuntu wso2.pem
-
-nova image-create <vm instance id> php-cloudimg-amd64
-
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/configure-software
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/configure-software b/tools/cartridge-create/configure-software
deleted file mode 100755
index 251a1ac..0000000
--- a/tools/cartridge-create/configure-software
+++ /dev/null
@@ -1,383 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-# ----------------------------------------------------------------------------
-
-
-ROOTFS=$1
-TEMPLATE=$2
-
-#
-# Locale settings (en_GB for Redcoats, en_US for Yanks):
-#
-LANG="en_US.UTF-8" 
-LANGUAGE="en_US.UTF-8" 
-LC_ALL="en_US.UTF-8" 
-LC_CTYPE="C"
-
-#
-# Ubuntu mirror to use:
-#
-###DEBMIRROR="http://archive.ubuntu.com/ubuntu/"
-#DEBMIRROR="http://us.archive.ubuntu.com/ubuntu/"
-DEBMIRROR="http://lk.archive.ubuntu.com/ubuntu/"
-
-
-mysql() {
-
-	# MySQL still prompts.  Bug.
-	#DEBCONF_FRONTEND='noninteractive' 
-	
-	chroot $ROOTFS apt-get update
-	# Next, all the LAMP packages.  We must first pre-save the password
-	# for MySQL to use:
-	#chroot $ROOTFS echo "mysql-server mysql-server/root_password select ubuntu" | chroot $ROOTFS debconf-set-selections
-	#chroot $ROOTFS echo "mysql-server mysql-server/root_password_again select ubuntu" | chroot $ROOTFS debconf-set-selections
-	
-	chroot $ROOTFS apt-get install -y \
-	nano zip mysql-server git \
-	apache2-mpm-prefork apache2-utils apache2.2-bin apache2.2-common dbconfig-common fontconfig-config libapache2-mod-php5 \
-	libaprutil1-dbd-sqlite3 libaprutil1-ldap libcap2 libfontconfig1 libgd2-xpm libjpeg-turbo8 libjpeg8 libmcrypt4 \
-	libt1-5 libxpm4 php5-cli php5-common php5-gd php5-mcrypt php5-mysql phpmyadmin ssl-cert ttf-dejavu-core ruby
-
-	# Be sure to have a new SSL cert for this new LXC host:
-	rm -f $ROOTFS/etc/ssl/private/ssl-cert-snakeoil.key
-    cp -f ./init_scripts/mysql/cc/ssl-cert-snakeoil.pem $ROOTFS/etc/ssl/certs/
-    cp -f ./init_scripts/mysql/cc/ssl-cert-snakeoil.key $ROOTFS/etc/ssl/private/
-	#chroot $ROOTFS dpkg-reconfigure ssl-cert
-
-	# Enable HTTPS:
-	chroot $ROOTFS a2enmod ssl
-	chroot $ROOTFS a2ensite default-ssl	
-	# Desable HTTP
-	chroot $ROOTFS a2dissite default	
-
- 	# set mysql to listen to all network
-	chroot $ROOTFS cp /etc/mysql/my.cnf /etc/mysql/my.cnf.org
-	chroot $ROOTFS cat /etc/mysql/my.cnf.org | sed -e 's/127.0.0.1/0.0.0.0/' > $ROOTFS/etc/mysql/my.cnf	
-
-	# See http://blog.bodhizazen.net/linux/lxc-configure-ubuntu-lucid-containers/
-	# This requirement is confirmed on 10.04.1 LTS.  Within LXC, the
-	# upstart "startup" signal is sent, but not "network-interface", etc.
-	pushd $ROOTFS/etc/init/
-	cp -a ufw.conf ufw.conf-dist
-	sed '
-s/start on (starting network-interface/start on startup\n#start on (starting network-interface/
-s/          or starting network-manager/#          or starting network-manager/
-s/          or starting networking)/#          or starting network-manager/
-' < ufw.conf-dist > ufw.conf
-	
-	popd
-
-}
-
-php() {
-
-    cp -f ./init_scripts/php/wso2-openstack-init.sh $ROOTFS/opt/
-    cp -f ./init_scripts/php/get-launch-params.rb $ROOTFS/opt/
-    cp -f ./init_scripts/php/cc/ssl-cert-snakeoil.pem $ROOTFS/etc/ssl/certs/
-    cp -f ./init_scripts/php/cc/ssl-cert-snakeoil.key $ROOTFS/etc/ssl/private/
-    
-	chroot $ROOTFS apt-get update
-	# Next, all the packages. 
-	
-	chroot $ROOTFS apt-get install -y \
-    nano zip build-essential mysql-client apache2 php5 php5-cli libapache2-mod-php5 php5-gd php5-mysql php-db php-pear \
-    php5-curl curl wget php5-ldap php5-adodb mailutils php5-imap php5-ldap \
-    openssl ssl-cert ldap-utils php5-mcrypt mcrypt ufw fail2ban git libboost-all-dev ruby
-
-    # Install the thrift library
-    tar -zxf ./init_scripts/php/thrift-0.8.0.tar.gz -C$ROOTFS/opt
-    chroot $ROOTFS cd /opt/thrift-0.8.0;./configure --libdir=/usr/lib;make;make install
-    tar -zxf ./init_scripts/php/cartridge_data_publisher_1.0.0.tar.gz -C$ROOTFS/opt
-    chroot $ROOTFS cd /opt/cartridge_data_publisher_1.0.0;make
-
-	# install gitpython 
-	# chroot $ROOTFS easy_install GitPython
-
-
-	# configure apache log write to syslog TODO : Need generic solution
-	chroot $ROOTFS cp /etc/apache2/apache2.conf /etc/apache2/apache2.conf.org
-    chroot $ROOTFS cat /etc/apache2/apache2.conf.org | sed -e 's/^ErrorLog.*/ErrorLog syslog:local2/' > $ROOTFS/etc/apache2/apache2.conf
-
-	# configure rsyslog TODO : Need generic solution
-	chroot $ROOTFS cp /etc/rsyslog.conf /etc/rsyslog.conf.org
-    chroot $ROOTFS cat /etc/rsyslog.conf.org | sed -e 's/^#$ModLoad\simtcp.*/$ModLoad imtcp/' |  sed -e 's/^\#\$ModLoad\simtcp.*/\$ModLoad imtcp/' | sed -e 's/^\#\$InputTCPServerRun\s514.*/\$InputTCPServerRun 514\nlocal2\.\*        \@\@localhost\:32000/' > $ROOTFS/etc/rsyslog.conf
-
-
-# adding simplesaml alias to apache
-chroot $ROOTFS cp /etc/apache2/sites-available/default /etc/apache2/sites-available/default-org
-chroot $ROOTFS cp /etc/apache2/sites-available/default-ssl /etc/apache2/sites-available/default-ssl-org
-chroot $ROOTFS cat /etc/apache2/sites-available/default-org | sed -e 's@DocumentRoot \/var\/www@DocumentRoot \/var\/www\/public\n\tAlias \/simplesaml \/var\/www\/simplesamlphp\/www@' > $ROOTFS/etc/apache2/sites-available/default
-chroot $ROOTFS cat /etc/apache2/sites-available/default-ssl-org | sed -e 's@DocumentRoot \/var\/www@DocumentRoot \/var\/www\/public\n\tAlias \/simplesaml \/var\/www\/simplesamlphp\/www@' > $ROOTFS/etc/apache2/sites-available/default-ssl
-	# Enable HTTPS:
-	chroot $ROOTFS a2enmod ssl
-	chroot $ROOTFS a2ensite default-ssl	
-
-
-	# See http://blog.bodhizazen.net/linux/lxc-configure-ubuntu-lucid-containers/
-	# This requirement is confirmed on 10.04.1 LTS.  Within LXC, the
-	# upstart "startup" signal is sent, but not "network-interface", etc.
-	pushd $ROOTFS/etc/init/
-	cp -a ufw.conf ufw.conf-dist
-	sed '
-s/start on (starting network-interface/start on startup\n#start on (starting network-interface/
-s/          or starting network-manager/#          or starting network-manager/
-s/          or starting networking)/#          or starting network-manager/
-' < ufw.conf-dist > ufw.conf
-	popd
-	
-    pushd $ROOTFS/etc
-    echo "#!/bin/bash -e
-mkdir -p /etc/agent/conf
-chmod 755 /opt/wso2-openstack-init.sh
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-    " > rc.local
-    popd
-
-}
-
-lamp() {
-
-    cp -f ./init_scripts/lamp/wso2-openstack-init.sh $ROOTFS/opt/
-    cp -f ./init_scripts/lamp/get-launch-params.rb $ROOTFS/opt/
-    cp -f ./init_scripts/lamp/server $ROOTFS/opt/
-    cp -f ./init_scripts/lamp/svn_client.sh $ROOTFS/opt/
-    cp -f ./init_scripts/lamp/svn_client_y.sh $ROOTFS/opt/
-    cp -f ./init_scripts/lamp/deployer.sh $ROOTFS/opt/
-
-    # Copy software
-    arr=$(echo $SOFTWARE | tr ":" "\n")
-    for x in $arr
-    do
-       cp -rf $x $ROOTFS/opt/
-    done
-
-
-	# MySQL still prompts.  Bug.
-	#DEBCONF_FRONTEND='noninteractive' 
-	
-	chroot $ROOTFS apt-get update
-	# Next, all the LAMP packages.  We must first pre-save the password
-	# for MySQL to use:
-	chroot $ROOTFS echo "mysql-server mysql-server/root_password select ubuntu" | chroot $ROOTFS debconf-set-selections
-	chroot $ROOTFS echo "mysql-server mysql-server/root_password_again select ubuntu" | chroot $ROOTFS debconf-set-selections
-	
-	chroot $ROOTFS apt-get install -y \
-	 nano zip mysql-server mysql-client \
-	 apache2 php5 php5-cli libapache2-mod-php5 php5-gd php5-mysql php-db php-pear php5-curl curl wget php5-ldap php5-adodb mailutils \
-	 php5-imap php5-ldap \
-	 openssl ssl-cert ldap-utils \
-	 php5-mcrypt mcrypt ufw fail2ban ruby subversion
-
-	# Be sure to have a new SSL cert for this new LXC host:
-	#rm -f $ROOTFS/etc/ssl/private/ssl-cert-snakeoil.key
-	#chroot $ROOTFS dpkg-reconfigure ssl-cert
-
-	# Enable HTTPS:
-	#chroot $ROOTFS a2enmod ssl
-	#chroot $ROOTFS a2ensite default-ssl	
-
-	# Turn on MySQL replication logs by default.  (Necessary for 
-	# incremental backups, even if you're not doing replication.)
-	pushd $ROOTFS/etc/mysql/conf.d
-	echo "[mysqld]
-log-bin=mysqld-bin
-server-id = 1
-
-# For an SSH Tunneled slave:
-# See also: /etc/rc.local for the SSH Tunnel that makes this work.
-#[mysqld]
-#master-host     = 127.0.0.1
-#master-user     = root
-#master-password = ubuntu
-#master-port     = 13306
-#server-id       = 2
-	" >> replication.cnf
-	popd
-
-pushd $ROOTFS/etc
-    echo "#!/bin/bash -e
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-    " > rc.local
-    popd
-
-	# Next, fix a couple of Debian gotchas:
-
-	# Comment out these two lines.  (Don't expire,
-	# and use the 1G default file size.
-	pushd $ROOTFS/etc/mysql
-	cp -a my.cnf my.cnf-dist
-	sed '
-s/expire_logs_days/#expire_logs_days/
-s/max_binlog_size/#max_binlog_size/
-' < my.cnf-dist > my.cnf
-	popd
-	
-	# See http://blog.bodhizazen.net/linux/lxc-configure-ubuntu-lucid-containers/
-	# This requirement is confirmed on 10.04.1 LTS.  Within LXC, the
-	# upstart "startup" signal is sent, but not "network-interface", etc.
-	pushd $ROOTFS/etc/init/
-	cp -a ufw.conf ufw.conf-dist
-	sed '
-s/start on (starting network-interface/start on startup\n#start on (starting network-interface/
-s/          or starting network-manager/#          or starting network-manager/
-s/          or starting networking)/#          or starting network-manager/
-' < ufw.conf-dist > ufw.conf
-	
-	cp -a mysql.conf mysql.conf-dist
-	sed --posix -e '
-s/start on (net-device-up/start on startup\n#start on (net-device-up/
-s/          and local-filesystems/#          and local-filesystems/
-s/\t  and runlevel \[2345\])/#\t  and runlevel \[2345\])/
-' < mysql.conf-dist > mysql.conf
-	popd
-	
-}
-
-wso2_carbon_server() {
-
-    cp -f ./init_scripts/carbon/wso2-openstack-init.sh $ROOTFS/opt/
-    cp -f ./init_scripts/carbon/get-launch-params.rb $ROOTFS/opt/
-    # Copy software
-    arr=$(echo $SOFTWARE | tr ":" "\n")
-    for x in $arr
-    do
-       cp -rf $x $ROOTFS/opt/
-    done
-
-	#chroot $ROOTFS apt-get update
-	
-	 chroot $ROOTFS apt-get install -y \
-	 nano zip \
-	 wget \
-	 openssl ssl-cert ldap-utils ruby git
-  
-     # TODO install puppet agent
-
-	# Be sure to have a new SSL cert for this new LXC host:
-	#rm -f $ROOTFS/etc/ssl/private/ssl-cert-snakeoil.key
-	#chroot $ROOTFS dpkg-reconfigure ssl-cert
-
-pushd $ROOTFS/etc
-    echo "#!/bin/bash -e
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-    " > rc.local
-    popd
-
-}
-
-jetty() {
-
-    cp -f ./init_scripts/jetty/wso2-openstack-init.sh $ROOTFS/opt/
-    cp -f ./init_scripts/jetty/get-launch-params.rb $ROOTFS/opt/
-    cp -f ./init_scripts/jetty/server $ROOTFS/opt/
-    cp -f ./init_scripts/jetty/svn_client.sh $ROOTFS/opt/
-    cp -f ./init_scripts/jetty/svn_client_y.sh $ROOTFS/opt/
-    cp -f ./init_scripts/jetty/deployer.sh $ROOTFS/opt/
-    # Copy software
-    arr=$(echo $SOFTWARE | tr ":" "\n")
-    for x in $arr
-    do
-       cp -rf $x $ROOTFS/opt/
-    done
-
-	#chroot $ROOTFS apt-get update
-	
-	chroot $ROOTFS apt-get install -y \
-	 nano zip \
-	 wget \
-	 openssl ssl-cert ldap-utils ruby subversion
-   
-pushd $ROOTFS/etc
-    echo "#!/bin/bash -e
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-    " > rc.local
-    popd
-
-}
-
-
-tomcat7() {
-
-    #chroot $ROOTFS echo "nameserver 8.8.8.8" >> $ROOTFS/etc/resolvconf/resolv.conf.d/base
-    echo "Please fix the resolve conf file"
-    read
-    #chroot $ROOTFS mkdir -p /run/resolveconf
-    #chroot $ROORFS touch /run/resolveconf/resolv.conf
-    #chroot echo "nameserver 8.8.8.8" > /run/resolveconf/resolv.conf
-    
-    echo "------------------------------------------"
-    chroot $ROOTFS cat /etc/resolv.conf
-    echo "------------------------------------------"
-
-
-    mount -o bind /dev $ROOTFS/dev
-
-
-    mount -t proc none $ROOTFS/proc
-
-
-    cp -f ./init_scripts/tomcat7/wso2-openstack-init.sh $ROOTFS/opt/
-    cp -f ./init_scripts/tomcat7/get-launch-params.rb $ROOTFS/opt/
-    
-    
-	chroot $ROOTFS apt-get update
-	# Next, all the packages. 
-	
-    chroot $ROOTFS apt-get install -y \
-    nano zip git\
-    ruby curl wget tomcat7
-     
-	# See http://blog.bodhizazen.net/linux/lxc-configure-ubuntu-lucid-containers/
-	# This requirement is confirmed on 10.04.1 LTS.  Within LXC, the
-	# upstart "startup" signal is sent, but not "network-interface", etc.
-	pushd $ROOTFS/etc/init/
-	cp -a ufw.conf ufw.conf-dist
-	sed '
-s/start on (starting network-interface/start on startup\n#start on (starting network-interface/
-s/          or starting network-manager/#          or starting network-manager/
-s/          or starting networking)/#          or starting network-manager/
-' < ufw.conf-dist > ufw.conf
-	popd
-	
-    pushd $ROOTFS/etc
-    echo "#!/bin/bash -e
-mkdir -p /etc/agent/conf
-chmod 755 /opt/wso2-openstack-init.sh
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-    " > rc.local
-    popd
-
-    umount $ROOTFS/dev
-    umount $ROOTFS/proc
-}
-
-
-# Don't prompt when running apt-get:
-export DEBCONF_FRONTEND='noninteractive' 
-
-# Run the config function with given $TEMPLATE name (if it exists):
-$TEMPLATE 
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/create-kvm-image.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/create-kvm-image.sh b/tools/cartridge-create/create-kvm-image.sh
deleted file mode 100755
index 795f42c..0000000
--- a/tools/cartridge-create/create-kvm-image.sh
+++ /dev/null
@@ -1,24 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-# ----------------------------------------------------------------------------
-
-
-./stratos-image create 192.168.16.131 mysql ubuntu stratos.pem
-#./stratos-image upload 192.168.16.131 precise-server-mysql-cloudimg-amd64

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/image-action.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/image-action.sh b/tools/cartridge-create/image-action.sh
deleted file mode 100755
index a6c8261..0000000
--- a/tools/cartridge-create/image-action.sh
+++ /dev/null
@@ -1,165 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-# ----------------------------------------------------------------------------
-
-
-# Die on any error:
-set -e
-
-work_dir=""
-action=""
-image_template=""
-image_root=""
-software=""
-image_type=""
-loopdevice="/dev/loop1"
-nbddevice="/dev/nbd3"
-nbdmount="/dev/nbd3p1"
-
-function image_validate {
-    if [ -z $action ]; then
-        echo "usage: image_action.sh action=<mount|create|unmount> <options>"
-        exit 1
-    fi
-
-    if [[ !($action == "mount") && !($action == "create") && !($action == "unmount") ]]; then
-        echo "usage: image_action.sh action=<mount|create|unmount> <options>"
-        exit 1
-    fi
-
-    if [[ (-n $action) && ($action == "create") && ( -z $image_template || -z $image_root ) ]]; then
-        echo "usage: image_action.sh action=create template=<template> image-root=<image_root>"
-        exit 1
-    fi
-
-    if [[ (-n $action) && ($action == "unmount") && (-z $image_template || -z $image_root) ]]; then
-        echo "usage: image_action.sh action=unmount image-id=<image_template> image-root=<image_root>"
-        exit 1
-    fi
-    
-    if [[ (-n $action) && ($action == "mount") && (-z $image_template || -z $image_root || -z $image_image) ]]; then
-        echo "usage: image_action.sh action=mount image-template=<image_template> image-root=<image_root> image-image=<image_image>"
-        exit 1
-    fi
-    
-}
-
-for var in $@; do
-    set -- `echo $var | tr '=' ' '`
-    key=$1
-    value=$2
-
-    if [ $key = "action" ]; then
-        action="$value"
-        echo "action:" $action
-    fi
-
-    if [ $key = "image-root" ]; then
-        image_root="$value"
-        echo "image root:" $image_root
-    fi
-    
-    if [ $key = "image-template" ]; then
-        image_template="$value"
-        echo "template:" $image_template
-    fi
-    
-    if [ $key = "image-image" ]; then
-        image_image="$value"
-        echo "image-image:" $image_image
-    fi
-    
-    if [ $key = "software" ]; then
-        software="$value"
-        echo "software:" $software
-    fi
-    
-    if [ $key = "image-type" ]; then
-        image_type="$value"
-        echo "image_type:" $image_type
-    fi
-
-done
-
-image_validate
-
-work_dir="$image_root/$image_template"
-if [[ (-n $action) && ($action == "unmount") ]]; then
-    echo "# unmount $image_template"
-    if [ -d $work_dir/$image_template ]; then
-        if [ $image_type == "qcow2" ]; then
-            umount $work_dir/$image_template
-            qemu-nbd -d $nbddevice
-            rmmod nbd
-        else
-            echo 'this action unmount image!'
-            umount $work_dir/$image_template/dev
-            umount $work_dir/$image_template/proc
-            umount $work_dir/$image_template/sys
-            umount $work_dir/$image_template
-            if [ -d $work_dir/$image_template/dev ]; then
-                umount -l $work_dir/$image_template
-            fi
-            losetup -d $loopdevice
-        fi
-    fi
-    exit 0
-fi
-
-if [[ (-n $action) && ($action == "mount") ]]; then
-    echo "# mount $image_template "
-    if [ ! -d "$work_dir/$image_template" ]; then
-        mkdir -p $work_dir/$image_template
-    fi
-    #cp -f $image_image $work_dir/
-    if [ $image_type == "qcow2" ]; then
-        modprobe nbd max_part=8
-        qemu-nbd -c $nbddevice $image_image
-        mount $nbdmount $work_dir/$image_template
-    else
-        #loopdevice=`losetup -f`
-        echo "Available loop device is $loopdevice"
-        losetup $loopdevice $image_image
-        #kpartx -av $loopdevice
-        mount $loopdevice $work_dir/$image_template 
-        mount -o bind /dev $work_dir/$image_template/dev
-        mount -o bind /proc $work_dir/$image_template/proc
-        mount -o bind /sys $work_dir/$image_template/sys
-    fi
-    exit 0
-fi
-
-# Where to create newly-created LXC container rootfs filesystems, fstabs, and confs:
-export BASEDIR=$work_dir
-
-# This is a list of semi-colon separated files/directories that will be needed by templates.
-export SOFTWARE="$software"
-export ROOTFS=$work_dir/$image_template
-export TEMPLATE=$image_template
-
-if [ -z "$TEMPLATE" ]; then
-	TEMPLATE="default"
-fi
-
-./configure_software $ROOTFS $TEMPLATE
-echo
-
-exit
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/default/default
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/default/default b/tools/cartridge-create/init-scripts/default/default
deleted file mode 100644
index 7d5274b..0000000
--- a/tools/cartridge-create/init-scripts/default/default
+++ /dev/null
@@ -1,43 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#
-#  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.
-#
-# ----------------------------------------------------------------------------
-
-INSTANCE=$1
-INSTANCE_USER=$2
-KEY=$3
-SOFTWARE=$4
-
-SCP="scp -i ./$KEY"
-SSH="ssh -i ./$KEY"
-
-$SCP ./wso2-openstack-init.sh $INSTANCE_USER@$INSTANCE:
-$SCP ./default.ctrg $INSTANCE_USER@$INSTANCE:
-$SCP ./get-launch-params.rb $INSTANCE_USER@$INSTANCE:
-
-# Copy additional software
-arr=$(echo $SOFTWARE | tr ":" "\n")
-for x in $arr
-do
-   $SCP $x $INSTANCE_USER@$INSTANCE:
-done
-
-# Execute the cartridge creation process in the remoter server
-$SSH $INSTANCE_USER@$INSTANCE "sudo chmod 755 ./default.ctrg;sudo ./default.ctrg"

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/default/default.ctrg
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/default/default.ctrg b/tools/cartridge-create/init-scripts/default/default.ctrg
deleted file mode 100644
index d9414f0..0000000
--- a/tools/cartridge-create/init-scripts/default/default.ctrg
+++ /dev/null
@@ -1,51 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#
-#  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.
-#
-# ----------------------------------------------------------------------------
-
-    mv ./wso2-openstack-init.sh /opt/
-    mv ./default.ctrg 
-    mv ./get-launch-params.rb /opt/
-    mv ./*.tar.gz /opt/
-    mv ./*.zip /opt/
-
-	apt-get update
-	# Next, all th packages.
-	
-	# See http://blog.bodhizazen.net/linux/lxc-configure-ubuntu-lucid-containers/
-	# This requirement is confirmed on 10.04.1 LTS.  Within LXC, the
-	# upstart "startup" signal is sent, but not "network-interface", etc.
-	pushd /etc/init/
-	cp -a ufw.conf ufw.conf-dist
-	sed '
-s/start on (starting network-interface/start on startup\n#start on (starting network-interface/
-s/          or starting network-manager/#          or starting network-manager/
-s/          or starting networking)/#          or starting network-manager/
-' < ufw.conf-dist > ufw.conf
-	
-	popd
-    
-    pushd /etc
-    echo "#!/bin/bash -e
-chmod 755 /opt/wso2-openstack-init.sh
-/opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log
-exit 0
-    " > rc.local
-    popd

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/default/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/default/get-launch-params.rb b/tools/cartridge-create/init-scripts/default/get-launch-params.rb
deleted file mode 100644
index c6368ca..0000000
--- a/tools/cartridge-create/init-scripts/default/get-launch-params.rb
+++ /dev/null
@@ -1,55 +0,0 @@
-#! /usr/bin/ruby
-#
-#
-# 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.
-#
-#
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/default/stratos-openstack-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/default/stratos-openstack-init.sh b/tools/cartridge-create/init-scripts/default/stratos-openstack-init.sh
deleted file mode 100644
index 7e8430a..0000000
--- a/tools/cartridge-create/init-scripts/default/stratos-openstack-init.sh
+++ /dev/null
@@ -1,57 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-export LOG=/var/log/wso2-openstack.log
-instance_path=/var/lib/cloud/instance
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    cp ${instance_path}/user-data.txt ${instance_path}/payload/user-data.zip
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/user-data.zip
-    echo "unzippeddd..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-    # Write a cronjob to execute wso2-openstack-init.sh periodically until public ip is assigned
-    #crontab -l > ./mycron
-    #echo "*/${CRON_DURATION} * * * * /opt/wso2-openstack-init.sh > /var/log/wso2-openstack-init.log" >> ./mycron
-    #crontab ./mycron
-    #rm ./mycron
-
-fi
-
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-echo "Done" >> $LOG
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/default/stratos.pem
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/default/stratos.pem b/tools/cartridge-create/init-scripts/default/stratos.pem
deleted file mode 100644
index 7b2155e..0000000
--- a/tools/cartridge-create/init-scripts/default/stratos.pem
+++ /dev/null
@@ -1,16 +0,0 @@
------BEGIN RSA PRIVATE KEY-----
-MIICXQIBAAKBgQDUdNzv8oHkA8Zn28iQH2qyiV7ZJlBITqp4iw21ZbuyhFtDw2c0
-7euC/g4zbdLjAO4Wofn03C9LSA8KcWKYz4ubaKd+6xG/ywTW2QDRFdGDUY6Dwvkj
-3vnLlPWqvRBpF8ZclkeIjX6svydRvov3F6BSsbYY3trm9PlMtsZq/jtswwIDAQAB
-AoGAEJTqZYPc5WnyA0shFTaOgk68a2BVJb+WCIB52m2NP7qa0OggVv42wmuHujXZ
-HsSE0Jllw9mni02ddugwlNKmB5+z2yiJoGkuaFhFNwB4xFjjujRwMf7ZtoDpa8Yo
-SS1f94dswB31kT601HcUyCEwRBfD9pYBduysFZ1I3/ozVukCQQDs1Lm+LvmZQgLa
-BaWqU73MShDypiyMHVyKwnDUu/zaHu+9r15z/UHroU2nRIRteNv77nUmHsQVHKOc
-0QpmEsT3AkEA5acVolx+4mSCe4ZXh1R9hHZ+HdRrvC2yBiZhHe3bHbcyBN+oPMF4
-OcUE2JsE2+IIJomC5B/v6vjsf67yCFo/lQJAfm+jKjGR94wSUasqIqDKd0IjgifN
-KJCUU1AzRJ+IAjr56t6xImNWyiE3f9FIkdkwOHO5/zv1mv/LKXFAh/YFSQJBAMKE
-MWjiW366j2K9OWohAGewTcZKZC5xrfZTj7LgAtY6kx1Zq5A6dvDHlgE53HW6EBlE
-JB/BhV9LFFZaAhtdBbkCQQDrx9X5f/Lbe39kx5UMtvYrswpYjbKW+qRoQ38NryYA
-G7rRPsgmrjURSEeH4VUG//7gV8wGze7cl50luI2T8+Kg
------END RSA PRIVATE KEY-----
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/ec2/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/ec2/get-launch-params.rb b/tools/cartridge-create/init-scripts/mysql/ec2/get-launch-params.rb
deleted file mode 100644
index 8991b7b..0000000
--- a/tools/cartridge-create/init-scripts/mysql/ec2/get-launch-params.rb
+++ /dev/null
@@ -1,51 +0,0 @@
-#! /usr/bin/ruby
-# ----------------------------------------------------------------------------
-#  Copyright 2005-20012 WSO2, Inc. http://www.apache.org
-#
-#  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.
-
-# ----------------------------------------------------------------------------
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/opt/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/ec2/healthcheck.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/ec2/healthcheck.sh b/tools/cartridge-create/init-scripts/mysql/ec2/healthcheck.sh
deleted file mode 100644
index 706022b..0000000
--- a/tools/cartridge-create/init-scripts/mysql/ec2/healthcheck.sh
+++ /dev/null
@@ -1,32 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-
-
-var=`nc -z localhost 80; echo $?`;
-if [ $var -eq 0 ]
-then
-    echo "port 80 is available" > /dev/null 2>&1
-else
-    echo "port 80 is not available" > /dev/null 2>&1
-    /etc/init.d/apache2 restart
-fi
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/ec2/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/ec2/stratos-init.sh b/tools/cartridge-create/init-scripts/mysql/ec2/stratos-init.sh
deleted file mode 100644
index 3dc20a8..0000000
--- a/tools/cartridge-create/init-scripts/mysql/ec2/stratos-init.sh
+++ /dev/null
@@ -1,152 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-
-export LOG=/var/log/stratos-cartridge.log
-instance_path=/opt
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-SLEEP_DURATION=3
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    wget http://169.254.169.254/latest/user-data -O ${instance_path}/payload/payload.zip
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/payload.zip
-    echo "unzipped..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-
-fi
-
-if [ -f public-ipv4 ]; then
-    echo "public-ipv4 already exists. Removing the public-ipv4 file" >> $LOG
-    rm public-ipv4
-fi
-
-echo ---------------------------- >> $LOG
-echo "getting public ip from metadata service" >> $LOG
-
-wget http://169.254.169.254/latest/meta-data/public-ipv4
-files="`cat public-ipv4`"
-if [[ -z ${files} ]]; then
-    echo "getting public ip" >> $LOG
-    for i in {1..30}
-    do
-      rm -f ./public-ipv4
-      wget http://169.254.169.254/latest/meta-data/public-ipv4
-      files="`cat public-ipv4`"
-      if [ -z $files ]; then
-          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-          sleep $SLEEP_DURATION
-      else
-          echo "Public ip assigned" >> $LOG
-          #crontab -r
-          break
-      fi
-    done
-
-    if [ -z $files ]; then
-      echo "Public ip is not yet assigned. So exit" >> $LOG
-      exit 0
-    fi
-    for x in $files
-    do
-        PUBLIC_IP="$x"
-    done
-
-
-else 
-   PUBLIC_IP="$files"
-   #crontab -r
-fi
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-echo "Setting MySQL root password" >> $LOG
-if [[ (-n ${MYSQL_PASSWORD} ) ]]; then
-	mysqladmin -u root password "${MYSQL_PASSWORD}"
-	mysql -uroot -p${MYSQL_PASSWORD} -e "GRANT ALL PRIVILEGES ON *.* TO 'root'@'%'   IDENTIFIED BY '${MYSQL_PASSWORD}' WITH GRANT OPTION;flush privileges;"
-	echo "MySQL root password set" >> $LOG
-fi
-
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.pem /etc/ssl/certs/ssl-cert-snakeoil.pem
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.key /etc/ssl/private/ssl-cert-snakeoil.key
-/etc/init.d/apache2 restart
-
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS} , BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-mkdir -p  /etc/agent/conf
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://service.agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-          <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "
-           <service>${SERVICE}</service>
-           <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-sleep 3
-echo "Sending register request to Cartridge agent service" >> $LOG
-curl -X POST -H "Content-Type: text/xml" -H "SOAPAction: urn:register" -d @/etc/agent/conf/request.xml -k --silent --output /dev/null "${CARTRIDGE_AGENT_EPR}"
-
-
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/get-launch-params.rb b/tools/cartridge-create/init-scripts/mysql/get-launch-params.rb
deleted file mode 100644
index c6368ca..0000000
--- a/tools/cartridge-create/init-scripts/mysql/get-launch-params.rb
+++ /dev/null
@@ -1,55 +0,0 @@
-#! /usr/bin/ruby
-#
-#
-# 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.
-#
-#
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/mysql
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/mysql b/tools/cartridge-create/init-scripts/mysql/mysql
deleted file mode 100644
index 063b14c..0000000
--- a/tools/cartridge-create/init-scripts/mysql/mysql
+++ /dev/null
@@ -1,46 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#
-#  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.
-#
-# ----------------------------------------------------------------------------
-
-INSTANCE=$1
-INSTANCE_USER=$2
-KEY=$3
-SOFTWARE=$4
-
-SCP="scp -i ./$KEY"
-SSH="ssh -i ./$KEY"
-
-$SCP ./wso2-cartridge-init.sh $INSTANCE_USER@$INSTANCE:
-$SCP ./mysql.ctrg $INSTANCE_USER@$INSTANCE:
-$SCP ./get-launch-params.rb $INSTANCE_USER@$INSTANCE:
-$SCP ./cc/ssl-cert-snakeoil.pem $INSTANCE_USER@$INSTANCE:
-$SCP ./cc/ssl-cert-snakeoil.key $INSTANCE_USER@$INSTANCE:
-$SCP ./phpMyAdmin-3.5.6-english.tar.xz $INSTANCE_USER@$INSTANCE:
-
-# Copy additional software
-arr=$(echo $SOFTWARE | tr ":" "\n")
-for x in $arr
-do
-   $SCP $x $INSTANCE_USER@$INSTANCE:
-done
-
-# Execute the cartridge creation process in the remoter server
-$SSH $INSTANCE_USER@$INSTANCE "sudo chmod 755 ./mysql.ctrg;sudo ./mysql.ctrg"

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/mysql.ctrg
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/mysql.ctrg b/tools/cartridge-create/init-scripts/mysql/mysql.ctrg
deleted file mode 100644
index 0e9b9cf..0000000
--- a/tools/cartridge-create/init-scripts/mysql/mysql.ctrg
+++ /dev/null
@@ -1,58 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#
-#  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.
-#
-# ----------------------------------------------------------------------------
-
-    mv ./wso2-cartridge-init.sh /opt/
-    mv ./get-launch-params.rb /opt/
-    mv ./ssl-cert-snakeoil.pem /etc/ssl/certs/
-    mv ./ssl-cert-snakeoil.key /etc/ssl/private/
-    mv ./*.tar.gz /opt/
-    mv ./*.zip /opt/
-#    tar -xf phpMyAdmin-3.5.6-english.tar.xz
-	apt-get update
-	# Next, all th packages.
-	
-	apt-get install -y \
-	nano zip mysql-server git \
-	xml-twig-tools phpmyadmin ruby
-#	apache2-mpm-prefork apache2-utils apache2.2-bin apache2.2-common dbconfig-common fontconfig-config libapache2-mod-php5 \
-#	libaprutil1-dbd-sqlite3 libaprutil1-ldap libcap2 libfontconfig1 libgd2-xpm libjpeg-turbo8 libjpeg8 libmcrypt4 \
-#	libt1-5 libxpm4 php5-cli php5-common php5-gd php5-mcrypt php5-mysql ssl-cert ttf-dejavu-core libboost-all-dev ruby
-
-	# Enable HTTPS:
-	a2enmod ssl
-	a2ensite default-ssl	
-	# Desable HTTP
-#	a2dissite default	
-
- 	# set mysql to listen to all network
-	cp /etc/mysql/my.cnf /etc/mysql/my.cnf.org
-	cat /etc/mysql/my.cnf.org | sed -e 's/127.0.0.1/0.0.0.0/' > $ROOTFS/etc/mysql/my.cnf	
-
-	# See http://blog.bodhizazen.net/linux/lxc-configure-ubuntu-lucid-containers/
-	# This requirement is confirmed on 10.04.1 LTS.  Within LXC, the
-	# upstart "startup" signal is sent, but not "network-interface", etc.
-    echo "#!/bin/bash -e
-mkdir -p /etc/agent/conf
-chmod 755 /opt/wso2-cartridge-init.sh
-/opt/wso2-cartridge-init.sh > /var/log/wso2-cartridge-init.log
-exit 0
-    " > /etc/rc.local

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/openstack/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/openstack/get-launch-params.rb b/tools/cartridge-create/init-scripts/mysql/openstack/get-launch-params.rb
deleted file mode 100644
index c6368ca..0000000
--- a/tools/cartridge-create/init-scripts/mysql/openstack/get-launch-params.rb
+++ /dev/null
@@ -1,55 +0,0 @@
-#! /usr/bin/ruby
-#
-#
-# 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.
-#
-#
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/var/lib/cloud/instance/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/openstack/healthcheck.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/openstack/healthcheck.sh b/tools/cartridge-create/init-scripts/mysql/openstack/healthcheck.sh
deleted file mode 100644
index 4194608..0000000
--- a/tools/cartridge-create/init-scripts/mysql/openstack/healthcheck.sh
+++ /dev/null
@@ -1,30 +0,0 @@
-#!/bin/bash
-#
-#
-# 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.
-#
-#
-
-var=`nc -z localhost 80; echo $?`;
-if [ $var -eq 0 ]
-then
-    echo "port 80 is available" > /dev/null 2>&1
-else
-    echo "port 80 is not available" > /dev/null 2>&1
-    /etc/init.d/apache2 restart
-fi

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/openstack/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/openstack/stratos-init.sh b/tools/cartridge-create/init-scripts/mysql/openstack/stratos-init.sh
deleted file mode 100755
index 29ae6f6..0000000
--- a/tools/cartridge-create/init-scripts/mysql/openstack/stratos-init.sh
+++ /dev/null
@@ -1,165 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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 script will be called from /etc/rc.local when the cartridge
-# instance is spawned. It will initiate all the tasks that needs to 
-# be run to bring the cartridge instance to operational state.
-
-export LOG=/var/log/stratos-cartridge.log
-instance_path=/var/lib/cloud/instance
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-RETRY_COUNT=30
-SLEEP_DURATION=3
-
-if [ ! -d ${instance_path}/payload ]; then
-
-    echo "creating payload dir ... " >> $LOG
-    mkdir ${instance_path}/payload
-    echo "payload dir created ... " >> $LOG
-    cp ${instance_path}/user-data.txt ${instance_path}/payload/user-data.zip
-    echo "payload copied  ... "  >> $LOG
-    unzip -d ${instance_path}/payload ${instance_path}/payload/user-data.zip
-    echo "unzippeddd..." >> $LOG
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /home/ubuntu/.bashrc
-    done
-    source /home/ubuntu/.bashrc
-    # Write a cronjob to execute wso2-cartridge-init.sh periodically until public ip is assigned
-    #crontab -l > ./mycron
-    #echo "*/${CRON_DURATION} * * * * /opt/wso2-cartridge-init.sh > /var/log/wso2-cartridge-init.log" >> ./mycron
-    #crontab ./mycron
-    #rm ./mycron
-
-fi
-
-
-echo ---------------------------- >> $LOG
-echo "getting public ip from metadata service" >> $LOG
-
-wget http://169.254.169.254/latest/meta-data/public-ipv4
-files="`cat public-ipv4`"
-if [[ -z ${files} ]]; then
-    echo "getting public ip" >> $LOG
-    for i in {1..30}
-    do
-      rm -f ./public-ipv4
-      wget http://169.254.169.254/latest/meta-data/public-ipv4
-      files="`cat public-ipv4`"
-      if [ -z $files ]; then
-          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-          sleep $SLEEP_DURATION
-      else
-          echo "Public ip assigned" >> $LOG
-          #crontab -r
-          break
-      fi
-    done
-
-    if [ -z $files ]; then
-      echo "Public ip is not yet assigned. So exit" >> $LOG
-      exit 0
-    fi
-    for x in $files
-    do
-        PUBLIC_IP="$x"
-    done
-
-
-else 
-   PUBLIC_IP="$files"
-   #crontab -r
-fi
-
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.pem /etc/ssl/certs/ssl-cert-snakeoil.pem
-cp -f ${instance_path}/payload/ssl-cert-snakeoil.key /etc/ssl/private/ssl-cert-snakeoil.key
-
-echo "Setting MySQL root password" >> $LOG
-if [[ (-n ${MYSQL_PASSWORD} ) ]]; then
-       mysqladmin -u root password "${MYSQL_PASSWORD}"
-       mysql -uroot -p${MYSQL_PASSWORD} -e "GRANT ALL PRIVILEGES ON *.* TO 'root'@'%'   IDENTIFIED BY '${MYSQL_PASSWORD}' WITH GRANT OPTION;flush privileges;"
-       echo "MySQL root password set" >> $LOG
-fi
-
-/etc/init.d/apache2 restart
-
-
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS} , BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-
-mkdir -p  /etc/agent/conf
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://service.agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-      <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "          <remoteHost>${PUBLIC_IP}</remoteHost>
-           <service>${SERVICE}</service>
-       <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-
-echo "Sending register request to Cartridge agent service" >> $LOG
-
-curl -X POST -H "Content-Type: text/xml" -H "SOAPAction: urn:register" -d @/etc/agent/conf/request.xml --silent --output /dev/null "$CARTRIDGE_AGENT_EPR" --insecure
-
-
-sleep 5
-
-/etc/init.d/apache2 restart
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/stratos.pem
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/stratos.pem b/tools/cartridge-create/init-scripts/mysql/stratos.pem
deleted file mode 100644
index abd2985..0000000
--- a/tools/cartridge-create/init-scripts/mysql/stratos.pem
+++ /dev/null
@@ -1,16 +0,0 @@
------BEGIN RSA PRIVATE KEY-----
-MIICXQIBAAKBgQDUExvnBa8QbdRPsyZFppsuO9pVG4Ve6cuo7cf4oXUiqnt5aYtC
-2h+1NoGwpxTyeqnMTw1UvyrGme3r/gwYBhtEwiSsXFTcPVqyA30wq1Gp+ghnj5NR
-sGEl4dVQYGl/+KbRDQQFmx6K31LAXc+EUrvUjCtXjuH5LrhRGgdIW44EeQIDAQAB
-AoGAMsJYHVVo71+6P1E7ydP0tH4y5cfuhicjTc2L3WCXrrJrV0YBxQB8Ml1XcTas
-dtURKwuIv036KQrSvXdS4bUkdULiDAfkx8I4IRK1TnT0SCHtoO/lOu3NweKI3QeW
-9DX8sdRZ1xOdarmLydJkyk/kLE8v8VbfPaxgxM8KiIMtwtkCQQD2sWf8+/FEOcW7
-11omtKAqIJW+mnARfSMUJspJgvVo+dQbQwdYhgH5z93Y5bH7bUmHZWNsnFYqcPOw
-Ns24QGtjAkEA3BNaqrvba4DEaX1o8Hp8o2NAindAjiKF0WP61l7TNCtgFt8hOiJF
-vTl0MOtPxIOlXrn/pIf0GiQHRykrt7tNcwJBAOd4fL820yIWJz/iiDdrIiGFI5yN
-onv2c9SztPkXBRgz2l6eHSVl0DLLZTjgBYmJ+QUvEARYCM2X4D/GnG63G0sCQEDF
-7YSc3/rnHmgSAkXtNyv7tW5LpRNwc8RqUdSweic7sP9qUuRCXBZSh7EyQPsM6CpW
-QjjRzvW2rvGx220rUqMCQQCiFgDaJvTl7iB9/G/Mzj8xIpABzcwq4AmneR2gEBxf
-38YHLAADdUymlG1hbs2J+yT6Tb5YGFFhDHdOTQ4FOAjl
------END RSA PRIVATE KEY-----
-

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/mysql/vcloud/stratos-init.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/mysql/vcloud/stratos-init.sh b/tools/cartridge-create/init-scripts/mysql/vcloud/stratos-init.sh
deleted file mode 100644
index 13649c2..0000000
--- a/tools/cartridge-create/init-scripts/mysql/vcloud/stratos-init.sh
+++ /dev/null
@@ -1,152 +0,0 @@
-#!/bin/bash
-
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-export LOG=/var/log/apache-cartridge.log
-instance_path=/var/lib/cloud/instance
-PUBLIC_IP=""
-KEY=`uuidgen`
-CRON_DURATION=1
-RETRY_COUNT=30
-SLEEP_DURATION=30
-
-#if [ ! -d ${instance_path}/payload ]; then
-#
-#    echo "creating payload dir ... " >> $LOG
-#    mkdir ${instance_path}/payload
-#    echo "payload dir created ... " >> $LOG
-#    cp ${instance_path}/user-data.txt ${instance_path}/payload/user-data.zip
-#    echo "payload copied  ... "  >> $LOG
-#    unzip -d ${instance_path}/payload ${instance_path}/payload/user-data.zip
-#    echo "unzippeddd..." >> $LOG
-#
-#    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-#    do
-#    echo "exporting to bashrc $i ... " >> $LOG
-#        echo "export" ${i} >> /home/ubuntu/.bashrc
-#    done
-#    source /home/ubuntu/.bashrc
-    # Write a cronjob to execute apache-openstack-init.sh periodically until public ip is assigned
-    #crontab -l > ./mycron
-    #echo "*/${CRON_DURATION} * * * * /opt/apache-openstack-init.sh > /var/log/apache-openstack-init.log" >> ./mycron
-    #crontab ./mycron
-    #rm ./mycron
-
-#fi
-
-    for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-    do
-    echo "exporting to bashrc $i ... " >> $LOG
-        echo "export" ${i} >> /root/.bashrc
-    done
-    source /root/.bashrc
-
-echo ---------------------------- >> $LOG
-echo "getting private IP" >> $LOG
-
-#wget http://169.254.169.254/latest/meta-data/public-ipv4
-#files="`cat public-ipv4`"
-#if [[ -z ${files} ]]; then
-#    echo "getting public ip" >> $LOG
-#    for i in {1..$RETRY_COUNT}
-#    do
-#      rm -f ./public-ipv4
-#      wget http://169.254.169.254/latest/meta-data/public-ipv4
-#      files="`cat public-ipv4`"
-#      if [ -z $files ]; then
-#          echo "Public ip is not yet assigned. Wait and continue for $i the time ..." >> $LOG
-#          sleep $SLEEP_DURATION
-#      else
-#          echo "Public ip assigned" >> $LOG
-          #crontab -r
-#          break
-#      fi
-#    done
-
-#    if [ -z $files ]; then
-#      echo "Public ip is not yet assigned. So shutdown the instance and exit" >> $LOG
-#      /sbin/poweroff
-#      exit 0
-#    fi
-#    for x in $files
-#    do
-#        PUBLIC_IP="$x"
-#    done
-
-
-#else 
-#   PUBLIC_IP="$files"
-   #crontab -r
-#fi
-PUBLIC_IP=`ifconfig | awk -F':' '/inet addr/&&!/127.0.0.1/{split($2,_," ");print _[1]}'`
-
-for i in `/usr/bin/ruby /opt/get-launch-params.rb`
-do
-    export ${i}
-done
-
-#PORTS=HTTP:8280:80|HTTPS:8243:443
-#MYSQL_HOST
-#MYSQL_USER
-#MYSQL_PASSWORD
-echo "Logging sys variables .. PUBLIC_IP:${PUBLIC_IP}, HOST_NAME:${HOST_NAME}, KEY:${KEY}, PORTS=${PORTS} , BAM:${BAM_IP}, GITREPO:${GIT_REPO}" >> $LOG
-
-
-echo "<soapenv:Envelope xmlns:soapenv=\"http://schemas.xmlsoap.org/soap/envelope/\" xmlns:agen=\"http://agent.cartridge.stratos.apache.org\">
-  <soapenv:Header/>
-  <soapenv:Body>
-     <agen:register>
-        <registrant> 
-           <alarmingLowerRate>${ALARMING_LOWER_RATE}</alarmingLowerRate>
-           <alarmingUpperRate>${ALARMING_UPPER_RATE}</alarmingUpperRate>
-           <hostName>${HOST_NAME}</hostName>
-           <key>${KEY}</key>
-          <maxInstanceCount>${MAX}</maxInstanceCount>
-	  <maxRequestsPerSecond>${MAX_REQUESTS_PER_SEC}</maxRequestsPerSecond>
-          <minInstanceCount>${MIN}</minInstanceCount> " > /etc/agent/conf/request.xml
-
-IFS='|' read -ra PT <<< "${PORTS}"
-for i in "${PT[@]}"; do
-IFS=':' read -ra PP <<< "$i"
-echo "          <portMappings>
-                        <primaryPort>${PP[1]}</primaryPort>
-                        <proxyPort>${PP[2]}</proxyPort>
-                        <type>${PP[0]}</type>
-                </portMappings>">> /etc/agent/conf/request.xml
-done
-
-echo "          <remoteHost>${PUBLIC_IP}</remoteHost>
-           <service>${SERVICE}</service>
-	   <remoteHost>${PUBLIC_IP}</remoteHost>
-           <roundsToAverage>${ROUNDS_TO_AVERAGE}</roundsToAverage>
-           <scaleDownFactor>${SCALE_DOWN_FACTOR}</scaleDownFactor>
-           <tenantRange>${TENANT_RANGE}</tenantRange>
-        </registrant>
-     </agen:register>
-  </soapenv:Body>
-</soapenv:Envelope>
-" >> /etc/agent/conf/request.xml
-
-
-echo "Sending register request to Cartridge agent service" >> $LOG
-
-curl -X POST -H "Content-Type: text/xml" -d @/etc/agent/conf/request.xml --silent --output /dev/null "$CARTRIDGE_AGENT_EPR"
-
-# ========================== // End of script ===========================================================

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/cartridge-data-publisher-1.0.2.zip
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/cartridge-data-publisher-1.0.2.zip b/tools/cartridge-create/init-scripts/php/cartridge-data-publisher-1.0.2.zip
deleted file mode 100644
index 08d8b1d..0000000
Binary files a/tools/cartridge-create/init-scripts/php/cartridge-data-publisher-1.0.2.zip and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/default
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/default b/tools/cartridge-create/init-scripts/php/default
deleted file mode 100644
index cbb5406..0000000
--- a/tools/cartridge-create/init-scripts/php/default
+++ /dev/null
@@ -1,59 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-
-<VirtualHost *:80>
-	ServerAdmin webmaster@localhost
-
-	DocumentRoot /var/www/www
-	Alias /simplesaml /var/www/simplesamlphp/www
-	<Directory />
-		Options FollowSymLinks
-		AllowOverride All
-	</Directory>
-	<Directory /var/www/>
-		Options Indexes FollowSymLinks MultiViews
-		AllowOverride All
-		Order allow,deny
-		allow from all
-	</Directory>
-
-	ScriptAlias /cgi-bin/ /usr/lib/cgi-bin/
-	<Directory "/usr/lib/cgi-bin">
-		AllowOverride None
-		Options +ExecCGI -MultiViews +SymLinksIfOwnerMatch
-		Order allow,deny
-		Allow from all
-	</Directory>
-
-	ErrorLog ${APACHE_LOG_DIR}/error.log
-
-	# Possible values include: debug, info, notice, warn, error, crit,
-	# alert, emerg.
-	LogLevel warn
-
-	CustomLog ${APACHE_LOG_DIR}/access.log combined
-
-    Alias /doc/ "/usr/share/doc/"
-    <Directory "/usr/share/doc/">
-        Options Indexes MultiViews FollowSymLinks
-        AllowOverride None
-        Order deny,allow
-        Deny from all
-        Allow from 127.0.0.0/255.0.0.0 ::1/128
-    </Directory>
-
-</VirtualHost>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/default-ssl
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/default-ssl b/tools/cartridge-create/init-scripts/php/default-ssl
deleted file mode 100644
index e48d3ea..0000000
--- a/tools/cartridge-create/init-scripts/php/default-ssl
+++ /dev/null
@@ -1,190 +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.
-
-<IfModule mod_ssl.c>
-<VirtualHost _default_:443>
-	ServerAdmin webmaster@localhost
-
-	DocumentRoot /var/www/www
-	Alias /simplesaml /var/www/simplesamlphp/www
-	<Directory />
-		Options FollowSymLinks
-		AllowOverride All
-	</Directory>
-	<Directory /var/www/>
-		Options Indexes FollowSymLinks MultiViews
-		AllowOverride All
-		Order allow,deny
-		allow from all
-	</Directory>
-
-	ScriptAlias /cgi-bin/ /usr/lib/cgi-bin/
-	<Directory "/usr/lib/cgi-bin">
-		AllowOverride None
-		Options +ExecCGI -MultiViews +SymLinksIfOwnerMatch
-		Order allow,deny
-		Allow from all
-	</Directory>
-
-	ErrorLog ${APACHE_LOG_DIR}/error.log
-
-	# Possible values include: debug, info, notice, warn, error, crit,
-	# alert, emerg.
-	LogLevel warn
-
-	CustomLog ${APACHE_LOG_DIR}/ssl_access.log combined
-
-	Alias /doc/ "/usr/share/doc/"
-	<Directory "/usr/share/doc/">
-		Options Indexes MultiViews FollowSymLinks
-		AllowOverride None
-		Order deny,allow
-		Deny from all
-		Allow from 127.0.0.0/255.0.0.0 ::1/128
-	</Directory>
-
-	#   SSL Engine Switch:
-	#   Enable/Disable SSL for this virtual host.
-	SSLEngine on
-
-	#   A self-signed (snakeoil) certificate can be created by installing
-	#   the ssl-cert package. See
-	#   /usr/share/doc/apache2.2-common/README.Debian.gz for more info.
-	#   If both key and certificate are stored in the same file, only the
-	#   SSLCertificateFile directive is needed.
-	SSLCertificateFile    /etc/ssl/certs/ssl-cert-snakeoil.pem
-	SSLCertificateKeyFile /etc/ssl/private/ssl-cert-snakeoil.key
-
-	#   Server Certificate Chain:
-	#   Point SSLCertificateChainFile at a file containing the
-	#   concatenation of PEM encoded CA certificates which form the
-	#   certificate chain for the server certificate. Alternatively
-	#   the referenced file can be the same as SSLCertificateFile
-	#   when the CA certificates are directly appended to the server
-	#   certificate for convinience.
-	#SSLCertificateChainFile /etc/apache2/ssl.crt/server-ca.crt
-
-	#   Certificate Authority (CA):
-	#   Set the CA certificate verification path where to find CA
-	#   certificates for client authentication or alternatively one
-	#   huge file containing all of them (file must be PEM encoded)
-	#   Note: Inside SSLCACertificatePath you need hash symlinks
-	#         to point to the certificate files. Use the provided
-	#         Makefile to update the hash symlinks after changes.
-	#SSLCACertificatePath /etc/ssl/certs/
-	#SSLCACertificateFile /etc/apache2/ssl.crt/ca-bundle.crt
-
-	#   Certificate Revocation Lists (CRL):
-	#   Set the CA revocation path where to find CA CRLs for client
-	#   authentication or alternatively one huge file containing all
-	#   of them (file must be PEM encoded)
-	#   Note: Inside SSLCARevocationPath you need hash symlinks
-	#         to point to the certificate files. Use the provided
-	#         Makefile to update the hash symlinks after changes.
-	#SSLCARevocationPath /etc/apache2/ssl.crl/
-	#SSLCARevocationFile /etc/apache2/ssl.crl/ca-bundle.crl
-
-	#   Client Authentication (Type):
-	#   Client certificate verification type and depth.  Types are
-	#   none, optional, require and optional_no_ca.  Depth is a
-	#   number which specifies how deeply to verify the certificate
-	#   issuer chain before deciding the certificate is not valid.
-	#SSLVerifyClient require
-	#SSLVerifyDepth  10
-
-	#   Access Control:
-	#   With SSLRequire you can do per-directory access control based
-	#   on arbitrary complex boolean expressions containing server
-	#   variable checks and other lookup directives.  The syntax is a
-	#   mixture between C and Perl.  See the mod_ssl documentation
-	#   for more details.
-	#<Location />
-	#SSLRequire (    %{SSL_CIPHER} !~ m/^(EXP|NULL)/ \
-	#            and %{SSL_CLIENT_S_DN_O} eq "Snake Oil, Ltd." \
-	#            and %{SSL_CLIENT_S_DN_OU} in {"Staff", "CA", "Dev"} \
-	#            and %{TIME_WDAY} >= 1 and %{TIME_WDAY} <= 5 \
-	#            and %{TIME_HOUR} >= 8 and %{TIME_HOUR} <= 20       ) \
-	#           or %{REMOTE_ADDR} =~ m/^192\.76\.162\.[0-9]+$/
-	#</Location>
-
-	#   SSL Engine Options:
-	#   Set various options for the SSL engine.
-	#   o FakeBasicAuth:
-	#     Translate the client X.509 into a Basic Authorisation.  This means that
-	#     the standard Auth/DBMAuth methods can be used for access control.  The
-	#     user name is the `one line' version of the client's X.509 certificate.
-	#     Note that no password is obtained from the user. Every entry in the user
-	#     file needs this password: `xxj31ZMTZzkVA'.
-	#   o ExportCertData:
-	#     This exports two additional environment variables: SSL_CLIENT_CERT and
-	#     SSL_SERVER_CERT. These contain the PEM-encoded certificates of the
-	#     server (always existing) and the client (only existing when client
-	#     authentication is used). This can be used to import the certificates
-	#     into CGI scripts.
-	#   o StdEnvVars:
-	#     This exports the standard SSL/TLS related `SSL_*' environment variables.
-	#     Per default this exportation is switched off for performance reasons,
-	#     because the extraction step is an expensive operation and is usually
-	#     useless for serving static content. So one usually enables the
-	#     exportation for CGI and SSI requests only.
-	#   o StrictRequire:
-	#     This denies access when "SSLRequireSSL" or "SSLRequire" applied even
-	#     under a "Satisfy any" situation, i.e. when it applies access is denied
-	#     and no other module can change it.
-	#   o OptRenegotiate:
-	#     This enables optimized SSL connection renegotiation handling when SSL
-	#     directives are used in per-directory context.
-	#SSLOptions +FakeBasicAuth +ExportCertData +StrictRequire
-	<FilesMatch "\.(cgi|shtml|phtml|php)$">
-		SSLOptions +StdEnvVars
-	</FilesMatch>
-	<Directory /usr/lib/cgi-bin>
-		SSLOptions +StdEnvVars
-	</Directory>
-
-	#   SSL Protocol Adjustments:
-	#   The safe and default but still SSL/TLS standard compliant shutdown
-	#   approach is that mod_ssl sends the close notify alert but doesn't wait for
-	#   the close notify alert from client. When you need a different shutdown
-	#   approach you can use one of the following variables:
-	#   o ssl-unclean-shutdown:
-	#     This forces an unclean shutdown when the connection is closed, i.e. no
-	#     SSL close notify alert is send or allowed to received.  This violates
-	#     the SSL/TLS standard but is needed for some brain-dead browsers. Use
-	#     this when you receive I/O errors because of the standard approach where
-	#     mod_ssl sends the close notify alert.
-	#   o ssl-accurate-shutdown:
-	#     This forces an accurate shutdown when the connection is closed, i.e. a
-	#     SSL close notify alert is send and mod_ssl waits for the close notify
-	#     alert of the client. This is 100% SSL/TLS standard compliant, but in
-	#     practice often causes hanging connections with brain-dead browsers. Use
-	#     this only for browsers where you know that their SSL implementation
-	#     works correctly.
-	#   Notice: Most problems of broken clients are also related to the HTTP
-	#   keep-alive facility, so you usually additionally want to disable
-	#   keep-alive for those clients, too. Use variable "nokeepalive" for this.
-	#   Similarly, one has to force some clients to use HTTP/1.0 to workaround
-	#   their broken HTTP/1.1 implementation. Use variables "downgrade-1.0" and
-	#   "force-response-1.0" for this.
-	BrowserMatch "MSIE [2-6]" \
-		nokeepalive ssl-unclean-shutdown \
-		downgrade-1.0 force-response-1.0
-	# MSIE 7 and newer should be able to use keepalive
-	BrowserMatch "MSIE [17-9]" ssl-unclean-shutdown
-
-</VirtualHost>
-</IfModule>

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/ec2/get-launch-params.rb
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/ec2/get-launch-params.rb b/tools/cartridge-create/init-scripts/php/ec2/get-launch-params.rb
deleted file mode 100644
index baab411..0000000
--- a/tools/cartridge-create/init-scripts/php/ec2/get-launch-params.rb
+++ /dev/null
@@ -1,54 +0,0 @@
-#! /usr/bin/ruby
-
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-
-### get-launch-params.rb
-
-# The following script obtains the launch parameters from 
-# the file /tmp/payload/launch-params, then parses out the 
-# parameters for this instance by using the launch index
-# of this particular EC2 instance.
-#
-# Pass the command the -e flag to output the instance 
-# parameters as exports of shell variables. Any other 
-# arguments are ignored.
-
-def get_launch_params(launch_params_file)
-  IO.readlines launch_params_file
-end
-
-export_stmt = ""
-
-launch_params = get_launch_params(
-  "/opt/apache-stratos-cartridge-agent/payload/launch-params")
-
-if launch_params.length > 0
-  instance_params_str = launch_params[0]
-
-  instance_params = instance_params_str.split(',')
-
-  export_stmt = "export " if ARGV.length > 0 && ARGV.include?("-e")
-
-  instance_params.each { |param|
-    puts export_stmt + param
-  }
-
-end

http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/89983ecc/tools/cartridge-create/init-scripts/php/ec2/healthcheck.sh
----------------------------------------------------------------------
diff --git a/tools/cartridge-create/init-scripts/php/ec2/healthcheck.sh b/tools/cartridge-create/init-scripts/php/ec2/healthcheck.sh
deleted file mode 100644
index eb06412..0000000
--- a/tools/cartridge-create/init-scripts/php/ec2/healthcheck.sh
+++ /dev/null
@@ -1,32 +0,0 @@
-#!/bin/bash
-# ----------------------------------------------------------------------------
-#  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.
-
-# ----------------------------------------------------------------------------
-
-
-var=`nc -z localhost 80; echo $?`;
-if [ $var -eq 0 ]
-then
-    echo "port 80 is available" > /dev/null 2>&1
-else
-    echo "port 80 is not available" > /dev/null 2>&1
-    /etc/init.d/apache2 restart
-fi
-
-


[2/8] git commit: duplicate log entries in SM - STRATOS-460

Posted by ud...@apache.org.
duplicate log entries in SM  - STRATOS-460


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

Branch: refs/heads/master
Commit: 552613f1821b12063d4004de732d0d69c505f44b
Parents: 141bcef
Author: Udara Liyanage <ud...@wso2.com>
Authored: Fri Mar 28 14:49:49 2014 -0400
Committer: Udara Liyanage <ud...@wso2.com>
Committed: Fri Mar 28 14:49:49 2014 -0400

----------------------------------------------------------------------
 products/stratos-manager/conf/log4j.properties | 6 +++---
 1 file changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/552613f1/products/stratos-manager/conf/log4j.properties
----------------------------------------------------------------------
diff --git a/products/stratos-manager/conf/log4j.properties b/products/stratos-manager/conf/log4j.properties
index dd6bcb9..da8fa3c 100755
--- a/products/stratos-manager/conf/log4j.properties
+++ b/products/stratos-manager/conf/log4j.properties
@@ -26,9 +26,9 @@
 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, CARBON_LOGFILE, CARBON_MEMORY
-log4j.logger.org.apache.axis2.clustering=INFO, CARBON_CONSOLE, CARBON_LOGFILE
-log4j.logger.org.apache=INFO, CARBON_LOGFILE, CARBON_MEMORY
+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


[3/8] git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos

Posted by ud...@apache.org.
Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos


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

Branch: refs/heads/master
Commit: c4d5b1695de229c61cab8c993bfc0210ab2ec693
Parents: 552613f 2651d6a
Author: Udara Liyanage <ud...@wso2.com>
Authored: Fri Mar 28 16:59:52 2014 -0400
Committer: Udara Liyanage <ud...@wso2.com>
Committed: Fri Mar 28 16:59:52 2014 -0400

----------------------------------------------------------------------
 .../behaviour/CartridgeMgtBehaviour.java        | 21 +++++++---
 .../client/CloudControllerServiceClient.java    |  4 ++
 .../category/DefaultLoadBalancerCategory.java   | 43 +++++++++++++-------
 .../lb/category/LoadBalancerCategory.java       | 17 +++-----
 4 files changed, 52 insertions(+), 33 deletions(-)
----------------------------------------------------------------------



[8/8] git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos

Posted by ud...@apache.org.
Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-stratos

Conflicts:
	tools/puppet3/manifests/nodes.pp


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

Branch: refs/heads/master
Commit: 15e535332841582382b3be3484e051d1870f8775
Parents: 89983ec 348fc62
Author: Udara Liyanage <ud...@wso2.com>
Authored: Mon Mar 31 17:21:00 2014 -0400
Committer: Udara Liyanage <ud...@wso2.com>
Committed: Mon Mar 31 17:21:00 2014 -0400

----------------------------------------------------------------------
 tools/puppet3-agent/config.sh    | 6 +++---
 tools/puppet3/manifests/nodes.pp | 6 ++++++
 2 files changed, 9 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-stratos/blob/15e53533/tools/puppet3/manifests/nodes.pp
----------------------------------------------------------------------
diff --cc tools/puppet3/manifests/nodes.pp
index 23e6141,36e6d2b..cf7cf73
--- a/tools/puppet3/manifests/nodes.pp
+++ b/tools/puppet3/manifests/nodes.pp
@@@ -117,3 -117,39 +117,9 @@@ node /wordpress/ inherits base 
    class {'mysql':}
  
  }
+ 
+ # default (base) cartridge node
+ node /default/ inherits base {
+   require java
+   class {'agent':}
+ }
 -
 -# stratos components related nodes
 -# not supported in alpha version.
 -node 'autoscaler.wso2.com' inherits base {
 -  require java
 -  class {'autoscaler': maintenance_mode => 'norestart',}
 -}
 -
 -node 'cc.wso2.com' inherits base {
 -  require java
 -  class {'cc': maintenance_mode   => 'norestart',}
 -}
 -
 -node 'cep.wso2.com' inherits base {
 -  require java
 -  class {'cep': maintenance_mode   => 'norestart',}
 -}
 -
 -
 -node 'mb.wso2.com' inherits base {
 -  require java
 -  class {'messagebroker': maintenance_mode   => 'norestart',}
 -}
 -
 -node 'sc.wso2.com' inherits base {
 -  require java
 -  class {'manager': maintenance_mode   => 'norestart',}
 -}
 -
 -