You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oodt.apache.org by ma...@apache.org on 2015/10/25 17:21:50 UTC

[05/16] oodt git commit: fix duplicate throws

fix duplicate throws


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

Branch: refs/heads/master
Commit: 178106052f4090a05501d743de71743214ed8592
Parents: 82400c1
Author: Tom Barber <to...@analytical-labs.com>
Authored: Sun Oct 25 15:43:01 2015 +0000
Committer: Tom Barber <to...@analytical-labs.com>
Committed: Sun Oct 25 15:43:01 2015 +0000

----------------------------------------------------------------------
 .../main/java/org/apache/oodt/commons/Configuration.java  |  2 +-
 .../java/org/apache/oodt/commons/ConfigurationTest.java   |  2 +-
 .../activity/DatagramLoggingActivityFactoryTest.java      |  2 +-
 .../oodt/cas/crawl/typedetection/MimeExtractorRepo.java   |  2 +-
 .../oodt/cas/curation/service/MetadataResource.java       | 10 +++++-----
 .../oodt/cas/curation/util/ExtractorConfigReader.java     |  2 +-
 .../oodt/cas/curation/util/ExtractorConfigWriter.java     |  2 +-
 .../filemgr/catalog/MappedDataSourceCatalogFactory.java   |  4 ++--
 .../apache/oodt/cas/filemgr/system/XmlRpcFileManager.java |  2 +-
 .../org/apache/oodt/cas/filemgr/tools/SolrIndexer.java    |  2 +-
 .../java/org/apache/oodt/cas/pge/PGETaskInstance.java     |  4 ++--
 .../oodt/cas/pge/config/XmlFilePgeConfigBuilder.java      |  2 +-
 .../main/java/org/apache/oodt/cas/pge/util/XmlHelper.java |  6 +++---
 .../oodt/profile/handlers/DatabaseProfileManager.java     |  2 +-
 .../apache/oodt/cas/protocol/http/util/TestHttpUtils.java |  6 +++---
 .../java/org/apache/oodt/cas/pushpull/config/Config.java  |  2 +-
 .../cas/pushpull/retrievalsystem/FileRetrievalSystem.java |  4 ++--
 .../oodt/cas/workflow/system/XmlRpcWorkflowManager.java   |  2 +-
 18 files changed, 29 insertions(+), 29 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/commons/src/main/java/org/apache/oodt/commons/Configuration.java
----------------------------------------------------------------------
diff --git a/commons/src/main/java/org/apache/oodt/commons/Configuration.java b/commons/src/main/java/org/apache/oodt/commons/Configuration.java
index e821628..740d810 100644
--- a/commons/src/main/java/org/apache/oodt/commons/Configuration.java
+++ b/commons/src/main/java/org/apache/oodt/commons/Configuration.java
@@ -72,7 +72,7 @@ public class Configuration {
 	  * @throws MalformedURLException If the URL specification is invalid.
 	  * @return An initialized configuration object.
 	  */
-	 public static Configuration getConfiguration() throws IOException, SAXException, MalformedURLException {
+	 public static Configuration getConfiguration() throws IOException, SAXException {
 		 // Got one?  Use it.
 		 if (configuration != null) return configuration;
 

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/commons/src/test/java/org/apache/oodt/commons/ConfigurationTest.java
----------------------------------------------------------------------
diff --git a/commons/src/test/java/org/apache/oodt/commons/ConfigurationTest.java b/commons/src/test/java/org/apache/oodt/commons/ConfigurationTest.java
index a90ee42..b37df44 100644
--- a/commons/src/test/java/org/apache/oodt/commons/ConfigurationTest.java
+++ b/commons/src/test/java/org/apache/oodt/commons/ConfigurationTest.java
@@ -53,7 +53,7 @@ public class ConfigurationTest extends TestCase {
 	}
 
 	/** Test the various property methods. */
-	public void testConfiguration() throws IOException, SAXException, MalformedURLException {
+	public void testConfiguration() throws IOException, SAXException {
 		Configuration c = new Configuration(tmpFile.toURL());
 		Properties props = new Properties();
 		props.setProperty("globalKey1", "preset-value");

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/commons/src/test/java/org/apache/oodt/commons/activity/DatagramLoggingActivityFactoryTest.java
----------------------------------------------------------------------
diff --git a/commons/src/test/java/org/apache/oodt/commons/activity/DatagramLoggingActivityFactoryTest.java b/commons/src/test/java/org/apache/oodt/commons/activity/DatagramLoggingActivityFactoryTest.java
index c49c9eb..e172843 100755
--- a/commons/src/test/java/org/apache/oodt/commons/activity/DatagramLoggingActivityFactoryTest.java
+++ b/commons/src/test/java/org/apache/oodt/commons/activity/DatagramLoggingActivityFactoryTest.java
@@ -109,7 +109,7 @@ public class DatagramLoggingActivityFactoryTest extends TestCase {
 	 * @throws IOException if an error occurs.
 	 * @throws ClassNotFoundException if an error occurs.
 	 */
-	public void testActivityReceipt() throws SocketException, IOException, ClassNotFoundException {
+	public void testActivityReceipt() throws IOException, ClassNotFoundException {
 		DatagramSocket socket = null;
 		try {
 			byte[] buf = new byte[512];

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/crawler/src/main/java/org/apache/oodt/cas/crawl/typedetection/MimeExtractorRepo.java
----------------------------------------------------------------------
diff --git a/crawler/src/main/java/org/apache/oodt/cas/crawl/typedetection/MimeExtractorRepo.java b/crawler/src/main/java/org/apache/oodt/cas/crawl/typedetection/MimeExtractorRepo.java
index 79c27ac..068d48f 100644
--- a/crawler/src/main/java/org/apache/oodt/cas/crawl/typedetection/MimeExtractorRepo.java
+++ b/crawler/src/main/java/org/apache/oodt/cas/crawl/typedetection/MimeExtractorRepo.java
@@ -124,7 +124,7 @@ public class MimeExtractorRepo {
 	}
 
 	public synchronized List<MetExtractorSpec> getExtractorSpecsForFile(
-			File file) throws FileNotFoundException, IOException {
+			File file) throws IOException {
 		String mimeType = this.mimeRepo.getMimeType(file);
 		if (mimeType == null && magic)
 			mimeType = this.mimeRepo.getMimeTypeByMagic(MimeTypeUtils

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/curator/services/src/main/java/org/apache/oodt/cas/curation/service/MetadataResource.java
----------------------------------------------------------------------
diff --git a/curator/services/src/main/java/org/apache/oodt/cas/curation/service/MetadataResource.java b/curator/services/src/main/java/org/apache/oodt/cas/curation/service/MetadataResource.java
index 7889906..3d3ec1a 100644
--- a/curator/services/src/main/java/org/apache/oodt/cas/curation/service/MetadataResource.java
+++ b/curator/services/src/main/java/org/apache/oodt/cas/curation/service/MetadataResource.java
@@ -210,7 +210,7 @@ public class MetadataResource extends CurationService {
    * @throws MetExtractionException
    */
   protected Metadata getStagingMetadata(String id, String configId,
-      Boolean overwrite) throws FileNotFoundException, InstantiationException,
+      Boolean overwrite) throws InstantiationException,
       IOException, MetExtractionException {
     if (configId == null || configId.trim().length() == 0) {
       return this.readMetFile(id + CurationService.config.getMetExtension());
@@ -450,7 +450,7 @@ public class MetadataResource extends CurationService {
    *           If there is an IO problem opening the met file.
    */
   public Metadata readMetFile(String file) throws InstantiationException,
-      FileNotFoundException, IOException {
+      IOException {
     SerializableMetadata metadata = new SerializableMetadata("UTF-8", false);
     metadata.loadMetadataFromXmlStream(new FileInputStream(config
         .getMetAreaPath()
@@ -489,7 +489,7 @@ public class MetadataResource extends CurationService {
    *           If there is an IO exception writing the {@link File}.
    */
   public void writeMetFile(String id, Metadata metadata)
-      throws FileNotFoundException, IOException {
+      throws IOException {
     SerializableMetadata serMet = new SerializableMetadata(metadata, "UTF-8",
         false);
     serMet.writeMetadataToXmlStream(new FileOutputStream(new File(config
@@ -596,7 +596,7 @@ public class MetadataResource extends CurationService {
    * @throws FileNotFoundException
    */
   public void updateCatalogMetadata(Product product, Metadata newMetadata)
-      throws CatalogException, FileNotFoundException, IOException {
+      throws CatalogException, IOException {
     System.getProperties().load(
         new FileInputStream(CurationService.config.getFileMgrProps()));
     Catalog catalog = this.getCatalog();
@@ -672,7 +672,7 @@ public class MetadataResource extends CurationService {
    *           If any error occurs during this delete operation.
    */
   public void deleteCatalogProduct(Product product) 
-  throws FileNotFoundException, IOException, CatalogException {
+  throws IOException, CatalogException {
 	  CurationService.config.getFileManagerClient().removeProduct(product);
   }  
 

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigReader.java
----------------------------------------------------------------------
diff --git a/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigReader.java b/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigReader.java
index 638b61b..33f73fa 100644
--- a/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigReader.java
+++ b/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigReader.java
@@ -31,7 +31,7 @@ import java.util.Properties;
 
 public class ExtractorConfigReader {
   public static ExtractorConfig readFromDirectory(File directory,
-      String configId) throws FileNotFoundException, IOException {
+      String configId) throws IOException {
     File propsFileDir = new File(directory, configId);
     Properties props = new Properties();
     props

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigWriter.java
----------------------------------------------------------------------
diff --git a/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigWriter.java b/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigWriter.java
index 5571c23..3a3a08e 100644
--- a/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigWriter.java
+++ b/curator/services/src/main/java/org/apache/oodt/cas/curation/util/ExtractorConfigWriter.java
@@ -30,7 +30,7 @@ import java.util.Iterator;
 public class ExtractorConfigWriter {
   
   public static void saveToDirectory(ExtractorConfig config, File dir)
-      throws FileNotFoundException, IOException {
+      throws IOException {
     Properties props = new Properties();
     props.setProperty(ExtractorConfig.PROP_CLASS_NAME, config.getClassName());
     File configDir = new File(dir, config.getIdentifier());

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/filemgr/src/main/java/org/apache/oodt/cas/filemgr/catalog/MappedDataSourceCatalogFactory.java
----------------------------------------------------------------------
diff --git a/filemgr/src/main/java/org/apache/oodt/cas/filemgr/catalog/MappedDataSourceCatalogFactory.java b/filemgr/src/main/java/org/apache/oodt/cas/filemgr/catalog/MappedDataSourceCatalogFactory.java
index ece146a..df3d1ff 100644
--- a/filemgr/src/main/java/org/apache/oodt/cas/filemgr/catalog/MappedDataSourceCatalogFactory.java
+++ b/filemgr/src/main/java/org/apache/oodt/cas/filemgr/catalog/MappedDataSourceCatalogFactory.java
@@ -47,8 +47,8 @@ public class MappedDataSourceCatalogFactory extends DataSourceCatalogFactory {
     private static final String TYPE_MAP_KEY = "org.apache.oodt.cas.filemgr."
             + "catalog.mappeddatasource.mapFile";
 
-    public MappedDataSourceCatalogFactory() throws FileNotFoundException,
-            IOException {
+    public MappedDataSourceCatalogFactory() throws
+        IOException {
         super();
         String mapFilePath = PathUtils.replaceEnvVariables(System
                 .getProperty(TYPE_MAP_KEY));

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/filemgr/src/main/java/org/apache/oodt/cas/filemgr/system/XmlRpcFileManager.java
----------------------------------------------------------------------
diff --git a/filemgr/src/main/java/org/apache/oodt/cas/filemgr/system/XmlRpcFileManager.java b/filemgr/src/main/java/org/apache/oodt/cas/filemgr/system/XmlRpcFileManager.java
index a003828..0adb7bf 100644
--- a/filemgr/src/main/java/org/apache/oodt/cas/filemgr/system/XmlRpcFileManager.java
+++ b/filemgr/src/main/java/org/apache/oodt/cas/filemgr/system/XmlRpcFileManager.java
@@ -1326,7 +1326,7 @@ public class XmlRpcFileManager {
     return pMet;
   }
     
-    private void loadConfiguration() throws FileNotFoundException, IOException {
+    private void loadConfiguration() throws IOException {
     // set up the configuration, if there is any
     if (System.getProperty("org.apache.oodt.cas.filemgr.properties") != null) {
       String configFile = System

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/filemgr/src/main/java/org/apache/oodt/cas/filemgr/tools/SolrIndexer.java
----------------------------------------------------------------------
diff --git a/filemgr/src/main/java/org/apache/oodt/cas/filemgr/tools/SolrIndexer.java b/filemgr/src/main/java/org/apache/oodt/cas/filemgr/tools/SolrIndexer.java
index 936fb1f..609b6af 100755
--- a/filemgr/src/main/java/org/apache/oodt/cas/filemgr/tools/SolrIndexer.java
+++ b/filemgr/src/main/java/org/apache/oodt/cas/filemgr/tools/SolrIndexer.java
@@ -204,7 +204,7 @@ public class SolrIndexer {
 	 *           When an error occurs communicating with the Solr server instance.
 	 */
 	public void indexMetFile(File file, boolean delete)
-	    throws InstantiationException, FileNotFoundException, IOException,
+	    throws InstantiationException, IOException,
 	    SolrServerException {
 		LOG.info("Attempting to index product from metadata file.");
 		try {

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/pge/src/main/java/org/apache/oodt/cas/pge/PGETaskInstance.java
----------------------------------------------------------------------
diff --git a/pge/src/main/java/org/apache/oodt/cas/pge/PGETaskInstance.java b/pge/src/main/java/org/apache/oodt/cas/pge/PGETaskInstance.java
index da410a6..108892c 100644
--- a/pge/src/main/java/org/apache/oodt/cas/pge/PGETaskInstance.java
+++ b/pge/src/main/java/org/apache/oodt/cas/pge/PGETaskInstance.java
@@ -447,7 +447,7 @@ public class PGETaskInstance implements WorkflowTaskInstance {
       return returnCode == 0;
    }
    
-   protected void processOutput() throws FileNotFoundException, IOException {
+   protected void processOutput() throws IOException {
      for (final OutputDir outputDir : this.pgeConfig.getOuputDirs()) {
          File[] createdFiles = new File(outputDir.getPath()).listFiles();
          for (File createdFile : createdFiles) {
@@ -493,7 +493,7 @@ public class PGETaskInstance implements WorkflowTaskInstance {
 	}
 
 	protected void writeFromMetadata(Metadata metadata, String toMetFilePath)
-			throws FileNotFoundException, IOException {
+			throws IOException {
 		new SerializableMetadata(metadata, "UTF-8", false)
 				.writeMetadataToXmlStream(new FileOutputStream(toMetFilePath));
 	}

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/pge/src/main/java/org/apache/oodt/cas/pge/config/XmlFilePgeConfigBuilder.java
----------------------------------------------------------------------
diff --git a/pge/src/main/java/org/apache/oodt/cas/pge/config/XmlFilePgeConfigBuilder.java b/pge/src/main/java/org/apache/oodt/cas/pge/config/XmlFilePgeConfigBuilder.java
index cd518e3..bcf1be2 100644
--- a/pge/src/main/java/org/apache/oodt/cas/pge/config/XmlFilePgeConfigBuilder.java
+++ b/pge/src/main/java/org/apache/oodt/cas/pge/config/XmlFilePgeConfigBuilder.java
@@ -148,7 +148,7 @@ public class XmlFilePgeConfigBuilder implements PgeConfigBuilder {
    }
 
    private void loadCustomMetadata(Element root, PgeMetadata pgeMetadata)
-         throws MalformedURLException, Exception {
+         throws Exception {
 
       // Check if there is a 'customMetadata' elem and load it.
       Element customMetadataElem = getCustomMetadataElement(root);

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/pge/src/main/java/org/apache/oodt/cas/pge/util/XmlHelper.java
----------------------------------------------------------------------
diff --git a/pge/src/main/java/org/apache/oodt/cas/pge/util/XmlHelper.java b/pge/src/main/java/org/apache/oodt/cas/pge/util/XmlHelper.java
index eb52905..532e607 100644
--- a/pge/src/main/java/org/apache/oodt/cas/pge/util/XmlHelper.java
+++ b/pge/src/main/java/org/apache/oodt/cas/pge/util/XmlHelper.java
@@ -333,17 +333,17 @@ public class XmlHelper {
 	}
 
 	public static String getDir(Element elem, Metadata metadata)
-			throws MalformedURLException, Exception {
+			throws Exception {
 		return fillIn(elem.getAttribute(DIR_ATTR), metadata);
 	}
 
 	public static String getShellType(Element elem, Metadata metadata)
-			throws MalformedURLException, Exception {
+			throws Exception {
 		return fillIn(elem.getAttribute(SHELL_TYPE_ATTR), metadata);
 	}
 
 	public static List<String> getExeCmds(Element elem, Metadata metadata)
-			throws MalformedURLException, DOMException, Exception {
+			throws Exception {
 		List<String> exeCmds = Lists.newArrayList();
 		NodeList nodeList = elem.getElementsByTagName(CMD_TAG);
 		for (int i = 0; i < nodeList.getLength(); i++) {

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/profile/src/main/java/org/apache/oodt/profile/handlers/DatabaseProfileManager.java
----------------------------------------------------------------------
diff --git a/profile/src/main/java/org/apache/oodt/profile/handlers/DatabaseProfileManager.java b/profile/src/main/java/org/apache/oodt/profile/handlers/DatabaseProfileManager.java
index af95a44..f2b1eb4 100755
--- a/profile/src/main/java/org/apache/oodt/profile/handlers/DatabaseProfileManager.java
+++ b/profile/src/main/java/org/apache/oodt/profile/handlers/DatabaseProfileManager.java
@@ -77,7 +77,7 @@ public abstract class DatabaseProfileManager implements ProfileManager
     	 **
     	***********************************************************************/	
 
-    	public DatabaseProfileManager(Properties props) throws SQLException, Exception {
+    	public DatabaseProfileManager(Properties props) throws Exception {
 		this(props, openConnection(props));
     	}
 

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/protocol/http/src/test/java/org/apache/oodt/cas/protocol/http/util/TestHttpUtils.java
----------------------------------------------------------------------
diff --git a/protocol/http/src/test/java/org/apache/oodt/cas/protocol/http/util/TestHttpUtils.java b/protocol/http/src/test/java/org/apache/oodt/cas/protocol/http/util/TestHttpUtils.java
index 67903ec..a6a16dc 100644
--- a/protocol/http/src/test/java/org/apache/oodt/cas/protocol/http/util/TestHttpUtils.java
+++ b/protocol/http/src/test/java/org/apache/oodt/cas/protocol/http/util/TestHttpUtils.java
@@ -62,7 +62,7 @@ public class TestHttpUtils extends TestCase {
 		assertEquals("http://localhost/base/directory/path/to/file", resolvedRelativeUri.toString());
 	}
 	
-	public void testConnectUrl() throws MalformedURLException, IOException {
+	public void testConnectUrl() throws IOException {
 		HttpURLConnection conn = HttpUtils.connect(new URL(APACHE_SVN_SITE + URL_OF_THIS_TEST));
 		assertNotSame(0, conn.getDate());
 		String urlText = HttpUtils.readUrl(conn);
@@ -150,7 +150,7 @@ public class TestHttpUtils extends TestCase {
 		assertFalse(matcher.find());
 	}
 	
-	public void testFindLinks() throws MalformedURLException, IOException, URISyntaxException {
+	public void testFindLinks() throws IOException, URISyntaxException {
 		URL url = new URL(APACHE_SVN_SITE + PARENT_URL_OF_THIS_TEST);
 		HttpFile parent = new HttpFile(PARENT_URL_OF_THIS_TEST, true, url);
 		HttpURLConnection conn = HttpUtils.connect(url);
@@ -165,7 +165,7 @@ public class TestHttpUtils extends TestCase {
 		assertTrue(foundThisTest);
 	}
 	
-	public void testIsDirectory() throws MalformedURLException, IOException {
+	public void testIsDirectory() throws IOException {
 		assertTrue(HttpUtils.isDirectory(new URL(APACHE_SVN_SITE + PARENT_URL_OF_THIS_TEST), ""));
 		assertFalse(HttpUtils.isDirectory(new URL(APACHE_SVN_SITE + URL_OF_THIS_TEST), ""));
 		assertTrue(HttpUtils.isDirectory(new URL(APACHE_SVN_SITE), ""));

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/pushpull/src/main/java/org/apache/oodt/cas/pushpull/config/Config.java
----------------------------------------------------------------------
diff --git a/pushpull/src/main/java/org/apache/oodt/cas/pushpull/config/Config.java b/pushpull/src/main/java/org/apache/oodt/cas/pushpull/config/Config.java
index a83a3ce..ddf35de 100644
--- a/pushpull/src/main/java/org/apache/oodt/cas/pushpull/config/Config.java
+++ b/pushpull/src/main/java/org/apache/oodt/cas/pushpull/config/Config.java
@@ -174,7 +174,7 @@ public class Config implements ConfigMetKeys {
      * @throws ClassNotFoundException
      */
     void loadProperties() throws ConfigException, InstantiationException,
-            FileNotFoundException, IOException, ClassNotFoundException {
+        IOException, ClassNotFoundException {
         this.loadExternalConfigFiles();
         this.loadProtocolTypes();
         this.loadParserInfo();

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/pushpull/src/main/java/org/apache/oodt/cas/pushpull/retrievalsystem/FileRetrievalSystem.java
----------------------------------------------------------------------
diff --git a/pushpull/src/main/java/org/apache/oodt/cas/pushpull/retrievalsystem/FileRetrievalSystem.java b/pushpull/src/main/java/org/apache/oodt/cas/pushpull/retrievalsystem/FileRetrievalSystem.java
index 8c7bf65..4dcaf97 100644
--- a/pushpull/src/main/java/org/apache/oodt/cas/pushpull/retrievalsystem/FileRetrievalSystem.java
+++ b/pushpull/src/main/java/org/apache/oodt/cas/pushpull/retrievalsystem/FileRetrievalSystem.java
@@ -276,8 +276,8 @@ public class FileRetrievalSystem {
                 + dir);
     }
 
-    public void changeToRoot(RemoteSite remoteSite) throws ProtocolException,
-            MalformedURLException, org.apache.oodt.cas.protocol.exceptions.ProtocolException {
+    public void changeToRoot(RemoteSite remoteSite) throws
+        MalformedURLException, org.apache.oodt.cas.protocol.exceptions.ProtocolException {
         if (validate(remoteSite))
             protocolHandler.cdToROOT(protocolHandler
                     .getAppropriateProtocolBySite(remoteSite, true));

http://git-wip-us.apache.org/repos/asf/oodt/blob/17810605/workflow/src/main/java/org/apache/oodt/cas/workflow/system/XmlRpcWorkflowManager.java
----------------------------------------------------------------------
diff --git a/workflow/src/main/java/org/apache/oodt/cas/workflow/system/XmlRpcWorkflowManager.java b/workflow/src/main/java/org/apache/oodt/cas/workflow/system/XmlRpcWorkflowManager.java
index 7e7d732..8945059 100644
--- a/workflow/src/main/java/org/apache/oodt/cas/workflow/system/XmlRpcWorkflowManager.java
+++ b/workflow/src/main/java/org/apache/oodt/cas/workflow/system/XmlRpcWorkflowManager.java
@@ -624,7 +624,7 @@ public class XmlRpcWorkflowManager {
             }
     }
 
-    public static void loadProperties() throws FileNotFoundException, IOException {
+    public static void loadProperties() throws IOException {
        String configFile = System.getProperty(PROPERTIES_FILE_PROPERTY);
        if (configFile != null) {
           LOG.log(Level.INFO,