You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by ma...@apache.org on 2019/06/17 16:09:04 UTC

[airavata] branch develop updated: AIRAVATA-2990 Applying sharing to exp statistics

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

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


The following commit(s) were added to refs/heads/develop by this push:
     new 4e986b5  AIRAVATA-2990 Applying sharing to exp statistics
4e986b5 is described below

commit 4e986b5d5a5f2233eab2181a2b1ef1483946a294
Author: Marcus Christie <ma...@apache.org>
AuthorDate: Mon Jun 17 12:08:16 2019 -0400

    AIRAVATA-2990 Applying sharing to exp statistics
---
 .../api/server/handler/AiravataServerHandler.java  |   23 +-
 .../expcatalog/ExperimentSummaryRepository.java    |   44 +-
 .../ExperimentSummaryRepositoryTest.java           |   37 +-
 .../api/service/handler/RegistryServerHandler.java |   10 +-
 .../airavata/registry/api/RegistryService.java     | 2076 +++++++++++---------
 .../component-cpis/registry-api.thrift             |    5 +-
 6 files changed, 1197 insertions(+), 998 deletions(-)

diff --git a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
index 7ca4346..c20dbb6 100644
--- a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
+++ b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
@@ -1225,7 +1225,28 @@ public class AiravataServerHandler implements Airavata.Iface {
         RegistryService.Client regClient = registryClientPool.getResource();
         SharingRegistryService.Client sharingClient = sharingClientPool.getResource();
         try {
-            ExperimentStatistics result = regClient.getExperimentStatistics(gatewayId, fromTime, toTime, userName, applicationName, resourceHostName);
+            // Find accessible experiments in date range
+            List<String> accessibleExpIds = new ArrayList<>();
+            List<SearchCriteria> sharingFilters = new ArrayList<>();
+            SearchCriteria entityTypeCriteria = new SearchCriteria();
+            entityTypeCriteria.setSearchField(EntitySearchField.ENTITY_TYPE_ID);
+            entityTypeCriteria.setSearchCondition(SearchCondition.EQUAL);
+            entityTypeCriteria.setValue(gatewayId + ":EXPERIMENT");
+            sharingFilters.add(entityTypeCriteria);
+            SearchCriteria fromCreatedTimeCriteria = new SearchCriteria();
+            fromCreatedTimeCriteria.setSearchField(EntitySearchField.CREATED_TIME);
+            fromCreatedTimeCriteria.setSearchCondition(SearchCondition.GTE);
+            fromCreatedTimeCriteria.setValue(Long.toString(fromTime));
+            sharingFilters.add(fromCreatedTimeCriteria);
+            SearchCriteria toCreatedTimeCriteria = new SearchCriteria();
+            toCreatedTimeCriteria.setSearchField(EntitySearchField.CREATED_TIME);
+            toCreatedTimeCriteria.setSearchCondition(SearchCondition.LTE);
+            toCreatedTimeCriteria.setValue(Long.toString(toTime));
+            sharingFilters.add(toCreatedTimeCriteria);
+            sharingClient.searchEntities(authzToken.getClaimsMap().get(Constants.GATEWAY_ID),
+                    userName + "@" + gatewayId, sharingFilters, 0, -1).forEach(e -> accessibleExpIds.add(e.getEntityId()));
+
+            ExperimentStatistics result = regClient.getExperimentStatistics(gatewayId, fromTime, toTime, userName, applicationName, resourceHostName, accessibleExpIds);
             registryClientPool.returnResource(regClient);
             sharingClientPool.returnResource(sharingClient);
             return result;
diff --git a/modules/registry/registry-core/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepository.java b/modules/registry/registry-core/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepository.java
index ede596d..ca75d62 100644
--- a/modules/registry/registry-core/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepository.java
+++ b/modules/registry/registry-core/src/main/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepository.java
@@ -151,7 +151,7 @@ public class ExperimentSummaryRepository extends ExpCatAbstractRepository<Experi
         return experimentSummaryModelList;
     }
 
-    public ExperimentStatistics getExperimentStatistics(Map<String,String> filters) throws RegistryException {
+    public ExperimentStatistics getAccessibleExperimentStatistics(List<String> accessibleExperimentIds, Map<String,String> filters) throws RegistryException {
 
         try {
 
@@ -203,40 +203,42 @@ public class ExperimentSummaryRepository extends ExpCatAbstractRepository<Experi
             }
 
             List<ExperimentSummaryModel> allExperiments = getExperimentStatisticsForState(null, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName);
+                    fromDate, toDate, userName, applicationName, resourceHostName, accessibleExperimentIds);
             experimentStatistics.setAllExperimentCount(allExperiments.size());
             experimentStatistics.setAllExperiments(allExperiments);
 
             List<ExperimentSummaryModel> createdExperiments = getExperimentStatisticsForState(ExperimentState.CREATED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName);
+                    fromDate, toDate, userName, applicationName, resourceHostName, accessibleExperimentIds);
             createdExperiments.addAll(getExperimentStatisticsForState(ExperimentState.VALIDATED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName));
+                    fromDate, toDate, userName, applicationName, resourceHostName, accessibleExperimentIds));
             experimentStatistics.setCreatedExperimentCount(createdExperiments.size());
             experimentStatistics.setCreatedExperiments(createdExperiments);
 
             List<ExperimentSummaryModel> runningExperiments = getExperimentStatisticsForState(ExperimentState.EXECUTING, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName);
-            runningExperiments.addAll(getExperimentStatisticsForState(ExperimentState.SCHEDULED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName));
-            runningExperiments.addAll(getExperimentStatisticsForState(ExperimentState.LAUNCHED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName));
+                    fromDate, toDate, userName, applicationName, resourceHostName, accessibleExperimentIds);
+            runningExperiments.addAll(getExperimentStatisticsForState(ExperimentState.SCHEDULED, gatewayId, fromDate,
+                    toDate, userName, applicationName, resourceHostName, accessibleExperimentIds));
+            runningExperiments.addAll(getExperimentStatisticsForState(ExperimentState.LAUNCHED, gatewayId, fromDate,
+                    toDate, userName, applicationName, resourceHostName, accessibleExperimentIds));
             experimentStatistics.setRunningExperimentCount(runningExperiments.size());
             experimentStatistics.setRunningExperiments(runningExperiments);
 
-            List<ExperimentSummaryModel> completedExperiments = getExperimentStatisticsForState(ExperimentState.COMPLETED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName);
+            List<ExperimentSummaryModel> completedExperiments = getExperimentStatisticsForState(
+                    ExperimentState.COMPLETED, gatewayId, fromDate, toDate, userName, applicationName, resourceHostName,
+                    accessibleExperimentIds);
             experimentStatistics.setCompletedExperimentCount(completedExperiments.size());
             experimentStatistics.setCompletedExperiments(completedExperiments);
 
-            List<ExperimentSummaryModel> failedExperiments = getExperimentStatisticsForState(ExperimentState.FAILED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName);
+            List<ExperimentSummaryModel> failedExperiments = getExperimentStatisticsForState(ExperimentState.FAILED,
+                    gatewayId, fromDate, toDate, userName, applicationName, resourceHostName, accessibleExperimentIds);
             experimentStatistics.setFailedExperimentCount(failedExperiments.size());
             experimentStatistics.setFailedExperiments(failedExperiments);
 
-            List<ExperimentSummaryModel> cancelledExperiments = getExperimentStatisticsForState(ExperimentState.CANCELED, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName);
-            cancelledExperiments.addAll(getExperimentStatisticsForState(ExperimentState.CANCELING, gatewayId,
-                    fromDate, toDate, userName, applicationName, resourceHostName));
+            List<ExperimentSummaryModel> cancelledExperiments = getExperimentStatisticsForState(
+                    ExperimentState.CANCELED, gatewayId, fromDate, toDate, userName, applicationName, resourceHostName,
+                    accessibleExperimentIds);
+            cancelledExperiments.addAll(getExperimentStatisticsForState(ExperimentState.CANCELING, gatewayId, fromDate,
+                    toDate, userName, applicationName, resourceHostName, accessibleExperimentIds));
             experimentStatistics.setCancelledExperimentCount(cancelledExperiments.size());
             experimentStatistics.setCancelledExperiments(cancelledExperiments);
 
@@ -251,7 +253,7 @@ public class ExperimentSummaryRepository extends ExpCatAbstractRepository<Experi
     }
 
     protected List<ExperimentSummaryModel> getExperimentStatisticsForState(ExperimentState experimentState, String gatewayId, Timestamp fromDate, Timestamp toDate,
-                                                                           String userName, String applicationName, String resourceHostName) throws RegistryException, IllegalArgumentException {
+                                                                           String userName, String applicationName, String resourceHostName, List<String> experimentIds) throws RegistryException, IllegalArgumentException {
 
         String query = "SELECT ES FROM " + ExperimentSummaryEntity.class.getSimpleName() + " ES WHERE ";
         Map<String, Object> queryParameters = new HashMap<>();
@@ -290,6 +292,12 @@ public class ExperimentSummaryRepository extends ExpCatAbstractRepository<Experi
             query += "ES.executionId LIKE :" + DBConstants.Experiment.EXECUTION_ID + " AND ";
         }
 
+        if (experimentIds != null) {
+            logger.debug("Filter Experiments by experimentIds");
+            queryParameters.put(DBConstants.Experiment.EXPERIMENT_ID, experimentIds);
+            query += "ES.experimentId IN :" + DBConstants.Experiment.EXPERIMENT_ID + " AND ";
+        }
+
         if (resourceHostName != null) {
             logger.debug("Filter Experiments by ResourceHostName");
             queryParameters.put(DBConstants.Experiment.RESOURCE_HOST_ID, resourceHostName);
diff --git a/modules/registry/registry-core/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepositoryTest.java b/modules/registry/registry-core/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepositoryTest.java
index 51d5a74..0d3e6f4 100644
--- a/modules/registry/registry-core/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepositoryTest.java
+++ b/modules/registry/registry-core/src/test/java/org/apache/airavata/registry/core/repositories/expcatalog/ExperimentSummaryRepositoryTest.java
@@ -98,10 +98,10 @@ public class ExperimentSummaryRepositoryTest extends TestBase{
         // Reload experiment to get its status' identifier
         experimentModelOne = experimentRepository.getExperiment(experimentIdOne);
 
-        String expertimentIdTwo = experimentRepository.addExperiment(experimentModelTwo);
-        assertTrue(expertimentIdTwo != null);
+        String experimentIdTwo = experimentRepository.addExperiment(experimentModelTwo);
+        assertTrue(experimentIdTwo != null);
         // Reload experiment to get its status' identifier
-        experimentModelTwo = experimentRepository.getExperiment(expertimentIdTwo);
+        experimentModelTwo = experimentRepository.getExperiment(experimentIdTwo);
 
         Timestamp timeOne = Timestamp.valueOf("2010-01-01 09:00:00");
         experimentModelOne.setCreationTime(timeOne.getTime());
@@ -109,13 +109,13 @@ public class ExperimentSummaryRepositoryTest extends TestBase{
 
         Timestamp timeTwo = Timestamp.valueOf("2018-01-01 09:00:00");
         experimentModelTwo.setCreationTime(timeTwo.getTime());
-        experimentRepository.updateExperiment(experimentModelTwo, expertimentIdTwo);
+        experimentRepository.updateExperiment(experimentModelTwo, experimentIdTwo);
 
         Map<String, String> filters = new HashMap<>();
         filters.put(DBConstants.Experiment.GATEWAY_ID, gatewayId);
         filters.put(DBConstants.Experiment.PROJECT_ID, projectId);
 
-        List<String> allExperimentIds = Arrays.asList( experimentIdOne, expertimentIdTwo);
+        List<String> allExperimentIds = Arrays.asList( experimentIdOne, experimentIdTwo);
         List<ExperimentSummaryModel> experimentSummaryModelList = experimentSummaryRepository.
                 searchAllAccessibleExperiments(allExperimentIds, filters, -1, 0, null, null);
         assertEquals(2, experimentSummaryModelList.size());
@@ -125,7 +125,7 @@ public class ExperimentSummaryRepositoryTest extends TestBase{
         experimentSummaryModelList = experimentSummaryRepository.
                 searchAllAccessibleExperiments(allExperimentIds, filters, -1, 0, null, null);
         assertTrue(experimentSummaryModelList.size() == 1);
-        assertEquals(expertimentIdTwo, experimentSummaryModelList.get(0).getExperimentId());
+        assertEquals(experimentIdTwo, experimentSummaryModelList.get(0).getExperimentId());
 
         String fromDate = String.valueOf(Timestamp.valueOf("2010-10-10 09:00:00").getTime());
         String toDate = String.valueOf(System.currentTimeMillis());
@@ -135,7 +135,7 @@ public class ExperimentSummaryRepositoryTest extends TestBase{
         experimentSummaryModelList = experimentSummaryRepository.
                 searchAllAccessibleExperiments(allExperimentIds, filters, -1, 0, null, null);
         assertTrue(experimentSummaryModelList.size() == 1);
-        assertEquals(expertimentIdTwo, experimentSummaryModelList.get(0).getExperimentId());
+        assertEquals(experimentIdTwo, experimentSummaryModelList.get(0).getExperimentId());
 
         filters.remove(DBConstants.ExperimentSummary.FROM_DATE);
         filters.remove(DBConstants.ExperimentSummary.TO_DATE);
@@ -174,14 +174,14 @@ public class ExperimentSummaryRepositoryTest extends TestBase{
         filters.put(DBConstants.ExperimentSummary.FROM_DATE, fromDate);
         filters.put(DBConstants.ExperimentSummary.TO_DATE, toDate);
 
-        ExperimentStatistics experimentStatistics = experimentSummaryRepository.getExperimentStatistics(filters);
+        ExperimentStatistics experimentStatistics = experimentSummaryRepository.getAccessibleExperimentStatistics(allExperimentIds, filters);
         assertTrue(experimentStatistics.getAllExperimentCount() == 0);
 
         filters.remove(DBConstants.Experiment.RESOURCE_HOST_ID);
 
-        experimentStatistics = experimentSummaryRepository.getExperimentStatistics(filters);
+        experimentStatistics = experimentSummaryRepository.getAccessibleExperimentStatistics(allExperimentIds, filters);
         assertTrue(experimentStatistics.getAllExperimentCount() == 1);
-        assertEquals(experimentStatistics.getAllExperiments().get(0).getExperimentId(), expertimentIdTwo);
+        assertEquals(experimentStatistics.getAllExperiments().get(0).getExperimentId(), experimentIdTwo);
 
         filters.remove(DBConstants.Experiment.USER_NAME);
         filters.remove(DBConstants.Experiment.EXECUTION_ID);
@@ -191,23 +191,30 @@ public class ExperimentSummaryRepositoryTest extends TestBase{
         assertTrue(statusIdOne != null);
 
         ExperimentStatus experimentStatusTwo = new ExperimentStatus(ExperimentState.EXECUTING);
-        String statusIdTwo = experimentStatusRepository.addExperimentStatus(experimentStatusTwo, expertimentIdTwo);
+        String statusIdTwo = experimentStatusRepository.addExperimentStatus(experimentStatusTwo, experimentIdTwo);
         assertTrue(statusIdTwo != null);
 
-        experimentStatistics = experimentSummaryRepository.getExperimentStatistics(filters);
+        experimentStatistics = experimentSummaryRepository.getAccessibleExperimentStatistics(allExperimentIds, filters);
         assertTrue(experimentStatistics.getAllExperimentCount() == 1);
         assertTrue(experimentStatistics.getRunningExperimentCount() == 1);
-        assertEquals(expertimentIdTwo, experimentStatistics.getAllExperiments().get(0).getExperimentId());
+        assertEquals(experimentIdTwo, experimentStatistics.getAllExperiments().get(0).getExperimentId());
 
         filters.remove(DBConstants.ExperimentSummary.FROM_DATE);
         filters.remove(DBConstants.ExperimentSummary.TO_DATE);
 
-        experimentStatistics = experimentSummaryRepository.getExperimentStatistics(filters);
+        experimentStatistics = experimentSummaryRepository.getAccessibleExperimentStatistics(allExperimentIds, filters);
         assertTrue(experimentStatistics.getAllExperimentCount() == 2);
         assertTrue(experimentStatistics.getCreatedExperimentCount() == 1);
+        assertTrue(experimentStatistics.getRunningExperimentCount() == 1);
+
+        // Experiment 2 is EXECUTING and should be the only one returned
+        experimentStatistics = experimentSummaryRepository.getAccessibleExperimentStatistics(Collections.singletonList(experimentIdTwo), filters);
+        assertTrue(experimentStatistics.getAllExperimentCount() == 1);
+        assertTrue(experimentStatistics.getCreatedExperimentCount() == 0);
+        assertTrue(experimentStatistics.getRunningExperimentCount() == 1);
 
         experimentRepository.removeExperiment(experimentIdOne);
-        experimentRepository.removeExperiment(expertimentIdTwo);
+        experimentRepository.removeExperiment(experimentIdTwo);
 
         gatewayRepository.removeGateway(gatewayId);
         projectRepository.removeProject(projectId);
diff --git a/modules/registry/registry-server/registry-api-service/src/main/java/org/apache/airavata/registry/api/service/handler/RegistryServerHandler.java b/modules/registry/registry-server/registry-api-service/src/main/java/org/apache/airavata/registry/api/service/handler/RegistryServerHandler.java
index 8f66d1c..9667f0e 100644
--- a/modules/registry/registry-server/registry-api-service/src/main/java/org/apache/airavata/registry/api/service/handler/RegistryServerHandler.java
+++ b/modules/registry/registry-server/registry-api-service/src/main/java/org/apache/airavata/registry/api/service/handler/RegistryServerHandler.java
@@ -439,13 +439,17 @@ public class RegistryServerHandler implements RegistryService.Iface {
      * @param toTime    Ending data time.
      */
     @Override
-    public ExperimentStatistics getExperimentStatistics(String gatewayId, long fromTime, long toTime, String userName, String applicationName, String resourceHostName) throws RegistryServiceException, TException {
+    public ExperimentStatistics getExperimentStatistics(String gatewayId, long fromTime, long toTime, String userName, String applicationName, String resourceHostName, List<String> accessibleExpIds) throws RegistryServiceException, TException {
         if (!isGatewayExistInternal(gatewayId)){
             logger.error("Gateway does not exist.Please provide a valid gateway id...");
             throw new AiravataSystemException(AiravataErrorType.INTERNAL_ERROR);
         }
+        if (accessibleExpIds == null) {
+            logger.debug("accessibleExpIds is null, defaulting to an empty list");
+            accessibleExpIds = Collections.emptyList();
+        }
         try {
-            Map<String, String> filters = new HashMap();
+            Map<String, String> filters = new HashMap<>();
             filters.put(Constants.FieldConstants.ExperimentConstants.GATEWAY_ID, gatewayId);
             filters.put(Constants.FieldConstants.ExperimentConstants.FROM_DATE, fromTime+"");
             filters.put(Constants.FieldConstants.ExperimentConstants.TO_DATE, toTime+"");
@@ -459,7 +463,7 @@ public class RegistryServerHandler implements RegistryService.Iface {
                 filters.put(Constants.FieldConstants.ExperimentConstants.RESOURCE_HOST_ID, resourceHostName);
             }
 
-            ExperimentStatistics result = experimentSummaryRepository.getExperimentStatistics(filters);
+            ExperimentStatistics result = experimentSummaryRepository.getAccessibleExperimentStatistics(accessibleExpIds, filters);
             logger.debug("Airavata retrieved experiments for gateway id : " + gatewayId + " between : " + AiravataUtils.getTime(fromTime) + " and " + AiravataUtils.getTime(toTime));
             return result;
         }catch (Exception e) {
diff --git a/modules/registry/registry-server/registry-api-stubs/src/main/java/org/apache/airavata/registry/api/RegistryService.java b/modules/registry/registry-server/registry-api-stubs/src/main/java/org/apache/airavata/registry/api/RegistryService.java
index c61b31e..caa4753 100644
--- a/modules/registry/registry-server/registry-api-stubs/src/main/java/org/apache/airavata/registry/api/RegistryService.java
+++ b/modules/registry/registry-server/registry-api-stubs/src/main/java/org/apache/airavata/registry/api/RegistryService.java
@@ -348,6 +348,8 @@ public class RegistryService {
      * @param resourceHostName
      *       Hostname id substring with which to further filter statistics.
      * 
+     * @param accessibleExpIds
+     *    Experiment IDs which are accessible to the current user.
      * 
      * 
      * @param gatewayId
@@ -356,8 +358,9 @@ public class RegistryService {
      * @param userName
      * @param applicationName
      * @param resourceHostName
+     * @param accessibleExpIds
      */
-    public org.apache.airavata.model.experiment.ExperimentStatistics getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName) throws org.apache.airavata.registry.api.exception.RegistryServiceException, org.apache.thrift.TException;
+    public org.apache.airavata.model.experiment.ExperimentStatistics getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, java.util.List<java.lang.String> accessibleExpIds) throws org.apache.airavata.registry.api.exception.RegistryServiceException, org.apache.thrift.TException;
 
     /**
      * 
@@ -2647,7 +2650,7 @@ public class RegistryService {
 
     public void searchExperiments(java.lang.String gatewayId, java.lang.String userName, java.util.List<java.lang.String> accessibleExpIds, java.util.Map<org.apache.airavata.model.experiment.ExperimentSearchFields,java.lang.String> filters, int limit, int offset, org.apache.thrift.async.AsyncMethodCallback<java.util.List<org.apache.airavata.model.experiment.ExperimentSummaryModel>> resultHandler) throws org.apache.thrift.TException;
 
-    public void getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler) throws org.apache.thrift.TException;
+    public void getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, java.util.List<java.lang.String> accessibleExpIds, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler) throws org.apache.thrift.TException;
 
     public void getExperimentsInProject(java.lang.String gatewayId, java.lang.String projectId, int limit, int offset, org.apache.thrift.async.AsyncMethodCallback<java.util.List<org.apache.airavata.model.experiment.ExperimentModel>> resultHandler) throws org.apache.thrift.TException;
 
@@ -3564,13 +3567,13 @@ public class RegistryService {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "searchExperiments failed: unknown result");
     }
 
-    public org.apache.airavata.model.experiment.ExperimentStatistics getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName) throws org.apache.airavata.registry.api.exception.RegistryServiceException, org.apache.thrift.TException
+    public org.apache.airavata.model.experiment.ExperimentStatistics getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, java.util.List<java.lang.String> accessibleExpIds) throws org.apache.airavata.registry.api.exception.RegistryServiceException, org.apache.thrift.TException
     {
-      send_getExperimentStatistics(gatewayId, fromTime, toTime, userName, applicationName, resourceHostName);
+      send_getExperimentStatistics(gatewayId, fromTime, toTime, userName, applicationName, resourceHostName, accessibleExpIds);
       return recv_getExperimentStatistics();
     }
 
-    public void send_getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName) throws org.apache.thrift.TException
+    public void send_getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, java.util.List<java.lang.String> accessibleExpIds) throws org.apache.thrift.TException
     {
       getExperimentStatistics_args args = new getExperimentStatistics_args();
       args.setGatewayId(gatewayId);
@@ -3579,6 +3582,7 @@ public class RegistryService {
       args.setUserName(userName);
       args.setApplicationName(applicationName);
       args.setResourceHostName(resourceHostName);
+      args.setAccessibleExpIds(accessibleExpIds);
       sendBase("getExperimentStatistics", args);
     }
 
@@ -8907,9 +8911,9 @@ public class RegistryService {
       }
     }
 
-    public void getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler) throws org.apache.thrift.TException {
+    public void getExperimentStatistics(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, java.util.List<java.lang.String> accessibleExpIds, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler) throws org.apache.thrift.TException {
       checkReady();
-      getExperimentStatistics_call method_call = new getExperimentStatistics_call(gatewayId, fromTime, toTime, userName, applicationName, resourceHostName, resultHandler, this, ___protocolFactory, ___transport);
+      getExperimentStatistics_call method_call = new getExperimentStatistics_call(gatewayId, fromTime, toTime, userName, applicationName, resourceHostName, accessibleExpIds, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
       ___manager.call(method_call);
     }
@@ -8921,7 +8925,8 @@ public class RegistryService {
       private java.lang.String userName;
       private java.lang.String applicationName;
       private java.lang.String resourceHostName;
-      public getExperimentStatistics_call(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.ap [...]
+      private java.util.List<java.lang.String> accessibleExpIds;
+      public getExperimentStatistics_call(java.lang.String gatewayId, long fromTime, long toTime, java.lang.String userName, java.lang.String applicationName, java.lang.String resourceHostName, java.util.List<java.lang.String> accessibleExpIds, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.trans [...]
         super(client, protocolFactory, transport, resultHandler, false);
         this.gatewayId = gatewayId;
         this.fromTime = fromTime;
@@ -8929,6 +8934,7 @@ public class RegistryService {
         this.userName = userName;
         this.applicationName = applicationName;
         this.resourceHostName = resourceHostName;
+        this.accessibleExpIds = accessibleExpIds;
       }
 
       public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
@@ -8940,6 +8946,7 @@ public class RegistryService {
         args.setUserName(userName);
         args.setApplicationName(applicationName);
         args.setResourceHostName(resourceHostName);
+        args.setAccessibleExpIds(accessibleExpIds);
         args.write(prot);
         prot.writeMessageEnd();
       }
@@ -15589,7 +15596,7 @@ public class RegistryService {
       public getExperimentStatistics_result getResult(I iface, getExperimentStatistics_args args) throws org.apache.thrift.TException {
         getExperimentStatistics_result result = new getExperimentStatistics_result();
         try {
-          result.success = iface.getExperimentStatistics(args.gatewayId, args.fromTime, args.toTime, args.userName, args.applicationName, args.resourceHostName);
+          result.success = iface.getExperimentStatistics(args.gatewayId, args.fromTime, args.toTime, args.userName, args.applicationName, args.resourceHostName, args.accessibleExpIds);
         } catch (org.apache.airavata.registry.api.exception.RegistryServiceException rse) {
           result.rse = rse;
         }
@@ -21415,7 +21422,7 @@ public class RegistryService {
       }
 
       public void start(I iface, getExperimentStatistics_args args, org.apache.thrift.async.AsyncMethodCallback<org.apache.airavata.model.experiment.ExperimentStatistics> resultHandler) throws org.apache.thrift.TException {
-        iface.getExperimentStatistics(args.gatewayId, args.fromTime, args.toTime, args.userName, args.applicationName, args.resourceHostName,resultHandler);
+        iface.getExperimentStatistics(args.gatewayId, args.fromTime, args.toTime, args.userName, args.applicationName, args.resourceHostName, args.accessibleExpIds,resultHandler);
       }
     }
 
@@ -51884,6 +51891,7 @@ public class RegistryService {
     private static final org.apache.thrift.protocol.TField USER_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("userName", org.apache.thrift.protocol.TType.STRING, (short)4);
     private static final org.apache.thrift.protocol.TField APPLICATION_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("applicationName", org.apache.thrift.protocol.TType.STRING, (short)5);
     private static final org.apache.thrift.protocol.TField RESOURCE_HOST_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("resourceHostName", org.apache.thrift.protocol.TType.STRING, (short)6);
+    private static final org.apache.thrift.protocol.TField ACCESSIBLE_EXP_IDS_FIELD_DESC = new org.apache.thrift.protocol.TField("accessibleExpIds", org.apache.thrift.protocol.TType.LIST, (short)7);
 
     private static final org.apache.thrift.scheme.SchemeFactory STANDARD_SCHEME_FACTORY = new getExperimentStatistics_argsStandardSchemeFactory();
     private static final org.apache.thrift.scheme.SchemeFactory TUPLE_SCHEME_FACTORY = new getExperimentStatistics_argsTupleSchemeFactory();
@@ -51894,6 +51902,7 @@ public class RegistryService {
     public java.lang.String userName; // required
     public java.lang.String applicationName; // required
     public java.lang.String resourceHostName; // required
+    public java.util.List<java.lang.String> accessibleExpIds; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements org.apache.thrift.TFieldIdEnum {
@@ -51902,7 +51911,8 @@ public class RegistryService {
       TO_TIME((short)3, "toTime"),
       USER_NAME((short)4, "userName"),
       APPLICATION_NAME((short)5, "applicationName"),
-      RESOURCE_HOST_NAME((short)6, "resourceHostName");
+      RESOURCE_HOST_NAME((short)6, "resourceHostName"),
+      ACCESSIBLE_EXP_IDS((short)7, "accessibleExpIds");
 
       private static final java.util.Map<java.lang.String, _Fields> byName = new java.util.HashMap<java.lang.String, _Fields>();
 
@@ -51929,6 +51939,8 @@ public class RegistryService {
             return APPLICATION_NAME;
           case 6: // RESOURCE_HOST_NAME
             return RESOURCE_HOST_NAME;
+          case 7: // ACCESSIBLE_EXP_IDS
+            return ACCESSIBLE_EXP_IDS;
           default:
             return null;
         }
@@ -51987,6 +51999,9 @@ public class RegistryService {
           new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
       tmpMap.put(_Fields.RESOURCE_HOST_NAME, new org.apache.thrift.meta_data.FieldMetaData("resourceHostName", org.apache.thrift.TFieldRequirementType.DEFAULT, 
           new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
+      tmpMap.put(_Fields.ACCESSIBLE_EXP_IDS, new org.apache.thrift.meta_data.FieldMetaData("accessibleExpIds", org.apache.thrift.TFieldRequirementType.REQUIRED, 
+          new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, 
+              new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING))));
       metaDataMap = java.util.Collections.unmodifiableMap(tmpMap);
       org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(getExperimentStatistics_args.class, metaDataMap);
     }
@@ -52000,7 +52015,8 @@ public class RegistryService {
       long toTime,
       java.lang.String userName,
       java.lang.String applicationName,
-      java.lang.String resourceHostName)
+      java.lang.String resourceHostName,
+      java.util.List<java.lang.String> accessibleExpIds)
     {
       this();
       this.gatewayId = gatewayId;
@@ -52011,6 +52027,7 @@ public class RegistryService {
       this.userName = userName;
       this.applicationName = applicationName;
       this.resourceHostName = resourceHostName;
+      this.accessibleExpIds = accessibleExpIds;
     }
 
     /**
@@ -52032,6 +52049,10 @@ public class RegistryService {
       if (other.isSetResourceHostName()) {
         this.resourceHostName = other.resourceHostName;
       }
+      if (other.isSetAccessibleExpIds()) {
+        java.util.List<java.lang.String> __this__accessibleExpIds = new java.util.ArrayList<java.lang.String>(other.accessibleExpIds);
+        this.accessibleExpIds = __this__accessibleExpIds;
+      }
     }
 
     public getExperimentStatistics_args deepCopy() {
@@ -52048,6 +52069,7 @@ public class RegistryService {
       this.userName = null;
       this.applicationName = null;
       this.resourceHostName = null;
+      this.accessibleExpIds = null;
     }
 
     public java.lang.String getGatewayId() {
@@ -52192,6 +52214,45 @@ public class RegistryService {
       }
     }
 
+    public int getAccessibleExpIdsSize() {
+      return (this.accessibleExpIds == null) ? 0 : this.accessibleExpIds.size();
+    }
+
+    public java.util.Iterator<java.lang.String> getAccessibleExpIdsIterator() {
+      return (this.accessibleExpIds == null) ? null : this.accessibleExpIds.iterator();
+    }
+
+    public void addToAccessibleExpIds(java.lang.String elem) {
+      if (this.accessibleExpIds == null) {
+        this.accessibleExpIds = new java.util.ArrayList<java.lang.String>();
+      }
+      this.accessibleExpIds.add(elem);
+    }
+
+    public java.util.List<java.lang.String> getAccessibleExpIds() {
+      return this.accessibleExpIds;
+    }
+
+    public getExperimentStatistics_args setAccessibleExpIds(java.util.List<java.lang.String> accessibleExpIds) {
+      this.accessibleExpIds = accessibleExpIds;
+      return this;
+    }
+
+    public void unsetAccessibleExpIds() {
+      this.accessibleExpIds = null;
+    }
+
+    /** Returns true if field accessibleExpIds is set (has been assigned a value) and false otherwise */
+    public boolean isSetAccessibleExpIds() {
+      return this.accessibleExpIds != null;
+    }
+
+    public void setAccessibleExpIdsIsSet(boolean value) {
+      if (!value) {
+        this.accessibleExpIds = null;
+      }
+    }
+
     public void setFieldValue(_Fields field, java.lang.Object value) {
       switch (field) {
       case GATEWAY_ID:
@@ -52242,6 +52303,14 @@ public class RegistryService {
         }
         break;
 
+      case ACCESSIBLE_EXP_IDS:
+        if (value == null) {
+          unsetAccessibleExpIds();
+        } else {
+          setAccessibleExpIds((java.util.List<java.lang.String>)value);
+        }
+        break;
+
       }
     }
 
@@ -52265,6 +52334,9 @@ public class RegistryService {
       case RESOURCE_HOST_NAME:
         return getResourceHostName();
 
+      case ACCESSIBLE_EXP_IDS:
+        return getAccessibleExpIds();
+
       }
       throw new java.lang.IllegalStateException();
     }
@@ -52288,6 +52360,8 @@ public class RegistryService {
         return isSetApplicationName();
       case RESOURCE_HOST_NAME:
         return isSetResourceHostName();
+      case ACCESSIBLE_EXP_IDS:
+        return isSetAccessibleExpIds();
       }
       throw new java.lang.IllegalStateException();
     }
@@ -52361,6 +52435,15 @@ public class RegistryService {
           return false;
       }
 
+      boolean this_present_accessibleExpIds = true && this.isSetAccessibleExpIds();
+      boolean that_present_accessibleExpIds = true && that.isSetAccessibleExpIds();
+      if (this_present_accessibleExpIds || that_present_accessibleExpIds) {
+        if (!(this_present_accessibleExpIds && that_present_accessibleExpIds))
+          return false;
+        if (!this.accessibleExpIds.equals(that.accessibleExpIds))
+          return false;
+      }
+
       return true;
     }
 
@@ -52388,6 +52471,10 @@ public class RegistryService {
       if (isSetResourceHostName())
         hashCode = hashCode * 8191 + resourceHostName.hashCode();
 
+      hashCode = hashCode * 8191 + ((isSetAccessibleExpIds()) ? 131071 : 524287);
+      if (isSetAccessibleExpIds())
+        hashCode = hashCode * 8191 + accessibleExpIds.hashCode();
+
       return hashCode;
     }
 
@@ -52459,6 +52546,16 @@ public class RegistryService {
           return lastComparison;
         }
       }
+      lastComparison = java.lang.Boolean.valueOf(isSetAccessibleExpIds()).compareTo(other.isSetAccessibleExpIds());
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+      if (isSetAccessibleExpIds()) {
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.accessibleExpIds, other.accessibleExpIds);
+        if (lastComparison != 0) {
+          return lastComparison;
+        }
+      }
       return 0;
     }
 
@@ -52518,6 +52615,14 @@ public class RegistryService {
         sb.append(this.resourceHostName);
       }
       first = false;
+      if (!first) sb.append(", ");
+      sb.append("accessibleExpIds:");
+      if (this.accessibleExpIds == null) {
+        sb.append("null");
+      } else {
+        sb.append(this.accessibleExpIds);
+      }
+      first = false;
       sb.append(")");
       return sb.toString();
     }
@@ -52529,6 +52634,9 @@ public class RegistryService {
       }
       // alas, we cannot check 'fromTime' because it's a primitive and you chose the non-beans generator.
       // alas, we cannot check 'toTime' because it's a primitive and you chose the non-beans generator.
+      if (accessibleExpIds == null) {
+        throw new org.apache.thrift.protocol.TProtocolException("Required field 'accessibleExpIds' was not present! Struct: " + toString());
+      }
       // check for sub-struct validity
     }
 
@@ -52616,6 +52724,24 @@ public class RegistryService {
                 org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
               }
               break;
+            case 7: // ACCESSIBLE_EXP_IDS
+              if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
+                {
+                  org.apache.thrift.protocol.TList _list84 = iprot.readListBegin();
+                  struct.accessibleExpIds = new java.util.ArrayList<java.lang.String>(_list84.size);
+                  java.lang.String _elem85;
+                  for (int _i86 = 0; _i86 < _list84.size; ++_i86)
+                  {
+                    _elem85 = iprot.readString();
+                    struct.accessibleExpIds.add(_elem85);
+                  }
+                  iprot.readListEnd();
+                }
+                struct.setAccessibleExpIdsIsSet(true);
+              } else { 
+                org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+              }
+              break;
             default:
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
           }
@@ -52663,6 +52789,18 @@ public class RegistryService {
           oprot.writeString(struct.resourceHostName);
           oprot.writeFieldEnd();
         }
+        if (struct.accessibleExpIds != null) {
+          oprot.writeFieldBegin(ACCESSIBLE_EXP_IDS_FIELD_DESC);
+          {
+            oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleExpIds.size()));
+            for (java.lang.String _iter87 : struct.accessibleExpIds)
+            {
+              oprot.writeString(_iter87);
+            }
+            oprot.writeListEnd();
+          }
+          oprot.writeFieldEnd();
+        }
         oprot.writeFieldStop();
         oprot.writeStructEnd();
       }
@@ -52683,6 +52821,13 @@ public class RegistryService {
         oprot.writeString(struct.gatewayId);
         oprot.writeI64(struct.fromTime);
         oprot.writeI64(struct.toTime);
+        {
+          oprot.writeI32(struct.accessibleExpIds.size());
+          for (java.lang.String _iter88 : struct.accessibleExpIds)
+          {
+            oprot.writeString(_iter88);
+          }
+        }
         java.util.BitSet optionals = new java.util.BitSet();
         if (struct.isSetUserName()) {
           optionals.set(0);
@@ -52714,6 +52859,17 @@ public class RegistryService {
         struct.setFromTimeIsSet(true);
         struct.toTime = iprot.readI64();
         struct.setToTimeIsSet(true);
+        {
+          org.apache.thrift.protocol.TList _list89 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleExpIds = new java.util.ArrayList<java.lang.String>(_list89.size);
+          java.lang.String _elem90;
+          for (int _i91 = 0; _i91 < _list89.size; ++_i91)
+          {
+            _elem90 = iprot.readString();
+            struct.accessibleExpIds.add(_elem90);
+          }
+        }
+        struct.setAccessibleExpIdsIsSet(true);
         java.util.BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           struct.userName = iprot.readString();
@@ -54329,14 +54485,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list84 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list84.size);
-                  org.apache.airavata.model.experiment.ExperimentModel _elem85;
-                  for (int _i86 = 0; _i86 < _list84.size; ++_i86)
+                  org.apache.thrift.protocol.TList _list92 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list92.size);
+                  org.apache.airavata.model.experiment.ExperimentModel _elem93;
+                  for (int _i94 = 0; _i94 < _list92.size; ++_i94)
                   {
-                    _elem85 = new org.apache.airavata.model.experiment.ExperimentModel();
-                    _elem85.read(iprot);
-                    struct.success.add(_elem85);
+                    _elem93 = new org.apache.airavata.model.experiment.ExperimentModel();
+                    _elem93.read(iprot);
+                    struct.success.add(_elem93);
                   }
                   iprot.readListEnd();
                 }
@@ -54382,9 +54538,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.experiment.ExperimentModel _iter87 : struct.success)
+            for (org.apache.airavata.model.experiment.ExperimentModel _iter95 : struct.success)
             {
-              _iter87.write(oprot);
+              _iter95.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -54431,9 +54587,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.experiment.ExperimentModel _iter88 : struct.success)
+            for (org.apache.airavata.model.experiment.ExperimentModel _iter96 : struct.success)
             {
-              _iter88.write(oprot);
+              _iter96.write(oprot);
             }
           }
         }
@@ -54451,14 +54607,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list89 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list89.size);
-            org.apache.airavata.model.experiment.ExperimentModel _elem90;
-            for (int _i91 = 0; _i91 < _list89.size; ++_i91)
+            org.apache.thrift.protocol.TList _list97 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list97.size);
+            org.apache.airavata.model.experiment.ExperimentModel _elem98;
+            for (int _i99 = 0; _i99 < _list97.size; ++_i99)
             {
-              _elem90 = new org.apache.airavata.model.experiment.ExperimentModel();
-              _elem90.read(iprot);
-              struct.success.add(_elem90);
+              _elem98 = new org.apache.airavata.model.experiment.ExperimentModel();
+              _elem98.read(iprot);
+              struct.success.add(_elem98);
             }
           }
           struct.setSuccessIsSet(true);
@@ -55521,14 +55677,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list92 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list92.size);
-                  org.apache.airavata.model.experiment.ExperimentModel _elem93;
-                  for (int _i94 = 0; _i94 < _list92.size; ++_i94)
+                  org.apache.thrift.protocol.TList _list100 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list100.size);
+                  org.apache.airavata.model.experiment.ExperimentModel _elem101;
+                  for (int _i102 = 0; _i102 < _list100.size; ++_i102)
                   {
-                    _elem93 = new org.apache.airavata.model.experiment.ExperimentModel();
-                    _elem93.read(iprot);
-                    struct.success.add(_elem93);
+                    _elem101 = new org.apache.airavata.model.experiment.ExperimentModel();
+                    _elem101.read(iprot);
+                    struct.success.add(_elem101);
                   }
                   iprot.readListEnd();
                 }
@@ -55565,9 +55721,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.experiment.ExperimentModel _iter95 : struct.success)
+            for (org.apache.airavata.model.experiment.ExperimentModel _iter103 : struct.success)
             {
-              _iter95.write(oprot);
+              _iter103.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -55606,9 +55762,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.experiment.ExperimentModel _iter96 : struct.success)
+            for (org.apache.airavata.model.experiment.ExperimentModel _iter104 : struct.success)
             {
-              _iter96.write(oprot);
+              _iter104.write(oprot);
             }
           }
         }
@@ -55623,14 +55779,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list97 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list97.size);
-            org.apache.airavata.model.experiment.ExperimentModel _elem98;
-            for (int _i99 = 0; _i99 < _list97.size; ++_i99)
+            org.apache.thrift.protocol.TList _list105 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.experiment.ExperimentModel>(_list105.size);
+            org.apache.airavata.model.experiment.ExperimentModel _elem106;
+            for (int _i107 = 0; _i107 < _list105.size; ++_i107)
             {
-              _elem98 = new org.apache.airavata.model.experiment.ExperimentModel();
-              _elem98.read(iprot);
-              struct.success.add(_elem98);
+              _elem106 = new org.apache.airavata.model.experiment.ExperimentModel();
+              _elem106.read(iprot);
+              struct.success.add(_elem106);
             }
           }
           struct.setSuccessIsSet(true);
@@ -63608,14 +63764,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list100 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list100.size);
-                  org.apache.airavata.model.application.io.OutputDataObjectType _elem101;
-                  for (int _i102 = 0; _i102 < _list100.size; ++_i102)
+                  org.apache.thrift.protocol.TList _list108 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list108.size);
+                  org.apache.airavata.model.application.io.OutputDataObjectType _elem109;
+                  for (int _i110 = 0; _i110 < _list108.size; ++_i110)
                   {
-                    _elem101 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-                    _elem101.read(iprot);
-                    struct.success.add(_elem101);
+                    _elem109 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+                    _elem109.read(iprot);
+                    struct.success.add(_elem109);
                   }
                   iprot.readListEnd();
                 }
@@ -63661,9 +63817,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter103 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter111 : struct.success)
             {
-              _iter103.write(oprot);
+              _iter111.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -63710,9 +63866,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter104 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter112 : struct.success)
             {
-              _iter104.write(oprot);
+              _iter112.write(oprot);
             }
           }
         }
@@ -63730,14 +63886,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list105 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list105.size);
-            org.apache.airavata.model.application.io.OutputDataObjectType _elem106;
-            for (int _i107 = 0; _i107 < _list105.size; ++_i107)
+            org.apache.thrift.protocol.TList _list113 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list113.size);
+            org.apache.airavata.model.application.io.OutputDataObjectType _elem114;
+            for (int _i115 = 0; _i115 < _list113.size; ++_i115)
             {
-              _elem106 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-              _elem106.read(iprot);
-              struct.success.add(_elem106);
+              _elem114 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+              _elem114.read(iprot);
+              struct.success.add(_elem114);
             }
           }
           struct.setSuccessIsSet(true);
@@ -64591,14 +64747,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list108 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list108.size);
-                  org.apache.airavata.model.application.io.OutputDataObjectType _elem109;
-                  for (int _i110 = 0; _i110 < _list108.size; ++_i110)
+                  org.apache.thrift.protocol.TList _list116 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list116.size);
+                  org.apache.airavata.model.application.io.OutputDataObjectType _elem117;
+                  for (int _i118 = 0; _i118 < _list116.size; ++_i118)
                   {
-                    _elem109 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-                    _elem109.read(iprot);
-                    struct.success.add(_elem109);
+                    _elem117 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+                    _elem117.read(iprot);
+                    struct.success.add(_elem117);
                   }
                   iprot.readListEnd();
                 }
@@ -64644,9 +64800,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter111 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter119 : struct.success)
             {
-              _iter111.write(oprot);
+              _iter119.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -64693,9 +64849,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter112 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter120 : struct.success)
             {
-              _iter112.write(oprot);
+              _iter120.write(oprot);
             }
           }
         }
@@ -64713,14 +64869,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list113 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list113.size);
-            org.apache.airavata.model.application.io.OutputDataObjectType _elem114;
-            for (int _i115 = 0; _i115 < _list113.size; ++_i115)
+            org.apache.thrift.protocol.TList _list121 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list121.size);
+            org.apache.airavata.model.application.io.OutputDataObjectType _elem122;
+            for (int _i123 = 0; _i123 < _list121.size; ++_i123)
             {
-              _elem114 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-              _elem114.read(iprot);
-              struct.success.add(_elem114);
+              _elem122 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+              _elem122.read(iprot);
+              struct.success.add(_elem122);
             }
           }
           struct.setSuccessIsSet(true);
@@ -65579,16 +65735,16 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map116 = iprot.readMapBegin();
-                  struct.success = new java.util.HashMap<java.lang.String,org.apache.airavata.model.status.JobStatus>(2*_map116.size);
-                  java.lang.String _key117;
-                  org.apache.airavata.model.status.JobStatus _val118;
-                  for (int _i119 = 0; _i119 < _map116.size; ++_i119)
+                  org.apache.thrift.protocol.TMap _map124 = iprot.readMapBegin();
+                  struct.success = new java.util.HashMap<java.lang.String,org.apache.airavata.model.status.JobStatus>(2*_map124.size);
+                  java.lang.String _key125;
+                  org.apache.airavata.model.status.JobStatus _val126;
+                  for (int _i127 = 0; _i127 < _map124.size; ++_i127)
                   {
-                    _key117 = iprot.readString();
-                    _val118 = new org.apache.airavata.model.status.JobStatus();
-                    _val118.read(iprot);
-                    struct.success.put(_key117, _val118);
+                    _key125 = iprot.readString();
+                    _val126 = new org.apache.airavata.model.status.JobStatus();
+                    _val126.read(iprot);
+                    struct.success.put(_key125, _val126);
                   }
                   iprot.readMapEnd();
                 }
@@ -65634,10 +65790,10 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (java.util.Map.Entry<java.lang.String, org.apache.airavata.model.status.JobStatus> _iter120 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, org.apache.airavata.model.status.JobStatus> _iter128 : struct.success.entrySet())
             {
-              oprot.writeString(_iter120.getKey());
-              _iter120.getValue().write(oprot);
+              oprot.writeString(_iter128.getKey());
+              _iter128.getValue().write(oprot);
             }
             oprot.writeMapEnd();
           }
@@ -65684,10 +65840,10 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.util.Map.Entry<java.lang.String, org.apache.airavata.model.status.JobStatus> _iter121 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, org.apache.airavata.model.status.JobStatus> _iter129 : struct.success.entrySet())
             {
-              oprot.writeString(_iter121.getKey());
-              _iter121.getValue().write(oprot);
+              oprot.writeString(_iter129.getKey());
+              _iter129.getValue().write(oprot);
             }
           }
         }
@@ -65705,16 +65861,16 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map122 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.HashMap<java.lang.String,org.apache.airavata.model.status.JobStatus>(2*_map122.size);
-            java.lang.String _key123;
-            org.apache.airavata.model.status.JobStatus _val124;
-            for (int _i125 = 0; _i125 < _map122.size; ++_i125)
+            org.apache.thrift.protocol.TMap _map130 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.HashMap<java.lang.String,org.apache.airavata.model.status.JobStatus>(2*_map130.size);
+            java.lang.String _key131;
+            org.apache.airavata.model.status.JobStatus _val132;
+            for (int _i133 = 0; _i133 < _map130.size; ++_i133)
             {
-              _key123 = iprot.readString();
-              _val124 = new org.apache.airavata.model.status.JobStatus();
-              _val124.read(iprot);
-              struct.success.put(_key123, _val124);
+              _key131 = iprot.readString();
+              _val132 = new org.apache.airavata.model.status.JobStatus();
+              _val132.read(iprot);
+              struct.success.put(_key131, _val132);
             }
           }
           struct.setSuccessIsSet(true);
@@ -66230,14 +66386,14 @@ public class RegistryService {
             case 2: // OUTPUTS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list126 = iprot.readListBegin();
-                  struct.outputs = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list126.size);
-                  org.apache.airavata.model.application.io.OutputDataObjectType _elem127;
-                  for (int _i128 = 0; _i128 < _list126.size; ++_i128)
+                  org.apache.thrift.protocol.TList _list134 = iprot.readListBegin();
+                  struct.outputs = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list134.size);
+                  org.apache.airavata.model.application.io.OutputDataObjectType _elem135;
+                  for (int _i136 = 0; _i136 < _list134.size; ++_i136)
                   {
-                    _elem127 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-                    _elem127.read(iprot);
-                    struct.outputs.add(_elem127);
+                    _elem135 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+                    _elem135.read(iprot);
+                    struct.outputs.add(_elem135);
                   }
                   iprot.readListEnd();
                 }
@@ -66278,9 +66434,9 @@ public class RegistryService {
           oprot.writeFieldBegin(OUTPUTS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.outputs.size()));
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter129 : struct.outputs)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter137 : struct.outputs)
             {
-              _iter129.write(oprot);
+              _iter137.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -66311,9 +66467,9 @@ public class RegistryService {
         oprot.writeString(struct.outputType);
         {
           oprot.writeI32(struct.outputs.size());
-          for (org.apache.airavata.model.application.io.OutputDataObjectType _iter130 : struct.outputs)
+          for (org.apache.airavata.model.application.io.OutputDataObjectType _iter138 : struct.outputs)
           {
-            _iter130.write(oprot);
+            _iter138.write(oprot);
           }
         }
         oprot.writeString(struct.id);
@@ -66325,14 +66481,14 @@ public class RegistryService {
         struct.outputType = iprot.readString();
         struct.setOutputTypeIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list131 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-          struct.outputs = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list131.size);
-          org.apache.airavata.model.application.io.OutputDataObjectType _elem132;
-          for (int _i133 = 0; _i133 < _list131.size; ++_i133)
+          org.apache.thrift.protocol.TList _list139 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+          struct.outputs = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list139.size);
+          org.apache.airavata.model.application.io.OutputDataObjectType _elem140;
+          for (int _i141 = 0; _i141 < _list139.size; ++_i141)
           {
-            _elem132 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-            _elem132.read(iprot);
-            struct.outputs.add(_elem132);
+            _elem140 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+            _elem140.read(iprot);
+            struct.outputs.add(_elem140);
           }
         }
         struct.setOutputsIsSet(true);
@@ -77771,14 +77927,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list134 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessModel>(_list134.size);
-                  org.apache.airavata.model.process.ProcessModel _elem135;
-                  for (int _i136 = 0; _i136 < _list134.size; ++_i136)
+                  org.apache.thrift.protocol.TList _list142 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessModel>(_list142.size);
+                  org.apache.airavata.model.process.ProcessModel _elem143;
+                  for (int _i144 = 0; _i144 < _list142.size; ++_i144)
                   {
-                    _elem135 = new org.apache.airavata.model.process.ProcessModel();
-                    _elem135.read(iprot);
-                    struct.success.add(_elem135);
+                    _elem143 = new org.apache.airavata.model.process.ProcessModel();
+                    _elem143.read(iprot);
+                    struct.success.add(_elem143);
                   }
                   iprot.readListEnd();
                 }
@@ -77815,9 +77971,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.process.ProcessModel _iter137 : struct.success)
+            for (org.apache.airavata.model.process.ProcessModel _iter145 : struct.success)
             {
-              _iter137.write(oprot);
+              _iter145.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -77856,9 +78012,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.process.ProcessModel _iter138 : struct.success)
+            for (org.apache.airavata.model.process.ProcessModel _iter146 : struct.success)
             {
-              _iter138.write(oprot);
+              _iter146.write(oprot);
             }
           }
         }
@@ -77873,14 +78029,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list139 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessModel>(_list139.size);
-            org.apache.airavata.model.process.ProcessModel _elem140;
-            for (int _i141 = 0; _i141 < _list139.size; ++_i141)
+            org.apache.thrift.protocol.TList _list147 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessModel>(_list147.size);
+            org.apache.airavata.model.process.ProcessModel _elem148;
+            for (int _i149 = 0; _i149 < _list147.size; ++_i149)
             {
-              _elem140 = new org.apache.airavata.model.process.ProcessModel();
-              _elem140.read(iprot);
-              struct.success.add(_elem140);
+              _elem148 = new org.apache.airavata.model.process.ProcessModel();
+              _elem148.read(iprot);
+              struct.success.add(_elem148);
             }
           }
           struct.setSuccessIsSet(true);
@@ -81425,14 +81581,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list142 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list142.size);
-                  org.apache.airavata.model.job.JobModel _elem143;
-                  for (int _i144 = 0; _i144 < _list142.size; ++_i144)
+                  org.apache.thrift.protocol.TList _list150 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list150.size);
+                  org.apache.airavata.model.job.JobModel _elem151;
+                  for (int _i152 = 0; _i152 < _list150.size; ++_i152)
                   {
-                    _elem143 = new org.apache.airavata.model.job.JobModel();
-                    _elem143.read(iprot);
-                    struct.success.add(_elem143);
+                    _elem151 = new org.apache.airavata.model.job.JobModel();
+                    _elem151.read(iprot);
+                    struct.success.add(_elem151);
                   }
                   iprot.readListEnd();
                 }
@@ -81469,9 +81625,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.job.JobModel _iter145 : struct.success)
+            for (org.apache.airavata.model.job.JobModel _iter153 : struct.success)
             {
-              _iter145.write(oprot);
+              _iter153.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -81510,9 +81666,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.job.JobModel _iter146 : struct.success)
+            for (org.apache.airavata.model.job.JobModel _iter154 : struct.success)
             {
-              _iter146.write(oprot);
+              _iter154.write(oprot);
             }
           }
         }
@@ -81527,14 +81683,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list147 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list147.size);
-            org.apache.airavata.model.job.JobModel _elem148;
-            for (int _i149 = 0; _i149 < _list147.size; ++_i149)
+            org.apache.thrift.protocol.TList _list155 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list155.size);
+            org.apache.airavata.model.job.JobModel _elem156;
+            for (int _i157 = 0; _i157 < _list155.size; ++_i157)
             {
-              _elem148 = new org.apache.airavata.model.job.JobModel();
-              _elem148.read(iprot);
-              struct.success.add(_elem148);
+              _elem156 = new org.apache.airavata.model.job.JobModel();
+              _elem156.read(iprot);
+              struct.success.add(_elem156);
             }
           }
           struct.setSuccessIsSet(true);
@@ -82302,14 +82458,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list150 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list150.size);
-                  org.apache.airavata.model.application.io.OutputDataObjectType _elem151;
-                  for (int _i152 = 0; _i152 < _list150.size; ++_i152)
+                  org.apache.thrift.protocol.TList _list158 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list158.size);
+                  org.apache.airavata.model.application.io.OutputDataObjectType _elem159;
+                  for (int _i160 = 0; _i160 < _list158.size; ++_i160)
                   {
-                    _elem151 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-                    _elem151.read(iprot);
-                    struct.success.add(_elem151);
+                    _elem159 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+                    _elem159.read(iprot);
+                    struct.success.add(_elem159);
                   }
                   iprot.readListEnd();
                 }
@@ -82346,9 +82502,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter153 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter161 : struct.success)
             {
-              _iter153.write(oprot);
+              _iter161.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -82387,9 +82543,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter154 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter162 : struct.success)
             {
-              _iter154.write(oprot);
+              _iter162.write(oprot);
             }
           }
         }
@@ -82404,14 +82560,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list155 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list155.size);
-            org.apache.airavata.model.application.io.OutputDataObjectType _elem156;
-            for (int _i157 = 0; _i157 < _list155.size; ++_i157)
+            org.apache.thrift.protocol.TList _list163 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list163.size);
+            org.apache.airavata.model.application.io.OutputDataObjectType _elem164;
+            for (int _i165 = 0; _i165 < _list163.size; ++_i165)
             {
-              _elem156 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-              _elem156.read(iprot);
-              struct.success.add(_elem156);
+              _elem164 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+              _elem164.read(iprot);
+              struct.success.add(_elem164);
             }
           }
           struct.setSuccessIsSet(true);
@@ -83179,14 +83335,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list158 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessWorkflow>(_list158.size);
-                  org.apache.airavata.model.process.ProcessWorkflow _elem159;
-                  for (int _i160 = 0; _i160 < _list158.size; ++_i160)
+                  org.apache.thrift.protocol.TList _list166 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessWorkflow>(_list166.size);
+                  org.apache.airavata.model.process.ProcessWorkflow _elem167;
+                  for (int _i168 = 0; _i168 < _list166.size; ++_i168)
                   {
-                    _elem159 = new org.apache.airavata.model.process.ProcessWorkflow();
-                    _elem159.read(iprot);
-                    struct.success.add(_elem159);
+                    _elem167 = new org.apache.airavata.model.process.ProcessWorkflow();
+                    _elem167.read(iprot);
+                    struct.success.add(_elem167);
                   }
                   iprot.readListEnd();
                 }
@@ -83223,9 +83379,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.process.ProcessWorkflow _iter161 : struct.success)
+            for (org.apache.airavata.model.process.ProcessWorkflow _iter169 : struct.success)
             {
-              _iter161.write(oprot);
+              _iter169.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -83264,9 +83420,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.process.ProcessWorkflow _iter162 : struct.success)
+            for (org.apache.airavata.model.process.ProcessWorkflow _iter170 : struct.success)
             {
-              _iter162.write(oprot);
+              _iter170.write(oprot);
             }
           }
         }
@@ -83281,14 +83437,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list163 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessWorkflow>(_list163.size);
-            org.apache.airavata.model.process.ProcessWorkflow _elem164;
-            for (int _i165 = 0; _i165 < _list163.size; ++_i165)
+            org.apache.thrift.protocol.TList _list171 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.process.ProcessWorkflow>(_list171.size);
+            org.apache.airavata.model.process.ProcessWorkflow _elem172;
+            for (int _i173 = 0; _i173 < _list171.size; ++_i173)
             {
-              _elem164 = new org.apache.airavata.model.process.ProcessWorkflow();
-              _elem164.read(iprot);
-              struct.success.add(_elem164);
+              _elem172 = new org.apache.airavata.model.process.ProcessWorkflow();
+              _elem172.read(iprot);
+              struct.success.add(_elem172);
             }
           }
           struct.setSuccessIsSet(true);
@@ -84777,13 +84933,13 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list166 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<java.lang.String>(_list166.size);
-                  java.lang.String _elem167;
-                  for (int _i168 = 0; _i168 < _list166.size; ++_i168)
+                  org.apache.thrift.protocol.TList _list174 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<java.lang.String>(_list174.size);
+                  java.lang.String _elem175;
+                  for (int _i176 = 0; _i176 < _list174.size; ++_i176)
                   {
-                    _elem167 = iprot.readString();
-                    struct.success.add(_elem167);
+                    _elem175 = iprot.readString();
+                    struct.success.add(_elem175);
                   }
                   iprot.readListEnd();
                 }
@@ -84820,9 +84976,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (java.lang.String _iter169 : struct.success)
+            for (java.lang.String _iter177 : struct.success)
             {
-              oprot.writeString(_iter169);
+              oprot.writeString(_iter177);
             }
             oprot.writeListEnd();
           }
@@ -84861,9 +85017,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.lang.String _iter170 : struct.success)
+            for (java.lang.String _iter178 : struct.success)
             {
-              oprot.writeString(_iter170);
+              oprot.writeString(_iter178);
             }
           }
         }
@@ -84878,13 +85034,13 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list171 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new java.util.ArrayList<java.lang.String>(_list171.size);
-            java.lang.String _elem172;
-            for (int _i173 = 0; _i173 < _list171.size; ++_i173)
+            org.apache.thrift.protocol.TList _list179 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new java.util.ArrayList<java.lang.String>(_list179.size);
+            java.lang.String _elem180;
+            for (int _i181 = 0; _i181 < _list179.size; ++_i181)
             {
-              _elem172 = iprot.readString();
-              struct.success.add(_elem172);
+              _elem180 = iprot.readString();
+              struct.success.add(_elem180);
             }
           }
           struct.setSuccessIsSet(true);
@@ -85733,14 +85889,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list174 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list174.size);
-                  org.apache.airavata.model.job.JobModel _elem175;
-                  for (int _i176 = 0; _i176 < _list174.size; ++_i176)
+                  org.apache.thrift.protocol.TList _list182 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list182.size);
+                  org.apache.airavata.model.job.JobModel _elem183;
+                  for (int _i184 = 0; _i184 < _list182.size; ++_i184)
                   {
-                    _elem175 = new org.apache.airavata.model.job.JobModel();
-                    _elem175.read(iprot);
-                    struct.success.add(_elem175);
+                    _elem183 = new org.apache.airavata.model.job.JobModel();
+                    _elem183.read(iprot);
+                    struct.success.add(_elem183);
                   }
                   iprot.readListEnd();
                 }
@@ -85786,9 +85942,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.job.JobModel _iter177 : struct.success)
+            for (org.apache.airavata.model.job.JobModel _iter185 : struct.success)
             {
-              _iter177.write(oprot);
+              _iter185.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -85835,9 +85991,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.job.JobModel _iter178 : struct.success)
+            for (org.apache.airavata.model.job.JobModel _iter186 : struct.success)
             {
-              _iter178.write(oprot);
+              _iter186.write(oprot);
             }
           }
         }
@@ -85855,14 +86011,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list179 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list179.size);
-            org.apache.airavata.model.job.JobModel _elem180;
-            for (int _i181 = 0; _i181 < _list179.size; ++_i181)
+            org.apache.thrift.protocol.TList _list187 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.job.JobModel>(_list187.size);
+            org.apache.airavata.model.job.JobModel _elem188;
+            for (int _i189 = 0; _i189 < _list187.size; ++_i189)
             {
-              _elem180 = new org.apache.airavata.model.job.JobModel();
-              _elem180.read(iprot);
-              struct.success.add(_elem180);
+              _elem188 = new org.apache.airavata.model.job.JobModel();
+              _elem188.read(iprot);
+              struct.success.add(_elem188);
             }
           }
           struct.setSuccessIsSet(true);
@@ -89317,14 +89473,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list182 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list182.size);
-                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem183;
-                  for (int _i184 = 0; _i184 < _list182.size; ++_i184)
+                  org.apache.thrift.protocol.TList _list190 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list190.size);
+                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem191;
+                  for (int _i192 = 0; _i192 < _list190.size; ++_i192)
                   {
-                    _elem183 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
-                    _elem183.read(iprot);
-                    struct.success.add(_elem183);
+                    _elem191 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
+                    _elem191.read(iprot);
+                    struct.success.add(_elem191);
                   }
                   iprot.readListEnd();
                 }
@@ -89361,9 +89517,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter185 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter193 : struct.success)
             {
-              _iter185.write(oprot);
+              _iter193.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -89402,9 +89558,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter186 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter194 : struct.success)
             {
-              _iter186.write(oprot);
+              _iter194.write(oprot);
             }
           }
         }
@@ -89419,14 +89575,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list187 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list187.size);
-            org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem188;
-            for (int _i189 = 0; _i189 < _list187.size; ++_i189)
+            org.apache.thrift.protocol.TList _list195 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list195.size);
+            org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem196;
+            for (int _i197 = 0; _i197 < _list195.size; ++_i197)
             {
-              _elem188 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
-              _elem188.read(iprot);
-              struct.success.add(_elem188);
+              _elem196 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
+              _elem196.read(iprot);
+              struct.success.add(_elem196);
             }
           }
           struct.setSuccessIsSet(true);
@@ -89951,13 +90107,13 @@ public class RegistryService {
             case 2: // ACCESSIBLE_APP_DEPLOYMENT_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list190 = iprot.readListBegin();
-                  struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list190.size);
-                  java.lang.String _elem191;
-                  for (int _i192 = 0; _i192 < _list190.size; ++_i192)
+                  org.apache.thrift.protocol.TList _list198 = iprot.readListBegin();
+                  struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list198.size);
+                  java.lang.String _elem199;
+                  for (int _i200 = 0; _i200 < _list198.size; ++_i200)
                   {
-                    _elem191 = iprot.readString();
-                    struct.accessibleAppDeploymentIds.add(_elem191);
+                    _elem199 = iprot.readString();
+                    struct.accessibleAppDeploymentIds.add(_elem199);
                   }
                   iprot.readListEnd();
                 }
@@ -89969,13 +90125,13 @@ public class RegistryService {
             case 3: // ACCESSIBLE_COMPUTE_RESOURCE_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list193 = iprot.readListBegin();
-                  struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list193.size);
-                  java.lang.String _elem194;
-                  for (int _i195 = 0; _i195 < _list193.size; ++_i195)
+                  org.apache.thrift.protocol.TList _list201 = iprot.readListBegin();
+                  struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list201.size);
+                  java.lang.String _elem202;
+                  for (int _i203 = 0; _i203 < _list201.size; ++_i203)
                   {
-                    _elem194 = iprot.readString();
-                    struct.accessibleComputeResourceIds.add(_elem194);
+                    _elem202 = iprot.readString();
+                    struct.accessibleComputeResourceIds.add(_elem202);
                   }
                   iprot.readListEnd();
                 }
@@ -90008,9 +90164,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_APP_DEPLOYMENT_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleAppDeploymentIds.size()));
-            for (java.lang.String _iter196 : struct.accessibleAppDeploymentIds)
+            for (java.lang.String _iter204 : struct.accessibleAppDeploymentIds)
             {
-              oprot.writeString(_iter196);
+              oprot.writeString(_iter204);
             }
             oprot.writeListEnd();
           }
@@ -90020,9 +90176,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_COMPUTE_RESOURCE_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleComputeResourceIds.size()));
-            for (java.lang.String _iter197 : struct.accessibleComputeResourceIds)
+            for (java.lang.String _iter205 : struct.accessibleComputeResourceIds)
             {
-              oprot.writeString(_iter197);
+              oprot.writeString(_iter205);
             }
             oprot.writeListEnd();
           }
@@ -90048,16 +90204,16 @@ public class RegistryService {
         oprot.writeString(struct.gatewayId);
         {
           oprot.writeI32(struct.accessibleAppDeploymentIds.size());
-          for (java.lang.String _iter198 : struct.accessibleAppDeploymentIds)
+          for (java.lang.String _iter206 : struct.accessibleAppDeploymentIds)
           {
-            oprot.writeString(_iter198);
+            oprot.writeString(_iter206);
           }
         }
         {
           oprot.writeI32(struct.accessibleComputeResourceIds.size());
-          for (java.lang.String _iter199 : struct.accessibleComputeResourceIds)
+          for (java.lang.String _iter207 : struct.accessibleComputeResourceIds)
           {
-            oprot.writeString(_iter199);
+            oprot.writeString(_iter207);
           }
         }
       }
@@ -90068,24 +90224,24 @@ public class RegistryService {
         struct.gatewayId = iprot.readString();
         struct.setGatewayIdIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list200 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list200.size);
-          java.lang.String _elem201;
-          for (int _i202 = 0; _i202 < _list200.size; ++_i202)
+          org.apache.thrift.protocol.TList _list208 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list208.size);
+          java.lang.String _elem209;
+          for (int _i210 = 0; _i210 < _list208.size; ++_i210)
           {
-            _elem201 = iprot.readString();
-            struct.accessibleAppDeploymentIds.add(_elem201);
+            _elem209 = iprot.readString();
+            struct.accessibleAppDeploymentIds.add(_elem209);
           }
         }
         struct.setAccessibleAppDeploymentIdsIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list203 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list203.size);
-          java.lang.String _elem204;
-          for (int _i205 = 0; _i205 < _list203.size; ++_i205)
+          org.apache.thrift.protocol.TList _list211 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list211.size);
+          java.lang.String _elem212;
+          for (int _i213 = 0; _i213 < _list211.size; ++_i213)
           {
-            _elem204 = iprot.readString();
-            struct.accessibleComputeResourceIds.add(_elem204);
+            _elem212 = iprot.readString();
+            struct.accessibleComputeResourceIds.add(_elem212);
           }
         }
         struct.setAccessibleComputeResourceIdsIsSet(true);
@@ -90492,14 +90648,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list206 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list206.size);
-                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem207;
-                  for (int _i208 = 0; _i208 < _list206.size; ++_i208)
+                  org.apache.thrift.protocol.TList _list214 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list214.size);
+                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem215;
+                  for (int _i216 = 0; _i216 < _list214.size; ++_i216)
                   {
-                    _elem207 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
-                    _elem207.read(iprot);
-                    struct.success.add(_elem207);
+                    _elem215 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
+                    _elem215.read(iprot);
+                    struct.success.add(_elem215);
                   }
                   iprot.readListEnd();
                 }
@@ -90536,9 +90692,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter209 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter217 : struct.success)
             {
-              _iter209.write(oprot);
+              _iter217.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -90577,9 +90733,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter210 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _iter218 : struct.success)
             {
-              _iter210.write(oprot);
+              _iter218.write(oprot);
             }
           }
         }
@@ -90594,14 +90750,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list211 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list211.size);
-            org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem212;
-            for (int _i213 = 0; _i213 < _list211.size; ++_i213)
+            org.apache.thrift.protocol.TList _list219 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule>(_list219.size);
+            org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule _elem220;
+            for (int _i221 = 0; _i221 < _list219.size; ++_i221)
             {
-              _elem212 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
-              _elem212.read(iprot);
-              struct.success.add(_elem212);
+              _elem220 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationModule();
+              _elem220.read(iprot);
+              struct.success.add(_elem220);
             }
           }
           struct.setSuccessIsSet(true);
@@ -95693,14 +95849,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list214 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list214.size);
-                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem215;
-                  for (int _i216 = 0; _i216 < _list214.size; ++_i216)
+                  org.apache.thrift.protocol.TList _list222 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list222.size);
+                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem223;
+                  for (int _i224 = 0; _i224 < _list222.size; ++_i224)
                   {
-                    _elem215 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-                    _elem215.read(iprot);
-                    struct.success.add(_elem215);
+                    _elem223 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+                    _elem223.read(iprot);
+                    struct.success.add(_elem223);
                   }
                   iprot.readListEnd();
                 }
@@ -95737,9 +95893,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter217 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter225 : struct.success)
             {
-              _iter217.write(oprot);
+              _iter225.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -95778,9 +95934,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter218 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter226 : struct.success)
             {
-              _iter218.write(oprot);
+              _iter226.write(oprot);
             }
           }
         }
@@ -95795,14 +95951,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list219 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list219.size);
-            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem220;
-            for (int _i221 = 0; _i221 < _list219.size; ++_i221)
+            org.apache.thrift.protocol.TList _list227 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list227.size);
+            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem228;
+            for (int _i229 = 0; _i229 < _list227.size; ++_i229)
             {
-              _elem220 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-              _elem220.read(iprot);
-              struct.success.add(_elem220);
+              _elem228 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+              _elem228.read(iprot);
+              struct.success.add(_elem228);
             }
           }
           struct.setSuccessIsSet(true);
@@ -96327,13 +96483,13 @@ public class RegistryService {
             case 2: // ACCESSIBLE_APP_DEPLOYMENT_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list222 = iprot.readListBegin();
-                  struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list222.size);
-                  java.lang.String _elem223;
-                  for (int _i224 = 0; _i224 < _list222.size; ++_i224)
+                  org.apache.thrift.protocol.TList _list230 = iprot.readListBegin();
+                  struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list230.size);
+                  java.lang.String _elem231;
+                  for (int _i232 = 0; _i232 < _list230.size; ++_i232)
                   {
-                    _elem223 = iprot.readString();
-                    struct.accessibleAppDeploymentIds.add(_elem223);
+                    _elem231 = iprot.readString();
+                    struct.accessibleAppDeploymentIds.add(_elem231);
                   }
                   iprot.readListEnd();
                 }
@@ -96345,13 +96501,13 @@ public class RegistryService {
             case 3: // ACCESSIBLE_COMPUTE_RESOURCE_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list225 = iprot.readListBegin();
-                  struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list225.size);
-                  java.lang.String _elem226;
-                  for (int _i227 = 0; _i227 < _list225.size; ++_i227)
+                  org.apache.thrift.protocol.TList _list233 = iprot.readListBegin();
+                  struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list233.size);
+                  java.lang.String _elem234;
+                  for (int _i235 = 0; _i235 < _list233.size; ++_i235)
                   {
-                    _elem226 = iprot.readString();
-                    struct.accessibleComputeResourceIds.add(_elem226);
+                    _elem234 = iprot.readString();
+                    struct.accessibleComputeResourceIds.add(_elem234);
                   }
                   iprot.readListEnd();
                 }
@@ -96384,9 +96540,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_APP_DEPLOYMENT_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleAppDeploymentIds.size()));
-            for (java.lang.String _iter228 : struct.accessibleAppDeploymentIds)
+            for (java.lang.String _iter236 : struct.accessibleAppDeploymentIds)
             {
-              oprot.writeString(_iter228);
+              oprot.writeString(_iter236);
             }
             oprot.writeListEnd();
           }
@@ -96396,9 +96552,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_COMPUTE_RESOURCE_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleComputeResourceIds.size()));
-            for (java.lang.String _iter229 : struct.accessibleComputeResourceIds)
+            for (java.lang.String _iter237 : struct.accessibleComputeResourceIds)
             {
-              oprot.writeString(_iter229);
+              oprot.writeString(_iter237);
             }
             oprot.writeListEnd();
           }
@@ -96424,16 +96580,16 @@ public class RegistryService {
         oprot.writeString(struct.gatewayId);
         {
           oprot.writeI32(struct.accessibleAppDeploymentIds.size());
-          for (java.lang.String _iter230 : struct.accessibleAppDeploymentIds)
+          for (java.lang.String _iter238 : struct.accessibleAppDeploymentIds)
           {
-            oprot.writeString(_iter230);
+            oprot.writeString(_iter238);
           }
         }
         {
           oprot.writeI32(struct.accessibleComputeResourceIds.size());
-          for (java.lang.String _iter231 : struct.accessibleComputeResourceIds)
+          for (java.lang.String _iter239 : struct.accessibleComputeResourceIds)
           {
-            oprot.writeString(_iter231);
+            oprot.writeString(_iter239);
           }
         }
       }
@@ -96444,24 +96600,24 @@ public class RegistryService {
         struct.gatewayId = iprot.readString();
         struct.setGatewayIdIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list232 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list232.size);
-          java.lang.String _elem233;
-          for (int _i234 = 0; _i234 < _list232.size; ++_i234)
+          org.apache.thrift.protocol.TList _list240 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list240.size);
+          java.lang.String _elem241;
+          for (int _i242 = 0; _i242 < _list240.size; ++_i242)
           {
-            _elem233 = iprot.readString();
-            struct.accessibleAppDeploymentIds.add(_elem233);
+            _elem241 = iprot.readString();
+            struct.accessibleAppDeploymentIds.add(_elem241);
           }
         }
         struct.setAccessibleAppDeploymentIdsIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list235 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list235.size);
-          java.lang.String _elem236;
-          for (int _i237 = 0; _i237 < _list235.size; ++_i237)
+          org.apache.thrift.protocol.TList _list243 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list243.size);
+          java.lang.String _elem244;
+          for (int _i245 = 0; _i245 < _list243.size; ++_i245)
           {
-            _elem236 = iprot.readString();
-            struct.accessibleComputeResourceIds.add(_elem236);
+            _elem244 = iprot.readString();
+            struct.accessibleComputeResourceIds.add(_elem244);
           }
         }
         struct.setAccessibleComputeResourceIdsIsSet(true);
@@ -96868,14 +97024,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list238 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list238.size);
-                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem239;
-                  for (int _i240 = 0; _i240 < _list238.size; ++_i240)
+                  org.apache.thrift.protocol.TList _list246 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list246.size);
+                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem247;
+                  for (int _i248 = 0; _i248 < _list246.size; ++_i248)
                   {
-                    _elem239 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-                    _elem239.read(iprot);
-                    struct.success.add(_elem239);
+                    _elem247 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+                    _elem247.read(iprot);
+                    struct.success.add(_elem247);
                   }
                   iprot.readListEnd();
                 }
@@ -96912,9 +97068,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter241 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter249 : struct.success)
             {
-              _iter241.write(oprot);
+              _iter249.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -96953,9 +97109,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter242 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter250 : struct.success)
             {
-              _iter242.write(oprot);
+              _iter250.write(oprot);
             }
           }
         }
@@ -96970,14 +97126,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list243 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list243.size);
-            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem244;
-            for (int _i245 = 0; _i245 < _list243.size; ++_i245)
+            org.apache.thrift.protocol.TList _list251 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list251.size);
+            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem252;
+            for (int _i253 = 0; _i253 < _list251.size; ++_i253)
             {
-              _elem244 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-              _elem244.read(iprot);
-              struct.success.add(_elem244);
+              _elem252 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+              _elem252.read(iprot);
+              struct.success.add(_elem252);
             }
           }
           struct.setSuccessIsSet(true);
@@ -97594,13 +97750,13 @@ public class RegistryService {
             case 3: // ACCESSIBLE_APP_DEPLOYMENT_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list246 = iprot.readListBegin();
-                  struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list246.size);
-                  java.lang.String _elem247;
-                  for (int _i248 = 0; _i248 < _list246.size; ++_i248)
+                  org.apache.thrift.protocol.TList _list254 = iprot.readListBegin();
+                  struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list254.size);
+                  java.lang.String _elem255;
+                  for (int _i256 = 0; _i256 < _list254.size; ++_i256)
                   {
-                    _elem247 = iprot.readString();
-                    struct.accessibleAppDeploymentIds.add(_elem247);
+                    _elem255 = iprot.readString();
+                    struct.accessibleAppDeploymentIds.add(_elem255);
                   }
                   iprot.readListEnd();
                 }
@@ -97612,13 +97768,13 @@ public class RegistryService {
             case 4: // ACCESSIBLE_COMPUTE_RESOURCE_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list249 = iprot.readListBegin();
-                  struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list249.size);
-                  java.lang.String _elem250;
-                  for (int _i251 = 0; _i251 < _list249.size; ++_i251)
+                  org.apache.thrift.protocol.TList _list257 = iprot.readListBegin();
+                  struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list257.size);
+                  java.lang.String _elem258;
+                  for (int _i259 = 0; _i259 < _list257.size; ++_i259)
                   {
-                    _elem250 = iprot.readString();
-                    struct.accessibleComputeResourceIds.add(_elem250);
+                    _elem258 = iprot.readString();
+                    struct.accessibleComputeResourceIds.add(_elem258);
                   }
                   iprot.readListEnd();
                 }
@@ -97656,9 +97812,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_APP_DEPLOYMENT_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleAppDeploymentIds.size()));
-            for (java.lang.String _iter252 : struct.accessibleAppDeploymentIds)
+            for (java.lang.String _iter260 : struct.accessibleAppDeploymentIds)
             {
-              oprot.writeString(_iter252);
+              oprot.writeString(_iter260);
             }
             oprot.writeListEnd();
           }
@@ -97668,9 +97824,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_COMPUTE_RESOURCE_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleComputeResourceIds.size()));
-            for (java.lang.String _iter253 : struct.accessibleComputeResourceIds)
+            for (java.lang.String _iter261 : struct.accessibleComputeResourceIds)
             {
-              oprot.writeString(_iter253);
+              oprot.writeString(_iter261);
             }
             oprot.writeListEnd();
           }
@@ -97697,16 +97853,16 @@ public class RegistryService {
         oprot.writeString(struct.appModuleId);
         {
           oprot.writeI32(struct.accessibleAppDeploymentIds.size());
-          for (java.lang.String _iter254 : struct.accessibleAppDeploymentIds)
+          for (java.lang.String _iter262 : struct.accessibleAppDeploymentIds)
           {
-            oprot.writeString(_iter254);
+            oprot.writeString(_iter262);
           }
         }
         {
           oprot.writeI32(struct.accessibleComputeResourceIds.size());
-          for (java.lang.String _iter255 : struct.accessibleComputeResourceIds)
+          for (java.lang.String _iter263 : struct.accessibleComputeResourceIds)
           {
-            oprot.writeString(_iter255);
+            oprot.writeString(_iter263);
           }
         }
       }
@@ -97719,24 +97875,24 @@ public class RegistryService {
         struct.appModuleId = iprot.readString();
         struct.setAppModuleIdIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list256 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list256.size);
-          java.lang.String _elem257;
-          for (int _i258 = 0; _i258 < _list256.size; ++_i258)
+          org.apache.thrift.protocol.TList _list264 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleAppDeploymentIds = new java.util.ArrayList<java.lang.String>(_list264.size);
+          java.lang.String _elem265;
+          for (int _i266 = 0; _i266 < _list264.size; ++_i266)
           {
-            _elem257 = iprot.readString();
-            struct.accessibleAppDeploymentIds.add(_elem257);
+            _elem265 = iprot.readString();
+            struct.accessibleAppDeploymentIds.add(_elem265);
           }
         }
         struct.setAccessibleAppDeploymentIdsIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list259 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list259.size);
-          java.lang.String _elem260;
-          for (int _i261 = 0; _i261 < _list259.size; ++_i261)
+          org.apache.thrift.protocol.TList _list267 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleComputeResourceIds = new java.util.ArrayList<java.lang.String>(_list267.size);
+          java.lang.String _elem268;
+          for (int _i269 = 0; _i269 < _list267.size; ++_i269)
           {
-            _elem260 = iprot.readString();
-            struct.accessibleComputeResourceIds.add(_elem260);
+            _elem268 = iprot.readString();
+            struct.accessibleComputeResourceIds.add(_elem268);
           }
         }
         struct.setAccessibleComputeResourceIdsIsSet(true);
@@ -98143,14 +98299,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list262 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list262.size);
-                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem263;
-                  for (int _i264 = 0; _i264 < _list262.size; ++_i264)
+                  org.apache.thrift.protocol.TList _list270 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list270.size);
+                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem271;
+                  for (int _i272 = 0; _i272 < _list270.size; ++_i272)
                   {
-                    _elem263 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-                    _elem263.read(iprot);
-                    struct.success.add(_elem263);
+                    _elem271 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+                    _elem271.read(iprot);
+                    struct.success.add(_elem271);
                   }
                   iprot.readListEnd();
                 }
@@ -98187,9 +98343,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter265 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter273 : struct.success)
             {
-              _iter265.write(oprot);
+              _iter273.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -98228,9 +98384,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter266 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter274 : struct.success)
             {
-              _iter266.write(oprot);
+              _iter274.write(oprot);
             }
           }
         }
@@ -98245,14 +98401,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list267 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list267.size);
-            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem268;
-            for (int _i269 = 0; _i269 < _list267.size; ++_i269)
+            org.apache.thrift.protocol.TList _list275 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list275.size);
+            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem276;
+            for (int _i277 = 0; _i277 < _list275.size; ++_i277)
             {
-              _elem268 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-              _elem268.read(iprot);
-              struct.success.add(_elem268);
+              _elem276 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+              _elem276.read(iprot);
+              struct.success.add(_elem276);
             }
           }
           struct.setSuccessIsSet(true);
@@ -99017,13 +99173,13 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list270 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<java.lang.String>(_list270.size);
-                  java.lang.String _elem271;
-                  for (int _i272 = 0; _i272 < _list270.size; ++_i272)
+                  org.apache.thrift.protocol.TList _list278 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<java.lang.String>(_list278.size);
+                  java.lang.String _elem279;
+                  for (int _i280 = 0; _i280 < _list278.size; ++_i280)
                   {
-                    _elem271 = iprot.readString();
-                    struct.success.add(_elem271);
+                    _elem279 = iprot.readString();
+                    struct.success.add(_elem279);
                   }
                   iprot.readListEnd();
                 }
@@ -99060,9 +99216,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (java.lang.String _iter273 : struct.success)
+            for (java.lang.String _iter281 : struct.success)
             {
-              oprot.writeString(_iter273);
+              oprot.writeString(_iter281);
             }
             oprot.writeListEnd();
           }
@@ -99101,9 +99257,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.lang.String _iter274 : struct.success)
+            for (java.lang.String _iter282 : struct.success)
             {
-              oprot.writeString(_iter274);
+              oprot.writeString(_iter282);
             }
           }
         }
@@ -99118,13 +99274,13 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list275 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new java.util.ArrayList<java.lang.String>(_list275.size);
-            java.lang.String _elem276;
-            for (int _i277 = 0; _i277 < _list275.size; ++_i277)
+            org.apache.thrift.protocol.TList _list283 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new java.util.ArrayList<java.lang.String>(_list283.size);
+            java.lang.String _elem284;
+            for (int _i285 = 0; _i285 < _list283.size; ++_i285)
             {
-              _elem276 = iprot.readString();
-              struct.success.add(_elem276);
+              _elem284 = iprot.readString();
+              struct.success.add(_elem284);
             }
           }
           struct.setSuccessIsSet(true);
@@ -99892,14 +100048,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list278 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list278.size);
-                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem279;
-                  for (int _i280 = 0; _i280 < _list278.size; ++_i280)
+                  org.apache.thrift.protocol.TList _list286 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list286.size);
+                  org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem287;
+                  for (int _i288 = 0; _i288 < _list286.size; ++_i288)
                   {
-                    _elem279 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-                    _elem279.read(iprot);
-                    struct.success.add(_elem279);
+                    _elem287 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+                    _elem287.read(iprot);
+                    struct.success.add(_elem287);
                   }
                   iprot.readListEnd();
                 }
@@ -99936,9 +100092,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter281 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter289 : struct.success)
             {
-              _iter281.write(oprot);
+              _iter289.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -99977,9 +100133,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter282 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _iter290 : struct.success)
             {
-              _iter282.write(oprot);
+              _iter290.write(oprot);
             }
           }
         }
@@ -99994,14 +100150,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list283 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list283.size);
-            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem284;
-            for (int _i285 = 0; _i285 < _list283.size; ++_i285)
+            org.apache.thrift.protocol.TList _list291 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription>(_list291.size);
+            org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription _elem292;
+            for (int _i293 = 0; _i293 < _list291.size; ++_i293)
             {
-              _elem284 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
-              _elem284.read(iprot);
-              struct.success.add(_elem284);
+              _elem292 = new org.apache.airavata.model.appcatalog.appdeployment.ApplicationDeploymentDescription();
+              _elem292.read(iprot);
+              struct.success.add(_elem292);
             }
           }
           struct.setSuccessIsSet(true);
@@ -104266,15 +104422,15 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map286 = iprot.readMapBegin();
-                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map286.size);
-                  java.lang.String _key287;
-                  java.lang.String _val288;
-                  for (int _i289 = 0; _i289 < _map286.size; ++_i289)
+                  org.apache.thrift.protocol.TMap _map294 = iprot.readMapBegin();
+                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map294.size);
+                  java.lang.String _key295;
+                  java.lang.String _val296;
+                  for (int _i297 = 0; _i297 < _map294.size; ++_i297)
                   {
-                    _key287 = iprot.readString();
-                    _val288 = iprot.readString();
-                    struct.success.put(_key287, _val288);
+                    _key295 = iprot.readString();
+                    _val296 = iprot.readString();
+                    struct.success.put(_key295, _val296);
                   }
                   iprot.readMapEnd();
                 }
@@ -104311,10 +104467,10 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter290 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter298 : struct.success.entrySet())
             {
-              oprot.writeString(_iter290.getKey());
-              oprot.writeString(_iter290.getValue());
+              oprot.writeString(_iter298.getKey());
+              oprot.writeString(_iter298.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -104353,10 +104509,10 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter291 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter299 : struct.success.entrySet())
             {
-              oprot.writeString(_iter291.getKey());
-              oprot.writeString(_iter291.getValue());
+              oprot.writeString(_iter299.getKey());
+              oprot.writeString(_iter299.getValue());
             }
           }
         }
@@ -104371,15 +104527,15 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map292 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map292.size);
-            java.lang.String _key293;
-            java.lang.String _val294;
-            for (int _i295 = 0; _i295 < _map292.size; ++_i295)
+            org.apache.thrift.protocol.TMap _map300 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map300.size);
+            java.lang.String _key301;
+            java.lang.String _val302;
+            for (int _i303 = 0; _i303 < _map300.size; ++_i303)
             {
-              _key293 = iprot.readString();
-              _val294 = iprot.readString();
-              struct.success.put(_key293, _val294);
+              _key301 = iprot.readString();
+              _val302 = iprot.readString();
+              struct.success.put(_key301, _val302);
             }
           }
           struct.setSuccessIsSet(true);
@@ -105147,14 +105303,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list296 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription>(_list296.size);
-                  org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _elem297;
-                  for (int _i298 = 0; _i298 < _list296.size; ++_i298)
+                  org.apache.thrift.protocol.TList _list304 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription>(_list304.size);
+                  org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _elem305;
+                  for (int _i306 = 0; _i306 < _list304.size; ++_i306)
                   {
-                    _elem297 = new org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription();
-                    _elem297.read(iprot);
-                    struct.success.add(_elem297);
+                    _elem305 = new org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription();
+                    _elem305.read(iprot);
+                    struct.success.add(_elem305);
                   }
                   iprot.readListEnd();
                 }
@@ -105191,9 +105347,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _iter299 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _iter307 : struct.success)
             {
-              _iter299.write(oprot);
+              _iter307.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -105232,9 +105388,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _iter300 : struct.success)
+            for (org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _iter308 : struct.success)
             {
-              _iter300.write(oprot);
+              _iter308.write(oprot);
             }
           }
         }
@@ -105249,14 +105405,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list301 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription>(_list301.size);
-            org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _elem302;
-            for (int _i303 = 0; _i303 < _list301.size; ++_i303)
+            org.apache.thrift.protocol.TList _list309 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription>(_list309.size);
+            org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription _elem310;
+            for (int _i311 = 0; _i311 < _list309.size; ++_i311)
             {
-              _elem302 = new org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription();
-              _elem302.read(iprot);
-              struct.success.add(_elem302);
+              _elem310 = new org.apache.airavata.model.appcatalog.appinterface.ApplicationInterfaceDescription();
+              _elem310.read(iprot);
+              struct.success.add(_elem310);
             }
           }
           struct.setSuccessIsSet(true);
@@ -106024,14 +106180,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list304 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.InputDataObjectType>(_list304.size);
-                  org.apache.airavata.model.application.io.InputDataObjectType _elem305;
-                  for (int _i306 = 0; _i306 < _list304.size; ++_i306)
+                  org.apache.thrift.protocol.TList _list312 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.InputDataObjectType>(_list312.size);
+                  org.apache.airavata.model.application.io.InputDataObjectType _elem313;
+                  for (int _i314 = 0; _i314 < _list312.size; ++_i314)
                   {
-                    _elem305 = new org.apache.airavata.model.application.io.InputDataObjectType();
-                    _elem305.read(iprot);
-                    struct.success.add(_elem305);
+                    _elem313 = new org.apache.airavata.model.application.io.InputDataObjectType();
+                    _elem313.read(iprot);
+                    struct.success.add(_elem313);
                   }
                   iprot.readListEnd();
                 }
@@ -106068,9 +106224,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.application.io.InputDataObjectType _iter307 : struct.success)
+            for (org.apache.airavata.model.application.io.InputDataObjectType _iter315 : struct.success)
             {
-              _iter307.write(oprot);
+              _iter315.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -106109,9 +106265,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.application.io.InputDataObjectType _iter308 : struct.success)
+            for (org.apache.airavata.model.application.io.InputDataObjectType _iter316 : struct.success)
             {
-              _iter308.write(oprot);
+              _iter316.write(oprot);
             }
           }
         }
@@ -106126,14 +106282,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list309 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.InputDataObjectType>(_list309.size);
-            org.apache.airavata.model.application.io.InputDataObjectType _elem310;
-            for (int _i311 = 0; _i311 < _list309.size; ++_i311)
+            org.apache.thrift.protocol.TList _list317 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.InputDataObjectType>(_list317.size);
+            org.apache.airavata.model.application.io.InputDataObjectType _elem318;
+            for (int _i319 = 0; _i319 < _list317.size; ++_i319)
             {
-              _elem310 = new org.apache.airavata.model.application.io.InputDataObjectType();
-              _elem310.read(iprot);
-              struct.success.add(_elem310);
+              _elem318 = new org.apache.airavata.model.application.io.InputDataObjectType();
+              _elem318.read(iprot);
+              struct.success.add(_elem318);
             }
           }
           struct.setSuccessIsSet(true);
@@ -106901,14 +107057,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list312 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list312.size);
-                  org.apache.airavata.model.application.io.OutputDataObjectType _elem313;
-                  for (int _i314 = 0; _i314 < _list312.size; ++_i314)
+                  org.apache.thrift.protocol.TList _list320 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list320.size);
+                  org.apache.airavata.model.application.io.OutputDataObjectType _elem321;
+                  for (int _i322 = 0; _i322 < _list320.size; ++_i322)
                   {
-                    _elem313 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-                    _elem313.read(iprot);
-                    struct.success.add(_elem313);
+                    _elem321 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+                    _elem321.read(iprot);
+                    struct.success.add(_elem321);
                   }
                   iprot.readListEnd();
                 }
@@ -106945,9 +107101,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter315 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter323 : struct.success)
             {
-              _iter315.write(oprot);
+              _iter323.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -106986,9 +107142,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter316 : struct.success)
+            for (org.apache.airavata.model.application.io.OutputDataObjectType _iter324 : struct.success)
             {
-              _iter316.write(oprot);
+              _iter324.write(oprot);
             }
           }
         }
@@ -107003,14 +107159,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list317 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list317.size);
-            org.apache.airavata.model.application.io.OutputDataObjectType _elem318;
-            for (int _i319 = 0; _i319 < _list317.size; ++_i319)
+            org.apache.thrift.protocol.TList _list325 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.application.io.OutputDataObjectType>(_list325.size);
+            org.apache.airavata.model.application.io.OutputDataObjectType _elem326;
+            for (int _i327 = 0; _i327 < _list325.size; ++_i327)
             {
-              _elem318 = new org.apache.airavata.model.application.io.OutputDataObjectType();
-              _elem318.read(iprot);
-              struct.success.add(_elem318);
+              _elem326 = new org.apache.airavata.model.application.io.OutputDataObjectType();
+              _elem326.read(iprot);
+              struct.success.add(_elem326);
             }
           }
           struct.setSuccessIsSet(true);
@@ -107772,15 +107928,15 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map320 = iprot.readMapBegin();
-                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map320.size);
-                  java.lang.String _key321;
-                  java.lang.String _val322;
-                  for (int _i323 = 0; _i323 < _map320.size; ++_i323)
+                  org.apache.thrift.protocol.TMap _map328 = iprot.readMapBegin();
+                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map328.size);
+                  java.lang.String _key329;
+                  java.lang.String _val330;
+                  for (int _i331 = 0; _i331 < _map328.size; ++_i331)
                   {
-                    _key321 = iprot.readString();
-                    _val322 = iprot.readString();
-                    struct.success.put(_key321, _val322);
+                    _key329 = iprot.readString();
+                    _val330 = iprot.readString();
+                    struct.success.put(_key329, _val330);
                   }
                   iprot.readMapEnd();
                 }
@@ -107817,10 +107973,10 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter324 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter332 : struct.success.entrySet())
             {
-              oprot.writeString(_iter324.getKey());
-              oprot.writeString(_iter324.getValue());
+              oprot.writeString(_iter332.getKey());
+              oprot.writeString(_iter332.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -107859,10 +108015,10 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter325 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter333 : struct.success.entrySet())
             {
-              oprot.writeString(_iter325.getKey());
-              oprot.writeString(_iter325.getValue());
+              oprot.writeString(_iter333.getKey());
+              oprot.writeString(_iter333.getValue());
             }
           }
         }
@@ -107877,15 +108033,15 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map326 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map326.size);
-            java.lang.String _key327;
-            java.lang.String _val328;
-            for (int _i329 = 0; _i329 < _map326.size; ++_i329)
+            org.apache.thrift.protocol.TMap _map334 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map334.size);
+            java.lang.String _key335;
+            java.lang.String _val336;
+            for (int _i337 = 0; _i337 < _map334.size; ++_i337)
             {
-              _key327 = iprot.readString();
-              _val328 = iprot.readString();
-              struct.success.put(_key327, _val328);
+              _key335 = iprot.readString();
+              _val336 = iprot.readString();
+              struct.success.put(_key335, _val336);
             }
           }
           struct.setSuccessIsSet(true);
@@ -110198,15 +110354,15 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map330 = iprot.readMapBegin();
-                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map330.size);
-                  java.lang.String _key331;
-                  java.lang.String _val332;
-                  for (int _i333 = 0; _i333 < _map330.size; ++_i333)
+                  org.apache.thrift.protocol.TMap _map338 = iprot.readMapBegin();
+                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map338.size);
+                  java.lang.String _key339;
+                  java.lang.String _val340;
+                  for (int _i341 = 0; _i341 < _map338.size; ++_i341)
                   {
-                    _key331 = iprot.readString();
-                    _val332 = iprot.readString();
-                    struct.success.put(_key331, _val332);
+                    _key339 = iprot.readString();
+                    _val340 = iprot.readString();
+                    struct.success.put(_key339, _val340);
                   }
                   iprot.readMapEnd();
                 }
@@ -110243,10 +110399,10 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter334 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter342 : struct.success.entrySet())
             {
-              oprot.writeString(_iter334.getKey());
-              oprot.writeString(_iter334.getValue());
+              oprot.writeString(_iter342.getKey());
+              oprot.writeString(_iter342.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -110285,10 +110441,10 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter335 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter343 : struct.success.entrySet())
             {
-              oprot.writeString(_iter335.getKey());
-              oprot.writeString(_iter335.getValue());
+              oprot.writeString(_iter343.getKey());
+              oprot.writeString(_iter343.getValue());
             }
           }
         }
@@ -110303,15 +110459,15 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map336 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map336.size);
-            java.lang.String _key337;
-            java.lang.String _val338;
-            for (int _i339 = 0; _i339 < _map336.size; ++_i339)
+            org.apache.thrift.protocol.TMap _map344 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map344.size);
+            java.lang.String _key345;
+            java.lang.String _val346;
+            for (int _i347 = 0; _i347 < _map344.size; ++_i347)
             {
-              _key337 = iprot.readString();
-              _val338 = iprot.readString();
-              struct.success.put(_key337, _val338);
+              _key345 = iprot.readString();
+              _val346 = iprot.readString();
+              struct.success.put(_key345, _val346);
             }
           }
           struct.setSuccessIsSet(true);
@@ -114371,15 +114527,15 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map340 = iprot.readMapBegin();
-                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map340.size);
-                  java.lang.String _key341;
-                  java.lang.String _val342;
-                  for (int _i343 = 0; _i343 < _map340.size; ++_i343)
+                  org.apache.thrift.protocol.TMap _map348 = iprot.readMapBegin();
+                  struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map348.size);
+                  java.lang.String _key349;
+                  java.lang.String _val350;
+                  for (int _i351 = 0; _i351 < _map348.size; ++_i351)
                   {
-                    _key341 = iprot.readString();
-                    _val342 = iprot.readString();
-                    struct.success.put(_key341, _val342);
+                    _key349 = iprot.readString();
+                    _val350 = iprot.readString();
+                    struct.success.put(_key349, _val350);
                   }
                   iprot.readMapEnd();
                 }
@@ -114416,10 +114572,10 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter344 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter352 : struct.success.entrySet())
             {
-              oprot.writeString(_iter344.getKey());
-              oprot.writeString(_iter344.getValue());
+              oprot.writeString(_iter352.getKey());
+              oprot.writeString(_iter352.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -114458,10 +114614,10 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter345 : struct.success.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.String> _iter353 : struct.success.entrySet())
             {
-              oprot.writeString(_iter345.getKey());
-              oprot.writeString(_iter345.getValue());
+              oprot.writeString(_iter353.getKey());
+              oprot.writeString(_iter353.getValue());
             }
           }
         }
@@ -114476,15 +114632,15 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map346 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map346.size);
-            java.lang.String _key347;
-            java.lang.String _val348;
-            for (int _i349 = 0; _i349 < _map346.size; ++_i349)
+            org.apache.thrift.protocol.TMap _map354 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new java.util.HashMap<java.lang.String,java.lang.String>(2*_map354.size);
+            java.lang.String _key355;
+            java.lang.String _val356;
+            for (int _i357 = 0; _i357 < _map354.size; ++_i357)
             {
-              _key347 = iprot.readString();
-              _val348 = iprot.readString();
-              struct.success.put(_key347, _val348);
+              _key355 = iprot.readString();
+              _val356 = iprot.readString();
+              struct.success.put(_key355, _val356);
             }
           }
           struct.setSuccessIsSet(true);
@@ -142117,15 +142273,15 @@ public class RegistryService {
             case 1: // JOB_SUBMISSION_PRIORITY_MAP
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map350 = iprot.readMapBegin();
-                  struct.jobSubmissionPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map350.size);
-                  java.lang.String _key351;
-                  int _val352;
-                  for (int _i353 = 0; _i353 < _map350.size; ++_i353)
+                  org.apache.thrift.protocol.TMap _map358 = iprot.readMapBegin();
+                  struct.jobSubmissionPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map358.size);
+                  java.lang.String _key359;
+                  int _val360;
+                  for (int _i361 = 0; _i361 < _map358.size; ++_i361)
                   {
-                    _key351 = iprot.readString();
-                    _val352 = iprot.readI32();
-                    struct.jobSubmissionPriorityMap.put(_key351, _val352);
+                    _key359 = iprot.readString();
+                    _val360 = iprot.readI32();
+                    struct.jobSubmissionPriorityMap.put(_key359, _val360);
                   }
                   iprot.readMapEnd();
                 }
@@ -142153,10 +142309,10 @@ public class RegistryService {
           oprot.writeFieldBegin(JOB_SUBMISSION_PRIORITY_MAP_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, struct.jobSubmissionPriorityMap.size()));
-            for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter354 : struct.jobSubmissionPriorityMap.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter362 : struct.jobSubmissionPriorityMap.entrySet())
             {
-              oprot.writeString(_iter354.getKey());
-              oprot.writeI32(_iter354.getValue());
+              oprot.writeString(_iter362.getKey());
+              oprot.writeI32(_iter362.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -142181,10 +142337,10 @@ public class RegistryService {
         org.apache.thrift.protocol.TTupleProtocol oprot = (org.apache.thrift.protocol.TTupleProtocol) prot;
         {
           oprot.writeI32(struct.jobSubmissionPriorityMap.size());
-          for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter355 : struct.jobSubmissionPriorityMap.entrySet())
+          for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter363 : struct.jobSubmissionPriorityMap.entrySet())
           {
-            oprot.writeString(_iter355.getKey());
-            oprot.writeI32(_iter355.getValue());
+            oprot.writeString(_iter363.getKey());
+            oprot.writeI32(_iter363.getValue());
           }
         }
       }
@@ -142193,15 +142349,15 @@ public class RegistryService {
       public void read(org.apache.thrift.protocol.TProtocol prot, changeJobSubmissionPriorities_args struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TTupleProtocol iprot = (org.apache.thrift.protocol.TTupleProtocol) prot;
         {
-          org.apache.thrift.protocol.TMap _map356 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
-          struct.jobSubmissionPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map356.size);
-          java.lang.String _key357;
-          int _val358;
-          for (int _i359 = 0; _i359 < _map356.size; ++_i359)
+          org.apache.thrift.protocol.TMap _map364 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
+          struct.jobSubmissionPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map364.size);
+          java.lang.String _key365;
+          int _val366;
+          for (int _i367 = 0; _i367 < _map364.size; ++_i367)
           {
-            _key357 = iprot.readString();
-            _val358 = iprot.readI32();
-            struct.jobSubmissionPriorityMap.put(_key357, _val358);
+            _key365 = iprot.readString();
+            _val366 = iprot.readI32();
+            struct.jobSubmissionPriorityMap.put(_key365, _val366);
           }
         }
         struct.setJobSubmissionPriorityMapIsSet(true);
@@ -142990,15 +143146,15 @@ public class RegistryService {
             case 1: // DATA_MOVEMENT_PRIORITY_MAP
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map360 = iprot.readMapBegin();
-                  struct.dataMovementPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map360.size);
-                  java.lang.String _key361;
-                  int _val362;
-                  for (int _i363 = 0; _i363 < _map360.size; ++_i363)
+                  org.apache.thrift.protocol.TMap _map368 = iprot.readMapBegin();
+                  struct.dataMovementPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map368.size);
+                  java.lang.String _key369;
+                  int _val370;
+                  for (int _i371 = 0; _i371 < _map368.size; ++_i371)
                   {
-                    _key361 = iprot.readString();
-                    _val362 = iprot.readI32();
-                    struct.dataMovementPriorityMap.put(_key361, _val362);
+                    _key369 = iprot.readString();
+                    _val370 = iprot.readI32();
+                    struct.dataMovementPriorityMap.put(_key369, _val370);
                   }
                   iprot.readMapEnd();
                 }
@@ -143026,10 +143182,10 @@ public class RegistryService {
           oprot.writeFieldBegin(DATA_MOVEMENT_PRIORITY_MAP_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, struct.dataMovementPriorityMap.size()));
-            for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter364 : struct.dataMovementPriorityMap.entrySet())
+            for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter372 : struct.dataMovementPriorityMap.entrySet())
             {
-              oprot.writeString(_iter364.getKey());
-              oprot.writeI32(_iter364.getValue());
+              oprot.writeString(_iter372.getKey());
+              oprot.writeI32(_iter372.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -143054,10 +143210,10 @@ public class RegistryService {
         org.apache.thrift.protocol.TTupleProtocol oprot = (org.apache.thrift.protocol.TTupleProtocol) prot;
         {
           oprot.writeI32(struct.dataMovementPriorityMap.size());
-          for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter365 : struct.dataMovementPriorityMap.entrySet())
+          for (java.util.Map.Entry<java.lang.String, java.lang.Integer> _iter373 : struct.dataMovementPriorityMap.entrySet())
           {
-            oprot.writeString(_iter365.getKey());
-            oprot.writeI32(_iter365.getValue());
+            oprot.writeString(_iter373.getKey());
+            oprot.writeI32(_iter373.getValue());
           }
         }
       }
@@ -143066,15 +143222,15 @@ public class RegistryService {
       public void read(org.apache.thrift.protocol.TProtocol prot, changeDataMovementPriorities_args struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TTupleProtocol iprot = (org.apache.thrift.protocol.TTupleProtocol) prot;
         {
-          org.apache.thrift.protocol.TMap _map366 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
-          struct.dataMovementPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map366.size);
-          java.lang.String _key367;
-          int _val368;
-          for (int _i369 = 0; _i369 < _map366.size; ++_i369)
+          org.apache.thrift.protocol.TMap _map374 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
+          struct.dataMovementPriorityMap = new java.util.HashMap<java.lang.String,java.lang.Integer>(2*_map374.size);
+          java.lang.String _key375;
+          int _val376;
+          for (int _i377 = 0; _i377 < _map374.size; ++_i377)
           {
-            _key367 = iprot.readString();
-            _val368 = iprot.readI32();
-            struct.dataMovementPriorityMap.put(_key367, _val368);
+            _key375 = iprot.readString();
+            _val376 = iprot.readI32();
+            struct.dataMovementPriorityMap.put(_key375, _val376);
           }
         }
         struct.setDataMovementPriorityMapIsSet(true);
@@ -157895,14 +158051,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list370 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference>(_list370.size);
-                  org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _elem371;
-                  for (int _i372 = 0; _i372 < _list370.size; ++_i372)
+                  org.apache.thrift.protocol.TList _list378 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference>(_list378.size);
+                  org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _elem379;
+                  for (int _i380 = 0; _i380 < _list378.size; ++_i380)
                   {
-                    _elem371 = new org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference();
-                    _elem371.read(iprot);
-                    struct.success.add(_elem371);
+                    _elem379 = new org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference();
+                    _elem379.read(iprot);
+                    struct.success.add(_elem379);
                   }
                   iprot.readListEnd();
                 }
@@ -157939,9 +158095,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _iter373 : struct.success)
+            for (org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _iter381 : struct.success)
             {
-              _iter373.write(oprot);
+              _iter381.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -157980,9 +158136,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _iter374 : struct.success)
+            for (org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _iter382 : struct.success)
             {
-              _iter374.write(oprot);
+              _iter382.write(oprot);
             }
           }
         }
@@ -157997,14 +158153,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list375 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference>(_list375.size);
-            org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _elem376;
-            for (int _i377 = 0; _i377 < _list375.size; ++_i377)
+            org.apache.thrift.protocol.TList _list383 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference>(_list383.size);
+            org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference _elem384;
+            for (int _i385 = 0; _i385 < _list383.size; ++_i385)
             {
-              _elem376 = new org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference();
-              _elem376.read(iprot);
-              struct.success.add(_elem376);
+              _elem384 = new org.apache.airavata.model.appcatalog.gatewayprofile.ComputeResourcePreference();
+              _elem384.read(iprot);
+              struct.success.add(_elem384);
             }
           }
           struct.setSuccessIsSet(true);
@@ -158772,14 +158928,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list378 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference>(_list378.size);
-                  org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _elem379;
-                  for (int _i380 = 0; _i380 < _list378.size; ++_i380)
+                  org.apache.thrift.protocol.TList _list386 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference>(_list386.size);
+                  org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _elem387;
+                  for (int _i388 = 0; _i388 < _list386.size; ++_i388)
                   {
-                    _elem379 = new org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference();
-                    _elem379.read(iprot);
-                    struct.success.add(_elem379);
+                    _elem387 = new org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference();
+                    _elem387.read(iprot);
+                    struct.success.add(_elem387);
                   }
                   iprot.readListEnd();
                 }
@@ -158816,9 +158972,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _iter381 : struct.success)
+            for (org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _iter389 : struct.success)
             {
-              _iter381.write(oprot);
+              _iter389.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -158857,9 +159013,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _iter382 : struct.success)
+            for (org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _iter390 : struct.success)
             {
-              _iter382.write(oprot);
+              _iter390.write(oprot);
             }
           }
         }
@@ -158874,14 +159030,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list383 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference>(_list383.size);
-            org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _elem384;
-            for (int _i385 = 0; _i385 < _list383.size; ++_i385)
+            org.apache.thrift.protocol.TList _list391 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference>(_list391.size);
+            org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference _elem392;
+            for (int _i393 = 0; _i393 < _list391.size; ++_i393)
             {
-              _elem384 = new org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference();
-              _elem384.read(iprot);
-              struct.success.add(_elem384);
+              _elem392 = new org.apache.airavata.model.appcatalog.gatewayprofile.StoragePreference();
+              _elem392.read(iprot);
+              struct.success.add(_elem392);
             }
           }
           struct.setSuccessIsSet(true);
@@ -159544,14 +159700,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list386 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile>(_list386.size);
-                  org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _elem387;
-                  for (int _i388 = 0; _i388 < _list386.size; ++_i388)
+                  org.apache.thrift.protocol.TList _list394 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile>(_list394.size);
+                  org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _elem395;
+                  for (int _i396 = 0; _i396 < _list394.size; ++_i396)
                   {
-                    _elem387 = new org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile();
-                    _elem387.read(iprot);
-                    struct.success.add(_elem387);
+                    _elem395 = new org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile();
+                    _elem395.read(iprot);
+                    struct.success.add(_elem395);
                   }
                   iprot.readListEnd();
                 }
@@ -159588,9 +159744,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _iter389 : struct.success)
+            for (org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _iter397 : struct.success)
             {
-              _iter389.write(oprot);
+              _iter397.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -159629,9 +159785,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _iter390 : struct.success)
+            for (org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _iter398 : struct.success)
             {
-              _iter390.write(oprot);
+              _iter398.write(oprot);
             }
           }
         }
@@ -159646,14 +159802,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list391 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile>(_list391.size);
-            org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _elem392;
-            for (int _i393 = 0; _i393 < _list391.size; ++_i393)
+            org.apache.thrift.protocol.TList _list399 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile>(_list399.size);
+            org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile _elem400;
+            for (int _i401 = 0; _i401 < _list399.size; ++_i401)
             {
-              _elem392 = new org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile();
-              _elem392.read(iprot);
-              struct.success.add(_elem392);
+              _elem400 = new org.apache.airavata.model.appcatalog.gatewayprofile.GatewayResourceProfile();
+              _elem400.read(iprot);
+              struct.success.add(_elem400);
             }
           }
           struct.setSuccessIsSet(true);
@@ -174281,14 +174437,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list394 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference>(_list394.size);
-                  org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _elem395;
-                  for (int _i396 = 0; _i396 < _list394.size; ++_i396)
+                  org.apache.thrift.protocol.TList _list402 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference>(_list402.size);
+                  org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _elem403;
+                  for (int _i404 = 0; _i404 < _list402.size; ++_i404)
                   {
-                    _elem395 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference();
-                    _elem395.read(iprot);
-                    struct.success.add(_elem395);
+                    _elem403 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference();
+                    _elem403.read(iprot);
+                    struct.success.add(_elem403);
                   }
                   iprot.readListEnd();
                 }
@@ -174325,9 +174481,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _iter397 : struct.success)
+            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _iter405 : struct.success)
             {
-              _iter397.write(oprot);
+              _iter405.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -174366,9 +174522,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _iter398 : struct.success)
+            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _iter406 : struct.success)
             {
-              _iter398.write(oprot);
+              _iter406.write(oprot);
             }
           }
         }
@@ -174383,14 +174539,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list399 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference>(_list399.size);
-            org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _elem400;
-            for (int _i401 = 0; _i401 < _list399.size; ++_i401)
+            org.apache.thrift.protocol.TList _list407 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference>(_list407.size);
+            org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference _elem408;
+            for (int _i409 = 0; _i409 < _list407.size; ++_i409)
             {
-              _elem400 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference();
-              _elem400.read(iprot);
-              struct.success.add(_elem400);
+              _elem408 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserComputeResourcePreference();
+              _elem408.read(iprot);
+              struct.success.add(_elem408);
             }
           }
           struct.setSuccessIsSet(true);
@@ -175258,14 +175414,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list402 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference>(_list402.size);
-                  org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _elem403;
-                  for (int _i404 = 0; _i404 < _list402.size; ++_i404)
+                  org.apache.thrift.protocol.TList _list410 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference>(_list410.size);
+                  org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _elem411;
+                  for (int _i412 = 0; _i412 < _list410.size; ++_i412)
                   {
-                    _elem403 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference();
-                    _elem403.read(iprot);
-                    struct.success.add(_elem403);
+                    _elem411 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference();
+                    _elem411.read(iprot);
+                    struct.success.add(_elem411);
                   }
                   iprot.readListEnd();
                 }
@@ -175302,9 +175458,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _iter405 : struct.success)
+            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _iter413 : struct.success)
             {
-              _iter405.write(oprot);
+              _iter413.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -175343,9 +175499,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _iter406 : struct.success)
+            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _iter414 : struct.success)
             {
-              _iter406.write(oprot);
+              _iter414.write(oprot);
             }
           }
         }
@@ -175360,14 +175516,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list407 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference>(_list407.size);
-            org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _elem408;
-            for (int _i409 = 0; _i409 < _list407.size; ++_i409)
+            org.apache.thrift.protocol.TList _list415 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference>(_list415.size);
+            org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference _elem416;
+            for (int _i417 = 0; _i417 < _list415.size; ++_i417)
             {
-              _elem408 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference();
-              _elem408.read(iprot);
-              struct.success.add(_elem408);
+              _elem416 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserStoragePreference();
+              _elem416.read(iprot);
+              struct.success.add(_elem416);
             }
           }
           struct.setSuccessIsSet(true);
@@ -176030,14 +176186,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list410 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile>(_list410.size);
-                  org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _elem411;
-                  for (int _i412 = 0; _i412 < _list410.size; ++_i412)
+                  org.apache.thrift.protocol.TList _list418 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile>(_list418.size);
+                  org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _elem419;
+                  for (int _i420 = 0; _i420 < _list418.size; ++_i420)
                   {
-                    _elem411 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile();
-                    _elem411.read(iprot);
-                    struct.success.add(_elem411);
+                    _elem419 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile();
+                    _elem419.read(iprot);
+                    struct.success.add(_elem419);
                   }
                   iprot.readListEnd();
                 }
@@ -176074,9 +176230,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _iter413 : struct.success)
+            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _iter421 : struct.success)
             {
-              _iter413.write(oprot);
+              _iter421.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -176115,9 +176271,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _iter414 : struct.success)
+            for (org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _iter422 : struct.success)
             {
-              _iter414.write(oprot);
+              _iter422.write(oprot);
             }
           }
         }
@@ -176132,14 +176288,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list415 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile>(_list415.size);
-            org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _elem416;
-            for (int _i417 = 0; _i417 < _list415.size; ++_i417)
+            org.apache.thrift.protocol.TList _list423 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile>(_list423.size);
+            org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile _elem424;
+            for (int _i425 = 0; _i425 < _list423.size; ++_i425)
             {
-              _elem416 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile();
-              _elem416.read(iprot);
-              struct.success.add(_elem416);
+              _elem424 = new org.apache.airavata.model.appcatalog.userresourceprofile.UserResourceProfile();
+              _elem424.read(iprot);
+              struct.success.add(_elem424);
             }
           }
           struct.setSuccessIsSet(true);
@@ -181096,14 +181252,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list418 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list418.size);
-                  org.apache.airavata.model.status.QueueStatusModel _elem419;
-                  for (int _i420 = 0; _i420 < _list418.size; ++_i420)
+                  org.apache.thrift.protocol.TList _list426 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list426.size);
+                  org.apache.airavata.model.status.QueueStatusModel _elem427;
+                  for (int _i428 = 0; _i428 < _list426.size; ++_i428)
                   {
-                    _elem419 = new org.apache.airavata.model.status.QueueStatusModel();
-                    _elem419.read(iprot);
-                    struct.success.add(_elem419);
+                    _elem427 = new org.apache.airavata.model.status.QueueStatusModel();
+                    _elem427.read(iprot);
+                    struct.success.add(_elem427);
                   }
                   iprot.readListEnd();
                 }
@@ -181140,9 +181296,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.status.QueueStatusModel _iter421 : struct.success)
+            for (org.apache.airavata.model.status.QueueStatusModel _iter429 : struct.success)
             {
-              _iter421.write(oprot);
+              _iter429.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -181181,9 +181337,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.status.QueueStatusModel _iter422 : struct.success)
+            for (org.apache.airavata.model.status.QueueStatusModel _iter430 : struct.success)
             {
-              _iter422.write(oprot);
+              _iter430.write(oprot);
             }
           }
         }
@@ -181198,14 +181354,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list423 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list423.size);
-            org.apache.airavata.model.status.QueueStatusModel _elem424;
-            for (int _i425 = 0; _i425 < _list423.size; ++_i425)
+            org.apache.thrift.protocol.TList _list431 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list431.size);
+            org.apache.airavata.model.status.QueueStatusModel _elem432;
+            for (int _i433 = 0; _i433 < _list431.size; ++_i433)
             {
-              _elem424 = new org.apache.airavata.model.status.QueueStatusModel();
-              _elem424.read(iprot);
-              struct.success.add(_elem424);
+              _elem432 = new org.apache.airavata.model.status.QueueStatusModel();
+              _elem432.read(iprot);
+              struct.success.add(_elem432);
             }
           }
           struct.setSuccessIsSet(true);
@@ -181540,14 +181696,14 @@ public class RegistryService {
             case 1: // QUEUE_STATUSES
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list426 = iprot.readListBegin();
-                  struct.queueStatuses = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list426.size);
-                  org.apache.airavata.model.status.QueueStatusModel _elem427;
-                  for (int _i428 = 0; _i428 < _list426.size; ++_i428)
+                  org.apache.thrift.protocol.TList _list434 = iprot.readListBegin();
+                  struct.queueStatuses = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list434.size);
+                  org.apache.airavata.model.status.QueueStatusModel _elem435;
+                  for (int _i436 = 0; _i436 < _list434.size; ++_i436)
                   {
-                    _elem427 = new org.apache.airavata.model.status.QueueStatusModel();
-                    _elem427.read(iprot);
-                    struct.queueStatuses.add(_elem427);
+                    _elem435 = new org.apache.airavata.model.status.QueueStatusModel();
+                    _elem435.read(iprot);
+                    struct.queueStatuses.add(_elem435);
                   }
                   iprot.readListEnd();
                 }
@@ -181575,9 +181731,9 @@ public class RegistryService {
           oprot.writeFieldBegin(QUEUE_STATUSES_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.queueStatuses.size()));
-            for (org.apache.airavata.model.status.QueueStatusModel _iter429 : struct.queueStatuses)
+            for (org.apache.airavata.model.status.QueueStatusModel _iter437 : struct.queueStatuses)
             {
-              _iter429.write(oprot);
+              _iter437.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -181602,9 +181758,9 @@ public class RegistryService {
         org.apache.thrift.protocol.TTupleProtocol oprot = (org.apache.thrift.protocol.TTupleProtocol) prot;
         {
           oprot.writeI32(struct.queueStatuses.size());
-          for (org.apache.airavata.model.status.QueueStatusModel _iter430 : struct.queueStatuses)
+          for (org.apache.airavata.model.status.QueueStatusModel _iter438 : struct.queueStatuses)
           {
-            _iter430.write(oprot);
+            _iter438.write(oprot);
           }
         }
       }
@@ -181613,14 +181769,14 @@ public class RegistryService {
       public void read(org.apache.thrift.protocol.TProtocol prot, registerQueueStatuses_args struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TTupleProtocol iprot = (org.apache.thrift.protocol.TTupleProtocol) prot;
         {
-          org.apache.thrift.protocol.TList _list431 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-          struct.queueStatuses = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list431.size);
-          org.apache.airavata.model.status.QueueStatusModel _elem432;
-          for (int _i433 = 0; _i433 < _list431.size; ++_i433)
+          org.apache.thrift.protocol.TList _list439 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+          struct.queueStatuses = new java.util.ArrayList<org.apache.airavata.model.status.QueueStatusModel>(_list439.size);
+          org.apache.airavata.model.status.QueueStatusModel _elem440;
+          for (int _i441 = 0; _i441 < _list439.size; ++_i441)
           {
-            _elem432 = new org.apache.airavata.model.status.QueueStatusModel();
-            _elem432.read(iprot);
-            struct.queueStatuses.add(_elem432);
+            _elem440 = new org.apache.airavata.model.status.QueueStatusModel();
+            _elem440.read(iprot);
+            struct.queueStatuses.add(_elem440);
           }
         }
         struct.setQueueStatusesIsSet(true);
@@ -186058,14 +186214,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list434 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list434.size);
-                  org.apache.airavata.model.data.replica.DataProductModel _elem435;
-                  for (int _i436 = 0; _i436 < _list434.size; ++_i436)
+                  org.apache.thrift.protocol.TList _list442 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list442.size);
+                  org.apache.airavata.model.data.replica.DataProductModel _elem443;
+                  for (int _i444 = 0; _i444 < _list442.size; ++_i444)
                   {
-                    _elem435 = new org.apache.airavata.model.data.replica.DataProductModel();
-                    _elem435.read(iprot);
-                    struct.success.add(_elem435);
+                    _elem443 = new org.apache.airavata.model.data.replica.DataProductModel();
+                    _elem443.read(iprot);
+                    struct.success.add(_elem443);
                   }
                   iprot.readListEnd();
                 }
@@ -186102,9 +186258,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.data.replica.DataProductModel _iter437 : struct.success)
+            for (org.apache.airavata.model.data.replica.DataProductModel _iter445 : struct.success)
             {
-              _iter437.write(oprot);
+              _iter445.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -186143,9 +186299,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.data.replica.DataProductModel _iter438 : struct.success)
+            for (org.apache.airavata.model.data.replica.DataProductModel _iter446 : struct.success)
             {
-              _iter438.write(oprot);
+              _iter446.write(oprot);
             }
           }
         }
@@ -186160,14 +186316,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list439 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list439.size);
-            org.apache.airavata.model.data.replica.DataProductModel _elem440;
-            for (int _i441 = 0; _i441 < _list439.size; ++_i441)
+            org.apache.thrift.protocol.TList _list447 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list447.size);
+            org.apache.airavata.model.data.replica.DataProductModel _elem448;
+            for (int _i449 = 0; _i449 < _list447.size; ++_i449)
             {
-              _elem440 = new org.apache.airavata.model.data.replica.DataProductModel();
-              _elem440.read(iprot);
-              struct.success.add(_elem440);
+              _elem448 = new org.apache.airavata.model.data.replica.DataProductModel();
+              _elem448.read(iprot);
+              struct.success.add(_elem448);
             }
           }
           struct.setSuccessIsSet(true);
@@ -187325,14 +187481,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list442 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list442.size);
-                  org.apache.airavata.model.data.replica.DataProductModel _elem443;
-                  for (int _i444 = 0; _i444 < _list442.size; ++_i444)
+                  org.apache.thrift.protocol.TList _list450 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list450.size);
+                  org.apache.airavata.model.data.replica.DataProductModel _elem451;
+                  for (int _i452 = 0; _i452 < _list450.size; ++_i452)
                   {
-                    _elem443 = new org.apache.airavata.model.data.replica.DataProductModel();
-                    _elem443.read(iprot);
-                    struct.success.add(_elem443);
+                    _elem451 = new org.apache.airavata.model.data.replica.DataProductModel();
+                    _elem451.read(iprot);
+                    struct.success.add(_elem451);
                   }
                   iprot.readListEnd();
                 }
@@ -187369,9 +187525,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.data.replica.DataProductModel _iter445 : struct.success)
+            for (org.apache.airavata.model.data.replica.DataProductModel _iter453 : struct.success)
             {
-              _iter445.write(oprot);
+              _iter453.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -187410,9 +187566,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.data.replica.DataProductModel _iter446 : struct.success)
+            for (org.apache.airavata.model.data.replica.DataProductModel _iter454 : struct.success)
             {
-              _iter446.write(oprot);
+              _iter454.write(oprot);
             }
           }
         }
@@ -187427,14 +187583,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list447 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list447.size);
-            org.apache.airavata.model.data.replica.DataProductModel _elem448;
-            for (int _i449 = 0; _i449 < _list447.size; ++_i449)
+            org.apache.thrift.protocol.TList _list455 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.data.replica.DataProductModel>(_list455.size);
+            org.apache.airavata.model.data.replica.DataProductModel _elem456;
+            for (int _i457 = 0; _i457 < _list455.size; ++_i457)
             {
-              _elem448 = new org.apache.airavata.model.data.replica.DataProductModel();
-              _elem448.read(iprot);
-              struct.success.add(_elem448);
+              _elem456 = new org.apache.airavata.model.data.replica.DataProductModel();
+              _elem456.read(iprot);
+              struct.success.add(_elem456);
             }
           }
           struct.setSuccessIsSet(true);
@@ -191059,13 +191215,13 @@ public class RegistryService {
             case 2: // ACCESSIBLE_GROUP_RES_PROFILE_IDS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list450 = iprot.readListBegin();
-                  struct.accessibleGroupResProfileIds = new java.util.ArrayList<java.lang.String>(_list450.size);
-                  java.lang.String _elem451;
-                  for (int _i452 = 0; _i452 < _list450.size; ++_i452)
+                  org.apache.thrift.protocol.TList _list458 = iprot.readListBegin();
+                  struct.accessibleGroupResProfileIds = new java.util.ArrayList<java.lang.String>(_list458.size);
+                  java.lang.String _elem459;
+                  for (int _i460 = 0; _i460 < _list458.size; ++_i460)
                   {
-                    _elem451 = iprot.readString();
-                    struct.accessibleGroupResProfileIds.add(_elem451);
+                    _elem459 = iprot.readString();
+                    struct.accessibleGroupResProfileIds.add(_elem459);
                   }
                   iprot.readListEnd();
                 }
@@ -191098,9 +191254,9 @@ public class RegistryService {
           oprot.writeFieldBegin(ACCESSIBLE_GROUP_RES_PROFILE_IDS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.accessibleGroupResProfileIds.size()));
-            for (java.lang.String _iter453 : struct.accessibleGroupResProfileIds)
+            for (java.lang.String _iter461 : struct.accessibleGroupResProfileIds)
             {
-              oprot.writeString(_iter453);
+              oprot.writeString(_iter461);
             }
             oprot.writeListEnd();
           }
@@ -191126,9 +191282,9 @@ public class RegistryService {
         oprot.writeString(struct.gatewayId);
         {
           oprot.writeI32(struct.accessibleGroupResProfileIds.size());
-          for (java.lang.String _iter454 : struct.accessibleGroupResProfileIds)
+          for (java.lang.String _iter462 : struct.accessibleGroupResProfileIds)
           {
-            oprot.writeString(_iter454);
+            oprot.writeString(_iter462);
           }
         }
       }
@@ -191139,13 +191295,13 @@ public class RegistryService {
         struct.gatewayId = iprot.readString();
         struct.setGatewayIdIsSet(true);
         {
-          org.apache.thrift.protocol.TList _list455 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-          struct.accessibleGroupResProfileIds = new java.util.ArrayList<java.lang.String>(_list455.size);
-          java.lang.String _elem456;
-          for (int _i457 = 0; _i457 < _list455.size; ++_i457)
+          org.apache.thrift.protocol.TList _list463 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+          struct.accessibleGroupResProfileIds = new java.util.ArrayList<java.lang.String>(_list463.size);
+          java.lang.String _elem464;
+          for (int _i465 = 0; _i465 < _list463.size; ++_i465)
           {
-            _elem456 = iprot.readString();
-            struct.accessibleGroupResProfileIds.add(_elem456);
+            _elem464 = iprot.readString();
+            struct.accessibleGroupResProfileIds.add(_elem464);
           }
         }
         struct.setAccessibleGroupResProfileIdsIsSet(true);
@@ -191552,14 +191708,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list458 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile>(_list458.size);
-                  org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _elem459;
-                  for (int _i460 = 0; _i460 < _list458.size; ++_i460)
+                  org.apache.thrift.protocol.TList _list466 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile>(_list466.size);
+                  org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _elem467;
+                  for (int _i468 = 0; _i468 < _list466.size; ++_i468)
                   {
-                    _elem459 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile();
-                    _elem459.read(iprot);
-                    struct.success.add(_elem459);
+                    _elem467 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile();
+                    _elem467.read(iprot);
+                    struct.success.add(_elem467);
                   }
                   iprot.readListEnd();
                 }
@@ -191596,9 +191752,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _iter461 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _iter469 : struct.success)
             {
-              _iter461.write(oprot);
+              _iter469.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -191637,9 +191793,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _iter462 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _iter470 : struct.success)
             {
-              _iter462.write(oprot);
+              _iter470.write(oprot);
             }
           }
         }
@@ -191654,14 +191810,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list463 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile>(_list463.size);
-            org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _elem464;
-            for (int _i465 = 0; _i465 < _list463.size; ++_i465)
+            org.apache.thrift.protocol.TList _list471 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile>(_list471.size);
+            org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile _elem472;
+            for (int _i473 = 0; _i473 < _list471.size; ++_i473)
             {
-              _elem464 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile();
-              _elem464.read(iprot);
-              struct.success.add(_elem464);
+              _elem472 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupResourceProfile();
+              _elem472.read(iprot);
+              struct.success.add(_elem472);
             }
           }
           struct.setSuccessIsSet(true);
@@ -197576,14 +197732,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list466 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference>(_list466.size);
-                  org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _elem467;
-                  for (int _i468 = 0; _i468 < _list466.size; ++_i468)
+                  org.apache.thrift.protocol.TList _list474 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference>(_list474.size);
+                  org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _elem475;
+                  for (int _i476 = 0; _i476 < _list474.size; ++_i476)
                   {
-                    _elem467 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference();
-                    _elem467.read(iprot);
-                    struct.success.add(_elem467);
+                    _elem475 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference();
+                    _elem475.read(iprot);
+                    struct.success.add(_elem475);
                   }
                   iprot.readListEnd();
                 }
@@ -197620,9 +197776,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _iter469 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _iter477 : struct.success)
             {
-              _iter469.write(oprot);
+              _iter477.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -197661,9 +197817,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _iter470 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _iter478 : struct.success)
             {
-              _iter470.write(oprot);
+              _iter478.write(oprot);
             }
           }
         }
@@ -197678,14 +197834,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list471 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference>(_list471.size);
-            org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _elem472;
-            for (int _i473 = 0; _i473 < _list471.size; ++_i473)
+            org.apache.thrift.protocol.TList _list479 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference>(_list479.size);
+            org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference _elem480;
+            for (int _i481 = 0; _i481 < _list479.size; ++_i481)
             {
-              _elem472 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference();
-              _elem472.read(iprot);
-              struct.success.add(_elem472);
+              _elem480 = new org.apache.airavata.model.appcatalog.groupresourceprofile.GroupComputeResourcePreference();
+              _elem480.read(iprot);
+              struct.success.add(_elem480);
             }
           }
           struct.setSuccessIsSet(true);
@@ -198453,14 +198609,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list474 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy>(_list474.size);
-                  org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _elem475;
-                  for (int _i476 = 0; _i476 < _list474.size; ++_i476)
+                  org.apache.thrift.protocol.TList _list482 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy>(_list482.size);
+                  org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _elem483;
+                  for (int _i484 = 0; _i484 < _list482.size; ++_i484)
                   {
-                    _elem475 = new org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy();
-                    _elem475.read(iprot);
-                    struct.success.add(_elem475);
+                    _elem483 = new org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy();
+                    _elem483.read(iprot);
+                    struct.success.add(_elem483);
                   }
                   iprot.readListEnd();
                 }
@@ -198497,9 +198653,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _iter477 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _iter485 : struct.success)
             {
-              _iter477.write(oprot);
+              _iter485.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -198538,9 +198694,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _iter478 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _iter486 : struct.success)
             {
-              _iter478.write(oprot);
+              _iter486.write(oprot);
             }
           }
         }
@@ -198555,14 +198711,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list479 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy>(_list479.size);
-            org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _elem480;
-            for (int _i481 = 0; _i481 < _list479.size; ++_i481)
+            org.apache.thrift.protocol.TList _list487 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy>(_list487.size);
+            org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy _elem488;
+            for (int _i489 = 0; _i489 < _list487.size; ++_i489)
             {
-              _elem480 = new org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy();
-              _elem480.read(iprot);
-              struct.success.add(_elem480);
+              _elem488 = new org.apache.airavata.model.appcatalog.groupresourceprofile.BatchQueueResourcePolicy();
+              _elem488.read(iprot);
+              struct.success.add(_elem488);
             }
           }
           struct.setSuccessIsSet(true);
@@ -199330,14 +199486,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list482 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy>(_list482.size);
-                  org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _elem483;
-                  for (int _i484 = 0; _i484 < _list482.size; ++_i484)
+                  org.apache.thrift.protocol.TList _list490 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy>(_list490.size);
+                  org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _elem491;
+                  for (int _i492 = 0; _i492 < _list490.size; ++_i492)
                   {
-                    _elem483 = new org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy();
-                    _elem483.read(iprot);
-                    struct.success.add(_elem483);
+                    _elem491 = new org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy();
+                    _elem491.read(iprot);
+                    struct.success.add(_elem491);
                   }
                   iprot.readListEnd();
                 }
@@ -199374,9 +199530,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _iter485 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _iter493 : struct.success)
             {
-              _iter485.write(oprot);
+              _iter493.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -199415,9 +199571,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _iter486 : struct.success)
+            for (org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _iter494 : struct.success)
             {
-              _iter486.write(oprot);
+              _iter494.write(oprot);
             }
           }
         }
@@ -199432,14 +199588,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list487 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy>(_list487.size);
-            org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _elem488;
-            for (int _i489 = 0; _i489 < _list487.size; ++_i489)
+            org.apache.thrift.protocol.TList _list495 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy>(_list495.size);
+            org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy _elem496;
+            for (int _i497 = 0; _i497 < _list495.size; ++_i497)
             {
-              _elem488 = new org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy();
-              _elem488.read(iprot);
-              struct.success.add(_elem488);
+              _elem496 = new org.apache.airavata.model.appcatalog.groupresourceprofile.ComputeResourcePolicy();
+              _elem496.read(iprot);
+              struct.success.add(_elem496);
             }
           }
           struct.setSuccessIsSet(true);
@@ -205166,14 +205322,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list490 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.Parser>(_list490.size);
-                  org.apache.airavata.model.appcatalog.parser.Parser _elem491;
-                  for (int _i492 = 0; _i492 < _list490.size; ++_i492)
+                  org.apache.thrift.protocol.TList _list498 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.Parser>(_list498.size);
+                  org.apache.airavata.model.appcatalog.parser.Parser _elem499;
+                  for (int _i500 = 0; _i500 < _list498.size; ++_i500)
                   {
-                    _elem491 = new org.apache.airavata.model.appcatalog.parser.Parser();
-                    _elem491.read(iprot);
-                    struct.success.add(_elem491);
+                    _elem499 = new org.apache.airavata.model.appcatalog.parser.Parser();
+                    _elem499.read(iprot);
+                    struct.success.add(_elem499);
                   }
                   iprot.readListEnd();
                 }
@@ -205210,9 +205366,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.parser.Parser _iter493 : struct.success)
+            for (org.apache.airavata.model.appcatalog.parser.Parser _iter501 : struct.success)
             {
-              _iter493.write(oprot);
+              _iter501.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -205251,9 +205407,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.parser.Parser _iter494 : struct.success)
+            for (org.apache.airavata.model.appcatalog.parser.Parser _iter502 : struct.success)
             {
-              _iter494.write(oprot);
+              _iter502.write(oprot);
             }
           }
         }
@@ -205268,14 +205424,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list495 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.Parser>(_list495.size);
-            org.apache.airavata.model.appcatalog.parser.Parser _elem496;
-            for (int _i497 = 0; _i497 < _list495.size; ++_i497)
+            org.apache.thrift.protocol.TList _list503 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.Parser>(_list503.size);
+            org.apache.airavata.model.appcatalog.parser.Parser _elem504;
+            for (int _i505 = 0; _i505 < _list503.size; ++_i505)
             {
-              _elem496 = new org.apache.airavata.model.appcatalog.parser.Parser();
-              _elem496.read(iprot);
-              struct.success.add(_elem496);
+              _elem504 = new org.apache.airavata.model.appcatalog.parser.Parser();
+              _elem504.read(iprot);
+              struct.success.add(_elem504);
             }
           }
           struct.setSuccessIsSet(true);
@@ -207890,14 +208046,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list498 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list498.size);
-                  org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem499;
-                  for (int _i500 = 0; _i500 < _list498.size; ++_i500)
+                  org.apache.thrift.protocol.TList _list506 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list506.size);
+                  org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem507;
+                  for (int _i508 = 0; _i508 < _list506.size; ++_i508)
                   {
-                    _elem499 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
-                    _elem499.read(iprot);
-                    struct.success.add(_elem499);
+                    _elem507 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
+                    _elem507.read(iprot);
+                    struct.success.add(_elem507);
                   }
                   iprot.readListEnd();
                 }
@@ -207934,9 +208090,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter501 : struct.success)
+            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter509 : struct.success)
             {
-              _iter501.write(oprot);
+              _iter509.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -207975,9 +208131,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter502 : struct.success)
+            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter510 : struct.success)
             {
-              _iter502.write(oprot);
+              _iter510.write(oprot);
             }
           }
         }
@@ -207992,14 +208148,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list503 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list503.size);
-            org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem504;
-            for (int _i505 = 0; _i505 < _list503.size; ++_i505)
+            org.apache.thrift.protocol.TList _list511 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list511.size);
+            org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem512;
+            for (int _i513 = 0; _i513 < _list511.size; ++_i513)
             {
-              _elem504 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
-              _elem504.read(iprot);
-              struct.success.add(_elem504);
+              _elem512 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
+              _elem512.read(iprot);
+              struct.success.add(_elem512);
             }
           }
           struct.setSuccessIsSet(true);
@@ -209595,14 +209751,14 @@ public class RegistryService {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list506 = iprot.readListBegin();
-                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list506.size);
-                  org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem507;
-                  for (int _i508 = 0; _i508 < _list506.size; ++_i508)
+                  org.apache.thrift.protocol.TList _list514 = iprot.readListBegin();
+                  struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list514.size);
+                  org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem515;
+                  for (int _i516 = 0; _i516 < _list514.size; ++_i516)
                   {
-                    _elem507 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
-                    _elem507.read(iprot);
-                    struct.success.add(_elem507);
+                    _elem515 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
+                    _elem515.read(iprot);
+                    struct.success.add(_elem515);
                   }
                   iprot.readListEnd();
                 }
@@ -209639,9 +209795,9 @@ public class RegistryService {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter509 : struct.success)
+            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter517 : struct.success)
             {
-              _iter509.write(oprot);
+              _iter517.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -209680,9 +209836,9 @@ public class RegistryService {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter510 : struct.success)
+            for (org.apache.airavata.model.appcatalog.parser.ParsingTemplate _iter518 : struct.success)
             {
-              _iter510.write(oprot);
+              _iter518.write(oprot);
             }
           }
         }
@@ -209697,14 +209853,14 @@ public class RegistryService {
         java.util.BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list511 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list511.size);
-            org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem512;
-            for (int _i513 = 0; _i513 < _list511.size; ++_i513)
+            org.apache.thrift.protocol.TList _list519 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new java.util.ArrayList<org.apache.airavata.model.appcatalog.parser.ParsingTemplate>(_list519.size);
+            org.apache.airavata.model.appcatalog.parser.ParsingTemplate _elem520;
+            for (int _i521 = 0; _i521 < _list519.size; ++_i521)
             {
-              _elem512 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
-              _elem512.read(iprot);
-              struct.success.add(_elem512);
+              _elem520 = new org.apache.airavata.model.appcatalog.parser.ParsingTemplate();
+              _elem520.read(iprot);
+              struct.success.add(_elem520);
             }
           }
           struct.setSuccessIsSet(true);
diff --git a/thrift-interface-descriptions/component-cpis/registry-api.thrift b/thrift-interface-descriptions/component-cpis/registry-api.thrift
index c27082c..e461bdf 100644
--- a/thrift-interface-descriptions/component-cpis/registry-api.thrift
+++ b/thrift-interface-descriptions/component-cpis/registry-api.thrift
@@ -363,13 +363,16 @@ service RegistryService extends base_api.BaseAPI {
              * @param resourceHostName
              *       Hostname id substring with which to further filter statistics.
              *
+             * @param accessibleExpIds
+             *    Experiment IDs which are accessible to the current user.
              **/
             experiment_model.ExperimentStatistics getExperimentStatistics(1: required string gatewayId,
                                     2: required i64 fromTime,
                                     3: required i64 toTime,
                                     4: string userName,
                                     5: string applicationName,
-                                    6: string resourceHostName)
+                                    6: string resourceHostName,
+                                    7: required list<string> accessibleExpIds)
                         throws (1: registry_api_errors.RegistryServiceException rse)