Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id 065E2200C06 for ; Fri, 27 Jan 2017 21:41:20 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id 0523C160B60; Fri, 27 Jan 2017 20:41:20 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 626B7160B40 for ; Fri, 27 Jan 2017 21:41:18 +0100 (CET) Received: (qmail 52244 invoked by uid 500); 27 Jan 2017 20:41:17 -0000 Mailing-List: contact commits-help@airavata.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@airavata.apache.org Delivered-To: mailing list commits@airavata.apache.org Received: (qmail 52235 invoked by uid 99); 27 Jan 2017 20:41:17 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 27 Jan 2017 20:41:17 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 7CEEEDFC61; Fri, 27 Jan 2017 20:41:17 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: scnakandala@apache.org To: commits@airavata.apache.org Date: Fri, 27 Jan 2017 20:41:17 -0000 Message-Id: <284d44886e2b46c581b16aad40480ab6@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [01/11] airavata git commit: modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata-server-stop.sh archived-at: Fri, 27 Jan 2017 20:41:20 -0000 Repository: airavata Updated Branches: refs/heads/develop e2b2f8621 -> 8e08042f9 http://git-wip-us.apache.org/repos/asf/airavata/blob/ce359dc0/modules/test-suite/multi-tenanted-airavata/src/main/java/org/apache/airavata/testsuite/multitenantedairavata/utils/TestFrameworkConstants.java ---------------------------------------------------------------------- diff --git a/modules/test-suite/multi-tenanted-airavata/src/main/java/org/apache/airavata/testsuite/multitenantedairavata/utils/TestFrameworkConstants.java b/modules/test-suite/multi-tenanted-airavata/src/main/java/org/apache/airavata/testsuite/multitenantedairavata/utils/TestFrameworkConstants.java index 6d1c100..9377e62 100644 --- a/modules/test-suite/multi-tenanted-airavata/src/main/java/org/apache/airavata/testsuite/multitenantedairavata/utils/TestFrameworkConstants.java +++ b/modules/test-suite/multi-tenanted-airavata/src/main/java/org/apache/airavata/testsuite/multitenantedairavata/utils/TestFrameworkConstants.java @@ -22,18 +22,21 @@ package org.apache.airavata.testsuite.multitenantedairavata.utils; public class TestFrameworkConstants { - public static final String AIRAVATA_CLIENT_PROPERTIES = "airavata-client.properties"; + public static final String AIRAVATA_SERVER_PROPERTIES = "airavata-server.properties"; public static final String TEST_FREAMEWORK_JSON = "test-framework.json"; - + public static final String WORK_DIR = System.getProperty("user.dir"); + public static final String SCRATCH_LOCATION = System.getProperty("user.dir") + "/local-exp-resources/scratch/"; + public static final String STORAGE_LOCATION = System.getProperty("user.dir") + "/local-exp-resources/storage/"; + public static final String LOCAL_ECHO_JOB_FILE_PATH = TestFrameworkConstants.WORK_DIR +"/local-exp-resources/wrapper/echo_wrapper.sh"; public static final class AiravataClientConstants { - public static final String THRIFT_SERVER_HOST = "thrift.server.host"; - public static final String THRIFT_SERVER_PORT = "thrift.server.port"; + public static final String THRIFT_SERVER_HOST = "apiserver.host"; + public static final String THRIFT_SERVER_PORT = "apiserver.port"; public static final String CS_JBDC_URL = "credential.store.jdbc.url"; public static final String CS_JBDC_DRIVER = "credential.store.jdbc.driver"; public static final String CS_DB_USERNAME = "credential.store.jdbc.user"; public static final String CS_DB_PWD = "credential.store.jdbc.password"; public static final String RABBIT_BROKER_URL = "rabbitmq.broker.url"; - public static final String RABBIT_EXCHANGE_NAME = "rabbitmq.exchange.name"; + public static final String RABBIT_EXCHANGE_NAME = "rabbitmq.status.exchange.name"; } public static final class FrameworkPropertiesConstants { @@ -41,6 +44,10 @@ public class TestFrameworkConstants { public static final String USERS_PER_GATEWAY = "users.per.gateway"; public static final String COMPUTE_RESOURCE_LIST = "compute.resoure.list"; public static final String LOGIN_USERNAME_LIST = "login.usernames"; + + public static final String STORAGE_RESOURCE_LIST = "storage.resource.list"; + public static final String STORAGE_RESOURCE_LOGIN_USERBANE_LIST = "storage.resource.login.username"; + public static final String APPLICATION_LIST = "application.list"; public static final String SSH_PUBKEY_LOCATION = "ssh.pub.key.location"; public static final String SSH_PRIKEY_LOCATION = "ssh.private.key.location"; @@ -48,7 +55,6 @@ public class TestFrameworkConstants { public static final String SSH_USERNAME = "ssh.username"; public static final String TOKEN_WRITE_LOCATION = "token.file.location"; public static final String RESULT_WRITE_LOCATION = "result.file.location"; - public static final String GATEWAYS_TOSKIP = "gateways.toskip"; public static final String TEST_USER = "test.user"; public static final String TEST_PROJECT = "test.project"; } @@ -69,46 +75,15 @@ public class TestFrameworkConstants { } public static final class AppcatalogConstants { - public static final String AMBER_APP_NAME = "Amber_Sander"; - public static final String ECHO_NAME = "Echo"; - public static final String ULTRASCAN = "Ultrascan"; - public static final String ESPRESSO_NAME = "ESPRESSO"; - public static final String GROMACS_NAME = "GROMACS"; - public static final String LAMMPS_NAME = "LAMMPS"; - public static final String NWCHEM_NAME = "NWChem"; - public static final String TRINITY_NAME = "Trinity"; - public static final String WRF_NAME = "WRF"; - public static final String PHASTA_NAME = "PHASTA"; - public static final String TINKER_MONTE_NAME = "TinkerMonte"; - public static final String GAUSSIAN_NAME = "Gaussian"; - public static final String GAMESS_NAME = "Gamess"; - - public static final String ECHO_DESCRIPTION = "A Simple Echo Application"; - public static final String AMBER_DESCRIPTION = "Assisted Model Building with Energy Refinement MD Package"; - public static final String ULTRASCAN_DESCRIPTION = "Ultrascan application"; - public static final String ESPRESSO_DESCRIPTION = "Nanoscale electronic-structure calculations and materials modeling"; - public static final String GROMACS_DESCRIPTION = "GROMACS Molecular Dynamics Package"; - public static final String LAMMPS_DESCRIPTION = "Large-scale Atomic/Molecular Massively Parallel Simulator"; - public static final String NWCHEM_DESCRIPTION = "Ab initio computational chemistry software package"; - public static final String TRINITY_DESCRPTION = "de novo reconstruction of transcriptomes from RNA-seq data"; - public static final String WRF_DESCRIPTION = "Weather Research and Forecasting"; - public static final String PHASTA_DESCRIPTION = "Computational fluid dynamics solver"; - public static final String TINKER_MONTE_DESCRIPTION = "Grid Chem Tinker Monte Application"; - public static final String GAUSSIAN_DESCRIPTION = "Grid Chem Gaussian Application"; - public static final String GAMESS_DESCRIPTION = "A Gamess Application"; - - public static final String STAMPEDE_RESOURCE_NAME = "stampede.tacc.xsede.org"; - public static final String TRESTLES_RESOURCE_NAME = "trestles.sdsc.xsede.org"; - public static final String BR2_RESOURCE_NAME = "bigred2.uits.iu.edu"; - public static final String GORDEN_RESOURCE_NAME = "gordon.sdsc.edu"; - public static final String ALAMO_RESOURCE_NAME = "alamo.uthscsa.edu"; - public static final String COMET_RESOURCE_NAME = "comet.sdsc.edu"; - public static final String LONESTAR_RESOURCE_NAME = "lonestar.tacc.utexas.edu"; - - - public static final String AMBER_HEAT_RST_LOCATION = "02_Heat.rst_location"; - public static final String AMBER_PROD_IN_LOCATION = "03_Prod.in_location"; - public static final String AMBER_PRMTOP_LOCATION = "prmtop_location"; + + public static final String LOCAL_ECHO_NAME = "LocalEcho"; + + public static final String LOCAL_ECHO_VERSION= "1.0"; + + public static final String LOCAL_ECHO_DESCRIPTION = "A Simple Local Echo Application"; + + public static final String LOCAL_RESOURCE_NAME = "localhost"; + } public static final class CredentialStoreConstants { @@ -116,5 +91,35 @@ public class TestFrameworkConstants { } + public final class LocalEchoProperties { + + public static final String HOST_NAME = "localhost"; + public static final String HOST_DESC = "localhost"; + public static final String LOCAL_ECHO_EXPERIMENT_INPUT = "HelloWorld!!!"; + public static final String LOCAL_ECHO_EXPERIMENT_EXPECTED_OUTPUT = "Echoed_Output=HelloWorld!!!"; + + public static final String RESOURCE_NAME = "localhost"; + public static final String LOGIN_USER = "airavata"; + + public final class LocalEchoComputeResource{ + public static final String JOB_MANAGER_COMMAND = "/bin/bash"; + public static final String ALLOCATION_PROJECT_NUMBER= "local1.0"; + public static final String BATCH_QUEUE = "CPU"; + } + + + public final class LocalApplication{ + public static final String INPUT_NAME = "input"; + public static final String INPUT_VALUE = "LocalEchoTest"; + public static final String INPUT_DESC = "Sample input to Local Echo"; + + public static final String STDOUT_NAME = "STDOUT"; + public static final String STDOUT_VALUE = "stdout.txt"; + + public static final String STDERR_NAME = "STDERR"; + public static final String STDERR_VALUE = "stderr.txt"; + } + + } } http://git-wip-us.apache.org/repos/asf/airavata/blob/ce359dc0/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata-server.properties ---------------------------------------------------------------------- diff --git a/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata-server.properties b/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata-server.properties new file mode 100644 index 0000000..c02a892 --- /dev/null +++ b/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata-server.properties @@ -0,0 +1,336 @@ +# +# +# 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: +# API Server, Registry, Workflow Interpreter, GFac, Orchestrator +# +########################################################################### + +########################################################################### +# API Server Registry Configuration +########################################################################### + +#for derby [AiravataJPARegistry] +registry.jdbc.driver=org.apache.derby.jdbc.ClientDriver +registry.jdbc.url=jdbc:derby:experiment_catalog;create=true;user=airavata;password=airavata +# MySql database configuration +#registry.jdbc.driver=com.mysql.jdbc.Driver +#registry.jdbc.url=jdbc:mysql://localhost:3306/experiment_catalog +registry.jdbc.user=airavata +registry.jdbc.password=airavata +#FIXME: Probably the following property should be removed. +start.derby.server.mode=false +validationQuery=SELECT 1 from CONFIGURATION +cache.enable=true +jpa.cache.size=5000 +#jpa.connection.properties=MaxActive=10,MaxIdle=5,MinIdle=2,MaxWait=60000,testWhileIdle=true,testOnBorrow=true +enable.sharing=true + +# Properties for default user mode +default.registry.user=admin +default.registry.password=admin +default.registry.password.hash.method=SHA +default.registry.gateway=php_reference_gateway +super.tenant.gatewayId=php_reference_gateway + +# Properties for cluster status monitoring +# cluster status monitoring job repeat time in seconds +cluster.status.monitoring.repeat.time=18000 + +########################################################################### +# Application Catalog DB Configuration +########################################################################### +#for derby [AiravataJPARegistry] +appcatalog.jdbc.driver=org.apache.derby.jdbc.ClientDriver +appcatalog.jdbc.url=jdbc:derby:app_catalog;create=true;user=airavata;password=airavata +# MySql database configuration +#appcatalog.jdbc.driver=com.mysql.jdbc.Driver +#appcatalog.jdbc.url=jdbc:mysql://localhost:3306/app_catalog +appcatalog.jdbc.user=airavata +appcatalog.jdbc.password=airavata +appcatalog.validationQuery=SELECT 1 from CONFIGURATION + +########################################################################## +# Replica Catalog DB Configuration +########################################################################### +#for derby [AiravataJPARegistry] +replicacatalog.jdbc.driver=org.apache.derby.jdbc.ClientDriver +replicacatalog.jdbc.url=jdbc:derby:replica_catalog;create=true;user=airavata;password=airavata +# MySql database configuration +#replicacatalog.jdbc.driver=com.mysql.jdbc.Driver +#replicacatalog.jdbc.url=jdbc:mysql://localhost:3306/replica_catalog +replicacatalog.jdbc.user=airavata +replicacatalog.jdbc.password=airavata +replicacatalog.validationQuery=SELECT 1 from CONFIGURATION + +########################################################################### +# Workflow Catalog DB Configuration +########################################################################### +#for derby [AiravataJPARegistry] +workflowcatalog.jdbc.driver=org.apache.derby.jdbc.ClientDriver +workflowcatalog.jdbc.url=jdbc:derby:workflow_catalog;create=true;user=airavata;password=airavata +# MySql database configuration +#workflowcatalog.jdbc.driver=com.mysql.jdbc.Driver +#workflowcatalog.jdbc.url=jdbc:mysql://localhost:3306/workflow_catalog +workflowcatalog.jdbc.user=airavata +workflowcatalog.jdbc.password=airavata +workflowcatalog.validationQuery=SELECT 1 from CONFIGURATION + +########################################################################### +# Sharing Catalog DB Configuration +########################################################################### +#for derby [AiravataJPARegistry] +sharingcatalog.jdbc.driver=org.apache.derby.jdbc.ClientDriver +sharingcatalog.jdbc.url=jdbc:derby:sharing_catalog;create=true;user=airavata;password=airavata +# MySql database configuration +#sharingcatalog.jdbc.driver=com.mysql.jdbc.Driver +#sharingcatalog.jdbc.url=jdbc:mysql://localhost:3306/sharing_catalog +sharingcatalog.jdbc.user=airavata +sharingcatalog.jdbc.password=airavata +sharingcatalog.validationQuery=SELECT 1 from CONFIGURATION + +########################################################################### +# Sharing Registry Server Configuration +########################################################################### +sharing.registry.server.host=localhost +sharing.registry.server.port=7878 + +########################################################################### +# User Profile MongoDB Configuration +########################################################################### +userprofile.mongodb.host=localhost +userprofile.mongodb.port=27017 + + +########################################################################### +# Server module Configuration +########################################################################### +#credential store server should be started before API server +servers=credentialstore,apiserver,orchestrator,gfac + + +########################################################################### +# API Server Configurations +########################################################################### +apiserver=org.apache.airavata.api.server.AiravataAPIServer +apiserver.name=apiserver-node0 +apiserver.host=localhost +apiserver.port=8930 +apiserver.min.threads=50 + +########################################################################### +# API Server SSL Configurations +########################################################################### +apiserver.tls.enabled=false +apiserver.keystore=/path/to/airavata.jks +apiserver.keystore.password=airavata + +########################################################################### +# Orchestrator Server Configurations +########################################################################### +orchestrator=org.apache.airavata.orchestrator.server.OrchestratorServer +orchestrator.server.name=orchestrator-node0 +orchestrator.server.host=localhost +orchestrator.server.port=8940 +orchestrator.server.min.threads=50 +job.validators=org.apache.airavata.orchestrator.core.validator.impl.BatchQueueValidator,org.apache.airavata.orchestrator.core.validator.impl.ExperimentStatusValidator +submitter.interval=10000 +threadpool.size=10 +start.submitter=true +embedded.mode=true +enable.validation=true + + +########################################################################### +# GFac Server Configurations +########################################################################### +gfac=org.apache.airavata.gfac.server.GfacServer +gfac.server.name=gfac-node0 +gfac.server.host=localhost +gfac.server.port=8950 +gfac.thread.pool.size=50 +host.scheduler=org.apache.airavata.gfac.impl.DefaultHostScheduler + + +########################################################################### +# Registry Server Configurations +########################################################################### +regserver=org.apache.airavata.registry.api.service.RegistryAPIServer +regserver.server.name=regserver-node0 +regserver.server.host=localhost +regserver.server.port=8970 +regserver.server.min.threads=50 + + +########################################################################### +# Airavata Workflow Interpreter Configurations +########################################################################### +workflowserver=org.apache.airavata.api.server.WorkflowServer +enactment.thread.pool.size=10 + +#to define custom workflow parser user following property +#workflow.parser=org.apache.airavata.workflow.core.parser.AiravataWorkflowBuilder + + + +########################################################################### +# Job Scheduler can send informative email messages to you about the status of your job. +# Specify a string which consists of either the single character "n" (no mail), or one or more +# of the characters "a" (send mail when job is aborted), "b" (send mail when job begins), +# and "e" (send mail when job terminates). The default is "a" if not specified. +########################################################################### + +job.notification.enable=true +#Provide comma separated email ids as a string if more than one +job.notification.emailids= +job.notification.flags=abe + +########################################################################### +# Credential Store module Configuration +########################################################################### +credential.store.keystore.url=../../../airavata_sym.jks +credential.store.keystore.alias=airavata +credential.store.keystore.password=airavata +credential.store.jdbc.url=jdbc:derby:credential-store;create=true;user=airavata;password=airavata +credential.store.jdbc.user=airavata +credential.store.jdbc.password=airavata +credential.store.jdbc.driver=org.apache.derby.jdbc.ClientDriver +credential.store.jdbc.validationQuery=SELECT 1 from CONFIGURATION +#credential.store.jdbc.driver=com.mysql.jdbc.Driver +#credential.store.jdbc.url=jdbc:mysql://localhost:3306/credential_store +credential.store.server.host=localhost +credential.store.server.port=8960 +credentialstore=org.apache.airavata.credential.store.server.CredentialStoreServer + +# these properties used by credential store email notifications +email.server=smtp.googlemail.com +email.server.port=465 +email.user=airavata +email.password=xxx +email.ssl=true +email.from=airavata@apache.org + +# SSH PKI key pair or ssh password can be used SSH based sshKeyAuthentication is used. +# if user specify both password sshKeyAuthentication gets the higher preference + +################# ---------- For ssh key pair sshKeyAuthentication ------------------- ################ +#ssh.public.key=/path to public key for ssh +#ssh.private.key=/path to private key file for ssh +#ssh.keypass=passphrase for the private key +#ssh.username=username for ssh connection +## If you set "yes" for ssh.strict.hostKey.checking, then you must provide known hosts file path +#ssh.strict.hostKey.checking=yes/no +#ssh.known.hosts.file=/path to known hosts file +### Incase of password sshKeyAuthentication. +#ssh.password=Password for ssh connection + +################ ---------- BES Properties ------------------- ############### +#bes.ca.cert.path=/certificates/cacert.pem +#bes.ca.key.path=/certificates/cakey.pem +#bes.ca.key.pass=passphrase + +########################################################################### +# Monitoring module Configuration +########################################################################### + +#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 +monitors=org.apache.airavata.gfac.monitor.impl.pull.qstat.QstatMonitor,org.apache.airavata.gfac.monitor.impl.LocalJobMonitor + +#These properties will used to enable email base monitoring +email.based.monitor.host=imap.gmail.com +email.based.monitor.address=test@scigap.com +email.based.monitor.password=changeme +email.based.monitor.folder.name=INBOX +# either imaps or pop3 +email.based.monitor.store.protocol=imaps +#These property will be used to query the email server periodically. value in milliseconds(ms). +email.based.monitoring.period=10000 + +########################################################################### +# AMQP Notification Configuration +########################################################################### +#for simple scenarios we can use the guest user +#rabbitmq.broker.url=amqp://localhost:5672 +#for production scenarios, give url as amqp://userName:password@hostName:portNumber/virtualHost, create user, virtualhost +# and give permissions, refer: http://blog.dtzq.com/2012/06/rabbitmq-users-and-virtual-hosts.html +rabbitmq.broker.url=amqp://airavata:airavata@149.165.228.91:5672/messaging +rabbitmq.status.exchange.name=status_exchange +rabbitmq.process.exchange.name=process_exchange +rabbitmq.experiment.exchange.name=experiment_exchange +durable.queue=false +prefetch.count=200 +process.launch.queue.name=process.launch.queue +experiment.launch.queue.name=experiment.launch.queue + +########################################################################### +# Zookeeper Server Configuration +########################################################################### +embedded.zk=true +zookeeper.server.connection=localhost:2181 +zookeeper.timeout=30000 + +########################################################################### +# Aurora Scheduler Configuration +########################################################################### +aurora.scheduler.hosts=sgg-mesos-master-1:8081,sgg-mesos-master-2:8081,sgg-mesos-master-3:8081 +aurora.scheduler.timeoutms=1000 +aurora.executor.name=AuroraExecutor +mesos.cluster.name=example +aurora.executor.config.template.filename=executor-config-template.json + +######################################################################## +## API Security Configuration +######################################################################## +api.secured=false +security.manager.class=org.apache.airavata.api.server.security.DefaultAiravataSecurityManager +### TLS related configuration #### +TLS.enabled=false +TLS.api.server.port=9930 +TLS.client.timeout=10000 +#### keystore configuration #### +keystore.path=airavata.jks +keystore.password=airavata +#### trust store configuration #### +trust.store=client_truststore.jks +trust.store.password=airavata +#### remote authorization server url #### +remote.oauth.authorization.server=https://idp.scigap.org:9443/services/ +#### xacml based authorization policy #### +authorization.policy=airavata-default-xacml-policy +#### authorization cache related configuration #### +authz.cache.enabled=true +authz.cache.manager.class=org.apache.airavata.api.server.security.authzcache.DefaultAuthzCacheManager +in.memory.cache.size=1000 + +# Kafka Logging related configuration +isRunningOnAws=false +kafka.broker.list=localhost:9092 +kafka.topic.prefix=local +enable.kafka.logging=false + +########################################################################### +# User Profile module Configuration +########################################################################### +user.profile.server.host=localhost +user.profile.server.port=8961 +user_profile=com.apache.airavata.user.profile.server.UserProfileServer \ No newline at end of file http://git-wip-us.apache.org/repos/asf/airavata/blob/ce359dc0/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata_sym.jks ---------------------------------------------------------------------- diff --git a/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata_sym.jks b/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata_sym.jks new file mode 100644 index 0000000..02a5855 Binary files /dev/null and b/modules/test-suite/multi-tenanted-airavata/src/main/resources/airavata_sym.jks differ http://git-wip-us.apache.org/repos/asf/airavata/blob/ce359dc0/modules/test-suite/multi-tenanted-airavata/src/main/resources/local-exp-resources/wrapper/echo_wrapper.sh ---------------------------------------------------------------------- diff --git a/modules/test-suite/multi-tenanted-airavata/src/main/resources/local-exp-resources/wrapper/echo_wrapper.sh b/modules/test-suite/multi-tenanted-airavata/src/main/resources/local-exp-resources/wrapper/echo_wrapper.sh new file mode 100644 index 0000000..53ed420 --- /dev/null +++ b/modules/test-suite/multi-tenanted-airavata/src/main/resources/local-exp-resources/wrapper/echo_wrapper.sh @@ -0,0 +1,7 @@ +#!/bin/bash +sleep 4 + +echo "Echoed_Output=$1" >> $2 1>> $3 + +#cp `pwd`/*.stdout `pwd`/output +#cp `pwd`/*.stderr `pwd`/output http://git-wip-us.apache.org/repos/asf/airavata/blob/ce359dc0/modules/test-suite/multi-tenanted-airavata/src/main/resources/log4j.properties ---------------------------------------------------------------------- diff --git a/modules/test-suite/multi-tenanted-airavata/src/main/resources/log4j.properties b/modules/test-suite/multi-tenanted-airavata/src/main/resources/log4j.properties new file mode 100644 index 0000000..a625c4f --- /dev/null +++ b/modules/test-suite/multi-tenanted-airavata/src/main/resources/log4j.properties @@ -0,0 +1,41 @@ +# +# 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. +# + +# Set root category priority to INFO and its only appender to CONSOLE. +log4j.rootCategory=INFO, CONSOLE,LOGFILE +log4j.rootLogger=INFO, CONSOLE, LOGFILE + +# Set the enterprise logger priority to FATAL +log4j.logger.org.apache.axis2.enterprise=FATAL +log4j.logger.de.hunsicker.jalopy.io=FATAL +log4j.logger.httpclient.wire.header=FATAL +log4j.logger.org.apache.commons.httpclient=FATAL +log4j.logger.org.apache.zookeeper=FATAL + +# CONSOLE is set to be a ConsoleAppender using a PatternLayout. +log4j.appender.CONSOLE=org.apache.log4j.ConsoleAppender +log4j.appender.CONSOLE.layout=org.apache.log4j.PatternLayout +log4j.appender.CONSOLE.layout.ConversionPattern=[%p] %m%n + +# LOGFILE is set to be a File appender using a PatternLayout. +log4j.appender.LOGFILE=org.apache.log4j.FileAppender +log4j.appender.LOGFILE.File=../../bin/airavata.log +log4j.appender.LOGFILE.Append=true +log4j.appender.LOGFILE.layout=org.apache.log4j.PatternLayout +log4j.appender.LOGFILE.layout.ConversionPattern=%d [%t] %-5p %c %x - %m%n http://git-wip-us.apache.org/repos/asf/airavata/blob/ce359dc0/modules/test-suite/multi-tenanted-airavata/src/main/resources/startup-airavata.sh ---------------------------------------------------------------------- diff --git a/modules/test-suite/multi-tenanted-airavata/src/main/resources/startup-airavata.sh b/modules/test-suite/multi-tenanted-airavata/src/main/resources/startup-airavata.sh new file mode 100755 index 0000000..158f657 --- /dev/null +++ b/modules/test-suite/multi-tenanted-airavata/src/main/resources/startup-airavata.sh @@ -0,0 +1,8 @@ +#!/usr/bin/env bash + +rm -rf base-airavata/apache-airavata-server-0.17-SNAPSHOT +cp ../../../../distribution/target/apache-airavata-server-0.17-SNAPSHOT-bin.tar.gz base-airavata/ +tar -xvf base-airavata/apache-airavata-server-0.17-SNAPSHOT-bin.tar.gz -C base-airavata/ +cp mysql-connector-java-5.1.39-bin.jar base-airavata/apache-airavata-server-0.17-SNAPSHOT/lib/ +cp airavata-server.properties base-airavata/apache-airavata-server-0.17-SNAPSHOT/bin/ +base-airavata/apache-airavata-server-0.17-SNAPSHOT/bin/airavata-server-start.sh all -d