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:30 UTC

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

Repository: oozie
Updated Branches:
  refs/heads/master 91c3d0c02 -> 4f4049347


http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/resources/test-custom-log4j.properties
----------------------------------------------------------------------
diff --git a/core/src/test/resources/test-custom-log4j.properties b/core/src/test/resources/test-custom-log4j.properties
index 747df01..8dd43a0 100644
--- a/core/src/test/resources/test-custom-log4j.properties
+++ b/core/src/test/resources/test-custom-log4j.properties
@@ -6,9 +6,9 @@
 # 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.

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/resources/test-oozie-log4j.properties
----------------------------------------------------------------------
diff --git a/core/src/test/resources/test-oozie-log4j.properties b/core/src/test/resources/test-oozie-log4j.properties
index 3040d4f..0524fb9 100644
--- a/core/src/test/resources/test-oozie-log4j.properties
+++ b/core/src/test/resources/test-oozie-log4j.properties
@@ -6,9 +6,9 @@
 # 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.

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/release-log.txt
----------------------------------------------------------------------
diff --git a/release-log.txt b/release-log.txt
index 84880ca..9a434d3 100644
--- a/release-log.txt
+++ b/release-log.txt
@@ -1,5 +1,6 @@
 -- Oozie 5.0.0 release (trunk - unreleased)
 
+OOZIE-3176 Oozie-core fails with checkstyle errors (alishap via andras.piros)
 OOZIE-2726 Flaky test due to daylight saving changes (sasishsaley, andras.piros via gezapeti)
 OOZIE-2645 Deprecate Instrumentation in favor of Metrics (andras.piros via gezapeti)
 OOZIE-3150 Remove references to not present dependencies within NOTICE.txt (gezapeti via andras.piros)

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/src/main/resources/checkstyle-header.txt
----------------------------------------------------------------------
diff --git a/src/main/resources/checkstyle-header.txt b/src/main/resources/checkstyle-header.txt
deleted file mode 100644
index 4247452..0000000
--- a/src/main/resources/checkstyle-header.txt
+++ /dev/null
@@ -1,17 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/src/main/resources/checkstyle.xml
----------------------------------------------------------------------
diff --git a/src/main/resources/checkstyle.xml b/src/main/resources/checkstyle.xml
index 68b6cce..d2489d1 100644
--- a/src/main/resources/checkstyle.xml
+++ b/src/main/resources/checkstyle.xml
@@ -26,10 +26,6 @@
 		<property name="message" value="Line has trailing spaces."/>
 	</module>
 
-	<module name="Header">
-		<property name="headerFile" value="${checkstyle.header.file}"/>
-	</module>
-
     <module name="TreeWalker">
 
 		<module name="LineLength">


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

Posted by an...@apache.org.
OOZIE-3176 Oozie-core fails with checkstyle errors (alishap via andras.piros)


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

Branch: refs/heads/master
Commit: 4f40493474ce60002e6bf2bcc1e67ac6701c6dd3
Parents: 91c3d0c
Author: Andras Piros <an...@cloudera.com>
Authored: Tue Mar 27 12:20:38 2018 +0200
Committer: Andras Piros <an...@cloudera.com>
Committed: Tue Mar 27 12:20:38 2018 +0200

----------------------------------------------------------------------
 .../java/org/apache/oozie/BundleActionBean.java |  52 +++--
 .../java/org/apache/oozie/BundleJobBean.java    |  74 +++++---
 .../org/apache/oozie/CoordinatorActionBean.java | 189 ++++++++++++++-----
 .../org/apache/oozie/CoordinatorJobBean.java    | 143 ++++++++++----
 .../org/apache/oozie/CoordinatorJobInfo.java    |   2 +-
 .../java/org/apache/oozie/DagELFunctions.java   |   3 +-
 .../java/org/apache/oozie/SLAEventBean.java     |   3 +-
 .../org/apache/oozie/WorkflowActionBean.java    | 104 +++++++---
 .../java/org/apache/oozie/WorkflowJobBean.java  |  91 ++++++---
 .../oozie/action/hadoop/JavaActionExecutor.java |   3 +-
 .../org/apache/oozie/client/rest/JsonBean.java  |   2 +-
 .../bundle/BundleJobSuspendXCommand.java        |   9 +-
 .../coord/CoordActionInputCheckXCommand.java    |   3 +-
 .../command/coord/CoordActionStartXCommand.java |   9 +-
 .../command/coord/CoordChangeXCommand.java      |   6 +-
 .../oozie/command/coord/CoordCommandUtils.java  |   3 +-
 .../CoordMaterializeTransitionXCommand.java     |   4 +-
 .../coord/CoordPushDependencyCheckXCommand.java |   3 +-
 .../command/coord/CoordResumeXCommand.java      |   3 +-
 .../command/coord/CoordSubmitXCommand.java      |  15 +-
 .../command/coord/CoordSuspendXCommand.java     |   3 +-
 .../oozie/command/wf/ActionEndXCommand.java     |   6 +-
 .../oozie/command/wf/ActionKillXCommand.java    |   6 +-
 .../oozie/command/wf/ActionStartXCommand.java   |   9 +-
 .../apache/oozie/command/wf/ActionXCommand.java |   3 +-
 .../java/org/apache/oozie/coord/CoordUtils.java |   3 +-
 .../org/apache/oozie/coord/HCatELFunctions.java |   6 +-
 ...undleJobsGetRunningOrPendingJPAExecutor.java |   3 +-
 .../jpa/CoordActionRemoveJPAExecutor.java       |   2 +-
 ...ordJobGetRunningActionsCountJPAExecutor.java |   2 +-
 ...WorkflowActionRetryManualGetJPAExecutor.java |   2 +-
 ...flowInfoWithActionsSubsetGetJPAExecutor.java |   2 +-
 .../jpa/WorkflowJobsBasicInfoFromParentId.java  |   2 +-
 .../oozie/service/AuthorizationService.java     |   3 +-
 .../org/apache/oozie/service/PurgeService.java  |   3 +-
 .../apache/oozie/servlet/JsonRestServlet.java   |   2 +-
 .../apache/oozie/servlet/ServletUtilities.java  |   6 +-
 .../apache/oozie/servlet/V0AdminServlet.java    |   3 +-
 .../org/apache/oozie/servlet/V0JobsServlet.java |   6 +-
 .../org/apache/oozie/servlet/V1JobServlet.java  |   3 +-
 .../apache/oozie/sla/SLARegistrationBean.java   |  22 ++-
 .../org/apache/oozie/sla/SLASummaryBean.java    |  29 ++-
 .../sla/listener/SLAEmailEventListener.java     |   6 +-
 .../org/apache/oozie/store/WorkflowStore.java   |  21 ++-
 .../apache/oozie/util/OozieRollingPolicy.java   |  25 +--
 .../apache/oozie/util/ParameterVerifier.java    |  14 +-
 .../oozie/util/ParameterVerifierException.java  |   4 +-
 .../oozie/util/PollablePriorityDelayQueue.java  |   3 +-
 .../java/org/apache/oozie/util/db/Schema.java   |   6 +-
 .../oozie/workflow/lite/ActionNodeDef.java      |   6 +-
 .../oozie/workflow/lite/DBLiteWorkflowLib.java  |   3 +-
 .../workflow/lite/LiteWorkflowAppParser.java    |   3 +-
 .../main/resources/localoozie-log4j.properties  |   4 +-
 .../org/apache/hadoop/examples/SleepJob.java    |  24 +--
 .../org/apache/oozie/TestCoordinatorEngine.java |  18 +-
 .../apache/oozie/TestLocalOozieClientCoord.java |   6 +-
 .../oozie/action/hadoop/InsertTestToken.java    |   3 +-
 .../action/hadoop/TestHadoopELFunctions.java    |   6 +-
 .../action/hadoop/TestJavaActionExecutor.java   |   3 +-
 .../action/hadoop/TestShellActionExecutor.java  |   3 +-
 .../command/bundle/TestBundleJobXCommand.java   |   4 +-
 .../bundle/TestBundlePauseUnpauseXCommand.java  |   8 +-
 .../command/bundle/TestBundleRerunXCommand.java |   6 +-
 .../bundle/TestBundleSubmitXCommand.java        |   2 +-
 .../oozie/command/coord/CoordXTestCase.java     |   2 +-
 .../TestCoordActionInputCheckXCommand.java      |   9 +-
 .../coord/TestCoordActionStartXCommand.java     |   6 +-
 .../command/coord/TestCoordChangeXCommand.java  |   9 +-
 .../command/coord/TestCoordKillXCommand.java    |  15 +-
 .../command/coord/TestCoordRerunXCommand.java   |   5 +-
 .../command/coord/TestCoordSubmitXCommand.java  | 133 ++++++++-----
 .../command/coord/TestCoordUpdateXCommand.java  |   3 +-
 .../command/coord/TestFutureActionsTimeOut.java |   3 +-
 .../command/coord/TestPastActionsTimeOut.java   |   6 +-
 .../command/wf/TestActionCheckXCommand.java     |  24 ++-
 .../oozie/command/wf/TestActionErrors.java      |   9 +-
 .../command/wf/TestActionStartXCommand.java     |  21 ++-
 .../oozie/command/wf/TestReRunXCommand.java     |   3 +-
 .../oozie/coord/TestCoordELEvaluator.java       |  30 ++-
 .../TestCoordActionGetForCheckJPAExecutor.java  |  10 +-
 ...tCoordActionGetForExternalIdJPAExecutor.java |  10 +-
 ...nsPendingFalseStatusCountGetJPAExecutor.java |   5 +-
 ...rdJobGetActionForNominalTimeJPAExecutor.java |   3 +-
 .../jpa/TestCoordJobGetActionsJPAExecutor.java  |   3 +-
 ...TestCoordJobGetActionsSubsetJPAExecutor.java |   3 +-
 ...stWorkflowIdGetForExternalIdJPAExecutor.java |   3 +-
 .../TestWorkflowJobsGetForPurgeJPAExecutor.java |   3 +-
 .../oozie/jms/TestJMSSLAEventListener.java      |   2 +-
 .../oozie/service/TestAuthorizationService.java |   2 +-
 .../oozie/service/TestCallableQueueService.java |  36 ++--
 .../TestCoordMaterializeTriggerService.java     |   4 +-
 .../oozie/service/TestEventHandlerService.java  |   3 +-
 .../service/TestLiteWorkflowStoreService.java   |   2 +-
 .../oozie/service/TestRecoveryService.java      |  31 ++-
 .../service/TestSparkConfigurationService.java  |   6 +-
 .../oozie/service/TestStatusTransitService.java |   6 +-
 .../oozie/servlet/TestV1AdminServlet.java       |   2 +-
 .../apache/oozie/servlet/TestV2SLAServlet.java  |   3 +-
 .../apache/oozie/test/MiniOozieTestCase.java    |   6 +-
 .../org/apache/oozie/test/XDataTestCase.java    |   3 +-
 .../java/org/apache/oozie/test/XFsTestCase.java |   3 +-
 .../oozie/util/TestCoordActionsInDateRange.java |   9 +-
 .../org/apache/oozie/util/TestLogStreamer.java  |   3 +-
 .../oozie/util/TestOozieRollingPolicy.java      |  28 +--
 .../oozie/util/TestParameterVerifier.java       |  42 ++---
 .../org/apache/oozie/util/TestXLogFilter.java   |  22 ++-
 .../apache/oozie/util/db/TestSqlStatement.java  |   9 +-
 .../workflow/lite/TestLiteWorkflowApp.java      |   6 +-
 .../lite/TestLiteWorkflowAppParser.java         |   6 +-
 .../test/resources/test-custom-log4j.properties |   4 +-
 .../test/resources/test-oozie-log4j.properties  |   4 +-
 release-log.txt                                 |   1 +
 src/main/resources/checkstyle-header.txt        |  17 --
 src/main/resources/checkstyle.xml               |   4 -
 114 files changed, 1068 insertions(+), 539 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/BundleActionBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/BundleActionBean.java b/core/src/main/java/org/apache/oozie/BundleActionBean.java
index eeec549..f5f3278 100644
--- a/core/src/main/java/org/apache/oozie/BundleActionBean.java
+++ b/core/src/main/java/org/apache/oozie/BundleActionBean.java
@@ -43,39 +43,61 @@ import org.json.simple.JSONObject;
 @Entity
 @Table(name = "BUNDLE_ACTIONS")
 @NamedQueries( {
-        @NamedQuery(name = "DELETE_BUNDLE_ACTION", query = "delete from BundleActionBean w where w.bundleActionId = :bundleActionId"),
+        @NamedQuery(name = "DELETE_BUNDLE_ACTION", query = "delete from BundleActionBean w where w.bundleActionId"
+                + " = :bundleActionId"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_ACTION_PENDING_MODTIME", query = "update BundleActionBean w set w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.bundleActionId = :bundleActionId"),
+        @NamedQuery(name = "UPDATE_BUNDLE_ACTION_PENDING_MODTIME", query = "update BundleActionBean w set w.lastModifiedTimestamp"
+                + " = :lastModifiedTime, w.pending = :pending where w.bundleActionId = :bundleActionId"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_ACTION_STATUS_PENDING_MODTIME", query = "update BundleActionBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.bundleActionId = :bundleActionId"),
+        @NamedQuery(name = "UPDATE_BUNDLE_ACTION_STATUS_PENDING_MODTIME", query = "update BundleActionBean w set w.statusStr "
+                + "= :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.bundleActionId "
+                + "= :bundleActionId"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_ACTION_STATUS_PENDING_MODTIME_COORDID", query = "update BundleActionBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending, w.coordId = :coordId where w.bundleActionId = :bundleActionId"),
+        @NamedQuery(name = "UPDATE_BUNDLE_ACTION_STATUS_PENDING_MODTIME_COORDID", query = "update BundleActionBean w set"
+                + " w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending, w.coordId "
+                + "= :coordId where w.bundleActionId = :bundleActionId"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_STATUS_UNIGNORED_FOR_BUNDLE", query = "select OBJECT(w) from BundleActionBean w where w.bundleId = :bundleId AND w.statusStr <> 'IGNORED'"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_STATUS_UNIGNORED_FOR_BUNDLE", query = "select OBJECT(w) from BundleActionBean w"
+                + " where w.bundleId = :bundleId AND w.statusStr <> 'IGNORED'"),
 
-        @NamedQuery(name = "GET_BUNDLE_UNIGNORED_ACTION_STATUS_PENDING_FOR_BUNDLE", query = "select w.coordId, w.statusStr, w.pending from BundleActionBean w where w.bundleId = :bundleId AND w.statusStr <> 'IGNORED'"),
+        @NamedQuery(name = "GET_BUNDLE_UNIGNORED_ACTION_STATUS_PENDING_FOR_BUNDLE", query = "select w.coordId, w.statusStr,"
+                + " w.pending from BundleActionBean w where w.bundleId = :bundleId AND w.statusStr <> 'IGNORED'"),
 
         @NamedQuery(name = "GET_BUNDLE_ACTIONS", query = "select OBJECT(w) from BundleActionBean w"),
 
-        @NamedQuery(name = "GET_BUNDLE_WAITING_ACTIONS_OLDER_THAN", query = "select w.bundleActionId, w.bundleId, w.statusStr, w.coordId, w.coordName from BundleActionBean w where w.pending > 0 AND w.lastModifiedTimestamp <= :lastModifiedTime"),
+        @NamedQuery(name = "GET_BUNDLE_WAITING_ACTIONS_OLDER_THAN", query = "select w.bundleActionId, w.bundleId, w.statusStr,"
+                + " w.coordId, w.coordName from BundleActionBean w where w.pending > 0 AND w.lastModifiedTimestamp "
+                + "<= :lastModifiedTime"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTION", query = "select OBJECT(w) from BundleActionBean w where w.bundleActionId = :bundleActionId"),
+        @NamedQuery(name = "GET_BUNDLE_ACTION", query = "select OBJECT(w) from BundleActionBean w where w.bundleActionId "
+                + "= :bundleActionId"),
 
         @NamedQuery(name = "GET_BUNDLE_ACTIONS_COUNT", query = "select count(w) from BundleActionBean w"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_COUNT_BY_JOB", query = "select count(w) from BundleActionBean w where w.bundleId = :bundleId"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_COUNT_BY_JOB", query = "select count(w) from BundleActionBean w where w.bundleId"
+                + " = :bundleId"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_PENDING_TRUE_COUNT", query = "select count(w) from BundleActionBean w where w.bundleId = :bundleId AND w.pending > 0"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_PENDING_TRUE_COUNT", query = "select count(w) from BundleActionBean w where"
+                + " w.bundleId = :bundleId AND w.pending > 0"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_NOT_EQUAL_STATUS_COUNT", query = "select count(w) from BundleActionBean w where w.bundleId = :bundleId AND w.statusStr <> :status"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_NOT_EQUAL_STATUS_COUNT", query = "select count(w) from BundleActionBean w where"
+                + " w.bundleId = :bundleId AND w.statusStr <> :status"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_NOT_TERMINATE_STATUS_COUNT", query = "select count(w) from BundleActionBean w where w.bundleId = :bundleId AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'SUSPENDED' OR w.statusStr = 'SUSPENDEDWITHERROR' OR w.statusStr = 'PREPSUSPENDED' OR w.statusStr = 'PAUSED' OR  w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr = 'PREPPAUSED')"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_NOT_TERMINATE_STATUS_COUNT", query = "select count(w) from BundleActionBean w"
+                + " where w.bundleId = :bundleId AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' OR w.statusStr "
+                + "= 'RUNNINGWITHERROR' OR w.statusStr = 'SUSPENDED' OR w.statusStr = 'SUSPENDEDWITHERROR' OR w.statusStr "
+                + "= 'PREPSUSPENDED' OR w.statusStr = 'PAUSED' OR  w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr "
+                + "= 'PREPPAUSED')"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_FAILED_NULL_COORD_COUNT", query = "select count(w) from BundleActionBean w where w.bundleId = :bundleId AND w.statusStr = 'FAILED' AND w.coordId IS NULL"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_FAILED_NULL_COORD_COUNT", query = "select count(w) from BundleActionBean w where"
+                + " w.bundleId = :bundleId AND w.statusStr = 'FAILED' AND w.coordId IS NULL"),
 
-        @NamedQuery(name = "GET_BUNDLE_ACTIONS_OLDER_THAN", query = "select OBJECT(w) from BundleActionBean w order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_ACTIONS_OLDER_THAN", query = "select OBJECT(w) from BundleActionBean w order by"
+                + " w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "DELETE_COMPLETED_ACTIONS_FOR_BUNDLE", query = "delete from BundleActionBean a where a.bundleId = :bundleId and (a.statusStr = 'SUCCEEDED' OR a.statusStr = 'FAILED' OR a.statusStr= 'KILLED' OR a.statusStr = 'DONEWITHERROR')"),
+        @NamedQuery(name = "DELETE_COMPLETED_ACTIONS_FOR_BUNDLE", query = "delete from BundleActionBean a where a.bundleId "
+                + "= :bundleId and (a.statusStr = 'SUCCEEDED' OR a.statusStr = 'FAILED' OR a.statusStr= 'KILLED' "
+                + "OR a.statusStr = 'DONEWITHERROR')"),
 
         @NamedQuery(name = "DELETE_ACTIONS_FOR_BUNDLE", query = "delete from BundleActionBean a where a.bundleId  IN (:bundleId)")})
 public class BundleActionBean implements Writable, JsonBean {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/BundleJobBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/BundleJobBean.java b/core/src/main/java/org/apache/oozie/BundleJobBean.java
index dec0967..e3ba331 100644
--- a/core/src/main/java/org/apache/oozie/BundleJobBean.java
+++ b/core/src/main/java/org/apache/oozie/BundleJobBean.java
@@ -53,19 +53,30 @@ import org.json.simple.JSONObject;
 
 @Entity
 @NamedQueries( {
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB", query = "update BundleJobBean w set w.appName = :appName, w.appPath = :appPath, w.conf = :conf, w.externalId = :externalId, w.timeOut = :timeOut, w.createdTimestamp = :createdTime, w.endTimestamp = :endTime, w.jobXml = :jobXml, w.lastModifiedTimestamp = :lastModifiedTime, w.origJobXml = :origJobXml, w.startTimestamp = :startTime, w.statusStr = :status, w.timeUnitStr = :timeUnit, w.pending = :pending where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB", query = "update BundleJobBean w set w.appName = :appName, w.appPath = :appPath,"
+                + " w.conf = :conf, w.externalId = :externalId, w.timeOut = :timeOut, w.createdTimestamp = :createdTime,"
+                + " w.endTimestamp = :endTime, w.jobXml = :jobXml, w.lastModifiedTimestamp = :lastModifiedTime, w.origJobXml"
+                + " = :origJobXml, w.startTimestamp = :startTime, w.statusStr = :status, w.timeUnitStr = :timeUnit, w.pending"
+                + " = :pending where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS", query = "update BundleJobBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS", query = "update BundleJobBean w set w.statusStr = :status,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PENDING", query = "update BundleJobBean w set w.statusStr = :status, w.pending = :pending where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PENDING", query = "update BundleJobBean w set w.statusStr = :status,"
+                + " w.pending = :pending where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PENDING_MODTIME", query = "update BundleJobBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PENDING_MODTIME", query = "update BundleJobBean w set w.statusStr = :status,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PENDING_SUSP_MOD_TIME", query = "update BundleJobBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending, w.suspendedTimestamp = :suspendedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PENDING_SUSP_MOD_TIME", query = "update BundleJobBean w set w.statusStr "
+                + "= :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending, w.suspendedTimestamp "
+                + "= :suspendedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PAUSE_ENDTIME", query = "update BundleJobBean w set w.statusStr = :status, w.pauseTimestamp = :pauseTime, w.endTimestamp = :endTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB_STATUS_PAUSE_ENDTIME", query = "update BundleJobBean w set w.statusStr = :status,"
+                + " w.pauseTimestamp = :pauseTime, w.endTimestamp = :endTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_BUNDLE_JOB_PAUSE_KICKOFF", query = "update BundleJobBean w set w.kickoffTimestamp = :kickoffTime, w.pauseTimestamp = :pauseTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_BUNDLE_JOB_PAUSE_KICKOFF", query = "update BundleJobBean w set w.kickoffTimestamp "
+                + "= :kickoffTime, w.pauseTimestamp = :pauseTime where w.id = :id"),
 
         @NamedQuery(name = "DELETE_BUNDLE_JOB", query = "delete from BundleJobBean w where w.id IN (:id)"),
 
@@ -75,39 +86,60 @@ import org.json.simple.JSONObject;
 
         @NamedQuery(name = "GET_BUNDLE_JOB_STATUS", query = "select w.statusStr from BundleJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOB_ID_STATUS_PENDING_MOD_PAUSE_SUSPEND_TIME", query = "select w.id, w.statusStr, w.pending, w.lastModifiedTimestamp, w.pauseTimestamp, w.suspendedTimestamp from BundleJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_BUNDLE_JOB_ID_STATUS_PENDING_MOD_PAUSE_SUSPEND_TIME", query = "select w.id, w.statusStr,"
+                + " w.pending, w.lastModifiedTimestamp, w.pauseTimestamp, w.suspendedTimestamp from BundleJobBean w where"
+                + " w.id = :id"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOB_ID_JOBXML_CONF", query = "select w.id, w.jobXml, w.conf from BundleJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_BUNDLE_JOB_ID_JOBXML_CONF", query = "select w.id, w.jobXml, w.conf from BundleJobBean w"
+                + " where w.id = :id"),
 
         @NamedQuery(name = "GET_BUNDLE_JOBS_COUNT", query = "select count(w) from BundleJobBean w"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_COLUMNS", query = "select w.id, w.appName, w.appPath, w.conf, w.statusStr, w.kickoffTimestamp, w.startTimestamp, w.endTimestamp, w.pauseTimestamp, w.createdTimestamp, w.user, w.group, w.timeUnitStr, w.timeOut from BundleJobBean w order by w.createdTimestamp desc"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_COLUMNS", query = "select w.id, w.appName, w.appPath, w.conf, w.statusStr,"
+                + " w.kickoffTimestamp, w.startTimestamp, w.endTimestamp, w.pauseTimestamp, w.createdTimestamp, w.user, w.group,"
+                + " w.timeUnitStr, w.timeOut from BundleJobBean w order by w.createdTimestamp desc"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_RUNNING_OR_PENDING", query = "select OBJECT(w) from BundleJobBean w where w.statusStr = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.pending = 1 order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_RUNNING_OR_PENDING", query = "select OBJECT(w) from BundleJobBean w where w.statusStr"
+                + " = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.pending = 1 order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_NEED_START", query = "select OBJECT(w) from BundleJobBean w where w.statusStr = 'PREP' AND (w.kickoffTimestamp IS NULL OR (w.kickoffTimestamp IS NOT NULL AND w.kickoffTimestamp <= :currentTime)) order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_NEED_START", query = "select OBJECT(w) from BundleJobBean w where w.statusStr "
+                + "= 'PREP' AND (w.kickoffTimestamp IS NULL OR (w.kickoffTimestamp IS NOT NULL AND w.kickoffTimestamp "
+                + "<= :currentTime)) order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_PAUSED", query = "select OBJECT(w) from BundleJobBean w where w.statusStr = 'PAUSED' OR w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr = 'PREPPAUSED' order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_PAUSED", query = "select OBJECT(w) from BundleJobBean w where w.statusStr = 'PAUSED'"
+                + " OR w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr = 'PREPPAUSED' order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_UNPAUSED", query = "select OBJECT(w) from BundleJobBean w where w.statusStr = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'PREP' order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_UNPAUSED", query = "select OBJECT(w) from BundleJobBean w where w.statusStr "
+                + "= 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'PREP' order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_OLDER_THAN", query = "select OBJECT(w) from BundleJobBean w where w.startTimestamp <= :matTime AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' or w.statusStr = 'RUNNINGWITHERROR')  order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_OLDER_THAN", query = "select OBJECT(w) from BundleJobBean w where w.startTimestamp "
+                + "<= :matTime AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' or w.statusStr = 'RUNNINGWITHERROR')  "
+                + "order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_BUNDLE_JOBS_OLDER_THAN_STATUS", query = "select OBJECT(w) from BundleJobBean w where w.statusStr = :status AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_BUNDLE_JOBS_OLDER_THAN_STATUS", query = "select OBJECT(w) from BundleJobBean w where w.statusStr"
+                + " = :status AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COMPLETED_BUNDLE_JOBS_OLDER_THAN", query = "select w.id from BundleJobBean w where ( w.statusStr = 'SUCCEEDED' OR w.statusStr = 'FAILED' OR w.statusStr = 'KILLED' OR w.statusStr = 'DONEWITHERROR') AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COMPLETED_BUNDLE_JOBS_OLDER_THAN", query = "select w.id from BundleJobBean w where ( w.statusStr"
+                + " = 'SUCCEEDED' OR w.statusStr = 'FAILED' OR w.statusStr = 'KILLED' OR w.statusStr = 'DONEWITHERROR') "
+                + "AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "BULK_MONITOR_BUNDLE_QUERY", query = "SELECT b.id, b.appName, b.statusStr, b.user FROM BundleJobBean b"),
+        @NamedQuery(name = "BULK_MONITOR_BUNDLE_QUERY", query = "SELECT b.id, b.appName, b.statusStr, b.user "
+                + "FROM BundleJobBean b"),
 
         // Join query
-        @NamedQuery(name = "BULK_MONITOR_ACTIONS_QUERY", query = "SELECT a.id, a.actionNumber, a.errorCode, a.errorMessage, a.externalId, " +
+        @NamedQuery(name = "BULK_MONITOR_ACTIONS_QUERY", query = "SELECT a.id, a.actionNumber, a.errorCode, a.errorMessage,"
+                + " a.externalId, " +
                 "a.externalStatus, a.statusStr, a.createdTimestamp, a.nominalTimestamp, a.missingDependencies, " +
                 "c.id, c.appName, c.statusStr FROM CoordinatorActionBean a, CoordinatorJobBean c " +
                 "WHERE a.jobId = c.id AND c.bundleId = :bundleId ORDER BY a.jobId, a.createdTimestamp"),
 
-        @NamedQuery(name = "BULK_MONITOR_COUNT_QUERY", query = "SELECT COUNT(a) FROM CoordinatorActionBean a, CoordinatorJobBean c"),
+        @NamedQuery(name = "BULK_MONITOR_COUNT_QUERY", query = "SELECT COUNT(a) FROM CoordinatorActionBean a,"
+                + " CoordinatorJobBean c"),
 
-        @NamedQuery(name = "GET_BUNDLE_IDS_FOR_STATUS_TRANSIT", query = "select DISTINCT w.id from BundleActionBean a , BundleJobBean w where a.lastModifiedTimestamp >= :lastModifiedTime and w.id = a.bundleId and (w.statusStr = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'PAUSED' OR w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr = 'SUSPENDED' OR w.statusStr = 'SUSPENDEDWITHERROR' OR w.pending = 1)"),
+        @NamedQuery(name = "GET_BUNDLE_IDS_FOR_STATUS_TRANSIT", query = "select DISTINCT w.id from BundleActionBean a ,"
+                + " BundleJobBean w where a.lastModifiedTimestamp >= :lastModifiedTime and w.id = a.bundleId and (w.statusStr"
+                + " = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'PAUSED' OR w.statusStr = 'PAUSEDWITHERROR'"
+                + " OR w.statusStr = 'SUSPENDED' OR w.statusStr = 'SUSPENDEDWITHERROR' OR w.pending = 1)"),
 
 
         @NamedQuery(name = "GET_BUNDLE_JOB_FOR_USER", query = "select w.user from BundleJobBean w where w.id = :id") })

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/CoordinatorActionBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/CoordinatorActionBean.java b/core/src/main/java/org/apache/oozie/CoordinatorActionBean.java
index ddec1e6..e985a5f 100644
--- a/core/src/main/java/org/apache/oozie/CoordinatorActionBean.java
+++ b/core/src/main/java/org/apache/oozie/CoordinatorActionBean.java
@@ -54,31 +54,56 @@ import org.json.simple.JSONObject;
 @Entity
 @NamedQueries({
 
-        @NamedQuery(name = "UPDATE_COORD_ACTION", query = "update CoordinatorActionBean w set w.actionNumber = :actionNumber, w.actionXml = :actionXml, w.consoleUrl = :consoleUrl, w.createdConf = :createdConf, w.errorCode = :errorCode, w.errorMessage = :errorMessage, w.externalStatus = :externalStatus, w.missingDependencies = :missingDependencies, w.runConf = :runConf, w.timeOut = :timeOut, w.trackerUri = :trackerUri, w.type = :type, w.createdTimestamp = :createdTime, w.externalId = :externalId, w.jobId = :jobId, w.lastModifiedTimestamp = :lastModifiedTime, w.nominalTimestamp = :nominalTime, w.slaXml = :slaXml, w.statusStr = :status where w.id = :id"),
-
-        @NamedQuery(name = "UPDATE_COORD_ACTION_MIN", query = "update CoordinatorActionBean w set w.actionXml = :actionXml, w.missingDependencies = :missingDependencies, w.lastModifiedTimestamp = :lastModifiedTime, w.statusStr = :status where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION", query = "update CoordinatorActionBean w set w.actionNumber = :actionNumber,"
+                + " w.actionXml = :actionXml, w.consoleUrl = :consoleUrl, w.createdConf = :createdConf, w.errorCode = :errorCode,"
+                + " w.errorMessage = :errorMessage, w.externalStatus = :externalStatus, w.missingDependencies "
+                + "= :missingDependencies, w.runConf = :runConf, w.timeOut = :timeOut, w.trackerUri = :trackerUri, w.type "
+                + "= :type, w.createdTimestamp = :createdTime, w.externalId = :externalId, w.jobId = :jobId,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime, w.nominalTimestamp = :nominalTime, w.slaXml = :slaXml,"
+                + " w.statusStr = :status where w.id = :id"),
+
+        @NamedQuery(name = "UPDATE_COORD_ACTION_MIN", query = "update CoordinatorActionBean w set w.actionXml = :actionXml,"
+                + " w.missingDependencies = :missingDependencies, w.lastModifiedTimestamp = :lastModifiedTime, w.statusStr "
+                + "= :status where w.id = :id"),
         // Query to update the action status, pending status and last modified time stamp of a Coordinator action
-        @NamedQuery(name = "UPDATE_COORD_ACTION_STATUS_PENDING_TIME", query = "update CoordinatorActionBean w set w.statusStr =:status, w.pending =:pending, w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_STATUS_PENDING_TIME", query = "update CoordinatorActionBean w set w.statusStr"
+                + " =:status, w.pending =:pending, w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
         // Update query for InputCheck
-        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_INPUTCHECK", query = "update CoordinatorActionBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.actionXml = :actionXml, w.missingDependencies = :missingDependencies where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_INPUTCHECK", query = "update CoordinatorActionBean w set w.statusStr "
+                + "= :status, w.lastModifiedTimestamp = :lastModifiedTime, w.actionXml = :actionXml, w.missingDependencies "
+                + "= :missingDependencies where w.id = :id"),
         // Update query for Push-based missing dependency check
-        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_PUSH_INPUTCHECK", query = "update CoordinatorActionBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime,  w.actionXml = :actionXml, w.pushMissingDependencies = :pushMissingDependencies where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_PUSH_INPUTCHECK", query = "update CoordinatorActionBean w set w.statusStr "
+                + "= :status, w.lastModifiedTimestamp = :lastModifiedTime,  w.actionXml = :actionXml, w.pushMissingDependencies "
+                + "= :pushMissingDependencies where w.id = :id"),
         // Update query for Push-based missing dependency check
-        @NamedQuery(name = "UPDATE_COORD_ACTION_DEPENDENCIES", query = "update CoordinatorActionBean w set w.missingDependencies = :missingDependencies, w.pushMissingDependencies = :pushMissingDependencies where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_DEPENDENCIES", query = "update CoordinatorActionBean w set w.missingDependencies"
+                + " = :missingDependencies, w.pushMissingDependencies = :pushMissingDependencies where w.id = :id"),
         // Update query for Start
-        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_START", query = "update CoordinatorActionBean w set w.statusStr =:status, w.lastModifiedTimestamp = :lastModifiedTime, w.runConf = :runConf, w.externalId = :externalId, w.pending = :pending, w.errorCode = :errorCode, w.errorMessage = :errorMessage  where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_START", query = "update CoordinatorActionBean w set w.statusStr =:status,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime, w.runConf = :runConf, w.externalId = :externalId, w.pending "
+                + "= :pending, w.errorCode = :errorCode, w.errorMessage = :errorMessage  where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_MODIFIED_DATE", query = "update CoordinatorActionBean w set w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_FOR_MODIFIED_DATE", query = "update CoordinatorActionBean w set"
+                + " w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_ACTION_RERUN", query = "update CoordinatorActionBean w set w.actionXml =:actionXml, w.statusStr = :status, w.externalId = :externalId, w.externalStatus = :externalStatus, w.rerunTimestamp = :rerunTime, w.lastModifiedTimestamp = :lastModifiedTime, w.createdTimestamp = :createdTime, w.createdConf = :createdConf, w.runConf = :runConf, w.missingDependencies = :missingDependencies, w.pushMissingDependencies = :pushMissingDependencies, w.errorCode = :errorCode, w.errorMessage = :errorMessage where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_ACTION_RERUN", query = "update CoordinatorActionBean w set w.actionXml =:actionXml,"
+                + " w.statusStr = :status, w.externalId = :externalId, w.externalStatus = :externalStatus, w.rerunTimestamp "
+                + "= :rerunTime, w.lastModifiedTimestamp = :lastModifiedTime, w.createdTimestamp = :createdTime, w.createdConf "
+                + "= :createdConf, w.runConf = :runConf, w.missingDependencies = :missingDependencies, w.pushMissingDependencies "
+                + "= :pushMissingDependencies, w.errorCode = :errorCode, w.errorMessage = :errorMessage where w.id = :id"),
 
-        @NamedQuery(name = "DELETE_COMPLETED_ACTIONS_FOR_COORDINATOR", query = "delete from CoordinatorActionBean a where a.jobId = :jobId and (a.statusStr = 'SUCCEEDED' OR a.statusStr = 'FAILED' OR a.statusStr= 'KILLED')"),
+        @NamedQuery(name = "DELETE_COMPLETED_ACTIONS_FOR_COORDINATOR", query = "delete from CoordinatorActionBean a where a.jobId"
+                + " = :jobId and (a.statusStr = 'SUCCEEDED' OR a.statusStr = 'FAILED' OR a.statusStr= 'KILLED')"),
 
-        @NamedQuery(name = "DELETE_ACTIONS_FOR_LONG_RUNNING_COORDINATOR", query = "delete from CoordinatorActionBean a where a.id IN (:actionId)"),
+        @NamedQuery(name = "DELETE_ACTIONS_FOR_LONG_RUNNING_COORDINATOR", query = "delete from CoordinatorActionBean a where a.id"
+                + " IN (:actionId)"),
 
-        @NamedQuery(name = "DELETE_UNSCHEDULED_ACTION", query = "delete from CoordinatorActionBean a where a.id = :id and (a.statusStr = 'WAITING' OR a.statusStr = 'READY')"),
+        @NamedQuery(name = "DELETE_UNSCHEDULED_ACTION", query = "delete from CoordinatorActionBean a where a.id = :id "
+                + "and (a.statusStr = 'WAITING' OR a.statusStr = 'READY')"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_COORDINATOR", query = "select a.id from CoordinatorActionBean a where a.jobId = :jobId"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_COORDINATOR", query = "select a.id from CoordinatorActionBean a where a.jobId"
+                + " = :jobId"),
 
         // Query used by XTestcase to setup tables
         @NamedQuery(name = "GET_COORD_ACTIONS", query = "select OBJECT(w) from CoordinatorActionBean w"),
@@ -86,87 +111,151 @@ import org.json.simple.JSONObject;
         @NamedQuery(name = "GET_COORD_ACTION", query = "select OBJECT(a) from CoordinatorActionBean a where a.id = :id"),
 
         // Select query used by SLAService on restart
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_SLA", query = "select a.id, a.jobId, a.statusStr, a.externalId, a.lastModifiedTimestamp from CoordinatorActionBean a where a.id = :id"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_SLA", query = "select a.id, a.jobId, a.statusStr, a.externalId,"
+                + " a.lastModifiedTimestamp from CoordinatorActionBean a where a.id = :id"),
         // Select query used by ActionInfo command
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_INFO", query = "select a.id, a.jobId, a.actionNumber, a.consoleUrl, a.errorCode, a.errorMessage, a.externalId, a.externalStatus, a.trackerUri, a.createdTimestamp, a.nominalTimestamp, a.statusStr, a.lastModifiedTimestamp, a.missingDependencies, a.pushMissingDependencies from CoordinatorActionBean a where a.id = :id"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_INFO", query = "select a.id, a.jobId, a.actionNumber, a.consoleUrl, a.errorCode,"
+                + " a.errorMessage, a.externalId, a.externalStatus, a.trackerUri, a.createdTimestamp, a.nominalTimestamp,"
+                + " a.statusStr, a.lastModifiedTimestamp, a.missingDependencies, a.pushMissingDependencies "
+                + "from CoordinatorActionBean a where a.id = :id"),
         // Select Query used by Timeout and skip commands
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_TIMEOUT", query = "select a.id, a.jobId, a.statusStr, a.runConf, a.pending, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.id = :id"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_TIMEOUT", query = "select a.id, a.jobId, a.statusStr, a.runConf, a.pending,"
+                + " a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.id = :id"),
         // Select query used by InputCheck command
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_INPUTCHECK", query = "select a.id, a.actionNumber, a.jobId, a.statusStr, a.runConf, a.nominalTimestamp, a.createdTimestamp, a.actionXml, a.missingDependencies, a.pushMissingDependencies, a.timeOut, a.externalId from CoordinatorActionBean a where a.id = :id"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_INPUTCHECK", query = "select a.id, a.actionNumber, a.jobId, a.statusStr,"
+                + " a.runConf, a.nominalTimestamp, a.createdTimestamp, a.actionXml, a.missingDependencies,"
+                + " a.pushMissingDependencies, a.timeOut, a.externalId from CoordinatorActionBean a where a.id = :id"),
         // Select query used by CoordActionUpdate command
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_EXTERNALID", query = "select a.id, a.jobId, a.statusStr, a.pending, a.externalId, a.lastModifiedTimestamp, a.slaXml, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.externalId = :externalId"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_EXTERNALID", query = "select a.id, a.jobId, a.statusStr, a.pending,"
+                + " a.externalId, a.lastModifiedTimestamp, a.slaXml, a.nominalTimestamp, a.createdTimestamp "
+                + "from CoordinatorActionBean a where a.externalId = :externalId"),
         // Select query used by Check command
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_CHECK", query = "select a.id, a.jobId, a.statusStr, a.pending, a.externalId, a.lastModifiedTimestamp, a.slaXml, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.id = :id"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_CHECK", query = "select a.id, a.jobId, a.statusStr, a.pending, a.externalId,"
+                + " a.lastModifiedTimestamp, a.slaXml, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a"
+                + " where a.id = :id"),
         // Select query used by Start command
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_START", query = "select a.id, a.jobId, a.statusStr, a.pending, a.createdConf, a.slaXml, a.actionXml, a.externalId, a.errorMessage, a.errorCode, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.id = :id"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_START", query = "select a.id, a.jobId, a.statusStr, a.pending, a.createdConf,"
+                + " a.slaXml, a.actionXml, a.externalId, a.errorMessage, a.errorCode, a.nominalTimestamp, a.createdTimestamp "
+                + "from CoordinatorActionBean a where a.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_JOB_FIFO", query = "select a.id, a.actionNumber, a.jobId, a.statusStr, a.pending, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr = 'READY' order by a.nominalTimestamp"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_JOB_FIFO", query = "select a.id, a.actionNumber, a.jobId, a.statusStr,"
+                + " a.pending, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId "
+                + "AND a.statusStr = 'READY' order by a.nominalTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_JOB_LIFO", query = "select a.id, a.actionNumber, a.jobId, a.statusStr, a.pending, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr = 'READY' order by a.nominalTimestamp desc"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_JOB_LIFO", query = "select a.id, a.actionNumber, a.jobId, a.statusStr,"
+                + " a.pending, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId "
+                + "AND a.statusStr = 'READY' order by a.nominalTimestamp desc"),
 
-        @NamedQuery(name = "GET_COORD_RUNNING_ACTIONS_COUNT", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId AND (a.statusStr = 'RUNNING' OR a.statusStr='SUBMITTED')"),
+        @NamedQuery(name = "GET_COORD_RUNNING_ACTIONS_COUNT", query = "select count(a) from CoordinatorActionBean a where a.jobId"
+                + " = :jobId AND (a.statusStr = 'RUNNING' OR a.statusStr='SUBMITTED')"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_COUNT_BY_JOBID", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_COUNT_BY_JOBID", query = "select count(a) from CoordinatorActionBean a "
+                + "where a.jobId = :jobId"),
 
-        @NamedQuery(name = "GET_COORD_ACTIVE_ACTIONS_COUNT_BY_JOBID", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr = 'WAITING'"),
+        @NamedQuery(name = "GET_COORD_ACTIVE_ACTIONS_COUNT_BY_JOBID", query = "select count(a) from CoordinatorActionBean a"
+                + " where a.jobId = :jobId AND a.statusStr = 'WAITING'"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_PENDING_FALSE_COUNT", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId AND a.pending = 0 AND (a.statusStr = 'SUSPENDED' OR a.statusStr = 'TIMEDOUT' OR a.statusStr = 'SUCCEEDED' OR a.statusStr = 'KILLED' OR a.statusStr = 'FAILED')"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_PENDING_FALSE_COUNT", query = "select count(a) from CoordinatorActionBean a "
+                + "where a.jobId = :jobId AND a.pending = 0 AND (a.statusStr = 'SUSPENDED' OR a.statusStr = 'TIMEDOUT' "
+                + "OR a.statusStr = 'SUCCEEDED' OR a.statusStr = 'KILLED' OR a.statusStr = 'FAILED')"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_PENDING_FALSE_STATUS_COUNT", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId AND a.pending = 0 AND a.statusStr = :status"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_PENDING_FALSE_STATUS_COUNT", query = "select count(a) from CoordinatorActionBean a"
+                + " where a.jobId = :jobId AND a.pending = 0 AND a.statusStr = :status"),
 
-        @NamedQuery(name = "GET_ACTIONS_FOR_COORD_JOB", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId"),
+        @NamedQuery(name = "GET_ACTIONS_FOR_COORD_JOB", query = "select count(a) from CoordinatorActionBean a where a.jobId"
+                + " = :jobId"),
         // Query to retrieve Coordinator actions sorted by nominal time
-        @NamedQuery(name = "GET_ACTIONS_FOR_COORD_JOB_ORDER_BY_NOMINAL_TIME", query = "select a.id, a.actionNumber, a.consoleUrl, a.errorCode, a.errorMessage, a.externalId, a.externalStatus, a.jobId, a.trackerUri, a.createdTimestamp, a.nominalTimestamp, a.statusStr, a.lastModifiedTimestamp, a.missingDependencies, a.pushMissingDependencies, a.timeOut from CoordinatorActionBean a where a.jobId = :jobId order by a.nominalTimestamp"),
+        @NamedQuery(name = "GET_ACTIONS_FOR_COORD_JOB_ORDER_BY_NOMINAL_TIME", query = "select a.id, a.actionNumber, a.consoleUrl,"
+                + " a.errorCode, a.errorMessage, a.externalId, a.externalStatus, a.jobId, a.trackerUri, a.createdTimestamp,"
+                + " a.nominalTimestamp, a.statusStr, a.lastModifiedTimestamp, a.missingDependencies, a.pushMissingDependencies,"
+                + " a.timeOut from CoordinatorActionBean a where a.jobId = :jobId order by a.nominalTimestamp"),
         // Query to maintain backward compatibility for coord job info command
-        @NamedQuery(name = "GET_ALL_COLS_FOR_ACTIONS_FOR_COORD_JOB_ORDER_BY_NOMINAL_TIME", query = "select OBJECT(a) from CoordinatorActionBean a where a.jobId = :jobId order by a.nominalTimestamp"),
+        @NamedQuery(name = "GET_ALL_COLS_FOR_ACTIONS_FOR_COORD_JOB_ORDER_BY_NOMINAL_TIME", query = "select OBJECT(a) "
+                + "from CoordinatorActionBean a where a.jobId = :jobId order by a.nominalTimestamp"),
         // Query to retrieve action id, action status, pending status and external Id of not completed Coordinator actions
-        @NamedQuery(name = "GET_COORD_ACTIONS_NOT_COMPLETED", query = "select a.id, a.statusStr, a.pending, a.externalId, a.pushMissingDependencies, a.nominalTimestamp, a.createdTimestamp, a.jobId from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr <> 'FAILED' AND a.statusStr <> 'TIMEDOUT' AND a.statusStr <> 'SUCCEEDED' AND a.statusStr <> 'KILLED' AND a.statusStr <> 'IGNORED'"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_NOT_COMPLETED", query = "select a.id, a.statusStr, a.pending, a.externalId,"
+                + " a.pushMissingDependencies, a.nominalTimestamp, a.createdTimestamp, a.jobId from CoordinatorActionBean a"
+                + " where a.jobId = :jobId AND a.statusStr <> 'FAILED' AND a.statusStr <> 'TIMEDOUT' AND a.statusStr "
+                + "<> 'SUCCEEDED' AND a.statusStr <> 'KILLED' AND a.statusStr <> 'IGNORED'"),
 
         // Query to retrieve action id, action status, pending status and external Id of running Coordinator actions
-        @NamedQuery(name = "GET_COORD_ACTIONS_RUNNING", query = "select a.id, a.statusStr, a.pending, a.externalId, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId and a.statusStr = 'RUNNING'"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_RUNNING", query = "select a.id, a.statusStr, a.pending, a.externalId,"
+                + " a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId "
+                + "and a.statusStr = 'RUNNING'"),
 
         // Query to retrieve action id, action status, pending status and external Id of suspended Coordinator actions
-        @NamedQuery(name = "GET_COORD_ACTIONS_SUSPENDED", query = "select a.id, a.statusStr, a.pending, a.externalId, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId and a.statusStr = 'SUSPENDED'"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_SUSPENDED", query = "select a.id, a.statusStr, a.pending, a.externalId,"
+                + " a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId "
+                + "and a.statusStr = 'SUSPENDED'"),
 
         // Query to retrieve count of Coordinator actions which are pending
-        @NamedQuery(name = "GET_COORD_ACTIONS_PENDING_COUNT", query = "select count(a) from CoordinatorActionBean a where a.jobId = :jobId AND a.pending > 0"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_PENDING_COUNT", query = "select count(a) from CoordinatorActionBean a where a.jobId"
+                + " = :jobId AND a.pending > 0"),
 
         // Query to retrieve status of Coordinator actions
-        @NamedQuery(name = "GET_COORD_ACTIONS_STATUS_UNIGNORED", query = "select a.statusStr, a.pending from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr <> 'IGNORED'"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_STATUS_UNIGNORED", query = "select a.statusStr, a.pending "
+                + "from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr <> 'IGNORED'"),
 
         // Query to retrieve status of Coordinator actions
         @NamedQuery(name = "GET_COORD_ACTION_STATUS", query = "select a.statusStr from CoordinatorActionBean a where a.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_ACTION_FOR_COORD_JOB_BY_ACTION_NUMBER", query = "select a.id from CoordinatorActionBean a where a.jobId = :jobId AND a.actionNumber = :actionNumber"),
+        @NamedQuery(name = "GET_COORD_ACTION_FOR_COORD_JOB_BY_ACTION_NUMBER", query = "select a.id from CoordinatorActionBean a"
+                + " where a.jobId = :jobId AND a.actionNumber = :actionNumber"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_BY_LAST_MODIFIED_TIME", query = "select a.jobId from CoordinatorActionBean a where a.lastModifiedTimestamp >= :lastModifiedTime"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_BY_LAST_MODIFIED_TIME", query = "select a.jobId from CoordinatorActionBean a "
+                + "where a.lastModifiedTimestamp >= :lastModifiedTime"),
 
         //Used by coordinator store only
-        @NamedQuery(name = "GET_RUNNING_ACTIONS_FOR_COORD_JOB", query = "select OBJECT(a) from CoordinatorActionBean a where a.jobId = :jobId AND a.statusStr = 'RUNNING'"),
+        @NamedQuery(name = "GET_RUNNING_ACTIONS_FOR_COORD_JOB", query = "select OBJECT(a) from CoordinatorActionBean a "
+                + "where a.jobId = :jobId AND a.statusStr = 'RUNNING'"),
 
-        @NamedQuery(name = "GET_RUNNING_ACTIONS_OLDER_THAN", query = "select a.id from CoordinatorActionBean a where a.statusStr = 'RUNNING' AND a.lastModifiedTimestamp <= :lastModifiedTime"),
+        @NamedQuery(name = "GET_RUNNING_ACTIONS_OLDER_THAN", query = "select a.id from CoordinatorActionBean a where a.statusStr"
+                + " = 'RUNNING' AND a.lastModifiedTimestamp <= :lastModifiedTime"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_WAITING_READY_SUBMITTED_OLDER_THAN", query = "select a.id, a.jobId, a.statusStr, a.externalId, a.pushMissingDependencies from CoordinatorActionBean a where (a.statusStr = 'WAITING' OR a.statusStr = 'SUBMITTED' OR a.statusStr = 'READY') AND a.lastModifiedTimestamp <= :lastModifiedTime and a.nominalTimestamp <= :currentTime and a.jobId in ( select w.id from CoordinatorJobBean w where w.statusStr = 'RUNNING' or w.statusStr = 'RUNNINGWITHERROR')"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_WAITING_READY_SUBMITTED_OLDER_THAN", query = "select a.id, a.jobId, a.statusStr,"
+                + " a.externalId, a.pushMissingDependencies from CoordinatorActionBean a where (a.statusStr = 'WAITING' "
+                + "OR a.statusStr = 'SUBMITTED' OR a.statusStr = 'READY') AND a.lastModifiedTimestamp <= :lastModifiedTime "
+                + "and a.nominalTimestamp <= :currentTime and a.jobId in ( select w.id from CoordinatorJobBean w"
+                + " where w.statusStr = 'RUNNING' or w.statusStr = 'RUNNINGWITHERROR')"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_RECOVERY_OLDER_THAN", query = "select a.id, a.jobId, a.statusStr, a.externalId, a.pending from CoordinatorActionBean a where a.pending > 0 AND (a.statusStr = 'SUSPENDED' OR a.statusStr = 'KILLED' OR a.statusStr = 'RUNNING') AND a.lastModifiedTimestamp <= :lastModifiedTime"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_FOR_RECOVERY_OLDER_THAN", query = "select a.id, a.jobId, a.statusStr, a.externalId,"
+                + " a.pending from CoordinatorActionBean a where a.pending > 0 AND (a.statusStr = 'SUSPENDED' OR a.statusStr "
+                + "= 'KILLED' OR a.statusStr = 'RUNNING') AND a.lastModifiedTimestamp <= :lastModifiedTime"),
         // Select query used by rerun, requires almost all columns so select * is used
-        @NamedQuery(name = "GET_TERMINATED_ACTIONS_FOR_DATES", query = "select OBJECT(a) from CoordinatorActionBean a where a.jobId = :jobId AND (a.statusStr = 'TIMEDOUT' OR a.statusStr = 'SUCCEEDED' OR a.statusStr = 'KILLED' OR a.statusStr = 'FAILED' OR a.statusStr = 'IGNORED') AND a.nominalTimestamp >= :startTime AND a.nominalTimestamp <= :endTime"),
+        @NamedQuery(name = "GET_TERMINATED_ACTIONS_FOR_DATES", query = "select OBJECT(a) from CoordinatorActionBean a "
+                + "where a.jobId = :jobId AND (a.statusStr = 'TIMEDOUT' OR a.statusStr = 'SUCCEEDED' OR a.statusStr = 'KILLED' "
+                + "OR a.statusStr = 'FAILED' OR a.statusStr = 'IGNORED') AND a.nominalTimestamp >= :startTime "
+                + "AND a.nominalTimestamp <= :endTime"),
         // Select query used by log
-        @NamedQuery(name = "GET_TERMINATED_ACTION_IDS_FOR_DATES", query = "select a.id from CoordinatorActionBean a where a.jobId = :jobId AND (a.statusStr = 'TIMEDOUT' OR a.statusStr = 'SUCCEEDED' OR a.statusStr = 'KILLED' OR a.statusStr = 'FAILED') AND a.nominalTimestamp >= :startTime AND a.nominalTimestamp <= :endTime"),
+        @NamedQuery(name = "GET_TERMINATED_ACTION_IDS_FOR_DATES", query = "select a.id from CoordinatorActionBean a where a.jobId"
+                + " = :jobId AND (a.statusStr = 'TIMEDOUT' OR a.statusStr = 'SUCCEEDED' OR a.statusStr = 'KILLED' OR a.statusStr"
+                + " = 'FAILED') AND a.nominalTimestamp >= :startTime AND a.nominalTimestamp <= :endTime"),
         // Select query used by rerun, requires almost all columns so select * is used
-        @NamedQuery(name = "GET_ACTION_FOR_NOMINALTIME", query = "select OBJECT(a) from CoordinatorActionBean a where a.jobId = :jobId AND a.nominalTimestamp = :nominalTime"),
+        @NamedQuery(name = "GET_ACTION_FOR_NOMINALTIME", query = "select OBJECT(a) from CoordinatorActionBean a where a.jobId "
+                + "= :jobId AND a.nominalTimestamp = :nominalTime"),
 
-        @NamedQuery(name = "GET_ACTIVE_ACTIONS_FOR_DATES", query = "select a.id, a.jobId, a.statusStr, a.externalId, a.pending, a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId AND (a.statusStr = 'WAITING' OR a.statusStr = 'READY' OR a.statusStr = 'SUBMITTED' OR a.statusStr = 'RUNNING'  OR a.statusStr = 'SUSPENDED') AND a.nominalTimestamp >= :startTime AND a.nominalTimestamp <= :endTime"),
+        @NamedQuery(name = "GET_ACTIVE_ACTIONS_FOR_DATES", query = "select a.id, a.jobId, a.statusStr, a.externalId, a.pending,"
+                + " a.nominalTimestamp, a.createdTimestamp from CoordinatorActionBean a where a.jobId = :jobId AND (a.statusStr "
+                + "= 'WAITING' OR a.statusStr = 'READY' OR a.statusStr = 'SUBMITTED' OR a.statusStr = 'RUNNING'  OR a.statusStr "
+                + "= 'SUSPENDED') AND a.nominalTimestamp >= :startTime AND a.nominalTimestamp <= :endTime"),
 
         @NamedQuery(name = "GET_COORD_ACTIONS_COUNT", query = "select count(w) from CoordinatorActionBean w"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_COUNT_RUNNING_FOR_RANGE", query = "select count(w) from CoordinatorActionBean w where w.statusStr = 'RUNNING' and w.jobId= :jobId and w.id >= :startAction AND w.id <= :endAction"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_COUNT_RUNNING_FOR_RANGE", query = "select count(w) from CoordinatorActionBean w"
+                + " where w.statusStr = 'RUNNING' and w.jobId= :jobId and w.id >= :startAction AND w.id <= :endAction"),
 
-        @NamedQuery(name = "GET_COORD_ACTIONS_MAX_MODIFIED_DATE_FOR_RANGE", query = "select max(w.lastModifiedTimestamp) from CoordinatorActionBean w where w.jobId= :jobId and w.id >= :startAction AND w.id <= :endAction"),
+        @NamedQuery(name = "GET_COORD_ACTIONS_MAX_MODIFIED_DATE_FOR_RANGE", query = "select max(w.lastModifiedTimestamp) "
+                + "from CoordinatorActionBean w where w.jobId= :jobId and w.id >= :startAction AND w.id <= :endAction"),
 
-         @NamedQuery(name = "GET_ACTIVE_ACTIONS_IDS_FOR_SLA_CHANGE", query = "select a.id, a.nominalTimestamp, a.createdTimestamp, a.actionXml  from CoordinatorActionBean a where a.id in (:ids) and (a.statusStr <> 'FAILED' AND a.statusStr <> 'KILLED' AND a.statusStr <> 'SUCCEEDED' AND a.statusStr <> 'TIMEDOUT'  AND a.statusStr <> 'IGNORED')"),
+         @NamedQuery(name = "GET_ACTIVE_ACTIONS_IDS_FOR_SLA_CHANGE", query = "select a.id, a.nominalTimestamp,"
+                 + " a.createdTimestamp, a.actionXml  from CoordinatorActionBean a where a.id in (:ids)"
+                 + " and (a.statusStr <> 'FAILED' AND a.statusStr <> 'KILLED' AND a.statusStr <> 'SUCCEEDED' AND a.statusStr "
+                 + "<> 'TIMEDOUT'  AND a.statusStr <> 'IGNORED')"),
 
-         @NamedQuery(name = "GET_ACTIVE_ACTIONS_JOBID_FOR_SLA_CHANGE", query = "select a.id, a.nominalTimestamp, a.createdTimestamp, a.actionXml  from CoordinatorActionBean a where a.jobId = :jobId and (a.statusStr <> 'FAILED' AND a.statusStr <> 'KILLED' AND a.statusStr <> 'SUCCEEDED' AND a.statusStr <> 'TIMEDOUT'  AND a.statusStr <> 'IGNORED')")
+         @NamedQuery(name = "GET_ACTIVE_ACTIONS_JOBID_FOR_SLA_CHANGE", query = "select a.id, a.nominalTimestamp,"
+                 + " a.createdTimestamp, a.actionXml  from CoordinatorActionBean a where a.jobId = :jobId and (a.statusStr "
+                 + "<> 'FAILED' AND a.statusStr <> 'KILLED' AND a.statusStr <> 'SUCCEEDED' AND a.statusStr <> 'TIMEDOUT'  "
+                 + "AND a.statusStr <> 'IGNORED')")
  })
 
 @Table(name = "COORD_ACTIONS")

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/CoordinatorJobBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/CoordinatorJobBean.java b/core/src/main/java/org/apache/oozie/CoordinatorJobBean.java
index 5999f40..1fe3c63 100644
--- a/core/src/main/java/org/apache/oozie/CoordinatorJobBean.java
+++ b/core/src/main/java/org/apache/oozie/CoordinatorJobBean.java
@@ -54,31 +54,55 @@ import org.json.simple.JSONObject;
 
 @Entity
 @NamedQueries( {
-        @NamedQuery(name = "UPDATE_COORD_JOB", query = "update CoordinatorJobBean w set w.appName = :appName, w.appPath = :appPath,w.concurrency = :concurrency, w.conf = :conf, w.externalId = :externalId, w.frequency = :frequency, w.lastActionNumber = :lastActionNumber, w.timeOut = :timeOut, w.timeZone = :timeZone, w.createdTimestamp = :createdTime, w.endTimestamp = :endTime, w.execution = :execution, w.jobXml = :jobXml, w.lastActionTimestamp = :lastAction, w.lastModifiedTimestamp = :lastModifiedTime, w.nextMaterializedTimestamp = :nextMaterializedTime, w.origJobXml = :origJobXml, w.slaXml=:slaXml, w.startTimestamp = :startTime, w.statusStr = :status, w.timeUnitStr = :timeUnit, w.appNamespace = :appNamespace, w.bundleId = :bundleId, w.matThrottling = :matThrottling  where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB", query = "update CoordinatorJobBean w set w.appName = :appName, w.appPath "
+                + "= :appPath,w.concurrency = :concurrency, w.conf = :conf, w.externalId = :externalId, w.frequency = :frequency,"
+                + " w.lastActionNumber = :lastActionNumber, w.timeOut = :timeOut, w.timeZone = :timeZone, w.createdTimestamp "
+                + "= :createdTime, w.endTimestamp = :endTime, w.execution = :execution, w.jobXml = :jobXml, w.lastActionTimestamp"
+                + " = :lastAction, w.lastModifiedTimestamp = :lastModifiedTime, w.nextMaterializedTimestamp "
+                + "= :nextMaterializedTime, w.origJobXml = :origJobXml, w.slaXml=:slaXml, w.startTimestamp = :startTime,"
+                + " w.statusStr = :status, w.timeUnitStr = :timeUnit, w.appNamespace = :appNamespace, w.bundleId = :bundleId,"
+                + " w.matThrottling = :matThrottling  where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS", query = "update CoordinatorJobBean w set w.statusStr =:status, w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS", query = "update CoordinatorJobBean w set w.statusStr =:status,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_PENDING", query = "update CoordinatorJobBean w set w.pending = :pending, w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_PENDING", query = "update CoordinatorJobBean w set w.pending = :pending,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_BUNDLEID", query = "update CoordinatorJobBean w set w.bundleId = :bundleId where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_BUNDLEID", query = "update CoordinatorJobBean w set w.bundleId = :bundleId "
+                + "where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_APPNAMESPACE", query = "update CoordinatorJobBean w set w.appNamespace = :appNamespace where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_APPNAMESPACE", query = "update CoordinatorJobBean w set w.appNamespace "
+                + "= :appNamespace where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_PENDING", query = "update CoordinatorJobBean w set w.statusStr = :status, w.pending = :pending where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_PENDING", query = "update CoordinatorJobBean w set w.statusStr = :status,"
+                + " w.pending = :pending where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_BUNDLEID_APPNAMESPACE_PAUSETIME", query = "update CoordinatorJobBean w set w.bundleId = :bundleId, w.appNamespace = :appNamespace, w.pauseTimestamp = :pauseTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_BUNDLEID_APPNAMESPACE_PAUSETIME", query = "update CoordinatorJobBean w set"
+                + " w.bundleId = :bundleId, w.appNamespace = :appNamespace, w.pauseTimestamp = :pauseTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_MODTIME", query = "update CoordinatorJobBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_MODTIME", query = "update CoordinatorJobBean w set w.statusStr = :status,"
+                + " w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_PENDING_MODTIME", query = "update CoordinatorJobBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_PENDING_MODTIME", query = "update CoordinatorJobBean w set w.statusStr "
+                + "= :status, w.lastModifiedTimestamp = :lastModifiedTime, w.pending = :pending where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_LAST_MODIFIED_TIME", query = "update CoordinatorJobBean w set w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_LAST_MODIFIED_TIME", query = "update CoordinatorJobBean w set"
+                + " w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_PENDING_TIME", query = "update CoordinatorJobBean w set w.statusStr = :status, w.pending = :pending, w.doneMaterialization = :doneMaterialization, w.lastModifiedTimestamp = :lastModifiedTime, w.suspendedTimestamp = :suspendedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_STATUS_PENDING_TIME", query = "update CoordinatorJobBean w set w.statusStr "
+                + "= :status, w.pending = :pending, w.doneMaterialization = :doneMaterialization, w.lastModifiedTimestamp "
+                + "= :lastModifiedTime, w.suspendedTimestamp = :suspendedTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_MATERIALIZE", query = "update CoordinatorJobBean w set w.statusStr = :status, w.pending = :pending, w.doneMaterialization = :doneMaterialization, w.lastActionTimestamp = :lastActionTime, w.lastActionNumber = :lastActionNumber, w.nextMaterializedTimestamp = :nextMatdTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_MATERIALIZE", query = "update CoordinatorJobBean w set w.statusStr = :status,"
+                + " w.pending = :pending, w.doneMaterialization = :doneMaterialization, w.lastActionTimestamp = :lastActionTime,"
+                + " w.lastActionNumber = :lastActionNumber, w.nextMaterializedTimestamp = :nextMatdTime where w.id = :id"),
 
-        @NamedQuery(name = "UPDATE_COORD_JOB_CHANGE", query = "update CoordinatorJobBean w set w.endTimestamp = :endTime, w.statusStr = :status, w.pending = :pending, w.doneMaterialization = :doneMaterialization, w.concurrency = :concurrency, w.pauseTimestamp = :pauseTime, w.lastActionNumber = :lastActionNumber, w.lastActionTimestamp = :lastActionTime, w.nextMaterializedTimestamp = :nextMatdTime, w.lastModifiedTimestamp = :lastModifiedTime where w.id = :id"),
+        @NamedQuery(name = "UPDATE_COORD_JOB_CHANGE", query = "update CoordinatorJobBean w set w.endTimestamp = :endTime,"
+                + " w.statusStr = :status, w.pending = :pending, w.doneMaterialization = :doneMaterialization, w.concurrency "
+                + "= :concurrency, w.pauseTimestamp = :pauseTime, w.lastActionNumber = :lastActionNumber, w.lastActionTimestamp "
+                + "= :lastActionTime, w.nextMaterializedTimestamp = :nextMatdTime, w.lastModifiedTimestamp = :lastModifiedTime"
+                + " where w.id = :id"),
 
         @NamedQuery(name = "UPDATE_COORD_JOB_CONF", query = "update CoordinatorJobBean w set w.conf = :conf where w.id = :id"),
 
@@ -90,21 +114,33 @@ import org.json.simple.JSONObject;
 
         @NamedQuery(name = "GET_COORD_JOB", query = "select OBJECT(w) from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_USER_APPNAME", query = "select w.user, w.appName from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_USER_APPNAME", query = "select w.user, w.appName from CoordinatorJobBean w "
+                + "where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_INPUT_CHECK", query = "select w.user, w.appName, w.statusStr, w.appNamespace, w.execution, w.frequency, w.timeUnitStr, w.timeZone, w.startTimestamp, w.endTimestamp, w.jobXml from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_INPUT_CHECK", query = "select w.user, w.appName, w.statusStr, w.appNamespace,"
+                + " w.execution, w.frequency, w.timeUnitStr, w.timeZone, w.startTimestamp, w.endTimestamp, w.jobXml "
+                + "from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_ACTION_READY", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.execution, w.concurrency, w.frequency, w.timeUnitStr, w.timeZone, w.startTimestamp, w.endTimestamp, w.jobXml from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_ACTION_READY", query = "select w.id, w.user, w.group, w.appName, w.statusStr,"
+                + " w.execution, w.concurrency, w.frequency, w.timeUnitStr, w.timeZone, w.startTimestamp, w.endTimestamp,"
+                + " w.jobXml from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_ACTION_KILL", query = "select w.id, w.user, w.group, w.appName, w.statusStr from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_ACTION_KILL", query = "select w.id, w.user, w.group, w.appName, w.statusStr "
+                + "from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_MATERIALIZE", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.frequency, w.matThrottling, w.timeOut, w.timeZone, w.startTimestamp, w.endTimestamp, w.pauseTimestamp, w.nextMaterializedTimestamp, w.lastActionTimestamp, w.lastActionNumber, w.doneMaterialization, w.bundleId, w.conf, w.jobXml, w.appNamespace, w.timeUnitStr, w.execution from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_MATERIALIZE", query = "select w.id, w.user, w.group, w.appName, w.statusStr,"
+                + " w.frequency, w.matThrottling, w.timeOut, w.timeZone, w.startTimestamp, w.endTimestamp, w.pauseTimestamp,"
+                + " w.nextMaterializedTimestamp, w.lastActionTimestamp, w.lastActionNumber, w.doneMaterialization, w.bundleId,"
+                + " w.conf, w.jobXml, w.appNamespace, w.timeUnitStr, w.execution from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_SUSPEND_KILL", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.bundleId, w.appNamespace, w.doneMaterialization from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_SUSPEND_KILL", query = "select w.id, w.user, w.group, w.appName, w.statusStr,"
+                + " w.bundleId, w.appNamespace, w.doneMaterialization from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_PENDING", query = "select OBJECT(w) from CoordinatorJobBean w where w.pending = 1 order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_PENDING", query = "select OBJECT(w) from CoordinatorJobBean w where w.pending = 1"
+                + " order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_CHANGED", query = "select OBJECT(w) from CoordinatorJobBean w where w.pending = 1 AND w.doneMaterialization = 1 AND w.lastModifiedTimestamp >= :lastModifiedTime"),
+        @NamedQuery(name = "GET_COORD_JOBS_CHANGED", query = "select OBJECT(w) from CoordinatorJobBean w where w.pending = 1 "
+                + "AND w.doneMaterialization = 1 AND w.lastModifiedTimestamp >= :lastModifiedTime"),
 
         @NamedQuery(name = "GET_COORD_JOBS_COUNT", query = "select count(w) from CoordinatorJobBean w"),
 
@@ -114,37 +150,66 @@ import org.json.simple.JSONObject;
                 + "from CoordinatorJobBean w order by w.createdTimestamp desc"),
 
         //TODO need to remove.
-        @NamedQuery(name = "GET_COORD_JOBS_OLDER_THAN", query = "select OBJECT(w) from CoordinatorJobBean w where w.startTimestamp <= :matTime AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' or w.statusStr = 'RUNNINGWITHERROR') AND (w.nextMaterializedTimestamp < :matTime OR w.nextMaterializedTimestamp IS NULL) AND (w.nextMaterializedTimestamp IS NULL OR (w.endTimestamp > w.nextMaterializedTimestamp AND (w.pauseTimestamp IS NULL OR w.pauseTimestamp > w.nextMaterializedTimestamp))) order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_OLDER_THAN", query = "select OBJECT(w) from CoordinatorJobBean w "
+                + "where w.startTimestamp <= :matTime AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' or w.statusStr "
+                + "= 'RUNNINGWITHERROR') AND (w.nextMaterializedTimestamp < :matTime OR w.nextMaterializedTimestamp IS NULL) "
+                + "AND (w.nextMaterializedTimestamp IS NULL OR (w.endTimestamp > w.nextMaterializedTimestamp "
+                + "AND (w.pauseTimestamp IS NULL OR w.pauseTimestamp > w.nextMaterializedTimestamp))) "
+                + "order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_OLDER_FOR_MATERIALIZATION", query = "select w.id from CoordinatorJobBean w where w.startTimestamp <= :matTime AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' or w.statusStr = 'RUNNINGWITHERROR') AND (w.nextMaterializedTimestamp < :matTime OR w.nextMaterializedTimestamp IS NULL) AND (w.nextMaterializedTimestamp IS NULL OR (w.endTimestamp > w.nextMaterializedTimestamp AND (w.pauseTimestamp IS NULL OR w.pauseTimestamp > w.nextMaterializedTimestamp))) and w.matThrottling > ( select count(a.jobId) from CoordinatorActionBean a where a.jobId = w.id and a.statusStr = 'WAITING') order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_OLDER_FOR_MATERIALIZATION", query = "select w.id from CoordinatorJobBean w "
+                + "where w.startTimestamp <= :matTime AND (w.statusStr = 'PREP' OR w.statusStr = 'RUNNING' or w.statusStr "
+                + "= 'RUNNINGWITHERROR') AND (w.nextMaterializedTimestamp < :matTime OR w.nextMaterializedTimestamp IS NULL) "
+                + "AND (w.nextMaterializedTimestamp IS NULL OR (w.endTimestamp > w.nextMaterializedTimestamp "
+                + "AND (w.pauseTimestamp IS NULL OR w.pauseTimestamp > w.nextMaterializedTimestamp))) and w.matThrottling "
+                + "> ( select count(a.jobId) from CoordinatorActionBean a where a.jobId = w.id and a.statusStr = 'WAITING') "
+                + "order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_OLDER_THAN_STATUS", query = "select OBJECT(w) from CoordinatorJobBean w where w.statusStr = :status AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_OLDER_THAN_STATUS", query = "select OBJECT(w) from CoordinatorJobBean w "
+                + "where w.statusStr = :status AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COMPLETED_COORD_JOBS_OLDER_THAN_STATUS", query = "select OBJECT(w) from CoordinatorJobBean w where ( w.statusStr = 'SUCCEEDED' OR w.statusStr = 'FAILED' or w.statusStr = 'KILLED') AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COMPLETED_COORD_JOBS_OLDER_THAN_STATUS", query = "select OBJECT(w) from CoordinatorJobBean w"
+                + " where ( w.statusStr = 'SUCCEEDED' OR w.statusStr = 'FAILED' or w.statusStr = 'KILLED') "
+                + "AND w.lastModifiedTimestamp <= :lastModTime order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COMPLETED_COORD_JOBS_WITH_NO_PARENT_OLDER_THAN_STATUS", query = "select w.id from CoordinatorJobBean w where ( w.statusStr = 'SUCCEEDED' OR w.statusStr = 'FAILED' or w.statusStr = 'KILLED' or w.statusStr = 'DONEWITHERROR') AND w.lastModifiedTimestamp <= :lastModTime and w.bundleId is null order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COMPLETED_COORD_JOBS_WITH_NO_PARENT_OLDER_THAN_STATUS", query = "select w.id "
+                + "from CoordinatorJobBean w where ( w.statusStr = 'SUCCEEDED' OR w.statusStr = 'FAILED' or w.statusStr "
+                + "= 'KILLED' or w.statusStr = 'DONEWITHERROR') AND w.lastModifiedTimestamp <= :lastModTime and w.bundleId "
+                + "is null order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_UNPAUSED", query = "select OBJECT(w) from CoordinatorJobBean w where w.statusStr = 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'PREP' order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_UNPAUSED", query = "select OBJECT(w) from CoordinatorJobBean w where w.statusStr "
+                + "= 'RUNNING' OR w.statusStr = 'RUNNINGWITHERROR' OR w.statusStr = 'PREP' order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_PAUSED", query = "select OBJECT(w) from CoordinatorJobBean w where w.statusStr = 'PAUSED' OR w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr = 'PREPPAUSED' order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_PAUSED", query = "select OBJECT(w) from CoordinatorJobBean w where w.statusStr "
+                + "= 'PAUSED' OR w.statusStr = 'PAUSEDWITHERROR' OR w.statusStr = 'PREPPAUSED' order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_FOR_BUNDLE", query = "select OBJECT(w) from CoordinatorJobBean w where w.bundleId = :bundleId order by w.lastModifiedTimestamp"),
+        @NamedQuery(name = "GET_COORD_JOBS_FOR_BUNDLE", query = "select OBJECT(w) from CoordinatorJobBean w where w.bundleId "
+                + "= :bundleId order by w.lastModifiedTimestamp"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_WITH_PARENT_ID", query = "select w.id from CoordinatorJobBean w where w.bundleId = :parentId"),
+        @NamedQuery(name = "GET_COORD_JOBS_WITH_PARENT_ID", query = "select w.id from CoordinatorJobBean w where w.bundleId"
+                + " = :parentId"),
 
-        @NamedQuery(name = "GET_COORD_COUNT_WITH_PARENT_ID_NOT_READY_FOR_PURGE", query = "select count(w) from CoordinatorJobBean w where w.bundleId = :parentId and (w.statusStr NOT IN ('SUCCEEDED', 'FAILED', 'KILLED', 'DONEWITHERROR') OR w.lastModifiedTimestamp >= :lastModTime)"),
+        @NamedQuery(name = "GET_COORD_COUNT_WITH_PARENT_ID_NOT_READY_FOR_PURGE", query = "select count(w) from CoordinatorJobBean"
+                + " w where w.bundleId = :parentId and (w.statusStr NOT IN ('SUCCEEDED', 'FAILED', 'KILLED', 'DONEWITHERROR') "
+                + "OR w.lastModifiedTimestamp >= :lastModTime)"),
 
-        @NamedQuery(name = "GET_COORD_JOB_FOR_USER_APPNAME", query = "select w.user, w.appName from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_FOR_USER_APPNAME", query = "select w.user, w.appName from CoordinatorJobBean w "
+                + "where w.id = :id"),
 
         @NamedQuery(name = "GET_COORD_JOB_FOR_USER", query = "select w.user from CoordinatorJobBean w where w.id = :id"),
 
         @NamedQuery(name = "GET_COORD_JOB_STATUS", query = "select w.statusStr from CoordinatorJobBean w where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_JOB_STATUS_PARENTID", query = "select w.statusStr, w.bundleId from CoordinatorJobBean w where w.id = :id"),
+        @NamedQuery(name = "GET_COORD_JOB_STATUS_PARENTID", query = "select w.statusStr, w.bundleId from CoordinatorJobBean w"
+                + " where w.id = :id"),
 
-        @NamedQuery(name = "GET_COORD_IDS_FOR_STATUS_TRANSIT", query = "select DISTINCT w.id from CoordinatorActionBean a, CoordinatorJobBean w where w.id = a.jobId and a.lastModifiedTimestamp >= :lastModifiedTime and (w.statusStr IN ('PAUSED', 'RUNNING', 'RUNNINGWITHERROR', 'PAUSEDWITHERROR') or w.pending = 1)  and w.statusStr <> 'IGNORED'"),
+        @NamedQuery(name = "GET_COORD_IDS_FOR_STATUS_TRANSIT", query = "select DISTINCT w.id from CoordinatorActionBean a,"
+                + " CoordinatorJobBean w where w.id = a.jobId and a.lastModifiedTimestamp >= :lastModifiedTime "
+                + "and (w.statusStr IN ('PAUSED', 'RUNNING', 'RUNNINGWITHERROR', 'PAUSEDWITHERROR') or w.pending = 1)  "
+                + "and w.statusStr <> 'IGNORED'"),
 
-        @NamedQuery(name = "GET_COORD_JOBS_FOR_BUNDLE_BY_APPNAME_ID", query = "select w.id from CoordinatorJobBean w where ( w.appName IN (:appName) OR w.id IN (:appName) )  AND w.bundleId = :bundleId"),
+        @NamedQuery(name = "GET_COORD_JOBS_FOR_BUNDLE_BY_APPNAME_ID", query = "select w.id from CoordinatorJobBean w "
+                + "where ( w.appName IN (:appName) OR w.id IN (:appName) )  AND w.bundleId = :bundleId"),
 
         @NamedQuery(name = "GET_COORD_JOB_CONF", query = "select w.conf from CoordinatorJobBean w where w.id = :id"),
 
@@ -152,7 +217,13 @@ import org.json.simple.JSONObject;
 
 })
 @NamedNativeQueries({
-        @NamedNativeQuery(name = "GET_COORD_FOR_ABANDONEDCHECK", query = "select w.id, w.USER_NAME, w.group_name, w.APP_NAME from coord_jobs w where ( w.STATUS = 'RUNNING' or w.STATUS = 'RUNNINGWITHERROR' ) and w.start_time < ?2 and w.created_time < ?2 and w.id in (select failedJobs.job_id from (select a.job_id from coord_actions a where ( a.STATUS = 'FAILED' or a.STATUS = 'TIMEDOUT'  or a.STATUS = 'SUSPENDED') group by a.job_id having count(*) >= ?1 ) failedJobs LEFT OUTER JOIN (select b.job_id from coord_actions b where b.STATUS = 'SUCCEEDED' group by b.job_id having count(*) > 0 ) successJobs   on  failedJobs.job_id = successJobs.job_id where successJobs.job_id is null )")
+        @NamedNativeQuery(name = "GET_COORD_FOR_ABANDONEDCHECK", query = "select w.id, w.USER_NAME, w.group_name, w.APP_NAME "
+                + "from coord_jobs w where ( w.STATUS = 'RUNNING' or w.STATUS = 'RUNNINGWITHERROR' ) and w.start_time "
+                + "< ?2 and w.created_time < ?2 and w.id in (select failedJobs.job_id from (select a.job_id from coord_actions a "
+                + "where ( a.STATUS = 'FAILED' or a.STATUS = 'TIMEDOUT'  or a.STATUS = 'SUSPENDED') group by a.job_id "
+                + "having count(*) >= ?1 ) failedJobs LEFT OUTER JOIN (select b.job_id from coord_actions b where b.STATUS "
+                + "= 'SUCCEEDED' group by b.job_id having count(*) > 0 ) successJobs   on  failedJobs.job_id "
+                + "= successJobs.job_id where successJobs.job_id is null )")
 
 })
 @Table(name = "COORD_JOBS")

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/CoordinatorJobInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/CoordinatorJobInfo.java b/core/src/main/java/org/apache/oozie/CoordinatorJobInfo.java
index 04c5bc9..ee309aa 100644
--- a/core/src/main/java/org/apache/oozie/CoordinatorJobInfo.java
+++ b/core/src/main/java/org/apache/oozie/CoordinatorJobInfo.java
@@ -28,7 +28,7 @@ public class CoordinatorJobInfo {
 
     /**
      * Create a coordinator info bean.
-     * 
+     *
      * @param jobs jobs being returned.
      * @param start coordiantor jobs offset.
      * @param len number of coordiantor jobs.

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/DagELFunctions.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/DagELFunctions.java b/core/src/main/java/org/apache/oozie/DagELFunctions.java
index 22ac624..1795852 100644
--- a/core/src/main/java/org/apache/oozie/DagELFunctions.java
+++ b/core/src/main/java/org/apache/oozie/DagELFunctions.java
@@ -119,7 +119,8 @@ public class DagELFunctions {
                     HADOOP_JOBS_PREFIX + action.getExternalChildIDs());
         }
         if (action.getStats() != null) {
-            workflowInstance.setVar(action.getName() + WorkflowInstance.NODE_VAR_SEPARATOR + MapReduceActionExecutor.HADOOP_COUNTERS,
+            workflowInstance.setVar(action.getName() + WorkflowInstance.NODE_VAR_SEPARATOR
+                    + MapReduceActionExecutor.HADOOP_COUNTERS,
                     action.getStats());
         }
         if (action.getErrorCode() != null) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/SLAEventBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/SLAEventBean.java b/core/src/main/java/org/apache/oozie/SLAEventBean.java
index b30867b..a560a43 100644
--- a/core/src/main/java/org/apache/oozie/SLAEventBean.java
+++ b/core/src/main/java/org/apache/oozie/SLAEventBean.java
@@ -39,7 +39,8 @@ import org.jdom.Element;
 @Deprecated
 @Entity
 @NamedQueries({
-        @NamedQuery(name = "GET_SLA_EVENT_NEWER_SEQ_LIMITED", query = "select OBJECT(w) from SLAEventBean w where w.event_id > :id order by w.event_id"),
+        @NamedQuery(name = "GET_SLA_EVENT_NEWER_SEQ_LIMITED", query = "select OBJECT(w) from SLAEventBean w where w.event_id "
+                + "> :id order by w.event_id"),
         @NamedQuery(name = "GET_SLA_EVENTS", query = "select OBJECT(w) from SLAEventBean w") })
 
 public class SLAEventBean extends JsonSLAEvent implements Writable {


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

Posted by an...@apache.org.
http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/WorkflowActionBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/WorkflowActionBean.java b/core/src/main/java/org/apache/oozie/WorkflowActionBean.java
index 6b05b89..32bebae 100644
--- a/core/src/main/java/org/apache/oozie/WorkflowActionBean.java
+++ b/core/src/main/java/org/apache/oozie/WorkflowActionBean.java
@@ -58,23 +58,47 @@ import org.json.simple.JSONObject;
 @Entity
 @NamedQueries({
 
-    @NamedQuery(name = "UPDATE_ACTION", query = "update WorkflowActionBean a set a.conf = :conf, a.consoleUrl = :consoleUrl, a.data = :data, a.stats = :stats, a.externalChildIDs = :externalChildIDs, a.errorCode = :errorCode, a.errorMessage = :errorMessage, a.externalId = :externalId, a.externalStatus = :externalStatus, a.name = :name, a.cred = :cred , a.retries = :retries, a.trackerUri = :trackerUri, a.transition = :transition, a.type = :type, a.endTimestamp = :endTime, a.executionPath = :executionPath, a.lastCheckTimestamp = :lastCheckTime, a.logToken = :logToken, a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.signalValue = :signalValue, a.slaXml = :slaXml, a.startTimestamp = :startTime, a.statusStr = :status, a.wfId=:wfId where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_FOR_LAST_CHECKED_TIME", query = "update WorkflowActionBean a set a.lastCheckTimestamp = :lastCheckTime where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_START", query = "update WorkflowActionBean a set a.startTimestamp = :startTime, a.externalChildIDs = :externalChildIDs, a.conf = :conf, a.errorCode = :errorCode, a.errorMessage = :errorMessage, a.startTimestamp = :startTime, a.externalId = :externalId, a.trackerUri = :trackerUri, a.consoleUrl = :consoleUrl, a.lastCheckTimestamp = :lastCheckTime, a.statusStr = :status, a.externalStatus = :externalStatus, a.data = :data, a.retries = :retries, a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.userRetryCount = :userRetryCount where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_CHECK", query = "update WorkflowActionBean a set a.userRetryCount = :userRetryCount, a.stats = :stats, a.externalChildIDs = :externalChildIDs, a.externalStatus = :externalStatus, a.statusStr = :status, a.data = :data, a.pending = :pending, a.errorCode = :errorCode, a.errorMessage = :errorMessage, a.lastCheckTimestamp = :lastCheckTime, a.retries = :retries, a.pendingAgeTimestamp = :pendingAge, a.startTimestamp = :startTime where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_END", query = "update WorkflowActionBean a set a.stats = :stats, a.errorCode = :errorCode, a.errorMessage = :errorMessage, a.retries = :retries, a.endTimestamp = :endTime, a.statusStr = :status, a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.signalValue = :signalValue, a.userRetryCount = :userRetryCount, a.externalStatus = :externalStatus where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_PENDING", query = "update WorkflowActionBean a set a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.executionPath = :executionPath where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_STATUS_PENDING", query = "update WorkflowActionBean a set a.statusStr = :status, a.pending = :pending, a.pendingAgeTimestamp = :pendingAge where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_PENDING_TRANS", query = "update WorkflowActionBean a set a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.transition = :transition where a.id = :id"),
-
-    @NamedQuery(name = "UPDATE_ACTION_PENDING_TRANS_ERROR", query = "update WorkflowActionBean a set a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.transition = :transition, a.errorCode = :errorCode, a.errorMessage = :errorMessage, a.statusStr = :status where a.id = :id"),
+    @NamedQuery(name = "UPDATE_ACTION", query = "update WorkflowActionBean a set a.conf = :conf, a.consoleUrl = :consoleUrl,"
+            + " a.data = :data, a.stats = :stats, a.externalChildIDs = :externalChildIDs, a.errorCode = :errorCode,"
+            + " a.errorMessage = :errorMessage, a.externalId = :externalId, a.externalStatus = :externalStatus, a.name = :name,"
+            + " a.cred = :cred , a.retries = :retries, a.trackerUri = :trackerUri, a.transition = :transition, a.type = :type,"
+            + " a.endTimestamp = :endTime, a.executionPath = :executionPath, a.lastCheckTimestamp = :lastCheckTime, a.logToken "
+            + "= :logToken, a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.signalValue = :signalValue, a.slaXml "
+            + "= :slaXml, a.startTimestamp = :startTime, a.statusStr = :status, a.wfId=:wfId where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_FOR_LAST_CHECKED_TIME", query = "update WorkflowActionBean a set a.lastCheckTimestamp "
+            + "= :lastCheckTime where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_START", query = "update WorkflowActionBean a set a.startTimestamp = :startTime,"
+            + " a.externalChildIDs = :externalChildIDs, a.conf = :conf, a.errorCode = :errorCode, a.errorMessage = :errorMessage,"
+            + " a.startTimestamp = :startTime, a.externalId = :externalId, a.trackerUri = :trackerUri, a.consoleUrl "
+            + "= :consoleUrl, a.lastCheckTimestamp = :lastCheckTime, a.statusStr = :status, a.externalStatus = :externalStatus,"
+            + " a.data = :data, a.retries = :retries, a.pending = :pending, a.pendingAgeTimestamp = :pendingAge, a.userRetryCount"
+            + " = :userRetryCount where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_CHECK", query = "update WorkflowActionBean a set a.userRetryCount = :userRetryCount,"
+            + " a.stats = :stats, a.externalChildIDs = :externalChildIDs, a.externalStatus = :externalStatus, a.statusStr "
+            + "= :status, a.data = :data, a.pending = :pending, a.errorCode = :errorCode, a.errorMessage = :errorMessage,"
+            + " a.lastCheckTimestamp = :lastCheckTime, a.retries = :retries, a.pendingAgeTimestamp = :pendingAge,"
+            + " a.startTimestamp = :startTime where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_END", query = "update WorkflowActionBean a set a.stats = :stats, a.errorCode = :errorCode,"
+            + " a.errorMessage = :errorMessage, a.retries = :retries, a.endTimestamp = :endTime, a.statusStr = :status, a.pending"
+            + " = :pending, a.pendingAgeTimestamp = :pendingAge, a.signalValue = :signalValue, a.userRetryCount "
+            + "= :userRetryCount, a.externalStatus = :externalStatus where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_PENDING", query = "update WorkflowActionBean a set a.pending = :pending,"
+            + " a.pendingAgeTimestamp = :pendingAge, a.executionPath = :executionPath where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_STATUS_PENDING", query = "update WorkflowActionBean a set a.statusStr = :status, a.pending"
+            + " = :pending, a.pendingAgeTimestamp = :pendingAge where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_PENDING_TRANS", query = "update WorkflowActionBean a set a.pending = :pending,"
+            + " a.pendingAgeTimestamp = :pendingAge, a.transition = :transition where a.id = :id"),
+
+    @NamedQuery(name = "UPDATE_ACTION_PENDING_TRANS_ERROR", query = "update WorkflowActionBean a set a.pending = :pending,"
+            + " a.pendingAgeTimestamp = :pendingAge, a.transition = :transition, a.errorCode = :errorCode, a.errorMessage "
+            + "= :errorMessage, a.statusStr = :status where a.id = :id"),
 
     @NamedQuery(name = "DELETE_ACTION", query = "delete from WorkflowActionBean a where a.id IN (:id)"),
 
@@ -84,33 +108,53 @@ import org.json.simple.JSONObject;
 
     @NamedQuery(name = "GET_ACTION", query = "select OBJECT(a) from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_ID_TYPE_LASTCHECK", query = "select a.id, a.type, a.lastCheckTimestamp from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_ID_TYPE_LASTCHECK", query = "select a.id, a.type, a.lastCheckTimestamp "
+            + "from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_FAIL", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.type, a.logToken, a.transition, a.errorCode, a.errorMessage from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_FAIL", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.type, a.logToken,"
+            + " a.transition, a.errorCode, a.errorMessage from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_SIGNAL", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.pendingAgeTimestamp, a.type, a.logToken, a.transition, a.errorCode, a.errorMessage, a.executionPath, a.signalValue, a.slaXml, a.externalId from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_SIGNAL", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.pendingAgeTimestamp,"
+            + " a.type, a.logToken, a.transition, a.errorCode, a.errorMessage, a.executionPath, a.signalValue, a.slaXml,"
+            + " a.externalId from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_CHECK", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.pendingAgeTimestamp, a.type, a.logToken, a.transition, a.retries, a.userRetryCount, a.userRetryMax, a.userRetryInterval, a.trackerUri, a.startTimestamp, a.endTimestamp, a.lastCheckTimestamp, a.errorCode, a.errorMessage, a.externalId, a.externalStatus, a.externalChildIDs, a.conf from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_CHECK", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.pendingAgeTimestamp,"
+            + " a.type, a.logToken, a.transition, a.retries, a.userRetryCount, a.userRetryMax, a.userRetryInterval, a.trackerUri,"
+            + " a.startTimestamp, a.endTimestamp, a.lastCheckTimestamp, a.errorCode, a.errorMessage, a.externalId,"
+            + " a.externalStatus, a.externalChildIDs, a.conf from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_END", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.pendingAgeTimestamp, a.type, a.logToken, a.transition, a.retries, a.trackerUri, a.userRetryCount, a.userRetryMax, a.userRetryInterval, a.startTimestamp, a.endTimestamp, a.errorCode, a.errorMessage, a.externalId, a.externalStatus, a.externalChildIDs, a.conf, a.data, a.stats from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_END", query = "select a.id, a.wfId, a.name, a.statusStr, a.pending, a.pendingAgeTimestamp,"
+            + " a.type, a.logToken, a.transition, a.retries, a.trackerUri, a.userRetryCount, a.userRetryMax, a.userRetryInterval,"
+            + " a.startTimestamp, a.endTimestamp, a.errorCode, a.errorMessage, a.externalId, a.externalStatus,"
+            + " a.externalChildIDs, a.conf, a.data, a.stats from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_COMPLETED", query = "select a.id, a.wfId, a.statusStr, a.type, a.logToken from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_COMPLETED", query = "select a.id, a.wfId, a.statusStr, a.type, a.logToken "
+            + "from WorkflowActionBean a where a.id = :id"),
 
     @NamedQuery(name = "GET_ACTION_FOR_UPDATE", query = "select OBJECT(a) from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTION_FOR_SLA", query = "select a.id, a.statusStr, a.startTimestamp, a.endTimestamp from WorkflowActionBean a where a.id = :id"),
+    @NamedQuery(name = "GET_ACTION_FOR_SLA", query = "select a.id, a.statusStr, a.startTimestamp, a.endTimestamp "
+            + "from WorkflowActionBean a where a.id = :id"),
 
-    @NamedQuery(name = "GET_ACTIONS_FOR_WORKFLOW", query = "select OBJECT(a) from WorkflowActionBean a where a.wfId = :wfId order by a.startTimestamp"),
+    @NamedQuery(name = "GET_ACTIONS_FOR_WORKFLOW", query = "select OBJECT(a) from WorkflowActionBean a where a.wfId = :wfId "
+            + "order by a.startTimestamp"),
 
-    @NamedQuery(name = "GET_ACTIONS_OF_WORKFLOW_FOR_UPDATE", query = "select OBJECT(a) from WorkflowActionBean a where a.wfId = :wfId order by a.startTimestamp"),
+    @NamedQuery(name = "GET_ACTIONS_OF_WORKFLOW_FOR_UPDATE", query = "select OBJECT(a) from WorkflowActionBean a where a.wfId "
+            + "= :wfId order by a.startTimestamp"),
 
-    @NamedQuery(name = "GET_PENDING_ACTIONS", query = "select a.id, a.wfId, a.statusStr, a.type, a.pendingAgeTimestamp from WorkflowActionBean a where a.pending = 1 AND a.pendingAgeTimestamp < :pendingAge AND a.statusStr <> 'RUNNING' AND a.createdTimeTS >= :createdTime"),
+    @NamedQuery(name = "GET_PENDING_ACTIONS", query = "select a.id, a.wfId, a.statusStr, a.type, a.pendingAgeTimestamp from"
+            + " WorkflowActionBean a where a.pending = 1 AND a.pendingAgeTimestamp < :pendingAge AND a.statusStr <> 'RUNNING' "
+            + "AND a.createdTimeTS >= :createdTime"),
 
-    @NamedQuery(name = "GET_RUNNING_ACTIONS", query = "select a.id from WorkflowActionBean a where a.pending = 1 AND a.statusStr = 'RUNNING' AND a.lastCheckTimestamp < :lastCheckTime"),
+    @NamedQuery(name = "GET_RUNNING_ACTIONS", query = "select a.id from WorkflowActionBean a where a.pending = 1 AND a.statusStr"
+            + " = 'RUNNING' AND a.lastCheckTimestamp < :lastCheckTime"),
 
-    @NamedQuery(name = "GET_RETRY_MANUAL_ACTIONS", query = "select OBJECT(a) from WorkflowActionBean a where a.wfId = :wfId AND (a.statusStr = 'START_RETRY' OR a.statusStr = 'START_MANUAL' OR a.statusStr = 'END_RETRY' OR a.statusStr = 'END_MANUAL')"),
+    @NamedQuery(name = "GET_RETRY_MANUAL_ACTIONS", query = "select OBJECT(a) from WorkflowActionBean a where a.wfId = :wfId "
+            + "AND (a.statusStr = 'START_RETRY' OR a.statusStr = 'START_MANUAL' OR a.statusStr = 'END_RETRY' OR a.statusStr "
+            + "= 'END_MANUAL')"),
 
-    @NamedQuery(name = "GET_ACTIONS_FOR_WORKFLOW_RERUN", query = "select a.id, a.name, a.statusStr, a.endTimestamp, a.type from WorkflowActionBean a where a.wfId = :wfId order by a.startTimestamp") })
+    @NamedQuery(name = "GET_ACTIONS_FOR_WORKFLOW_RERUN", query = "select a.id, a.name, a.statusStr, a.endTimestamp, a.type "
+            + "from WorkflowActionBean a where a.wfId = :wfId order by a.startTimestamp") })
 @Table(name = "WF_ACTIONS")
 public class WorkflowActionBean implements Writable, WorkflowAction, JsonBean {
     @Id

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/WorkflowJobBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/WorkflowJobBean.java b/core/src/main/java/org/apache/oozie/WorkflowJobBean.java
index cb06bec..22a01d3 100644
--- a/core/src/main/java/org/apache/oozie/WorkflowJobBean.java
+++ b/core/src/main/java/org/apache/oozie/WorkflowJobBean.java
@@ -55,73 +55,110 @@ import java.util.List;
 
 @NamedQueries({
 
-    @NamedQuery(name = "UPDATE_WORKFLOW", query = "update WorkflowJobBean w set w.appName = :appName, w.appPath = :appPath, w.conf = :conf, w.group = :groupName, w.run = :run, w.user = :user, w.createdTimestamp = :createdTime, w.endTimestamp = :endTime, w.externalId = :externalId, w.lastModifiedTimestamp = :lastModTime,w.logToken = :logToken, w.protoActionConf = :protoActionConf, w.slaXml =:slaXml, w.startTimestamp = :startTime, w.statusStr = :status, w.wfInstance = :wfInstance where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW", query = "update WorkflowJobBean w set w.appName = :appName, w.appPath = :appPath,"
+            + " w.conf = :conf, w.group = :groupName, w.run = :run, w.user = :user, w.createdTimestamp = :createdTime,"
+            + " w.endTimestamp = :endTime, w.externalId = :externalId, w.lastModifiedTimestamp = :lastModTime,w.logToken "
+            + "= :logToken, w.protoActionConf = :protoActionConf, w.slaXml =:slaXml, w.startTimestamp = :startTime, w.statusStr "
+            + "= :status, w.wfInstance = :wfInstance where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_MODTIME", query = "update WorkflowJobBean w set w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_MODTIME", query = "update WorkflowJobBean w set w.lastModifiedTimestamp = :lastModTime"
+            + " where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_MODTIME", query = "update WorkflowJobBean w set w.statusStr = :status, w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_MODTIME", query = "update WorkflowJobBean w set w.statusStr = :status,"
+            + " w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_PARENT_MODIFIED", query = "update WorkflowJobBean w set w.parentId = :parentId, w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_PARENT_MODIFIED", query = "update WorkflowJobBean w set w.parentId = :parentId,"
+            + " w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_INSTANCE_MODIFIED", query = "update WorkflowJobBean w set w.statusStr = :status, w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_INSTANCE_MODIFIED", query = "update WorkflowJobBean w set w.statusStr = :status,"
+            + " w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_INSTANCE_MOD_END", query = "update WorkflowJobBean w set w.statusStr = :status, w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime, w.endTimestamp = :endTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_INSTANCE_MOD_END", query = "update WorkflowJobBean w set w.statusStr = :status,"
+            + " w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime, w.endTimestamp = :endTime where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_INSTANCE_MOD_START_END", query = "update WorkflowJobBean w set w.statusStr = :status, w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime, w.startTimestamp = :startTime, w.endTimestamp = :endTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_STATUS_INSTANCE_MOD_START_END", query = "update WorkflowJobBean w set w.statusStr "
+            + "= :status, w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime, w.startTimestamp = :startTime,"
+            + " w.endTimestamp = :endTime where w.id = :id"),
 
-    @NamedQuery(name = "UPDATE_WORKFLOW_RERUN", query = "update WorkflowJobBean w set w.appName = :appName, w.protoActionConf = :protoActionConf, w.appPath = :appPath, w.conf = :conf, w.logToken = :logToken, w.user = :user, w.group = :group, w.externalId = :externalId, w.endTimestamp = :endTime, w.run = :run, w.statusStr = :status, w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
+    @NamedQuery(name = "UPDATE_WORKFLOW_RERUN", query = "update WorkflowJobBean w set w.appName = :appName, w.protoActionConf "
+            + "= :protoActionConf, w.appPath = :appPath, w.conf = :conf, w.logToken = :logToken, w.user = :user, w.group "
+            + "= :group, w.externalId = :externalId, w.endTimestamp = :endTime, w.run = :run, w.statusStr = :status,"
+            + " w.wfInstance = :wfInstance, w.lastModifiedTimestamp = :lastModTime where w.id = :id"),
 
     @NamedQuery(name = "DELETE_WORKFLOW", query = "delete from WorkflowJobBean w where w.id IN (:id)"),
 
     @NamedQuery(name = "GET_WORKFLOWS", query = "select OBJECT(w) from WorkflowJobBean w order by w.startTimestamp desc"),
 
-    @NamedQuery(name = "GET_WORKFLOWS_COLUMNS", query = "select w.id, w.appName, w.statusStr, w.run, w.user, w.group, w.createdTimestamp, w.startTimestamp, w.lastModifiedTimestamp, w.endTimestamp, w.externalId, w.parentId from WorkflowJobBean w order by w.createdTimestamp desc"),
+    @NamedQuery(name = "GET_WORKFLOWS_COLUMNS", query = "select w.id, w.appName, w.statusStr, w.run, w.user, w.group,"
+            + " w.createdTimestamp, w.startTimestamp, w.lastModifiedTimestamp, w.endTimestamp, w.externalId, w.parentId "
+            + "from WorkflowJobBean w order by w.createdTimestamp desc"),
 
     @NamedQuery(name = "GET_WORKFLOWS_COUNT", query = "select count(w) from WorkflowJobBean w"),
 
-    @NamedQuery(name = "GET_COMPLETED_WORKFLOWS_OLDER_THAN", query = "select w from WorkflowJobBean w where w.endTimestamp < :endTime"),
+    @NamedQuery(name = "GET_COMPLETED_WORKFLOWS_OLDER_THAN", query = "select w from WorkflowJobBean w where w.endTimestamp"
+            + " < :endTime"),
 
-    @NamedQuery(name = "GET_COMPLETED_WORKFLOWS_WITH_NO_PARENT_OLDER_THAN", query = "select w.id from WorkflowJobBean w where w.endTimestamp < :endTime and w.parentId is null"),
+    @NamedQuery(name = "GET_COMPLETED_WORKFLOWS_WITH_NO_PARENT_OLDER_THAN", query = "select w.id from WorkflowJobBean w "
+            + "where w.endTimestamp < :endTime and w.parentId is null"),
 
-    @NamedQuery(name = "GET_COMPLETED_COORD_WORKFLOWS_OLDER_THAN", query = "select w.id, w.parentId from WorkflowJobBean w where w.endTimestamp < :endTime and w.parentId like '%C@%'"),
+    @NamedQuery(name = "GET_COMPLETED_COORD_WORKFLOWS_OLDER_THAN", query = "select w.id, w.parentId from WorkflowJobBean w "
+            + "where w.endTimestamp < :endTime and w.parentId like '%C@%'"),
 
     @NamedQuery(name = "GET_WORKFLOW", query = "select OBJECT(w) from WorkflowJobBean w where w.id = :id"),
 
     @NamedQuery(name = "GET_WORKFLOW_STARTTIME", query = "select w.id, w.startTimestamp from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_START_END_TIME", query = "select w.id, w.startTimestamp, w.endTimestamp from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_START_END_TIME", query = "select w.id, w.startTimestamp, w.endTimestamp "
+            + "from WorkflowJobBean w where w.id = :id"),
 
     @NamedQuery(name = "GET_WORKFLOW_USER_GROUP", query = "select w.user, w.group from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_SUSPEND", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.parentId, w.startTimestamp, w.endTimestamp, w.logToken, w.wfInstance  from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_SUSPEND", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.parentId,"
+            + " w.startTimestamp, w.endTimestamp, w.logToken, w.wfInstance  from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_RERUN", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.run, w.logToken, w.wfInstance, w.parentId from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_RERUN", query = "select w.id, w.user, w.group, w.appName, w.statusStr, w.run, w.logToken,"
+            + " w.wfInstance, w.parentId from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_DEFINITION", query = "select w.id, w.user, w.group, w.appName, w.logToken, w.wfInstance from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_DEFINITION", query = "select w.id, w.user, w.group, w.appName, w.logToken, w.wfInstance "
+            + "from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_ACTION_OP", query = "select w.id, w.user, w.group, w.appName, w.appPath, w.statusStr, w.run, w.parentId, w.logToken, w.wfInstance, w.protoActionConf from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_ACTION_OP", query = "select w.id, w.user, w.group, w.appName, w.appPath, w.statusStr, w.run,"
+            + " w.parentId, w.logToken, w.wfInstance, w.protoActionConf from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_KILL", query = "select w.id, w.user, w.group, w.appName, w.appPath, w.statusStr, w.parentId, w.startTimestamp, w.endTimestamp, w.logToken, w.wfInstance, w.slaXml, w.protoActionConf from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_KILL", query = "select w.id, w.user, w.group, w.appName, w.appPath, w.statusStr, w.parentId,"
+            + " w.startTimestamp, w.endTimestamp, w.logToken, w.wfInstance, w.slaXml, w.protoActionConf from WorkflowJobBean w"
+            + " where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_RESUME", query = "select w.id, w.user, w.group, w.appName, w.appPath, w.statusStr, w.parentId, w.startTimestamp, w.endTimestamp, w.logToken, w.wfInstance, w.protoActionConf from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_RESUME", query = "select w.id, w.user, w.group, w.appName, w.appPath, w.statusStr,"
+            + " w.parentId, w.startTimestamp, w.endTimestamp, w.logToken, w.wfInstance, w.protoActionConf from WorkflowJobBean w "
+            + "where w.id = :id"),
 
     @NamedQuery(name = "GET_WORKFLOW_FOR_UPDATE", query = "select OBJECT(w) from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_FOR_SLA", query = "select w.id, w.statusStr, w.startTimestamp, w.endTimestamp from WorkflowJobBean w where w.id = :id"),
+    @NamedQuery(name = "GET_WORKFLOW_FOR_SLA", query = "select w.id, w.statusStr, w.startTimestamp, w.endTimestamp "
+            + "from WorkflowJobBean w where w.id = :id"),
 
-    @NamedQuery(name = "GET_WORKFLOW_ID_FOR_EXTERNAL_ID", query = "select  w.id from WorkflowJobBean w where w.externalId = :externalId"),
+    @NamedQuery(name = "GET_WORKFLOW_ID_FOR_EXTERNAL_ID", query = "select  w.id from WorkflowJobBean w where w.externalId "
+            + "= :externalId"),
 
-    @NamedQuery(name = "GET_WORKFLOWS_COUNT_WITH_STATUS", query = "select count(w) from WorkflowJobBean w where w.statusStr = :status"),
+    @NamedQuery(name = "GET_WORKFLOWS_COUNT_WITH_STATUS", query = "select count(w) from WorkflowJobBean w where w.statusStr "
+            + "= :status"),
 
-    @NamedQuery(name = "GET_WORKFLOWS_COUNT_WITH_STATUS_IN_LAST_N_SECS", query = "select count(w) from WorkflowJobBean w where w.statusStr = :status and w.lastModifiedTimestamp > :lastModTime"),
+    @NamedQuery(name = "GET_WORKFLOWS_COUNT_WITH_STATUS_IN_LAST_N_SECS", query = "select count(w) from WorkflowJobBean w "
+            + "where w.statusStr = :status and w.lastModifiedTimestamp > :lastModTime"),
 
-    @NamedQuery(name = "GET_WORKFLOWS_WITH_WORKFLOW_PARENT_ID", query = "select w.id from WorkflowJobBean w where w.parentId = :parentId"),
+    @NamedQuery(name = "GET_WORKFLOWS_WITH_WORKFLOW_PARENT_ID", query = "select w.id from WorkflowJobBean w where w.parentId "
+            + "= :parentId"),
 
-    @NamedQuery(name = "GET_WORKFLOWS_WITH_COORD_PARENT_ID", query = "select w.id from WorkflowJobBean w where w.parentId like :parentId"), // when setting parentId parameter, make sure to append a '%' (percent symbol) at the end (e.g. 0000004-130709155224435-oozie-rkan-C%")
+    @NamedQuery(name = "GET_WORKFLOWS_WITH_COORD_PARENT_ID", query = "select w.id from WorkflowJobBean w where w.parentId "
+            + "like :parentId"), // when setting parentId parameter, make sure to append a '%' (percent symbol) at the end
+    //(e.g. 0000004-130709155224435-oozie-rkan-C%")
 
-    @NamedQuery(name = "GET_WORKFLOWS_BASIC_INFO_BY_PARENT_ID", query = "select w.id, w.statusStr, w.endTimestamp, w.lastModifiedTimestamp from WorkflowJobBean w where w.parentId = :parentId"),
+    @NamedQuery(name = "GET_WORKFLOWS_BASIC_INFO_BY_PARENT_ID", query = "select w.id, w.statusStr, w.endTimestamp,"
+            + " w.lastModifiedTimestamp from WorkflowJobBean w where w.parentId = :parentId"),
 
-    @NamedQuery(name = "GET_WORKFLOWS_BASIC_INFO_BY_COORD_PARENT_ID", query = "select w.id,  w.statusStr, w.endTimestamp, w.lastModifiedTimestamp from WorkflowJobBean w where w.parentId like :parentId"),
+    @NamedQuery(name = "GET_WORKFLOWS_BASIC_INFO_BY_COORD_PARENT_ID", query = "select w.id,  w.statusStr, w.endTimestamp,"
+            + " w.lastModifiedTimestamp from WorkflowJobBean w where w.parentId like :parentId"),
 
     @NamedQuery(name = "GET_WORKFLOW_FOR_USER", query = "select w.user from WorkflowJobBean w where w.id = :id"),
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/action/hadoop/JavaActionExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/action/hadoop/JavaActionExecutor.java b/core/src/main/java/org/apache/oozie/action/hadoop/JavaActionExecutor.java
index b9c89b2..427f43d 100644
--- a/core/src/main/java/org/apache/oozie/action/hadoop/JavaActionExecutor.java
+++ b/core/src/main/java/org/apache/oozie/action/hadoop/JavaActionExecutor.java
@@ -135,7 +135,8 @@ public class JavaActionExecutor extends ActionExecutor {
     public static final String LAUNCER_VIEW_ACL = "oozie.launcher.view.acl";
 
     public static final String MAPREDUCE_TO_CLASSPATH = "mapreduce.needed.for";
-    public static final String OOZIE_LAUNCHER_ADD_MAPREDUCE_TO_CLASSPATH_PROPERTY = ActionExecutor.CONF_PREFIX + MAPREDUCE_TO_CLASSPATH;
+    public static final String OOZIE_LAUNCHER_ADD_MAPREDUCE_TO_CLASSPATH_PROPERTY = ActionExecutor.CONF_PREFIX
+            + MAPREDUCE_TO_CLASSPATH;
 
     public static final String MAX_EXTERNAL_STATS_SIZE = "oozie.external.stats.max.size";
     public static final String ACL_VIEW_JOB = "mapreduce.job.acl-view-job";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/client/rest/JsonBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/client/rest/JsonBean.java b/core/src/main/java/org/apache/oozie/client/rest/JsonBean.java
index c8bd7c2..00d06ef 100644
--- a/core/src/main/java/org/apache/oozie/client/rest/JsonBean.java
+++ b/core/src/main/java/org/apache/oozie/client/rest/JsonBean.java
@@ -31,7 +31,7 @@ public interface JsonBean {
      * @return the JSONObject for the bean with GMT time zone.
      */
     JSONObject toJSONObject();
-    
+
     /**
      * Return the JSONObject for the bean with the given time zone.
      *

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/bundle/BundleJobSuspendXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/bundle/BundleJobSuspendXCommand.java b/core/src/main/java/org/apache/oozie/command/bundle/BundleJobSuspendXCommand.java
index 669ac5e..5c3d84e 100644
--- a/core/src/main/java/org/apache/oozie/command/bundle/BundleJobSuspendXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/bundle/BundleJobSuspendXCommand.java
@@ -131,7 +131,8 @@ public class BundleJobSuspendXCommand extends SuspendTransitionXCommand {
     protected void verifyPrecondition() throws CommandException, PreconditionException {
         if (bundleJob.getStatus() == Job.Status.SUCCEEDED || bundleJob.getStatus() == Job.Status.FAILED
                 || bundleJob.getStatus() == Job.Status.KILLED || bundleJob.getStatus() == Job.Status.DONEWITHERROR) {
-            LOG.info("BundleJobSuspendXCommand is not going to execute because job either succeeded, failed, killed, or donewitherror; id = "
+            LOG.info("BundleJobSuspendXCommand is not going to execute because job either succeeded, failed, killed,"
+                    + " or donewitherror; id = "
                             + jobId + ", status = " + bundleJob.getStatus());
             throw new PreconditionException(ErrorCode.E1312, jobId, bundleJob.getStatus().toString());
         }
@@ -146,7 +147,8 @@ public class BundleJobSuspendXCommand extends SuspendTransitionXCommand {
         bundleJob.setSuspendedTime(new Date());
         bundleJob.setLastModifiedTime(new Date());
 
-        LOG.debug("Suspend bundle job id = " + jobId + ", status = " + bundleJob.getStatus() + ", pending = " + bundleJob.isPending());
+        LOG.debug("Suspend bundle job id = " + jobId + ", status = " + bundleJob.getStatus() + ", pending = "
+        + bundleJob.isPending());
         updateList.add(new UpdateEntry<BundleJobQuery>(BundleJobQuery.UPDATE_BUNDLE_JOB_STATUS_PENDING_SUSP_MOD_TIME, bundleJob));
     }
 
@@ -160,7 +162,8 @@ public class BundleJobSuspendXCommand extends SuspendTransitionXCommand {
                 if (action.getCoordId() != null) {
                     queue(new CoordSuspendXCommand(action.getCoordId()));
                     updateBundleAction(action);
-                    LOG.debug("Suspend bundle action = [{0}], new status = [{1}], pending = [{2}] and queue CoordSuspendXCommand for [{3}]",
+                    LOG.debug("Suspend bundle action = [{0}], new status = [{1}], pending = [{2}] and queue CoordSuspendXCommand"
+                            + " for [{3}]",
                             action.getBundleActionId(), action.getStatus(), action.getPending(), action.getCoordId());
                 } else {
                     updateBundleAction(action);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordActionInputCheckXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordActionInputCheckXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordActionInputCheckXCommand.java
index 179cc45..b3174d2 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordActionInputCheckXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordActionInputCheckXCommand.java
@@ -510,7 +510,8 @@ public class CoordActionInputCheckXCommand extends CoordinatorXCommand<Void> {
             return;
         }
 
-        if (coordJob.getStatus() != Job.Status.RUNNING && coordJob.getStatus() != Job.Status.RUNNINGWITHERROR && coordJob.getStatus() != Job.Status.PAUSED
+        if (coordJob.getStatus() != Job.Status.RUNNING && coordJob.getStatus() != Job.Status.RUNNINGWITHERROR
+                && coordJob.getStatus() != Job.Status.PAUSED
                 && coordJob.getStatus() != Job.Status.PAUSEDWITHERROR) {
             throw new PreconditionException(
                     ErrorCode.E1100, "["+ actionId + "]::CoordActionInputCheck:: Ignoring action." +

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordActionStartXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordActionStartXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordActionStartXCommand.java
index 16d7036..dbc188a 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordActionStartXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordActionStartXCommand.java
@@ -193,7 +193,8 @@ public class CoordActionStartXCommand extends CoordinatorXCommand<Void> {
             DagEngine dagEngine = Services.get().get(DagEngineService.class).getDagEngine(user);
             try {
                 Configuration conf = new XConfiguration(new StringReader(coordAction.getRunConf()));
-                SLAEventBean slaEvent = SLADbOperations.createStatusEvent(coordAction.getSlaXml(), coordAction.getId(), Status.STARTED,
+                SLAEventBean slaEvent = SLADbOperations.createStatusEvent(coordAction.getSlaXml(), coordAction.getId(),
+                        Status.STARTED,
                         SlaAppType.COORDINATOR_ACTION, log);
                 if(slaEvent != null) {
                     insertList.add(slaEvent);
@@ -221,7 +222,8 @@ public class CoordActionStartXCommand extends CoordinatorXCommand<Void> {
                 JPAService jpaService = Services.get().get(JPAService.class);
                 if (jpaService != null) {
                     log.debug("Updating WF record for WFID :" + coordAction.getExternalId() + " with parent id: " + actionId);
-                    WorkflowJobBean wfJob = WorkflowJobQueryExecutor.getInstance().get(WorkflowJobQuery.GET_WORKFLOW_STARTTIME, coordAction.getExternalId());
+                    WorkflowJobBean wfJob = WorkflowJobQueryExecutor.getInstance().get(WorkflowJobQuery.GET_WORKFLOW_STARTTIME,
+                            coordAction.getExternalId());
                     wfJob.setParentId(actionId);
                     wfJob.setLastModifiedTime(new Date());
                     BatchQueryExecutor executor = BatchQueryExecutor.getInstance();
@@ -281,7 +283,8 @@ public class CoordActionStartXCommand extends CoordinatorXCommand<Void> {
                                     CoordActionQuery.UPDATE_COORD_ACTION_FOR_START, coordAction));
                     insertList = new ArrayList<JsonBean>();
 
-                    SLAEventBean slaEvent = SLADbOperations.createStatusEvent(coordAction.getSlaXml(), coordAction.getId(), Status.FAILED,
+                    SLAEventBean slaEvent = SLADbOperations.createStatusEvent(coordAction.getSlaXml(), coordAction.getId(),
+                            Status.FAILED,
                             SlaAppType.COORDINATOR_ACTION, log);
                     if(slaEvent != null) {
                         insertList.add(slaEvent); //Update SLA events

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordChangeXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordChangeXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordChangeXCommand.java
index ff7bf8a..3b7b664 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordChangeXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordChangeXCommand.java
@@ -281,7 +281,8 @@ public class CoordChangeXCommand extends CoordinatorXCommand<Void> {
                     if (SLAService.isEnabled()) {
                         Services.get().get(SLAService.class).removeRegistration(actionId);
                     }
-                    SLARegistrationBean slaReg = SLARegistrationQueryExecutor.getInstance().get(SLARegQuery.GET_SLA_REG_ALL, actionId);
+                    SLARegistrationBean slaReg = SLARegistrationQueryExecutor.getInstance().get(SLARegQuery.GET_SLA_REG_ALL,
+                            actionId);
                     if (slaReg != null) {
                         LOG.debug("Deleting registration bean corresponding to action " + slaReg.getId());
                         deleteList.add(slaReg);
@@ -446,7 +447,8 @@ public class CoordChangeXCommand extends CoordinatorXCommand<Void> {
                 }
             }
 
-            if (coordJob.getNextMaterializedTime() != null && coordJob.getEndTime().compareTo(coordJob.getNextMaterializedTime()) <= 0) {
+            if (coordJob.getNextMaterializedTime() != null && coordJob.getEndTime()
+                    .compareTo(coordJob.getNextMaterializedTime()) <= 0) {
                 LOG.info("[" + coordJob.getId() + "]: all actions have been materialized, job status = " + coordJob.getStatus()
                         + ", set pending to true");
                 // set doneMaterialization to true when materialization is done

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordCommandUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordCommandUtils.java b/core/src/main/java/org/apache/oozie/command/coord/CoordCommandUtils.java
index fbc6152..4e4a569 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordCommandUtils.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordCommandUtils.java
@@ -198,7 +198,8 @@ public class CoordCommandUtils {
                     || getFuncType(startInst) == ENDOFWEEKS || getFuncType(startInst) == ENDOFDAYS) {
                 if (getFuncType(endInst) != CURRENT) {
                     throw new CommandException(ErrorCode.E1010,
-                            "Only start-instance as absolute/endOfMonths/endOfWeeks/endOfDays and end-instance as current is supported."
+                            "Only start-instance as absolute/endOfMonths/endOfWeeks/endOfDays and end-instance as current is"
+                            + " supported."
                                     + " start = " + startInst + "  end = " + endInst);
                 }
             }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordMaterializeTransitionXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordMaterializeTransitionXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordMaterializeTransitionXCommand.java
index b4e62e9..ff1aa37 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordMaterializeTransitionXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordMaterializeTransitionXCommand.java
@@ -222,7 +222,9 @@ public class CoordMaterializeTransitionXCommand extends MaterializeTransitionXCo
         if (endMatdTime.compareTo(jobEndTime) > 0) {
             endMatdTime = jobEndTime;
         }
-        LOG.debug("Materializing coord job id=" + jobId + ", start=" + DateUtils.formatDateOozieTZ(startMatdTime) + ", end=" + DateUtils.formatDateOozieTZ(endMatdTime)
+
+        LOG.debug("Materializing coord job id=" + jobId + ", start=" + DateUtils.formatDateOozieTZ(startMatdTime) + ", end="
+                + DateUtils.formatDateOozieTZ(endMatdTime)
                 + ", window=" + materializationWindow);
     }
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordPushDependencyCheckXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordPushDependencyCheckXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordPushDependencyCheckXCommand.java
index 1e864ea..41b78af 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordPushDependencyCheckXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordPushDependencyCheckXCommand.java
@@ -185,7 +185,8 @@ public class CoordPushDependencyCheckXCommand extends CoordinatorXCommand<Void>
                 if (isTimeout()) {
                     LOG.debug("Queueing timeout command");
                     // XCommand.queue() will not work when there is a Exception
-                    callableQueueService.queue(new CoordActionTimeOutXCommand(coordAction, coordJob.getUser(), coordJob.getAppName()));
+                    callableQueueService.queue(new CoordActionTimeOutXCommand(coordAction, coordJob.getUser(),
+                            coordJob.getAppName()));
                     unregisterMissingDependencies(missingDependenciesArray, actionId);
                 }
                 else if (coordPullInputDependency.getMissingDependenciesAsList().size() > 0) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordResumeXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordResumeXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordResumeXCommand.java
index 1998924..3a70ebc 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordResumeXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordResumeXCommand.java
@@ -97,7 +97,8 @@ public class CoordResumeXCommand extends ResumeTransitionXCommand {
 
     @Override
     protected void verifyPrecondition() throws CommandException, PreconditionException {
-        if (coordJob.getStatus() != CoordinatorJob.Status.SUSPENDED && coordJob.getStatus() != CoordinatorJob.Status.SUSPENDEDWITHERROR && coordJob.getStatus() != Job.Status.PREPSUSPENDED) {
+        if (coordJob.getStatus() != CoordinatorJob.Status.SUSPENDED && coordJob.getStatus() != CoordinatorJob.Status
+                .SUSPENDEDWITHERROR && coordJob.getStatus() != Job.Status.PREPSUSPENDED) {
             throw new PreconditionException(ErrorCode.E1100, "CoordResumeXCommand not Resumed - "
                     + "job not in SUSPENDED/SUSPENDEDWITHERROR/PREPSUSPENDED state, job = " + jobId);
         }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordSubmitXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordSubmitXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordSubmitXCommand.java
index 42bdc99..2226b46 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordSubmitXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordSubmitXCommand.java
@@ -374,7 +374,8 @@ public class CoordSubmitXCommand extends SubmitTransitionXCommand {
 
   /*
   * Check against multiple data instance values inside a single <instance> <start-instance> or <end-instance> tag
-  * If found, the job is not submitted and user is informed to correct the error, instead of defaulting to the first instance value in the list
+  * If found, the job is not submitted and user is informed to correct the error,
+  *  instead of defaulting to the first instance value in the list
   */
     private void checkMultipleTimeInstances(Element eCoordJob, String eventType, String dataType) throws CoordinatorJobException {
         Element eventsSpec, dataSpec, instance;
@@ -385,7 +386,8 @@ public class CoordSubmitXCommand extends SubmitTransitionXCommand {
         if (eventsSpec != null) {
             dataSpec = eventsSpec.getChild(dataType, ns);
             if (dataSpec != null) {
-                // In case of input-events, there can be multiple child <instance> datasets. Iterating to ensure none of them have errors
+                // In case of input-events, there can be multiple child <instance> datasets.
+                // Iterating to ensure none of them have errors
                 instanceSpecList = dataSpec.getChildren("instance", ns);
                 Iterator instanceIter = instanceSpecList.iterator();
                 while(instanceIter.hasNext()) {
@@ -405,13 +407,15 @@ public class CoordSubmitXCommand extends SubmitTransitionXCommand {
                     }
                 }
 
-                // In case of input-events, there can be multiple child <start-instance> datasets. Iterating to ensure none of them have errors
+                // In case of input-events, there can be multiple child <start-instance> datasets.
+                // Iterating to ensure none of them have errors
                 instanceSpecList = dataSpec.getChildren("start-instance", ns);
                 instanceIter = instanceSpecList.iterator();
                 while(instanceIter.hasNext()) {
                     instance = ((Element) instanceIter.next());
                     if(instance.getContentSize() == 0) { //empty string or whitespace
-                        throw new CoordinatorJobException(ErrorCode.E1021, "<start-instance> tag within " + eventType + " is empty!");
+                        throw new CoordinatorJobException(ErrorCode.E1021, "<start-instance> tag within " + eventType
+                                + " is empty!");
                     }
                     instanceValue = instance.getContent(0).toString();
                     boolean isInvalid = false;
@@ -425,7 +429,8 @@ public class CoordSubmitXCommand extends SubmitTransitionXCommand {
                     }
                 }
 
-                // In case of input-events, there can be multiple child <end-instance> datasets. Iterating to ensure none of them have errors
+                // In case of input-events, there can be multiple child <end-instance> datasets.
+                // Iterating to ensure none of them have errors
                 instanceSpecList = dataSpec.getChildren("end-instance", ns);
                 instanceIter = instanceSpecList.iterator();
                 while(instanceIter.hasNext()) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/coord/CoordSuspendXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/coord/CoordSuspendXCommand.java b/core/src/main/java/org/apache/oozie/command/coord/CoordSuspendXCommand.java
index 1195ef0..7a4f0c0 100644
--- a/core/src/main/java/org/apache/oozie/command/coord/CoordSuspendXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/coord/CoordSuspendXCommand.java
@@ -164,7 +164,8 @@ public class CoordSuspendXCommand extends SuspendTransitionXCommand {
         InstrumentUtils.incrJobCounter(getName(), 1, getInstrumentation());
         coordJob.setLastModifiedTime(new Date());
         coordJob.setSuspendedTime(new Date());
-        LOG.debug("Suspend coordinator job id = " + jobId + ", status = " + coordJob.getStatus() + ", pending = " + coordJob.isPending());
+        LOG.debug("Suspend coordinator job id = " + jobId + ", status = " + coordJob.getStatus() + ", pending = "
+        + coordJob.isPending());
         updateList.add(new UpdateEntry<CoordJobQuery>(CoordJobQuery.UPDATE_COORD_JOB_STATUS_PENDING_TIME, coordJob));
     }
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/wf/ActionEndXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/wf/ActionEndXCommand.java b/core/src/main/java/org/apache/oozie/command/wf/ActionEndXCommand.java
index 86ee1cc..ef0ed66 100644
--- a/core/src/main/java/org/apache/oozie/command/wf/ActionEndXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/wf/ActionEndXCommand.java
@@ -129,7 +129,8 @@ public class ActionEndXCommand extends ActionXCommand<Void> {
         }
         if (wfAction.isPending()
                 && (wfAction.getStatus() == WorkflowActionBean.Status.DONE
-                        || wfAction.getStatus() == WorkflowActionBean.Status.END_RETRY || wfAction.getStatus() == WorkflowActionBean.Status.END_MANUAL)) {
+                        || wfAction.getStatus() == WorkflowActionBean.Status.END_RETRY || wfAction.getStatus()
+                        == WorkflowActionBean.Status.END_MANUAL)) {
 
             if (wfJob.getStatus() != WorkflowJob.Status.RUNNING) {
                 throw new PreconditionException(ErrorCode.E0811,  WorkflowJob.Status.RUNNING.toString());
@@ -217,7 +218,8 @@ public class ActionEndXCommand extends ActionXCommand<Void> {
                         break;
                 }
                 if (!shouldHandleUserRetry || !handleUserRetry(context, wfAction)) {
-                    SLAEventBean slaEvent = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(), slaStatus, SlaAppType.WORKFLOW_ACTION);
+                    SLAEventBean slaEvent = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(), slaStatus,
+                            SlaAppType.WORKFLOW_ACTION);
                     if(slaEvent != null) {
                         insertList.add(slaEvent);
                     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/wf/ActionKillXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/wf/ActionKillXCommand.java b/core/src/main/java/org/apache/oozie/command/wf/ActionKillXCommand.java
index 61891b8..94598a8 100644
--- a/core/src/main/java/org/apache/oozie/command/wf/ActionKillXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/wf/ActionKillXCommand.java
@@ -155,7 +155,8 @@ public class ActionKillXCommand extends ActionXCommand<Void> {
                     wfJob.setLastModifiedTime(new Date());
                     updateList.add(new UpdateEntry<WorkflowJobQuery>(WorkflowJobQuery.UPDATE_WORKFLOW_MODTIME, wfJob));
                     // Add SLA status event (KILLED) for WF_ACTION
-                    SLAEventBean slaEvent = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(), Status.KILLED,
+                    SLAEventBean slaEvent = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(),
+                            Status.KILLED,
                             SlaAppType.WORKFLOW_ACTION);
                     if(slaEvent != null) {
                         insertList.add(slaEvent);
@@ -174,7 +175,8 @@ public class ActionKillXCommand extends ActionXCommand<Void> {
                     wfJob.setLastModifiedTime(new Date());
                     updateList.add(new UpdateEntry<WorkflowJobQuery>(WorkflowJobQuery.UPDATE_WORKFLOW_STATUS_MODTIME, wfJob));
                     // What will happen to WF and COORD_ACTION, NOTIFICATION?
-                    SLAEventBean slaEvent = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(), Status.FAILED,
+                    SLAEventBean slaEvent = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(),
+                            Status.FAILED,
                             SlaAppType.WORKFLOW_ACTION);
                     if(slaEvent != null) {
                         insertList.add(slaEvent);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/wf/ActionStartXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/wf/ActionStartXCommand.java b/core/src/main/java/org/apache/oozie/command/wf/ActionStartXCommand.java
index 71c29cd..ab40c6e 100644
--- a/core/src/main/java/org/apache/oozie/command/wf/ActionStartXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/wf/ActionStartXCommand.java
@@ -227,7 +227,8 @@ public class ActionStartXCommand extends ActionXCommand<org.apache.oozie.command
                 wfAction.setErrorInfo(null, null);
                 incrActionCounter(wfAction.getType(), 1);
 
-                LOG.info("Start action [{0}] with user-retry state : userRetryCount [{1}], userRetryMax [{2}], userRetryInterval [{3}]",
+                LOG.info("Start action [{0}] with user-retry state : userRetryCount [{1}], userRetryMax [{2}], userRetryInterval"
+                        + " [{3}]",
                                 wfAction.getId(), wfAction.getUserRetryCount(), wfAction.getUserRetryMax(), wfAction
                                         .getUserRetryInterval());
 
@@ -237,7 +238,8 @@ public class ActionStartXCommand extends ActionXCommand<org.apache.oozie.command
                 if (wfAction.getStartTime() == null) {
                     context.setStartTime();
                 }
-                context.setVar(JobUtils.getRetryKey(wfAction, JsonTags.WORKFLOW_ACTION_START_TIME), String.valueOf(new Date().getTime()));
+                context.setVar(JobUtils.getRetryKey(wfAction, JsonTags.WORKFLOW_ACTION_START_TIME),
+                        String.valueOf(new Date().getTime()));
                 executor.start(context, wfAction);
                 cron.stop();
                 FaultInjection.activate("org.apache.oozie.command.SkipCommitFaultInjection");
@@ -309,7 +311,8 @@ public class ActionStartXCommand extends ActionXCommand<org.apache.oozie.command
                     try {
                         failJob(context);
                         endWF();
-                        SLAEventBean slaEvent1 = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(), Status.FAILED,
+                        SLAEventBean slaEvent1 = SLADbXOperations.createStatusEvent(wfAction.getSlaXml(), wfAction.getId(),
+                                Status.FAILED,
                                 SlaAppType.WORKFLOW_ACTION);
                         if(slaEvent1 != null) {
                             insertList.add(slaEvent1);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/command/wf/ActionXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/command/wf/ActionXCommand.java b/core/src/main/java/org/apache/oozie/command/wf/ActionXCommand.java
index 29ccd32..7e328b7 100644
--- a/core/src/main/java/org/apache/oozie/command/wf/ActionXCommand.java
+++ b/core/src/main/java/org/apache/oozie/command/wf/ActionXCommand.java
@@ -442,7 +442,8 @@ public abstract class ActionXCommand<T> extends WorkflowXCommand<T> {
 
         /*
          * (non-Javadoc)
-         * @see org.apache.oozie.action.ActionExecutor.Context#setEndData(org.apache.oozie.client.WorkflowAction.Status, java.lang.String)
+         * @see org.apache.oozie.action.ActionExecutor.Context#setEndData(org.apache.oozie.client.WorkflowAction.Status,
+         * java.lang.String)
          */
         public void setEndData(WorkflowAction.Status status, String signalValue) {
             action.setEndData(status, signalValue);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/coord/CoordUtils.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/coord/CoordUtils.java b/core/src/main/java/org/apache/oozie/coord/CoordUtils.java
index 2874bf6..e0c6af9 100644
--- a/core/src/main/java/org/apache/oozie/coord/CoordUtils.java
+++ b/core/src/main/java/org/apache/oozie/coord/CoordUtils.java
@@ -202,7 +202,8 @@ public class CoordUtils {
                 String[] range = s.split("-");
                 // Check the format for action's range
                 if (range.length != 2) {
-                    throw new CommandException(ErrorCode.E0302, "format is wrong for action's range '" + s + "', an example of correct format is 1-5");
+                    throw new CommandException(ErrorCode.E0302, "format is wrong for action's range '" + s + "', an example of"
+                            + " correct format is 1-5");
                 }
                 int start;
                 int end;

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/coord/HCatELFunctions.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/coord/HCatELFunctions.java b/core/src/main/java/org/apache/oozie/coord/HCatELFunctions.java
index f40f406..12c0b81 100644
--- a/core/src/main/java/org/apache/oozie/coord/HCatELFunctions.java
+++ b/core/src/main/java/org/apache/oozie/coord/HCatELFunctions.java
@@ -319,7 +319,8 @@ public class HCatELFunctions {
     }
 
     /**
-     * Used to specify the MAXIMUM value of an HCat partition which is input dependency for workflow job.<p> Look for two evaluator-level
+     * Used to specify the MAXIMUM value of an HCat partition which is input dependency for workflow job.
+     * <p> Look for two evaluator-level
      * variables <p> A) .datain.&lt;DATAIN_NAME&gt; B) .datain.&lt;DATAIN_NAME&gt;.unresolved <p> A defines the current list of
      * HCat URIs. <p> B defines whether there are any unresolved EL-function (i.e latest) <p> If there are something
      * unresolved, this function will echo back the original function <p> otherwise it sends the max partition value.
@@ -364,7 +365,8 @@ public class HCatELFunctions {
     }
 
     /**
-     * Used to specify the MINIMUM value of an HCat partition which is input dependency for workflow job.<p> Look for two evaluator-level
+     * Used to specify the MINIMUM value of an HCat partition which is input dependency for workflow job.
+     * <p> Look for two evaluator-level
      * variables <p> A) .datain.&lt;DATAIN_NAME&gt; B) .datain.&lt;DATAIN_NAME&gt;.unresolved <p> A defines the current list of
      * HCat URIs. <p> B defines whether there are any unresolved EL-function (i.e latest) <p> If there are something
      * unresolved, this function will echo back the original function <p> otherwise it sends the min partition value.

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/executor/jpa/BundleJobsGetRunningOrPendingJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/BundleJobsGetRunningOrPendingJPAExecutor.java b/core/src/main/java/org/apache/oozie/executor/jpa/BundleJobsGetRunningOrPendingJPAExecutor.java
index 18ceb10..bfb0b84 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/BundleJobsGetRunningOrPendingJPAExecutor.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/BundleJobsGetRunningOrPendingJPAExecutor.java
@@ -28,7 +28,8 @@ import org.apache.oozie.BundleJobBean;
 import org.apache.oozie.ErrorCode;
 
 /**
- * Get a list of Bundle Jobs that are are RUNNING or RUNNINGWITHERROR status or the pending flag is 1. The result is ordered by lastModifiedTimestamp.
+ * Get a list of Bundle Jobs that are are RUNNING or RUNNINGWITHERROR status or the pending flag is 1.
+ * The result is ordered by lastModifiedTimestamp.
  */
 public class BundleJobsGetRunningOrPendingJPAExecutor implements JPAExecutor<List<BundleJobBean>> {
     private int limit;

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/executor/jpa/CoordActionRemoveJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/CoordActionRemoveJPAExecutor.java b/core/src/main/java/org/apache/oozie/executor/jpa/CoordActionRemoveJPAExecutor.java
index 02a4f68..bedff49 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/CoordActionRemoveJPAExecutor.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/CoordActionRemoveJPAExecutor.java
@@ -34,7 +34,7 @@ public class CoordActionRemoveJPAExecutor implements JPAExecutor<Void> {
 
     /**
      * Constructor which records coordinator action id.
-     * 
+     *
      * @param coordActionId
      */
     public CoordActionRemoveJPAExecutor(String coordActionId) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/executor/jpa/CoordJobGetRunningActionsCountJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/CoordJobGetRunningActionsCountJPAExecutor.java b/core/src/main/java/org/apache/oozie/executor/jpa/CoordJobGetRunningActionsCountJPAExecutor.java
index 274b3c1..567df40 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/CoordJobGetRunningActionsCountJPAExecutor.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/CoordJobGetRunningActionsCountJPAExecutor.java
@@ -25,7 +25,7 @@ import org.apache.oozie.ErrorCode;
 import org.apache.oozie.util.ParamChecker;
 
 /**
- * Load the number of running actions for a coordinator job. 
+ * Load the number of running actions for a coordinator job.
  */
 public class CoordJobGetRunningActionsCountJPAExecutor implements JPAExecutor<Integer> {
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowActionRetryManualGetJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowActionRetryManualGetJPAExecutor.java b/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowActionRetryManualGetJPAExecutor.java
index 51449db..606c9b7 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowActionRetryManualGetJPAExecutor.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowActionRetryManualGetJPAExecutor.java
@@ -34,7 +34,7 @@ public class WorkflowActionRetryManualGetJPAExecutor implements JPAExecutor<List
 
     /**
      * This creates the WorkflowActionRetryManualGetJPAExecutor executor object.
-     * 
+     *
      * @param wfId
      */
     public WorkflowActionRetryManualGetJPAExecutor(String wfId) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowInfoWithActionsSubsetGetJPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowInfoWithActionsSubsetGetJPAExecutor.java b/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowInfoWithActionsSubsetGetJPAExecutor.java
index 43c7d08..5f12b4d 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowInfoWithActionsSubsetGetJPAExecutor.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowInfoWithActionsSubsetGetJPAExecutor.java
@@ -43,7 +43,7 @@ public class WorkflowInfoWithActionsSubsetGetJPAExecutor implements JPAExecutor<
     /**
      * This will create the WorkflowInfoWithActionsSubsetGetJPAExecutor object. which is responsible for getting the
      * Workflow job with actions in certain range.
-     * 
+     *
      * @param wfJobId
      * @param start
      * @param len

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowJobsBasicInfoFromParentId.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowJobsBasicInfoFromParentId.java b/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowJobsBasicInfoFromParentId.java
index 4b8adfb..5721d96 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowJobsBasicInfoFromParentId.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/WorkflowJobsBasicInfoFromParentId.java
@@ -7,7 +7,7 @@
  * "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
+ *      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,

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/service/AuthorizationService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/service/AuthorizationService.java b/core/src/main/java/org/apache/oozie/service/AuthorizationService.java
index d76e1ea..33fd9c3 100644
--- a/core/src/main/java/org/apache/oozie/service/AuthorizationService.java
+++ b/core/src/main/java/org/apache/oozie/service/AuthorizationService.java
@@ -406,7 +406,8 @@ public class AuthorizationService implements Service {
                     incrCounter(INSTR_FAILED_AUTH_COUNTER, 1);
                     throw new AuthorizationException(ErrorCode.E0504, appPath);
                 }
-                if (conf.get(XOozieClient.IS_PROXY_SUBMISSION) == null) { // Only further check existence of job definition files for non proxy submission jobs;
+                if (conf.get(XOozieClient.IS_PROXY_SUBMISSION) == null) { // Only further check existence of job definition
+                    //files for non proxy submission jobs;
                     if (!fs.isFile(path)) {
                         Path appXml = new Path(path, fileName);
                         if (!fs.exists(appXml)) {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/service/PurgeService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/service/PurgeService.java b/core/src/main/java/org/apache/oozie/service/PurgeService.java
index c2c966b..81f22b6 100644
--- a/core/src/main/java/org/apache/oozie/service/PurgeService.java
+++ b/core/src/main/java/org/apache/oozie/service/PurgeService.java
@@ -22,7 +22,8 @@ import org.apache.hadoop.conf.Configuration;
 import org.apache.oozie.command.PurgeXCommand;
 
 /**
- * The PurgeService schedules purging of completed jobs and associated action older than a specified age for workflow, coordinator and bundle.
+ * The PurgeService schedules purging of completed jobs and associated action older than a specified age for workflow,
+ *  coordinator and bundle.
  */
 public class PurgeService implements Service {
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/servlet/JsonRestServlet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/servlet/JsonRestServlet.java b/core/src/main/java/org/apache/oozie/servlet/JsonRestServlet.java
index 404d3cd..17dc686 100644
--- a/core/src/main/java/org/apache/oozie/servlet/JsonRestServlet.java
+++ b/core/src/main/java/org/apache/oozie/servlet/JsonRestServlet.java
@@ -381,7 +381,7 @@ public abstract class JsonRestServlet extends HttpServlet {
      * @param timeZoneId time zone to use for dates in the JSON response.
      * @throws java.io.IOException thrown if the bean could not be serialized to the response output stream.
      */
-    protected void sendJsonResponse(HttpServletResponse response, int statusCode, JsonBean bean, String timeZoneId) 
+    protected void sendJsonResponse(HttpServletResponse response, int statusCode, JsonBean bean, String timeZoneId)
             throws IOException {
         response.setStatus(statusCode);
         JSONObject json = bean.toJSONObject(timeZoneId);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/servlet/ServletUtilities.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/servlet/ServletUtilities.java b/core/src/main/java/org/apache/oozie/servlet/ServletUtilities.java
index 9cdd915..3eb32d5 100644
--- a/core/src/main/java/org/apache/oozie/servlet/ServletUtilities.java
+++ b/core/src/main/java/org/apache/oozie/servlet/ServletUtilities.java
@@ -71,11 +71,13 @@ public class ServletUtilities {
         }
 
         if (n == 0) {
-            throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0302, "a workflow, coordinator, or bundle app path is required");
+            throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0302, "a workflow, coordinator,"
+                    + " or bundle app path is required");
         }
 
         if (n != 1) {
-            throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0302, "Multiple app paths specified, only one is allowed");
+            throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0302, "Multiple app paths specified,"
+                    + " only one is allowed");
         }
     }
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/servlet/V0AdminServlet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/servlet/V0AdminServlet.java b/core/src/main/java/org/apache/oozie/servlet/V0AdminServlet.java
index d4a0989..b43ab99 100644
--- a/core/src/main/java/org/apache/oozie/servlet/V0AdminServlet.java
+++ b/core/src/main/java/org/apache/oozie/servlet/V0AdminServlet.java
@@ -42,7 +42,8 @@ public class V0AdminServlet extends BaseAdminServlet {
 
     static {
         RESOURCES_INFO[0] = new ResourceInfo(RestConstants.ADMIN_STATUS_RESOURCE, Arrays.asList("PUT", "GET"),
-                                             Arrays.asList(new ParameterInfo(RestConstants.ADMIN_SAFE_MODE_PARAM, Boolean.class, true,
+                                             Arrays.asList(new ParameterInfo(RestConstants.ADMIN_SAFE_MODE_PARAM, Boolean.class,
+                                                     true,
                                                                              Arrays.asList("PUT"))));
         RESOURCES_INFO[1] = new ResourceInfo(RestConstants.ADMIN_OS_ENV_RESOURCE, Arrays.asList("GET"),
                 Collections.EMPTY_LIST);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/servlet/V0JobsServlet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/servlet/V0JobsServlet.java b/core/src/main/java/org/apache/oozie/servlet/V0JobsServlet.java
index ff50f3d..1d80094 100644
--- a/core/src/main/java/org/apache/oozie/servlet/V0JobsServlet.java
+++ b/core/src/main/java/org/apache/oozie/servlet/V0JobsServlet.java
@@ -56,7 +56,8 @@ public class V0JobsServlet extends BaseJobsServlet {
         try {
             String action = request.getParameter(RestConstants.ACTION_PARAM);
             if (action != null && !action.equals(RestConstants.JOB_ACTION_START)) {
-                throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0303, RestConstants.ACTION_PARAM, action);
+                throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0303, RestConstants.ACTION_PARAM,
+                        action);
             }
             boolean startJob = (action != null);
             String user = conf.get(OozieClient.USER_NAME);
@@ -75,7 +76,8 @@ public class V0JobsServlet extends BaseJobsServlet {
      * v0 service implementation to get a JSONObject representation of a job from its external ID
      */
     @Override
-    protected JSONObject getJobIdForExternalId(HttpServletRequest request, String externalId) throws XServletException, IOException {
+    protected JSONObject getJobIdForExternalId(HttpServletRequest request, String externalId) throws XServletException,
+    IOException {
         JSONObject json = new JSONObject();
         try {
             DagEngine dagEngine = Services.get().get(DagEngineService.class)

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/servlet/V1JobServlet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/servlet/V1JobServlet.java b/core/src/main/java/org/apache/oozie/servlet/V1JobServlet.java
index 0d275fd..361141b 100644
--- a/core/src/main/java/org/apache/oozie/servlet/V1JobServlet.java
+++ b/core/src/main/java/org/apache/oozie/servlet/V1JobServlet.java
@@ -88,7 +88,8 @@ public class V1JobServlet extends BaseJobServlet {
             startBundleJob(request, response);
         }
         else {
-            throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0303, RestConstants.ACTION_PARAM, RestConstants.JOB_ACTION_START);
+            throw new XServletException(HttpServletResponse.SC_BAD_REQUEST, ErrorCode.E0303, RestConstants.ACTION_PARAM,
+                    RestConstants.JOB_ACTION_START);
         }
 
     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/sla/SLARegistrationBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/sla/SLARegistrationBean.java b/core/src/main/java/org/apache/oozie/sla/SLARegistrationBean.java
index 5eac78c..d10366d 100644
--- a/core/src/main/java/org/apache/oozie/sla/SLARegistrationBean.java
+++ b/core/src/main/java/org/apache/oozie/sla/SLARegistrationBean.java
@@ -45,21 +45,31 @@ import org.json.simple.JSONObject;
 @Table(name = "SLA_REGISTRATION")
 @NamedQueries({
 
- @NamedQuery(name = "UPDATE_SLA_REG_ALL", query = "update SLARegistrationBean w set w.jobId = :jobId, w.nominalTimeTS = :nominalTime, w.expectedStartTS = :expectedStartTime, w.expectedEndTS = :expectedEndTime, w.expectedDuration = :expectedDuration, w.slaConfig = :slaConfig, w.notificationMsg = :notificationMsg, w.upstreamApps = :upstreamApps, w.appType = :appType, w.appName = :appName, w.user = :user, w.parentId = :parentId, w.jobData = :jobData where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_REG_ALL", query = "update SLARegistrationBean w set w.jobId = :jobId, w.nominalTimeTS "
+         + "= :nominalTime, w.expectedStartTS = :expectedStartTime, w.expectedEndTS = :expectedEndTime, w.expectedDuration "
+         + "= :expectedDuration, w.slaConfig = :slaConfig, w.notificationMsg = :notificationMsg, w.upstreamApps = :upstreamApps,"
+         + " w.appType = :appType, w.appName = :appName, w.user = :user, w.parentId = :parentId, w.jobData = :jobData "
+         + "where w.jobId = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_CONFIG", query = "update SLARegistrationBean w set w.slaConfig = :slaConfig where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_CONFIG", query = "update SLARegistrationBean w set w.slaConfig = :slaConfig where w.jobId"
+         + " = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_EXPECTED_VALUE", query = "update SLARegistrationBean w set w.expectedStartTS = :expectedStartTime, w.expectedEndTS = :expectedEndTime , w.expectedDuration = :expectedDuration  where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_EXPECTED_VALUE", query = "update SLARegistrationBean w set w.expectedStartTS "
+         + "= :expectedStartTime, w.expectedEndTS = :expectedEndTime , w.expectedDuration = :expectedDuration  where w.jobId"
+         + " = :jobId"),
 
- @NamedQuery(name = "GET_SLA_REG_ON_RESTART", query = "select w.notificationMsg, w.upstreamApps, w.slaConfig, w.jobData from SLARegistrationBean w where w.jobId = :id"),
+ @NamedQuery(name = "GET_SLA_REG_ON_RESTART", query = "select w.notificationMsg, w.upstreamApps, w.slaConfig, w.jobData "
+         + "from SLARegistrationBean w where w.jobId = :id"),
 
  @NamedQuery(name = "GET_SLA_REG_ALL", query = "select OBJECT(w) from SLARegistrationBean w where w.jobId = :id"),
 
  @NamedQuery(name = "GET_SLA_CONFIGS", query = "select w.jobId, w.slaConfig from SLARegistrationBean w where w.jobId IN (:ids)"),
 
- @NamedQuery(name = "GET_SLA_EXPECTED_VALUE_CONFIG", query = "select w.jobId, w.slaConfig, w.expectedStartTS, w.expectedEndTS, w.expectedDuration, w.nominalTimeTS from SLARegistrationBean w where w.jobId = :id"),
+ @NamedQuery(name = "GET_SLA_EXPECTED_VALUE_CONFIG", query = "select w.jobId, w.slaConfig, w.expectedStartTS, w.expectedEndTS,"
+         + " w.expectedDuration, w.nominalTimeTS from SLARegistrationBean w where w.jobId = :id"),
 
- @NamedQuery(name = "GET_SLA_REG_FOR_PARENT_ID", query = "select w.jobId, w.slaConfig from SLARegistrationBean w where w.parentId = :parentId"),
+ @NamedQuery(name = "GET_SLA_REG_FOR_PARENT_ID", query = "select w.jobId, w.slaConfig from SLARegistrationBean w "
+         + "where w.parentId = :parentId"),
 
  @NamedQuery(name = "GET_SLA_REGISTRATIONS", query = "select OBJECT(w) from SLARegistrationBean w")
  })

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/sla/SLASummaryBean.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/sla/SLASummaryBean.java b/core/src/main/java/org/apache/oozie/sla/SLASummaryBean.java
index e9ea9ba..65802d9 100644
--- a/core/src/main/java/org/apache/oozie/sla/SLASummaryBean.java
+++ b/core/src/main/java/org/apache/oozie/sla/SLASummaryBean.java
@@ -48,21 +48,36 @@ import org.json.simple.JSONObject;
 @Table(name = "SLA_SUMMARY")
 @NamedQueries({
 
- @NamedQuery(name = "UPDATE_SLA_SUMMARY_FOR_SLA_STATUS", query = "update  SLASummaryBean w set w.slaStatus = :slaStatus, w.eventStatus = :eventStatus, w.eventProcessed = :eventProcessed, w.lastModifiedTS = :lastModifiedTS where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_SUMMARY_FOR_SLA_STATUS", query = "update  SLASummaryBean w set w.slaStatus = :slaStatus,"
+         + " w.eventStatus = :eventStatus, w.eventProcessed = :eventProcessed, w.lastModifiedTS = :lastModifiedTS "
+         + "where w.jobId = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_SUMMARY_FOR_STATUS_ACTUAL_TIMES", query = "update SLASummaryBean w set w.slaStatus = :slaStatus, w.eventStatus = :eventStatus, w.eventProcessed = :eventProcessed, w.jobStatus = :jobStatus, w.lastModifiedTS = :lastModifiedTS, w.actualStartTS = :actualStartTS, w.actualEndTS = :actualEndTS, w.actualDuration = :actualDuration where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_SUMMARY_FOR_STATUS_ACTUAL_TIMES", query = "update SLASummaryBean w set w.slaStatus = :slaStatus,"
+         + " w.eventStatus = :eventStatus, w.eventProcessed = :eventProcessed, w.jobStatus = :jobStatus, w.lastModifiedTS "
+         + "= :lastModifiedTS, w.actualStartTS = :actualStartTS, w.actualEndTS = :actualEndTS, w.actualDuration = :actualDuration"
+         + " where w.jobId = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_SUMMARY_FOR_EXPECTED_TIMES", query = "update SLASummaryBean w set w.nominalTimeTS = :nominalTime, w.expectedStartTS = :expectedStartTime, w.expectedEndTS = :expectedEndTime, w.expectedDuration = :expectedDuration , w.lastModifiedTS = :lastModTime where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_SUMMARY_FOR_EXPECTED_TIMES", query = "update SLASummaryBean w set w.nominalTimeTS "
+         + "= :nominalTime, w.expectedStartTS = :expectedStartTime, w.expectedEndTS = :expectedEndTime, w.expectedDuration "
+         + "= :expectedDuration , w.lastModifiedTS = :lastModTime where w.jobId = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_SUMMARY_EVENTPROCESSED", query = "update SLASummaryBean w set w.eventProcessed = :eventProcessed where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_SUMMARY_EVENTPROCESSED", query = "update SLASummaryBean w set w.eventProcessed "
+         + "= :eventProcessed where w.jobId = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_SUMMARY_LAST_MODIFIED_TIME", query = "update SLASummaryBean w set w.lastModifiedTS = :lastModifiedTS where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_SUMMARY_LAST_MODIFIED_TIME", query = "update SLASummaryBean w set w.lastModifiedTS "
+         + "= :lastModifiedTS where w.jobId = :jobId"),
 
- @NamedQuery(name = "UPDATE_SLA_SUMMARY_ALL", query = "update SLASummaryBean w set w.jobId = :jobId, w.appName = :appName, w.appType = :appType, w.nominalTimeTS = :nominalTime, w.expectedStartTS = :expectedStartTime, w.expectedEndTS = :expectedEndTime, w.expectedDuration = :expectedDuration, w.jobStatus = :jobStatus, w.slaStatus = :slaStatus, w.eventStatus = :eventStatus, w.lastModifiedTS = :lastModTime, w.user = :user, w.parentId = :parentId, w.eventProcessed = :eventProcessed, w.actualDuration = :actualDuration, w.actualEndTS = :actualEndTS, w.actualStartTS = :actualStartTS where w.jobId = :jobId"),
+ @NamedQuery(name = "UPDATE_SLA_SUMMARY_ALL", query = "update SLASummaryBean w set w.jobId = :jobId, w.appName = :appName,"
+         + " w.appType = :appType, w.nominalTimeTS = :nominalTime, w.expectedStartTS = :expectedStartTime, w.expectedEndTS "
+         + "= :expectedEndTime, w.expectedDuration = :expectedDuration, w.jobStatus = :jobStatus, w.slaStatus = :slaStatus,"
+         + " w.eventStatus = :eventStatus, w.lastModifiedTS = :lastModTime, w.user = :user, w.parentId = :parentId,"
+         + " w.eventProcessed = :eventProcessed, w.actualDuration = :actualDuration, w.actualEndTS = :actualEndTS,"
+         + " w.actualStartTS = :actualStartTS where w.jobId = :jobId"),
 
  @NamedQuery(name = "GET_SLA_SUMMARY", query = "select OBJECT(w) from SLASummaryBean w where w.jobId = :id"),
 
- @NamedQuery(name = "GET_SLA_SUMMARY_RECORDS_RESTART", query = "select OBJECT(w) from SLASummaryBean w where w.eventProcessed <= 7 AND w.lastModifiedTS >= :lastModifiedTime"),
+ @NamedQuery(name = "GET_SLA_SUMMARY_RECORDS_RESTART", query = "select OBJECT(w) from SLASummaryBean w where w.eventProcessed "
+         + "<= 7 AND w.lastModifiedTS >= :lastModifiedTime"),
 
  @NamedQuery(name = "GET_SLA_SUMMARY_EVENTPROCESSED", query = "select w.eventProcessed from SLASummaryBean w where w.jobId = :id"),
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/sla/listener/SLAEmailEventListener.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/sla/listener/SLAEmailEventListener.java b/core/src/main/java/org/apache/oozie/sla/listener/SLAEmailEventListener.java
index d08521c..6e863df 100644
--- a/core/src/main/java/org/apache/oozie/sla/listener/SLAEmailEventListener.java
+++ b/core/src/main/java/org/apache/oozie/sla/listener/SLAEmailEventListener.java
@@ -84,8 +84,10 @@ public class SLAEmailEventListener extends SLAEventListener {
         EVENT_STATUS("SLA Status"), APP_TYPE("App Type"), APP_NAME("App Name"), USER("User"), JOBID("Job ID"), PARENT_JOBID(
                 "Parent Job ID"), JOB_URL("Job URL"), PARENT_JOB_URL("Parent Job URL"), NOMINAL_TIME("Nominal Time"),
                 EXPECTED_START_TIME("Expected Start Time"), ACTUAL_START_TIME("Actual Start Time"),
-                EXPECTED_END_TIME("Expected End Time"), ACTUAL_END_TIME("Actual End Time"), EXPECTED_DURATION("Expected Duration (in mins)"),
-                ACTUAL_DURATION("Actual Duration (in mins)"), NOTIFICATION_MESSAGE("Notification Message"), UPSTREAM_APPS("Upstream Apps"),
+                EXPECTED_END_TIME("Expected End Time"), ACTUAL_END_TIME("Actual End Time"),
+                EXPECTED_DURATION("Expected Duration (in mins)"),
+                ACTUAL_DURATION("Actual Duration (in mins)"), NOTIFICATION_MESSAGE("Notification Message"),
+                UPSTREAM_APPS("Upstream Apps"),
                 JOB_STATUS("Job Status");
         private String name;
 


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

Posted by an...@apache.org.
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");
 


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

Posted by an...@apache.org.
http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/store/WorkflowStore.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/store/WorkflowStore.java b/core/src/main/java/org/apache/oozie/store/WorkflowStore.java
index 821abc5..573bcdd 100644
--- a/core/src/main/java/org/apache/oozie/store/WorkflowStore.java
+++ b/core/src/main/java/org/apache/oozie/store/WorkflowStore.java
@@ -319,12 +319,15 @@ public class WorkflowStore extends Store {
         ParamChecker.notEmpty(wfId, "WorkflowID");
         List<WorkflowActionBean> actions = doOperation("getActionsForWorkflow",
                                                        new Callable<List<WorkflowActionBean>>() {
-                                                           public List<WorkflowActionBean> call() throws SQLException, StoreException, WorkflowException,
+                                                           public List<WorkflowActionBean> call() throws SQLException,
+                                                                   StoreException, WorkflowException,
                                                                    InterruptedException {
                                                                List<WorkflowActionBean> actions;
-                                                               List<WorkflowActionBean> actionList = new ArrayList<WorkflowActionBean>();
+                                                               List<WorkflowActionBean> actionList
+                                                                       = new ArrayList<WorkflowActionBean>();
                                                                try {
-                                                                   Query q = entityManager.createNamedQuery("GET_ACTIONS_FOR_WORKFLOW");
+                                                                   Query q = entityManager.createNamedQuery(
+                                                                           "GET_ACTIONS_FOR_WORKFLOW");
 
                                                                    /*
                                                                    * OpenJPAQuery oq = OpenJPAPersistence.cast(q);
@@ -368,12 +371,15 @@ public class WorkflowStore extends Store {
         ParamChecker.notEmpty(wfId, "WorkflowID");
         List<WorkflowActionBean> actions = doOperation("getActionsForWorkflow",
                                                        new Callable<List<WorkflowActionBean>>() {
-                                                           public List<WorkflowActionBean> call() throws SQLException, StoreException, WorkflowException,
+                                                           public List<WorkflowActionBean> call() throws SQLException,
+                                                                   StoreException, WorkflowException,
                                                                    InterruptedException {
                                                                List<WorkflowActionBean> actions;
-                                                               List<WorkflowActionBean> actionList = new ArrayList<WorkflowActionBean>();
+                                                               List<WorkflowActionBean> actionList
+                                                                       = new ArrayList<WorkflowActionBean>();
                                                                try {
-                                                                   Query q = entityManager.createNamedQuery("GET_ACTIONS_FOR_WORKFLOW");
+                                                                   Query q = entityManager.createNamedQuery(
+                                                                           "GET_ACTIONS_FOR_WORKFLOW");
                                                                    OpenJPAQuery oq = OpenJPAPersistence.cast(q);
                                                                    q.setParameter("wfId", wfId);
                                                                    q.setFirstResult(start - 1);
@@ -792,7 +798,8 @@ public class WorkflowStore extends Store {
                         actionDeleted += g.executeUpdate();
                     }
                 }
-                XLog.getLog(getClass()).debug("ENDED Workflow Purge deleted jobs :" + workflows.size() + " and actions " + actionDeleted);
+                XLog.getLog(getClass()).debug("ENDED Workflow Purge deleted jobs :" + workflows.size() + " and actions "
+                            + actionDeleted);
                 return null;
             }
         });

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/util/OozieRollingPolicy.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/OozieRollingPolicy.java b/core/src/main/java/org/apache/oozie/util/OozieRollingPolicy.java
index 625053c..ceae9a8 100644
--- a/core/src/main/java/org/apache/oozie/util/OozieRollingPolicy.java
+++ b/core/src/main/java/org/apache/oozie/util/OozieRollingPolicy.java
@@ -47,11 +47,11 @@ public class OozieRollingPolicy extends RollingPolicyBase implements TriggeringP
      * Unfortunately, TimeBasedRollingPolicy is declared final, so we can't subclass it; instead, we have to wrap it
      */
     private TimeBasedRollingPolicy tbrp;
-    
+
     private Semaphore deleteSem;
-    
+
     private Thread deleteThread;
-    
+
     private int maxHistory = 720;       // (720 hours / 24 hours per day = 30 days) as default
 
     String oozieLogDir;
@@ -64,7 +64,7 @@ public class OozieRollingPolicy extends RollingPolicyBase implements TriggeringP
     public void setMaxHistory(int maxHistory) {
         this.maxHistory = maxHistory;
     }
-    
+
     public OozieRollingPolicy() {
         deleteSem = new Semaphore(1);
         deleteThread = new Thread();
@@ -98,22 +98,23 @@ public class OozieRollingPolicy extends RollingPolicyBase implements TriggeringP
         tbrp.setFileNamePattern(getFileNamePattern());
         tbrp.activateOptions();
     }
-    
+
     @Override
     public RolloverDescription initialize(String file, boolean append) throws SecurityException {
         return tbrp.initialize(file, append);
     }
-    
+
     @Override
     public RolloverDescription rollover(final String activeFile) throws SecurityException {
         return tbrp.rollover(activeFile);
     }
-    
+
     @Override
-    public boolean isTriggeringEvent(final Appender appender, final LoggingEvent event, final String filename, 
+    public boolean isTriggeringEvent(final Appender appender, final LoggingEvent event, final String filename,
     final long fileLength) {
         if (maxHistory >= 0) {  // -1 = disable
-            // Only delete old logs if we're not already deleting logs and another thread hasn't already started setting up to delete
+            // Only delete old logs if we're not already deleting logs and another thread hasn't already started setting
+            // up to delete
             // the old logs
             if (deleteSem.tryAcquire()) {
                 if (!deleteThread.isAlive()) {
@@ -131,7 +132,7 @@ public class OozieRollingPolicy extends RollingPolicyBase implements TriggeringP
         }
         return tbrp.isTriggeringEvent(appender, event, filename, fileLength);
     }
-    
+
     private void deleteOldFiles() {
         ArrayList<FileInfo> fileList = new ArrayList<FileInfo>();
         if (oozieLogDir != null && logFileName != null) {
@@ -163,7 +164,7 @@ public class OozieRollingPolicy extends RollingPolicyBase implements TriggeringP
             }
         }
     }
-    
+
     private long getGZFileCreationTime(String fileName) {
         SimpleDateFormat formatter;
         String date = fileName.substring(logFileName.length(), fileName.length() - 3); //3 for .gz
@@ -212,5 +213,5 @@ public class OozieRollingPolicy extends RollingPolicyBase implements TriggeringP
             }
         }
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/util/ParameterVerifier.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/ParameterVerifier.java b/core/src/main/java/org/apache/oozie/util/ParameterVerifier.java
index f3f4630..ed323a8 100644
--- a/core/src/main/java/org/apache/oozie/util/ParameterVerifier.java
+++ b/core/src/main/java/org/apache/oozie/util/ParameterVerifier.java
@@ -30,14 +30,14 @@ import org.apache.hadoop.conf.Configuration;
 /**
  * Utility class to parse and verify the &lt;parameters&gt; section in a workflow or coordinator job
  */
-public abstract class ParameterVerifier 
+public abstract class ParameterVerifier
 {
     private static final Pattern nsVersionPattern = Pattern.compile("uri:oozie:(workflow|coordinator|bundle):(\\d+.\\d+)");
-    
+
     private static final double workflowMinVersion = 0.4;
     private static final double coordinatorMinVersion = 0.4;
     private static final double bundleMinVersion = 0.2;
-    
+
     /**
      * Verify the parameters section (if supported in the schema)
      *
@@ -50,7 +50,7 @@ public abstract class ParameterVerifier
         if (rootElement == null) {
             return;
         }
-        
+
         if (supportsParameters(rootElement.getNamespaceURI())) {
             Element params = rootElement.getChild("parameters", rootElement.getNamespace());
             if (params != null) {
@@ -88,15 +88,15 @@ public abstract class ParameterVerifier
             }
         }
     }
-    
+
     static boolean supportsParameters(String namespaceURI) {
         boolean supports = false;
         Matcher m = nsVersionPattern.matcher(namespaceURI);
         if (m.matches() && m.groupCount() == 2) {
             String type = m.group(1);
             double ver = Double.parseDouble(m.group(2));
-            supports = ((type.equals("workflow") && ver >= workflowMinVersion) || 
-                    (type.equals("coordinator") && ver >= coordinatorMinVersion) || 
+            supports = ((type.equals("workflow") && ver >= workflowMinVersion) ||
+                    (type.equals("coordinator") && ver >= coordinatorMinVersion) ||
                     (type.equals("bundle") && ver >= bundleMinVersion));
         }
         return supports;

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/util/ParameterVerifierException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/ParameterVerifierException.java b/core/src/main/java/org/apache/oozie/util/ParameterVerifierException.java
index ef9a591..d1eb1c7 100644
--- a/core/src/main/java/org/apache/oozie/util/ParameterVerifierException.java
+++ b/core/src/main/java/org/apache/oozie/util/ParameterVerifierException.java
@@ -26,7 +26,7 @@ import org.apache.hadoop.conf.Configuration;
  * Exception thrown by {@link ParameterVerifier}.
  */
 public class ParameterVerifierException extends XException {
-    
+
     /**
      * Create a ParameterHandler exception from a XException.
      *
@@ -45,5 +45,5 @@ public class ParameterVerifierException extends XException {
     public ParameterVerifierException(ErrorCode errorCode, Object... params) {
         super(errorCode, params);
     }
-    
+
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/util/PollablePriorityDelayQueue.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/PollablePriorityDelayQueue.java b/core/src/main/java/org/apache/oozie/util/PollablePriorityDelayQueue.java
index 03279eb..0f73603 100644
--- a/core/src/main/java/org/apache/oozie/util/PollablePriorityDelayQueue.java
+++ b/core/src/main/java/org/apache/oozie/util/PollablePriorityDelayQueue.java
@@ -62,7 +62,8 @@ public class PollablePriorityDelayQueue<E> extends PriorityDelayQueue<E> {
                             queues[i - 1].remove(e);
                         }
                         else {
-                            debug("poll(): the iterator element [{0}], from P[{1}] is not eligible to poll", e.getElement().toString(), i);
+                            debug("poll(): the iterator element [{0}], from P[{1}] is not eligible to poll",
+                                    e.getElement().toString(), i);
                             e = null;
                         }
                     }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/util/db/Schema.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/db/Schema.java b/core/src/main/java/org/apache/oozie/util/db/Schema.java
index 1278be1..a56da52 100644
--- a/core/src/main/java/org/apache/oozie/util/db/Schema.java
+++ b/core/src/main/java/org/apache/oozie/util/db/Schema.java
@@ -119,7 +119,8 @@ public class Schema {
                 retVal = (dbType.equals(DBType.HSQL) ? "VARCHAR" : (dbType.equals(DBType.ORACLE) ? "CLOB" : "TEXT"));
             }
             else {
-                retVal = (dbType.equals(DBType.ORACLE) ? "VARCHAR2(" + column.getLength() + ")" : "VARCHAR(" + column.getLength() + ")");
+                retVal = (dbType.equals(DBType.ORACLE) ? "VARCHAR2(" + column.getLength() + ")" : "VARCHAR("
+            + column.getLength() + ")");
             }
         }
         else {
@@ -136,7 +137,8 @@ public class Schema {
                     }
                     else {
                         if (Blob.class.equals(column.getType())) {
-                            retVal = (dbType.equals(DBType.MySQL) ? "MEDIUMBLOB" : (dbType.equals(DBType.ORACLE) ? "BLOB" : "LONGVARBINARY"));
+                            retVal = (dbType.equals(DBType.MySQL) ? "MEDIUMBLOB" : (dbType.equals(DBType.ORACLE)
+                                    ? "BLOB" : "LONGVARBINARY"));
                         }
                         else {
                             throw new RuntimeException("Column Type[" + column.getType() + "] not mapped to any DB Data Type !!");

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/workflow/lite/ActionNodeDef.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/workflow/lite/ActionNodeDef.java b/core/src/main/java/org/apache/oozie/workflow/lite/ActionNodeDef.java
index 97c7134..1e4852d 100644
--- a/core/src/main/java/org/apache/oozie/workflow/lite/ActionNodeDef.java
+++ b/core/src/main/java/org/apache/oozie/workflow/lite/ActionNodeDef.java
@@ -25,7 +25,7 @@ import java.util.Arrays;
 
 /**
  * Node definition for workflow action. This node definition is serialized object and should provide
- * readFields() and write() for read and write of fields in this class.  
+ * readFields() and write() for read and write of fields in this class.
  *
  */
 public class ActionNodeDef extends NodeDef {
@@ -37,12 +37,12 @@ public class ActionNodeDef extends NodeDef {
                          String onError) {
         super(name, ParamChecker.notNull(conf, "conf"), actionHandlerClass, Arrays.asList(onOk, onError));
     }
-    
+
     public ActionNodeDef(String name, String conf, Class<? extends ActionNodeHandler> actionHandlerClass, String onOk,
             String onError, String cred) {
         super(name, ParamChecker.notNull(conf, "conf"), actionHandlerClass, Arrays.asList(onOk, onError), cred);
     }
-    
+
     public ActionNodeDef(String name, String conf, Class<? extends ActionNodeHandler> actionHandlerClass, String onOk,
             String onError, String cred, String userRetryMax, String userRetryInterval, String userRetryPolicy) {
         super(name, ParamChecker.notNull(conf, "conf"), actionHandlerClass, Arrays.asList(onOk, onError), cred,

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/workflow/lite/DBLiteWorkflowLib.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/workflow/lite/DBLiteWorkflowLib.java b/core/src/main/java/org/apache/oozie/workflow/lite/DBLiteWorkflowLib.java
index dd6afa0..22c14fc 100644
--- a/core/src/main/java/org/apache/oozie/workflow/lite/DBLiteWorkflowLib.java
+++ b/core/src/main/java/org/apache/oozie/workflow/lite/DBLiteWorkflowLib.java
@@ -98,7 +98,8 @@ public class DBLiteWorkflowLib extends LiteWorkflowLib {
         ParamChecker.notNull(instance, "instance");
         try {
             SqlStatement.update(OozieTable.WF_PROCESS_INSTANCE).set(OozieColumn.PI_state,
-                                                                    WritableUtils.toByteArray((LiteWorkflowInstance) instance)).where(
+                                                                    WritableUtils
+                                                                    .toByteArray((LiteWorkflowInstance) instance)).where(
                     SqlStatement.isEqual(OozieColumn.PI_wfId, instance.getId())).
                     prepareAndSetValues(connection).executeUpdate();
         }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/java/org/apache/oozie/workflow/lite/LiteWorkflowAppParser.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/workflow/lite/LiteWorkflowAppParser.java b/core/src/main/java/org/apache/oozie/workflow/lite/LiteWorkflowAppParser.java
index 78b0652..a767124 100644
--- a/core/src/main/java/org/apache/oozie/workflow/lite/LiteWorkflowAppParser.java
+++ b/core/src/main/java/org/apache/oozie/workflow/lite/LiteWorkflowAppParser.java
@@ -556,7 +556,8 @@ public class LiteWorkflowAppParser {
 
                 Element launcherConfiguration = actionElement.getChild(LAUNCHER_E, actionNs);
                 if (launcherConfiguration != null) {
-                    LauncherConfigHandler launcherConfigHandler = new LauncherConfigHandler(actionConf, launcherConfiguration, actionNs);
+                    LauncherConfigHandler launcherConfigHandler = new LauncherConfigHandler(
+                            actionConf, launcherConfiguration, actionNs);
                     launcherConfigHandler.processSettings();
                 }
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/main/resources/localoozie-log4j.properties
----------------------------------------------------------------------
diff --git a/core/src/main/resources/localoozie-log4j.properties b/core/src/main/resources/localoozie-log4j.properties
index 906397f..89fa398 100644
--- a/core/src/main/resources/localoozie-log4j.properties
+++ b/core/src/main/resources/localoozie-log4j.properties
@@ -6,9 +6,9 @@
 # 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.

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/hadoop/examples/SleepJob.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/hadoop/examples/SleepJob.java b/core/src/test/java/org/apache/hadoop/examples/SleepJob.java
index 342f8b3..ddfd26f 100644
--- a/core/src/test/java/org/apache/hadoop/examples/SleepJob.java
+++ b/core/src/test/java/org/apache/hadoop/examples/SleepJob.java
@@ -37,13 +37,13 @@ import org.apache.hadoop.util.Tool;
 import org.apache.hadoop.util.ToolRunner;
 
 /**
- * Dummy class for testing MR framefork. Sleeps for a defined period 
- * of time in mapper and reducer. Generates fake input for map / reduce 
- * jobs. Note that generated number of input pairs is in the order 
+ * Dummy class for testing MR framefork. Sleeps for a defined period
+ * of time in mapper and reducer. Generates fake input for map / reduce
+ * jobs. Note that generated number of input pairs is in the order
  * of <code>numMappers * mapSleepTime / 100</code>, so the job uses
  * some disk space.
  */
-public class SleepJob extends Configured implements Tool,  
+public class SleepJob extends Configured implements Tool,
              Mapper<IntWritable, IntWritable, IntWritable, NullWritable>,
              Reducer<IntWritable, NullWritable, NullWritable, NullWritable>,
              Partitioner<IntWritable,NullWritable> {
@@ -57,7 +57,7 @@ public class SleepJob extends Configured implements Tool,
   public int getPartition(IntWritable k, NullWritable v, int numPartitions) {
     return k.get() % numPartitions;
   }
-  
+
   public static class EmptySplit implements InputSplit {
     public void write(DataOutput out) throws IOException { }
     public void readFields(DataInput in) throws IOException { }
@@ -113,7 +113,7 @@ public class SleepJob extends Configured implements Tool,
       OutputCollector<IntWritable, NullWritable> output, Reporter reporter)
       throws IOException {
 
-    //it is expected that every map processes mapSleepCount number of records. 
+    //it is expected that every map processes mapSleepCount number of records.
     try {
       reporter.setStatus("Sleeping... (" +
           (mapSleepDuration * (mapSleepCount - count)) + ") ms left");
@@ -139,7 +139,7 @@ public class SleepJob extends Configured implements Tool,
       reporter.setStatus("Sleeping... (" +
           (reduceSleepDuration * (reduceSleepCount - count)) + ") ms left");
         Thread.sleep(reduceSleepDuration);
-      
+
     }
     catch (InterruptedException ex) {
       throw (IOException)new IOException(
@@ -172,14 +172,14 @@ public class SleepJob extends Configured implements Tool,
   public int run(int numMapper, int numReducer, long mapSleepTime,
       int mapSleepCount, long reduceSleepTime,
       int reduceSleepCount) throws IOException {
-    JobConf job = setupJobConf(numMapper, numReducer, mapSleepTime, 
+    JobConf job = setupJobConf(numMapper, numReducer, mapSleepTime,
                   mapSleepCount, reduceSleepTime, reduceSleepCount);
     JobClient.runJob(job);
     return 0;
   }
 
-  public JobConf setupJobConf(int numMapper, int numReducer, 
-                                long mapSleepTime, int mapSleepCount, 
+  public JobConf setupJobConf(int numMapper, int numReducer,
+                                long mapSleepTime, int mapSleepCount,
                                 long reduceSleepTime, int reduceSleepCount) {
     JobConf job = new JobConf(getConf(), SleepJob.class);
     job.setNumMapTasks(numMapper);
@@ -232,11 +232,11 @@ public class SleepJob extends Configured implements Tool,
         recSleepTime = Long.parseLong(args[++i]);
       }
     }
-    
+
     // sleep for *SleepTime duration in Task by recSleepTime per record
     mapSleepCount = (int)Math.ceil(mapSleepTime / ((double)recSleepTime));
     reduceSleepCount = (int)Math.ceil(reduceSleepTime / ((double)recSleepTime));
-    
+
     return run(numMapper, numReducer, mapSleepTime, mapSleepCount,
         reduceSleepTime, reduceSleepCount);
   }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/TestCoordinatorEngine.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/TestCoordinatorEngine.java b/core/src/test/java/org/apache/oozie/TestCoordinatorEngine.java
index c6c9c49..5070f95 100644
--- a/core/src/test/java/org/apache/oozie/TestCoordinatorEngine.java
+++ b/core/src/test/java/org/apache/oozie/TestCoordinatorEngine.java
@@ -70,7 +70,8 @@ public class TestCoordinatorEngine extends XTestCase {
         Configuration conf = new XConfiguration();
         String appPath = getTestCaseFileUri("coordinator.xml");
 
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-01T02:00Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" 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=\"local_a\" frequency=\"${coord:days(1)}\" initial-instance=\"2009-02-01T01:00Z\" "
@@ -125,7 +126,8 @@ public class TestCoordinatorEngine extends XTestCase {
     public void testCustomDoneFlag() throws Exception {
         Configuration conf = new XConfiguration();
         String appPath = getTestCaseFileUri("coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-01T02:00Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" 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=\"local_a\" frequency=\"${coord:days(1)}\" initial-instance=\"2009-02-01T01:00Z\" "
@@ -179,7 +181,8 @@ public class TestCoordinatorEngine extends XTestCase {
     public void testEmptyDoneFlag() throws Exception {
         Configuration conf = new XConfiguration();
         String appPath = getTestCaseFileUri("coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-01T02:00Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" 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=\"local_a\" frequency=\"${coord:days(1)}\" initial-instance=\"2009-02-01T01:00Z\" "
@@ -233,7 +236,8 @@ public class TestCoordinatorEngine extends XTestCase {
     public void testDoneFlagCreation() throws Exception {
         Configuration conf = new XConfiguration();
         String appPath = getTestCaseFileUri("coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-01T02:00Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" 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=\"local_a\" frequency=\"${coord:days(1)}\" initial-instance=\"2009-02-01T01:00Z\" "
@@ -288,7 +292,8 @@ public class TestCoordinatorEngine extends XTestCase {
     private String _testSubmitJob(String appPath) throws Exception {
         Configuration conf = new XConfiguration();
 
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:minutes(20)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:minutes(20)}\" start=\"2009-02-01T01:00Z\" end="
+                + "\"2009-02-03T23:59Z\" 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:minutes(20)}\" initial-instance=\"2009-02-01T01:00Z\" "
@@ -299,7 +304,8 @@ public class TestCoordinatorEngine 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/TestLocalOozieClientCoord.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/TestLocalOozieClientCoord.java b/core/src/test/java/org/apache/oozie/TestLocalOozieClientCoord.java
index 177bff7..d1a1763 100644
--- a/core/src/test/java/org/apache/oozie/TestLocalOozieClientCoord.java
+++ b/core/src/test/java/org/apache/oozie/TestLocalOozieClientCoord.java
@@ -167,9 +167,11 @@ public class TestLocalOozieClientCoord extends XDataTestCase {
                 + "xmlns=\"uri:oozie:coordinator:0.1\"> <controls> <timeout>10</timeout> <concurrency>1</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:minutes(20)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template> </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}")
+                + "</uri-template> </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:minutes(20)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template> </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}")
+                + "</uri-template> </dataset> "
                 + "</datasets> <input-events> "
                 + "<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\"> "

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/action/hadoop/InsertTestToken.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/action/hadoop/InsertTestToken.java b/core/src/test/java/org/apache/oozie/action/hadoop/InsertTestToken.java
index 9558aa5..42ce6ad 100644
--- a/core/src/test/java/org/apache/oozie/action/hadoop/InsertTestToken.java
+++ b/core/src/test/java/org/apache/oozie/action/hadoop/InsertTestToken.java
@@ -32,7 +32,8 @@ public class InsertTestToken implements CredentialsProvider {
     }
 
     /* (non-Javadoc)
-     * @see org.apache.oozie.action.hadoop.Credentials#addtoJobConf(org.apache.hadoop.mapred.JobConf, org.apache.oozie.action.hadoop.CredentialsProperties, org.apache.oozie.action.ActionExecutor.Context)
+     * @see org.apache.oozie.action.hadoop.Credentials#addtoJobConf(org.apache.hadoop.mapred.JobConf,
+     *  org.apache.oozie.action.hadoop.CredentialsProperties, org.apache.oozie.action.ActionExecutor.Context)
      */
 
     @Override

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/action/hadoop/TestHadoopELFunctions.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/action/hadoop/TestHadoopELFunctions.java b/core/src/test/java/org/apache/oozie/action/hadoop/TestHadoopELFunctions.java
index c6ec63c..907e3cd 100644
--- a/core/src/test/java/org/apache/oozie/action/hadoop/TestHadoopELFunctions.java
+++ b/core/src/test/java/org/apache/oozie/action/hadoop/TestHadoopELFunctions.java
@@ -91,8 +91,10 @@ public class TestHadoopELFunctions extends ActionExecutorTestCase {
                 + "\"NUMBER_JOBS\":\"2\","
                 + "\"RECORD_WRITTEN\":\"33\","
                 + "\"JOB_GRAPH\":\"job_201111300933_0004,job_201111300933_0005\","
-                + "\"job_201111300933_0004\":{\"MAP_INPUT_RECORDS\":\"33\",\"MIN_REDUCE_TIME\":\"0\",\"MULTI_STORE_COUNTERS\":{},\"ERROR_MESSAGE\":null,\"JOB_ID\":\"job_201111300933_0004\"},"
-                + "\"job_201111300933_0005\":{\"MAP_INPUT_RECORDS\":\"37\",\"MIN_REDUCE_TIME\":\"0\",\"MULTI_STORE_COUNTERS\":{},\"ERROR_MESSAGE\":null,\"JOB_ID\":\"job_201111300933_0005\"},"
+                + "\"job_201111300933_0004\":{\"MAP_INPUT_RECORDS\":\"33\",\"MIN_REDUCE_TIME\":\"0\",\"MULTI_STORE_COUNTERS\":{},"
+                + "\"ERROR_MESSAGE\":null,\"JOB_ID\":\"job_201111300933_0004\"},"
+                + "\"job_201111300933_0005\":{\"MAP_INPUT_RECORDS\":\"37\",\"MIN_REDUCE_TIME\":\"0\",\"MULTI_STORE_COUNTERS\":{},"
+                + "\"ERROR_MESSAGE\":null,\"JOB_ID\":\"job_201111300933_0005\"},"
                 + "\"BYTES_WRITTEN\":\"1410\"," + "\"HADOOP_VERSION\":\"0.20.2\"," + "\"RETURN_CODE\":\"0\","
                 + "\"ERROR_CODE\":\"-1\"," + "}";
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/action/hadoop/TestJavaActionExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/action/hadoop/TestJavaActionExecutor.java b/core/src/test/java/org/apache/oozie/action/hadoop/TestJavaActionExecutor.java
index 2bd6a3f..e9ba8a8 100644
--- a/core/src/test/java/org/apache/oozie/action/hadoop/TestJavaActionExecutor.java
+++ b/core/src/test/java/org/apache/oozie/action/hadoop/TestJavaActionExecutor.java
@@ -2526,7 +2526,8 @@ public class TestJavaActionExecutor extends ActionExecutorTestCase {
                 "<job-tracker>" + getJobTrackerUri() + "</job-tracker>" +
                 "<name-node>" + getNameNodeUri() + "</name-node>" +
                 "<configuration>" +
-                "  <property><name>oozie.launcher.env</name><value>LAUNCHER_ENVIRON=foo1" + File.pathSeparator + "B=foo2</value></property>" +
+                "  <property><name>oozie.launcher.env</name><value>LAUNCHER_ENVIRON=foo1" + File.pathSeparator +
+                "B=foo2</value></property>" +
                 "</configuration>" +
                 "<main-class>" + LauncherMainTester.class.getName() + "</main-class>" +
                 "</java>";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/action/hadoop/TestShellActionExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/action/hadoop/TestShellActionExecutor.java b/core/src/test/java/org/apache/oozie/action/hadoop/TestShellActionExecutor.java
index 8d0b441..846a4e8 100644
--- a/core/src/test/java/org/apache/oozie/action/hadoop/TestShellActionExecutor.java
+++ b/core/src/test/java/org/apache/oozie/action/hadoop/TestShellActionExecutor.java
@@ -283,7 +283,8 @@ public class TestShellActionExecutor extends ActionExecutorTestCase {
         String actionXml = "<shell>" + "<job-tracker>" + getJobTrackerUri() + "</job-tracker>" + "<name-node>"
                 + getNameNodeUri() + "</name-node>" + "<exec>" + SHELL_EXEC + "</exec>" + "<argument>" + SHELL_PARAM + "</argument>"
                 + "<argument>" + SHELL_SCRIPTNAME + "</argument>" + "<argument>A</argument>" + "<argument>B</argument>"
-                + "<env-var>var1=val1</env-var>" + "<env-var>var2=" + envValueHavingEqualSign + "</env-var>" + "<file>" + script.toString()
+                + "<env-var>var1=val1</env-var>" + "<env-var>var2=" + envValueHavingEqualSign + "</env-var>" + "<file>"
+                + script.toString()
                 + "#" + script.getName() + "</file>" + "<capture-output />" + "</shell>";
 
         Context context = createContext(actionXml);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/bundle/TestBundleJobXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/bundle/TestBundleJobXCommand.java b/core/src/test/java/org/apache/oozie/command/bundle/TestBundleJobXCommand.java
index c6ecb5e..374c0b7 100644
--- a/core/src/test/java/org/apache/oozie/command/bundle/TestBundleJobXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/bundle/TestBundleJobXCommand.java
@@ -45,7 +45,7 @@ public class TestBundleJobXCommand extends XDataTestCase {
 
     /**
      * Test: submit bundle job, then check job info
-     * 
+     *
      * @throws Exception
      */
     public void testBundleJobInfo1() throws Exception {
@@ -66,7 +66,7 @@ public class TestBundleJobXCommand extends XDataTestCase {
 
     /**
      * Test: jobId is wrong
-     * 
+     *
      * @throws Exception
      */
     public void testBundleJobInfoFailed() throws Exception {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/bundle/TestBundlePauseUnpauseXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/bundle/TestBundlePauseUnpauseXCommand.java b/core/src/test/java/org/apache/oozie/command/bundle/TestBundlePauseUnpauseXCommand.java
index 46819d9..e860aea 100644
--- a/core/src/test/java/org/apache/oozie/command/bundle/TestBundlePauseUnpauseXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/bundle/TestBundlePauseUnpauseXCommand.java
@@ -59,12 +59,12 @@ public class TestBundlePauseUnpauseXCommand extends XDataTestCase {
 
         job = jpaService.execute(bundleJobGetCmd);
         assertEquals(job.getStatus(), Job.Status.PREPPAUSED);
-        
+
         new BundleUnpauseXCommand(job).call();
         job = jpaService.execute(bundleJobGetCmd);
         assertEquals(job.getStatus(), Job.Status.PREP);
     }
-    
+
     /**
      * Test : Pause a RUNNING bundle
      *
@@ -83,7 +83,7 @@ public class TestBundlePauseUnpauseXCommand extends XDataTestCase {
 
         job = jpaService.execute(bundleJobGetCmd);
         assertEquals(job.getStatus(), Job.Status.PAUSED);
-        
+
         new BundleUnpauseXCommand(job).call();
         job = jpaService.execute(bundleJobGetCmd);
         assertEquals(job.getStatus(), Job.Status.RUNNING);
@@ -107,7 +107,7 @@ public class TestBundlePauseUnpauseXCommand extends XDataTestCase {
 
         job = jpaService.execute(bundleJobGetCmd);
         assertEquals(job.getStatus(), Job.Status.PAUSEDWITHERROR);
-        
+
         new BundleUnpauseXCommand(job).call();
         job = jpaService.execute(bundleJobGetCmd);
         assertEquals(job.getStatus(), Job.Status.RUNNINGWITHERROR);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/bundle/TestBundleRerunXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/bundle/TestBundleRerunXCommand.java b/core/src/test/java/org/apache/oozie/command/bundle/TestBundleRerunXCommand.java
index 4a10a8b..599a22a 100644
--- a/core/src/test/java/org/apache/oozie/command/bundle/TestBundleRerunXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/bundle/TestBundleRerunXCommand.java
@@ -291,7 +291,8 @@ public class TestBundleRerunXCommand extends XDataTestCase {
     }
 
 
-    protected BundleJobBean addRecordToBundleJobTableWithPausedTime(Job.Status jobStatus, boolean pending, Date pausedTime) throws Exception {
+    protected BundleJobBean addRecordToBundleJobTableWithPausedTime(Job.Status jobStatus, boolean pending, Date pausedTime)
+            throws Exception {
         BundleJobBean bundle = createBundleJob(jobStatus, pending);
         bundle.setPauseTime(pausedTime);
         try {
@@ -308,7 +309,8 @@ public class TestBundleRerunXCommand extends XDataTestCase {
         return bundle;
     }
 
-    protected CoordinatorJobBean addRecordToCoordJobTable(String coordId, CoordinatorJob.Status status, boolean pending, boolean doneMatd) throws Exception {
+    protected CoordinatorJobBean addRecordToCoordJobTable(
+            String coordId, CoordinatorJob.Status status, boolean pending, boolean doneMatd) throws Exception {
         CoordinatorJobBean coordJob = createCoordJob(status, pending, doneMatd);
         coordJob.setId(coordId);
         coordJob.setAppName(coordId);

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/bundle/TestBundleSubmitXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/bundle/TestBundleSubmitXCommand.java b/core/src/test/java/org/apache/oozie/command/bundle/TestBundleSubmitXCommand.java
index 429eb0d..9c7a516 100644
--- a/core/src/test/java/org/apache/oozie/command/bundle/TestBundleSubmitXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/bundle/TestBundleSubmitXCommand.java
@@ -59,7 +59,7 @@ public class TestBundleSubmitXCommand extends XDataTestCase {
 
     /**
      * https://issues.apache.org/jira/browse/OOZIE-945
-     * 
+     *
      * @throws Exception
      */
     public void testJobXmlCommentRemoved() throws Exception {

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/CoordXTestCase.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/CoordXTestCase.java b/core/src/test/java/org/apache/oozie/command/coord/CoordXTestCase.java
index 4a25356..3dca56f 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/CoordXTestCase.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/CoordXTestCase.java
@@ -30,7 +30,7 @@ public abstract class CoordXTestCase extends XTestCase {
         super.setUp();
         services = new Services();
         services.init();
-        
+
         jpaService = Services.get().get(JPAService.class);
         if (jpaService == null) {
             fail("jpaService can not be null");

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionInputCheckXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionInputCheckXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionInputCheckXCommand.java
index 99872dc..d1d2689 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionInputCheckXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionInputCheckXCommand.java
@@ -983,7 +983,8 @@ public class TestCoordActionInputCheckXCommand extends XDataTestCase {
 
         String confStr = jobConf.toXmlString(false);
         coordJob.setConf(confStr);
-        String appXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' name='NAME' frequency=\"1\" start='2009-02-01T01:00" + TZ + "' end='2009-02-03T23:59" + TZ + "' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        String appXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' name='NAME' frequency=\"1\" start='2009-02-01T01:00"
+        + TZ + "' end='2009-02-03T23:59" + TZ + "' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
         appXml += "<controls>";
         appXml += "<timeout>10</timeout>";
         appXml += "<concurrency>2</concurrency>";
@@ -991,7 +992,8 @@ public class TestCoordActionInputCheckXCommand extends XDataTestCase {
         appXml += "</controls>";
         appXml += "<input-events>";
         appXml += "<data-in name='A' dataset='a'>";
-        appXml += "<dataset name='a' frequency='7' initial-instance='2009-01-01T01:00" + TZ + "' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        appXml += "<dataset name='a' frequency='7' initial-instance='2009-01-01T01:00" + TZ + "' timezone='UTC'"
+                + " freq_timeunit='DAY' end_of_duration='NONE'>";
         appXml += "<uri-template>" + getTestCaseFileUri("${YEAR}/${MONTH}/${DAY}" )+ "</uri-template>";
         appXml += "</dataset>";
         if (dataInType.equals("future")) {
@@ -1010,7 +1012,8 @@ public class TestCoordActionInputCheckXCommand 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-01-01T01:00" + TZ + "' timezone='UTC' freq_timeunit='DAY' end_of_duration='NONE'>";
+        appXml += "<dataset name='local_a' frequency='7' initial-instance='2009-01-01T01:00" + TZ + "' timezone='UTC'"
+                + " freq_timeunit='DAY' end_of_duration='NONE'>";
         appXml += "<uri-template>" + getTestCaseFileUri("${YEAR}/${MONTH}/${DAY}" )+ "</uri-template>";
         appXml += "</dataset>";
         appXml += "<start-instance>${coord:current(-3)}</start-instance>";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionStartXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionStartXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionStartXCommand.java
index db66c72..261c496 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionStartXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordActionStartXCommand.java
@@ -229,7 +229,8 @@ public class TestCoordActionStartXCommand 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("coord/workflows/${YEAR}/${DAY}") + "</uri-template>";
         actionXml += "</dataset>";
         actionXml += "<instance>${coord:latest(0)}</instance>";
@@ -237,7 +238,8 @@ public class TestCoordActionStartXCommand 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("coord/workflows/${YEAR}/${DAY}") + "</uri-template>";
         actionXml += "</dataset>";
         actionXml += "<instance>${coord:current(-1)}</instance>";

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/TestCoordChangeXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordChangeXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordChangeXCommand.java
index b8eb15d..b784093 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordChangeXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordChangeXCommand.java
@@ -972,7 +972,8 @@ public class TestCoordChangeXCommand extends XDataTestCase {
 
         String confStr = "<configuration></configuration>";
         coordJob.setConf(confStr);
-        String appXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' name='NAME' frequency=\"5\" start='2009-02-01T01:00Z' end='2009-02-01T01:09Z' timezone='UTC' freq_timeunit='MINUTE' end_of_duration='NONE'>";
+        String appXml = "<coordinator-app xmlns='uri:oozie:coordinator:0.2' name='NAME' frequency=\"5\" start='2009-02-01T01:00Z'"
+                + " end='2009-02-01T01:09Z' timezone='UTC' freq_timeunit='MINUTE' end_of_duration='NONE'>";
         appXml += "<controls>";
         appXml += "<timeout>10</timeout>";
         appXml += "<concurrency>2</concurrency>";
@@ -980,7 +981,8 @@ public class TestCoordChangeXCommand extends XDataTestCase {
         appXml += "</controls>";
         appXml += "<input-events>";
         appXml += "<data-in name='A' dataset='a'>";
-        appXml += "<dataset name='a' frequency='5' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='MINUTE' end_of_duration='NONE'>";
+        appXml += "<dataset name='a' frequency='5' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='MINUTE'"
+                + " end_of_duration='NONE'>";
         appXml += "<uri-template>file:///tmp/coord/workflows/${YEAR}/${DAY}</uri-template>";
         appXml += "</dataset>";
         appXml += "<instance>${coord:latest(0)}</instance>";
@@ -988,7 +990,8 @@ public class TestCoordChangeXCommand extends XDataTestCase {
         appXml += "</input-events>";
         appXml += "<output-events>";
         appXml += "<data-out name='LOCAL_A' dataset='local_a'>";
-        appXml += "<dataset name='local_a' frequency='5' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit='MINUTE' end_of_duration='NONE'>";
+        appXml += "<dataset name='local_a' frequency='5' initial-instance='2009-02-01T01:00Z' timezone='UTC' freq_timeunit="
+                + "'MINUTE' end_of_duration='NONE'>";
         appXml += "<uri-template>file:///tmp/coord/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/command/coord/TestCoordKillXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordKillXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordKillXCommand.java
index 111eace..1fe8d3b 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordKillXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordKillXCommand.java
@@ -77,7 +77,8 @@ public class TestCoordKillXCommand extends XDataTestCase {
         Date end = DateUtils.parseDateOozieTZ(currentDatePlusMonth);
 
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, start, end, false, false, 0);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.READY, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.READY,
+                "coord-action-get.xml", 0);
 
         JPAService jpaService = Services.get().get(JPAService.class);
         assertNotNull(jpaService);
@@ -135,7 +136,8 @@ public class TestCoordKillXCommand extends XDataTestCase {
         Date end = DateUtils.parseDateOozieTZ(currentDatePlusMonth);
 
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.RUNNING, start, end, false, true, 0);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.RUNNING, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.RUNNING,
+                "coord-action-get.xml", 0);
 
         JPAService jpaService = Services.get().get(JPAService.class);
         assertNotNull(jpaService);
@@ -163,7 +165,8 @@ public class TestCoordKillXCommand extends XDataTestCase {
      */
     public void testCoordKillFailedOnAction() throws Exception {
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.SUCCEEDED, false, true);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.SUCCEEDED, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.SUCCEEDED,
+                "coord-action-get.xml", 0);
 
         JPAService jpaService = Services.get().get(JPAService.class);
         assertNotNull(jpaService);
@@ -200,7 +203,8 @@ public class TestCoordKillXCommand extends XDataTestCase {
         assertNotNull(jpaService);
 
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.SUCCEEDED, false, true);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.RUNNING, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.RUNNING,
+                "coord-action-get.xml", 0);
 
         job.setAppNamespace(SchemaService.COORDINATOR_NAMESPACE_URI_1);
         CoordJobQueryExecutor.getInstance().executeUpdate(CoordJobQuery.UPDATE_COORD_JOB_APPNAMESPACE, job);
@@ -231,7 +235,8 @@ public class TestCoordKillXCommand extends XDataTestCase {
         final String testJobId = "0000001-" + new Date().getTime() + "-testCoordKill-C";
 
         CoordinatorJobBean job = addRecordToCoordJobTable(CoordinatorJob.Status.SUCCEEDED, false, true);
-        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.READY, "coord-action-get.xml", 0);
+        CoordinatorActionBean action = addRecordToCoordActionTable(job.getId(), 1, CoordinatorAction.Status.READY,
+                "coord-action-get.xml", 0);
 
         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/command/coord/TestCoordRerunXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordRerunXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordRerunXCommand.java
index 9a05a85..c408103 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordRerunXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordRerunXCommand.java
@@ -452,7 +452,8 @@ public class TestCoordRerunXCommand extends XDataTestCase {
             @Override
             public boolean evaluate() throws Exception {
                 CoordinatorAction bean = coordClient.getCoordActionInfo(actionId);
-                return (bean.getStatus() == CoordinatorAction.Status.READY || bean.getStatus() == CoordinatorAction.Status.SUBMITTED);
+                return (bean.getStatus() == CoordinatorAction.Status.READY || bean.getStatus() == CoordinatorAction.Status
+                        .SUBMITTED);
             }
         });
 
@@ -563,7 +564,7 @@ public class TestCoordRerunXCommand extends XDataTestCase {
         // after cleanup
         assertFalse(fs.exists(success));
     }
-    
+
     /**
      * Test : rerun with refresh option when input dependency is hcat partition
      *

http://git-wip-us.apache.org/repos/asf/oozie/blob/4f404934/core/src/test/java/org/apache/oozie/command/coord/TestCoordSubmitXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordSubmitXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordSubmitXCommand.java
index dcc97ad..6e52a8e 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordSubmitXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordSubmitXCommand.java
@@ -82,18 +82,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testBasicSubmit() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"${appName}-foo\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"${appName}-foo\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <controls> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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>";
@@ -134,8 +138,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
                 + "<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>";
@@ -152,18 +156,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testBasicSubmitWithStartTimeAfterEndTime() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2010-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2010-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <controls> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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>";
@@ -364,7 +372,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
             assertTrue(e.getMessage().contains(sc.COORD_INPUT_EVENTS) && e.getMessage().contains("per data-in instance"));
         }
 
-        // CASE 2: Multiple data-in instances specified as separate <instance> tags, but one or more tags are empty. Check works for whitespace in the tags too
+        // CASE 2: Multiple data-in instances specified as separate <instance> tags, but one or more tags are empty.
+        // Check works for whitespace in the tags too
         reader = IOUtils.getResourceAsReader("coord-multiple-input-instance2.xml", -1);
         writer = new FileWriter(appPathFile);
         IOUtils.copyCharStream(reader, writer);
@@ -538,7 +547,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
             assertTrue(e.getMessage().contains(sc.COORD_OUTPUT_EVENTS) && e.getMessage().contains("is empty"));
         }
 
-        // CASE 3: Multiple <instance> tags within data-out should fail coordinator schema validation - different error than above is expected
+        // CASE 3: Multiple <instance> tags within data-out should fail coordinator schema validation -
+        // different error than above is expected
         reader = IOUtils.getResourceAsReader("coord-multiple-output-instance3.xml", -1);
         writer = new FileWriter(appPathFile);
         IOUtils.copyCharStream(reader, writer);
@@ -612,18 +622,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
         BundleJobBean coordJob = addRecordToBundleJobTable(Job.Status.PREP, false);
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <controls> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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>";
@@ -655,18 +669,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testBasicSubmitWithWrongNamespace() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.1\"> <controls> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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>";
@@ -695,15 +713,18 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testBasicSubmitWithSLA() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns:xsi='http://www.w3.org/2001/XMLSchema-instance' xmlns='uri:oozie:coordinator:0.2' "
                 +       "xmlns:sla='uri:oozie:sla:0.1'> <controls> <timeout>${coord:minutes(10)}</timeout> "
                 +       "<concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"Stats\" frequency=\"${coord:days(1)}\" initial-instance=\"2009-01-01T01:00Z\" "
                 + "timezone=\"UTC\"><uri-template>hcat://foo:11002/myOutputDatabase/myOutputTable/datestamp=${YEAR}${MONTH}${DAY}"
                 + "</uri-template></dataset>"
@@ -755,18 +776,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitFixedValues() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <controls> <timeout>10</timeout> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"60\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"120\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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>";
@@ -788,18 +813,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSchemaError() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequencyERROR=\"10\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequencyERROR=\"10\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <controls> <timeout>10</timeout> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"60\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"120\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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>";
@@ -824,7 +853,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitNoDatasets() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> "
                 + "<controls> <timeout>10</timeout> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> "
@@ -849,7 +879,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitNoUsername() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> "
                 + "<controls> <timeout>10</timeout> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> "
@@ -877,7 +908,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitNoControls() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> "
                 + "<action> <workflow> <app-path>hdfs:///tmp/workflows/</app-path> "
                 + "<configuration> <property> <name>inputA</name> <value>blah</value> </property> "
@@ -901,11 +933,13 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitWithDoneFlag() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <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\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
                 + "timezone=\"UTC\"> <uri-template>file:///tmp/coord/workflows/${YEAR}/${DAY}</uri-template> "
                 + "<done-flag>consume_me</done-flag> </dataset>"
@@ -917,7 +951,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
                 + "<data-in name=\"B\" dataset=\"local_b\"> <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>";
@@ -940,11 +975,13 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitWithVarAppName() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"${NAME}\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"${NAME}\" frequency=\"${coord:days(1)}\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.3\"> <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\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
                 + "timezone=\"UTC\"> <uri-template>file:///tmp/coord/workflows/${YEAR}/${DAY}</uri-template> "
                 + "<done-flag>consume_me</done-flag> </dataset>"
@@ -956,7 +993,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
                 + "<data-in name=\"B\" dataset=\"local_b\"> <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>";
@@ -983,7 +1021,8 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     public void testSubmitReservedVars() throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"10\" start=\"2009-02-01T01:00Z\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> "
                 + "<action> <workflow> <app-path>hdfs:///tmp/workflows/</app-path> "
                 + "<configuration> <property> <name>inputA</name> <value>blah</value> </property> "
@@ -1221,18 +1260,22 @@ public class TestCoordSubmitXCommand extends XDataTestCase {
     private void _testConfigDefaults(boolean withDefaults) throws Exception {
         Configuration conf = new XConfiguration();
         File appPathFile = new File(getTestCaseDir(), "coordinator.xml");
-        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"${startTime}\" end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
+        String appXml = "<coordinator-app name=\"NAME\" frequency=\"${coord:days(1)}\" start=\"${startTime}\""
+                + " end=\"2009-02-03T23:59Z\" timezone=\"UTC\" "
                 + "xmlns=\"uri:oozie:coordinator:0.2\"> <controls> <concurrency>2</concurrency> "
                 + "<execution>LIFO</execution> </controls> <datasets> "
                 + "<dataset name=\"a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "<dataset name=\"local_a\" frequency=\"${coord:days(7)}\" initial-instance=\"2009-02-01T01:00Z\" "
-                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>  </dataset> "
+                + "timezone=\"UTC\"> <uri-template>" + getTestCaseFileUri("coord/workflows/${YEAR}/${DAY}") + "</uri-template>"
+                        + "  </dataset> "
                 + "</datasets> <input-events> "
                 + "<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/TestCoordUpdateXCommand.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/oozie/command/coord/TestCoordUpdateXCommand.java b/core/src/test/java/org/apache/oozie/command/coord/TestCoordUpdateXCommand.java
index 5bee228..1528a52 100644
--- a/core/src/test/java/org/apache/oozie/command/coord/TestCoordUpdateXCommand.java
+++ b/core/src/test/java/org/apache/oozie/command/coord/TestCoordUpdateXCommand.java
@@ -271,7 +271,8 @@ public class TestCoordUpdateXCommand extends XDataTestCase {
             @Override
             public boolean evaluate() throws Exception {
                 CoordinatorAction bean = coordClient.getCoordActionInfo(actionId);
-                return (bean.getStatus() == CoordinatorAction.Status.WAITING || bean.getStatus() == CoordinatorAction.Status.SUBMITTED);
+                return (bean.getStatus() == CoordinatorAction.Status.WAITING || bean.getStatus()
+                        == CoordinatorAction.Status.SUBMITTED);
             }
         });
         CoordinatorAction bean = coordClient.getCoordActionInfo(actionId);