You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by sh...@apache.org on 2016/10/03 21:25:28 UTC

[5/6] airavata git commit: Replaced xslt templates with groovy templates, fixed AIRAVATA-2124

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/JobDescriptor.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/JobDescriptor.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/JobDescriptor.java
deleted file mode 100644
index f1f72df..0000000
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/JobDescriptor.java
+++ /dev/null
@@ -1,489 +0,0 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.airavata.gfac.core;
-
-import org.apache.airavata.gfac.core.cluster.CommandOutput;
-import org.apache.airavata.gfac.core.x2012.x12.AfterAnyList;
-import org.apache.airavata.gfac.core.x2012.x12.AfterOKList;
-import org.apache.airavata.gfac.core.x2012.x12.InputList;
-import org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument;
-import org.apache.xmlbeans.XmlException;
-
-import java.util.List;
-
-/**
- * This class define a job with required parameters, based on this configuration API is generating a Pbs script and
- * submit the job to the computing resource
- */
-public class JobDescriptor {
-
-    private JobDescriptorDocument jobDescriptionDocument;
-
-
-    public JobDescriptor() {
-        jobDescriptionDocument = JobDescriptorDocument.Factory.newInstance();
-        jobDescriptionDocument.addNewJobDescriptor();
-    }
-
-    public JobDescriptor(JobDescriptorDocument jobDescriptorDocument) {
-        this.jobDescriptionDocument = jobDescriptorDocument;
-    }
-
-
-    public JobDescriptor(CommandOutput commandOutput) {
-        jobDescriptionDocument = JobDescriptorDocument.Factory.newInstance();
-        jobDescriptionDocument.addNewJobDescriptor();
-    }
-
-
-    public String toXML() {
-        return jobDescriptionDocument.xmlText();
-    }
-
-    public JobDescriptorDocument getJobDescriptorDocument() {
-        return this.jobDescriptionDocument;
-    }
-
-    /**
-     * With new app catalog thrift object integration, we don't use this
-     * @param xml
-     * @return
-     * @throws XmlException
-     */
-    @Deprecated
-    public static JobDescriptor fromXML(String xml)
-            throws XmlException {
-        JobDescriptorDocument parse = JobDescriptorDocument.Factory
-                .parse(xml);
-        JobDescriptor jobDescriptor = new JobDescriptor(parse);
-        return jobDescriptor;
-    }
-
-
-    //todo write bunch of setter getters to set and get jobdescription parameters
-    public void setWorkingDirectory(String workingDirectory) {
-        this.getJobDescriptorDocument().getJobDescriptor().setWorkingDirectory(workingDirectory);
-    }
-
-    public String getWorkingDirectory() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getWorkingDirectory();
-    }
-
-    public void setShellName(String shellName) {
-        this.getJobDescriptorDocument().getJobDescriptor().setShellName(shellName);
-    }
-
-    public void setJobName(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setJobName(name);
-    }
-
-    public void setExecutablePath(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setExecutablePath(name);
-    }
-
-    public void setAllEnvExport(boolean name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setAllEnvExport(name);
-    }
-
-    public void setMailOptions(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setMailOptions(name);
-    }
-
-    public void setStandardOutFile(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setStandardOutFile(name);
-    }
-
-    public void setStandardErrorFile(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setStandardErrorFile(name);
-    }
-
-    public void setNodes(int name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setNodes(name);
-    }
-
-    public void setProcessesPerNode(int name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setProcessesPerNode(name);
-    }
-
-    public String getOutputDirectory() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getOutputDirectory();
-    }
-
-    public String getInputDirectory() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getInputDirectory();
-    }
-    public void setOutputDirectory(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setOutputDirectory(name);
-    }
-
-    public void setInputDirectory(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setInputDirectory(name);
-    }
-
-    /**
-     * Users can pass the minute count for maxwalltime
-     * @param minutes
-     */
-    public void setMaxWallTime(String minutes) {
-        this.getJobDescriptorDocument().getJobDescriptor().setMaxWallTime(
-                GFacUtils.maxWallTimeCalculator(Integer.parseInt(minutes)));
-
-    }
-
-
-    public void setMaxWallTimeForLSF(String minutes) {
-        this.getJobDescriptorDocument().getJobDescriptor().setMaxWallTime(
-                GFacUtils.maxWallTimeCalculatorForLSF(Integer.parseInt(minutes)));
-
-    }
-    public void setAcountString(String name) {
-        this.getJobDescriptorDocument().getJobDescriptor().setAcountString(name);
-    }
-
-    public void setInputValues(List<String> inputValue) {
-        InputList inputList = this.getJobDescriptorDocument().getJobDescriptor().addNewInputs();
-        inputList.setInputArray(inputValue.toArray(new String[inputValue.size()]));
-    }
-
-    public void setJobID(String jobID) {
-        this.getJobDescriptorDocument().getJobDescriptor().setJobID(jobID);
-    }
-
-    public void setQueueName(String queueName) {
-        this.getJobDescriptorDocument().getJobDescriptor().setQueueName(queueName);
-    }
-
-    public void setStatus(String queueName) {
-        this.getJobDescriptorDocument().getJobDescriptor().setStatus(queueName);
-    }
-
-    public void setAfterAnyList(String[] afterAnyList) {
-        AfterAnyList afterAny = this.getJobDescriptorDocument().getJobDescriptor().addNewAfterAny();
-        afterAny.setAfterAnyArray(afterAnyList);
-    }
-
-    public void setAfterOKList(String[] afterOKList) {
-        AfterOKList afterAnyList = this.getJobDescriptorDocument().getJobDescriptor().addNewAfterOKList();
-        afterAnyList.setAfterOKListArray(afterOKList);
-    }
-    public void setCTime(String cTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setCTime(cTime);
-    }
-    public void setQTime(String qTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setQTime(qTime);
-    }
-    public void setMTime(String mTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setMTime(mTime);
-    }
-    public void setSTime(String sTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setSTime(sTime);
-    }
-    public void setCompTime(String compTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setCompTime(compTime);
-    }
-    public void setOwner(String owner) {
-        this.getJobDescriptorDocument().getJobDescriptor().setOwner(owner);
-    }
-    public void setExecuteNode(String executeNode) {
-        this.getJobDescriptorDocument().getJobDescriptor().setExecuteNode(executeNode);
-    }
-    public void setEllapsedTime(String ellapsedTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setEllapsedTime(ellapsedTime);
-    }
-
-    public void setUsedCPUTime(String usedCPUTime) {
-        this.getJobDescriptorDocument().getJobDescriptor().setUsedCPUTime(usedCPUTime);
-    }
-    public void setCPUCount(int usedCPUTime) {
-            this.getJobDescriptorDocument().getJobDescriptor().setCpuCount(usedCPUTime);
-        }
-    public void setUsedMemory(String usedMemory) {
-        this.getJobDescriptorDocument().getJobDescriptor().setUsedMem(usedMemory);
-    }
-    public void setVariableList(String variableList) {
-        this.getJobDescriptorDocument().getJobDescriptor().setVariableList(variableList);
-    }
-    public void setSubmitArgs(String submitArgs) {
-        this.getJobDescriptorDocument().getJobDescriptor().setSubmitArgs(submitArgs);
-    }
-
-    public void setPreJobCommands(String[] commands){
-        if(this.getJobDescriptorDocument().getJobDescriptor().getPreJobCommands() == null){
-            this.getJobDescriptorDocument().getJobDescriptor().addNewPreJobCommands();
-        }
-        this.getJobDescriptorDocument().getJobDescriptor().getPreJobCommands().setCommandArray(commands);
-    }
-
-     public void setPostJobCommands(String[] commands){
-        if(this.getJobDescriptorDocument().getJobDescriptor().getPostJobCommands() == null){
-            this.getJobDescriptorDocument().getJobDescriptor().addNewPostJobCommands();
-        }
-        this.getJobDescriptorDocument().getJobDescriptor().getPostJobCommands().setCommandArray(commands);
-    }
-
-    public void setModuleLoadCommands(String[] commands) {
-        if (this.getJobDescriptorDocument().getJobDescriptor().getModuleLoadCommands() == null) {
-            this.getJobDescriptorDocument().getJobDescriptor().addNewModuleLoadCommands();
-        }
-        this.getJobDescriptorDocument().getJobDescriptor().getModuleLoadCommands().setCommandArray(commands);
-    }
-
-    public void addModuleLoadCommands(String command) {
-        if (this.getJobDescriptorDocument().getJobDescriptor().getModuleLoadCommands() == null) {
-            this.getJobDescriptorDocument().getJobDescriptor().addNewModuleLoadCommands();
-        }
-        this.getJobDescriptorDocument().getJobDescriptor().getModuleLoadCommands().addCommand(command);
-    }
-
-    public void addPreJobCommand(String command){
-        if(this.getJobDescriptorDocument().getJobDescriptor().getPreJobCommands() == null){
-            this.getJobDescriptorDocument().getJobDescriptor().addNewPreJobCommands();
-        }
-        this.getJobDescriptorDocument().getJobDescriptor().getPreJobCommands().addCommand(command);
-    }
-
-     public void addPostJobCommand(String command){
-        if(this.getJobDescriptorDocument().getJobDescriptor().getPostJobCommands() == null){
-            this.getJobDescriptorDocument().getJobDescriptor().addNewPostJobCommands();
-        }
-        this.getJobDescriptorDocument().getJobDescriptor().getPostJobCommands().addCommand(command);
-    }
-
-    public void setPartition(String partition){
-        this.getJobDescriptorDocument().getJobDescriptor().setPartition(partition);
-    }
-
-     public void setUserName(String userName){
-        this.getJobDescriptorDocument().getJobDescriptor().setUserName(userName);
-    }
-     public void setNodeList(String nodeList){
-        this.getJobDescriptorDocument().getJobDescriptor().setNodeList(nodeList);
-    }
-    public void setJobSubmitter(String jobSubmitter){
-           this.getJobDescriptorDocument().getJobDescriptor().setJobSubmitterCommand(jobSubmitter);
-    }
-    public String getNodeList(){
-        return this.getJobDescriptorDocument().getJobDescriptor().getNodeList();
-    }
-    public String getExecutablePath() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getExecutablePath();
-    }
-
-    public boolean getAllEnvExport() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getAllEnvExport();
-    }
-
-    public String getMailOptions() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getMailOptions();
-    }
-
-    public String getStandardOutFile() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getStandardOutFile();
-    }
-
-    public String getStandardErrorFile() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getStandardErrorFile();
-    }
-
-    public int getNodes(int name) {
-        return this.getJobDescriptorDocument().getJobDescriptor().getNodes();
-    }
-
-    public int getCPUCount(int name) {
-        return this.getJobDescriptorDocument().getJobDescriptor().getCpuCount();
-    }
-
-    public int getProcessesPerNode() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getProcessesPerNode();
-    }
-
-    public String getMaxWallTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getMaxWallTime();
-    }
-
-    public String getAcountString() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getAcountString();
-    }
-
-    public String[] getInputValues() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getInputs().getInputArray();
-    }
-
-    public String getJobID() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getJobID();
-    }
-
-    public String getQueueName() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getQueueName();
-    }
-
-    public String getStatus() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getStatus();
-    }
-
-    public String[] getAfterAnyList() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getAfterAny().getAfterAnyArray();
-    }
-
-    public String[] getAfterOKList() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getAfterOKList().getAfterOKListArray();
-    }
-    public String getCTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getCTime();
-    }
-    public String getQTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getQTime();
-    }
-    public String getMTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getMTime();
-    }
-    public String getSTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getSTime();
-    }
-    public String getCompTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getCompTime();
-    }
-    public String getOwner() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getOwner();
-    }
-    public String getExecuteNode() {
-         return this.getJobDescriptorDocument().getJobDescriptor().getExecuteNode();
-    }
-    public String getEllapsedTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getEllapsedTime();
-    }
-
-    public String getUsedCPUTime() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getUsedCPUTime();
-    }
-
-    public String getUsedMemory() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getUsedMem();
-    }
-    public void getShellName() {
-        this.getJobDescriptorDocument().getJobDescriptor().getShellName();
-    }
-
-    public String getJobName() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getJobName();
-    }
-
-    public String getJobId() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getJobID();
-    }
-
-
-    public String getVariableList() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getJobID();
-    }
-    public String getSubmitArgs() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getJobID();
-    }
-
-    public String[] getPostJobCommands(){
-        if(this.getJobDescriptorDocument().getJobDescriptor().getPostJobCommands() != null) {
-            return this.getJobDescriptorDocument().getJobDescriptor().getPostJobCommands().getCommandArray();
-        }
-        return null;
-    }
-
-    public String[] getModuleCommands() {
-        if (this.getJobDescriptorDocument().getJobDescriptor().getModuleLoadCommands() != null) {
-            return this.getJobDescriptorDocument().getJobDescriptor().getModuleLoadCommands().getCommandArray();
-        }
-        return null;
-    }
-
-    public String[] getPreJobCommands(){
-        if(this.getJobDescriptorDocument().getJobDescriptor().getPreJobCommands() != null) {
-            return this.getJobDescriptorDocument().getJobDescriptor().getPreJobCommands().getCommandArray();
-        }
-        return null;
-    }
-
-    public String getJobSubmitterCommand(){
-          return this.getJobDescriptorDocument().getJobDescriptor().getJobSubmitterCommand();
-    }
-
-    public String getPartition(){
-        return this.getJobDescriptorDocument().getJobDescriptor().getPartition();
-    }
-
-    public String getUserName(){
-        return this.getJobDescriptorDocument().getJobDescriptor().getUserName();
-    }
-
-    public void setCallBackIp(String ip){
-        this.jobDescriptionDocument.getJobDescriptor().setCallBackIp(ip);
-    }
-
-    public void setCallBackPort(String ip){
-        this.jobDescriptionDocument.getJobDescriptor().setCallBackPort(ip);
-    }
-
-
-    public String getCallBackIp(){
-        return this.jobDescriptionDocument.getJobDescriptor().getCallBackIp();
-    }
-    public String getCallBackPort(){
-        return this.jobDescriptionDocument.getJobDescriptor().getCallBackPort();
-    }
-
-    public void setMailType(String emailType) {
-        this.getJobDescriptorDocument().getJobDescriptor().setMailType(emailType);
-    }
-
-    public String getMailType() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getMailType();
-    }
-    public void setMailAddress(String emailAddress) {
-        this.getJobDescriptorDocument().getJobDescriptor().setMailAddress(emailAddress);
-    }
-
-    public String getMailAddress() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getMailAddress();
-    }
-
-    public String getChassisName() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getChassisName();
-    }
-
-    public void setChassisName(String chassisName){
-        this.getJobDescriptorDocument().getJobDescriptor().setChassisName(chassisName);
-    }
-
-    public void setQoS(String qos){
-        this.getJobDescriptorDocument().getJobDescriptor().setQualityOfService(qos);
-    }
-
-    public String getQoS() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getQualityOfService();
-    }
-
-    public void setReservation(String reservation) {
-        this.getJobDescriptorDocument().getJobDescriptor().setReservation(reservation);
-    }
-
-    public String getReservation() {
-        return this.getJobDescriptorDocument().getJobDescriptor().getReservation();
-    }
-    
-}
-

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/Script.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/Script.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/Script.java
new file mode 100644
index 0000000..1e3ecd9
--- /dev/null
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/Script.java
@@ -0,0 +1,75 @@
+/**
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.airavata.gfac.core;/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+public enum Script {
+
+    SHELL_NAME("shellName"),
+    QUEUE_NAME("queueName"),
+    NODES("nodes"),
+    CPU_COUNT("cpuCount"),
+    MAIL_ADDRESS("mailAddress"),
+    ACCOUNT_STRING("accountString"),
+    MAX_WALL_TIME("maxWallTime"),
+    JOB_NAME("jobName"),
+    STANDARD_OUT_FILE("standardOutFile"),
+    STANDARD_ERROR_FILE("standardErrorFile"),
+    QUALITY_OF_SERVICE("qualityOfService"),
+    RESERVATION("reservation"),
+    EXPORTS("exports"),
+    MODULE_COMMANDS("moduleCommands"),
+    WORKING_DIR("workingDirectory"),
+    PRE_JOB_COMMANDS("preJobCommands"),
+    JOB_SUBMITTER_COMMAND("jobSubmitterCommand"),
+    EXECUTABLE_PATH("executablePath"),
+    INPUTS("inputs"),
+    POST_JOB_COMMANDS("postJobCommands"),
+    USED_MEM("usedMem"),
+    PROCESS_PER_NODE("processPerNode"),
+    CHASSIS_NAME("chassisName"),
+    INPUT_DIR("inputDir"),
+    OUTPUT_DIR("outputDir"),
+    USER_NAME("userName"),
+    ;
+
+    String name;
+    Script(String name) {
+        this.name = name;
+    }
+}

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cluster/OutputParser.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cluster/OutputParser.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cluster/OutputParser.java
index 3259e85..d90ae1d 100644
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cluster/OutputParser.java
+++ b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/cluster/OutputParser.java
@@ -19,7 +19,6 @@
  */
 package org.apache.airavata.gfac.core.cluster;
 
-import org.apache.airavata.gfac.core.JobDescriptor;
 import org.apache.airavata.gfac.core.SSHApiException;
 import org.apache.airavata.model.status.JobStatus;
 
@@ -28,13 +27,6 @@ import java.util.Map;
 public interface OutputParser {
 
     /**
-     * Tihs can be used to fill a jobdescriptor based on the output
-     * @param descriptor
-     * @return
-     */
-    public void parseSingleJob(JobDescriptor descriptor, String rawOutput)throws SSHApiException;
-
-    /**
      * This can be used to parseSingleJob the result of a job submission to get the JobID
      * @param rawOutput
      * @return

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterAnyList.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterAnyList.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterAnyList.java
deleted file mode 100644
index 8c80646..0000000
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterAnyList.java
+++ /dev/null
@@ -1,185 +0,0 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/*
- * XML Type:  afterAnyList
- * Namespace: http://airavata.apache.org/gfac/core/2012/12
- * Java type: org.apache.airavata.gfac.core.x2012.x12.AfterAnyList
- *
- * Automatically generated - do not modify.
- */
-package org.apache.airavata.gfac.core.x2012.x12;
-
-
-/**
- * An XML afterAnyList(@http://airavata.apache.org/gfac/core/2012/12).
- *
- * This is a complex type.
- */
-public interface AfterAnyList extends org.apache.xmlbeans.XmlObject
-{
-    public static final org.apache.xmlbeans.SchemaType type = (org.apache.xmlbeans.SchemaType)
-        org.apache.xmlbeans.XmlBeans.typeSystemForClassLoader(AfterAnyList.class.getClassLoader(), "schemaorg_apache_xmlbeans.system.sD070E302A2FC7CFEA0F2B3EB44FAE57D").resolveHandle("afteranylisteefatype");
-    
-    /**
-     * Gets array of all "afterAny" elements
-     */
-    java.lang.String[] getAfterAnyArray();
-    
-    /**
-     * Gets ith "afterAny" element
-     */
-    java.lang.String getAfterAnyArray(int i);
-    
-    /**
-     * Gets (as xml) array of all "afterAny" elements
-     */
-    org.apache.xmlbeans.XmlString[] xgetAfterAnyArray();
-    
-    /**
-     * Gets (as xml) ith "afterAny" element
-     */
-    org.apache.xmlbeans.XmlString xgetAfterAnyArray(int i);
-    
-    /**
-     * Returns number of "afterAny" element
-     */
-    int sizeOfAfterAnyArray();
-    
-    /**
-     * Sets array of all "afterAny" element
-     */
-    void setAfterAnyArray(java.lang.String[] afterAnyArray);
-    
-    /**
-     * Sets ith "afterAny" element
-     */
-    void setAfterAnyArray(int i, java.lang.String afterAny);
-    
-    /**
-     * Sets (as xml) array of all "afterAny" element
-     */
-    void xsetAfterAnyArray(org.apache.xmlbeans.XmlString[] afterAnyArray);
-    
-    /**
-     * Sets (as xml) ith "afterAny" element
-     */
-    void xsetAfterAnyArray(int i, org.apache.xmlbeans.XmlString afterAny);
-    
-    /**
-     * Inserts the value as the ith "afterAny" element
-     */
-    void insertAfterAny(int i, java.lang.String afterAny);
-    
-    /**
-     * Appends the value as the last "afterAny" element
-     */
-    void addAfterAny(java.lang.String afterAny);
-    
-    /**
-     * Inserts and returns a new empty value (as xml) as the ith "afterAny" element
-     */
-    org.apache.xmlbeans.XmlString insertNewAfterAny(int i);
-    
-    /**
-     * Appends and returns a new empty value (as xml) as the last "afterAny" element
-     */
-    org.apache.xmlbeans.XmlString addNewAfterAny();
-    
-    /**
-     * Removes the ith "afterAny" element
-     */
-    void removeAfterAny(int i);
-    
-    /**
-     * A factory class with static methods for creating instances
-     * of this type.
-     */
-    
-    public static final class Factory
-    {
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList newInstance() {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList newInstance(org.apache.xmlbeans.XmlOptions options) {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, options ); }
-        
-        /** @param xmlAsString the string value to parse */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.lang.String xmlAsString) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.lang.String xmlAsString, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, options ); }
-        
-        /** @param file the file from which to load an xml document */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.io.File file) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.io.File file, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.net.URL u) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.net.URL u, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.io.InputStream is) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.io.InputStream is, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.io.Reader r) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(java.io.Reader r, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(javax.xml.stream.XMLStreamReader sr) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(javax.xml.stream.XMLStreamReader sr, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(org.w3c.dom.Node node) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(org.w3c.dom.Node node, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterAnyList parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterAnyList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, options ); }
-        
-        private Factory() { } // No instance of this class allowed
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterOKList.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterOKList.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterOKList.java
deleted file mode 100644
index 15688c1..0000000
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/AfterOKList.java
+++ /dev/null
@@ -1,185 +0,0 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/*
- * XML Type:  afterOKList
- * Namespace: http://airavata.apache.org/gfac/core/2012/12
- * Java type: org.apache.airavata.gfac.core.x2012.x12.AfterOKList
- *
- * Automatically generated - do not modify.
- */
-package org.apache.airavata.gfac.core.x2012.x12;
-
-
-/**
- * An XML afterOKList(@http://airavata.apache.org/gfac/core/2012/12).
- *
- * This is a complex type.
- */
-public interface AfterOKList extends org.apache.xmlbeans.XmlObject
-{
-    public static final org.apache.xmlbeans.SchemaType type = (org.apache.xmlbeans.SchemaType)
-        org.apache.xmlbeans.XmlBeans.typeSystemForClassLoader(AfterOKList.class.getClassLoader(), "schemaorg_apache_xmlbeans.system.sD070E302A2FC7CFEA0F2B3EB44FAE57D").resolveHandle("afteroklistc764type");
-    
-    /**
-     * Gets array of all "afterOKList" elements
-     */
-    java.lang.String[] getAfterOKListArray();
-    
-    /**
-     * Gets ith "afterOKList" element
-     */
-    java.lang.String getAfterOKListArray(int i);
-    
-    /**
-     * Gets (as xml) array of all "afterOKList" elements
-     */
-    org.apache.xmlbeans.XmlString[] xgetAfterOKListArray();
-    
-    /**
-     * Gets (as xml) ith "afterOKList" element
-     */
-    org.apache.xmlbeans.XmlString xgetAfterOKListArray(int i);
-    
-    /**
-     * Returns number of "afterOKList" element
-     */
-    int sizeOfAfterOKListArray();
-    
-    /**
-     * Sets array of all "afterOKList" element
-     */
-    void setAfterOKListArray(java.lang.String[] afterOKListArray);
-    
-    /**
-     * Sets ith "afterOKList" element
-     */
-    void setAfterOKListArray(int i, java.lang.String afterOKList);
-    
-    /**
-     * Sets (as xml) array of all "afterOKList" element
-     */
-    void xsetAfterOKListArray(org.apache.xmlbeans.XmlString[] afterOKListArray);
-    
-    /**
-     * Sets (as xml) ith "afterOKList" element
-     */
-    void xsetAfterOKListArray(int i, org.apache.xmlbeans.XmlString afterOKList);
-    
-    /**
-     * Inserts the value as the ith "afterOKList" element
-     */
-    void insertAfterOKList(int i, java.lang.String afterOKList);
-    
-    /**
-     * Appends the value as the last "afterOKList" element
-     */
-    void addAfterOKList(java.lang.String afterOKList);
-    
-    /**
-     * Inserts and returns a new empty value (as xml) as the ith "afterOKList" element
-     */
-    org.apache.xmlbeans.XmlString insertNewAfterOKList(int i);
-    
-    /**
-     * Appends and returns a new empty value (as xml) as the last "afterOKList" element
-     */
-    org.apache.xmlbeans.XmlString addNewAfterOKList();
-    
-    /**
-     * Removes the ith "afterOKList" element
-     */
-    void removeAfterOKList(int i);
-    
-    /**
-     * A factory class with static methods for creating instances
-     * of this type.
-     */
-    
-    public static final class Factory
-    {
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList newInstance() {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList newInstance(org.apache.xmlbeans.XmlOptions options) {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, options ); }
-        
-        /** @param xmlAsString the string value to parse */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.lang.String xmlAsString) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.lang.String xmlAsString, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, options ); }
-        
-        /** @param file the file from which to load an xml document */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.io.File file) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.io.File file, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.net.URL u) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.net.URL u, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.io.InputStream is) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.io.InputStream is, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.io.Reader r) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(java.io.Reader r, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(javax.xml.stream.XMLStreamReader sr) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(javax.xml.stream.XMLStreamReader sr, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(org.w3c.dom.Node node) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(org.w3c.dom.Node node, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.AfterOKList parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.AfterOKList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, options ); }
-        
-        private Factory() { } // No instance of this class allowed
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/ExportProperties.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/ExportProperties.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/ExportProperties.java
deleted file mode 100644
index 8bea40c..0000000
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/ExportProperties.java
+++ /dev/null
@@ -1,202 +0,0 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/*
- * XML Type:  exportProperties
- * Namespace: http://airavata.apache.org/gfac/core/2012/12
- * Java type: org.apache.airavata.gfac.core.x2012.x12.ExportProperties
- *
- * Automatically generated - do not modify.
- */
-package org.apache.airavata.gfac.core.x2012.x12;
-
-
-/**
- * An XML exportProperties(@http://airavata.apache.org/gfac/core/2012/12).
- *
- * This is a complex type.
- */
-public interface ExportProperties extends org.apache.xmlbeans.XmlObject
-{
-    public static final org.apache.xmlbeans.SchemaType type = (org.apache.xmlbeans.SchemaType)
-        org.apache.xmlbeans.XmlBeans.typeSystemForClassLoader(ExportProperties.class.getClassLoader(), "schemaorg_apache_xmlbeans.system.sD070E302A2FC7CFEA0F2B3EB44FAE57D").resolveHandle("exportproperties2741type");
-    
-    /**
-     * Gets array of all "name" elements
-     */
-    org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name[] getNameArray();
-    
-    /**
-     * Gets ith "name" element
-     */
-    org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name getNameArray(int i);
-    
-    /**
-     * Returns number of "name" element
-     */
-    int sizeOfNameArray();
-    
-    /**
-     * Sets array of all "name" element
-     */
-    void setNameArray(org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name[] nameArray);
-    
-    /**
-     * Sets ith "name" element
-     */
-    void setNameArray(int i, org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name name);
-    
-    /**
-     * Inserts and returns a new empty value (as xml) as the ith "name" element
-     */
-    org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name insertNewName(int i);
-    
-    /**
-     * Appends and returns a new empty value (as xml) as the last "name" element
-     */
-    org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name addNewName();
-    
-    /**
-     * Removes the ith "name" element
-     */
-    void removeName(int i);
-    
-    /**
-     * An XML name(@http://airavata.apache.org/gfac/core/2012/12).
-     *
-     * This is an atomic type that is a restriction of org.apache.airavata.gfac.core.x2012.x12.ExportProperties$Name.
-     */
-    public interface Name extends org.apache.xmlbeans.XmlString
-    {
-        public static final org.apache.xmlbeans.SchemaType type = (org.apache.xmlbeans.SchemaType)
-            org.apache.xmlbeans.XmlBeans.typeSystemForClassLoader(Name.class.getClassLoader(), "schemaorg_apache_xmlbeans.system.sD070E302A2FC7CFEA0F2B3EB44FAE57D").resolveHandle("namee668elemtype");
-        
-        /**
-         * Gets the "value" attribute
-         */
-        java.lang.String getValue();
-        
-        /**
-         * Gets (as xml) the "value" attribute
-         */
-        org.apache.xmlbeans.XmlString xgetValue();
-        
-        /**
-         * Sets the "value" attribute
-         */
-        void setValue(java.lang.String value);
-        
-        /**
-         * Sets (as xml) the "value" attribute
-         */
-        void xsetValue(org.apache.xmlbeans.XmlString value);
-        
-        /**
-         * A factory class with static methods for creating instances
-         * of this type.
-         */
-        
-        public static final class Factory
-        {
-            public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name newInstance() {
-              return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, null ); }
-            
-            public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name newInstance(org.apache.xmlbeans.XmlOptions options) {
-              return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties.Name) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, options ); }
-            
-            private Factory() { } // No instance of this class allowed
-        }
-    }
-    
-    /**
-     * A factory class with static methods for creating instances
-     * of this type.
-     */
-    
-    public static final class Factory
-    {
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties newInstance() {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties newInstance(org.apache.xmlbeans.XmlOptions options) {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, options ); }
-        
-        /** @param xmlAsString the string value to parse */
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.lang.String xmlAsString) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.lang.String xmlAsString, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, options ); }
-        
-        /** @param file the file from which to load an xml document */
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.io.File file) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.io.File file, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.net.URL u) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.net.URL u, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.io.InputStream is) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.io.InputStream is, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.io.Reader r) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(java.io.Reader r, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(javax.xml.stream.XMLStreamReader sr) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(javax.xml.stream.XMLStreamReader sr, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(org.w3c.dom.Node node) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(org.w3c.dom.Node node, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.ExportProperties parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.ExportProperties) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, options ); }
-        
-        private Factory() { } // No instance of this class allowed
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/InputList.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/InputList.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/InputList.java
deleted file mode 100644
index 3c16f56..0000000
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/InputList.java
+++ /dev/null
@@ -1,185 +0,0 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/*
- * XML Type:  inputList
- * Namespace: http://airavata.apache.org/gfac/core/2012/12
- * Java type: org.apache.airavata.gfac.core.x2012.x12.InputList
- *
- * Automatically generated - do not modify.
- */
-package org.apache.airavata.gfac.core.x2012.x12;
-
-
-/**
- * An XML inputList(@http://airavata.apache.org/gfac/core/2012/12).
- *
- * This is a complex type.
- */
-public interface InputList extends org.apache.xmlbeans.XmlObject
-{
-    public static final org.apache.xmlbeans.SchemaType type = (org.apache.xmlbeans.SchemaType)
-        org.apache.xmlbeans.XmlBeans.typeSystemForClassLoader(InputList.class.getClassLoader(), "schemaorg_apache_xmlbeans.system.sD070E302A2FC7CFEA0F2B3EB44FAE57D").resolveHandle("inputlistccd2type");
-    
-    /**
-     * Gets array of all "input" elements
-     */
-    java.lang.String[] getInputArray();
-    
-    /**
-     * Gets ith "input" element
-     */
-    java.lang.String getInputArray(int i);
-    
-    /**
-     * Gets (as xml) array of all "input" elements
-     */
-    org.apache.xmlbeans.XmlString[] xgetInputArray();
-    
-    /**
-     * Gets (as xml) ith "input" element
-     */
-    org.apache.xmlbeans.XmlString xgetInputArray(int i);
-    
-    /**
-     * Returns number of "input" element
-     */
-    int sizeOfInputArray();
-    
-    /**
-     * Sets array of all "input" element
-     */
-    void setInputArray(java.lang.String[] inputArray);
-    
-    /**
-     * Sets ith "input" element
-     */
-    void setInputArray(int i, java.lang.String input);
-    
-    /**
-     * Sets (as xml) array of all "input" element
-     */
-    void xsetInputArray(org.apache.xmlbeans.XmlString[] inputArray);
-    
-    /**
-     * Sets (as xml) ith "input" element
-     */
-    void xsetInputArray(int i, org.apache.xmlbeans.XmlString input);
-    
-    /**
-     * Inserts the value as the ith "input" element
-     */
-    void insertInput(int i, java.lang.String input);
-    
-    /**
-     * Appends the value as the last "input" element
-     */
-    void addInput(java.lang.String input);
-    
-    /**
-     * Inserts and returns a new empty value (as xml) as the ith "input" element
-     */
-    org.apache.xmlbeans.XmlString insertNewInput(int i);
-    
-    /**
-     * Appends and returns a new empty value (as xml) as the last "input" element
-     */
-    org.apache.xmlbeans.XmlString addNewInput();
-    
-    /**
-     * Removes the ith "input" element
-     */
-    void removeInput(int i);
-    
-    /**
-     * A factory class with static methods for creating instances
-     * of this type.
-     */
-    
-    public static final class Factory
-    {
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList newInstance() {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList newInstance(org.apache.xmlbeans.XmlOptions options) {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, options ); }
-        
-        /** @param xmlAsString the string value to parse */
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.lang.String xmlAsString) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.lang.String xmlAsString, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, options ); }
-        
-        /** @param file the file from which to load an xml document */
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.io.File file) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.io.File file, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.net.URL u) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.net.URL u, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.io.InputStream is) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.io.InputStream is, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.io.Reader r) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(java.io.Reader r, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(javax.xml.stream.XMLStreamReader sr) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(javax.xml.stream.XMLStreamReader sr, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(org.w3c.dom.Node node) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(org.w3c.dom.Node node, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.InputList parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.InputList) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, options ); }
-        
-        private Factory() { } // No instance of this class allowed
-    }
-}

http://git-wip-us.apache.org/repos/asf/airavata/blob/c3064689/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/JobDescriptorDocument.java
----------------------------------------------------------------------
diff --git a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/JobDescriptorDocument.java b/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/JobDescriptorDocument.java
deleted file mode 100644
index 49563ae..0000000
--- a/modules/gfac/gfac-core/src/main/java/org/apache/airavata/gfac/core/x2012/x12/JobDescriptorDocument.java
+++ /dev/null
@@ -1,131 +0,0 @@
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/*
- * An XML document type.
- * Localname: JobDescriptor
- * Namespace: http://airavata.apache.org/gfac/core/2012/12
- * Java type: org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument
- *
- * Automatically generated - do not modify.
- */
-package org.apache.airavata.gfac.core.x2012.x12;
-
-
-/**
- * A document containing one JobDescriptor(@http://airavata.apache.org/gfac/core/2012/12) element.
- *
- * This is a complex type.
- */
-public interface JobDescriptorDocument extends org.apache.xmlbeans.XmlObject
-{
-    public static final org.apache.xmlbeans.SchemaType type = (org.apache.xmlbeans.SchemaType)
-        org.apache.xmlbeans.XmlBeans.typeSystemForClassLoader(JobDescriptorDocument.class.getClassLoader(), "schemaorg_apache_xmlbeans.system.sD070E302A2FC7CFEA0F2B3EB44FAE57D").resolveHandle("jobdescriptor217edoctype");
-    
-    /**
-     * Gets the "JobDescriptor" element
-     */
-    org.apache.airavata.gfac.core.x2012.x12.PbsParams getJobDescriptor();
-    
-    /**
-     * Sets the "JobDescriptor" element
-     */
-    void setJobDescriptor(org.apache.airavata.gfac.core.x2012.x12.PbsParams jobDescriptor);
-    
-    /**
-     * Appends and returns a new empty "JobDescriptor" element
-     */
-    org.apache.airavata.gfac.core.x2012.x12.PbsParams addNewJobDescriptor();
-    
-    /**
-     * A factory class with static methods for creating instances
-     * of this type.
-     */
-    
-    public static final class Factory
-    {
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument newInstance() {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument newInstance(org.apache.xmlbeans.XmlOptions options) {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newInstance( type, options ); }
-        
-        /** @param xmlAsString the string value to parse */
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.lang.String xmlAsString) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.lang.String xmlAsString, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xmlAsString, type, options ); }
-        
-        /** @param file the file from which to load an xml document */
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.io.File file) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.io.File file, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( file, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.net.URL u) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.net.URL u, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( u, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.io.InputStream is) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.io.InputStream is, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( is, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.io.Reader r) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(java.io.Reader r, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, java.io.IOException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( r, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(javax.xml.stream.XMLStreamReader sr) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(javax.xml.stream.XMLStreamReader sr, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( sr, type, options ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(org.w3c.dom.Node node) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, null ); }
-        
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(org.w3c.dom.Node node, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( node, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument parse(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return (org.apache.airavata.gfac.core.x2012.x12.JobDescriptorDocument) org.apache.xmlbeans.XmlBeans.getContextTypeLoader().parse( xis, type, options ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, null ); }
-        
-        /** @deprecated {@link org.apache.xmlbeans.xml.stream.XMLInputStream} */
-        public static org.apache.xmlbeans.xml.stream.XMLInputStream newValidatingXMLInputStream(org.apache.xmlbeans.xml.stream.XMLInputStream xis, org.apache.xmlbeans.XmlOptions options) throws org.apache.xmlbeans.XmlException, org.apache.xmlbeans.xml.stream.XMLStreamException {
-          return org.apache.xmlbeans.XmlBeans.getContextTypeLoader().newValidatingXMLInputStream( xis, type, options ); }
-        
-        private Factory() { } // No instance of this class allowed
-    }
-}