You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airavata.apache.org by sm...@apache.org on 2011/08/05 19:34:26 UTC

svn commit: r1154324 - in /incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type: ./ app/ host/

Author: smarru
Date: Fri Aug  5 17:34:26 2011
New Revision: 1154324

URL: http://svn.apache.org/viewvc?rev=1154324&view=rev
Log:
fixed the duplicated created by earlier commit to fix AIRAVATA-70

Modified:
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ApplicationDeploymentDescription.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/DataType.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/HostDescription.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Parameter.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ServiceDescription.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Type.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/GramApplicationDeployment.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/ShellApplicationDeployment.java
    incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/host/GlobusHost.java

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ApplicationDeploymentDescription.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ApplicationDeploymentDescription.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ApplicationDeploymentDescription.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ApplicationDeploymentDescription.java Fri Aug  5 17:34:26 2011
@@ -67,102 +67,5 @@ public class ApplicationDeploymentDescri
 
     public void setOutputDir(String outputDir) {
         this.outputDir = outputDir;
-    }
-
-    public String getTypeName() {
-		return "HostDescption";
-	}
-
-	public void fromString(String val) {
-		// TODO Auto-generated method stub
-	}
-	
-	public String writeToString(){
-		return "HostDescption";
-	}
-
-}
-/*
- *
- * 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.core.gfac.type;
-
-public class ApplicationDeploymentDescription implements Type {
-
-	private String name;
-	private String tmpDir;
-	private String workingDir;
-	private String inputDir;
-	private String outputDir;
-	
-	public String getName() {
-        return name;
-    }
-
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    public String getTmpDir() {
-        return tmpDir;
-    }
-
-    public void setTmpDir(String tmpDir) {
-        this.tmpDir = tmpDir;
-    }
-
-    public String getWorkingDir() {
-        return workingDir;
-    }
-
-    public void setWorkingDir(String workingDir) {
-        this.workingDir = workingDir;
-    }
-
-    public String getInputDir() {
-        return inputDir;
-    }
-
-    public void setInputDir(String inputDir) {
-        this.inputDir = inputDir;
-    }
-
-    public String getOutputDir() {
-        return outputDir;
-    }
-
-    public void setOutputDir(String outputDir) {
-        this.outputDir = outputDir;
-    }
-
-    public String getTypeName() {
-		return "HostDescption";
-	}
-
-	public void fromString(String val) {
-		// TODO Auto-generated method stub
-	}
-	
-	public String writeToString(){
-		return "HostDescption";
-	}
-
+    }    
 }

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/DataType.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/DataType.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/DataType.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/DataType.java Fri Aug  5 17:34:26 2011
@@ -22,29 +22,4 @@
 package org.apache.airavata.core.gfac.type;
 
 public interface DataType extends Type{	
-}
-/*
- *
- * 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.core.gfac.type;
-
-public interface DataType extends Type{	
-}
+}
\ No newline at end of file

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/HostDescription.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/HostDescription.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/HostDescription.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/HostDescription.java Fri Aug  5 17:34:26 2011
@@ -31,38 +31,4 @@ public class HostDescription implements 
     public void setName(String name) {
         this.name = name;
     }
-}
-/*
- *
- * 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.core.gfac.type;
-
-public class HostDescription implements Type {
-
-    private String name;
-
-    public String getName() {
-        return name;
-    }
-    public void setName(String name) {
-        this.name = name;
-    }
-}
+}
\ No newline at end of file

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Parameter.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Parameter.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Parameter.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Parameter.java Fri Aug  5 17:34:26 2011
@@ -37,44 +37,4 @@ public class Parameter implements Type{
     public void setType(DataType type) {
         this.type = type;
     }    
-}
-/*
- *
- * 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.core.gfac.type;
-
-public class Parameter implements Type{
-    private String name;
-    private DataType type;
-    
-    public String getName() {
-        return name;
-    }
-    public void setName(String name) {
-        this.name = name;
-    }
-    public DataType getType() {
-        return type;
-    }
-    public void setType(DataType type) {
-        this.type = type;
-    }    
-}
+}
\ No newline at end of file

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ServiceDescription.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ServiceDescription.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ServiceDescription.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/ServiceDescription.java Fri Aug  5 17:34:26 2011
@@ -53,58 +53,3 @@ public class ServiceDescription implemen
         this.outputParameters = outputParameters;
     }
 }
-/*
- *
- * 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.core.gfac.type;
-
-import java.util.List;
-
-public class ServiceDescription implements Type {
-
-	private String name;
-	private List<Parameter> inputParameters;
-	private List<Parameter> outputParameters;	
-	
-	public String getName() {
-        return name;
-    }
-
-    public void setName(String name) {
-        this.name = name;
-    }
-
-    public List<Parameter> getInputParameters() {
-        return inputParameters;
-    }
-
-    public void setInputParameters(List<Parameter> inputParameters) {
-        this.inputParameters = inputParameters;
-    }
-
-    public List<Parameter> getOutputParameters() {
-        return outputParameters;
-    }
-
-    public void setOutputParameters(List<Parameter> outputParameters) {
-        this.outputParameters = outputParameters;
-    }
-}

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Type.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Type.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Type.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/Type.java Fri Aug  5 17:34:26 2011
@@ -25,30 +25,3 @@ import java.io.Serializable;
 
 public interface Type extends Serializable{
 }
-/*
- *
- * 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.core.gfac.type;
-
-import java.io.Serializable;
-
-public interface Type extends Serializable{
-}

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/GramApplicationDeployment.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/GramApplicationDeployment.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/GramApplicationDeployment.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/GramApplicationDeployment.java Fri Aug  5 17:34:26 2011
@@ -57,70 +57,5 @@ public class GramApplicationDeployment e
     }
     public void setCpuCount(int cpuCount) {
         this.cpuCount = cpuCount;
-    }
-    
-    
-}
-/*
- *
- * 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.core.gfac.type.app;
-
-public class GramApplicationDeployment extends ShellApplicationDeployment {
-    private String projectName;
-    private String queueName;
-    private int wallTime;
-    private int nodeCount;
-    private int cpuCount;
-    
-    public String getProjectName() {
-        return projectName;
-    }
-    public void setProjectName(String projectName) {
-        this.projectName = projectName;
-    }
-    public String getQueueName() {
-        return queueName;
-    }
-    public void setQueueName(String queueName) {
-        this.queueName = queueName;
-    }
-    public int getWallTime() {
-        return wallTime;
-    }
-    public void setWallTime(int wallTime) {
-        this.wallTime = wallTime;
-    }
-    public int getNodeCount() {
-        return nodeCount;
-    }
-    public void setNodeCount(int nodeCount) {
-        this.nodeCount = nodeCount;
-    }
-    public int getCpuCount() {
-        return cpuCount;
-    }
-    public void setCpuCount(int cpuCount) {
-        this.cpuCount = cpuCount;
-    }
-    
-    
+    }   
 }

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/ShellApplicationDeployment.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/ShellApplicationDeployment.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/ShellApplicationDeployment.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/app/ShellApplicationDeployment.java Fri Aug  5 17:34:26 2011
@@ -72,77 +72,3 @@ public class ShellApplicationDeployment 
         this.stdIn = stdIn;
     }    
 }
-/*
- *
- * 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.core.gfac.type.app;
-
-import java.util.Map;
-
-import org.apache.airavata.core.gfac.type.ApplicationDeploymentDescription;
-
-public class ShellApplicationDeployment extends ApplicationDeploymentDescription {    
-    private String executable;
-    private String stdOut;
-    private String stdErr;
-    private String stdIn;
-    private Map<String, String> env;
-    
-    public String getExecutable() {
-        return executable;
-    }
-
-    public void setExecutable(String executable) {
-        this.executable = executable;
-    }
-
-    public Map<String, String> getEnv() {
-        return env;
-    }
-
-    public void setEnv(Map<String, String> env) {
-        this.env = env;
-    }
-
-    public String getStdOut() {
-        return stdOut;
-    }
-
-    public void setStdOut(String stdOut) {
-        this.stdOut = stdOut;
-    }
-
-    public String getStdErr() {
-        return stdErr;
-    }
-
-    public void setStdErr(String stderr) {
-        this.stdErr = stderr;
-    }
-
-    public String getStdIn() {
-        return stdIn;
-    }
-
-    public void setStdIn(String stdIn) {
-        this.stdIn = stdIn;
-    }    
-}

Modified: incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/host/GlobusHost.java
URL: http://svn.apache.org/viewvc/incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/host/GlobusHost.java?rev=1154324&r1=1154323&r2=1154324&view=diff
==============================================================================
--- incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/host/GlobusHost.java (original)
+++ incubator/airavata/trunk/modules/commons/gfac-schema/src/main/java/org/apache/airavata/core/gfac/type/host/GlobusHost.java Fri Aug  5 17:34:26 2011
@@ -32,43 +32,5 @@ public class GlobusHost extends HostDesc
 
     public void setGridFTPEndPoint(String gridFTPEndPoint) {
         this.gridFTPEndPoint = gridFTPEndPoint;
-    }
-    
-}
-/*
- *
- * 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.core.gfac.type.host;
-
-import org.apache.airavata.core.gfac.type.HostDescription;
-
-public class GlobusHost extends HostDescription {
-    private String gridFTPEndPoint;
-
-    public String getGridFTPEndPoint() {
-        return gridFTPEndPoint;
-    }
-
-    public void setGridFTPEndPoint(String gridFTPEndPoint) {
-        this.gridFTPEndPoint = gridFTPEndPoint;
-    }
-    
-}
+    }   
+}
\ No newline at end of file