You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by la...@apache.org on 2014/03/31 16:32:42 UTC

git commit: removing duplicated airavata-server.properties, AIRAVATA-1004

Repository: airavata
Updated Branches:
  refs/heads/master 80cbc3e88 -> b47a807b4


removing duplicated airavata-server.properties, AIRAVATA-1004


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

Branch: refs/heads/master
Commit: b47a807b4ca0a2bdf983f4933f4929cb561f8840
Parents: 80cbc3e
Author: lahiru <la...@apache.org>
Authored: Mon Mar 31 10:32:33 2014 -0400
Committer: lahiru <la...@apache.org>
Committed: Mon Mar 31 10:32:33 2014 -0400

----------------------------------------------------------------------
 .../main/resources/airavata-server.properties   |  56 ----
 .../impl/PropertiesBasedServiceImplTest.java    | 167 -----------
 .../main/resources/airavata-server.properties   | 276 -------------------
 .../main/resources/airavata-server.properties   | 274 ------------------
 .../main/resources/airavata-server.properties   | 236 ----------------
 5 files changed, 1009 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/airavata/blob/b47a807b/airavata-api/airavata-api-server/src/main/resources/airavata-server.properties
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-api-server/src/main/resources/airavata-server.properties b/airavata-api/airavata-api-server/src/main/resources/airavata-server.properties
deleted file mode 100644
index f6caac7..0000000
--- a/airavata-api/airavata-api-server/src/main/resources/airavata-server.properties
+++ /dev/null
@@ -1,56 +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.
-#
-
-###########################################################################
-#
-#  Temporarily adding the API configuration to this property file. These
-#    needs to be merged with rest of airavata-server.properties
-#
-###########################################################################
-
-api.server.port = 8930
-
-#This property will enable https and stops http, during the url registration, https urls will be stored and
-# http urls will not get registered, because currently airavata supports only one url for each service
-#enable.https=false
-#system properties used by services to register service URLs
-system.gateway=default
-system.user=admin
-system.password=admin
-
-###########################################################################
-# Airavata Registry Configuration
-###########################################################################
-#for derby [AiravataJPARegistry]
-registry.jdbc.driver=org.apache.derby.jdbc.ClientDriver
-registry.jdbc.url=jdbc:derby://localhost:1527/persistent_data;create=true;user=airavata;password=airavata
-# MySql database configuration
-#registry.jdbc.driver=com.mysql.jdbc.Driver
-#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
-registry.jdbc.user=airavata
-registry.jdbc.password=airavata
-start.derby.server.mode=true
-validationQuery=SELECT 1 from CONFIGURATION
-jpa.connection.properties=MaxActive=10,MaxIdle=5,MinIdle=2,MaxWait=60000,testWhileIdle=true,testOnBorrow=true
-# Properties to setup registry service
-default.registry.user=admin
-default.registry.password=admin
-default.registry.password.hash.method=SHA
-default.registry.gateway=default

http://git-wip-us.apache.org/repos/asf/airavata/blob/b47a807b/modules/gfac/gfac-core/src/test/java/org/apache/airavata/core/gfac/services/impl/PropertiesBasedServiceImplTest.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/test/java/org/apache/airavata/core/gfac/services/impl/PropertiesBasedServiceImplTest.java b/modules/gfac/gfac-core/src/test/java/org/apache/airavata/core/gfac/services/impl/PropertiesBasedServiceImplTest.java
deleted file mode 100644
index 2292343..0000000
--- a/modules/gfac/gfac-core/src/test/java/org/apache/airavata/core/gfac/services/impl/PropertiesBasedServiceImplTest.java
+++ /dev/null
@@ -1,167 +0,0 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-package org.apache.airavata.core.gfac.services.impl;
-
-import static org.junit.Assert.fail;
-
-public class PropertiesBasedServiceImplTest {
-//	@Before
-//	public void setUp() throws Exception {
-//		/*
-//		 * Create database
-//		 */
-//        Map<String,String> config = new HashMap<String,String>();
-//            config.put("org.apache.jackrabbit.repository.home","target");
-//		AiravataJCRRegistry jcrRegistry = new AiravataJCRRegistry(null,
-//				"org.apache.jackrabbit.core.RepositoryFactoryImpl", "admin",
-//				"admin", config);
-//
-//		/*
-//		 * Host
-//		 */
-//		HostDescription host = new HostDescription();
-//		host.getType().setHostName("localhost");
-//		host.getType().setHostAddress("localhost");
-//
-//		/*
-//		 * App
-//		 */
-//		ApplicationDeploymentDescription appDesc = new ApplicationDeploymentDescription();
-//		ApplicationDeploymentDescriptionType app = appDesc.getType();
-//		ApplicationName name = ApplicationName.Factory.newInstance();
-//		name.setStringValue("EchoLocal");
-//		app.setApplicationName(name);
-//
-//		/*
-//		 * Use bat file if it is compiled on Windows
-//		 */
-//		if(SystemUtils.IS_OS_WINDOWS){
-//			URL url = this.getClass().getClassLoader().getResource("echo.bat");
-//			app.setExecutableLocation(url.getFile());
-//		}else{
-//			//for unix and Mac
-//			app.setExecutableLocation("/bin/echo");
-//		}
-//
-//		/*
-//		 * Default tmp location
-//		 */
-//		String tempDir = System.getProperty("java.io.tmpdir");
-//		if(tempDir == null){
-//			tempDir = "/tmp";
-//		}
-//
-//		app.setScratchWorkingDirectory(tempDir);
-//		app.setStaticWorkingDirectory(tempDir);
-//		app.setInputDataDirectory(tempDir + File.separator + "input");
-//		app.setOutputDataDirectory(tempDir + File.separator + "output");
-//		app.setStandardOutput(tempDir + File.separator + "echo.stdout");
-//		app.setStandardError(tempDir + File.separator + "echo.stdout");
-//
-//		/*
-//		 * Service
-//		 */
-//		ServiceDescription serv = new ServiceDescription();
-//		serv.getType().setName("SimpleEcho");
-//
-//		List<InputParameterType> inputList = new ArrayList<InputParameterType>();
-//		InputParameterType input = InputParameterType.Factory.newInstance();
-//		input.setParameterName("echo_input");
-//		input.setParameterType(StringParameterType.Factory.newInstance());
-//		inputList.add(input);
-//		InputParameterType[] inputParamList = inputList.toArray(new InputParameterType[inputList
-//				.size()]);
-//
-//		List<OutputParameterType> outputList = new ArrayList<OutputParameterType>();
-//		OutputParameterType output = OutputParameterType.Factory.newInstance();
-//		output.setParameterName("echo_output");
-//		output.setParameterType(StringParameterType.Factory.newInstance());
-//		outputList.add(output);
-//		OutputParameterType[] outputParamList = outputList
-//				.toArray(new OutputParameterType[outputList.size()]);
-//
-//		serv.getType().setInputParametersArray(inputParamList);
-//		serv.getType().setOutputParametersArray(outputParamList);
-//
-//		/*
-//		 * Save to registry
-//		 */
-//		jcrRegistry.saveHostDescription(host);
-//		jcrRegistry.saveApplicationDescription(serv.getType().getName(), host
-//				.getType().getHostName(), appDesc);
-//		jcrRegistry.saveServiceDescription(serv);
-//		jcrRegistry.deployServiceOnHost(serv.getType().getName(), host
-//				.getType().getHostName());
-//	}
-//
-//	@Test
-//	public void testExecute() {
-//		try {
-//
-//			DefaultInvocationContext ct = new DefaultInvocationContext();
-//			DefaultExecutionContext ec = new DefaultExecutionContext();
-//			ec.addNotifiable(new LoggingNotification());
-//			ct.setExecutionContext(ec);
-//             Map<String,String> config = new HashMap<String,String>();
-//            config.put("org.apache.jackrabbit.repository.home","target");
-//		    AiravataJCRRegistry jcrRegistry = new AiravataJCRRegistry(null,
-//				"org.apache.jackrabbit.core.RepositoryFactoryImpl", "admin",
-//				"admin", config);
-//
-//            ec.setRegistryService(jcrRegistry);
-//			ct.setServiceName("SimpleEcho");
-//
-//			/*
-//			 * Input
-//			 */
-//			ParameterContextImpl input = new ParameterContextImpl();
-//			ActualParameter echo_input = new ActualParameter();
-//			((StringParameterType)echo_input.getType()).setValue("echo_output=hello");
-//			input.add("echo_input", echo_input);
-//
-//			/*
-//			 * Output
-//			 */
-//			ParameterContextImpl output = new ParameterContextImpl();
-//			ActualParameter echo_output = new ActualParameter();
-//			output.add("echo_output", echo_output);
-//
-//			// parameter
-//			ct.setInput(input);
-//			ct.setOutput(output);
-//
-//			PropertiesBasedServiceImpl service = new PropertiesBasedServiceImpl();
-//			service.init();
-//			service.execute(ct);
-//
-//			Assert.assertNotNull(ct.getOutput());
-//			Assert.assertNotNull(ct.getOutput().getValue("echo_output"));
-//			Assert.assertEquals("hello", ((StringParameterType)((ActualParameter)ct.getOutput().getValue("echo_output")).getType()).getValue());
-//            jcrRegistry.getSession().logout();
-//            IOUtil.deleteDirectory(new File((new File(".")).getAbsolutePath() + File.separator + "target"));
-//
-//		} catch (Exception e) {
-//			e.printStackTrace();
-//			fail("ERROR");
-//		}
-//	}
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/b47a807b/modules/orchestrator/airavata-orchestrator-service/src/main/resources/airavata-server.properties
----------------------------------------------------------------------
diff --git a/modules/orchestrator/airavata-orchestrator-service/src/main/resources/airavata-server.properties b/modules/orchestrator/airavata-orchestrator-service/src/main/resources/airavata-server.properties
deleted file mode 100644
index 672c7c9..0000000
--- a/modules/orchestrator/airavata-orchestrator-service/src/main/resources/airavata-server.properties
+++ /dev/null
@@ -1,276 +0,0 @@
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-###########################################################################
-#
-#  This properties file provides configuration for all Airavata Services:
-#  Registry, Workflow Interpreter, GFac, Message Broker, Message Box
-#
-###########################################################################
-
-###########################################################################
-# Airavata Embedded-Tomcat Server Configuration
-###########################################################################
-# By default, tomcat runs on port 80. If the port is changed, it will be
-#  have to be specified with port properties. This will be picked up by
-#  the registry service to register the service end-points.
-
-port=8080
-
-# Axis2 server automatically picks up IP address from axis configuration,
-#  but some DHCP enables machines do not report correct ip addresses,
-#  in which case, the IP address can be manually specified.
-
-#ip=192.2.33.12
-
-
-#This property will enable https and stops http, during the url registration, https urls will be stored and
-# http urls will not get registered, because currently airavata supports only one url for each service
-#enable.https=false
-#system properties used by services to register service URLs
-system.gateway=default
-system.user=admin
-system.password=admin
-airavata.server.url=http://localhost:8080/airavata/services/registry
-
-###########################################################################
-# Airavata Registry Configuration
-###########################################################################
-#for derby [AiravataJPARegistry]
-registry.jdbc.driver=org.apache.derby.jdbc.ClientDriver
-registry.jdbc.url=jdbc:derby://localhost:1527/persistent_data;create=true;user=airavata;password=airavata
-# MySql database configuration
-#registry.jdbc.driver=com.mysql.jdbc.Driver
-#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
-registry.jdbc.user=airavata
-registry.jdbc.password=airavata
-start.derby.server.mode=true
-validationQuery=SELECT 1 from CONFIGURATION
-jpa.connection.properties=MaxActive=10,MaxIdle=5,MinIdle=2,MaxWait=60000,testWhileIdle=true,testOnBorrow=true
-# Properties to setup registry service
-default.registry.user=admin
-default.registry.password=admin
-default.registry.password.hash.method=SHA
-default.registry.gateway=default
-#for rest [RegistryClient]
-#registry.jdbc.url=http://localhost:9080/airavata-services
-
-#user defined registry accessor classes
-#class.provenance.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.configuration.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.descriptor.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.project.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.user.workflow.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.published.workflow.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-
-############################################################    ###############
-# Airavata Workflow Interpreter Configurations
-###########################################################################
-
-runInThread=true
-provenance=true
-provenanceWriterThreadPoolSize=20
-gfac.embedded=true
-
-#
-# Security Configuration used by Airavata Generic Factory Service
-#  to interact with Computational Resources.
-#
-
-###########################################################################
-# Airavata GFac MyProxy GSI credentials to access Grid Resources.
-###########################################################################
-
-myproxy.server=myproxy.teragrid.org
-myproxy.user=ogce
-myproxy.pass=
-myproxy.life=3600
-# XSEDE Trusted certificates can be downloaded from https://software.xsede.org/security/xsede-certs.tar.gz
-trusted.cert.location=/Users/lahirugunathilake/Downloads/certificates
-# SSH PKI key pair or ssh password can be used SSH based authentication is used.
-# if user specify both password authentication gets the higher preference
-
-################# ---------- For ssh key pair authentication ------------------- ################
-#public.ssh.key=/path to public key for ssh
-#ssh.username=username for ssh connection
-#private.ssh.key=/path to private key file for ssh
-#ssh.keypass=passphrase for the private key
-
-
-################# ---------- For ssh key pair authentication ------------------- ################
-#ssh.username=username for ssh connection
-#ssh.password=Password for ssh connection
-
-
-
-###########################################################################
-# Airavata Message Broker Basic Configurations.
-#  the Advanced section provides detailed custom configuration properties.
-###########################################################################
-
-# Default derby database configuration
-broker.jdbc.driver=org.apache.derby.jdbc.EmbeddedDriver
-broker.jdbc.url=jdbc:derby:wsmg;create=true;user=airavata;password=airavata
-
-# Note: This database will only be used  if 'broker.storage.type=persistent'
-#       is set in advanced properties below.
-# MySql database configuration
-#broker.jdbc.driver=com.mysql.jdbc.Driver
-#broker.jdbc.url=jdbc:mysql://localhost:3306/wsmg?user=airavata&password=airavata
-
-###########################################################################
-# Airavata Message Box Basic Configurations,
-#  the Advanced section provides detailed custom configuration properties.
-###########################################################################
-
-# Default derby database
-msgBox.jdbc.driver=org.apache.derby.jdbc.EmbeddedDriver
-msgBox.jdbc.url=jdbc:derby:wsmg;create=true;user=airavata;password=airavata
-
-# MySql database configuration
-#msgBox.jdbc.driver=com.mysql.jdbc.Driver
-#msgBox.jdbc.url=jdbc:mysql://localhost:3306/wsmg?user=airavata&password=airavata
-
-###########################################################################
-# Advance configuration to change service implementations
-###########################################################################
-
-#Update the server context root path if airavata server is deployed under a different context root other than axis2
-server.context-root=airavata-server
-
-#
-# Class which implemented HostScheduler interface. It will determine the which host to submit the request
-#
-host.scheduler=org.apache.airavata.gfac.scheduler.impl.SimpleHostScheduler
-
-#
-# Data Service Plugins classes
-#
-datachain.classes= org.apache.airavata.core.gfac.extension.data.RegistryDataService
-
-#
-# Pre execution Plugins classes. For example, GridFTP Input Staging
-#
-prechain.classes= org.apache.airavata.core.gfac.extension.pre.GridFtpInputStaging
-prechain.classes= org.apache.airavata.core.gfac.extension.pre.HttpInputStaging
-
-#
-# Post execution Plugins classes. For example, GridFTP Output Staging
-#
-postchain.classes= org.apache.airavata.core.gfac.extension.post.GridFtpOutputStaging
-postchain.classes= org.apache.airavata.core.gfac.extension.post.OutputRegister
-
-#
-# Advanced Message Broker Configurations
-#
-
-#socket time out in milliseconds for sending messages. (defaults is 20000)
-broker.socket.timeout=60000
-
-broker.storage.type=persistent
-#broker.storage.type=memory
-
-#specifies wether delivery component should be started or not.
-broker.start.delivery.thread=true
-
-#fixed thread pool based delivery
-#broker.delivery.method=pcrew
-
-#dynamic thread pool based delivery
-#broker.delivery.method=parallel
-
-#single thread delivery
-broker.delivery.method=serial
-
-#number of message delivery failures before a url become black listed (default is 2)
-#broker.msg.delivery.retries=2
-
-#time period (in seconds) a url will be kept blacklisted (default is 5 seconds)
-#consumer.expiration.time.gap=5
-
-#maximum number of messages to be send to a one consumer/url at time.
-#applicable if 'broker.delivery.method' is 'pcrew' . (default is 10)
-
-#sending.batch.size=10
-
-#size of the thread pool. only applicable if 'broker.delivery.method' is 'pcrew'. (default is 4)
-#sending.thread.pool.size=4
-
-#
-# Advanced Message Box Configurations
-#
-msgBox.usedatabase=true
-messagePreservationDays=2
-messagePreservationHours=0
-messagePreservationMinutes=0
-messagePerservationIntervalDays=0
-messagePerservationIntervalHours=1
-messagePerservationIntervalMinutes=0
-
-###---------------------------REGISTRY API IMPLEMENTATION---------------------------###
-
-class.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.registry.accessor=org.apache.airavata.rest.client.RegistryClient
-
-###########################################################################
-# AMQP Notification Configuration
-###########################################################################
-amqp.notification.enable=1
-
-amqp.broker.host=localhost
-amqp.broker.port=5672
-amqp.broker.username=guest
-amqp.broker.password=guest
-
-amqp.sender=org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPSenderImpl
-amqp.topic.sender=org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPTopicSenderImpl
-amqp.broadcast.sender=org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPBroadcastSenderImpl
-
-###---------------------------Computational Middleware Configurations---------------------------###
-
-#enable.application.job.status.history=true
-#http://localhost:8080/axis2/services/RegistryService?wsdl
-registry.service.wsdl=http://localhost:${port}/${server.context-root}/services/RegistryService?wsdl
-
-# If false, disables two phase commit when submitting jobs
-TwoPhase=true
-
-
-###---------------------------Monitoring module Configurations---------------------------###
-#This will be the primary monitoring tool which runs in airavata, in future there will be multiple monitoring
-#mechanisms and one would be able to start a monitor
-primaryMonitor=org.apache.airavata.job.monitor.impl.pull.qstat.QstatMonitor
-#We do not support a secondaray monitoring at this point or host specific monitoring
-secondaryMonitor=org.apache.airavata.job.monitor.impl.push.amqp.AMQPMonitor
-#This is the amqp related configuration and this lists down the Rabbitmq host, this is an xsede specific configuration
-amqp.hosts=info1.dyn.teragrid.org,info2.dyn.teragrid.org
-connection.name=xsede_private
-
-
-###---------------------------Orchestrator module Configurations---------------------------###
-job.submitter=org.apache.airavata.orchestrator.core.impl.EmbeddedGFACJobSubmitter
-job.validator=org.apache.airavata.orchestrator.core.validator.impl.SimpleAppDataValidator
-submitter.interval=10000
-threadpool.size=10
-start.submitter=true
-embedded.mode=true
-enable.validation=false
-
-

http://git-wip-us.apache.org/repos/asf/airavata/blob/b47a807b/modules/orchestrator/orchestrator-core/src/main/resources/airavata-server.properties
----------------------------------------------------------------------
diff --git a/modules/orchestrator/orchestrator-core/src/main/resources/airavata-server.properties b/modules/orchestrator/orchestrator-core/src/main/resources/airavata-server.properties
deleted file mode 100644
index ed563a6..0000000
--- a/modules/orchestrator/orchestrator-core/src/main/resources/airavata-server.properties
+++ /dev/null
@@ -1,274 +0,0 @@
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-###########################################################################
-#
-#  This properties file provides configuration for all Airavata Services:
-#  Registry, Workflow Interpreter, GFac, Message Broker, Message Box
-#
-###########################################################################
-
-###########################################################################
-# Airavata Embedded-Tomcat Server Configuration
-###########################################################################
-# By default, tomcat runs on port 80. If the port is changed, it will be
-#  have to be specified with port properties. This will be picked up by
-#  the registry service to register the service end-points.
-
-port=8080
-
-# Axis2 server automatically picks up IP address from axis configuration,
-#  but some DHCP enables machines do not report correct ip addresses,
-#  in which case, the IP address can be manually specified.
-
-#ip=192.2.33.12
-
-
-#This property will enable https and stops http, during the url registration, https urls will be stored and
-# http urls will not get registered, because currently airavata supports only one url for each service
-#enable.https=false
-#system properties used by services to register service URLs
-system.gateway=default
-system.user=admin
-system.password=admin
-airavata.server.url=http://localhost:8080/airavata/services/registry
-
-###########################################################################
-# Airavata Registry Configuration
-###########################################################################
-#for derby [AiravataJPARegistry]
-registry.jdbc.driver=org.apache.derby.jdbc.ClientDriver
-registry.jdbc.url=jdbc:derby://localhost:1527/persistent_data;create=true;user=airavata;password=airavata
-# MySql database configuration
-#registry.jdbc.driver=com.mysql.jdbc.Driver
-#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
-registry.jdbc.user=airavata
-registry.jdbc.password=airavata
-start.derby.server.mode=true
-validationQuery=SELECT 1 from CONFIGURATION
-jpa.connection.properties=MaxActive=10,MaxIdle=5,MinIdle=2,MaxWait=60000,testWhileIdle=true,testOnBorrow=true
-# Properties to setup registry service
-default.registry.user=admin
-default.registry.password=admin
-default.registry.password.hash.method=SHA
-default.registry.gateway=default
-#for rest [RegistryClient]
-#registry.jdbc.url=http://localhost:9080/airavata-services
-
-#user defined registry accessor classes
-#class.provenance.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.configuration.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.descriptor.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.project.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.user.workflow.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.published.workflow.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-
-############################################################    ###############
-# Airavata Workflow Interpreter Configurations
-###########################################################################
-
-runInThread=true
-provenance=true
-provenanceWriterThreadPoolSize=20
-gfac.embedded=true
-
-#
-# Security Configuration used by Airavata Generic Factory Service
-#  to interact with Computational Resources.
-#
-
-###########################################################################
-# Airavata GFac MyProxy GSI credentials to access Grid Resources.
-###########################################################################
-
-myproxy.server=myproxy.teragrid.org
-myproxy.user=username
-myproxy.pass=password
-myproxy.life=3600
-# XSEDE Trusted certificates can be downloaded from https://software.xsede.org/security/xsede-certs.tar.gz
-trusted.cert.location=/path/to/trusted/certificates
-
-# SSH PKI key pair or ssh password can be used SSH based authentication is used.
-# if user specify both password authentication gets the higher preference
-
-################# ---------- For ssh key pair authentication ------------------- ################
-#public.ssh.key=/path to public key for ssh
-#ssh.username=username for ssh connection
-#private.ssh.key=/path to private key file for ssh
-#ssh.keypass=passphrase for the private key
-
-
-################# ---------- For ssh key pair authentication ------------------- ################
-#ssh.username=username for ssh connection
-#ssh.password=Password for ssh connection
-
-
-
-###########################################################################
-# Airavata Message Broker Basic Configurations.
-#  the Advanced section provides detailed custom configuration properties.
-###########################################################################
-
-# Default derby database configuration
-broker.jdbc.driver=org.apache.derby.jdbc.EmbeddedDriver
-broker.jdbc.url=jdbc:derby:wsmg;create=true;user=airavata;password=airavata
-
-# Note: This database will only be used  if 'broker.storage.type=persistent'
-#       is set in advanced properties below.
-# MySql database configuration
-#broker.jdbc.driver=com.mysql.jdbc.Driver
-#broker.jdbc.url=jdbc:mysql://localhost:3306/wsmg?user=airavata&password=airavata
-
-###########################################################################
-# Airavata Message Box Basic Configurations,
-#  the Advanced section provides detailed custom configuration properties.
-###########################################################################
-
-# Default derby database
-msgBox.jdbc.driver=org.apache.derby.jdbc.EmbeddedDriver
-msgBox.jdbc.url=jdbc:derby:wsmg;create=true;user=airavata;password=airavata
-
-# MySql database configuration
-#msgBox.jdbc.driver=com.mysql.jdbc.Driver
-#msgBox.jdbc.url=jdbc:mysql://localhost:3306/wsmg?user=airavata&password=airavata
-
-###########################################################################
-# Advance configuration to change service implementations
-###########################################################################
-
-#Update the server context root path if airavata server is deployed under a different context root other than axis2
-server.context-root=airavata-server
-
-#
-# Class which implemented HostScheduler interface. It will determine the which host to submit the request
-#
-host.scheduler=org.apache.airavata.gfac.scheduler.impl.SimpleHostScheduler
-
-#
-# Data Service Plugins classes
-#
-datachain.classes= org.apache.airavata.core.gfac.extension.data.RegistryDataService
-
-#
-# Pre execution Plugins classes. For example, GridFTP Input Staging
-#
-prechain.classes= org.apache.airavata.core.gfac.extension.pre.GridFtpInputStaging
-prechain.classes= org.apache.airavata.core.gfac.extension.pre.HttpInputStaging
-
-#
-# Post execution Plugins classes. For example, GridFTP Output Staging
-#
-postchain.classes= org.apache.airavata.core.gfac.extension.post.GridFtpOutputStaging
-postchain.classes= org.apache.airavata.core.gfac.extension.post.OutputRegister
-
-#
-# Advanced Message Broker Configurations
-#
-
-#socket time out in milliseconds for sending messages. (defaults is 20000)
-broker.socket.timeout=60000
-
-broker.storage.type=persistent
-#broker.storage.type=memory
-
-#specifies wether delivery component should be started or not.
-broker.start.delivery.thread=true
-
-#fixed thread pool based delivery
-#broker.delivery.method=pcrew
-
-#dynamic thread pool based delivery
-#broker.delivery.method=parallel
-
-#single thread delivery
-broker.delivery.method=serial
-
-#number of message delivery failures before a url become black listed (default is 2)
-#broker.msg.delivery.retries=2
-
-#time period (in seconds) a url will be kept blacklisted (default is 5 seconds)
-#consumer.expiration.time.gap=5
-
-#maximum number of messages to be send to a one consumer/url at time.
-#applicable if 'broker.delivery.method' is 'pcrew' . (default is 10)
-
-#sending.batch.size=10
-
-#size of the thread pool. only applicable if 'broker.delivery.method' is 'pcrew'. (default is 4)
-#sending.thread.pool.size=4
-
-#
-# Advanced Message Box Configurations
-#
-msgBox.usedatabase=true
-messagePreservationDays=2
-messagePreservationHours=0
-messagePreservationMinutes=0
-messagePerservationIntervalDays=0
-messagePerservationIntervalHours=1
-messagePerservationIntervalMinutes=0
-
-###---------------------------REGISTRY API IMPLEMENTATION---------------------------###
-
-class.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.registry.accessor=org.apache.airavata.rest.client.RegistryClient
-
-###########################################################################
-# AMQP Notification Configuration
-###########################################################################
-amqp.notification.enable=1
-
-amqp.broker.host=localhost
-amqp.broker.port=5672
-amqp.broker.username=guest
-amqp.broker.password=guest
-
-amqp.sender=org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPSenderImpl
-amqp.topic.sender=org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPTopicSenderImpl
-amqp.broadcast.sender=org.apache.airavata.wsmg.client.amqp.rabbitmq.AMQPBroadcastSenderImpl
-
-###---------------------------Computational Middleware Configurations---------------------------###
-
-#enable.application.job.status.history=true
-#http://localhost:8080/axis2/services/RegistryService?wsdl
-registry.service.wsdl=http://localhost:${port}/${server.context-root}/services/RegistryService?wsdl
-
-# If false, disables two phase commit when submitting jobs
-TwoPhase=true
-
-###---------------------------Monitoring module Configurations---------------------------###
-#This will be the primary monitoring tool which runs in airavata, in future there will be multiple monitoring
-#mechanisms and one would be able to start a monitor
-primaryMonitor=org.apache.airavata.job.monitor.impl.pull.qstat.QstatMonitor
-#We do not support a secondaray monitoring at this point or host specific monitoring
-secondaryMonitor=org.apache.airavata.job.monitor.impl.push.amqp.AMQPMonitor
-#This is the amqp related configuration and this lists down the Rabbitmq host, this is an xsede specific configuration
-amqp.hosts=info1.dyn.teragrid.org,info2.dyn.teragrid.org
-connection.name=xsede_private
-
-
-###---------------------------Orchestrator module Configurations---------------------------###
-job.submitter=org.apache.airavata.orchestrator.core.impl.EmbeddedGFACJobSubmitter
-job.validator=org.apache.airavata.orchestrator.core.validator.impl.SimpleAppDataValidator
-submitter.interval=10000
-threadpool.size=10
-start.submitter=true
-embedded.mode=true
-enable.validation=false

http://git-wip-us.apache.org/repos/asf/airavata/blob/b47a807b/modules/rest/webapp/src/main/resources/airavata-server.properties
----------------------------------------------------------------------
diff --git a/modules/rest/webapp/src/main/resources/airavata-server.properties b/modules/rest/webapp/src/main/resources/airavata-server.properties
deleted file mode 100644
index fef423d..0000000
--- a/modules/rest/webapp/src/main/resources/airavata-server.properties
+++ /dev/null
@@ -1,236 +0,0 @@
-#
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-###########################################################################
-#
-#  This properties file provides configuration for all Airavata Services: 
-#  Registry, Workflow Interpreter, GFac, Message Broker, Message Box
-#
-###########################################################################
-
-###########################################################################
-# Airavata Embedded-Tomcat Server Configuration
-###########################################################################
-# By default, tomcat runs on port 80. If the port is changed, it will be  
-#  have to be specified with port properties. This will be picked up by 
-#  the registry service to register the service end-points.
-
-port=8080
-
-# Axis2 server automatically picks up IP address from axis configuration, 
-#  but some DHCP enables machines do not report correct ip addresses,  
-#  in which case, the IP address can be manually specified. 
-
-#ip=192.2.33.12
-
-#This property will enable https and stops http, during the url registration, https urls will be stored and
-# http urls will not get registered, because currently airavata supports only one url for each service
-#enable.https=false
-
-###########################################################################
-# Airavata Registry Configuration
-###########################################################################
-system.gateway=default
-system.user=admin
-system.password=admin
-#for derby [AiravataJPARegistry]
-registry.jdbc.driver=org.apache.derby.jdbc.ClientDriver
-registry.jdbc.url=jdbc:derby://localhost:1527/persistent_data;create=true;user=airavata;password=airavata
-# MySql database configuration
-#registry.jdbc.driver=com.mysql.jdbc.Driver
-#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
-registry.jdbc.user=airavata
-registry.jdbc.password=airavata
-start.derby.server.mode=true
-default.registry.user=admin
-default.registry.password=admin
-default.registry.password.hash.method=SHA
-default.registry.gateway=default
-validationQuery=SELECT 1 from Configuration
-jpa.connection.properties=MaxActive=10,MaxIdle=5,MinIdle=2,MaxWait=60000,testWhileIdle=true,testOnBorrow=true
-#for rest [RegistryClient]
-#registry.jdbc.url=http://localhost:9080/airavata-services
-
-#user defined registry accessor classes
-#class.provenance.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.configuration.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.descriptor.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.project.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.user.workflow.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.published.workflow.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-
-###########################################################################
-# Airavata Workflow Interpreter Configurations
-###########################################################################
-
-runInThread=true
-provenance=true
-provenanceWriterThreadPoolSize=20
-gfac.embedded=true
-
-#
-# Security Configuration used by Airavata Generic Factory Service
-#  to interact with Computational Resources.
-#
-
-###########################################################################
-# Airavata GFac MyProxy GSI credentials to access Grid Resources.
-###########################################################################
-
-myproxy.server=myproxy.teragrid.org
-myproxy.user=username
-myproxy.pass=password
-myproxy.life=3600
-# XSEDE Trusted certificates can be downloaded from https://software.xsede.org/security/xsede-certs.tar.gz
-trusted.cert.location=/path/to/trusted/certificates
-
-# SSH PKI key pair is SSH based authentication is used.
-#ssh.key=/home/user/.ssh/id_rsa
-#ssh.keypass=
-#ssh.username=usernameAtHost
-
-###########################################################################
-# Airavata Message Broker Basic Configurations.
-#  the Advanced section provides detailed custom configuration properties.
-###########################################################################
-
-# Default derby database configuration
-broker.jdbc.driver=org.apache.derby.jdbc.EmbeddedDriver
-broker.jdbc.url=jdbc:derby:wsmg;create=true;user=airavata;password=airavata
-
-# Note: This database will only be used  if 'broker.storage.type=persistent' 
-#       is set in advanced properties below.
-# MySql database configuration
-#broker.jdbc.driver=com.mysql.jdbc.Driver
-#broker.jdbc.url=jdbc:mysql://localhost:3306/wsmg?user=airavata&password=airavata
-
-###########################################################################
-# Airavata Message Box Basic Configurations, 
-#  the Advanced section provides detailed custom configuration properties.
-###########################################################################  
-
-# Default derby database
-msgBox.jdbc.driver=org.apache.derby.jdbc.EmbeddedDriver
-msgBox.jdbc.url=jdbc:derby:wsmg;create=true;user=airavata;password=airavata
-
-# MySql database configuration
-#msgBox.jdbc.driver=com.mysql.jdbc.Driver
-#msgBox.jdbc.url=jdbc:mysql://localhost:3306/wsmg?user=airavata&password=airavata
-
-###########################################################################
-# Advance configuration to change service implementations
-###########################################################################
-
-#Update the server context root path if airavata server is deployed under a different context root other than axis2
-#server.context-root=airavata-server
-
-
-#
-# Class which implemented HostScheduler interface. It will determine the which host to submit the request
-#
-host.scheduler=org.apache.airavata.gfac.scheduler.impl.SimpleHostScheduler
-
-
-#
-# Data Service Plugins classes
-#
-datachain.classes= org.apache.airavata.core.gfac.extension.data.RegistryDataService
-
-#
-# Pre execution Plugins classes. For example, GridFTP Input Staging
-#
-prechain.classes= org.apache.airavata.core.gfac.extension.pre.GridFtpInputStaging
-prechain.classes= org.apache.airavata.core.gfac.extension.pre.HttpInputStaging
-
-#
-# Post execution Plugins classes. For example, GridFTP Output Staging
-#
-postchain.classes= org.apache.airavata.core.gfac.extension.post.GridFtpOutputStaging
-postchain.classes= org.apache.airavata.core.gfac.extension.post.OutputRegister
-
-#
-# Advanced Message Broker Configurations
-#
-
-#socket time out in milliseconds for sending messages. (defaults is 20000)
-broker.socket.timeout=60000
-
-broker.storage.type=persistent
-#broker.storage.type=memory
-
-#specifies wether delivery component should be started or not.
-broker.start.delivery.thread=true
-
-#fixed thread pool based delivery
-#broker.delivery.method=pcrew
-
-#dynamic thread pool based delivery
-#broker.delivery.method=parallel
-
-#single thread delivery
-broker.delivery.method=serial
-
-#number of message delivery failures before a url become black listed (default is 2)
-#broker.msg.delivery.retries=2
-
-#time period (in seconds) a url will be kept blacklisted (default is 5 seconds) 
-#consumer.expiration.time.gap=5 
-
-#maximum number of messages to be send to a one consumer/url at time. 
-#applicable if 'broker.delivery.method' is 'pcrew' . (default is 10)
-
-#sending.batch.size=10
-
-#size of the thread pool. only applicable if 'broker.delivery.method' is 'pcrew'. (default is 4)
-#sending.thread.pool.size=4
-
-#
-# Advanced Message Box Configurations
-# 
-msgBox.usedatabase=true
-messagePreservationDays=2
-messagePreservationHours=0
-messagePreservationMinutes=0
-messagePerservationIntervalDays=0
-messagePerservationIntervalHours=1
-messagePerservationIntervalMinutes=0
-
-###---------------------------REGISTRY API IMPLEMENTATION---------------------------###
-
-class.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-#class.registry.accessor=org.apache.airavata.rest.client.RegistryClient
-registry.service.wsdl=http://localhost:${port}/axis2/services/RegistryService?wsdl
-
-# credential store specific parameters
-credential.store.keystore.url=../webapps/airavata/WEB-INF/classes/credential-store/airavata.jks
-credential.store.keystore.alias=airavata
-credential.store.keystore.password=airavata
-
-notifier.enabled=false
-#period in milliseconds
-notifier.duration=5000
-
-email.server=smtp.googlemail.com
-email.server.port=465
-email.user=airavata
-email.password=xxx
-email.ssl=true
-email.from=airavata@apache.org
-