You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by sc...@apache.org on 2015/06/07 19:00:48 UTC

[07/44] airavata git commit: Changing the thrift model variable names to lower camel case

Changing the thrift model variable names to lower camel case


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

Branch: refs/heads/mongo-registry
Commit: b376aa859656d99dcc0651e2d381ed7d13427f3b
Parents: 86994f6
Author: Supun Nakandala <sc...@apache.org>
Authored: Sun May 24 23:37:55 2015 +0530
Committer: Supun Nakandala <sc...@apache.org>
Committed: Sun May 24 23:37:57 2015 +0530

----------------------------------------------------------------------
 .../server/handler/AiravataServerHandler.java   |   8 +-
 .../AiravataExperimentStatusUpdator.java        |   4 +-
 .../api/server/util/DataModelUtils.java         |   4 +-
 .../handler/AiravataServerHandlerTest.java      |  14 +-
 .../lib/airavata/experimentModel_types.cpp      | 136 ++++++------
 .../lib/airavata/experimentModel_types.h        | 112 +++++-----
 .../lib/airavata/workspaceModel_types.cpp       |  14 +-
 .../lib/airavata/workspaceModel_types.h         |  10 +-
 .../Model/Workspace/Experiment/Types.php        | 160 +++++++--------
 .../lib/Airavata/Model/Workspace/Types.php      |  16 +-
 .../model/workspace/experiment/ttypes.py        | 188 ++++++++---------
 .../apache/airavata/model/workspace/ttypes.py   |  20 +-
 .../client/samples/CancelExperiments.java       |   2 +-
 .../client/samples/CreateLaunchBES.java         |   6 +-
 .../client/samples/CreateLaunchExperiment.java  |   6 +-
 .../samples/CreateLaunchExperimentUS3.java      |   2 +-
 .../samples/TestCreateLaunchExperiment.java     |   6 +-
 .../airavata/model/workspace/Project.java       |  90 ++++----
 .../ComputationalResourceScheduling.java        |  96 ++++-----
 .../experiment/DataTransferDetails.java         | 115 +++++------
 .../workspace/experiment/ErrorDetails.java      |  90 ++++----
 .../model/workspace/experiment/Experiment.java  | 205 +++++++++----------
 .../workspace/experiment/ExperimentSummary.java | 176 ++++++++--------
 .../model/workspace/experiment/JobDetails.java  | 115 +++++------
 .../model/workspace/experiment/TaskDetails.java | 115 +++++------
 .../experiment/UserConfigurationData.java       |  88 ++++----
 .../model/util/ExperimentModelUtil.java         |   4 +-
 .../experimentModel.thrift                      |  20 +-
 .../workspaceModel.thrift                       |   2 +-
 .../apache/airavata/gfac/cpi/GfacService.java   |  56 ++---
 .../apache/airavata/gfac/cpi/GfacService.java   |  56 ++---
 .../gaussian/handler/GaussianHandler.java       |   6 +-
 .../gfac/bes/provider/impl/BESProvider.java     |  45 ++--
 .../bes/security/UNICORESecurityContext.java    |  19 +-
 .../gfac/bes/utils/DataTransferrer.java         |   2 +-
 .../airavata/gfac/bes/utils/JSDLUtils.java      |  25 +--
 .../gfac/bes/utils/ResourceProcessor.java       |   8 +-
 .../gfac/core/context/JobExecutionContext.java  |   4 +-
 .../airavata/gfac/core/cpi/BetterGfacImpl.java  |  82 ++++----
 .../apache/airavata/gfac/core/cpi/GFacImpl.java |  52 ++---
 .../gfac/core/handler/AbstractHandler.java      |   4 +-
 .../core/monitor/AiravataJobStatusUpdator.java  |   2 +-
 .../gfac/core/monitor/ExperimentIdentity.java   |   6 +-
 .../core/monitor/GfacInternalStatusUpdator.java |   6 +-
 .../airavata/gfac/core/monitor/MonitorID.java   |  28 +--
 .../state/GfacExperimentStateChangeRequest.java |   6 +-
 .../monitor/state/JobStatusChangeRequest.java   |   4 +-
 .../monitor/state/JobStatusChangedEvent.java    |   4 +-
 .../airavata/gfac/core/utils/GFacUtils.java     |  32 +--
 .../gfac/core/utils/OutHandlerWorker.java       |   2 +-
 .../handler/GSISSHDirectorySetupHandler.java    |   4 +-
 .../gfac/gsissh/handler/GSISSHInputHandler.java |   6 +-
 .../gsissh/handler/GSISSHOutputHandler.java     |  14 +-
 .../gsissh/handler/NewGSISSHOutputHandler.java  |   2 +-
 .../gsissh/provider/impl/GSISSHProvider.java    |  22 +-
 .../gfac/gsissh/util/GFACGSISSHUtils.java       |   2 +-
 .../impl/GSISSHProviderTestWithMyProxyAuth.java |   4 +-
 .../gfac/local/provider/impl/LocalProvider.java |  24 +--
 .../gfac/services/impl/LocalProviderTest.java   |   6 +-
 .../gfac/monitor/email/EmailBasedMonitor.java   |   8 +-
 .../airavata/gfac/monitor/HPCMonitorID.java     |  12 +-
 .../handlers/GridPullMonitorHandler.java        |   6 +-
 .../monitor/impl/pull/qstat/HPCPullMonitor.java |  44 ++--
 .../impl/pull/qstat/ResourceConnection.java     |   4 +-
 .../monitor/impl/push/amqp/AMQPMonitor.java     |  10 +-
 .../airavata/gfac/monitor/util/CommonUtils.java |  20 +-
 .../ssh/handler/AdvancedSCPInputHandler.java    |   4 +-
 .../ssh/handler/AdvancedSCPOutputHandler.java   |   4 +-
 .../gfac/ssh/handler/NewSSHOutputHandler.java   |   2 +-
 .../ssh/handler/SSHDirectorySetupHandler.java   |   4 +-
 .../gfac/ssh/handler/SSHInputHandler.java       |   6 +-
 .../gfac/ssh/handler/SSHOutputHandler.java      |  14 +-
 .../gfac/ssh/provider/impl/SSHProvider.java     |  26 +--
 .../airavata/gfac/ssh/util/GFACSSHUtils.java    |   2 +-
 .../airavata/gfac/ssh/util/HandleOutputs.java   |   2 +-
 .../services/impl/BigRed2TestWithSSHAuth.java   |   4 +-
 .../impl/SSHProviderTestWithSSHAuth.java        |   2 +-
 .../airavata/integration/DataRetrievalIT.java   |   6 +-
 .../server/OrchestratorServerHandler.java       |  10 +-
 .../orchestrator/cpi/OrchestratorService.java   |  56 ++---
 .../core/model/ExperimentConfigurationData.java |   4 +-
 .../cpi/impl/SimpleOrchestratorImpl.java        |  14 +-
 .../orchestrator/core/NewOrchestratorTest.java  |   2 +-
 .../core/OrchestratorTestWithGRAM.java          |   2 +-
 .../orchestrator/core/ValidatorTest.java        |   6 +-
 .../orchestrator/core/util/SecondValidator.java |   2 +-
 .../orchestrator/core/util/TestValidator.java   |   4 +-
 .../registry/jpa/impl/ExperimentRegistry.java   |  54 ++---
 .../registry/jpa/impl/ProjectRegistry.java      |   6 +-
 .../registry/jpa/impl/RegistryImpl.java         |   6 +-
 .../registry/jpa/model/ErrorDetail.java         |   4 +-
 .../registry/jpa/model/ProjectUser.java         |   4 +-
 .../registry/jpa/model/ProjectUser_PK.java      |   4 +-
 .../jpa/resources/ErrorDetailResource.java      |   6 +-
 .../jpa/resources/ProjectUserResource.java      |   4 +-
 .../registry/jpa/resources/Utils.java           |   4 +-
 .../registry/jpa/resources/WorkerResource.java  |   2 +-
 .../jpa/utils/ThriftDataModelConversion.java    |  22 +-
 .../jpa/ExecutionErrorResourceTest.java         |   6 +-
 .../jpa/ExperimentDataResourceTest.java         |   2 +-
 .../jpa/ExperimentMetadataResourceTest.java     |   2 +-
 .../registry/jpa/GFacJobDataResourceTest.java   |   2 +-
 .../registry/jpa/GFacJobStatusResourceTest.java |   2 +-
 .../registry/jpa/GramDataResourceTest.java      |   2 +-
 .../registry/jpa/NodeDataResourceTest.java      |   2 +-
 .../jpa/OrchestratorDataResourceTest.java       |   2 +-
 .../registry/jpa/RegistryUseCaseTest.java       |  14 +-
 .../registry/jpa/WorkflowDataResourceTest.java  |   2 +-
 .../registry/cpi/CompositeIdentifier.java       |  21 +-
 .../ExperimentExecution.java                    |   6 +-
 .../engine/interpretor/WorkflowInterpreter.java |  36 ++--
 .../core/SimpleWorkflowInterpreter.java         |  16 +-
 .../WorkflowInterpretorEventListener.java       |  24 +--
 .../ui/experiment/LaunchApplicationWindow.java  |  16 +-
 .../WorkflowInterpreterLaunchWindow.java        |  20 +-
 .../xbaya/ui/monitor/MonitorEventHandler.java   |   6 +-
 .../airavata/api/samples/ExperimentSample.java  |   2 +-
 .../airavata/gsi/ssh/api/job/JobDescriptor.java |   9 +-
 .../gsi/ssh/api/job/PBSOutputParser.java        |   2 +-
 .../gsi/ssh/api/job/SlurmOutputParser.java      |   2 +-
 .../gsi/ssh/api/job/UGEOutputParser.java        |   2 +-
 121 files changed, 1432 insertions(+), 1519 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/handler/AiravataServerHandler.java
----------------------------------------------------------------------
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 fff3810..c905bcd 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
@@ -1430,11 +1430,11 @@ public class AiravataServerHandler implements Airavata.Iface {
                     List<Object> taskDetails = registry.get(RegistryModelType.TASK_DETAIL, Constants.FieldConstants.TaskDetailConstants.NODE_ID, nodeInstanceId);
                     if (taskDetails != null && !taskDetails.isEmpty()){
                         for (Object ts : taskDetails){
-                            String taskID = ((TaskDetails) ts).getTaskID();
+                            String taskID = ((TaskDetails) ts).getTaskId();
                             List<Object> jobDetails = registry.get(RegistryModelType.JOB_DETAIL, Constants.FieldConstants.JobDetaisConstants.TASK_ID, taskID);
                             if (jobDetails != null && !jobDetails.isEmpty()){
                                 for (Object job : jobDetails){
-                                    String jobID = ((JobDetails) job).getJobID();
+                                    String jobID = ((JobDetails) job).getJobId();
                                     jobStatus.put(jobID, ((JobDetails) job).getJobStatus());
                                 }
                             }
@@ -1468,7 +1468,7 @@ public class AiravataServerHandler implements Airavata.Iface {
                     List<Object> taskDetails = registry.get(RegistryModelType.TASK_DETAIL, Constants.FieldConstants.TaskDetailConstants.NODE_ID, nodeInstanceId);
                     if (taskDetails != null && !taskDetails.isEmpty()){
                         for (Object ts : taskDetails){
-                            String taskID = ((TaskDetails) ts).getTaskID();
+                            String taskID = ((TaskDetails) ts).getTaskId();
                             List<Object> jobDetails = registry.get(RegistryModelType.JOB_DETAIL, Constants.FieldConstants.JobDetaisConstants.TASK_ID, taskID);
                             if (jobDetails != null && !jobDetails.isEmpty()){
                                 for (Object job : jobDetails){
@@ -1505,7 +1505,7 @@ public class AiravataServerHandler implements Airavata.Iface {
                     List<Object> taskDetails = registry.get(RegistryModelType.TASK_DETAIL, Constants.FieldConstants.TaskDetailConstants.NODE_ID, nodeInstanceId);
                     if (taskDetails != null && !taskDetails.isEmpty()){
                         for (Object ts : taskDetails){
-                            String taskID = ((TaskDetails) ts).getTaskID();
+                            String taskID = ((TaskDetails) ts).getTaskId();
                             List<Object> dataTransferDetails = registry.get(RegistryModelType.DATA_TRANSFER_DETAIL, Constants.FieldConstants.JobDetaisConstants.TASK_ID, taskID);
                             if (dataTransferDetails != null && !dataTransferDetails.isEmpty()){
                                 for (Object dataTransfer : dataTransferDetails){

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java
index dd7bcd0..1d4b577 100644
--- a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java
+++ b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/listener/AiravataExperimentStatusUpdator.java
@@ -23,11 +23,9 @@ package org.apache.airavata.api.server.listener;
 import com.google.common.eventbus.Subscribe;
 import org.apache.airavata.api.server.util.DataModelUtils;
 import org.apache.airavata.common.exception.AiravataException;
-import org.apache.airavata.common.exception.ApplicationSettingsException;
 import org.apache.airavata.common.utils.*;
 import org.apache.airavata.common.utils.listener.AbstractActivityListener;
 import org.apache.airavata.messaging.core.MessageContext;
-import org.apache.airavata.messaging.core.MessageHandler;
 import org.apache.airavata.messaging.core.Publisher;
 import org.apache.airavata.messaging.core.impl.RabbitMQTaskLaunchConsumer;
 import org.apache.airavata.model.messaging.event.ExperimentStatusChangeEvent;
@@ -188,7 +186,7 @@ public class AiravataExperimentStatusUpdator implements AbstractActivityListener
     	Experiment details = (Experiment)airavataRegistry.get(RegistryModelType.EXPERIMENT, experimentId);
         if(details == null) {
             details = new Experiment();
-            details.setExperimentID(experimentId);
+            details.setExperimentId(experimentId);
         }
         org.apache.airavata.model.workspace.experiment.ExperimentStatus status = new org.apache.airavata.model.workspace.experiment.ExperimentStatus();
         status.setExperimentState(state);

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/util/DataModelUtils.java
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/util/DataModelUtils.java b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/util/DataModelUtils.java
index 8af8956..d630572 100644
--- a/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/util/DataModelUtils.java
+++ b/airavata-api/airavata-api-server/src/main/java/org/apache/airavata/api/server/util/DataModelUtils.java
@@ -48,8 +48,8 @@ public class DataModelUtils {
 				}
 			}
 		} catch (AppCatalogException e) {
-            logger.error("Error while retrieving execution type for experiment : " + experiment.getExperimentID(), e);
-            throw new Exception("Error while retrieving execution type for experiment : " + experiment.getExperimentID(), e);
+            logger.error("Error while retrieving execution type for experiment : " + experiment.getExperimentId(), e);
+            throw new Exception("Error while retrieving execution type for experiment : " + experiment.getExperimentId(), e);
 		}
 		return ExecutionType.UNKNOWN;
 	}

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-api-server/src/test/java/org/apache/airavata/api/server/handler/AiravataServerHandlerTest.java
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-api-server/src/test/java/org/apache/airavata/api/server/handler/AiravataServerHandlerTest.java b/airavata-api/airavata-api-server/src/test/java/org/apache/airavata/api/server/handler/AiravataServerHandlerTest.java
index 1094563..66be2f2 100644
--- a/airavata-api/airavata-api-server/src/test/java/org/apache/airavata/api/server/handler/AiravataServerHandlerTest.java
+++ b/airavata-api/airavata-api-server/src/test/java/org/apache/airavata/api/server/handler/AiravataServerHandlerTest.java
@@ -80,7 +80,7 @@ public class AiravataServerHandlerTest {
 
             //testing the update of a project
             Project updatedProject = new Project();
-            updatedProject.setProjectID(projectId1);
+            updatedProject.setProjectId(projectId1);
             updatedProject.setOwner("TestUser"+TAG);
             updatedProject.setName("UpdatedTestProject"+TAG);
             updatedProject.setDescription("This is an updated test project"+TAG);
@@ -88,7 +88,7 @@ public class AiravataServerHandlerTest {
 
             //testing project retrieval
             Project retrievedProject = airavataServerHandler.getProject(projectId1);
-            Assert.assertEquals(updatedProject.getProjectID(), retrievedProject.getProjectID());
+            Assert.assertEquals(updatedProject.getProjectId(), retrievedProject.getProjectId());
             Assert.assertEquals(updatedProject.getOwner(), retrievedProject.getOwner());
             Assert.assertEquals(updatedProject.getName(), retrievedProject.getName());
             Assert.assertEquals(updatedProject.getDescription(), retrievedProject.getDescription());
@@ -184,7 +184,7 @@ public class AiravataServerHandlerTest {
             ComputationalResourceScheduling scheduling = new ComputationalResourceScheduling();
             scheduling.setResourceHostId(UUID.randomUUID().toString());
             scheduling.setComputationalProjectAccount("TG-STA110014S");
-            scheduling.setTotalCPUCount(1);
+            scheduling.setTotalCpuCount(1);
             scheduling.setNodeCount(1);
             scheduling.setWallTimeLimit(15);
             scheduling.setQueueName("normal");
@@ -195,7 +195,7 @@ public class AiravataServerHandlerTest {
             userConfigurationData.setComputationalResourceScheduling(scheduling);
 
             Experiment experiment = new Experiment();
-            experiment.setProjectID(projectId1);
+            experiment.setProjectId(projectId1);
             experiment.setUserName("TestUser" + TAG);
             experiment.setName("TestExperiment"+TAG);
             experiment.setDescription("experiment");
@@ -209,7 +209,7 @@ public class AiravataServerHandlerTest {
             //retrieving the stored experiment
             Experiment retrievedExperiment = airavataServerHandler.getExperiment(experimentId1);
             Assert.assertNotNull(retrievedExperiment);
-            Assert.assertEquals(retrievedExperiment.getProjectID(), experiment.getProjectID());
+            Assert.assertEquals(retrievedExperiment.getProjectId(), experiment.getProjectId());
             Assert.assertEquals(retrievedExperiment.getDescription(), experiment.getDescription());
             Assert.assertEquals(retrievedExperiment.getName(), experiment.getName());
             Assert.assertEquals(retrievedExperiment.getApplicationId(), experiment.getApplicationId());
@@ -226,7 +226,7 @@ public class AiravataServerHandlerTest {
 
             //creating more experiments
             experiment = new Experiment();
-            experiment.setProjectID(projectId1);
+            experiment.setProjectId(projectId1);
             experiment.setUserName("TestUser" + TAG);
             experiment.setName("TestExperiment2" + TAG);
             experiment.setDescription("experiment");
@@ -238,7 +238,7 @@ public class AiravataServerHandlerTest {
             Assert.assertNotNull(experimentId2);
 
             experiment = new Experiment();
-            experiment.setProjectID(projectId1);
+            experiment.setProjectId(projectId1);
             experiment.setUserName("TestUser" + TAG);
             experiment.setName("TestExperiment3"+TAG);
             experiment.setDescription("experiment");

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.cpp
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.cpp b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.cpp
index 34e4aa6..46a68d8 100644
--- a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.cpp
+++ b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.cpp
@@ -752,8 +752,8 @@ uint32_t ComputationalResourceScheduling::read(::apache::thrift::protocol::TProt
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          xfer += iprot->readI32(this->totalCPUCount);
-          this->__isset.totalCPUCount = true;
+          xfer += iprot->readI32(this->totalCpuCount);
+          this->__isset.totalCpuCount = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -843,9 +843,9 @@ uint32_t ComputationalResourceScheduling::write(::apache::thrift::protocol::TPro
     xfer += oprot->writeString(this->resourceHostId);
     xfer += oprot->writeFieldEnd();
   }
-  if (this->__isset.totalCPUCount) {
-    xfer += oprot->writeFieldBegin("totalCPUCount", ::apache::thrift::protocol::T_I32, 2);
-    xfer += oprot->writeI32(this->totalCPUCount);
+  if (this->__isset.totalCpuCount) {
+    xfer += oprot->writeFieldBegin("totalCpuCount", ::apache::thrift::protocol::T_I32, 2);
+    xfer += oprot->writeI32(this->totalCpuCount);
     xfer += oprot->writeFieldEnd();
   }
   if (this->__isset.nodeCount) {
@@ -896,7 +896,7 @@ uint32_t ComputationalResourceScheduling::write(::apache::thrift::protocol::TPro
 void swap(ComputationalResourceScheduling &a, ComputationalResourceScheduling &b) {
   using ::std::swap;
   swap(a.resourceHostId, b.resourceHostId);
-  swap(a.totalCPUCount, b.totalCPUCount);
+  swap(a.totalCpuCount, b.totalCpuCount);
   swap(a.nodeCount, b.nodeCount);
   swap(a.numberOfThreads, b.numberOfThreads);
   swap(a.queueName, b.queueName);
@@ -1286,8 +1286,8 @@ uint32_t UserConfigurationData::read(::apache::thrift::protocol::TProtocol* ipro
         break;
       case 9:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->userDN);
-          this->__isset.userDN = true;
+          xfer += iprot->readString(this->userDn);
+          this->__isset.userDn = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -1358,9 +1358,9 @@ uint32_t UserConfigurationData::write(::apache::thrift::protocol::TProtocol* opr
     xfer += oprot->writeBool(this->throttleResources);
     xfer += oprot->writeFieldEnd();
   }
-  if (this->__isset.userDN) {
-    xfer += oprot->writeFieldBegin("userDN", ::apache::thrift::protocol::T_STRING, 9);
-    xfer += oprot->writeString(this->userDN);
+  if (this->__isset.userDn) {
+    xfer += oprot->writeFieldBegin("userDn", ::apache::thrift::protocol::T_STRING, 9);
+    xfer += oprot->writeString(this->userDn);
     xfer += oprot->writeFieldEnd();
   }
   if (this->__isset.generateCert) {
@@ -1383,7 +1383,7 @@ void swap(UserConfigurationData &a, UserConfigurationData &b) {
   swap(a.advanceOutputDataHandling, b.advanceOutputDataHandling);
   swap(a.qosParams, b.qosParams);
   swap(a.throttleResources, b.throttleResources);
-  swap(a.userDN, b.userDN);
+  swap(a.userDn, b.userDn);
   swap(a.generateCert, b.generateCert);
   swap(a.__isset, b.__isset);
 }
@@ -1402,7 +1402,7 @@ uint32_t ErrorDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_errorID = false;
+  bool isset_errorId = false;
 
   while (true)
   {
@@ -1414,8 +1414,8 @@ uint32_t ErrorDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->errorID);
-          isset_errorID = true;
+          xfer += iprot->readString(this->errorId);
+          isset_errorId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -1511,7 +1511,7 @@ uint32_t ErrorDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_errorID)
+  if (!isset_errorId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   return xfer;
 }
@@ -1520,8 +1520,8 @@ uint32_t ErrorDetails::write(::apache::thrift::protocol::TProtocol* oprot) const
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("ErrorDetails");
 
-  xfer += oprot->writeFieldBegin("errorID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->errorID);
+  xfer += oprot->writeFieldBegin("errorId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->errorId);
   xfer += oprot->writeFieldEnd();
 
   if (this->__isset.creationTime) {
@@ -1579,7 +1579,7 @@ uint32_t ErrorDetails::write(::apache::thrift::protocol::TProtocol* oprot) const
 
 void swap(ErrorDetails &a, ErrorDetails &b) {
   using ::std::swap;
-  swap(a.errorID, b.errorID);
+  swap(a.errorId, b.errorId);
   swap(a.creationTime, b.creationTime);
   swap(a.actualErrorMessage, b.actualErrorMessage);
   swap(a.userFriendlyMessage, b.userFriendlyMessage);
@@ -1605,7 +1605,7 @@ uint32_t JobDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_jobID = false;
+  bool isset_jobId = false;
   bool isset_jobDescription = false;
 
   while (true)
@@ -1618,8 +1618,8 @@ uint32_t JobDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->jobID);
-          isset_jobID = true;
+          xfer += iprot->readString(this->jobId);
+          isset_jobId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -1709,7 +1709,7 @@ uint32_t JobDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_jobID)
+  if (!isset_jobId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   if (!isset_jobDescription)
     throw TProtocolException(TProtocolException::INVALID_DATA);
@@ -1720,8 +1720,8 @@ uint32_t JobDetails::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("JobDetails");
 
-  xfer += oprot->writeFieldBegin("jobID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->jobID);
+  xfer += oprot->writeFieldBegin("jobId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->jobId);
   xfer += oprot->writeFieldEnd();
 
   xfer += oprot->writeFieldBegin("jobDescription", ::apache::thrift::protocol::T_STRING, 2);
@@ -1778,7 +1778,7 @@ uint32_t JobDetails::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
 void swap(JobDetails &a, JobDetails &b) {
   using ::std::swap;
-  swap(a.jobID, b.jobID);
+  swap(a.jobId, b.jobId);
   swap(a.jobDescription, b.jobDescription);
   swap(a.creationTime, b.creationTime);
   swap(a.jobStatus, b.jobStatus);
@@ -1804,7 +1804,7 @@ uint32_t DataTransferDetails::read(::apache::thrift::protocol::TProtocol* iprot)
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_transferID = false;
+  bool isset_transferId = false;
   bool isset_transferDescription = false;
 
   while (true)
@@ -1817,8 +1817,8 @@ uint32_t DataTransferDetails::read(::apache::thrift::protocol::TProtocol* iprot)
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->transferID);
-          isset_transferID = true;
+          xfer += iprot->readString(this->transferId);
+          isset_transferId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -1856,7 +1856,7 @@ uint32_t DataTransferDetails::read(::apache::thrift::protocol::TProtocol* iprot)
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_transferID)
+  if (!isset_transferId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   if (!isset_transferDescription)
     throw TProtocolException(TProtocolException::INVALID_DATA);
@@ -1867,8 +1867,8 @@ uint32_t DataTransferDetails::write(::apache::thrift::protocol::TProtocol* oprot
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("DataTransferDetails");
 
-  xfer += oprot->writeFieldBegin("transferID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->transferID);
+  xfer += oprot->writeFieldBegin("transferId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->transferId);
   xfer += oprot->writeFieldEnd();
 
   if (this->__isset.creationTime) {
@@ -1892,7 +1892,7 @@ uint32_t DataTransferDetails::write(::apache::thrift::protocol::TProtocol* oprot
 
 void swap(DataTransferDetails &a, DataTransferDetails &b) {
   using ::std::swap;
-  swap(a.transferID, b.transferID);
+  swap(a.transferId, b.transferId);
   swap(a.creationTime, b.creationTime);
   swap(a.transferDescription, b.transferDescription);
   swap(a.transferStatus, b.transferStatus);
@@ -1913,7 +1913,7 @@ uint32_t TaskDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_taskID = false;
+  bool isset_taskId = false;
 
   while (true)
   {
@@ -1925,8 +1925,8 @@ uint32_t TaskDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->taskID);
-          isset_taskID = true;
+          xfer += iprot->readString(this->taskId);
+          isset_taskId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -2132,7 +2132,7 @@ uint32_t TaskDetails::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_taskID)
+  if (!isset_taskId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   return xfer;
 }
@@ -2141,8 +2141,8 @@ uint32_t TaskDetails::write(::apache::thrift::protocol::TProtocol* oprot) const
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("TaskDetails");
 
-  xfer += oprot->writeFieldBegin("taskID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->taskID);
+  xfer += oprot->writeFieldBegin("taskId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->taskId);
   xfer += oprot->writeFieldEnd();
 
   if (this->__isset.creationTime) {
@@ -2275,7 +2275,7 @@ uint32_t TaskDetails::write(::apache::thrift::protocol::TProtocol* oprot) const
 
 void swap(TaskDetails &a, TaskDetails &b) {
   using ::std::swap;
-  swap(a.taskID, b.taskID);
+  swap(a.taskId, b.taskId);
   swap(a.creationTime, b.creationTime);
   swap(a.applicationId, b.applicationId);
   swap(a.applicationVersion, b.applicationVersion);
@@ -2764,8 +2764,8 @@ uint32_t Experiment::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_experimentID = false;
-  bool isset_projectID = false;
+  bool isset_experimentId = false;
+  bool isset_projectId = false;
   bool isset_userName = false;
   bool isset_name = false;
 
@@ -2779,16 +2779,16 @@ uint32_t Experiment::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->experimentID);
-          isset_experimentID = true;
+          xfer += iprot->readString(this->experimentId);
+          isset_experimentId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->projectID);
-          isset_projectID = true;
+          xfer += iprot->readString(this->projectId);
+          isset_projectId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -3026,9 +3026,9 @@ uint32_t Experiment::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_experimentID)
+  if (!isset_experimentId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
-  if (!isset_projectID)
+  if (!isset_projectId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   if (!isset_userName)
     throw TProtocolException(TProtocolException::INVALID_DATA);
@@ -3041,12 +3041,12 @@ uint32_t Experiment::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("Experiment");
 
-  xfer += oprot->writeFieldBegin("experimentID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->experimentID);
+  xfer += oprot->writeFieldBegin("experimentId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->experimentId);
   xfer += oprot->writeFieldEnd();
 
-  xfer += oprot->writeFieldBegin("projectID", ::apache::thrift::protocol::T_STRING, 2);
-  xfer += oprot->writeString(this->projectID);
+  xfer += oprot->writeFieldBegin("projectId", ::apache::thrift::protocol::T_STRING, 2);
+  xfer += oprot->writeString(this->projectId);
   xfer += oprot->writeFieldEnd();
 
   if (this->__isset.creationTime) {
@@ -3197,8 +3197,8 @@ uint32_t Experiment::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
 void swap(Experiment &a, Experiment &b) {
   using ::std::swap;
-  swap(a.experimentID, b.experimentID);
-  swap(a.projectID, b.projectID);
+  swap(a.experimentId, b.experimentId);
+  swap(a.projectId, b.projectId);
   swap(a.creationTime, b.creationTime);
   swap(a.userName, b.userName);
   swap(a.name, b.name);
@@ -3235,8 +3235,8 @@ uint32_t ExperimentSummary::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_experimentID = false;
-  bool isset_projectID = false;
+  bool isset_experimentId = false;
+  bool isset_projectId = false;
   bool isset_userName = false;
   bool isset_name = false;
 
@@ -3250,16 +3250,16 @@ uint32_t ExperimentSummary::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->experimentID);
-          isset_experimentID = true;
+          xfer += iprot->readString(this->experimentId);
+          isset_experimentId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->projectID);
-          isset_projectID = true;
+          xfer += iprot->readString(this->projectId);
+          isset_projectId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -3341,9 +3341,9 @@ uint32_t ExperimentSummary::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_experimentID)
+  if (!isset_experimentId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
-  if (!isset_projectID)
+  if (!isset_projectId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   if (!isset_userName)
     throw TProtocolException(TProtocolException::INVALID_DATA);
@@ -3356,12 +3356,12 @@ uint32_t ExperimentSummary::write(::apache::thrift::protocol::TProtocol* oprot)
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("ExperimentSummary");
 
-  xfer += oprot->writeFieldBegin("experimentID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->experimentID);
+  xfer += oprot->writeFieldBegin("experimentId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->experimentId);
   xfer += oprot->writeFieldEnd();
 
-  xfer += oprot->writeFieldBegin("projectID", ::apache::thrift::protocol::T_STRING, 2);
-  xfer += oprot->writeString(this->projectID);
+  xfer += oprot->writeFieldBegin("projectId", ::apache::thrift::protocol::T_STRING, 2);
+  xfer += oprot->writeString(this->projectId);
   xfer += oprot->writeFieldEnd();
 
   if (this->__isset.creationTime) {
@@ -3412,8 +3412,8 @@ uint32_t ExperimentSummary::write(::apache::thrift::protocol::TProtocol* oprot)
 
 void swap(ExperimentSummary &a, ExperimentSummary &b) {
   using ::std::swap;
-  swap(a.experimentID, b.experimentID);
-  swap(a.projectID, b.projectID);
+  swap(a.experimentId, b.experimentId);
+  swap(a.projectId, b.projectId);
   swap(a.creationTime, b.creationTime);
   swap(a.userName, b.userName);
   swap(a.name, b.name);

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.h
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.h b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.h
index 3f7f2b7..36c5f92 100644
--- a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.h
+++ b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/experimentModel_types.h
@@ -495,9 +495,9 @@ class ApplicationStatus {
 void swap(ApplicationStatus &a, ApplicationStatus &b);
 
 typedef struct _ComputationalResourceScheduling__isset {
-  _ComputationalResourceScheduling__isset() : resourceHostId(false), totalCPUCount(false), nodeCount(false), numberOfThreads(false), queueName(false), wallTimeLimit(false), jobStartTime(false), totalPhysicalMemory(false), computationalProjectAccount(false), chassisName(false) {}
+  _ComputationalResourceScheduling__isset() : resourceHostId(false), totalCpuCount(false), nodeCount(false), numberOfThreads(false), queueName(false), wallTimeLimit(false), jobStartTime(false), totalPhysicalMemory(false), computationalProjectAccount(false), chassisName(false) {}
   bool resourceHostId;
-  bool totalCPUCount;
+  bool totalCpuCount;
   bool nodeCount;
   bool numberOfThreads;
   bool queueName;
@@ -514,13 +514,13 @@ class ComputationalResourceScheduling {
   static const char* ascii_fingerprint; // = "F43E914A611D39345BCC729678C1C696";
   static const uint8_t binary_fingerprint[16]; // = {0xF4,0x3E,0x91,0x4A,0x61,0x1D,0x39,0x34,0x5B,0xCC,0x72,0x96,0x78,0xC1,0xC6,0x96};
 
-  ComputationalResourceScheduling() : resourceHostId(), totalCPUCount(0), nodeCount(0), numberOfThreads(0), queueName(), wallTimeLimit(0), jobStartTime(0), totalPhysicalMemory(0), computationalProjectAccount(), chassisName() {
+  ComputationalResourceScheduling() : resourceHostId(), totalCpuCount(0), nodeCount(0), numberOfThreads(0), queueName(), wallTimeLimit(0), jobStartTime(0), totalPhysicalMemory(0), computationalProjectAccount(), chassisName() {
   }
 
   virtual ~ComputationalResourceScheduling() throw() {}
 
   std::string resourceHostId;
-  int32_t totalCPUCount;
+  int32_t totalCpuCount;
   int32_t nodeCount;
   int32_t numberOfThreads;
   std::string queueName;
@@ -537,9 +537,9 @@ class ComputationalResourceScheduling {
     __isset.resourceHostId = true;
   }
 
-  void __set_totalCPUCount(const int32_t val) {
-    totalCPUCount = val;
-    __isset.totalCPUCount = true;
+  void __set_totalCpuCount(const int32_t val) {
+    totalCpuCount = val;
+    __isset.totalCpuCount = true;
   }
 
   void __set_nodeCount(const int32_t val) {
@@ -588,9 +588,9 @@ class ComputationalResourceScheduling {
       return false;
     else if (__isset.resourceHostId && !(resourceHostId == rhs.resourceHostId))
       return false;
-    if (__isset.totalCPUCount != rhs.__isset.totalCPUCount)
+    if (__isset.totalCpuCount != rhs.__isset.totalCpuCount)
       return false;
-    else if (__isset.totalCPUCount && !(totalCPUCount == rhs.totalCPUCount))
+    else if (__isset.totalCpuCount && !(totalCpuCount == rhs.totalCpuCount))
       return false;
     if (__isset.nodeCount != rhs.__isset.nodeCount)
       return false;
@@ -855,14 +855,14 @@ class QualityOfServiceParams {
 void swap(QualityOfServiceParams &a, QualityOfServiceParams &b);
 
 typedef struct _UserConfigurationData__isset {
-  _UserConfigurationData__isset() : shareExperimentPublicly(true), computationalResourceScheduling(false), advanceInputDataHandling(false), advanceOutputDataHandling(false), qosParams(false), throttleResources(true), userDN(false), generateCert(true) {}
+  _UserConfigurationData__isset() : shareExperimentPublicly(true), computationalResourceScheduling(false), advanceInputDataHandling(false), advanceOutputDataHandling(false), qosParams(false), throttleResources(true), userDn(false), generateCert(true) {}
   bool shareExperimentPublicly;
   bool computationalResourceScheduling;
   bool advanceInputDataHandling;
   bool advanceOutputDataHandling;
   bool qosParams;
   bool throttleResources;
-  bool userDN;
+  bool userDn;
   bool generateCert;
 } _UserConfigurationData__isset;
 
@@ -872,7 +872,7 @@ class UserConfigurationData {
   static const char* ascii_fingerprint; // = "0EA9FCA690C445780E02BCAC89B1D820";
   static const uint8_t binary_fingerprint[16]; // = {0x0E,0xA9,0xFC,0xA6,0x90,0xC4,0x45,0x78,0x0E,0x02,0xBC,0xAC,0x89,0xB1,0xD8,0x20};
 
-  UserConfigurationData() : airavataAutoSchedule(false), overrideManualScheduledParams(false), shareExperimentPublicly(false), throttleResources(false), userDN(), generateCert(false) {
+  UserConfigurationData() : airavataAutoSchedule(false), overrideManualScheduledParams(false), shareExperimentPublicly(false), throttleResources(false), userDn(), generateCert(false) {
   }
 
   virtual ~UserConfigurationData() throw() {}
@@ -885,7 +885,7 @@ class UserConfigurationData {
   AdvancedOutputDataHandling advanceOutputDataHandling;
   QualityOfServiceParams qosParams;
   bool throttleResources;
-  std::string userDN;
+  std::string userDn;
   bool generateCert;
 
   _UserConfigurationData__isset __isset;
@@ -928,9 +928,9 @@ class UserConfigurationData {
     __isset.throttleResources = true;
   }
 
-  void __set_userDN(const std::string& val) {
-    userDN = val;
-    __isset.userDN = true;
+  void __set_userDn(const std::string& val) {
+    userDn = val;
+    __isset.userDn = true;
   }
 
   void __set_generateCert(const bool val) {
@@ -968,9 +968,9 @@ class UserConfigurationData {
       return false;
     else if (__isset.throttleResources && !(throttleResources == rhs.throttleResources))
       return false;
-    if (__isset.userDN != rhs.__isset.userDN)
+    if (__isset.userDn != rhs.__isset.userDn)
       return false;
-    else if (__isset.userDN && !(userDN == rhs.userDN))
+    else if (__isset.userDn && !(userDn == rhs.userDn))
       return false;
     if (__isset.generateCert != rhs.__isset.generateCert)
       return false;
@@ -1009,12 +1009,12 @@ class ErrorDetails {
   static const char* ascii_fingerprint; // = "170CA6E79EB283F31417B9D68071DA33";
   static const uint8_t binary_fingerprint[16]; // = {0x17,0x0C,0xA6,0xE7,0x9E,0xB2,0x83,0xF3,0x14,0x17,0xB9,0xD6,0x80,0x71,0xDA,0x33};
 
-  ErrorDetails() : errorID("DO_NOT_SET_AT_CLIENTS"), creationTime(0), actualErrorMessage(), userFriendlyMessage(), errorCategory((ErrorCategory::type)0), transientOrPersistent(false), correctiveAction((CorrectiveAction::type)0), actionableGroup((ActionableGroup::type)0) {
+  ErrorDetails() : errorId("DO_NOT_SET_AT_CLIENTS"), creationTime(0), actualErrorMessage(), userFriendlyMessage(), errorCategory((ErrorCategory::type)0), transientOrPersistent(false), correctiveAction((CorrectiveAction::type)0), actionableGroup((ActionableGroup::type)0) {
   }
 
   virtual ~ErrorDetails() throw() {}
 
-  std::string errorID;
+  std::string errorId;
   int64_t creationTime;
   std::string actualErrorMessage;
   std::string userFriendlyMessage;
@@ -1026,8 +1026,8 @@ class ErrorDetails {
 
   _ErrorDetails__isset __isset;
 
-  void __set_errorID(const std::string& val) {
-    errorID = val;
+  void __set_errorId(const std::string& val) {
+    errorId = val;
   }
 
   void __set_creationTime(const int64_t val) {
@@ -1072,7 +1072,7 @@ class ErrorDetails {
 
   bool operator == (const ErrorDetails & rhs) const
   {
-    if (!(errorID == rhs.errorID))
+    if (!(errorId == rhs.errorId))
       return false;
     if (__isset.creationTime != rhs.__isset.creationTime)
       return false;
@@ -1138,12 +1138,12 @@ class JobDetails {
   static const char* ascii_fingerprint; // = "114EFEA8CA07DC82CC947D9F47547394";
   static const uint8_t binary_fingerprint[16]; // = {0x11,0x4E,0xFE,0xA8,0xCA,0x07,0xDC,0x82,0xCC,0x94,0x7D,0x9F,0x47,0x54,0x73,0x94};
 
-  JobDetails() : jobID("DO_NOT_SET_AT_CLIENTS"), jobDescription(), creationTime(0), computeResourceConsumed(), jobName(), workingDir() {
+  JobDetails() : jobId("DO_NOT_SET_AT_CLIENTS"), jobDescription(), creationTime(0), computeResourceConsumed(), jobName(), workingDir() {
   }
 
   virtual ~JobDetails() throw() {}
 
-  std::string jobID;
+  std::string jobId;
   std::string jobDescription;
   int64_t creationTime;
   JobStatus jobStatus;
@@ -1155,8 +1155,8 @@ class JobDetails {
 
   _JobDetails__isset __isset;
 
-  void __set_jobID(const std::string& val) {
-    jobID = val;
+  void __set_jobId(const std::string& val) {
+    jobId = val;
   }
 
   void __set_jobDescription(const std::string& val) {
@@ -1200,7 +1200,7 @@ class JobDetails {
 
   bool operator == (const JobDetails & rhs) const
   {
-    if (!(jobID == rhs.jobID))
+    if (!(jobId == rhs.jobId))
       return false;
     if (!(jobDescription == rhs.jobDescription))
       return false;
@@ -1259,20 +1259,20 @@ class DataTransferDetails {
   static const char* ascii_fingerprint; // = "40D4FEC20E3B334AEEBA92DA2AB9E91E";
   static const uint8_t binary_fingerprint[16]; // = {0x40,0xD4,0xFE,0xC2,0x0E,0x3B,0x33,0x4A,0xEE,0xBA,0x92,0xDA,0x2A,0xB9,0xE9,0x1E};
 
-  DataTransferDetails() : transferID("DO_NOT_SET_AT_CLIENTS"), creationTime(0), transferDescription() {
+  DataTransferDetails() : transferId("DO_NOT_SET_AT_CLIENTS"), creationTime(0), transferDescription() {
   }
 
   virtual ~DataTransferDetails() throw() {}
 
-  std::string transferID;
+  std::string transferId;
   int64_t creationTime;
   std::string transferDescription;
   TransferStatus transferStatus;
 
   _DataTransferDetails__isset __isset;
 
-  void __set_transferID(const std::string& val) {
-    transferID = val;
+  void __set_transferId(const std::string& val) {
+    transferId = val;
   }
 
   void __set_creationTime(const int64_t val) {
@@ -1291,7 +1291,7 @@ class DataTransferDetails {
 
   bool operator == (const DataTransferDetails & rhs) const
   {
-    if (!(transferID == rhs.transferID))
+    if (!(transferId == rhs.transferId))
       return false;
     if (__isset.creationTime != rhs.__isset.creationTime)
       return false;
@@ -1343,12 +1343,12 @@ class TaskDetails {
   static const char* ascii_fingerprint; // = "B7529305C4CBCDA0A164DA14865F0E67";
   static const uint8_t binary_fingerprint[16]; // = {0xB7,0x52,0x93,0x05,0xC4,0xCB,0xCD,0xA0,0xA1,0x64,0xDA,0x14,0x86,0x5F,0x0E,0x67};
 
-  TaskDetails() : taskID("DO_NOT_SET_AT_CLIENTS"), creationTime(0), applicationId(), applicationVersion(), applicationDeploymentId(), enableEmailNotification(0) {
+  TaskDetails() : taskId("DO_NOT_SET_AT_CLIENTS"), creationTime(0), applicationId(), applicationVersion(), applicationDeploymentId(), enableEmailNotification(0) {
   }
 
   virtual ~TaskDetails() throw() {}
 
-  std::string taskID;
+  std::string taskId;
   int64_t creationTime;
   std::string applicationId;
   std::string applicationVersion;
@@ -1367,8 +1367,8 @@ class TaskDetails {
 
   _TaskDetails__isset __isset;
 
-  void __set_taskID(const std::string& val) {
-    taskID = val;
+  void __set_taskId(const std::string& val) {
+    taskId = val;
   }
 
   void __set_creationTime(const int64_t val) {
@@ -1448,7 +1448,7 @@ class TaskDetails {
 
   bool operator == (const TaskDetails & rhs) const
   {
-    if (!(taskID == rhs.taskID))
+    if (!(taskId == rhs.taskId))
       return false;
     if (__isset.creationTime != rhs.__isset.creationTime)
       return false;
@@ -1784,13 +1784,13 @@ class Experiment {
   static const char* ascii_fingerprint; // = "2826868ECEA08F4F71C71DEAD5A3270F";
   static const uint8_t binary_fingerprint[16]; // = {0x28,0x26,0x86,0x8E,0xCE,0xA0,0x8F,0x4F,0x71,0xC7,0x1D,0xEA,0xD5,0xA3,0x27,0x0F};
 
-  Experiment() : experimentID("DO_NOT_SET_AT_CLIENTS"), projectID("DEFAULT"), creationTime(0), userName(), name(), description(), applicationId(), applicationVersion(), workflowTemplateId(), workflowTemplateVersion(), gatewayExecutionId(), enableEmailNotification(0), workflowExecutionInstanceId() {
+  Experiment() : experimentId("DO_NOT_SET_AT_CLIENTS"), projectId("DEFAULT"), creationTime(0), userName(), name(), description(), applicationId(), applicationVersion(), workflowTemplateId(), workflowTemplateVersion(), gatewayExecutionId(), enableEmailNotification(0), workflowExecutionInstanceId() {
   }
 
   virtual ~Experiment() throw() {}
 
-  std::string experimentID;
-  std::string projectID;
+  std::string experimentId;
+  std::string projectId;
   int64_t creationTime;
   std::string userName;
   std::string name;
@@ -1813,12 +1813,12 @@ class Experiment {
 
   _Experiment__isset __isset;
 
-  void __set_experimentID(const std::string& val) {
-    experimentID = val;
+  void __set_experimentId(const std::string& val) {
+    experimentId = val;
   }
 
-  void __set_projectID(const std::string& val) {
-    projectID = val;
+  void __set_projectId(const std::string& val) {
+    projectId = val;
   }
 
   void __set_creationTime(const int64_t val) {
@@ -1916,9 +1916,9 @@ class Experiment {
 
   bool operator == (const Experiment & rhs) const
   {
-    if (!(experimentID == rhs.experimentID))
+    if (!(experimentId == rhs.experimentId))
       return false;
-    if (!(projectID == rhs.projectID))
+    if (!(projectId == rhs.projectId))
       return false;
     if (__isset.creationTime != rhs.__isset.creationTime)
       return false;
@@ -2022,13 +2022,13 @@ class ExperimentSummary {
   static const char* ascii_fingerprint; // = "44FD485ABF32F5EB94D6F393F51241B6";
   static const uint8_t binary_fingerprint[16]; // = {0x44,0xFD,0x48,0x5A,0xBF,0x32,0xF5,0xEB,0x94,0xD6,0xF3,0x93,0xF5,0x12,0x41,0xB6};
 
-  ExperimentSummary() : experimentID(), projectID(), creationTime(0), userName(), name(), description(), applicationId() {
+  ExperimentSummary() : experimentId(), projectId(), creationTime(0), userName(), name(), description(), applicationId() {
   }
 
   virtual ~ExperimentSummary() throw() {}
 
-  std::string experimentID;
-  std::string projectID;
+  std::string experimentId;
+  std::string projectId;
   int64_t creationTime;
   std::string userName;
   std::string name;
@@ -2039,12 +2039,12 @@ class ExperimentSummary {
 
   _ExperimentSummary__isset __isset;
 
-  void __set_experimentID(const std::string& val) {
-    experimentID = val;
+  void __set_experimentId(const std::string& val) {
+    experimentId = val;
   }
 
-  void __set_projectID(const std::string& val) {
-    projectID = val;
+  void __set_projectId(const std::string& val) {
+    projectId = val;
   }
 
   void __set_creationTime(const int64_t val) {
@@ -2082,9 +2082,9 @@ class ExperimentSummary {
 
   bool operator == (const ExperimentSummary & rhs) const
   {
-    if (!(experimentID == rhs.experimentID))
+    if (!(experimentId == rhs.experimentId))
       return false;
-    if (!(projectID == rhs.projectID))
+    if (!(projectId == rhs.projectId))
       return false;
     if (__isset.creationTime != rhs.__isset.creationTime)
       return false;

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.cpp
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.cpp b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.cpp
index 311ea63..c3f8fb8 100644
--- a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.cpp
+++ b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.cpp
@@ -120,7 +120,7 @@ uint32_t Project::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   using ::apache::thrift::protocol::TProtocolException;
 
-  bool isset_projectID = false;
+  bool isset_projectId = false;
   bool isset_owner = false;
   bool isset_name = false;
 
@@ -134,8 +134,8 @@ uint32_t Project::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->projectID);
-          isset_projectID = true;
+          xfer += iprot->readString(this->projectId);
+          isset_projectId = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -221,7 +221,7 @@ uint32_t Project::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   xfer += iprot->readStructEnd();
 
-  if (!isset_projectID)
+  if (!isset_projectId)
     throw TProtocolException(TProtocolException::INVALID_DATA);
   if (!isset_owner)
     throw TProtocolException(TProtocolException::INVALID_DATA);
@@ -234,8 +234,8 @@ uint32_t Project::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
   xfer += oprot->writeStructBegin("Project");
 
-  xfer += oprot->writeFieldBegin("projectID", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->projectID);
+  xfer += oprot->writeFieldBegin("projectId", ::apache::thrift::protocol::T_STRING, 1);
+  xfer += oprot->writeString(this->projectId);
   xfer += oprot->writeFieldEnd();
 
   xfer += oprot->writeFieldBegin("owner", ::apache::thrift::protocol::T_STRING, 2);
@@ -289,7 +289,7 @@ uint32_t Project::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
 void swap(Project &a, Project &b) {
   using ::std::swap;
-  swap(a.projectID, b.projectID);
+  swap(a.projectId, b.projectId);
   swap(a.owner, b.owner);
   swap(a.name, b.name);
   swap(a.description, b.description);

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.h
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.h b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.h
index 41593a6..cc88b42 100644
--- a/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.h
+++ b/airavata-api/airavata-client-sdks/airavata-cpp-sdk/src/main/resources/lib/airavata/workspaceModel_types.h
@@ -102,12 +102,12 @@ class Project {
   static const char* ascii_fingerprint; // = "AFD8090DE564134035942D450F918628";
   static const uint8_t binary_fingerprint[16]; // = {0xAF,0xD8,0x09,0x0D,0xE5,0x64,0x13,0x40,0x35,0x94,0x2D,0x45,0x0F,0x91,0x86,0x28};
 
-  Project() : projectID("DEFAULT"), owner(), name(), description(), creationTime(0) {
+  Project() : projectId("DEFAULT"), owner(), name(), description(), creationTime(0) {
   }
 
   virtual ~Project() throw() {}
 
-  std::string projectID;
+  std::string projectId;
   std::string owner;
   std::string name;
   std::string description;
@@ -117,8 +117,8 @@ class Project {
 
   _Project__isset __isset;
 
-  void __set_projectID(const std::string& val) {
-    projectID = val;
+  void __set_projectId(const std::string& val) {
+    projectId = val;
   }
 
   void __set_owner(const std::string& val) {
@@ -151,7 +151,7 @@ class Project {
 
   bool operator == (const Project & rhs) const
   {
-    if (!(projectID == rhs.projectID))
+    if (!(projectId == rhs.projectId))
       return false;
     if (!(owner == rhs.owner))
       return false;

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Experiment/Types.php
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Experiment/Types.php b/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Experiment/Types.php
index 753dc13..0b1459b 100644
--- a/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Experiment/Types.php
+++ b/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Experiment/Types.php
@@ -772,7 +772,7 @@ class ComputationalResourceScheduling {
   static $_TSPEC;
 
   public $resourceHostId = null;
-  public $totalCPUCount = null;
+  public $totalCpuCount = null;
   public $nodeCount = null;
   public $numberOfThreads = null;
   public $queueName = null;
@@ -790,7 +790,7 @@ class ComputationalResourceScheduling {
           'type' => TType::STRING,
           ),
         2 => array(
-          'var' => 'totalCPUCount',
+          'var' => 'totalCpuCount',
           'type' => TType::I32,
           ),
         3 => array(
@@ -831,8 +831,8 @@ class ComputationalResourceScheduling {
       if (isset($vals['resourceHostId'])) {
         $this->resourceHostId = $vals['resourceHostId'];
       }
-      if (isset($vals['totalCPUCount'])) {
-        $this->totalCPUCount = $vals['totalCPUCount'];
+      if (isset($vals['totalCpuCount'])) {
+        $this->totalCpuCount = $vals['totalCpuCount'];
       }
       if (isset($vals['nodeCount'])) {
         $this->nodeCount = $vals['nodeCount'];
@@ -889,7 +889,7 @@ class ComputationalResourceScheduling {
           break;
         case 2:
           if ($ftype == TType::I32) {
-            $xfer += $input->readI32($this->totalCPUCount);
+            $xfer += $input->readI32($this->totalCpuCount);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -968,9 +968,9 @@ class ComputationalResourceScheduling {
       $xfer += $output->writeString($this->resourceHostId);
       $xfer += $output->writeFieldEnd();
     }
-    if ($this->totalCPUCount !== null) {
-      $xfer += $output->writeFieldBegin('totalCPUCount', TType::I32, 2);
-      $xfer += $output->writeI32($this->totalCPUCount);
+    if ($this->totalCpuCount !== null) {
+      $xfer += $output->writeFieldBegin('totalCpuCount', TType::I32, 2);
+      $xfer += $output->writeI32($this->totalCpuCount);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->nodeCount !== null) {
@@ -1387,7 +1387,7 @@ class UserConfigurationData {
   public $advanceOutputDataHandling = null;
   public $qosParams = null;
   public $throttleResources = false;
-  public $userDN = null;
+  public $userDn = null;
   public $generateCert = false;
 
   public function __construct($vals=null) {
@@ -1430,7 +1430,7 @@ class UserConfigurationData {
           'type' => TType::BOOL,
           ),
         9 => array(
-          'var' => 'userDN',
+          'var' => 'userDn',
           'type' => TType::STRING,
           ),
         10 => array(
@@ -1464,8 +1464,8 @@ class UserConfigurationData {
       if (isset($vals['throttleResources'])) {
         $this->throttleResources = $vals['throttleResources'];
       }
-      if (isset($vals['userDN'])) {
-        $this->userDN = $vals['userDN'];
+      if (isset($vals['userDn'])) {
+        $this->userDn = $vals['userDn'];
       }
       if (isset($vals['generateCert'])) {
         $this->generateCert = $vals['generateCert'];
@@ -1554,7 +1554,7 @@ class UserConfigurationData {
           break;
         case 9:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->userDN);
+            $xfer += $input->readString($this->userDn);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -1631,9 +1631,9 @@ class UserConfigurationData {
       $xfer += $output->writeBool($this->throttleResources);
       $xfer += $output->writeFieldEnd();
     }
-    if ($this->userDN !== null) {
-      $xfer += $output->writeFieldBegin('userDN', TType::STRING, 9);
-      $xfer += $output->writeString($this->userDN);
+    if ($this->userDn !== null) {
+      $xfer += $output->writeFieldBegin('userDn', TType::STRING, 9);
+      $xfer += $output->writeString($this->userDn);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->generateCert !== null) {
@@ -1651,7 +1651,7 @@ class UserConfigurationData {
 class ErrorDetails {
   static $_TSPEC;
 
-  public $errorID = "DO_NOT_SET_AT_CLIENTS";
+  public $errorId = "DO_NOT_SET_AT_CLIENTS";
   public $creationTime = null;
   public $actualErrorMessage = null;
   public $userFriendlyMessage = null;
@@ -1665,7 +1665,7 @@ class ErrorDetails {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'errorID',
+          'var' => 'errorId',
           'type' => TType::STRING,
           ),
         2 => array(
@@ -1707,8 +1707,8 @@ class ErrorDetails {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['errorID'])) {
-        $this->errorID = $vals['errorID'];
+      if (isset($vals['errorId'])) {
+        $this->errorId = $vals['errorId'];
       }
       if (isset($vals['creationTime'])) {
         $this->creationTime = $vals['creationTime'];
@@ -1758,7 +1758,7 @@ class ErrorDetails {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->errorID);
+            $xfer += $input->readString($this->errorId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -1842,9 +1842,9 @@ class ErrorDetails {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('ErrorDetails');
-    if ($this->errorID !== null) {
-      $xfer += $output->writeFieldBegin('errorID', TType::STRING, 1);
-      $xfer += $output->writeString($this->errorID);
+    if ($this->errorId !== null) {
+      $xfer += $output->writeFieldBegin('errorId', TType::STRING, 1);
+      $xfer += $output->writeString($this->errorId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->creationTime !== null) {
@@ -1909,7 +1909,7 @@ class ErrorDetails {
 class JobDetails {
   static $_TSPEC;
 
-  public $jobID = "DO_NOT_SET_AT_CLIENTS";
+  public $jobId = "DO_NOT_SET_AT_CLIENTS";
   public $jobDescription = null;
   public $creationTime = null;
   public $jobStatus = null;
@@ -1923,7 +1923,7 @@ class JobDetails {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'jobID',
+          'var' => 'jobId',
           'type' => TType::STRING,
           ),
         2 => array(
@@ -1968,8 +1968,8 @@ class JobDetails {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['jobID'])) {
-        $this->jobID = $vals['jobID'];
+      if (isset($vals['jobId'])) {
+        $this->jobId = $vals['jobId'];
       }
       if (isset($vals['jobDescription'])) {
         $this->jobDescription = $vals['jobDescription'];
@@ -2019,7 +2019,7 @@ class JobDetails {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->jobID);
+            $xfer += $input->readString($this->jobId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -2106,9 +2106,9 @@ class JobDetails {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('JobDetails');
-    if ($this->jobID !== null) {
-      $xfer += $output->writeFieldBegin('jobID', TType::STRING, 1);
-      $xfer += $output->writeString($this->jobID);
+    if ($this->jobId !== null) {
+      $xfer += $output->writeFieldBegin('jobId', TType::STRING, 1);
+      $xfer += $output->writeString($this->jobId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->jobDescription !== null) {
@@ -2179,7 +2179,7 @@ class JobDetails {
 class DataTransferDetails {
   static $_TSPEC;
 
-  public $transferID = "DO_NOT_SET_AT_CLIENTS";
+  public $transferId = "DO_NOT_SET_AT_CLIENTS";
   public $creationTime = null;
   public $transferDescription = null;
   public $transferStatus = null;
@@ -2188,7 +2188,7 @@ class DataTransferDetails {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'transferID',
+          'var' => 'transferId',
           'type' => TType::STRING,
           ),
         2 => array(
@@ -2207,8 +2207,8 @@ class DataTransferDetails {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['transferID'])) {
-        $this->transferID = $vals['transferID'];
+      if (isset($vals['transferId'])) {
+        $this->transferId = $vals['transferId'];
       }
       if (isset($vals['creationTime'])) {
         $this->creationTime = $vals['creationTime'];
@@ -2243,7 +2243,7 @@ class DataTransferDetails {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->transferID);
+            $xfer += $input->readString($this->transferId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -2283,9 +2283,9 @@ class DataTransferDetails {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('DataTransferDetails');
-    if ($this->transferID !== null) {
-      $xfer += $output->writeFieldBegin('transferID', TType::STRING, 1);
-      $xfer += $output->writeString($this->transferID);
+    if ($this->transferId !== null) {
+      $xfer += $output->writeFieldBegin('transferId', TType::STRING, 1);
+      $xfer += $output->writeString($this->transferId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->creationTime !== null) {
@@ -2316,7 +2316,7 @@ class DataTransferDetails {
 class TaskDetails {
   static $_TSPEC;
 
-  public $taskID = "DO_NOT_SET_AT_CLIENTS";
+  public $taskId = "DO_NOT_SET_AT_CLIENTS";
   public $creationTime = null;
   public $applicationId = null;
   public $applicationVersion = null;
@@ -2337,7 +2337,7 @@ class TaskDetails {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'taskID',
+          'var' => 'taskId',
           'type' => TType::STRING,
           ),
         2 => array(
@@ -2436,8 +2436,8 @@ class TaskDetails {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['taskID'])) {
-        $this->taskID = $vals['taskID'];
+      if (isset($vals['taskId'])) {
+        $this->taskId = $vals['taskId'];
       }
       if (isset($vals['creationTime'])) {
         $this->creationTime = $vals['creationTime'];
@@ -2508,7 +2508,7 @@ class TaskDetails {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->taskID);
+            $xfer += $input->readString($this->taskId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -2700,9 +2700,9 @@ class TaskDetails {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('TaskDetails');
-    if ($this->taskID !== null) {
-      $xfer += $output->writeFieldBegin('taskID', TType::STRING, 1);
-      $xfer += $output->writeString($this->taskID);
+    if ($this->taskId !== null) {
+      $xfer += $output->writeFieldBegin('taskId', TType::STRING, 1);
+      $xfer += $output->writeString($this->taskId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->creationTime !== null) {
@@ -3455,8 +3455,8 @@ class ValidationResults {
 class Experiment {
   static $_TSPEC;
 
-  public $experimentID = "DO_NOT_SET_AT_CLIENTS";
-  public $projectID = "DEFAULT";
+  public $experimentId = "DO_NOT_SET_AT_CLIENTS";
+  public $projectId = "DEFAULT";
   public $creationTime = null;
   public $userName = null;
   public $name = null;
@@ -3481,11 +3481,11 @@ class Experiment {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'experimentID',
+          'var' => 'experimentId',
           'type' => TType::STRING,
           ),
         2 => array(
-          'var' => 'projectID',
+          'var' => 'projectId',
           'type' => TType::STRING,
           ),
         3 => array(
@@ -3598,11 +3598,11 @@ class Experiment {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['experimentID'])) {
-        $this->experimentID = $vals['experimentID'];
+      if (isset($vals['experimentId'])) {
+        $this->experimentId = $vals['experimentId'];
       }
-      if (isset($vals['projectID'])) {
-        $this->projectID = $vals['projectID'];
+      if (isset($vals['projectId'])) {
+        $this->projectId = $vals['projectId'];
       }
       if (isset($vals['creationTime'])) {
         $this->creationTime = $vals['creationTime'];
@@ -3685,14 +3685,14 @@ class Experiment {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->experimentID);
+            $xfer += $input->readString($this->experimentId);
           } else {
             $xfer += $input->skip($ftype);
           }
           break;
         case 2:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->projectID);
+            $xfer += $input->readString($this->projectId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -3910,14 +3910,14 @@ class Experiment {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('Experiment');
-    if ($this->experimentID !== null) {
-      $xfer += $output->writeFieldBegin('experimentID', TType::STRING, 1);
-      $xfer += $output->writeString($this->experimentID);
+    if ($this->experimentId !== null) {
+      $xfer += $output->writeFieldBegin('experimentId', TType::STRING, 1);
+      $xfer += $output->writeString($this->experimentId);
       $xfer += $output->writeFieldEnd();
     }
-    if ($this->projectID !== null) {
-      $xfer += $output->writeFieldBegin('projectID', TType::STRING, 2);
-      $xfer += $output->writeString($this->projectID);
+    if ($this->projectId !== null) {
+      $xfer += $output->writeFieldBegin('projectId', TType::STRING, 2);
+      $xfer += $output->writeString($this->projectId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->creationTime !== null) {
@@ -4103,8 +4103,8 @@ class Experiment {
 class ExperimentSummary {
   static $_TSPEC;
 
-  public $experimentID = null;
-  public $projectID = null;
+  public $experimentId = null;
+  public $projectId = null;
   public $creationTime = null;
   public $userName = null;
   public $name = null;
@@ -4117,11 +4117,11 @@ class ExperimentSummary {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'experimentID',
+          'var' => 'experimentId',
           'type' => TType::STRING,
           ),
         2 => array(
-          'var' => 'projectID',
+          'var' => 'projectId',
           'type' => TType::STRING,
           ),
         3 => array(
@@ -4161,11 +4161,11 @@ class ExperimentSummary {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['experimentID'])) {
-        $this->experimentID = $vals['experimentID'];
+      if (isset($vals['experimentId'])) {
+        $this->experimentId = $vals['experimentId'];
       }
-      if (isset($vals['projectID'])) {
-        $this->projectID = $vals['projectID'];
+      if (isset($vals['projectId'])) {
+        $this->projectId = $vals['projectId'];
       }
       if (isset($vals['creationTime'])) {
         $this->creationTime = $vals['creationTime'];
@@ -4212,14 +4212,14 @@ class ExperimentSummary {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->experimentID);
+            $xfer += $input->readString($this->experimentId);
           } else {
             $xfer += $input->skip($ftype);
           }
           break;
         case 2:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->projectID);
+            $xfer += $input->readString($this->projectId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -4298,14 +4298,14 @@ class ExperimentSummary {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('ExperimentSummary');
-    if ($this->experimentID !== null) {
-      $xfer += $output->writeFieldBegin('experimentID', TType::STRING, 1);
-      $xfer += $output->writeString($this->experimentID);
+    if ($this->experimentId !== null) {
+      $xfer += $output->writeFieldBegin('experimentId', TType::STRING, 1);
+      $xfer += $output->writeString($this->experimentId);
       $xfer += $output->writeFieldEnd();
     }
-    if ($this->projectID !== null) {
-      $xfer += $output->writeFieldBegin('projectID', TType::STRING, 2);
-      $xfer += $output->writeString($this->projectID);
+    if ($this->projectId !== null) {
+      $xfer += $output->writeFieldBegin('projectId', TType::STRING, 2);
+      $xfer += $output->writeString($this->projectId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->creationTime !== null) {

http://git-wip-us.apache.org/repos/asf/airavata/blob/b376aa85/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Types.php
----------------------------------------------------------------------
diff --git a/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Types.php b/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Types.php
index 7ccd55c..aa4718f 100644
--- a/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Types.php
+++ b/airavata-api/airavata-client-sdks/airavata-php-sdk/src/main/resources/lib/Airavata/Model/Workspace/Types.php
@@ -112,7 +112,7 @@ class Group {
 class Project {
   static $_TSPEC;
 
-  public $projectID = "DEFAULT";
+  public $projectId = "DEFAULT";
   public $owner = null;
   public $name = null;
   public $description = null;
@@ -124,7 +124,7 @@ class Project {
     if (!isset(self::$_TSPEC)) {
       self::$_TSPEC = array(
         1 => array(
-          'var' => 'projectID',
+          'var' => 'projectId',
           'type' => TType::STRING,
           ),
         2 => array(
@@ -162,8 +162,8 @@ class Project {
         );
     }
     if (is_array($vals)) {
-      if (isset($vals['projectID'])) {
-        $this->projectID = $vals['projectID'];
+      if (isset($vals['projectId'])) {
+        $this->projectId = $vals['projectId'];
       }
       if (isset($vals['owner'])) {
         $this->owner = $vals['owner'];
@@ -207,7 +207,7 @@ class Project {
       {
         case 1:
           if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->projectID);
+            $xfer += $input->readString($this->projectId);
           } else {
             $xfer += $input->skip($ftype);
           }
@@ -287,9 +287,9 @@ class Project {
   public function write($output) {
     $xfer = 0;
     $xfer += $output->writeStructBegin('Project');
-    if ($this->projectID !== null) {
-      $xfer += $output->writeFieldBegin('projectID', TType::STRING, 1);
-      $xfer += $output->writeString($this->projectID);
+    if ($this->projectId !== null) {
+      $xfer += $output->writeFieldBegin('projectId', TType::STRING, 1);
+      $xfer += $output->writeString($this->projectId);
       $xfer += $output->writeFieldEnd();
     }
     if ($this->owner !== null) {