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/11/05 19:57:22 UTC

[2/2] oodt git commit: OODT-917 tests for WM to validate XMLRPC interface

OODT-917 tests for WM to validate XMLRPC interface


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

Branch: refs/heads/master
Commit: 538c0d6babead00cc383b87204f4919d162b26f1
Parents: 684adae
Author: Tom Barber <to...@analytical-labs.com>
Authored: Thu Nov 5 18:56:22 2015 +0000
Committer: Tom Barber <to...@analytical-labs.com>
Committed: Thu Nov 5 18:56:22 2015 +0000

----------------------------------------------------------------------
 .../system/TestXmlRpcResourceManagerClient.java |   21 +-
 .../workflow/system/XmlRpcWorkflowManager.java  | 1052 +++++++++---------
 .../system/TestXmlRpcWorkflowManagerClient.java |   50 +-
 3 files changed, 568 insertions(+), 555 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oodt/blob/538c0d6b/resource/src/test/java/org/apache/oodt/cas/resource/system/TestXmlRpcResourceManagerClient.java
----------------------------------------------------------------------
diff --git a/resource/src/test/java/org/apache/oodt/cas/resource/system/TestXmlRpcResourceManagerClient.java b/resource/src/test/java/org/apache/oodt/cas/resource/system/TestXmlRpcResourceManagerClient.java
index dce1094..cef79e4 100644
--- a/resource/src/test/java/org/apache/oodt/cas/resource/system/TestXmlRpcResourceManagerClient.java
+++ b/resource/src/test/java/org/apache/oodt/cas/resource/system/TestXmlRpcResourceManagerClient.java
@@ -1,3 +1,16 @@
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.oodt.cas.resource.system;
 
 import org.apache.commons.io.FileUtils;
@@ -26,20 +39,18 @@ import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.fail;
 
 /**
- * Created by bugg on 05/11/15.
+ * Tests for the XmlRpcResourceManagerClient to ensure communications between client and server operate correctly.
  */
 public class TestXmlRpcResourceManagerClient {
 
   private static final int RM_PORT = 50001;
 
-  private static XmlRpcResourceManager rm;
-  private static File thetmpPolicyDir;
   private static XmlRpcResourceManagerClient rmc;
 
   @BeforeClass
   public static void setUp() throws Exception {
     generateTestConfiguration();
-    rm = new XmlRpcResourceManager(RM_PORT);
+    XmlRpcResourceManager rm = new XmlRpcResourceManager(RM_PORT);
     rmc = new XmlRpcResourceManagerClient(new URL("http://localhost:" +RM_PORT));
 
   }
@@ -79,7 +90,7 @@ public class TestXmlRpcResourceManagerClient {
         tmpPolicyDir.toURI().toString());
 
     System.getProperties().putAll(config);
-    thetmpPolicyDir = tmpPolicyDir;
+
   }
 
   @Test

http://git-wip-us.apache.org/repos/asf/oodt/blob/538c0d6b/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 a733204..0256602 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
@@ -42,8 +42,8 @@ import java.net.MalformedURLException;
 import java.net.URL;
 import java.net.UnknownHostException;
 import java.util.Hashtable;
-import java.util.Map;
 import java.util.List;
+import java.util.Map;
 import java.util.Vector;
 import java.util.logging.Level;
 import java.util.logging.Logger;
@@ -59,55 +59,55 @@ import static org.apache.oodt.cas.workflow.util.GenericWorkflowObjectFactory.get
  */
 public class XmlRpcWorkflowManager {
 
-   private static final Logger LOG = Logger.getLogger(XmlRpcWorkflowManager.class.getName());
+  private static final Logger LOG = Logger.getLogger(XmlRpcWorkflowManager.class.getName());
 
-   public static final int DEFAULT_WEB_SERVER_PORT = 9001;
-   public static final String XML_RPC_HANDLER_NAME = "workflowmgr";
+  public static final int DEFAULT_WEB_SERVER_PORT = 9001;
+  public static final String XML_RPC_HANDLER_NAME = "workflowmgr";
 
-   public static final String PROPERTIES_FILE_PROPERTY = "org.apache.oodt.cas.workflow.properties";
-   public static final String WORKFLOW_ENGINE_FACTORY_PROPERTY = "workflow.engine.factory";
-   public static final String ENGINE_RUNNER_FACTORY_PROPERTY = "workflow.engine.runner.factory";
-   public static final String WORKFLOW_REPOSITORY_FACTORY_PROPERTY = "workflow.repo.factory";
+  public static final String PROPERTIES_FILE_PROPERTY = "org.apache.oodt.cas.workflow.properties";
+  public static final String WORKFLOW_ENGINE_FACTORY_PROPERTY = "workflow.engine.factory";
+  public static final String ENGINE_RUNNER_FACTORY_PROPERTY = "workflow.engine.runner.factory";
+  public static final String WORKFLOW_REPOSITORY_FACTORY_PROPERTY = "workflow.repo.factory";
 
   private WebServer webServer;
-   private final WorkflowEngine engine;
-   private WorkflowRepository repo;
-
-   public XmlRpcWorkflowManager() {
-      this(DEFAULT_WEB_SERVER_PORT);
-   }
-
-   public XmlRpcWorkflowManager(int port) {
-      Preconditions.checkArgument(port > 0, "Must specify a port greater than 0");
-
-     engine = getWorkflowEngineFromProperty();
-      engine.setWorkflowManagerUrl(safeGetUrlFromString("http://"
-            + getHostname() + ":" + port));
-      repo = getWorkflowRepositoryFromProperty();
-
-      // start up the web server
-      webServer = new WebServer(port);
-      webServer.addHandler(XML_RPC_HANDLER_NAME, this);
-      webServer.start();
-
-      LOG.log(Level.INFO, "Workflow Manager started by "
-            + System.getProperty("user.name", "unknown"));
-   }
-
-   public boolean shutdown() {
-      if (webServer != null) {
-         webServer.shutdown();
-         webServer = null;
-         return true;
-      } else {
-        return false;
-      }
-   }
+  private final WorkflowEngine engine;
+  private WorkflowRepository repo;
+
+  public XmlRpcWorkflowManager() {
+    this(DEFAULT_WEB_SERVER_PORT);
+  }
+
+  public XmlRpcWorkflowManager(int port) {
+    Preconditions.checkArgument(port > 0, "Must specify a port greater than 0");
+
+    engine = getWorkflowEngineFromProperty();
+    engine.setWorkflowManagerUrl(safeGetUrlFromString("http://"
+                                                      + getHostname() + ":" + port));
+    repo = getWorkflowRepositoryFromProperty();
+
+    // start up the web server
+    webServer = new WebServer(port);
+    webServer.addHandler(XML_RPC_HANDLER_NAME, this);
+    webServer.start();
+
+    LOG.log(Level.INFO, "Workflow Manager started by "
+                        + System.getProperty("user.name", "unknown"));
+  }
+
+  public boolean shutdown() {
+    if (webServer != null) {
+      webServer.shutdown();
+      webServer = null;
+      return true;
+    } else {
+      return false;
+    }
+  }
 
-   public boolean refreshRepository() {
-     repo = getWorkflowRepositoryFromProperty();
-     return true;
-   }
+  public boolean refreshRepository() {
+    repo = getWorkflowRepositoryFromProperty();
+    return true;
+  }
 
   public String executeDynamicWorkflow(Vector<String> taskIds, Hashtable metadata)
       throws RepositoryException, EngineException {
@@ -142,596 +142,600 @@ public class XmlRpcWorkflowManager {
     return inst.getId();
   }
 
-    public List getRegisteredEvents() throws RepositoryException {
-
-        List events;
-        Vector eventsVector = new Vector();
+  public List getRegisteredEvents() throws RepositoryException {
 
-        try {
-            events = repo.getRegisteredEvents();
+    List events;
+    Vector eventsVector = new Vector();
 
-            if (events != null) {
-              for (Object event : events) {
-                eventsVector.add(event);
-              }
+    try {
+      events = repo.getRegisteredEvents();
 
-            }
+      if (events != null) {
+        for (Object event : events) {
+          eventsVector.add(event);
+        }
 
-            return eventsVector;
+      }
 
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            throw new RepositoryException(
-                    "Exception getting registered events from repository: Message: "
-                            + e.getMessage());
-        }
+      return eventsVector;
 
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      throw new RepositoryException(
+          "Exception getting registered events from repository: Message: "
+          + e.getMessage());
     }
 
-    public Map getFirstPage() {
-    	WorkflowInstancePage page = engine.getInstanceRepository()
-                .getFirstPage();
-        if (page != null) {
-            populateWorkflows(page.getPageWorkflows());
-            return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
-        } else {
-          return XmlRpcStructFactory
-              .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
-                  .blankPage());
-        }
+  }
+
+  public Map getFirstPage() {
+    WorkflowInstancePage page = engine.getInstanceRepository()
+                                      .getFirstPage();
+    if (page != null) {
+      populateWorkflows(page.getPageWorkflows());
+      return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
+    } else {
+      return XmlRpcStructFactory
+          .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
+              .blankPage());
     }
+  }
 
   public Map getNextPage(Hashtable currentPage) {
     return this.getNextPageCore(currentPage);
   }
-    public Map getNextPageCore(Map currentPage) {
-        // first unpack current page
-        WorkflowInstancePage currPage = XmlRpcStructFactory
-                .getWorkflowInstancePageFromXmlRpc(currentPage);
-        WorkflowInstancePage page = engine.getInstanceRepository().getNextPage(
-                currPage);
-        if (page != null) {
-            populateWorkflows(page.getPageWorkflows());
-            return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
-        } else {
-          return XmlRpcStructFactory
-              .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
-                  .blankPage());
-        }
+
+  public Map getNextPageCore(Map currentPage) {
+    // first unpack current page
+    WorkflowInstancePage currPage = XmlRpcStructFactory
+        .getWorkflowInstancePageFromXmlRpc(currentPage);
+    WorkflowInstancePage page = engine.getInstanceRepository().getNextPage(
+        currPage);
+    if (page != null) {
+      populateWorkflows(page.getPageWorkflows());
+      return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
+    } else {
+      return XmlRpcStructFactory
+          .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
+              .blankPage());
     }
+  }
 
   public Map getPrevPage(Hashtable currentPage) {
     return this.getNextPageCore(currentPage);
   }
 
-    public Map getPrevPageCore(Map currentPage) {
-        // first unpack current page
-        WorkflowInstancePage currPage = XmlRpcStructFactory
-                .getWorkflowInstancePageFromXmlRpc(currentPage);
-        WorkflowInstancePage page = engine.getInstanceRepository().getPrevPage(
-                currPage);
-        if (page != null) {
-            populateWorkflows(page.getPageWorkflows());
-            return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
-        } else {
-          return XmlRpcStructFactory
-              .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
-                  .blankPage());
-        }
+  public Map getPrevPageCore(Map currentPage) {
+    // first unpack current page
+    WorkflowInstancePage currPage = XmlRpcStructFactory
+        .getWorkflowInstancePageFromXmlRpc(currentPage);
+    WorkflowInstancePage page = engine.getInstanceRepository().getPrevPage(
+        currPage);
+    if (page != null) {
+      populateWorkflows(page.getPageWorkflows());
+      return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
+    } else {
+      return XmlRpcStructFactory
+          .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
+              .blankPage());
     }
+  }
 
-    public Map getLastPage() {
-        WorkflowInstancePage page = engine.getInstanceRepository()
-                .getLastPage();
-        if (page != null) {
-            populateWorkflows(page.getPageWorkflows());
-            return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
-        } else {
-          return XmlRpcStructFactory
-              .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
-                  .blankPage());
-        }
+  public Map getLastPage() {
+    WorkflowInstancePage page = engine.getInstanceRepository()
+                                      .getLastPage();
+    if (page != null) {
+      populateWorkflows(page.getPageWorkflows());
+      return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
+    } else {
+      return XmlRpcStructFactory
+          .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
+              .blankPage());
     }
+  }
 
-    public Map paginateWorkflowInstances(int pageNum, String status)
-            throws InstanceRepositoryException {
-        WorkflowInstancePage page = engine.getInstanceRepository()
-                .getPagedWorkflows(pageNum, status);
-        if (page != null) {
-            populateWorkflows(page.getPageWorkflows());
-            return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
-        } else {
-          return XmlRpcStructFactory
-              .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
-                  .blankPage());
-        }
-
+  public Map paginateWorkflowInstances(int pageNum, String status)
+      throws InstanceRepositoryException {
+    WorkflowInstancePage page = engine.getInstanceRepository()
+                                      .getPagedWorkflows(pageNum, status);
+    if (page != null) {
+      populateWorkflows(page.getPageWorkflows());
+      return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
+    } else {
+      return XmlRpcStructFactory
+          .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
+              .blankPage());
     }
 
-    public Map paginateWorkflowInstances(int pageNum)
-            throws InstanceRepositoryException {
-        WorkflowInstancePage page = engine.getInstanceRepository()
-                .getPagedWorkflows(pageNum);
-        if (page != null) {
-            populateWorkflows(page.getPageWorkflows());
-            return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
-        } else {
-          return XmlRpcStructFactory
-              .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
-                  .blankPage());
-        }
-    }
+  }
 
-    public Map getWorkflowInstanceMetadata(String wInstId) {
-        Metadata met = engine.getWorkflowInstanceMetadata(wInstId);
-        return met.getHashTable();
+  public Map paginateWorkflowInstances(int pageNum)
+      throws InstanceRepositoryException {
+    WorkflowInstancePage page = engine.getInstanceRepository()
+                                      .getPagedWorkflows(pageNum);
+    if (page != null) {
+      populateWorkflows(page.getPageWorkflows());
+      return XmlRpcStructFactory.getXmlRpcWorkflowInstancePage(page);
+    } else {
+      return XmlRpcStructFactory
+          .getXmlRpcWorkflowInstancePage(WorkflowInstancePage
+              .blankPage());
     }
+  }
 
-    public List getWorkflowsByEvent(String eventName)
-            throws RepositoryException {
-        List workflows;
-        Vector workflowList = new Vector();
+  public Map getWorkflowInstanceMetadata(String wInstId) {
+    Metadata met = engine.getWorkflowInstanceMetadata(wInstId);
+    return met.getHashTable();
+  }
 
-        try {
-            workflows = repo.getWorkflowsForEvent(eventName);
-
-            if (workflows != null) {
-              for (Object workflow1 : workflows) {
-                Workflow w = (Workflow) workflow1;
-                Map workflow = XmlRpcStructFactory
-                    .getXmlRpcWorkflow(w);
-                workflowList.add(workflow);
-              }
-            }
+  public List getWorkflowsByEvent(String eventName)
+      throws RepositoryException {
+    List workflows;
+    Vector workflowList = new Vector();
 
-            return workflowList;
+    try {
+      workflows = repo.getWorkflowsForEvent(eventName);
 
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            throw new RepositoryException(
-                    "Exception getting workflows for event: " + eventName
-                            + " from repository: Message: " + e.getMessage());
+      if (workflows != null) {
+        for (Object workflow1 : workflows) {
+          Workflow w = (Workflow) workflow1;
+          Map workflow = XmlRpcStructFactory
+              .getXmlRpcWorkflow(w);
+          workflowList.add(workflow);
         }
+      }
+
+      return workflowList;
+
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      throw new RepositoryException(
+          "Exception getting workflows for event: " + eventName
+          + " from repository: Message: " + e.getMessage());
     }
+  }
+
   public boolean handleEvent(String eventName, Hashtable metadata)
       throws RepositoryException, EngineException {
     return this.handleEventCore(eventName, metadata);
   }
-    public boolean handleEventCore(String eventName, Map metadata)
-            throws RepositoryException, EngineException {
-        LOG.log(Level.INFO, "WorkflowManager: Received event: " + eventName);
 
-        List workflows;
+  public boolean handleEventCore(String eventName, Map metadata)
+      throws RepositoryException, EngineException {
+    LOG.log(Level.INFO, "WorkflowManager: Received event: " + eventName);
 
-        try {
-            workflows = repo.getWorkflowsForEvent(eventName);
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            throw new RepositoryException(
-                    "Exception getting workflows associated with event: "
-                            + eventName + ": Message: " + e.getMessage());
-        }
+    List workflows;
 
-        if (workflows != null) {
-          for (Object workflow : workflows) {
-            Workflow w = (Workflow) workflow;
-            LOG.log(Level.INFO, "WorkflowManager: Workflow " + w.getName()
-                                + " retrieved for event " + eventName);
-
-            Metadata m = new Metadata();
-            m.addMetadata(metadata);
-
-            try {
-              engine.startWorkflow(w, m);
-            } catch (Exception e) {
-              LOG.log(Level.SEVERE, e.getMessage());
-              throw new EngineException(
-                  "Engine exception when starting workflow: "
-                  + w.getName() + ": Message: "
-                  + e.getMessage());
-            }
-          }
-            return true;
-        } else {
-          return false;
-        }
+    try {
+      workflows = repo.getWorkflowsForEvent(eventName);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      throw new RepositoryException(
+          "Exception getting workflows associated with event: "
+          + eventName + ": Message: " + e.getMessage());
     }
 
-    public Map getWorkflowInstanceById(String wInstId) {
-        WorkflowInstance inst;
+    if (workflows != null) {
+      for (Object workflow : workflows) {
+        Workflow w = (Workflow) workflow;
+        LOG.log(Level.INFO, "WorkflowManager: Workflow " + w.getName()
+                            + " retrieved for event " + eventName);
+
+        Metadata m = new Metadata();
+        m.addMetadata(metadata);
 
         try {
-            inst = engine.getInstanceRepository().getWorkflowInstanceById(
-                    wInstId);
+          engine.startWorkflow(w, m);
         } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            LOG.log(Level.WARNING,
-                    "Error obtaining workflow instance with ID: [" + wInstId
-                            + "]: Message: " + e.getMessage());
-            inst = new WorkflowInstance();
+          LOG.log(Level.SEVERE, e.getMessage());
+          throw new EngineException(
+              "Engine exception when starting workflow: "
+              + w.getName() + ": Message: "
+              + e.getMessage());
         }
-
-        return XmlRpcStructFactory.getXmlRpcWorkflowInstance(inst);
-
+      }
+      return true;
+    } else {
+      return false;
     }
+  }
 
-    public synchronized boolean stopWorkflowInstance(String workflowInstId) {
-        engine.stopWorkflow(workflowInstId);
-        return true;
-    }
+  public Map getWorkflowInstanceById(String wInstId) {
+    WorkflowInstance inst;
 
-    public synchronized boolean pauseWorkflowInstance(String workflowInstId) {
-        engine.pauseWorkflowInstance(workflowInstId);
-        return true;
+    try {
+      inst = engine.getInstanceRepository().getWorkflowInstanceById(
+          wInstId);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      LOG.log(Level.WARNING,
+          "Error obtaining workflow instance with ID: [" + wInstId
+          + "]: Message: " + e.getMessage());
+      inst = new WorkflowInstance();
     }
 
-    public synchronized boolean resumeWorkflowInstance(String workflowInstId) {
-        engine.resumeWorkflowInstance(workflowInstId);
-        return true;
-    }
+    return XmlRpcStructFactory.getXmlRpcWorkflowInstance(inst);
 
-    public double getWorkflowWallClockMinutes(String workflowInstId) {
-        return engine.getWallClockMinutes(workflowInstId);
-    }
+  }
 
-    public double getWorkflowCurrentTaskWallClockMinutes(String workflowInstId) {
-        return engine.getCurrentTaskWallClockMinutes(workflowInstId);
-    }
+  public synchronized boolean stopWorkflowInstance(String workflowInstId) {
+    engine.stopWorkflow(workflowInstId);
+    return true;
+  }
 
-    public int getNumWorkflowInstancesByStatus(String status) throws InstanceRepositoryException {
-        return engine.getInstanceRepository().getNumWorkflowInstancesByStatus(
-                status);
-    }
+  public synchronized boolean pauseWorkflowInstance(String workflowInstId) {
+    engine.pauseWorkflowInstance(workflowInstId);
+    return true;
+  }
 
-    public int getNumWorkflowInstances() throws InstanceRepositoryException {
-        return engine.getInstanceRepository().getNumWorkflowInstances();
-    }
+  public synchronized boolean resumeWorkflowInstance(String workflowInstId) {
+    engine.resumeWorkflowInstance(workflowInstId);
+    return true;
+  }
+
+  public double getWorkflowWallClockMinutes(String workflowInstId) {
+    return engine.getWallClockMinutes(workflowInstId);
+  }
 
-    public List getWorkflowInstancesByStatus(String status)
-            throws EngineException {
-        List workflowInsts;
+  public double getWorkflowCurrentTaskWallClockMinutes(String workflowInstId) {
+    return engine.getCurrentTaskWallClockMinutes(workflowInstId);
+  }
 
-        Vector workflowInstances = new Vector();
+  public int getNumWorkflowInstancesByStatus(String status) throws InstanceRepositoryException {
+    return engine.getInstanceRepository().getNumWorkflowInstancesByStatus(
+        status);
+  }
 
-        try {
-            workflowInsts = engine.getInstanceRepository()
-                    .getWorkflowInstancesByStatus(status);
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            LOG.log(Level.WARNING,
-                    "Exception getting workflow instances by status: Message: ["
-                            + e.getMessage() + "]");
-            return workflowInstances;
-        }
+  public int getNumWorkflowInstances() throws InstanceRepositoryException {
+    return engine.getInstanceRepository().getNumWorkflowInstances();
+  }
 
-        if (workflowInsts != null) {
-            LOG.log(Level.INFO,
-                    "Getting workflow instances by status: retrieved: "
-                            + workflowInsts.size() + " instances");
-
-            try {
-              for (Object workflowInst : workflowInsts) {
-                WorkflowInstance wInst = (WorkflowInstance) workflowInst;
-                // pick up the description of the workflow
-                Workflow wDesc = repo.getWorkflowById(wInst.getWorkflow()
-                                                           .getId());
-                // TODO: hack for now, fix this, we shouldn't have to cast
-                // here, bad
-                // design
-                if (wDesc == null) {
-                  //Possible dynamic workflow for instance
-                  //reconsitute it from cache
-                  wDesc = wInst.getWorkflow();
-                  repo.addWorkflow(wDesc);
-                }
-                wInst.setWorkflow(wDesc);
-                Map workflowInstance = XmlRpcStructFactory
-                    .getXmlRpcWorkflowInstance(wInst);
-                workflowInstances.add(workflowInstance);
-              }
-            } catch (Exception e) {
-                LOG.log(Level.SEVERE, e.getMessage());
-                throw new EngineException(
-                        "Exception getting workflow instances by statusfrom workflow engine: Message: "
-                                + e.getMessage());
-            }
+  public List getWorkflowInstancesByStatus(String status)
+      throws EngineException {
+    List workflowInsts;
+
+    Vector workflowInstances = new Vector();
+
+    try {
+      workflowInsts = engine.getInstanceRepository()
+                            .getWorkflowInstancesByStatus(status);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      LOG.log(Level.WARNING,
+          "Exception getting workflow instances by status: Message: ["
+          + e.getMessage() + "]");
+      return workflowInstances;
+    }
+
+    if (workflowInsts != null) {
+      LOG.log(Level.INFO,
+          "Getting workflow instances by status: retrieved: "
+          + workflowInsts.size() + " instances");
+
+      try {
+        for (Object workflowInst : workflowInsts) {
+          WorkflowInstance wInst = (WorkflowInstance) workflowInst;
+          // pick up the description of the workflow
+          Workflow wDesc = repo.getWorkflowById(wInst.getWorkflow()
+                                                     .getId());
+          // TODO: hack for now, fix this, we shouldn't have to cast
+          // here, bad
+          // design
+          if (wDesc == null) {
+            //Possible dynamic workflow for instance
+            //reconsitute it from cache
+            wDesc = wInst.getWorkflow();
+            repo.addWorkflow(wDesc);
+          }
+          wInst.setWorkflow(wDesc);
+          Map workflowInstance = XmlRpcStructFactory
+              .getXmlRpcWorkflowInstance(wInst);
+          workflowInstances.add(workflowInstance);
         }
-
-        return workflowInstances;
+      } catch (Exception e) {
+        LOG.log(Level.SEVERE, e.getMessage());
+        throw new EngineException(
+            "Exception getting workflow instances by statusfrom workflow engine: Message: "
+            + e.getMessage());
+      }
     }
 
-    public List getWorkflowInstances() throws EngineException {
-        List workflowInsts;
-
-        Vector workflowInstances = new Vector();
+    return workflowInstances;
+  }
 
-        try {
-            workflowInsts = engine.getInstanceRepository()
-                    .getWorkflowInstances();
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            LOG.log(Level.WARNING,
-                    "Exception getting workflow instances: Message: ["
-                            + e.getMessage() + "]");
-            return workflowInstances;
-        }
+  public List getWorkflowInstances() throws EngineException {
+    List workflowInsts;
+
+    Vector workflowInstances = new Vector();
+
+    try {
+      workflowInsts = engine.getInstanceRepository()
+                            .getWorkflowInstances();
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      LOG.log(Level.WARNING,
+          "Exception getting workflow instances: Message: ["
+          + e.getMessage() + "]");
+      return workflowInstances;
+    }
+
+    if (workflowInsts != null) {
+      LOG.log(Level.INFO, "Getting workflow instances: retrieved: "
+                          + workflowInsts.size() + " instances");
+
+      try {
+        for (Object workflowInst : workflowInsts) {
+          WorkflowInstance wInst = (WorkflowInstance) workflowInst;
+          // pick up the description of the workflow
+          Workflow wDesc = repo.getWorkflowById(wInst.getWorkflow()
+                                                     .getId());
+          if (wDesc == null) {
+            //possible dynamic workflow
+            //reconsitute it from cached instance
+            wDesc = wInst.getWorkflow();
+            //now save it
+            repo.addWorkflow(wDesc);
 
-        if (workflowInsts != null) {
-            LOG.log(Level.INFO, "Getting workflow instances: retrieved: "
-                    + workflowInsts.size() + " instances");
-
-            try {
-              for (Object workflowInst : workflowInsts) {
-                WorkflowInstance wInst = (WorkflowInstance) workflowInst;
-                // pick up the description of the workflow
-                Workflow wDesc = repo.getWorkflowById(wInst.getWorkflow()
-                                                           .getId());
-                if (wDesc == null) {
-                  //possible dynamic workflow
-                  //reconsitute it from cached instance
-                  wDesc = wInst.getWorkflow();
-                  //now save it
-                  repo.addWorkflow(wDesc);
-
-                }
-                // TODO: hack for now, fix this, we shouldn't have to cast
-                // here, bad
-                // design
-                wInst.setWorkflow(wDesc);
-                Map workflowInstance = XmlRpcStructFactory
-                    .getXmlRpcWorkflowInstance(wInst);
-                workflowInstances.add(workflowInstance);
-              }
-                return workflowInstances;
-            } catch (Exception e) {
-                LOG.log(Level.SEVERE, e.getMessage());
-                throw new EngineException(
-                        "Exception getting workflow instances from workflow engine: Message: "
-                                + e.getMessage());
-            }
-        } else {
-          return null;
+          }
+          // TODO: hack for now, fix this, we shouldn't have to cast
+          // here, bad
+          // design
+          wInst.setWorkflow(wDesc);
+          Map workflowInstance = XmlRpcStructFactory
+              .getXmlRpcWorkflowInstance(wInst);
+          workflowInstances.add(workflowInstance);
         }
+        return workflowInstances;
+      } catch (Exception e) {
+        LOG.log(Level.SEVERE, e.getMessage());
+        throw new EngineException(
+            "Exception getting workflow instances from workflow engine: Message: "
+            + e.getMessage());
+      }
+    } else {
+      return null;
     }
+  }
 
-    public List getWorkflows() throws RepositoryException {
-        List workflowList = repo.getWorkflows();
-        Vector workflows = new Vector();
-
-        if (workflowList != null) {
-            LOG.log(Level.INFO, "Getting workflows: retrieved: "
-                    + workflowList.size() + " workflows");
-
-            try {
-              for (Object aWorkflowList : workflowList) {
-                Workflow w = (Workflow) aWorkflowList;
-                Map workflow = XmlRpcStructFactory
-                    .getXmlRpcWorkflow(w);
-                workflows.add(workflow);
-              }
-
-                return workflows;
-            } catch (Exception e) {
-                LOG.log(Level.SEVERE, e.getMessage());
-                throw new RepositoryException(
-                        "Exception getting workflows from repository: Message: "
-                                + e.getMessage());
-            }
+  public List getWorkflows() throws RepositoryException {
+    List workflowList = repo.getWorkflows();
+    Vector workflows = new Vector();
 
-        } else {
-          return null;
+    if (workflowList != null) {
+      LOG.log(Level.INFO, "Getting workflows: retrieved: "
+                          + workflowList.size() + " workflows");
+
+      try {
+        for (Object aWorkflowList : workflowList) {
+          Workflow w = (Workflow) aWorkflowList;
+          Map workflow = XmlRpcStructFactory
+              .getXmlRpcWorkflow(w);
+          workflows.add(workflow);
         }
 
+        return workflows;
+      } catch (Exception e) {
+        LOG.log(Level.SEVERE, e.getMessage());
+        throw new RepositoryException(
+            "Exception getting workflows from repository: Message: "
+            + e.getMessage());
+      }
+
+    } else {
+      return null;
     }
 
-    public Map getTaskById(String taskId) throws RepositoryException {
-        try {
-            WorkflowTask t = repo.getWorkflowTaskById(taskId);
-            return XmlRpcStructFactory.getXmlRpcWorkflowTask(t);
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            throw new RepositoryException(
-                    "Exception getting task by id: Message: " + e.getMessage());
+  }
 
-        }
-    }
+  public Map getTaskById(String taskId) throws RepositoryException {
+    try {
+      WorkflowTask t = repo.getWorkflowTaskById(taskId);
+      return XmlRpcStructFactory.getXmlRpcWorkflowTask(t);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      throw new RepositoryException(
+          "Exception getting task by id: Message: " + e.getMessage());
 
-    public Map getConditionById(String conditionId)
-            throws RepositoryException {
-        try {
-            WorkflowCondition c = repo.getWorkflowConditionById(conditionId);
-            return XmlRpcStructFactory.getXmlRpcWorkflowCondition(c);
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            throw new RepositoryException(
-                    "Exception getting condition by id: Message: "
-                            + e.getMessage());
-        }
     }
+  }
 
-    public Map getWorkflowById(String workflowId)
-            throws RepositoryException {
-        try {
-            Workflow workflow = repo.getWorkflowById(workflowId);
-            return XmlRpcStructFactory.getXmlRpcWorkflow(workflow);
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            throw new RepositoryException(
-                    "Exception getting workflow by id from the repository: Message: "
-                            + e.getMessage());
-        }
+  public Map getConditionById(String conditionId)
+      throws RepositoryException {
+    try {
+      WorkflowCondition c = repo.getWorkflowConditionById(conditionId);
+      return XmlRpcStructFactory.getXmlRpcWorkflowCondition(c);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      throw new RepositoryException(
+          "Exception getting condition by id: Message: "
+          + e.getMessage());
     }
+  }
 
-    public synchronized boolean updateMetadataForWorkflow(
-            String workflowInstId, Hashtable metadata) {
-        Metadata met = new Metadata();
-        met.addMetadata(metadata);
-        return this.engine.updateMetadata(workflowInstId, met);
+  public Map getWorkflowById(String workflowId)
+      throws RepositoryException {
+    try {
+      Workflow workflow = repo.getWorkflowById(workflowId);
+      return XmlRpcStructFactory.getXmlRpcWorkflow(workflow);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      throw new RepositoryException(
+          "Exception getting workflow by id from the repository: Message: "
+          + e.getMessage());
     }
+  }
+
+  public synchronized boolean updateMetadataForWorkflow(
+      String workflowInstId, Hashtable metadata) {
+    Metadata met = new Metadata();
+    met.addMetadata(metadata);
+    return this.engine.updateMetadata(workflowInstId, met);
+  }
 
   public synchronized boolean updateWorkflowInstance(Hashtable workflowInst) {
     return this.updateWorkflowInstanceCore(workflowInst);
   }
-    public synchronized boolean updateWorkflowInstanceCore(Map workflowInst) {
-        WorkflowInstance wInst = XmlRpcStructFactory
-                .getWorkflowInstanceFromXmlRpc(workflowInst);
-        return doUpdateWorkflowInstance(wInst);
 
-    }
-
-    public synchronized boolean setWorkflowInstanceCurrentTaskStartDateTime(
-            String wInstId, String startDateTimeIsoStr) {
-        WorkflowInstance wInst;
-        try {
-            wInst = this.engine.getInstanceRepository()
-                    .getWorkflowInstanceById(wInstId);
-        } catch (InstanceRepositoryException e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            return false;
-        }
-        wInst.setCurrentTaskStartDateTimeIsoStr(startDateTimeIsoStr);
-        return doUpdateWorkflowInstance(wInst);
-    }
+  public synchronized boolean updateWorkflowInstanceCore(Map workflowInst) {
+    WorkflowInstance wInst = XmlRpcStructFactory
+        .getWorkflowInstanceFromXmlRpc(workflowInst);
+    return doUpdateWorkflowInstance(wInst);
 
-    public synchronized boolean setWorkflowInstanceCurrentTaskEndDateTime(
-            String wInstId, String endDateTimeIsoStr) {
-        WorkflowInstance wInst;
-        try {
-            wInst = this.engine.getInstanceRepository()
-                    .getWorkflowInstanceById(wInstId);
-        } catch (InstanceRepositoryException e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            return false;
-        }
-        wInst.setCurrentTaskEndDateTimeIsoStr(endDateTimeIsoStr);
-        return doUpdateWorkflowInstance(wInst);
-    }
-
-    public synchronized boolean updateWorkflowInstanceStatus(
-            String workflowInstanceId, String status) throws InstanceRepositoryException {
-        WorkflowInstance wInst;
-            wInst = engine.getInstanceRepository().getWorkflowInstanceById(
-                    workflowInstanceId);
+  }
 
+  public synchronized boolean setWorkflowInstanceCurrentTaskStartDateTime(
+      String wInstId, String startDateTimeIsoStr) {
+    WorkflowInstance wInst;
+    try {
+      wInst = this.engine.getInstanceRepository()
+                         .getWorkflowInstanceById(wInstId);
+    } catch (InstanceRepositoryException e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      return false;
+    }
+    wInst.setCurrentTaskStartDateTimeIsoStr(startDateTimeIsoStr);
+    return doUpdateWorkflowInstance(wInst);
+  }
 
-        wInst.setStatus(status);
-        return doUpdateWorkflowInstance(wInst);
-    }
+  public synchronized boolean setWorkflowInstanceCurrentTaskEndDateTime(
+      String wInstId, String endDateTimeIsoStr) {
+    WorkflowInstance wInst;
+    try {
+      wInst = this.engine.getInstanceRepository()
+                         .getWorkflowInstanceById(wInstId);
+    } catch (InstanceRepositoryException e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      return false;
+    }
+    wInst.setCurrentTaskEndDateTimeIsoStr(endDateTimeIsoStr);
+    return doUpdateWorkflowInstance(wInst);
+  }
 
-    public static void main(String[] args) throws IOException {
-        int portNum = -1;
-        String usage = "XmlRpcWorkflowManager --portNum <port number for xml rpc service>\n";
+  public synchronized boolean updateWorkflowInstanceStatus(
+      String workflowInstanceId, String status) throws InstanceRepositoryException {
+    WorkflowInstance wInst;
+    wInst = engine.getInstanceRepository().getWorkflowInstanceById(
+        workflowInstanceId);
 
-        for (int i = 0; i < args.length; i++) {
-            if (args[i].equals("--portNum")) {
-                portNum = Integer.parseInt(args[++i]);
-            }
-        }
 
-        if (portNum == -1) {
-            System.err.println(usage);
-            System.exit(1);
-        }
+    wInst.setStatus(status);
+    return doUpdateWorkflowInstance(wInst);
+  }
 
-        loadProperties();
-        new XmlRpcWorkflowManager(portNum);
+  public static void main(String[] args) throws IOException {
+    int portNum = -1;
+    String usage = "XmlRpcWorkflowManager --portNum <port number for xml rpc service>\n";
 
-        for (;;) {
-          try {
-            Thread.currentThread().join();
-          } catch (InterruptedException ignore) {
-          }
-        }
+    for (int i = 0; i < args.length; i++) {
+      if (args[i].equals("--portNum")) {
+        portNum = Integer.parseInt(args[++i]);
+      }
     }
 
-    public static void loadProperties() throws IOException {
-       String configFile = System.getProperty(PROPERTIES_FILE_PROPERTY);
-       if (configFile != null) {
-          LOG.log(Level.INFO,
-                "Loading Workflow Manager Configuration Properties from: ["
-                      + configFile + "]");
-          System.getProperties().load(new FileInputStream(new File(
-                configFile)));
-       }
+    if (portNum == -1) {
+      System.err.println(usage);
+      System.exit(1);
     }
 
-    private static WorkflowEngine getWorkflowEngineFromProperty() {
-       return getWorkflowEngineFromClassName(System.getProperty(
-             WORKFLOW_ENGINE_FACTORY_PROPERTY,
-             ThreadPoolWorkflowEngineFactory.class.getCanonicalName()));
-    }
+    loadProperties();
+    new XmlRpcWorkflowManager(portNum);
 
-    private static WorkflowRepository getWorkflowRepositoryFromProperty() {
-       return getWorkflowRepositoryFromClassName(System.getProperty(
-             WORKFLOW_REPOSITORY_FACTORY_PROPERTY,
-             DataSourceWorkflowRepositoryFactory.class.getCanonicalName()));
+    for (; ; ) {
+      try {
+        Thread.currentThread().join();
+      } catch (InterruptedException ignore) {
+      }
     }
+  }
 
-    private String getHostname() {
-        try {
-            // Get hostname by textual representation of IP address
-            InetAddress addr = InetAddress.getLocalHost();
-            // Get the host name
-          return addr.getHostName();
-        } catch (UnknownHostException ignored) {
-        }
-        return null;
+  public static void loadProperties() throws IOException {
+    String configFile = System.getProperty(PROPERTIES_FILE_PROPERTY);
+    if (configFile != null) {
+      LOG.log(Level.INFO,
+          "Loading Workflow Manager Configuration Properties from: ["
+          + configFile + "]");
+      System.getProperties().load(new FileInputStream(new File(
+          configFile)));
     }
+  }
 
-    private URL safeGetUrlFromString(String urlStr) {
-        try {
-            return new URL(urlStr);
-        } catch (MalformedURLException e) {
-            return null;
-        }
+  private static WorkflowEngine getWorkflowEngineFromProperty() {
+    return getWorkflowEngineFromClassName(System.getProperty(
+        WORKFLOW_ENGINE_FACTORY_PROPERTY,
+        ThreadPoolWorkflowEngineFactory.class.getCanonicalName()));
+  }
+
+  private static WorkflowRepository getWorkflowRepositoryFromProperty() {
+    return getWorkflowRepositoryFromClassName(System.getProperty(
+        WORKFLOW_REPOSITORY_FACTORY_PROPERTY,
+        DataSourceWorkflowRepositoryFactory.class.getCanonicalName()));
+  }
+
+  private String getHostname() {
+    try {
+      // Get hostname by textual representation of IP address
+      InetAddress addr = InetAddress.getLocalHost();
+      // Get the host name
+      return addr.getHostName();
+    } catch (UnknownHostException ignored) {
     }
+    return null;
+  }
 
-    private boolean doUpdateWorkflowInstance(WorkflowInstance wInst) {
-        try {
-            engine.getInstanceRepository().updateWorkflowInstance(wInst);
-            return true;
-        } catch (InstanceRepositoryException e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            return false;
-        }
+  private URL safeGetUrlFromString(String urlStr) {
+    try {
+      return new URL(urlStr);
+    } catch (MalformedURLException e) {
+      return null;
     }
+  }
 
-    private void populateWorkflows(List wInsts) {
-        if (wInsts != null && wInsts.size() > 0) {
-          for (Object wInst1 : wInsts) {
-            WorkflowInstance wInst = (WorkflowInstance) wInst1;
-            if (wInst.getWorkflow() == null || ((wInst.getWorkflow().getName() == null
-                                                 || wInst.getWorkflow().getId() == null))) {
-              wInst.setWorkflow(safeGetWorkflowById(wInst.getWorkflow()
-                                                         .getId()));
-            } else {
-              // check to see if the workflow exists in the
-              // repo
-              try {
-                if (repo.getWorkflowById(wInst.getWorkflow().getId()) == null) {
-                  repo.addWorkflow(wInst.getWorkflow());
-                }
-              } catch (RepositoryException e) {
-                LOG.log(Level.WARNING, "Attempting to look up workflow: [" + wInst.getWorkflow()
-                                                                                  .getId()
-                                       + "] in populate workflows. Message: " + e.getMessage());
-                LOG.log(Level.SEVERE, e.getMessage());
-              }
+  private boolean doUpdateWorkflowInstance(WorkflowInstance wInst) {
+    try {
+      engine.getInstanceRepository().updateWorkflowInstance(wInst);
+      return true;
+    } catch (InstanceRepositoryException e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      return false;
+    }
+  }
 
+  private void populateWorkflows(List wInsts) {
+    if (wInsts != null && wInsts.size() > 0) {
+      for (Object wInst1 : wInsts) {
+        WorkflowInstance wInst = (WorkflowInstance) wInst1;
+        if (wInst.getWorkflow() == null || ((wInst.getWorkflow().getName() == null
+                                             || wInst.getWorkflow().getId() == null))) {
+          wInst.setWorkflow(safeGetWorkflowById(wInst.getWorkflow()
+                                                     .getId()));
+        } else {
+          // check to see if the workflow exists in the
+          // repo
+          try {
+            if (repo.getWorkflowById(wInst.getWorkflow().getId()) == null) {
+              repo.addWorkflow(wInst.getWorkflow());
             }
+          } catch (RepositoryException e) {
+            LOG.log(Level.WARNING, "Attempting to look up workflow: [" + wInst.getWorkflow()
+                                                                              .getId()
+                                   + "] in populate workflows. Message: " + e.getMessage());
+            LOG.log(Level.SEVERE, e.getMessage());
           }
+
         }
+      }
     }
+  }
 
-    private Workflow safeGetWorkflowById(String workflowId) {
-        try {
-            return repo.getWorkflowById(workflowId);
-        } catch (Exception e) {
-            LOG.log(Level.SEVERE, e.getMessage());
-            LOG.log(Level.WARNING, "Error getting workflow by its id: ["
-                    + workflowId + "]: Message: " + e.getMessage());
-            return new Workflow();
-        }
+  private Workflow safeGetWorkflowById(String workflowId) {
+    try {
+      return repo.getWorkflowById(workflowId);
+    } catch (Exception e) {
+      LOG.log(Level.SEVERE, e.getMessage());
+      LOG.log(Level.WARNING, "Error getting workflow by its id: ["
+                             + workflowId + "]: Message: " + e.getMessage());
+      return new Workflow();
     }
+  }
 
 }

http://git-wip-us.apache.org/repos/asf/oodt/blob/538c0d6b/workflow/src/test/java/org/apache/oodt/cas/workflow/system/TestXmlRpcWorkflowManagerClient.java
----------------------------------------------------------------------
diff --git a/workflow/src/test/java/org/apache/oodt/cas/workflow/system/TestXmlRpcWorkflowManagerClient.java b/workflow/src/test/java/org/apache/oodt/cas/workflow/system/TestXmlRpcWorkflowManagerClient.java
index a341847..a12ea19 100644
--- a/workflow/src/test/java/org/apache/oodt/cas/workflow/system/TestXmlRpcWorkflowManagerClient.java
+++ b/workflow/src/test/java/org/apache/oodt/cas/workflow/system/TestXmlRpcWorkflowManagerClient.java
@@ -1,18 +1,14 @@
 /**
- * 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.
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.oodt.cas.workflow.system;
@@ -60,9 +56,9 @@ import static org.junit.Assert.*;
 
 
 /**
- * 
+ *
  * Test harness for the {@link XmlRpcWorkflowManagerClient}.
- * 
+ *
  */
 public class TestXmlRpcWorkflowManagerClient {
 
@@ -92,7 +88,6 @@ public class TestXmlRpcWorkflowManagerClient {
   public TestXmlRpcWorkflowManagerClient() {
 
 
-
   }
 
   @BeforeClass
@@ -171,7 +166,7 @@ public class TestXmlRpcWorkflowManagerClient {
 
 
   @AfterClass
-  public static void cleandown(){
+  public static void cleandown() {
 
     stopXmlRpcWorkflowManager();
   }
@@ -224,6 +219,7 @@ public class TestXmlRpcWorkflowManagerClient {
 
 
   }
+
   @Test
   public void testGetWorkflowInstancesByStatus() throws Exception {
 
@@ -232,6 +228,7 @@ public class TestXmlRpcWorkflowManagerClient {
     assertNotNull(wflows);
 
   }
+
   @Test
   public void testGetWorkflowInstanceMetadata2() throws Exception {
     WorkflowInstance wf = (WorkflowInstance) fmc.getFirstPage().getPageWorkflows().get(0);
@@ -239,12 +236,12 @@ public class TestXmlRpcWorkflowManagerClient {
     assertThat(wf, is(not(Matchers.nullValue())));
 
 
-
     Metadata meta = fmc.getWorkflowInstanceMetadata(wf.getId());
 
     assertNotNull(meta);
 
   }
+
   @Test
   public void testGetWorkflowCurrentTaskWallClockMinutes() throws Exception {
     XmlRpcWorkflowManagerClient fmc = new XmlRpcWorkflowManagerClient(new URL(
@@ -260,6 +257,7 @@ public class TestXmlRpcWorkflowManagerClient {
     assertThat(clock, is(not(Matchers.nullValue())));
 
   }
+
   @Test
   public void testGetTaskById() throws Exception {
 
@@ -270,8 +268,8 @@ public class TestXmlRpcWorkflowManagerClient {
     assertThat(task.getTaskName(), equalTo("Hello World"));
 
 
-
   }
+
   @Test
   public void testGetRegisteredEvents() throws Exception {
 
@@ -294,6 +292,7 @@ public class TestXmlRpcWorkflowManagerClient {
     fail();
 
   }
+
   @Test
   public void testGetConditionById() throws Exception {
 
@@ -306,14 +305,13 @@ public class TestXmlRpcWorkflowManagerClient {
   }
 
   @Test
-  public void testGetNumWorkflowInstances() throws Exception{
+  public void testGetNumWorkflowInstances() throws Exception {
 
     int num = fmc.getNumWorkflowInstances();
 
     assertThat(num, is(not(0)));
 
 
-
   }
 
   @Test
@@ -388,8 +386,6 @@ public class TestXmlRpcWorkflowManagerClient {
   }
 
 
-
-
   private static void startXmlRpcWorkflowManager() {
     System.setProperty("java.util.logging.config.file", new File(
         "./src/main/resources/logging.properties").getAbsolutePath());
@@ -428,7 +424,8 @@ public class TestXmlRpcWorkflowManagerClient {
 
     try {
       System.setProperty("org.apache.oodt.cas.workflow.repo.dirs", "file://"
-                                                                   + new File("./src/main/resources/examples").getCanonicalPath());
+                                                                   + new File("./src/main/resources/examples")
+                                                                       .getCanonicalPath());
       System.setProperty("org.apache.oodt.cas.workflow.lifecycle.filePath",
           new File("./src/main/resources/examples/workflow-lifecycle.xml")
               .getCanonicalPath());
@@ -466,7 +463,8 @@ public class TestXmlRpcWorkflowManagerClient {
 
     try {
       System.setProperty("org.apache.oodt.cas.workflow.repo.dirs", "file://"
-                                                                   + new File("./src/main/resources/examples").getCanonicalPath());
+                                                                   + new File("./src/main/resources/examples")
+                                                                       .getCanonicalPath());
       System.setProperty("org.apache.oodt.cas.workflow.lifecycle.filePath",
           new File("./src/main/resources/examples/workflow-lifecycle.xml")
               .getCanonicalPath());