You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oozie.apache.org by an...@apache.org on 2018/03/27 10:25:31 UTC

[2/5] oozie git commit: OOZIE-3176 Oozie-core fails with checkstyle errors (alishap via andras.piros)

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/TestFutureActionsTimeOut.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestFutureActionsTimeOut.java b/core/src/test/java/org/apache/oozie/command/coord/TestFutureActionsTimeOut.java
index a6fce4e..11706dd 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestFutureActionsTimeOut.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestFutureActionsTimeOut.java
@@ -110,7 +110,8 @@ public class TestFutureActionsTimeOut extends XTestCase {
                 + "<data-in name=\"A\" dataset=\"a\"> <instance>${coord:latest(0)}</instance> </data-in>  "
                 + "</input-events> "
                 + "<output-events> <data-out name=\"LOCAL_A\" dataset=\"local_a\"> "
-                + "<instance>${coord:current(-1)}</instance> </data-out> </output-events> <action> <workflow> <app-path>hdfs:///tmp/workflows/</app-path> "
+                + "<instance>${coord:current(-1)}</instance> </data-out> </output-events> <action> <workflow> <app-path>hdfs:"
+                + "///tmp/workflows/</app-path> "
                 + "<configuration> <property> <name>inputA</name> <value>${coord:dataIn('A')}</value> </property> "
                 + "<property> <name>inputB</name> <value>${coord:dataOut('LOCAL_A')}</value> "
                 + "</property></configuration> </workflow> </action> </coordinator-app>";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/TestPastActionsTimeOut.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestPastActionsTimeOut.java b/core/src/test/java/org/apache/oozie/command/coord/TestPastActionsTimeOut.java
index f4327ae..df536fc 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestPastActionsTimeOut.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestPastActionsTimeOut.java
@@ -64,7 +64,8 @@ public class TestPastActionsTimeOut extends XTestCase {
     private String _testSubmitJob(String appPath) throws Exception {
         Configuration conf = new XConfiguration();
 
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"15\" start=\"2009-02-01T01:00Z\" end=\"2009-02-01T02:00Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"15\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-01T02:00Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.1\"> <controls> <timeout>10</timeout> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
@@ -75,7 +76,8 @@ public class TestPastActionsTimeOut extends XTestCase {
                 + "<data-in name=\"A\" dataset=\"a\"> <instance>${coord:latest(0)}</instance> </data-in>  "
                 + "</input-events> "
                 + "<output-events> <data-out name=\"LOCAL_A\" dataset=\"local_a\"> "
-                + "<instance>${coord:current(-1)}</instance> </data-out> </output-events> <action> <workflow> <app-path>hdfs:///tmp/workflows/</app-path> "
+                + "<instance>${coord:current(-1)}</instance> </data-out> </output-events> <action> <workflow>"
+                + " <app-path>hdfs:///tmp/workflows/</app-path> "
                 + "<configuration> <property> <name>inputA</name> <value>${coord:dataIn('A')}</value> </property> "
                 + "<property> <name>inputB</name> <value>${coord:dataOut('LOCAL_A')}</value> "
                 + "</property></configuration> </workflow> </action> </coordinator-app>";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/wf/TestActionCheckXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/wf/TestActionCheckXCommand.java b/core/src/test/java/org/apache/oozie/command/wf/TestActionCheckXCommand.java
index 25d16cf..19d5630 100644
--- a/core/src/test/java/org/apache/oozie/command/wf/TestActionCheckXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/wf/TestActionCheckXCommand.java
@@ -89,7 +89,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         long counterVal;
 
         try {
-            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                    .getValue();
         } catch (NullPointerException e){
             //counter might be null
             counterVal = 0L;
@@ -100,7 +101,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         checkCmd.call();
 
         //precondition failed because of actionCheckDelay > 0
-        counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+        counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                .getValue();
         assertEquals(1L, counterVal);
     }
 
@@ -120,7 +122,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         long counterVal;
 
         try {
-            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                    .getValue();
         } catch (NullPointerException e){
             //counter might be null
             counterVal = 0L;
@@ -131,7 +134,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         checkCmd.call();
 
         //precondition failed because of pending = false
-        counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+        counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                .getValue();
         assertEquals(1L, counterVal);
     }
 
@@ -151,7 +155,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         long counterVal;
 
         try{
-            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                    .getValue();
         } catch (NullPointerException e){
             //counter might be null
             counterVal = 0L;
@@ -162,7 +167,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         checkCmd.call();
 
         //precondition failed because of action != RUNNING
-        counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+        counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                .getValue();
         assertEquals(1L, counterVal);
     }
 
@@ -182,7 +188,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
         long counterVal;
 
         try {
-            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed").getValue();
+            counterVal = inst.getCounters().get(XCommand.INSTRUMENTATION_GROUP).get(checkCmd.getName() + ".preconditionfailed")
+                    .getValue();
         } catch (NullPointerException e){
             //counter might be null
             counterVal = 0L;
@@ -598,7 +605,8 @@ public class TestActionCheckXCommand extends XDataTestCase {
     }
 
     @Override
-    protected WorkflowActionBean addRecordToWfActionTable(String wfId, String actionName, WorkflowAction.Status status) throws Exception {
+    protected WorkflowActionBean addRecordToWfActionTable(
+            String wfId, String actionName, WorkflowAction.Status status) throws Exception {
         WorkflowActionBean action = createWorkflowActionSetPending(wfId, status);
         try {
             JPAService jpaService = Services.get().get(JPAService.class);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/wf/TestActionErrors.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/wf/TestActionErrors.java b/core/src/test/java/org/apache/oozie/command/wf/TestActionErrors.java
index dadebb5..519b384 100644
--- a/core/src/test/java/org/apache/oozie/command/wf/TestActionErrors.java
+++ b/core/src/test/java/org/apache/oozie/command/wf/TestActionErrors.java
@@ -196,7 +196,7 @@ public class TestActionErrors extends XDataTestCase {
         _testError("end.error", "ok", "OK");
         assertTrue(true);
     }
-    
+
     /**
      * Tests for correct functionality when a {@link org.apache.oozie.action.ActionExecutorException.ErrorType#ERROR} is
      * generated when executing start. </p> Checks for user retry is applied to actions for specified retry-max=2.
@@ -207,7 +207,7 @@ public class TestActionErrors extends XDataTestCase {
     	_testErrorWithUserRetry("start.error", "error", "based_on_action_status");
         assertTrue(true);
     }
-    
+
     /**
      * Tests for correct functionality when a {@link org.apache.oozie.action.ActionExecutorException.ErrorType#ERROR} is
      * generated when executing end. </p> Checks for user retry is applied to actions for specified retry-max=2.
@@ -218,7 +218,7 @@ public class TestActionErrors extends XDataTestCase {
     	_testErrorWithUserRetry("end.error", "ok", "OK");
         assertTrue(true);
     }
-    
+
     /**
      * Tests for the job to be KILLED and status set to FAILED in case an Action Handler does not call setExecutionData
      * in it's start() implementation.
@@ -410,7 +410,8 @@ public class TestActionErrors extends XDataTestCase {
      * @param expErrorMsg expected error message.
      * @throws Exception
      */
-    private void _testNonTransientWithCoordActionUpdate(String errorType, WorkflowActionBean.Status expStatus1, String expErrorMsg) throws Exception {
+    private void _testNonTransientWithCoordActionUpdate(
+            String errorType, WorkflowActionBean.Status expStatus1, String expErrorMsg) throws Exception {
         String workflowPath = getTestCaseFileUri("workflow.xml");
         Reader reader = IOUtils.getResourceAsReader("wf-ext-schema-valid.xml", -1);
         Writer writer = new FileWriter(new File(getTestCaseDir(), "workflow.xml"));

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/wf/TestActionStartXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/wf/TestActionStartXCommand.java b/core/src/test/java/org/apache/oozie/command/wf/TestActionStartXCommand.java
index 80c5d54..bd41d03 100644
--- a/core/src/test/java/org/apache/oozie/command/wf/TestActionStartXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/wf/TestActionStartXCommand.java
@@ -182,7 +182,8 @@ public class TestActionStartXCommand extends XDataTestCase {
 
     public void testActionReuseWfJobAppPath() throws Exception {
         JPAService jpaService = Services.get().get(JPAService.class);
-        WorkflowJobBean job = this.addRecordToWfJobTableWithCustomAppPath(WorkflowJob.Status.RUNNING, WorkflowInstance.Status.RUNNING);
+        WorkflowJobBean job = this.addRecordToWfJobTableWithCustomAppPath(
+                WorkflowJob.Status.RUNNING, WorkflowInstance.Status.RUNNING);
         WorkflowActionBean action = this.addRecordToWfActionTableWithAppPathConfig(job.getId(), "1", WorkflowAction.Status.PREP);
         WorkflowActionGetJPAExecutor wfActionGetCmd = new WorkflowActionGetJPAExecutor(action.getId());
 
@@ -206,14 +207,16 @@ public class TestActionStartXCommand extends XDataTestCase {
      * <p/>
      * Escaped string needs to be 'escaped' before converting to XML Document, otherwise,
      * exception will be thrown.
-     * @see org.apache.oozie.DagELFunctions#configureEvaluator(org.apache.oozie.util.ELEvaluator.ELEvaluator evaluator, org.apache.oozie.WorkflowJobBean, org.apache.oozie.WorkflowActionBean)
+     * @see org.apache.oozie.DagELFunctions#configureEvaluator(org.apache.oozie.util.ELEvaluator.ELEvaluator evaluator,
+     *  org.apache.oozie.WorkflowJobBean, org.apache.oozie.WorkflowActionBean)
      *
      * @throws Exception thrown if failed to execute test case
      */
     public void testActionWithEscapedStringAndCDATA() throws Exception {
         // create workflow job and action beans with escaped parameters and CDATA value
         JPAService jpaService = Services.get().get(JPAService.class);
-        WorkflowJobBean job = this.addRecordToWfJobTableWithEscapedStringAndCDATA(WorkflowJob.Status.RUNNING, WorkflowInstance.Status.RUNNING);
+        WorkflowJobBean job = this.addRecordToWfJobTableWithEscapedStringAndCDATA(
+                WorkflowJob.Status.RUNNING, WorkflowInstance.Status.RUNNING);
         WorkflowActionBean action = this.addRecordToWfActionTableWithEscapedStringAndCDATA(job.getId(), WorkflowAction.Status.PREP);
         WorkflowActionGetJPAExecutor wfActionGetCmd = new WorkflowActionGetJPAExecutor(action.getId());
 
@@ -243,7 +246,8 @@ public class TestActionStartXCommand extends XDataTestCase {
      * @return workflow job bean
      * @throws Exception thrown if failed to create workflow job
      */
-    protected WorkflowJobBean addRecordToWfJobTableWithCustomAppPath(WorkflowJob.Status jobStatus, WorkflowInstance.Status instanceStatus)
+    protected WorkflowJobBean addRecordToWfJobTableWithCustomAppPath(
+            WorkflowJob.Status jobStatus, WorkflowInstance.Status instanceStatus)
     throws Exception {
         WorkflowApp app = new LiteWorkflowApp("testApp", "<workflow-app/>",
             new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "end")).
@@ -279,7 +283,8 @@ public class TestActionStartXCommand extends XDataTestCase {
      * @return workflow action bean
      * @throws Exception thrown if failed to create workflow action
      */
-    protected WorkflowActionBean addRecordToWfActionTableWithAppPathConfig(String wfId, String actionName, WorkflowAction.Status status)
+    protected WorkflowActionBean addRecordToWfActionTableWithAppPathConfig(
+            String wfId, String actionName, WorkflowAction.Status status)
             throws Exception {
         WorkflowActionBean action = createWorkflowActionWithAppPathConfig(wfId, status);
         try {
@@ -345,7 +350,8 @@ public class TestActionStartXCommand extends XDataTestCase {
 
 
     /* (non-Javadoc)
-     * @see org.apache.oozie.test.XDataTestCase#addRecordToWfActionTable(java.lang.String, java.lang.String, org.apache.oozie.client.WorkflowAction.Status)
+     * @see org.apache.oozie.test.XDataTestCase#addRecordToWfActionTable(
+     * java.lang.String, java.lang.String, org.apache.oozie.client.WorkflowAction.Status)
      */
     @Override
     protected WorkflowActionBean addRecordToWfActionTable(String wfId, String actionName, WorkflowAction.Status status)
@@ -448,7 +454,8 @@ public class TestActionStartXCommand extends XDataTestCase {
         // The properties should not be escaped here. It will be escaped when set to configuration.
         conf.set("testAmpSign", "http://test.apache.com/a-webservices?urlSigner=signUrl&namespace=nova.proxy");
         conf.set("testCDATA",
-                        "<![CDATA[?redirect=http%3A%2F%2Ftest.apache.com%2Fa-webservices%2Fv1%2FurlSigner%2FsignUrl&amp;namespace=nova.proxy&amp;keyDBHash=Vsy6n_C7K6NG0z4R2eBlKg--]]>");
+                        "<![CDATA[?redirect=http%3A%2F%2Ftest.apache.com%2Fa-webservices%2Fv1%2FurlSigner%2FsignUrl&amp;namespace"
+                        + "=nova.proxy&amp;keyDBHash=Vsy6n_C7K6NG0z4R2eBlKg--]]>");
 
         WorkflowJobBean wfBean = createWorkflow(app, conf, jobStatus, instanceStatus);
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/wf/TestReRunXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/wf/TestReRunXCommand.java b/core/src/test/java/org/apache/oozie/command/wf/TestReRunXCommand.java
index 45cbbc4..c40b305 100644
--- a/core/src/test/java/org/apache/oozie/command/wf/TestReRunXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/wf/TestReRunXCommand.java
@@ -208,7 +208,8 @@ public class TestReRunXCommand extends XDataTestCase {
 
         conf.setProperty("nnbase", path.toString());
         conf.setProperty("base", conf.getProperty("nnbase"));
-        // setting the variables "srcDir" and "dstDir", used as a file paths in the workflow, to parameterized expressions to test resolution.
+        // setting the variables "srcDir" and "dstDir", used as a file paths in the workflow,
+        // to parameterized expressions to test resolution.
         conf.setProperty("srcDir", "${base}/p1");
         conf.setProperty("dstDir", "${base}/p2");
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/coord/TestCoordELEvaluator.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/coord/TestCoordELEvaluator.java b/core/src/test/java/org/apache/oozie/coord/TestCoordELEvaluator.java
index a429665..5e9a121 100644
--- a/core/src/test/java/org/apache/oozie/coord/TestCoordELEvaluator.java
+++ b/core/src/test/java/org/apache/oozie/coord/TestCoordELEvaluator.java
@@ -121,13 +121,16 @@ public class TestCoordELEvaluator extends XTestCase {
     }
 
     public void testCreateDataEvaluator() throws Exception {
-        String jobXml = "<coordinator-app name=\"mycoordinator-app\" start=\"2009-02-01T01:00GMT\" end=\"2009-02-03T23:59GMT\" timezone=\"UTC\"";
+        String jobXml = "<coordinator-app name=\"mycoordinator-app\" start=\"2009-02-01T01:00GMT\""
+                + " end=\"2009-02-03T23:59GMT\" timezone=\"UTC\"";
         jobXml += " frequency=\"720\" freq_timeunit=\"MINUTE\"";
         jobXml += " action-nominal-time='2009-09-01T00:00Z' action-actual-time='2010-10-01T00:00Z'>";
-        jobXml += "<input-events><data-in name=\"A\" dataset=\"a\"><uris>file:///tmp/coord/US/2009/1/30|file:///tmp/coord/US/2009/1/31</uris>";
+        jobXml += "<input-events><data-in name=\"A\" dataset=\"a\">"
+                + "<uris>file:///tmp/coord/US/2009/1/30|file:///tmp/coord/US/2009/1/31</uris>";
         jobXml += "<dataset name=\"a\" frequency=\"1440\" initial-instance=\"2009-01-01T00:00Z\">";
         jobXml += "<uri-template>file:///tmp/coord/US/${YEAR}/${MONTH}/${DAY}</uri-template></dataset></data-in></input-events>";
-        jobXml += "<action><workflow><url>http://foobar.com:8080/oozie</url><app-path>hdfs://foobarfoobar.com:9000/usr/tucu/mywf</app-path>";
+        jobXml += "<action><workflow><url>http://foobar.com:8080/oozie</url>"
+                + "<app-path>hdfs://foobarfoobar.com:9000/usr/tucu/mywf</app-path>";
         jobXml += "<configuration><property><name>inputA</name><value>${coord:dataIn('A')}</value></property>";
         jobXml += "<property><name>ACTIONID</name><value>${coord:actionId()}</value></property>";
         jobXml += "<property><name>NAME</name><value>${coord:name()}</value></property>";
@@ -135,8 +138,10 @@ public class TestCoordELEvaluator extends XTestCase {
         jobXml += "<property><name>ACTUALTIME</name><value>${coord:actualTime()}</value></property>";
         jobXml += "</configuration></workflow></action></coordinator-app>";
 
-        String reply = "<action><workflow><url>http://foobar.com:8080/oozie</url><app-path>hdfs://foobarfoobar.com:9000/usr/tucu/mywf</app-path>";
-        reply += "<configuration><property><name>inputA</name><value>file:///tmp/coord/US/2009/1/30|file:///tmp/coord/US/2009/1/31</value></property>";
+        String reply = "<action><workflow><url>http://foobar.com:8080/oozie</url>"
+                + "<app-path>hdfs://foobarfoobar.com:9000/usr/tucu/mywf</app-path>";
+        reply += "<configuration><property><name>inputA</name>"
+                + "<value>file:///tmp/coord/US/2009/1/30|file:///tmp/coord/US/2009/1/31</value></property>";
         reply += "<property><name>ACTIONID</name><value>00000-oozie-C@1</value></property>";
         reply += "<property><name>NAME</name><value>mycoordinator-app</value></property>";
         reply += "<property><name>NOMINALTIME</name><value>2009-09-01T00:00Z</value></property>";
@@ -151,8 +156,10 @@ public class TestCoordELEvaluator extends XTestCase {
     }
 
     public void testCreateInstancesELEvaluator() throws Exception {
-        String dataEvntXML = "<data-in name=\"A\" dataset=\"a\"><uris>file:///tmp/coord/US/2009/1/30|file:///tmp/coord/US/2009/1/31</uris>";
-        dataEvntXML += "<dataset name=\"a\" frequency=\"1440\" initial-instance=\"2009-01-01T00:00Z\" freq_timeunit=\"MINUTE\" timezone=\"UTC\" end_of_duration=\"NONE\">";
+        String dataEvntXML = "<data-in name=\"A\" dataset=\"a\">"
+                + "<uris>file:///tmp/coord/US/2009/1/30|file:///tmp/coord/US/2009/1/31</uris>";
+        dataEvntXML += "<dataset name=\"a\" frequency=\"1440\" initial-instance=\"2009-01-01T00:00Z\""
+                + " freq_timeunit=\"MINUTE\" timezone=\"UTC\" end_of_duration=\"NONE\">";
         dataEvntXML += "<uri-template>file:///tmp/coord/US/${YEAR}/${MONTH}/${DAY}</uri-template></dataset></data-in>";
         Element event = XmlUtils.parseXml(dataEvntXML);
         SyncCoordAction appInst = new SyncCoordAction();
@@ -180,8 +187,10 @@ public class TestCoordELEvaluator extends XTestCase {
 
         Date actualTime = DateUtils.parseDateOozieTZ("2009-09-01T01:00Z");
         Date nominalTime = DateUtils.parseDateOozieTZ("2009-09-01T00:00Z");
-        String dataEvntXML = "<data-in name=\"A\" dataset=\"a\"><uris>" + getTestCaseFileUri("US/2009/1/30") + "|file:///tmp/coord/US/2009/1/31</uris>";
-        dataEvntXML += "<dataset name=\"a\" frequency=\"1440\" initial-instance=\"2009-01-01T00:00Z\"  freq_timeunit=\"MINUTE\" timezone=\"UTC\" end_of_duration=\"NONE\">";
+        String dataEvntXML = "<data-in name=\"A\" dataset=\"a\"><uris>" + getTestCaseFileUri("US/2009/1/30")
+                + "|file:///tmp/coord/US/2009/1/31</uris>";
+        dataEvntXML += "<dataset name=\"a\" frequency=\"1440\" initial-instance=\"2009-01-01T00:00Z\""
+                + "  freq_timeunit=\"MINUTE\" timezone=\"UTC\" end_of_duration=\"NONE\">";
         dataEvntXML += "<uri-template>" + getTestCaseFileUri("${YEAR}/${MONTH}/${DAY}") + "</uri-template></dataset></data-in>";
         Element dEvent = XmlUtils.parseXml(dataEvntXML);
         ELEvaluator eval = CoordELEvaluator.createLazyEvaluator(actualTime, nominalTime, dEvent, conf);
@@ -219,7 +228,8 @@ public class TestCoordELEvaluator extends XTestCase {
                         + "<property> <name>timeout</name>  <value>180</value>  </property> "
                         + "<property> <name>concurrency_level</name> <value>1</value> </property> "
                         + "<property> <name>execution_order</name> <value>LIFO</value> </property>"
-                        + "<property> <name>include_ds_files</name>  <value>file:///homes/" + getTestUser() + "/workspace/oozie-main/core/src/main/java/org/apache/oozie/coord/datasets.xml</value>"
+                        + "<property> <name>include_ds_files</name>  <value>file:///homes/" + getTestUser()
+                        + "/workspace/oozie-main/core/src/main/java/org/apache/oozie/coord/datasets.xml</value>"
                         + " </property></configuration>");
         return conf.toString();
     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForCheckJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForCheckJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForCheckJPAExecutor.java
index 05d93a8..5ffd837 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForCheckJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForCheckJPAExecutor.java
@@ -46,14 +46,18 @@ public class TestCoordActionGetForCheckJPAExecutor extends XDataTestCase {
     public void testCoordActionGet() throws Exception {
         int actionNum = 1;
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, false, false);
-        CoordinatorActionBean action = createCoordAction(job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = createCoordAction(
+                job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
         action.setSlaXml(XDataTestCase.slaXml);
         // Insert the action
         insertRecordCoordAction(action);
-        _testGetActionForCheck(action.getId(), job.getId(), CoordinatorAction.Status.WAITING, 0, action.getId() + "_E", XDataTestCase.slaXml);
+        _testGetActionForCheck(action.getId(), job.getId(), CoordinatorAction.Status.WAITING, 0, action.getId()
+                + "_E", XDataTestCase.slaXml);
     }
 
-    private void _testGetActionForCheck(String actionId, String jobId, CoordinatorAction.Status status, int pending, String extId, String slaXml) throws Exception {
+    private void _testGetActionForCheck(
+            String actionId, String jobId, CoordinatorAction.Status status, int pending, String extId, String slaXml)
+                    throws Exception {
         try {
             JPAService jpaService = Services.get().get(JPAService.class);
             assertNotNull(jpaService);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForExternalIdJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForExternalIdJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForExternalIdJPAExecutor.java
index 5b748f0..c35cf01 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForExternalIdJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionGetForExternalIdJPAExecutor.java
@@ -46,14 +46,18 @@ public class TestCoordActionGetForExternalIdJPAExecutor extends XDataTestCase {
     public void testCoordActionGet() throws Exception {
         int actionNum = 1;
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, false, false);
-        CoordinatorActionBean action = createCoordAction(job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = createCoordAction(
+                job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
         action.setSlaXml(XDataTestCase.slaXml);
      // Insert the action
         insertRecordCoordAction(action);
-        _testGetActionByExternalId(action.getId(), job.getId(), CoordinatorAction.Status.WAITING, 0, action.getId() + "_E", XDataTestCase.slaXml);
+        _testGetActionByExternalId(action.getId(), job.getId(), CoordinatorAction.Status.WAITING, 0, action.getId()
+                + "_E", XDataTestCase.slaXml);
     }
 
-    private void _testGetActionByExternalId(String actionId, String jobId, CoordinatorAction.Status status, int pending, String extId, String slaXml) throws Exception {
+    private void _testGetActionByExternalId(
+            String actionId, String jobId, CoordinatorAction.Status status, int pending, String extId, String slaXml)
+                    throws Exception {
         try {
             JPAService jpaService = Services.get().get(JPAService.class);
             assertNotNull(jpaService);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionsPendingFalseStatusCountGetJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionsPendingFalseStatusCountGetJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionsPendingFalseStatusCountGetJPAExecutor.java
index a35c987..fe50d90 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionsPendingFalseStatusCountGetJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordActionsPendingFalseStatusCountGetJPAExecutor.java
@@ -56,8 +56,9 @@ public class TestCoordActionsPendingFalseStatusCountGetJPAExecutor extends XData
     private void _testPendingFalseStatusCount(String jobId, int expected) throws Exception {
         JPAService jpaService = Services.get().get(JPAService.class);
         assertNotNull(jpaService);
-        CoordActionsPendingFalseStatusCountGetJPAExecutor actionSucceededCmd = new CoordActionsPendingFalseStatusCountGetJPAExecutor(
-                jobId, CoordinatorAction.Status.SUCCEEDED.toString());
+        CoordActionsPendingFalseStatusCountGetJPAExecutor actionSucceededCmd
+                = new CoordActionsPendingFalseStatusCountGetJPAExecutor(
+                        jobId, CoordinatorAction.Status.SUCCEEDED.toString());
         int cnt = jpaService.execute(actionSucceededCmd);
         assertEquals(cnt, expected);
     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionForNominalTimeJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionForNominalTimeJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionForNominalTimeJPAExecutor.java
index 3d90cdf..11968a3 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionForNominalTimeJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionForNominalTimeJPAExecutor.java
@@ -50,7 +50,8 @@ public class TestCoordJobGetActionForNominalTimeJPAExecutor extends XDataTestCas
     public void testCoordActionGet() throws Exception {
         int actionNum = 1;
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, false, false);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(
+                job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
 
         Path appPath = new Path(getFsTestCaseDir(), "coord");
         String actionXml = getCoordActionXml(appPath, "coord-action-get.xml");

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsJPAExecutor.java
index e9fa9f6..bfeb2e0 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsJPAExecutor.java
@@ -48,7 +48,8 @@ public class TestCoordJobGetActionsJPAExecutor extends XDataTestCase {
     public void testCoordActionGet() throws Exception {
         int actionNum = 1;
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, false, false);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(
+                job.getId(), actionNum, CoordinatorAction.Status.WAITING, "coord-action-get.xml", 0);
 
         _testGetActions(job.getId(), action.getId());
     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsSubsetJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsSubsetJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsSubsetJPAExecutor.java
index 9ccd62a..393d1f1 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsSubsetJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestCoordJobGetActionsSubsetJPAExecutor.java
@@ -200,7 +200,8 @@ public class TestCoordJobGetActionsSubsetJPAExecutor extends XDataTestCase {
         String resourceXmlName = "coord-action-get.xml";
         Date dummyCreationTime = new Date();
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, false, false);
-        CoordinatorActionBean action = createCoordAction(job.getId(), actionNum, CoordinatorAction.Status.WAITING, resourceXmlName, 0);
+        CoordinatorActionBean action = createCoordAction(
+                job.getId(), actionNum, CoordinatorAction.Status.WAITING, resourceXmlName, 0);
         // Add some attributes
         action.setConsoleUrl("consoleUrl");
         action.setExternalStatus("externalStatus");

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowIdGetForExternalIdJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowIdGetForExternalIdJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowIdGetForExternalIdJPAExecutor.java
index df57b72..8d3f9fe 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowIdGetForExternalIdJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowIdGetForExternalIdJPAExecutor.java
@@ -65,7 +65,8 @@ public class TestWorkflowIdGetForExternalIdJPAExecutor extends XDataTestCase {
     }
 
     @Override
-    protected WorkflowJobBean addRecordToWfJobTable(WorkflowJob.Status jobStatus, WorkflowInstance.Status instanceStatus) throws Exception {
+    protected WorkflowJobBean addRecordToWfJobTable(WorkflowJob.Status jobStatus, WorkflowInstance.Status instanceStatus)
+            throws Exception {
         WorkflowApp app =
             new LiteWorkflowApp("testApp", "<workflow-app/>",
                 new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "end")).

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowJobsGetForPurgeJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowJobsGetForPurgeJPAExecutor.java b/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowJobsGetForPurgeJPAExecutor.java
index 620dc6d..a569298 100644
--- a/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowJobsGetForPurgeJPAExecutor.java
+++ b/core/src/test/java/org/apache/oozie/executor/jpa/TestWorkflowJobsGetForPurgeJPAExecutor.java
@@ -97,7 +97,8 @@ public class TestWorkflowJobsGetForPurgeJPAExecutor extends XDataTestCase {
     }
 
     @Override
-    protected WorkflowJobBean addRecordToWfJobTable(WorkflowJob.Status jobStatus, WorkflowInstance.Status instanceStatus) throws Exception {
+    protected WorkflowJobBean addRecordToWfJobTable(WorkflowJob.Status jobStatus, WorkflowInstance.Status instanceStatus)
+            throws Exception {
         WorkflowApp app =
             new LiteWorkflowApp("testApp", "<workflow-app/>",
                 new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "end")).

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/jms/TestJMSSLAEventListener.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/jms/TestJMSSLAEventListener.java b/core/src/test/java/org/apache/oozie/jms/TestJMSSLAEventListener.java
index 30fd151..6f6792e 100644
--- a/core/src/test/java/org/apache/oozie/jms/TestJMSSLAEventListener.java
+++ b/core/src/test/java/org/apache/oozie/jms/TestJMSSLAEventListener.java
@@ -402,7 +402,7 @@ public class TestJMSSLAEventListener extends XTestCase {
         assertEquals(actualDuration, durationMissMsg.getActualDuration());
         assertEquals("notification of duration met", durationMissMsg.getNotificationMessage());
     }
-    
+
     private SLACalcStatus _createSLACalcStatus(String actionId) {
         SLARegistrationBean reg = new SLARegistrationBean();
         reg.setId(actionId);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestAuthorizationService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestAuthorizationService.java b/core/src/test/java/org/apache/oozie/service/TestAuthorizationService.java
index ca5b940..8df0904 100644
--- a/core/src/test/java/org/apache/oozie/service/TestAuthorizationService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestAuthorizationService.java
@@ -236,7 +236,7 @@ public class TestAuthorizationService extends XDataTestCase {
         URI uri = getFileSystem().getUri();
         Configuration fsConf = has.createConfiguration(uri.getAuthority());
         FileSystem fileSystem = has.createFileSystem(getTestUser(), uri, fsConf);
-        
+
         try {
             as.authorizeForGroup(getTestUser3(), getTestGroup());
             fail();

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestCallableQueueService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestCallableQueueService.java b/core/src/test/java/org/apache/oozie/service/TestCallableQueueService.java
index ebe8e48..9c2a11d 100644
--- a/core/src/test/java/org/apache/oozie/service/TestCallableQueueService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestCallableQueueService.java
@@ -540,9 +540,12 @@ public class TestCallableQueueService extends XTestCase {
 
     public void testQueueUniquenessWithSameKeyInComposite() throws Exception {
         EXEC_ORDER = new AtomicLong();
-        final MyCallable callable1 = new MyCallable("QueueUniquenessWithSameKeyInComposite", "QueueUniquenessWithSameKeyInComposite", 0, 200);
-        final MyCallable callable2 = new MyCallable("QueueUniquenessWithSameKeyInComposite", "QueueUniquenessWithSameKeyInComposite", 0, 200);
-        final MyCallable callable3 = new MyCallable("QueueUniquenessWithSameKeyInComposite", "QueueUniquenessWithSameKeyInComposite", 0, 200);
+        final MyCallable callable1 = new MyCallable(
+                "QueueUniquenessWithSameKeyInComposite", "QueueUniquenessWithSameKeyInComposite", 0, 200);
+        final MyCallable callable2 = new MyCallable(
+                "QueueUniquenessWithSameKeyInComposite", "QueueUniquenessWithSameKeyInComposite", 0, 200);
+        final MyCallable callable3 = new MyCallable(
+                "QueueUniquenessWithSameKeyInComposite", "QueueUniquenessWithSameKeyInComposite", 0, 200);
 
         List<MyCallable> callables = Arrays.asList(callable1, callable2, callable3);
 
@@ -566,9 +569,12 @@ public class TestCallableQueueService extends XTestCase {
 
     public void testQueueUniquenessWithSameKeyInOneComposite() throws Exception {
         EXEC_ORDER = new AtomicLong();
-        final MyCallable callable1 = new MyCallable("QueueUniquenessWithSameKeyInOneComposite", "QueueUniquenessWithSameKeyInOneComposite", 0, 100);
-        final MyCallable callable2 = new MyCallable("QueueUniquenessWithSameKeyInOneComposite", "QueueUniquenessWithSameKeyInOneComposite", 0, 100);
-        final MyCallable callable3 = new MyCallable("QueueUniquenessWithSameKeyInOneComposite", "QueueUniquenessWithSameKeyInOneComposite", 0, 100);
+        final MyCallable callable1 = new MyCallable(
+                "QueueUniquenessWithSameKeyInOneComposite", "QueueUniquenessWithSameKeyInOneComposite", 0, 100);
+        final MyCallable callable2 = new MyCallable(
+                "QueueUniquenessWithSameKeyInOneComposite", "QueueUniquenessWithSameKeyInOneComposite", 0, 100);
+        final MyCallable callable3 = new MyCallable(
+                "QueueUniquenessWithSameKeyInOneComposite", "QueueUniquenessWithSameKeyInOneComposite", 0, 100);
 
         CallableQueueService queueservice = Services.get().get(CallableQueueService.class);
 
@@ -612,9 +618,12 @@ public class TestCallableQueueService extends XTestCase {
 
     public void testQueueUniquenessWithDiffKeyInComposite() throws Exception {
         EXEC_ORDER = new AtomicLong();
-        final MyCallable callable1 = new MyCallable("QueueUniquenessWithDiffKeyInComposite1", "QueueUniquenessWithDiffKeyInComposite", 0, 100);
-        final MyCallable callable2 = new MyCallable("QueueUniquenessWithDiffKeyInComposite2", "QueueUniquenessWithDiffKeyInComposite", 0, 100);
-        final MyCallable callable3 = new MyCallable("QueueUniquenessWithDiffKeyInComposite3", "QueueUniquenessWithDiffKeyInComposite", 0, 100);
+        final MyCallable callable1 = new MyCallable(
+                "QueueUniquenessWithDiffKeyInComposite1", "QueueUniquenessWithDiffKeyInComposite", 0, 100);
+        final MyCallable callable2 = new MyCallable(
+                "QueueUniquenessWithDiffKeyInComposite2", "QueueUniquenessWithDiffKeyInComposite", 0, 100);
+        final MyCallable callable3 = new MyCallable(
+                "QueueUniquenessWithDiffKeyInComposite3", "QueueUniquenessWithDiffKeyInComposite", 0, 100);
 
         List<MyCallable> callables = Arrays.asList(callable1, callable2, callable3);
 
@@ -638,9 +647,12 @@ public class TestCallableQueueService extends XTestCase {
 
     public void testQueueUniquenessWithDiffKeyInOneComposite() throws Exception {
         EXEC_ORDER = new AtomicLong();
-        final MyCallable callable1 = new MyCallable("QueueUniquenessWithDiffKeyInOneComposite1", "QueueUniquenessWithDiffKeyInOneComposite", 0, 100);
-        final MyCallable callable2 = new MyCallable("QueueUniquenessWithDiffKeyInOneComposite2", "QueueUniquenessWithDiffKeyInOneComposite", 0, 100);
-        final MyCallable callable3 = new MyCallable("QueueUniquenessWithDiffKeyInOneComposite3", "QueueUniquenessWithDiffKeyInOneComposite", 0, 100);
+        final MyCallable callable1 = new MyCallable(
+                "QueueUniquenessWithDiffKeyInOneComposite1", "QueueUniquenessWithDiffKeyInOneComposite", 0, 100);
+        final MyCallable callable2 = new MyCallable(
+                "QueueUniquenessWithDiffKeyInOneComposite2", "QueueUniquenessWithDiffKeyInOneComposite", 0, 100);
+        final MyCallable callable3 = new MyCallable(
+                "QueueUniquenessWithDiffKeyInOneComposite3", "QueueUniquenessWithDiffKeyInOneComposite", 0, 100);
 
         CallableQueueService queueservice = Services.get().get(CallableQueueService.class);
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestCoordMaterializeTriggerService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestCoordMaterializeTriggerService.java b/core/src/test/java/org/apache/oozie/service/TestCoordMaterializeTriggerService.java
index aadf3fb..0be960c 100644
--- a/core/src/test/java/org/apache/oozie/service/TestCoordMaterializeTriggerService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestCoordMaterializeTriggerService.java
@@ -242,7 +242,9 @@ public class TestCoordMaterializeTriggerService extends XDataTestCase {
     }
 
     @Override
-    protected CoordinatorJobBean createCoordJob(CoordinatorJob.Status status, Date start, Date end, boolean pending, boolean doneMatd, int lastActionNum) throws Exception {
+    protected CoordinatorJobBean createCoordJob(
+            CoordinatorJob.Status status, Date start, Date end, boolean pending, boolean doneMatd, int lastActionNum)
+                    throws Exception {
         Path appPath = new Path(getFsTestCaseDir(), "coord");
         String appXml = writeCoordXml(appPath);
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestEventHandlerService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestEventHandlerService.java b/core/src/test/java/org/apache/oozie/service/TestEventHandlerService.java
index 53b7f62..c797d54 100644
--- a/core/src/test/java/org/apache/oozie/service/TestEventHandlerService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestEventHandlerService.java
@@ -228,7 +228,8 @@ public class TestEventHandlerService extends XDataTestCase {
 
             log = appender.getLog();
             logEntry = log.get(2);
-            assertTrue(logEntry.getMessage().toString().contains("APP[myapp] JOB[jobid2] ACTION[jobid2@1] Queueing event : ID: jobid2@1"));
+            assertTrue(logEntry.getMessage().toString()
+                    .contains("APP[myapp] JOB[jobid2] ACTION[jobid2@1] Queueing event : ID: jobid2@1"));
 
             WorkflowJobEvent event3 = new WorkflowJobEvent("jobid-other", "parentid", WorkflowJob.Status.RUNNING, getTestUser(),
                     "myapp-other", null, null);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestLiteWorkflowStoreService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestLiteWorkflowStoreService.java b/core/src/test/java/org/apache/oozie/service/TestLiteWorkflowStoreService.java
index 1eda445..06473d0 100644
--- a/core/src/test/java/org/apache/oozie/service/TestLiteWorkflowStoreService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestLiteWorkflowStoreService.java
@@ -57,7 +57,7 @@ public class TestLiteWorkflowStoreService extends XTestCase {
         testConf.set(LiteWorkflowStoreService.CONF_USER_RETRY_ERROR_CODE_EXT, " ");
         // Retrieval to enlist the codes properly, otherwise whitespaces cause the key-value lookup to return false
         Set<String> allowedRetryCodes = LiteWorkflowStoreService.getUserRetryErrorCode();
-        assertTrue(allowedRetryCodes.contains(ForTestingActionExecutor.TEST_ERROR));   
+        assertTrue(allowedRetryCodes.contains(ForTestingActionExecutor.TEST_ERROR));
     }
 
     public void testRetryAllErrorCode() throws Exception {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestRecoveryService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestRecoveryService.java b/core/src/test/java/org/apache/oozie/service/TestRecoveryService.java
index ce04c6d..78efd16 100644
--- a/core/src/test/java/org/apache/oozie/service/TestRecoveryService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestRecoveryService.java
@@ -377,7 +377,8 @@ public class TestRecoveryService extends XDataTestCase {
         waitFor(10000, new Predicate() {
             public boolean evaluate() throws Exception {
                 CoordinatorActionBean bean = ce.getCoordAction(actionId);
-                return (bean.getStatus() == CoordinatorAction.Status.RUNNING || bean.getStatus() == CoordinatorAction.Status.SUCCEEDED);
+                return (bean.getStatus() == CoordinatorAction.Status.RUNNING || bean.getStatus()
+                        == CoordinatorAction.Status.SUCCEEDED);
             }
         });
 
@@ -536,7 +537,8 @@ public class TestRecoveryService extends XDataTestCase {
 
     /**
      * Tests functionality of the Recovery Service Runnable command. </p> Insert a coordinator job with SUSPENDED and
-     * action with SUSPENDED and workflow with RUNNING. Then, runs the recovery runnable and ensures the workflow status changes to SUSPENDED.
+     * action with SUSPENDED and workflow with RUNNING. Then, runs the recovery runnable and ensures the workflow status
+     *  changes to SUSPENDED.
      *
      * @throws Exception
      */
@@ -573,7 +575,8 @@ public class TestRecoveryService extends XDataTestCase {
 
     /**
      * Tests functionality of the Recovery Service Runnable command. </p> Insert a coordinator job with KILLED and
-     * action with KILLED and workflow with RUNNING. Then, runs the recovery runnable and ensures the workflow status changes to KILLED.
+     * action with KILLED and workflow with RUNNING. Then, runs the recovery runnable and ensures the workflow
+     *  status changes to KILLED.
      *
      * @throws Exception
      */
@@ -610,7 +613,8 @@ public class TestRecoveryService extends XDataTestCase {
 
     /**
      * Tests functionality of the Recovery Service Runnable command. </p> Insert a coordinator job with RUNNING and
-     * action with RUNNING and workflow with SUSPENDED. Then, runs the recovery runnable and ensures the workflow status changes to RUNNING.
+     * action with RUNNING and workflow with SUSPENDED. Then, runs the recovery runnable and ensures the workflow status
+     *  changes to RUNNING.
      *
      * @throws Exception
      */
@@ -693,7 +697,9 @@ public class TestRecoveryService extends XDataTestCase {
         action.setLastModifiedTime(new Date());
         action.setStatus(CoordinatorAction.Status.SUBMITTED);
         String appPath = getTestCaseFileUri("one-op/workflow.xml");
-        String actionXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' xmlns:sla='uri:oozie:sla:0.1' name='NAME' frequency=\"1\" start='2009-02-01T01:00Z' end='2009-02-03T23:59Z' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'  instance-number=\"1\" action-nominal-time=\"2009-02-01T01:00Z\">";
+        String actionXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' xmlns:sla='uri:oozie:sla:0.1' name='NAME'"
+                + " frequency=\"1\" start='2009-02-01T01:00Z' end='2009-02-03T23:59Z' timezone='UTC' freq_timeunit='DAY'"
+                + " end_of_duration='NONE'  instance-number=\"1\" action-nominal-time=\"2009-02-01T01:00Z\">";
         actionXml += "<controls>";
         actionXml += "<timeout>10</timeout>";
         actionXml += "<concurrency>2</concurrency>";
@@ -701,7 +707,8 @@ public class TestRecoveryService extends XDataTestCase {
         actionXml += "</controls>";
         actionXml += "<input-events>";
         actionXml += "<data-in name='A' dataset='a'>";
-        actionXml += "<dataset name='a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        actionXml += "<dataset name='a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC'"
+                + " freq_timeunit='DAY' end_of_duration='NONE'>";
         actionXml += "<uri-template>" + getTestCaseFileUri("workflows/workflows/${YEAR}/${DAY}") + "</uri-template>";
         actionXml += "</dataset>";
         actionXml += "<instance>${coord:latest(0)}</instance>";
@@ -709,7 +716,8 @@ public class TestRecoveryService extends XDataTestCase {
         actionXml += "</input-events>";
         actionXml += "<output-events>";
         actionXml += "<data-out name='LOCAL_A' dataset='local_a'>";
-        actionXml += "<dataset name='local_a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        actionXml += "<dataset name='local_a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC'"
+                + " freq_timeunit='DAY' end_of_duration='NONE'>";
         actionXml += "<uri-template>" + getTestCaseFileUri("workflows/${YEAR}/${DAY}") + "</uri-template>";
         actionXml += "</dataset>";
         actionXml += "<instance>${coord:current(-1)}</instance>";
@@ -795,7 +803,8 @@ public class TestRecoveryService extends XDataTestCase {
 
         String confStr = "<configuration></configuration>";
         coordJob.setConf(confStr);
-        String appXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' name='NAME' frequency=\"1\" start='2009-02-01T01:00Z' end='2009-02-03T23:59Z'";
+        String appXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' name='NAME' frequency=\"1\" start='2009-02-01T01:00Z'"
+                + " end='2009-02-03T23:59Z'";
         appXml += " timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
         appXml += "<controls>";
         appXml += "<timeout>10</timeout>";
@@ -804,7 +813,8 @@ public class TestRecoveryService extends XDataTestCase {
         appXml += "</controls>";
         appXml += "<input-events>";
         appXml += "<data-in name='A' dataset='a'>";
-        appXml += "<dataset name='a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        appXml += "<dataset name='a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC'"
+                + " freq_timeunit='DAY' end_of_duration='NONE'>";
         appXml += "<uri-template>" + getTestCaseFileUri("workflows/${YEAR}/${DAY}") + "</uri-template>";
         appXml += "</dataset>";
         appXml += "<instance>${coord:latest(0)}</instance>";
@@ -812,7 +822,8 @@ public class TestRecoveryService extends XDataTestCase {
         appXml += "</input-events>";
         appXml += "<output-events>";
         appXml += "<data-out name='LOCAL_A' dataset='local_a'>";
-        appXml += "<dataset name='local_a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        appXml += "<dataset name='local_a' frequency='7' initial-instance='2009-02-01T01:00Z' timezone='UTC'"
+                + " freq_timeunit='DAY' end_of_duration='NONE'>";
         appXml += "<uri-template>" + getTestCaseFileUri("workflows/${YEAR}/${DAY}") + "</uri-template>";
         appXml += "</dataset>";
         appXml += "<instance>${coord:current(-1)}</instance>";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestSparkConfigurationService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestSparkConfigurationService.java b/core/src/test/java/org/apache/oozie/service/TestSparkConfigurationService.java
index 1278efa..b79d997 100644
--- a/core/src/test/java/org/apache/oozie/service/TestSparkConfigurationService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestSparkConfigurationService.java
@@ -85,8 +85,10 @@ public class TestSparkConfigurationService extends XTestCase {
         assertEquals("A", sparkConfigs.get("a"));
         assertEquals("B", sparkConfigs.get("b"));
         assertEquals("foo", sparkConfigs.get("spark.yarn.jar"));
-        ConfigurationService.setBoolean("oozie.service.SparkConfigurationService.spark.configurations.ignore.spark.yarn.jar", true);
-        ConfigurationService.set("oozie.service.SparkConfigurationService.spark.configurations.blacklist", "spark.yarn.jar,spark.yarn.jars");
+        ConfigurationService.setBoolean(
+                "oozie.service.SparkConfigurationService.spark.configurations.ignore.spark.yarn.jar", true);
+        ConfigurationService.set(
+                "oozie.service.SparkConfigurationService.spark.configurations.blacklist", "spark.yarn.jar,spark.yarn.jars");
         scs.destroy();
         ConfigurationService.set("oozie.service.SparkConfigurationService.spark.configurations",
                 "rm1=" + sparkConf1Dir.getAbsolutePath() +   // define

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/service/TestStatusTransitService.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/service/TestStatusTransitService.java b/core/src/test/java/org/apache/oozie/service/TestStatusTransitService.java
index 0bcbce0..a92cd87 100644
--- a/core/src/test/java/org/apache/oozie/service/TestStatusTransitService.java
+++ b/core/src/test/java/org/apache/oozie/service/TestStatusTransitService.java
@@ -558,7 +558,8 @@ public class TestStatusTransitService extends XDataTestCase {
     }
 
     /**
-     * Test : Keep the backward support for states on. 2 coord actions are running, 1 killed, check if job pending is reset and state changed to
+     * Test : Keep the backward support for states on. 2 coord actions are running, 1 killed, check if job pending is reset
+     *  and state changed to
      * RUNNING. Make sure the status is not RUNNINGWITHERROR
      *
      * @throws Exception
@@ -1422,7 +1423,8 @@ public class TestStatusTransitService extends XDataTestCase {
 
     /**
      * Tests functionality of the StatusTransitService Runnable command. </p> Insert a coordinator job with RUNNING and
-     * pending true and coordinator actions for that job with pending false. Insert a coordinator action with a stale coord job id. Then, runs the StatusTransitService runnable and ensures
+     * pending true and coordinator actions for that job with pending false. Insert a coordinator action with a stale coord
+     *  job id. Then, runs the StatusTransitService runnable and ensures
      * the job status of the good job changes to SUCCEEDED.
      *
      * @throws Exception

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/servlet/TestV1AdminServlet.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/servlet/TestV1AdminServlet.java b/core/src/test/java/org/apache/oozie/servlet/TestV1AdminServlet.java
index 8ec56dd..2f613ee 100644
--- a/core/src/test/java/org/apache/oozie/servlet/TestV1AdminServlet.java
+++ b/core/src/test/java/org/apache/oozie/servlet/TestV1AdminServlet.java
@@ -263,7 +263,7 @@ public class TestV1AdminServlet extends DagServletTestCase {
         });
 
     }
-    
+
     public void testAvailableTimeZones() throws Exception {
         runTest("/v1/admin/*", V1AdminServlet.class, IS_SECURITY_ENABLED, new Callable<Void>() {
             public Void call() throws Exception {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/servlet/TestV2SLAServlet.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/servlet/TestV2SLAServlet.java b/core/src/test/java/org/apache/oozie/servlet/TestV2SLAServlet.java
index 03f2323..d2bdb51 100644
--- a/core/src/test/java/org/apache/oozie/servlet/TestV2SLAServlet.java
+++ b/core/src/test/java/org/apache/oozie/servlet/TestV2SLAServlet.java
@@ -245,7 +245,8 @@ public class TestV2SLAServlet extends DagServletTestCase {
                 for(int i=0; i < array.size(); i++) {
                     json = (JSONObject) array.get(i);
                     id = (String)json.get(JsonTags.SLA_SUMMARY_ID);
-                    assertTrue(id.equals(cjBean1.getId()+"@2") || id.equals(cjBean2.getId()+"@1") || id.equals(cjBean2.getId()+"@2"));
+                    assertTrue(id.equals(cjBean1.getId()+"@2") || id.equals(cjBean2.getId()+"@1")
+                            || id.equals(cjBean2.getId()+"@2"));
                     parentId = (String) json.get(JsonTags.SLA_SUMMARY_PARENT_ID);
                     assertTrue(parentId.equals(cjBean1.getId()) || parentId.equals(cjBean2.getId()));
                 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/test/MiniOozieTestCase.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/test/MiniOozieTestCase.java b/core/src/test/java/org/apache/oozie/test/MiniOozieTestCase.java
index 12ede02..0a030d6 100644
--- a/core/src/test/java/org/apache/oozie/test/MiniOozieTestCase.java
+++ b/core/src/test/java/org/apache/oozie/test/MiniOozieTestCase.java
@@ -40,13 +40,15 @@ import org.apache.oozie.local.LocalOozie;
  * <p/>
  * The test working directory is created in the specified FS URI, under the current user name home directory, under the
  * subdirectory name specified wit the system property {@link XTestCase#OOZIE_TEST_DIR}. The default value is '/tmp'.
- * <p/> The path of the test working directory is: '$FS_URI/user/$USER/$OOZIE_TEST_DIR/oozietest/$TEST_CASE_CLASS/$TEST_CASE_METHOD/'
+ * <p/> The path of the test working directory is: '$FS_URI/user/$USER/$OOZIE_TEST_DIR/oozietest/$TEST_CASE_CLASS/
+ * $TEST_CASE_METHOD/'
  * <p/> For example: 'hdfs://localhost:9000/user/tucu/tmp/oozietest/org.apache.oozie.service.TestELService/testEL/'
  * <p/>
  * To run Oozie test, subclass create OozieClient via <code>OozieClient wc = getClient()</code> and submit Oozie job
  * with job properties and job xml.
  * <p/>
- * To check job's progress, subclass retrieve job object via <code>getJobInfo()</code> and then check job's status via <code>getStatus()</code>.
+ * To check job's progress, subclass retrieve job object via <code>getJobInfo()</code> and then check job's status via
+ *  <code>getStatus()</code>.
  * <p/>
  * For example,
  * <code>

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/test/XDataTestCase.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/test/XDataTestCase.java b/core/src/test/java/org/apache/oozie/test/XDataTestCase.java
index 2105e2f..a8fe703 100644
--- a/core/src/test/java/org/apache/oozie/test/XDataTestCase.java
+++ b/core/src/test/java/org/apache/oozie/test/XDataTestCase.java
@@ -417,7 +417,8 @@ public abstract class XDataTestCase extends XHCatTestCase {
      * @return coord job bean
      * @throws IOException
      */
-    protected CoordinatorJobBean createCoordJob(CoordinatorJob.Status status, Date start, Date end, Date createTime, boolean pending,
+    protected CoordinatorJobBean createCoordJob(
+            CoordinatorJob.Status status, Date start, Date end, Date createTime, boolean pending,
             boolean doneMatd, int lastActionNum) throws Exception {
         Path appPath = new Path(getFsTestCaseDir(), "coord");
         String appXml = writeCoordXml(appPath, start, end);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/test/XFsTestCase.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/test/XFsTestCase.java b/core/src/test/java/org/apache/oozie/test/XFsTestCase.java
index 2b33d93..80f5f45 100644
--- a/core/src/test/java/org/apache/oozie/test/XFsTestCase.java
+++ b/core/src/test/java/org/apache/oozie/test/XFsTestCase.java
@@ -44,7 +44,8 @@ import java.net.URI;
  *
  * The test working directory is created in the specified FS URI, under the current user name home directory, under the
  * subdirectory name specified wit the system property {@link XTestCase#OOZIE_TEST_DIR}. The default value is '/tmp'.
- * <p/> The path of the test working directory is: '$FS_URI/user/$USER/$OOZIE_TEST_DIR/oozietest/$TEST_CASE_CLASS/$TEST_CASE_METHOD/'
+ * <p/> The path of the test working directory is: '$FS_URI/user/$USER/$OOZIE_TEST_DIR/oozietest/$TEST_CASE_CLASS/
+ * $TEST_CASE_METHOD/'
  * <p/> For example: 'hdfs://localhost:9000/user/tucu/tmp/oozietest/org.apache.oozie.service.TestELService/testEL/'
  */
 public abstract class XFsTestCase extends XTestCase {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/util/TestCoordActionsInDateRange.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/util/TestCoordActionsInDateRange.java b/core/src/test/java/org/apache/oozie/util/TestCoordActionsInDateRange.java
index d8acc99..f35bbe5 100644
--- a/core/src/test/java/org/apache/oozie/util/TestCoordActionsInDateRange.java
+++ b/core/src/test/java/org/apache/oozie/util/TestCoordActionsInDateRange.java
@@ -117,11 +117,14 @@ public class TestCoordActionsInDateRange extends XDataTestCase {
               assertEquals(ErrorCode.E0308, e.getErrorCode());
             }
 
-            // Testing for the number of coordinator actions in a date range that spans from half an hour prior to the nominal time to 1 hour after the nominal time
-            int noOfActions = CoordActionsInDateRange.getCoordActionIdsFromDates(job.getId().toString(), date1 + "::" + date2).size();
+            // Testing for the number of coordinator actions in a date range that spans from half an hour prior to the nominal
+            // time to 1 hour after the nominal time
+            int noOfActions = CoordActionsInDateRange.getCoordActionIdsFromDates(job.getId().toString(), date1 + "::" + date2)
+                    .size();
             assertEquals(1, noOfActions);
 
-            // Testing for the number of coordinator actions in a date range that spans from half an hour after the nominal time to 1 hour after the nominal time
+            // Testing for the number of coordinator actions in a date range that spans from half an hour after the nominal
+            // time to 1 hour after the nominal time
             date1 = DateUtils.formatDateOozieTZ(new Date(nominalTimeMilliseconds + (noOfMillisecondsinOneHour / 2)));
             noOfActions = CoordActionsInDateRange.getCoordActionIdsFromDates(job.getId().toString(), date1 + "::" + date2).size();
             assertEquals(0, noOfActions);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/util/TestLogStreamer.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/util/TestLogStreamer.java b/core/src/test/java/org/apache/oozie/util/TestLogStreamer.java
index 3253512..7088870 100644
--- a/core/src/test/java/org/apache/oozie/util/TestLogStreamer.java
+++ b/core/src/test/java/org/apache/oozie/util/TestLogStreamer.java
@@ -256,7 +256,8 @@ public class TestLogStreamer extends XTestCase {
         xf.setLogLevel("DEBUG|INFO");
         XLogStreamer str2 = new XLogStreamer(xf, getTestCaseDir(), "oozie.log", 1);
         Calendar calendarEntry = Calendar.getInstance();
-        // Setting start-time to 2012-04-24-19 for log stream (month-1 passed as parameter since 0=January), and end time is current time
+        // Setting start-time to 2012-04-24-19 for log stream (month-1 passed as parameter since 0=January),
+        // and end time is current time
         calendarEntry.set(2012, 3, 24, 19, 0);
         str2.streamLog(sw2, calendarEntry.getTime(), new Date(System.currentTimeMillis()));
         String[] out = sw2.toString().split("\n");

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/util/TestOozieRollingPolicy.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/util/TestOozieRollingPolicy.java b/core/src/test/java/org/apache/oozie/util/TestOozieRollingPolicy.java
index 051ce56..3a54625 100644
--- a/core/src/test/java/org/apache/oozie/util/TestOozieRollingPolicy.java
+++ b/core/src/test/java/org/apache/oozie/util/TestOozieRollingPolicy.java
@@ -28,7 +28,7 @@ import org.apache.log4j.LogManager;
 import org.apache.oozie.test.XTestCase;
 
 public class TestOozieRollingPolicy extends XTestCase {
-    
+
     @Override
     protected void setUp() throws Exception {
         super.setUp();
@@ -61,8 +61,8 @@ public class TestOozieRollingPolicy extends XTestCase {
 
     private void _testDeletingOldFiles(String oozieLogName, int calendarUnit) throws IOException{
         // OozieRollingPolicy gets the log path and log name from XLogService by calling Services.get.get(XLogService.class) so we
-        // use a mock version where we overwrite the XLogService.getOozieLogName() and XLogService.getOozieLogPath() to simply 
-        // return these values instead of involving Services.  We then overwrite OozieRollingPolicy.getXLogService() to return the 
+        // use a mock version where we overwrite the XLogService.getOozieLogName() and XLogService.getOozieLogPath() to simply
+        // return these values instead of involving Services.  We then overwrite OozieRollingPolicy.getXLogService() to return the
         // mock one instead.
         String oozieLogPath = getTestCaseDir();
 
@@ -76,7 +76,7 @@ public class TestOozieRollingPolicy extends XTestCase {
 
         }
         orp.setMaxHistory(3);   // only keep 3 newest logs
-        
+
         Calendar cal = new GregorianCalendar();
         final File f0 = new File(oozieLogPath, oozieLogName);
         f0.createNewFile();
@@ -93,7 +93,7 @@ public class TestOozieRollingPolicy extends XTestCase {
         cal.add(calendarUnit, 1);
         final File f4 = new File(oozieLogPath, oozieLogName + formatDateForFilename(cal, calendarUnit) + ".gz");
         f4.createNewFile();
-        
+
         // Test that it only deletes the oldest file (f1)
         orp.isTriggeringEvent(null, null, null, 0);
         waitFor(60 * 1000, new Predicate() {
@@ -103,17 +103,17 @@ public class TestOozieRollingPolicy extends XTestCase {
             }
         });
         assertTrue(f0.exists() && !f1.exists() && f2.exists() && f3.exists() && f4.exists());
-        
+
         cal.add(calendarUnit, 1);
         final File f5 = new File(oozieLogPath, oozieLogName + formatDateForFilename(cal, calendarUnit));
         f5.createNewFile();
         f5.setLastModified(cal.getTimeInMillis());
-        
+
         cal.add(calendarUnit, -15);
         final File f6 = new File(oozieLogPath, oozieLogName + formatDateForFilename(cal, calendarUnit));
         f6.createNewFile();
         f6.setLastModified(cal.getTimeInMillis());
-        
+
         // Test that it can delete more than one file when necessary and that it works with non .gz files
         orp.isTriggeringEvent(null, null, null, 0);
         waitFor(60 * 1000, new Predicate() {
@@ -123,18 +123,18 @@ public class TestOozieRollingPolicy extends XTestCase {
             }
         });
         assertTrue(f0.exists() && !f1.exists() && !f2.exists() && f3.exists() && f4.exists() && f5.exists() && !f6.exists());
-        
+
         final File f7 = new File(oozieLogPath, "blah.txt");
         f7.createNewFile();
         f7.setLastModified(cal.getTimeInMillis());
-        
+
         cal.add(calendarUnit, 1);
         final File f8 = new File(oozieLogPath, oozieLogName + formatDateForFilename(cal, calendarUnit));
         cal.add(calendarUnit, 15);
         f8.createNewFile();
         f8.setLastModified(cal.getTimeInMillis());
-        
-        // Test that it ignores "other" files even if they are oldest and test that it uses the modified time for non .gz files 
+
+        // Test that it ignores "other" files even if they are oldest and test that it uses the modified time for non .gz files
         // (instead of the time from the filename)
         orp.isTriggeringEvent(null, null, null, 0);
         waitFor(60 * 1000, new Predicate() {
@@ -144,11 +144,11 @@ public class TestOozieRollingPolicy extends XTestCase {
                         f7.exists() && f8.exists());
             }
         });
-        assertTrue(f0.exists() && !f1.exists() && !f2.exists() && !f3.exists() && f4.exists() && f5.exists() && !f6.exists() && 
+        assertTrue(f0.exists() && !f1.exists() && !f2.exists() && !f3.exists() && f4.exists() && f5.exists() && !f6.exists() &&
                    f7.exists() && f8.exists());
     }
 
-    
+
     private String formatDateForFilename(Calendar cal, int calendarUnit) {
         int year = cal.get(Calendar.YEAR);
         int month = cal.get(Calendar.MONTH) + 1;

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/util/TestParameterVerifier.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/util/TestParameterVerifier.java b/core/src/test/java/org/apache/oozie/util/TestParameterVerifier.java
index 8cd89cb..15bd99a 100644
--- a/core/src/test/java/org/apache/oozie/util/TestParameterVerifier.java
+++ b/core/src/test/java/org/apache/oozie/util/TestParameterVerifier.java
@@ -31,37 +31,37 @@ public class TestParameterVerifier extends XTestCase {
         } catch (IllegalArgumentException ex) {
             assertEquals("conf cannot be null", ex.getMessage());
         }
-        
+
         Configuration conf = new Configuration(false);
         conf.set("A", "a");
         ParameterVerifier.verifyParameters(conf, null);
         assertEquals(1, conf.size());
         assertEquals("a", conf.get("A"));
-        
+
         try {
             ParameterVerifier.verifyParameters(null, null);
         } catch (IllegalArgumentException ex) {
             assertEquals("conf cannot be null", ex.getMessage());
         }
     }
-    
+
     public void testVerifyParametersEmpty() throws Exception {
         Configuration conf = new Configuration(false);
         conf.set("A", "a");
-        
+
         ParameterVerifier.verifyParameters(conf, XmlUtils.parseXml("<root xmlns=\"uri:oozie:workflow:0.4\"></root>"));
         assertEquals(1, conf.size());
         assertEquals("a", conf.get("A"));
-        
+
         ParameterVerifier.verifyParameters(conf, XmlUtils.parseXml("<root xmlns=\"uri:oozie:workflow:0.4\">"
                 + "<parameters></parameters></root>"));
         assertEquals(1, conf.size());
         assertEquals("a", conf.get("A"));
     }
-    
+
     public void testVerifyParametersMissing() throws Exception {
         Configuration conf = new Configuration(false);
-        
+
         String str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name>hello</name></property>"
                 + "</parameters></root>";
@@ -74,18 +74,18 @@ public class TestParameterVerifier extends XTestCase {
             assertTrue(ex.getMessage().contains("1"));
             assertEquals(0, conf.size());
         }
-        
+
         conf = new Configuration(false);
-        
+
         str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name>hello</name><value>world</value></property>"
                 + "</parameters></root>";
         ParameterVerifier.verifyParameters(conf, XmlUtils.parseXml(str));
         assertEquals(1, conf.size());
         assertEquals("world", conf.get("hello"));
-        
+
         conf = new Configuration(false);
-        
+
         str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name>hello</name></property>"
                 + "<property><name>foo</name><value>bar</value></property>"
@@ -103,18 +103,18 @@ public class TestParameterVerifier extends XTestCase {
             assertEquals("bar", conf.get("foo"));
         }
     }
-    
+
     public void testVerifyParametersDefined() throws Exception {
         Configuration conf = new Configuration(false);
         conf.set("hello", "planet");
-        
+
         String str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name>hello</name></property>"
                 + "</parameters></root>";
         ParameterVerifier.verifyParameters(conf, XmlUtils.parseXml(str));
         assertEquals(1, conf.size());
         assertEquals("planet", conf.get("hello"));
-        
+
         str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name>hello</name><value>world</value></property>"
                 + "</parameters></root>";
@@ -122,10 +122,10 @@ public class TestParameterVerifier extends XTestCase {
         assertEquals(1, conf.size());
         assertEquals("planet", conf.get("hello"));
     }
-    
+
     public void testVerifyParametersEmptyName() throws Exception {
         Configuration conf = new Configuration(false);
-        
+
         String str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name></name></property>"
                 + "</parameters></root>";
@@ -135,7 +135,7 @@ public class TestParameterVerifier extends XTestCase {
         } catch(ParameterVerifierException ex) {
             assertEquals(ErrorCode.E0739, ex.getErrorCode());
         }
-        
+
         str = "<root xmlns=\"uri:oozie:workflow:0.4\"><parameters>"
                 + "<property><name>hello</name></property>"
                 + "<property><name></name></property>"
@@ -147,20 +147,20 @@ public class TestParameterVerifier extends XTestCase {
             assertEquals(ErrorCode.E0739, ex.getErrorCode());
         }
     }
-    
+
     public void testSupportsParameters() throws Exception {
         assertFalse(ParameterVerifier.supportsParameters("uri:oozie:workflow:0.3"));
         assertTrue(ParameterVerifier.supportsParameters("uri:oozie:workflow:0.4"));
         assertTrue(ParameterVerifier.supportsParameters("uri:oozie:workflow:0.5"));
-        
+
         assertFalse(ParameterVerifier.supportsParameters("uri:oozie:coordinator:0.3"));
         assertTrue(ParameterVerifier.supportsParameters("uri:oozie:coordinator:0.4"));
         assertTrue(ParameterVerifier.supportsParameters("uri:oozie:coordinator:0.5"));
-        
+
         assertFalse(ParameterVerifier.supportsParameters("uri:oozie:bundle:0.1"));
         assertTrue(ParameterVerifier.supportsParameters("uri:oozie:bundle:0.2"));
         assertTrue(ParameterVerifier.supportsParameters("uri:oozie:bundle:0.3"));
-        
+
         assertFalse(ParameterVerifier.supportsParameters("uri:oozie:foo:0.4"));
         assertFalse(ParameterVerifier.supportsParameters("foo"));
     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/util/TestXLogFilter.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/util/TestXLogFilter.java b/core/src/test/java/org/apache/oozie/util/TestXLogFilter.java
index ec712c9..f29bf71 100644
--- a/core/src/test/java/org/apache/oozie/util/TestXLogFilter.java
+++ b/core/src/test/java/org/apache/oozie/util/TestXLogFilter.java
@@ -79,13 +79,21 @@ public class TestXLogFilter extends XTestCase {
     private int matches(XLogFilter xf) {
         xf.constructPattern();
         ArrayList<String> a = new ArrayList<String>();
-        a.add("2009-06-24 02:43:13,958 DEBUG WorkflowRunnerCallable:323 - USER[oozie] GROUP[-] TOKEN[-] APP[example-forkjoinwf] JOB[14-200904160239--example-forkjoinwf] ACTION[-] End workflow state change");
-        a.add("2009-06-24 02:43:13,961  INFO WorkflowRunnerCallable:317 - USER[-] GROUP[-] TOKEN[-] APP[example-forkjoinwf] JOB[14-200904160239--example-forkjoinwf] ACTION[-] [org.apache.oozie.core.command.WorkflowRunnerCallable] released lock");
-        a.add("2009-06-24 02:43:13,986  WARN JobClient:539 - Use GenericOptionsParser for parsing the arguments. Applications should implement Tool for the same.");
-        a.add("2009-06-24 02:43:14,431  WARN JobClient:661 - No job jar file set.  User classes may not be found. See JobConf(Class) or JobConf#setJar(String).");
-        a.add("2009-06-24 02:43:14,505  INFO ActionExecutorCallable:317 - USER[oozie] GROUP[oozie] TOKEN[-] APP[-] JOB[-] ACTION[-] Released Lock");
-        a.add("2009-06-24 02:43:19,344 DEBUG PendingSignalsCallable:323 - USER[oozie] GROUP[oozie] TOKEN[MYtoken] APP[-] JOB[-] ACTION[-] Number of pending signals to check [0]");
-        a.add("2009-06-24 02:43:29,151 DEBUG PendingActionsCallable:323 - USER[-] GROUP[-] TOKEN[-] APP[-] JOB[-] ACTION[-] Number of pending actions [0] ");
+        a.add("2009-06-24 02:43:13,958 DEBUG WorkflowRunnerCallable:323 - USER[oozie] GROUP[-] TOKEN[-] APP[example-forkjoinwf]"
+                + " JOB[14-200904160239--example-forkjoinwf] ACTION[-] End workflow state change");
+        a.add("2009-06-24 02:43:13,961  INFO WorkflowRunnerCallable:317 - USER[-] GROUP[-] TOKEN[-] APP[example-forkjoinwf]"
+                + " JOB[14-200904160239--example-forkjoinwf] ACTION[-] [org.apache.oozie.core.command.WorkflowRunnerCallable]"
+                + " released lock");
+        a.add("2009-06-24 02:43:13,986  WARN JobClient:539 - Use GenericOptionsParser for parsing the arguments. Applications"
+                + " should implement Tool for the same.");
+        a.add("2009-06-24 02:43:14,431  WARN JobClient:661 - No job jar file set.  User classes may not be found. See JobConf"
+                + "(Class) or JobConf#setJar(String).");
+        a.add("2009-06-24 02:43:14,505  INFO ActionExecutorCallable:317 - USER[oozie] GROUP[oozie] TOKEN[-] APP[-] JOB[-]"
+                + " ACTION[-] Released Lock");
+        a.add("2009-06-24 02:43:19,344 DEBUG PendingSignalsCallable:323 - USER[oozie] GROUP[oozie] TOKEN[MYtoken] APP[-] JOB[-]"
+                + " ACTION[-] Number of pending signals to check [0]");
+        a.add("2009-06-24 02:43:29,151 DEBUG PendingActionsCallable:323 - USER[-] GROUP[-] TOKEN[-] APP[-] JOB[-] ACTION[-]"
+                + " Number of pending actions [0] ");
         int matchCnt = 0;
         for (int i = 0; i < a.size(); i++) {
             if (xf.matches(xf.splitLogMessage(a.get(i)))) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/util/db/TestSqlStatement.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/util/db/TestSqlStatement.java b/core/src/test/java/org/apache/oozie/util/db/TestSqlStatement.java
index 91a1698..d5055a2 100644
--- a/core/src/test/java/org/apache/oozie/util/db/TestSqlStatement.java
+++ b/core/src/test/java/org/apache/oozie/util/db/TestSqlStatement.java
@@ -111,7 +111,8 @@ public class TestSqlStatement extends XTestCase {
         assertEquals(5, checkIdAndName(rsReader));
 
         rsReader = parse(selectColumns(TEST_STRING, TEST_LONG).where(isLike(TEST_STRING, names[0])).orderBy(TEST_LONG,
-                                                                                                            true).prepareAndSetValues(conn).executeQuery());
+                                                                                                            true)
+                .prepareAndSetValues(conn).executeQuery());
         assertEquals(1, checkIdAndName(rsReader));
 
         rsReader = parse(selectColumns(TEST_STRING, TEST_LONG).where(isNotLike(TEST_STRING, names[4])).orderBy(
@@ -131,7 +132,8 @@ public class TestSqlStatement extends XTestCase {
         assertEquals(3, checkIdAndName(rsReader));
 
         rsReader = parse(selectColumns(TEST_STRING, TEST_LONG).where(lessThanOrEqual(TEST_LONG, 3)).orderBy(TEST_LONG,
-                                                                                                            true).prepareAndSetValues(conn).executeQuery());
+                                                                                                            true)
+                .prepareAndSetValues(conn).executeQuery());
         assertEquals(4, checkIdAndName(rsReader));
 
         ResultSet rs = getCount(TEST_TABLE).where(greaterThan(TEST_LONG, 3)).prepareAndSetValues(conn).executeQuery();
@@ -208,7 +210,8 @@ public class TestSqlStatement extends XTestCase {
 
         currTime = new java.sql.Timestamp(Calendar.getInstance().getTimeInMillis());
         SqlStatement stmt = insertInto(TEST_TABLE).value(TEST_LONG, "1").value(TEST_STRING, "2").value(TEST_BOOLEAN,
-                                                                                                       "3").value(TEST_TIMESTAMP, "4").value(TEST_BLOB, "5");
+                                                                                                       "3")
+                .value(TEST_TIMESTAMP, "4").value(TEST_BLOB, "5");
         Map<Object, Object> values = new HashMap<Object, Object>();
         values.put("1", i);
         values.put("2", names[i]);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowApp.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowApp.java b/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowApp.java
index 74c1618..2026439 100644
--- a/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowApp.java
+++ b/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowApp.java
@@ -48,7 +48,8 @@ public class TestLiteWorkflowApp extends XTestCase {
     @Test
     public void testReadWrite() throws Exception{
         String definition = "test"+ RandomStringUtils.random(100 * 1024);
-        LiteWorkflowApp app = new LiteWorkflowApp("name", definition, new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "foo"));
+        LiteWorkflowApp app = new LiteWorkflowApp(
+                "name", definition, new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "foo"));
         app.addNode(new EndNodeDef("foo", LiteWorkflowStoreService.LiteControlNodeHandler.class));
         ByteArrayOutputStream baos= new ByteArrayOutputStream();
         DataOutputStream out = new DataOutputStream(baos);
@@ -68,7 +69,8 @@ public class TestLiteWorkflowApp extends XTestCase {
     @Test
     public void testOldFormatRead() throws Exception{
         String definition = Strings.repeat("abcdefghijk", 6234);
-        LiteWorkflowApp app = new LiteWorkflowApp("name", definition, new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "foo"));
+        LiteWorkflowApp app = new LiteWorkflowApp(
+                "name", definition, new StartNodeDef(LiteWorkflowStoreService.LiteControlNodeHandler.class, "foo"));
         app.addNode(new EndNodeDef("foo", LiteWorkflowStoreService.LiteControlNodeHandler.class));
         DataInputStream in = new DataInputStream(IOUtils.getResourceAsStream("oldWorkFlowApp.serialized", -1));
         LiteWorkflowApp app2 = new LiteWorkflowApp();

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowAppParser.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowAppParser.java b/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowAppParser.java
index f5baf6b..61e386c 100644
--- a/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowAppParser.java
+++ b/core/src/test/java/org/apache/oozie/workflow/lite/TestLiteWorkflowAppParser.java
@@ -603,7 +603,8 @@ public class TestLiteWorkflowAppParser extends XTestCase {
     public void testParserGlobalLauncherAM() throws Exception {
         LiteWorkflowAppParser parser = newLiteWorkflowAppParser();
 
-        LiteWorkflowApp workflowApp = parser.validateAndParse(IOUtils.getResourceAsReader("wf-schema-global-launcherconf.xml", -1), new Configuration());
+        LiteWorkflowApp workflowApp = parser.validateAndParse(
+                IOUtils.getResourceAsReader("wf-schema-global-launcherconf.xml", -1), new Configuration());
 
         XConfiguration xconf = extractConfig(workflowApp, "action1");
 
@@ -620,7 +621,8 @@ public class TestLiteWorkflowAppParser extends XTestCase {
     public void testParserGlobalLauncherAMOverridden() throws Exception {
         LiteWorkflowAppParser parser = newLiteWorkflowAppParser();
 
-        LiteWorkflowApp workflowApp = parser.validateAndParse(IOUtils.getResourceAsReader("wf-schema-global-launcherconf-override.xml", -1), new Configuration());
+        LiteWorkflowApp workflowApp = parser.validateAndParse(
+                IOUtils.getResourceAsReader("wf-schema-global-launcherconf-override.xml", -1), new Configuration());
 
         XConfiguration xconf = extractConfig(workflowApp, "a");