You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by di...@apache.org on 2019/04/30 13:25:21 UTC

[airavata] branch master updated: Removing ansibles for GFac installation

This is an automated email from the ASF dual-hosted git repository.

dimuthuupe pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/airavata.git


The following commit(s) were added to refs/heads/master by this push:
     new 0251884  Removing ansibles for GFac installation
0251884 is described below

commit 0251884d11a18ea691792a5df03849fed214861f
Author: Dimuthu Wannipurage <di...@gmail.com>
AuthorDate: Tue Apr 30 09:25:04 2019 -0400

    Removing ansibles for GFac installation
---
 dev-tools/ansible/roles/gfac/defaults/main.yml     |  27 --
 dev-tools/ansible/roles/gfac/handlers/main.yml     |  28 --
 dev-tools/ansible/roles/gfac/tasks/main.yml        |  96 -------
 .../gfac/templates/airavata-server.properties.j2   | 302 ---------------------
 .../roles/gfac/templates/gfac-config.yaml.j2       | 145 ----------
 .../ansible/roles/gfac/templates/logback.xml.j2    |  58 ----
 6 files changed, 656 deletions(-)

diff --git a/dev-tools/ansible/roles/gfac/defaults/main.yml b/dev-tools/ansible/roles/gfac/defaults/main.yml
deleted file mode 100644
index 1d97bcd..0000000
--- a/dev-tools/ansible/roles/gfac/defaults/main.yml
+++ /dev/null
@@ -1,27 +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.
-#
-
-gfac_log_dir: "{{ gfac_dir }}/{{ airavata_dist }}/logs"
-gfac_log_max_history: 30
-gfac_log_total_size_cap: "1GB"
-mariadb_connector_jar_url: "http://downloads.mariadb.com/Connectors/java/connector-java-2.0.2/mariadb-java-client-2.0.2.jar"
-
-default_registry_user : "admin"
-default_registry_password : "admin"
diff --git a/dev-tools/ansible/roles/gfac/handlers/main.yml b/dev-tools/ansible/roles/gfac/handlers/main.yml
deleted file mode 100644
index 5d8f61b..0000000
--- a/dev-tools/ansible/roles/gfac/handlers/main.yml
+++ /dev/null
@@ -1,28 +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.
-#
-
----
-
-# Gfac related handlers
-- name: start gfac
-  command: ./bin/airavata-server-start.sh gfac -d chdir="{{ gfac_dir }}/{{ airavata_dist }}/" creates="{{ gfac_dir }}/{{ airavata_dist }}/bin/server_start_*"
-
-- name: stop gfac
-  command: ./bin/airavata-server-stop.sh -f chdir="{{ gfac_dir }}/{{ airavata_dist }}/" removes="{{ gfac_dir }}/{{ airavata_dist }}/bin/server_start_*"
diff --git a/dev-tools/ansible/roles/gfac/tasks/main.yml b/dev-tools/ansible/roles/gfac/tasks/main.yml
deleted file mode 100644
index db3fea4..0000000
--- a/dev-tools/ansible/roles/gfac/tasks/main.yml
+++ /dev/null
@@ -1,96 +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.
-#
-
----
-
-################################################################################
-# gfac deployments
-- name: Create Gfac deployment directory
-  file: path="{{ gfac_dir }}" state=directory owner={{ user }} group={{ group }}
-  when: build|success
-
-- name: Check previous deployments
-  stat: path="{{ gfac_dir }}/{{ airavata_dist }}" get_md5=no get_checksum=no
-  register: check
-
-- name: stop gfac
-  command: ./bin/airavata-server-stop.sh -f
-           chdir="{{ gfac_dir }}/{{ airavata_dist }}/"
-           removes="{{ gfac_dir }}/{{ airavata_dist }}/bin/server_start_*"
-  when: check.stat.exists == True
-
-- name: Delete previous deployments
-  file: path="{{ gfac_dir }}/{{ airavata_dist }}" state=absent
-
-- name: Copy distribution to gfac deployment directory
-  unarchive: src="{{ airavata_source_dir }}/modules/distribution/target/{{ airavata_dist_name }}"
-             dest="{{ gfac_dir }}/"
-             copy=no
-
-- name: set gfac private ip
-  set_fact:
-    gfac_host: "{{ ansible_default_ipv4.address }}"
-
-- name: Copy Airavata server properties file
-  template: src=airavata-server.properties.j2
-            dest="{{ gfac_dir }}/{{ airavata_dist }}/bin/airavata-server.properties"
-            owner={{ user }}
-            group={{ group }}
-            mode="u=rw,g=r,o=r"
-
-- name: Copy Gfac configuration file
-  template: src=gfac-config.yaml.j2
-            dest="{{ gfac_dir }}/{{ airavata_dist }}/bin/gfac-config.yaml"
-            owner={{ user }}
-            group={{ group }}
-            mode="u=rw,g=r,o=r"
-
-- name: Copy logback configuration file
-  template: src=logback.xml.j2
-            dest="{{ gfac_dir }}/{{ airavata_dist }}/bin/logback.xml"
-            owner={{ user }}
-            group={{ group }}
-            mode="u=rw,g=r,o=r"
-
-- name: create logs directory
-  file: path="{{ gfac_log_dir }}" state=directory owner={{ user }} group={{ group }}
-
-- name: Copy MariaDB connector jar to lib
-  get_url: url="{{ mariadb_connector_jar_url }}"
-          dest="{{ gfac_dir }}/{{ airavata_dist }}/lib/"
-          owner={{ user }}
-          group={{ group }}
-
-- name: Open firwall ports
-  firewalld: port="{{ gfac_port }}/tcp" zone=public permanent=true state=enabled immediate=yes
-  become_user: root
-
-- name: stop gfac
-  command: ./bin/airavata-server-stop.sh -f
-           chdir="{{ gfac_dir }}/{{ airavata_dist }}/"
-           removes="{{ gfac_dir }}/{{ airavata_dist }}/bin/server_start_*"
-
-- name: start gfac
-  command: ./bin/airavata-server-start.sh gfac -d -log "{{ gfac_log_dir }}/output.log"
-           chdir="{{ gfac_dir }}/{{ airavata_dist }}/"
-           creates="{{ gfac_dir }}/{{ airavata_dist }}/bin/server_start_*"
-
-
-...
diff --git a/dev-tools/ansible/roles/gfac/templates/airavata-server.properties.j2 b/dev-tools/ansible/roles/gfac/templates/airavata-server.properties.j2
deleted file mode 100644
index 7c984df..0000000
--- a/dev-tools/ansible/roles/gfac/templates/airavata-server.properties.j2
+++ /dev/null
@@ -1,302 +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:
-#  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://localhost:1527/experiment_catalog;create=true;user=airavata;password=airavata
-# MariaDB database configuration
-registry.jdbc.driver=org.mariadb.jdbc.Driver
-registry.jdbc.url=jdbc:mariadb://{{ db_server }}:{{ db_server_port }}/{{ exp_catalog }}
-registry.jdbc.user={{ db_user }}
-registry.jdbc.password={{ db_password }}
-#FIXME: Probably the following property should be removed.
-start.derby.server.mode=false
-validationQuery=SELECT 1 from CONFIGURATION
-cache.enable=false
-jpa.cache.size=-1
-#jpa.connection.properties=MaxActive=10,MaxIdle=5,MinIdle=2,MaxWait=60000,testWhileIdle=true,testOnBorrow=true
-enable.sharing={{enable_sharing}}
-
-# Properties for default user mode
-default.registry.user={{ default_registry_user }}
-default.registry.password={{ default_registry_password }}
-default.registry.password.hash.method=SHA
-default.registry.gateway={{ default_gateway }}
-super.tenant.gatewayId={{ default_gateway }}
-
-# Properties for cluster status monitoring
-# cluster status monitoring job repeat time in seconds
-cluster.status.monitoring.enable=false
-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://localhost:1527/app_catalog;create=true;user=airavata;password=airavata
-# MariaDB database configuration
-appcatalog.jdbc.driver=org.mariadb.jdbc.Driver
-appcatalog.jdbc.url=jdbc:mariadb://{{ db_server }}:3306/{{ app_catalog }}
-appcatalog.jdbc.user={{ db_user }}
-appcatalog.jdbc.password={{ db_password }}
-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://localhost:1527/replica_catalog;create=true;user=airavata;password=airavata
-# MariaDB database configuration
-replicacatalog.jdbc.driver=org.mariadb.jdbc.Driver
-replicacatalog.jdbc.url=jdbc:mariadb://{{ db_server }}:3306/{{ replica_catalog }}
-replicacatalog.jdbc.user={{ db_user }}
-replicacatalog.jdbc.password={{ db_password }}
-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://localhost:1527/workflow_catalog;create=true;user=airavata;password=airavata
-# MariaDB database configuration
-workflowcatalog.jdbc.driver=org.mariadb.jdbc.Driver
-workflowcatalog.jdbc.url=jdbc:mariadb://{{ db_server }}:3306/{{ workflow_catalog }}
-workflowcatalog.jdbc.user={{ db_user }}
-workflowcatalog.jdbc.password={{ db_password }}
-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://localhost:1527/sharing_catalog;create=true;user=airavata;password=airavata
-# MariaDB database configuration
-sharingcatalog.jdbc.driver=org.mariadb.jdbc.Driver
-sharingcatalog.jdbc.url=jdbc:mariadb://{{ db_server }}:3306/{{ sharing_catalog }}
-sharingcatalog.jdbc.user={{ db_user }}
-sharingcatalog.jdbc.password={{ db_password }}
-sharingcatalog.validationQuery=SELECT 1 from CONFIGURATION
-
-###########################################################################
-#  User Profile MongoDB Configuration
-###########################################################################
-userprofile.mongodb.host=localhost
-userprofile.mongodb.port=27017
-
-
-###########################################################################
-#  Server module Configuration
-###########################################################################
-#credential store server should be started before API server
-#This is obsolete property with new script files.
-#servers=credentialstore,apiserver,orchestrator
-
-
-###########################################################################
-#  API Server Configurations
-###########################################################################
-apiserver=org.apache.airavata.api.server.AiravataAPIServer
-apiserver.name={{ api_server_name }}
-apiserver.host={{ api_server_host }}
-apiserver.port={{ api_server_port }}
-apiserver.min.threads=50
-
-###########################################################################
-#  Orchestrator Server Configurations
-###########################################################################
-orchestrator=org.apache.airavata.orchestrator.server.OrchestratorServer
-orchestrator.server.name={{ orchestrator_name }}
-orchestrator.server.host={{ orchestrator_host }}
-orchestrator.server.port={{ orchestrator_port }}
-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
-
-###########################################################################
-#  Registry Server Configurations
-###########################################################################
-regserver=org.apache.airavata.registry.api.service.RegistryAPIServer
-regserver.server.name={{registry_name}}
-regserver.server.host={{registry_host}}
-regserver.server.port={{registry_port}}
-regserver.server.min.threads=50
-
-###########################################################################
-#  GFac Server Configurations
-###########################################################################
-gfac=org.apache.airavata.gfac.server.GfacServer
-gfac.server.name={{ gfac_name }}
-gfac.server.host={{ gfac_host }}
-gfac.server.port={{ gfac_port }}
-gfac.thread.pool.size=50
-host.scheduler=org.apache.airavata.orchestrator.core.schedule.DefaultHostScheduler
-
-
-
-###########################################################################
-# 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={{ keystores_location }}/{{ cred_keystore_src_path | basename }}
-credential.store.keystore.alias={{ cred_keystore_alias }}
-credential.store.keystore.password={{ cred_keystore_passwd }}
-credential.store.jdbc.url=jdbc:mariadb://{{ db_server }}:3306/{{ credential_store }}
-credential.store.jdbc.user={{ db_user }}
-credential.store.jdbc.password={{ db_password }}
-credential.store.jdbc.driver=org.mariadb.jdbc.Driver
-credential.store.server.host={{ cred_store_server_host }}
-credential.store.server.port={{ cred_store_port }}
-credentialstore=org.apache.airavata.credential.store.server.CredentialStoreServer
-credential.stroe.jdbc.validationQuery=SELECT 1 from CONFIGURATION
-
-# 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=<location>/certificates/cacert.pem
-#bes.ca.key.path=<location>/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={{ monitor_email_address }}
-email.based.monitor.password={{ monitor_email_password }}
-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={{ rabbitmq_broker_url }}
-rabbitmq.status.exchange.name=status_exchange
-rabbitmq.process.exchange.name=process_exchange
-rabbitmq.experiment.exchange.name=experiment_exchange
-durable.queue=false
-prefetch.count=400
-process.launch.queue.name=process.launch.queue
-experiment.launch..queue.name=experiment.launch.queue
-
-###########################################################################
-# Zookeeper Server Configuration
-###########################################################################
-embedded.zk=false
-zookeeper.server.connection={{ zookeeper_connection_url }}
-zookeeper.timeout=30000
-
-########################################################################
-## API Security Configuration
-########################################################################
-api.secured={{ api_secured }}
-security.manager.class=org.apache.airavata.api.server.security.KeyCloakSecurityManager
-### TLS related configuration ####
-TLS.enabled={{ tls_enable }}
-TLS.api.server.port={{ api_server_tls_port }}
-TLS.client.timeout=10000
-#### keystore configuration ####
-keystore.path={{ keystores_location }}/{{ keystore_src_path | basename }}
-keystore.password={{ keystore_passwd }}
-#### trust store configuration ####
-trust.store={{ keystores_location }}/{{ client_truststore_src_path | basename }}
-trust.store.password={{ client_truststore_passwd }}
-#### authorization cache related configuration ####
-authz.cache.enabled=true
-authz.cache.manager.class=org.apache.airavata.service.security.authzcache.DefaultAuthzCacheManager
-in.memory.cache.size=1000
-
-###########################################################################
-# DB Event Manager Runner
-###########################################################################
-db_event_manager=org.apache.airavata.db.event.manager.DBEventManagerRunner
diff --git a/dev-tools/ansible/roles/gfac/templates/gfac-config.yaml.j2 b/dev-tools/ansible/roles/gfac/templates/gfac-config.yaml.j2
deleted file mode 100644
index 6c85772..0000000
--- a/dev-tools/ansible/roles/gfac/templates/gfac-config.yaml.j2
+++ /dev/null
@@ -1,145 +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.
-#
-################################################################
-
-jobSubmitters:
-  - submissionProtocol: SSH
-    taskClass: org.apache.airavata.gfac.impl.task.DefaultJobSubmissionTask
-#   properties:
-#     - userName: airavata
-#       passPhrase: airavata
-#       privateKey: /path/to/the/privatekey
-#       publicKey: /path/to/the/publickey
-#       hostName: remote.client.hostName
-
-  - submissionProtocol: SSH_FORK
-    taskClass: org.apache.airavata.gfac.impl.task.ForkJobSubmissionTask
-
-  - submissionProtocol: LOCAL
-    taskClass: org.apache.airavata.gfac.impl.task.DefaultJobSubmissionTask
-
-# Following job subbmitters are not yet implemented.
-
- # - submissionProtocol: GSISSH
- #   taskClass: org.apache.airavata.task.adapters.GSISSHJobSubmissionTask
-commonTasks:
-   - type: SETUP
-     taskClass: org.apache.airavata.task.common.SetupTask
-
-   - type: CLEANUP
-     taskClass: org.apache.airavata.task.common.CleanupTask
-
-fileTransferTasks:
-#  - transferProtocol: SCP
-#    taskClass: org.apache.airavata.gfac.impl.task.DataStageTask
-
-# If your client doen't run the same instance where airavata server is running then you need to comment above
-# DataStageTask and uncomment SCPDataStageTask. To work with SCPDataStageTask, you either need to
-# provide ssh keys or password.
-
-  - transferProtocol: SCP
-    taskClass: org.apache.airavata.gfac.impl.task.SCPDataStageTask
-    properties:
-     - userName: root
-       passPhrase: ultrascan 
-       privateKeyPath: /home/airavata/.ssh/id_rsa
-       publicKeyPath: /home/airavata/.ssh/id_rsa.pub
-       hostName: gw75.iu.xsede.org 
-       inputPath: /var/www/portal/experimentData/
-#      password: password
-
-# Following transfer tasks are not yet implemented.
-  #- transferProtocol: SFTP
-  #  taskClass: org.apache.airavata.task.adapters.SFTPFileTransferTask
-
-  #- transferProtocol: GRIDFTP
-  #  taskClass: org.apache.airavata.task.adapters.GRIDFTPFileTransferTask
-
-  #- transferProtocol: LOCAL
-  #  taskClass: org.apache.airavata.task.adapters.LocalFileTransferTask
-
-resources:
-  - jobManagerType: PBS
-    commandOutputParser: org.apache.airavata.gfac.impl.job.PBSOutputParser
-    emailParser: org.apache.airavata.gfac.monitor.email.parser.PBSEmailParser
-    resourceEmailAddresses:
-      - pbsconsult@sdsc.edu  # gordon
-      - adm@trident.bigred2.uits.iu.edu # Bigred2
-      - root <ad...@trident.bigred2.uits.iu.edu> # Bigred2
-      - root <ad...@scyld.localdomain> # alamo
-      - root <ad...@m2.karst.uits.iu.edu> #karst
-      - root <ad...@m1.mason.indiana.edu> #mason
-      - smic3 <sm...@mail.hpc.lsu.edu> # philip.hpc.lsu
-      - adm@jetstream-cloud.org
-      - adm <ad...@smic3.hpc.lsu.edu> #supermic
-      - root <ad...@alamo.uthscsa.edu> #alamo
-      - root <ad...@s1.carbonate.uits.iu.edu> #carbonate
-      - GW77 Job Emails <gw...@scigap.org> #gw77 email to fix email issues
-
-  - jobManagerType: SLURM
-    commandOutputParser: org.apache.airavata.gfac.impl.job.SlurmOutputParser
-    emailParser: org.apache.airavata.gfac.monitor.email.parser.SLURMEmailParser
-    resourceEmailAddresses:
-      - SDSC Admin <sl...@comet-fe3.sdsc.edu> # comet
-      - slurm@batch1.stampede.tacc.utexas.edu # stampede
-      - SDSC Admin <sl...@comet-fe4.sdsc.edu> # comet new
-      - slurm@comet-fe4.sdsc.edu
-      - Slurm <sl...@psc.edu> # bridges
-      - Slurm Daemon <sl...@odin.oscer.ou.edu> # OU Schooner
-      - slurm@lnet28.stampede.tacc.utexas.edu # stampede2
-      - Slurm service account <sl...@chpc.utah.edu> # Utah Ember
-      - SLURM workload manager <sl...@jetstream.chemcompute.org> # JS Mark Cluster
-      - root@master.ls5.tacc.utexas.edu
-      - batch-jsc@fz-juelich.de # Jureca Email
-      - Slurm <sl...@br003.pvt.bridges.psc.edu>
-      - slurm@jetstream-cloud.org
-      - slurm@slurm-example.novalocal
-      - slurm@tutorial-headnode.novalocal # Jetstream Ultrascan static cluster with 10 nodes
-      - slurm@batch1.stampede2.tacc.utexas.edu #Stampede2
-      - slurm@sra-master.jetstreamlocal #Searching SRA
-      - Slurm Admin <sl...@hpclogin01.rs.gsu.edu> #GSU cluster
-      - slurm@head.cluster #USD cluster
-      - slurm@js-169-158.jetstream-cloud.org
-      - slurm@joker.nmsu.edu
-      - SLURM resource manager <sl...@bigdawg.research.siu.edu> #Bigdawg
-      - SLURM resource manager <sl...@interactwel-slurm-headnode.novalocal> #InterACTWEL Jetstream
-      - slurm@zoar #R System cluster
-      - GW77 Job Emails <gw...@scigap.org> #gw77 email to fix email issues
-      - SLURM resource manager <sl...@seagrid-slurm-headnode.novalocal> #seagrid elastic cluster
-
-  - jobManagerType: UGE
-    commandOutputParser: org.apache.airavata.gfac.impl.job.UGEOutputParser
-    emailParser: org.apache.airavata.gfac.monitor.email.parser.UGEEmailParser
-    resourceEmailAddresses:
-      - ls4.tacc.utexas.edu # contain Lonestar
-      - root <ro...@local> # USD HPC Cluster
-      - root <li...@siu.edu> # SIU Little Dog
-      - sge@bigdog.research.siu.edu # SIU Big Dog
-      - root <ro...@legacy.usd.edu> # USD HPC Cluster
-
-
-  - jobManagerType: LSF
-    commandOutputParser: org.apache.airavata.gfac.impl.job.LSFOutputParser
-    emailParser: org.apache.airavata.gfac.monitor.email.parser.LSFEmailParser
-    resourceEmailAddresses:
-      - iu.xsede.edu # test resource mail address
-      - tcs.tulsahpc.org #Tandy
-
-  - jobManagerType: FORK
-    commandOutputParser: org.apache.airavata.gfac.impl.job.ForkOutputParser
diff --git a/dev-tools/ansible/roles/gfac/templates/logback.xml.j2 b/dev-tools/ansible/roles/gfac/templates/logback.xml.j2
deleted file mode 100644
index d796821..0000000
--- a/dev-tools/ansible/roles/gfac/templates/logback.xml.j2
+++ /dev/null
@@ -1,58 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-      http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing,
-    software distributed under the License is distributed on an
-    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-    KIND, either express or implied.  See the License for the
-    specific language governing permissions and limitations
-    under the License.
-
--->
-<configuration>
-    <appender name="CONSOLE" class="ch.qos.logback.core.ConsoleAppender">
-        <encoder>
-            <pattern>[%p] %m%n</pattern>
-        </encoder>
-    </appender>
-    <appender name="LOGFILE" class="ch.qos.logback.core.rolling.RollingFileAppender">
-        <!--See http://logback.qos.ch/manual/appenders.html#RollingFileAppender-->
-        <!--and http://logback.qos.ch/manual/appenders.html#TimeBasedRollingPolicy-->
-        <!--for further documentation-->
-        <File>{{ gfac_log_dir }}/airavata.log</File>
-        <Append>true</Append>
-        <encoder>
-            <pattern>%d [%t] %-5p %c{30} %X - %m%n</pattern>
-        </encoder>
-        <rollingPolicy class="ch.qos.logback.core.rolling.TimeBasedRollingPolicy">
-            <fileNamePattern>{{ gfac_log_dir }}/airavata.log.%d{yyyy-MM-dd}</fileNamePattern>
-            <!-- maxHistory is needed in order for totalSizeCap to be applied -->
-            <maxHistory>{{ gfac_log_max_history }}</maxHistory>
-            <totalSizeCap>{{ gfac_log_total_size_cap }}</totalSizeCap>
-        </rollingPolicy>
-    </appender>
-    <logger name="org.apache.zookeeper" level="ERROR"/>
-    <logger name="edu.internet2.middleware.grouper" level="ERROR"/>
-    <logger name="org.globus" level="INFO"/>
-    <logger name="org.apache.commons.httpclient" level="ERROR"/>
-    <logger name="org.apache.airavata" level="INFO"/>
-    <logger name="org.hibernate" level="ERROR"/>
-    <logger name="de.hunsicker.jalopy.io" level="ERROR"/>
-    <logger name="httpclient.wire.header" level="ERROR"/>
-    <logger name="org.apache.axis2.enterprise" level="ERROR"/>
-    <root level="INFO">
-        <!--<appender-ref ref="CONSOLE"/>-->
-        <appender-ref ref="LOGFILE"/>
-    </root>
-</configuration>