You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by sa...@apache.org on 2013/01/04 15:41:42 UTC

svn commit: r1428898 - in /airavata/trunk/modules: airavata-client/src/main/resources/ commons/utils/src/main/java/org/apache/airavata/common/utils/ distribution/airavata-server/src/main/resources/conf/ gfac-axis2/src/main/java/org/apache/airavata/serv...

Author: samindaw
Date: Fri Jan  4 14:41:42 2013
New Revision: 1428898

URL: http://svn.apache.org/viewvc?rev=1428898&view=rev
Log:
retrieve registry settings from ariavata-client/server properties files if registry.properties file is not present

Added:
    airavata/trunk/modules/airavata-client/src/main/resources/airavata-client.properties   (with props)
    airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/AiravataUtils.java   (with props)
    airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ExecutionMode.java   (with props)
    airavata/trunk/modules/xbaya-gui/src/main/resources/airavata-client.properties   (with props)
Removed:
    airavata/trunk/modules/xbaya-gui/src/test/resources/airavata-server.properties
Modified:
    airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ServerSettings.java
    airavata/trunk/modules/distribution/airavata-server/src/main/resources/conf/airavata-server.properties
    airavata/trunk/modules/gfac-axis2/src/main/java/org/apache/airavata/services/gfac/axis2/GFacService.java
    airavata/trunk/modules/registry/registry-api/src/main/java/org/apache/airavata/registry/api/util/RegistrySettings.java
    airavata/trunk/modules/rest/webapp/src/main/resources/airavata-server.properties
    airavata/trunk/modules/ws-messenger/messagebox/src/main/java/org/apache/airavata/wsmg/msgbox/MsgBoxServiceLifeCycle.java
    airavata/trunk/modules/ws-messenger/messagebroker/src/main/java/org/apache/airavata/wsmg/broker/BrokerServiceLifeCycle.java
    airavata/trunk/modules/xbaya-gui/src/main/java/org/apache/airavata/xbaya/interpretor/WorkflowInterpretorSkeleton.java

Added: airavata/trunk/modules/airavata-client/src/main/resources/airavata-client.properties
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/airavata-client/src/main/resources/airavata-client.properties?rev=1428898&view=auto
==============================================================================
--- airavata/trunk/modules/airavata-client/src/main/resources/airavata-client.properties (added)
+++ airavata/trunk/modules/airavata-client/src/main/resources/airavata-client.properties Fri Jan  4 14:41:42 2013
@@ -0,0 +1,45 @@
+#
+#
+# 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 Airavata Clients: 
+#  XBaya and Airavata API
+#
+###########################################################################
+
+#
+# Accessing Airavata Registry Configuration
+# For 0.5 release the data case information is required. For 0.6 and beyond
+# the clients should only need Registry Service End Points.
+#
+registry.user=admin
+registry.password=admin
+gateway.id=default
+registry.jdbc.user=airavata
+registry.jdbc.password=airavata
+
+#for mysql
+#registry.jdbc.driver=com.mysql.jdbc.Driver
+#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
+
+#for derby
+registry.jdbc.driver=org.apache.derby.jdbc.ClientDriver
+registry.jdbc.url=jdbc:derby://localhost:1527/persistent_data;create=true;user=airavata;password=airavata

Propchange: airavata/trunk/modules/airavata-client/src/main/resources/airavata-client.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/AiravataUtils.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/AiravataUtils.java?rev=1428898&view=auto
==============================================================================
--- airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/AiravataUtils.java (added)
+++ airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/AiravataUtils.java Fri Jan  4 14:41:42 2013
@@ -0,0 +1,53 @@
+/*
+ *
+ * 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.common.utils;
+
+public class AiravataUtils {
+	private static final String EXECUTION_MODE="application.execution.mode";
+	public static void setExecutionMode(ExecutionMode mode){
+		System.setProperty(EXECUTION_MODE, mode.name());
+	}
+	
+	public static ExecutionMode getExecutionMode(){
+		if (System.getProperties().containsKey(EXECUTION_MODE)) {
+			return ExecutionMode.valueOf(System.getProperty(EXECUTION_MODE));
+		}else{
+			return null;
+		}
+	}
+	
+	public static boolean isServer(){
+		return getExecutionMode()==ExecutionMode.SERVER;
+	}
+	
+	public static boolean isClient(){
+		return getExecutionMode()!=ExecutionMode.SERVER;
+	}
+	
+	public static void setExecutionAsServer(){
+		setExecutionMode(ExecutionMode.SERVER);
+	}
+	
+	public static void setExecutionAsClient(){
+		setExecutionMode(ExecutionMode.CLIENT);
+	}
+}

Propchange: airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/AiravataUtils.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ExecutionMode.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ExecutionMode.java?rev=1428898&view=auto
==============================================================================
--- airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ExecutionMode.java (added)
+++ airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ExecutionMode.java Fri Jan  4 14:41:42 2013
@@ -0,0 +1,27 @@
+/*
+ *
+ * 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.common.utils;
+
+public enum ExecutionMode {
+	CLIENT,
+	SERVER
+}

Propchange: airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ExecutionMode.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ServerSettings.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ServerSettings.java?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ServerSettings.java (original)
+++ airavata/trunk/modules/commons/utils/src/main/java/org/apache/airavata/common/utils/ServerSettings.java Fri Jan  4 14:41:42 2013
@@ -29,7 +29,7 @@ import org.apache.airavata.common.except
 import org.apache.airavata.common.exception.UnspecifiedServerSettingsException;
 
 public class ServerSettings {
-    private static final String REPOSITORY_PROPERTIES = "airavata-server.properties";
+    public static final String REPOSITORY_PROPERTIES = "airavata-server.properties";
     private static Properties properties = new Properties();
     private static Exception propertyLoadException;
     private static final String DEFAULT_GATEWAY_ID="gateway.id";

Modified: airavata/trunk/modules/distribution/airavata-server/src/main/resources/conf/airavata-server.properties
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/distribution/airavata-server/src/main/resources/conf/airavata-server.properties?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/distribution/airavata-server/src/main/resources/conf/airavata-server.properties (original)
+++ airavata/trunk/modules/distribution/airavata-server/src/main/resources/conf/airavata-server.properties Fri Jan  4 14:41:42 2013
@@ -125,12 +125,6 @@ msgBox.jdbc.url=jdbc:derby:wsmg;create=t
 # Advance configuration to change service implementations
 ###########################################################################
 
-# By default all provenance data is also cataloged in Airavata Registry. 
-# A custom provenance implementation can be plugged in for Provenance Registry. 
-# The full qualified path to the implementation class has to be specified.
-# BY default a mysql JPA provenanceRegistry implementation is bundled.
-class.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-
 #
 # Class which implemented Scheduler interface. It will be used to determine a Provider
 #
@@ -200,5 +194,30 @@ 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 API IMPLEMENTATION - CUSTOM SETTINGS----------------------###
+
+#for mysql [AiravataJPARegistry]
+#registry.jdbc.driver=com.mysql.jdbc.Driver
+#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
+
+#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
+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
+
+#for rest [RegistryClient]
+#registry.jdbc.url=http://localhost:9080/airavata-services
 
 

Modified: airavata/trunk/modules/gfac-axis2/src/main/java/org/apache/airavata/services/gfac/axis2/GFacService.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/gfac-axis2/src/main/java/org/apache/airavata/services/gfac/axis2/GFacService.java?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/gfac-axis2/src/main/java/org/apache/airavata/services/gfac/axis2/GFacService.java (original)
+++ airavata/trunk/modules/gfac-axis2/src/main/java/org/apache/airavata/services/gfac/axis2/GFacService.java Fri Jan  4 14:41:42 2013
@@ -35,6 +35,7 @@ import org.apache.airavata.client.api.Ai
 import org.apache.airavata.client.api.AiravataAPIInvocationException;
 import org.apache.airavata.client.tools.PeriodicExecutorThread;
 import org.apache.airavata.common.exception.ServerSettingsException;
+import org.apache.airavata.common.utils.AiravataUtils;
 import org.apache.airavata.common.utils.ServerSettings;
 import org.apache.airavata.common.utils.ServiceUtils;
 import org.apache.airavata.core.gfac.context.GFacConfiguration;
@@ -82,6 +83,7 @@ public class GFacService implements Serv
     private Thread thread;
 
     public void startUp(ConfigurationContext configctx, AxisService service) {
+    	AiravataUtils.setExecutionAsServer();
         AxisConfiguration config = null;
         List<Phase> phases = null;
         config = service.getAxisConfiguration();

Modified: airavata/trunk/modules/registry/registry-api/src/main/java/org/apache/airavata/registry/api/util/RegistrySettings.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/registry/registry-api/src/main/java/org/apache/airavata/registry/api/util/RegistrySettings.java?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/registry/registry-api/src/main/java/org/apache/airavata/registry/api/util/RegistrySettings.java (original)
+++ airavata/trunk/modules/registry/registry-api/src/main/java/org/apache/airavata/registry/api/util/RegistrySettings.java Fri Jan  4 14:41:42 2013
@@ -21,22 +21,35 @@
 
 package org.apache.airavata.registry.api.util;
 
+import java.io.File;
 import java.net.URL;
 import java.util.Properties;
 
+import org.apache.airavata.common.utils.AiravataUtils;
+import org.apache.airavata.common.utils.ServerSettings;
 import org.apache.airavata.registry.api.exception.RegistrySettingsException;
 import org.apache.airavata.registry.api.exception.RegistrySettingsLoadException;
 import org.apache.airavata.registry.api.exception.UnspecifiedRegistrySettingsException;
 
 public class RegistrySettings {
     private static final String REPOSITORY_PROPERTIES = "registry.properties";
+    private static final String SERVER_REPOSITORY_PROPERTIES = ServerSettings.REPOSITORY_PROPERTIES;
+    private static final String CLIENT_REPOSITORY_PROPERTIES = "airavata-client.properties";
     private static Properties properties = new Properties();
     private static Exception propertyLoadException;
     private static final String REGISTRY_ACCESSOR_CLASS = "class.registry.accessor";
     
     static{
-    	URL url = RegistrySettings.class.getClassLoader()
-				.getResource(REPOSITORY_PROPERTIES);
+    	String propertyFileName = REPOSITORY_PROPERTIES;
+    	if (!(new File(propertyFileName)).exists()) {
+    		if (AiravataUtils.isServer()){
+        		propertyFileName=SERVER_REPOSITORY_PROPERTIES;
+        	}else{
+        		propertyFileName=CLIENT_REPOSITORY_PROPERTIES;
+        	}
+		}
+		URL url = RegistrySettings.class.getClassLoader()
+				.getResource(propertyFileName);
         try {
             properties.load(url.openStream());
         } catch (Exception e) {

Modified: airavata/trunk/modules/rest/webapp/src/main/resources/airavata-server.properties
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/rest/webapp/src/main/resources/airavata-server.properties?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/rest/webapp/src/main/resources/airavata-server.properties (original)
+++ airavata/trunk/modules/rest/webapp/src/main/resources/airavata-server.properties Fri Jan  4 14:41:42 2013
@@ -125,12 +125,6 @@ msgBox.jdbc.url=jdbc:derby:wsmg;create=t
 # Advance configuration to change service implementations
 ###########################################################################
 
-# By default all provenance data is also cataloged in Airavata Registry. 
-# A custom provenance implementation can be plugged in for Provenance Registry. 
-# The full qualified path to the implementation class has to be specified.
-# BY default a mysql JPA provenanceRegistry implementation is bundled.
-class.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
-
 #
 # Class which implemented Scheduler interface. It will be used to determine a Provider
 #
@@ -200,5 +194,25 @@ 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 API IMPLEMENTATION - CUSTOM SETTINGS----------------------###
+
+#for mysql [AiravataJPARegistry]
+#registry.jdbc.driver=com.mysql.jdbc.Driver
+#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
+
+#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
+registry.jdbc.user=airavata
+registry.jdbc.password=airavata
+default.registry.password.hash.method=SHA
+start.derby.server.mode=true
 
+#for rest [RegistryClient]
+#registry.jdbc.url=http://localhost:9080/airavata-services
 

Modified: airavata/trunk/modules/ws-messenger/messagebox/src/main/java/org/apache/airavata/wsmg/msgbox/MsgBoxServiceLifeCycle.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/ws-messenger/messagebox/src/main/java/org/apache/airavata/wsmg/msgbox/MsgBoxServiceLifeCycle.java?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/ws-messenger/messagebox/src/main/java/org/apache/airavata/wsmg/msgbox/MsgBoxServiceLifeCycle.java (original)
+++ airavata/trunk/modules/ws-messenger/messagebox/src/main/java/org/apache/airavata/wsmg/msgbox/MsgBoxServiceLifeCycle.java Fri Jan  4 14:41:42 2013
@@ -27,6 +27,7 @@ import org.apache.airavata.client.Airava
 import org.apache.airavata.client.api.AiravataAPI;
 import org.apache.airavata.client.api.AiravataAPIInvocationException;
 import org.apache.airavata.client.tools.PeriodicExecutorThread;
+import org.apache.airavata.common.utils.AiravataUtils;
 import org.apache.airavata.common.utils.ServerSettings;
 import org.apache.airavata.common.utils.ServiceUtils;
 import org.apache.airavata.wsmg.commons.config.ConfigurationManager;
@@ -88,7 +89,7 @@ public class MsgBoxServiceLifeCycle impl
     }
 
     public void startUp(ConfigurationContext configurationcontext, AxisService axisservice) {
-
+    	AiravataUtils.setExecutionAsServer();
         Axis2Utils.overrideAddressingPhaseHander(configurationcontext, new StoreMessageHandler());
 
         // Load the configuration file from the classpath

Modified: airavata/trunk/modules/ws-messenger/messagebroker/src/main/java/org/apache/airavata/wsmg/broker/BrokerServiceLifeCycle.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/ws-messenger/messagebroker/src/main/java/org/apache/airavata/wsmg/broker/BrokerServiceLifeCycle.java?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/ws-messenger/messagebroker/src/main/java/org/apache/airavata/wsmg/broker/BrokerServiceLifeCycle.java (original)
+++ airavata/trunk/modules/ws-messenger/messagebroker/src/main/java/org/apache/airavata/wsmg/broker/BrokerServiceLifeCycle.java Fri Jan  4 14:41:42 2013
@@ -28,6 +28,7 @@ import org.apache.airavata.client.Airava
 import org.apache.airavata.client.api.AiravataAPI;
 import org.apache.airavata.client.api.AiravataAPIInvocationException;
 import org.apache.airavata.client.tools.PeriodicExecutorThread;
+import org.apache.airavata.common.utils.AiravataUtils;
 import org.apache.airavata.common.utils.ServerSettings;
 import org.apache.airavata.common.utils.ServiceUtils;
 import org.apache.airavata.wsmg.broker.handler.PublishedMessageHandler;
@@ -113,7 +114,7 @@ public class BrokerServiceLifeCycle impl
     }
 
     public void startUp(ConfigurationContext configContext, AxisService axisService) {
-
+    	AiravataUtils.setExecutionAsServer();
         Boolean inited = (Boolean) configContext.getProperty(WsmgCommonConstants.BROKER_INITED);
 
         if (inited == null || inited == false) {

Modified: airavata/trunk/modules/xbaya-gui/src/main/java/org/apache/airavata/xbaya/interpretor/WorkflowInterpretorSkeleton.java
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/xbaya-gui/src/main/java/org/apache/airavata/xbaya/interpretor/WorkflowInterpretorSkeleton.java?rev=1428898&r1=1428897&r2=1428898&view=diff
==============================================================================
--- airavata/trunk/modules/xbaya-gui/src/main/java/org/apache/airavata/xbaya/interpretor/WorkflowInterpretorSkeleton.java (original)
+++ airavata/trunk/modules/xbaya-gui/src/main/java/org/apache/airavata/xbaya/interpretor/WorkflowInterpretorSkeleton.java Fri Jan  4 14:41:42 2013
@@ -47,6 +47,7 @@ import org.apache.airavata.client.api.Ai
 import org.apache.airavata.client.stub.interpretor.NameValue;
 import org.apache.airavata.client.tools.PeriodicExecutorThread;
 import org.apache.airavata.common.exception.ServerSettingsException;
+import org.apache.airavata.common.utils.AiravataUtils;
 import org.apache.airavata.common.utils.ServerSettings;
 import org.apache.airavata.common.utils.ServiceUtils;
 import org.apache.airavata.common.workflow.execution.context.WorkflowContextHeaderBuilder;
@@ -137,6 +138,7 @@ public class WorkflowInterpretorSkeleton
     }
 
     public void startUp(final ConfigurationContext configctx, AxisService service) {
+    	AiravataUtils.setExecutionAsServer();
     	new Thread(){
 			@Override
     		public void run() {

Added: airavata/trunk/modules/xbaya-gui/src/main/resources/airavata-client.properties
URL: http://svn.apache.org/viewvc/airavata/trunk/modules/xbaya-gui/src/main/resources/airavata-client.properties?rev=1428898&view=auto
==============================================================================
--- airavata/trunk/modules/xbaya-gui/src/main/resources/airavata-client.properties (added)
+++ airavata/trunk/modules/xbaya-gui/src/main/resources/airavata-client.properties Fri Jan  4 14:41:42 2013
@@ -0,0 +1,53 @@
+#
+#
+# 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 Airavata Clients: 
+#  XBaya and Airavata API
+#
+###########################################################################
+
+###---------------------------REGISTRY API IMPLEMENTATION---------------------------###
+
+#class.registry.accessor=org.apache.airavata.persistance.registry.jpa.impl.AiravataJPARegistry
+class.registry.accessor=org.apache.airavata.rest.client.RegistryClient
+
+###---------------------REGISTRY API IMPLEMENTATION - CUSTOM SETTINGS----------------------###
+
+#for mysql [AiravataJPARegistry]
+#registry.jdbc.driver=com.mysql.jdbc.Driver
+#registry.jdbc.url=jdbc:mysql://localhost:3306/persistent_data
+
+#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
+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
+
+#for rest [RegistryClient]
+#registry.jdbc.url=http://localhost:9080/airavata-services
+

Propchange: airavata/trunk/modules/xbaya-gui/src/main/resources/airavata-client.properties
------------------------------------------------------------------------------
    svn:mime-type = text/plain