You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oozie.apache.org by ja...@apache.org on 2016/08/26 20:42:23 UTC

oozie git commit: OOZIE-2657 Clean up redundant access modifiers from oozie interfaces (abhishekbafna via jaydeepvishwakarma)

Repository: oozie
Updated Branches:
  refs/heads/master 0754451da -> 4c88e29ec


OOZIE-2657 Clean up redundant access modifiers from oozie interfaces (abhishekbafna via jaydeepvishwakarma)


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

Branch: refs/heads/master
Commit: 4c88e29ec669441a757d870077b11949741a4559
Parents: 0754451
Author: jvishwakarma <jv...@walmartlabs.com>
Authored: Sat Aug 27 02:11:24 2016 +0530
Committer: jvishwakarma <jv...@walmartlabs.com>
Committed: Sat Aug 27 02:11:24 2016 +0530

----------------------------------------------------------------------
 .../java/org/apache/oozie/client/BundleJob.java |   4 +-
 .../apache/oozie/client/CoordinatorAction.java  |   2 +-
 .../org/apache/oozie/client/CoordinatorJob.java |   4 +-
 .../main/java/org/apache/oozie/client/Job.java  |   6 +-
 .../java/org/apache/oozie/client/SLAEvent.java  |  46 +-
 .../org/apache/oozie/client/WorkflowAction.java |   2 +-
 .../org/apache/oozie/client/WorkflowJob.java    |   2 +-
 .../org/apache/oozie/client/rest/JsonTags.java  | 438 +++++++++----------
 .../apache/oozie/client/rest/RestConstants.java | 192 ++++----
 .../org/apache/oozie/client/rest/JsonBean.java  |   4 +-
 .../oozie/compression/CompressionCodec.java     |   8 +-
 .../input/logic/CoordInputLogicEvaluator.java   |   6 +-
 .../org/apache/oozie/dependency/URIHandler.java |  34 +-
 .../dependency/hcat/HCatDependencyCache.java    |  20 +-
 .../java/org/apache/oozie/event/EventQueue.java |  18 +-
 .../apache/oozie/executor/jpa/JPAExecutor.java  |   4 +-
 .../org/apache/oozie/jms/ConnectionContext.java |  18 +-
 .../org/apache/oozie/jms/MessageHandler.java    |   2 +-
 .../java/org/apache/oozie/service/Service.java  |  12 +-
 .../org/apache/oozie/sla/SLACalculator.java     |   2 +-
 .../org/apache/oozie/util/Instrumentable.java   |   2 +-
 .../java/org/apache/oozie/util/XCallable.java   |  16 +-
 .../org/apache/oozie/workflow/WorkflowApp.java  |   4 +-
 .../apache/oozie/workflow/WorkflowInstance.java |  40 +-
 .../org/apache/oozie/workflow/WorkflowLib.java  |  18 +-
 release-log.txt                                 |   1 +
 .../oozie/action/hadoop/LauncherURIHandler.java |   6 +-
 .../action/hadoop/OozieActionConfigurator.java  |   2 +-
 28 files changed, 457 insertions(+), 456 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/BundleJob.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/BundleJob.java b/client/src/main/java/org/apache/oozie/client/BundleJob.java
index 9764c3f..1adf4e2 100644
--- a/client/src/main/java/org/apache/oozie/client/BundleJob.java
+++ b/client/src/main/java/org/apache/oozie/client/BundleJob.java
@@ -29,7 +29,7 @@ public interface BundleJob extends Job {
     /**
      * Defines the possible frequency unit of all Oozie applications in Bundle.
      */
-    public static enum Timeunit {
+    enum Timeunit {
         MINUTE, HOUR, DAY, WEEK, MONTH, END_OF_DAY, END_OF_MONTH, NONE
     }
 
@@ -66,6 +66,6 @@ public interface BundleJob extends Job {
      *
      * @return createdTime
      */
-    public Date getCreatedTime();
+    Date getCreatedTime();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/CoordinatorAction.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/CoordinatorAction.java b/client/src/main/java/org/apache/oozie/client/CoordinatorAction.java
index 57af8b2..20bf9d6 100644
--- a/client/src/main/java/org/apache/oozie/client/CoordinatorAction.java
+++ b/client/src/main/java/org/apache/oozie/client/CoordinatorAction.java
@@ -28,7 +28,7 @@ public interface CoordinatorAction {
     /**
      * Defines the possible status of an application instance.
      */
-    public static enum Status {
+    enum Status {
         WAITING,
         READY,
         SUBMITTED,

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/CoordinatorJob.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/CoordinatorJob.java b/client/src/main/java/org/apache/oozie/client/CoordinatorJob.java
index 5123695..d98a6ac 100644
--- a/client/src/main/java/org/apache/oozie/client/CoordinatorJob.java
+++ b/client/src/main/java/org/apache/oozie/client/CoordinatorJob.java
@@ -29,14 +29,14 @@ public interface CoordinatorJob extends Job {
     /**
      * Defines the possible execution order of an Oozie application.
      */
-    public static enum Execution {
+    enum Execution {
         FIFO, LIFO, LAST_ONLY, NONE
     }
 
     /**
      * Defines the possible frequency unit of an Oozie application.
      */
-    public static enum Timeunit {
+    enum Timeunit {
         MINUTE, HOUR, DAY, WEEK, MONTH, END_OF_DAY, END_OF_MONTH, CRON, NONE
     }
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/Job.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/Job.java b/client/src/main/java/org/apache/oozie/client/Job.java
index 6f3fbdf..277e112 100644
--- a/client/src/main/java/org/apache/oozie/client/Job.java
+++ b/client/src/main/java/org/apache/oozie/client/Job.java
@@ -27,7 +27,7 @@ public interface Job {
     /**
      * Defines the possible status of an Oozie JOB.
      */
-    public static enum Status {
+    enum Status {
         PREMATER, PREP, RUNNING, SUSPENDED, SUCCEEDED, KILLED, FAILED, PAUSED,PREPPAUSED,
         PREPSUSPENDED, RUNNINGWITHERROR, SUSPENDEDWITHERROR, PAUSEDWITHERROR, DONEWITHERROR, IGNORED
     }
@@ -132,13 +132,13 @@ public interface Job {
      *
      * @return pauseTime
      */
-    public Date getPauseTime();
+    Date getPauseTime();
 
         /**
      * Return externalId
      *
      * @return externalId
      */
-    public String getExternalId();
+    String getExternalId();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/SLAEvent.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/SLAEvent.java b/client/src/main/java/org/apache/oozie/client/SLAEvent.java
index a684891..9d7273a 100644
--- a/client/src/main/java/org/apache/oozie/client/SLAEvent.java
+++ b/client/src/main/java/org/apache/oozie/client/SLAEvent.java
@@ -31,57 +31,57 @@ public interface SLAEvent {
     /**
      * Defines the possible status of an SLA events or Job status for SLA events.
      */
-    public static enum Status {
+    enum Status {
         CREATED, STARTED, SUCCEEDED, KILLED, FAILED
     }
 
     /**
      * Defines the possible status of an SLA events.
      */
-    public static enum SlaAppType {
+    enum SlaAppType {
         COORDINATOR_ACTION, COORDINATOR_JOB, WORKFLOW_JOB, WORKFLOW_ACTION
     }
 
-    public long getEvent_id();
+    long getEvent_id();
 
-    public String getSlaId();
+    String getSlaId();
 
-    public SlaAppType getAppType();
+    SlaAppType getAppType();
 
-    public String getAppName();
+    String getAppName();
 
-    public String getUser();
+    String getUser();
 
-    public String getGroupName();
+    String getGroupName();
 
-    public String getParentClientId();
+    String getParentClientId();
 
-    public String getParentSlaId();
+    String getParentSlaId();
 
-    public Date getExpectedStart();
+    Date getExpectedStart();
 
-    public Date getExpectedEnd();
+    Date getExpectedEnd();
 
-    public Date getStatusTimestamp();
+    Date getStatusTimestamp();
 
-    public String getNotificationMsg();
+    String getNotificationMsg();
 
-    public String getAlertContact();
+    String getAlertContact();
 
-    public String getDevContact();
+    String getDevContact();
 
-    public String getQaContact();
+    String getQaContact();
 
-    public String getSeContact();
+    String getSeContact();
 
-    public String getAlertFrequency();
+    String getAlertFrequency();
 
-    public String getAlertPercentage();
+    String getAlertPercentage();
 
-    public String getUpstreamApps();
+    String getUpstreamApps();
 
-    public Status getJobStatus();
+    Status getJobStatus();
 
-    public String getJobData();
+    String getJobData();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/WorkflowAction.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/WorkflowAction.java b/client/src/main/java/org/apache/oozie/client/WorkflowAction.java
index 293f6ee..18154ff 100644
--- a/client/src/main/java/org/apache/oozie/client/WorkflowAction.java
+++ b/client/src/main/java/org/apache/oozie/client/WorkflowAction.java
@@ -28,7 +28,7 @@ public interface WorkflowAction {
     /**
      * Defines the possible stati of a action.
      */
-    public static enum Status {
+    enum Status {
         PREP,
         RUNNING,
         OK,

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/WorkflowJob.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/WorkflowJob.java b/client/src/main/java/org/apache/oozie/client/WorkflowJob.java
index d7b7daf..131d9b2 100644
--- a/client/src/main/java/org/apache/oozie/client/WorkflowJob.java
+++ b/client/src/main/java/org/apache/oozie/client/WorkflowJob.java
@@ -29,7 +29,7 @@ public interface WorkflowJob {
     /**
      * Defines the possible stati of a workflow.
      */
-    public static enum Status {
+    enum Status {
         PREP, RUNNING, SUCCEEDED, KILLED, FAILED, SUSPENDED
     }
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/rest/JsonTags.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/rest/JsonTags.java b/client/src/main/java/org/apache/oozie/client/rest/JsonTags.java
index b3b148a..397e9ed 100644
--- a/client/src/main/java/org/apache/oozie/client/rest/JsonTags.java
+++ b/client/src/main/java/org/apache/oozie/client/rest/JsonTags.java
@@ -23,228 +23,228 @@ package org.apache.oozie.client.rest;
  */
 public interface JsonTags {
 
-    public static final String OOZIE_SAFE_MODE = "safeMode"; //Applicable for V0 only
-    public static final String OOZIE_SYSTEM_MODE = "systemMode";
-    public static final String BUILD_VERSION = "buildVersion";
-    public static final String QUEUE_DUMP = "queueDump";
-    public static final String CALLABLE_DUMP = "callableDump";
-    public static final String UNIQUE_MAP_DUMP = "uniqueMapDump";
-    public static final String UNIQUE_ENTRY_DUMP = "uniqueEntryDump";
-
-    public static final String SHARELIB_LIB_UPDATE = "sharelibUpdate";
-    public static final String SHARELIB_LIB = "sharelib";
-    public static final String SHARELIB_LIB_NAME = "name";
-    public static final String SHARELIB_LIB_FILES = "files";
-    public static final String SHARELIB_UPDATE_HOST = "host";
-    public static final String SHARELIB_UPDATE_STATUS = "status";
-
-    public static final String JOB_ID = "id";
-
-    public static final String JOB_IDS = "ids";
-
-    public static final String WORKFLOW_APP_PATH = "appPath";
-    public static final String WORKFLOW_APP_NAME = "appName";
-    public static final String WORKFLOW_ID = "id";
-    public static final String WORKFLOW_EXTERNAL_ID = "externalId";
-    public static final String WORKFLOW_PARENT_ID = "parentId";
-    public static final String WORKFLOW_CONF = "conf";
-    public static final String WORKFLOW_STATUS = "status";
-    public static final String WORKFLOW_LAST_MOD_TIME = "lastModTime";
-    public static final String WORKFLOW_CREATED_TIME = "createdTime";
-    public static final String WORKFLOW_START_TIME = "startTime";
-    public static final String WORKFLOW_END_TIME = "endTime";
-    public static final String WORKFLOW_USER = "user";
+    String OOZIE_SAFE_MODE = "safeMode"; //Applicable for V0 only
+    String OOZIE_SYSTEM_MODE = "systemMode";
+    String BUILD_VERSION = "buildVersion";
+    String QUEUE_DUMP = "queueDump";
+    String CALLABLE_DUMP = "callableDump";
+    String UNIQUE_MAP_DUMP = "uniqueMapDump";
+    String UNIQUE_ENTRY_DUMP = "uniqueEntryDump";
+
+    String SHARELIB_LIB_UPDATE = "sharelibUpdate";
+    String SHARELIB_LIB = "sharelib";
+    String SHARELIB_LIB_NAME = "name";
+    String SHARELIB_LIB_FILES = "files";
+    String SHARELIB_UPDATE_HOST = "host";
+    String SHARELIB_UPDATE_STATUS = "status";
+
+    String JOB_ID = "id";
+
+    String JOB_IDS = "ids";
+
+    String WORKFLOW_APP_PATH = "appPath";
+    String WORKFLOW_APP_NAME = "appName";
+    String WORKFLOW_ID = "id";
+    String WORKFLOW_EXTERNAL_ID = "externalId";
+    String WORKFLOW_PARENT_ID = "parentId";
+    String WORKFLOW_CONF = "conf";
+    String WORKFLOW_STATUS = "status";
+    String WORKFLOW_LAST_MOD_TIME = "lastModTime";
+    String WORKFLOW_CREATED_TIME = "createdTime";
+    String WORKFLOW_START_TIME = "startTime";
+    String WORKFLOW_END_TIME = "endTime";
+    String WORKFLOW_USER = "user";
     @Deprecated
-    public static final String WORKFLOW_GROUP = "group";
-    public static final String WORKFLOW_ACL = "acl";
-    public static final String WORKFLOW_RUN = "run";
-    public static final String WORKFLOW_CONSOLE_URL = "consoleUrl";
-    public static final String WORKFLOW_ACTIONS = "actions";
-
-    public static final String WORKFLOWS_JOBS = "workflows";
-    public static final String WORKFLOWS_TOTAL = "total";
-    public static final String WORKFLOWS_OFFSET = "offset";
-    public static final String WORKFLOWS_LEN = "len";
-
-    public static final String WORKFLOW_ACTION_ID = "id";
-    public static final String WORKFLOW_ACTION_NAME = "name";
-    public static final String WORKFLOW_ACTION_AUTH = "cred";
-    public static final String WORKFLOW_ACTION_TYPE = "type";
-    public static final String WORKFLOW_ACTION_CONF = "conf";
-    public static final String WORKFLOW_ACTION_RETRIES = "retries";
-    public static final String WORKFLOW_ACTION_START_TIME = "startTime";
-    public static final String WORKFLOW_ACTION_END_TIME = "endTime";
-    public static final String WORKFLOW_ACTION_STATUS = "status";
-    public static final String WORKFLOW_ACTION_TRANSITION = "transition";
-    public static final String WORKFLOW_ACTION_DATA = "data";
-    public static final String WORKFLOW_ACTION_STATS = "stats";
-    public static final String WORKFLOW_ACTION_EXTERNAL_CHILD_IDS = "externalChildIDs";
-    public static final String WORKFLOW_ACTION_EXTERNAL_ID = "externalId";
-    public static final String WORKFLOW_ACTION_EXTERNAL_STATUS = "externalStatus";
-    public static final String WORKFLOW_ACTION_TRACKER_URI = "trackerUri";
-    public static final String WORKFLOW_ACTION_CONSOLE_URL = "consoleUrl";
-    public static final String WORKFLOW_ACTION_ERROR_CODE = "errorCode";
-    public static final String WORKFLOW_ACTION_ERROR_MESSAGE = "errorMessage";
-    public static final String WORKFLOW_ACTION_USER_RETRY_INTERVAL = "userRetryInterval";
-    public static final String WORKFLOW_ACTION_USER_RETRY_COUNT = "userRetryCount";
-    public static final String WORKFLOW_ACTION_USER_RETRY_MAX = "userRetryMax";
-    public static final String WORKFLOW_ACTION_CRED = "cred";
-
-    public static final String COORDINATOR_JOB_ID = "coordJobId";
-    public static final String COORDINATOR_JOB_NAME = "coordJobName";
-    public static final String COORDINATOR_JOB_PATH = "coordJobPath";
-    public static final String COORDINATOR_JOB_FREQUENCY = "frequency";
-    public static final String COORDINATOR_JOB_TIMEUNIT = "timeUnit";
-    public static final String COORDINATOR_JOB_TIMEZONE = "timeZone";
-    public static final String COORDINATOR_JOB_CONCURRENCY = "concurrency";
-    public static final String COORDINATOR_JOB_MAT_THROTTLING = "mat_throttling";
-    public static final String COORDINATOR_JOB_EXECUTION = "execution";
-    public static final String COORDINATOR_JOB_TIMEOUT = "timeOut";
-    public static final String COORDINATOR_JOB_LAST_ACTION_TIME = "lastAction";
-    public static final String COORDINATOR_JOB_NEXT_MATERIALIZED_TIME = "nextMaterializedTime";
-    public static final String COORDINATOR_JOB_CONF = "conf";
-    public static final String COORDINATOR_JOB_STATUS = "status";
-    public static final String COORDINATOR_JOB_EXECUTIONPOLICY = "executionPolicy";
-    public static final String COORDINATOR_JOB_START_TIME = "startTime";
-    public static final String COORDINATOR_JOB_END_TIME = "endTime";
-    public static final String COORDINATOR_JOB_PAUSE_TIME = "pauseTime";
-    public static final String COORDINATOR_JOB_CONSOLE_URL = "consoleUrl";
-    public static final String COORDINATOR_JOB_ACTIONS = "actions";
-    public static final String COORDINATOR_JOB_USER = "user";
-    public static final String COORDINATOR_JOB_NUM_ACTION = "total";
+    String WORKFLOW_GROUP = "group";
+    String WORKFLOW_ACL = "acl";
+    String WORKFLOW_RUN = "run";
+    String WORKFLOW_CONSOLE_URL = "consoleUrl";
+    String WORKFLOW_ACTIONS = "actions";
+
+    String WORKFLOWS_JOBS = "workflows";
+    String WORKFLOWS_TOTAL = "total";
+    String WORKFLOWS_OFFSET = "offset";
+    String WORKFLOWS_LEN = "len";
+
+    String WORKFLOW_ACTION_ID = "id";
+    String WORKFLOW_ACTION_NAME = "name";
+    String WORKFLOW_ACTION_AUTH = "cred";
+    String WORKFLOW_ACTION_TYPE = "type";
+    String WORKFLOW_ACTION_CONF = "conf";
+    String WORKFLOW_ACTION_RETRIES = "retries";
+    String WORKFLOW_ACTION_START_TIME = "startTime";
+    String WORKFLOW_ACTION_END_TIME = "endTime";
+    String WORKFLOW_ACTION_STATUS = "status";
+    String WORKFLOW_ACTION_TRANSITION = "transition";
+    String WORKFLOW_ACTION_DATA = "data";
+    String WORKFLOW_ACTION_STATS = "stats";
+    String WORKFLOW_ACTION_EXTERNAL_CHILD_IDS = "externalChildIDs";
+    String WORKFLOW_ACTION_EXTERNAL_ID = "externalId";
+    String WORKFLOW_ACTION_EXTERNAL_STATUS = "externalStatus";
+    String WORKFLOW_ACTION_TRACKER_URI = "trackerUri";
+    String WORKFLOW_ACTION_CONSOLE_URL = "consoleUrl";
+    String WORKFLOW_ACTION_ERROR_CODE = "errorCode";
+    String WORKFLOW_ACTION_ERROR_MESSAGE = "errorMessage";
+    String WORKFLOW_ACTION_USER_RETRY_INTERVAL = "userRetryInterval";
+    String WORKFLOW_ACTION_USER_RETRY_COUNT = "userRetryCount";
+    String WORKFLOW_ACTION_USER_RETRY_MAX = "userRetryMax";
+    String WORKFLOW_ACTION_CRED = "cred";
+
+    String COORDINATOR_JOB_ID = "coordJobId";
+    String COORDINATOR_JOB_NAME = "coordJobName";
+    String COORDINATOR_JOB_PATH = "coordJobPath";
+    String COORDINATOR_JOB_FREQUENCY = "frequency";
+    String COORDINATOR_JOB_TIMEUNIT = "timeUnit";
+    String COORDINATOR_JOB_TIMEZONE = "timeZone";
+    String COORDINATOR_JOB_CONCURRENCY = "concurrency";
+    String COORDINATOR_JOB_MAT_THROTTLING = "mat_throttling";
+    String COORDINATOR_JOB_EXECUTION = "execution";
+    String COORDINATOR_JOB_TIMEOUT = "timeOut";
+    String COORDINATOR_JOB_LAST_ACTION_TIME = "lastAction";
+    String COORDINATOR_JOB_NEXT_MATERIALIZED_TIME = "nextMaterializedTime";
+    String COORDINATOR_JOB_CONF = "conf";
+    String COORDINATOR_JOB_STATUS = "status";
+    String COORDINATOR_JOB_EXECUTIONPOLICY = "executionPolicy";
+    String COORDINATOR_JOB_START_TIME = "startTime";
+    String COORDINATOR_JOB_END_TIME = "endTime";
+    String COORDINATOR_JOB_PAUSE_TIME = "pauseTime";
+    String COORDINATOR_JOB_CONSOLE_URL = "consoleUrl";
+    String COORDINATOR_JOB_ACTIONS = "actions";
+    String COORDINATOR_JOB_USER = "user";
+    String COORDINATOR_JOB_NUM_ACTION = "total";
 
     @Deprecated
-    public static final String COORDINATOR_JOB_GROUP = "group";
-    public static final String COORDINATOR_JOB_ACL = "acl";
-    public static final String COORDINATOR_JOB_EXTERNAL_ID = "coordExternalId";
-
-    public static final String COORDINATOR_ACTION_ID = "id";
-    public static final String COORDINATOR_ACTION_NAME = "name";
-    public static final String COORDINATOR_ACTION_TYPE = "type";
-    public static final String COORDINATOR_ACTION_CREATED_CONF = "createdConf";
-    public static final String COORDINATOR_ACTION_RUNTIME_CONF = "runConf";
-    public static final String COORDINATOR_ACTION_NUMBER = "actionNumber";
-    public static final String COORDINATOR_ACTION_CREATED_TIME = "createdTime";
-    public static final String COORDINATOR_ACTION_EXTERNALID = "externalId";
-    public static final String COORDINATOR_JOB_BUNDLE_ID = "bundleId";
-    public static final String COORDINATOR_ACTION_LAST_MODIFIED_TIME = "lastModifiedTime";
-    public static final String COORDINATOR_ACTION_NOMINAL_TIME = "nominalTime";
-    public static final String COORDINATOR_ACTION_STATUS = "status";
-    public static final String COORDINATOR_ACTION_MISSING_DEPS = "missingDependencies";
-    public static final String COORDINATOR_ACTION_PUSH_MISSING_DEPS = "pushMissingDependencies";
-    public static final String COORDINATOR_ACTION_EXTERNAL_STATUS = "externalStatus";
-    public static final String COORDINATOR_ACTION_TRACKER_URI = "trackerUri";
-    public static final String COORDINATOR_ACTION_CONSOLE_URL = "consoleUrl";
-    public static final String COORDINATOR_ACTION_ERROR_CODE = "errorCode";
-    public static final String COORDINATOR_ACTION_ERROR_MESSAGE = "errorMessage";
-    public static final String COORDINATOR_ACTIONS = "actions";
-    public static final String COORDINATOR_ACTION_DATA = "data";
-    public static final String COORDINATOR_JOB_DATA = "data";
-
-    public static final String BUNDLE_JOB_ID = "bundleJobId";
-    public static final String BUNDLE_JOB_NAME = "bundleJobName";
-    public static final String BUNDLE_JOB_PATH = "bundleJobPath";
-    public static final String BUNDLE_JOB_TIMEUNIT = "timeUnit";
-    public static final String BUNDLE_JOB_TIMEOUT = "timeOut";
-    public static final String BUNDLE_JOB_CONF = "conf";
-    public static final String BUNDLE_JOB_STATUS = "status";
-    public static final String BUNDLE_JOB_KICKOFF_TIME = "kickoffTime";
-    public static final String BUNDLE_JOB_START_TIME = "startTime";
-    public static final String BUNDLE_JOB_END_TIME = "endTime";
-    public static final String BUNDLE_JOB_PAUSE_TIME = "pauseTime";
-    public static final String BUNDLE_JOB_CREATED_TIME = "createdTime";
-    public static final String BUNDLE_JOB_CONSOLE_URL = "consoleUrl";
-    public static final String BUNDLE_JOB_USER = "user";
+    String COORDINATOR_JOB_GROUP = "group";
+    String COORDINATOR_JOB_ACL = "acl";
+    String COORDINATOR_JOB_EXTERNAL_ID = "coordExternalId";
+
+    String COORDINATOR_ACTION_ID = "id";
+    String COORDINATOR_ACTION_NAME = "name";
+    String COORDINATOR_ACTION_TYPE = "type";
+    String COORDINATOR_ACTION_CREATED_CONF = "createdConf";
+    String COORDINATOR_ACTION_RUNTIME_CONF = "runConf";
+    String COORDINATOR_ACTION_NUMBER = "actionNumber";
+    String COORDINATOR_ACTION_CREATED_TIME = "createdTime";
+    String COORDINATOR_ACTION_EXTERNALID = "externalId";
+    String COORDINATOR_JOB_BUNDLE_ID = "bundleId";
+    String COORDINATOR_ACTION_LAST_MODIFIED_TIME = "lastModifiedTime";
+    String COORDINATOR_ACTION_NOMINAL_TIME = "nominalTime";
+    String COORDINATOR_ACTION_STATUS = "status";
+    String COORDINATOR_ACTION_MISSING_DEPS = "missingDependencies";
+    String COORDINATOR_ACTION_PUSH_MISSING_DEPS = "pushMissingDependencies";
+    String COORDINATOR_ACTION_EXTERNAL_STATUS = "externalStatus";
+    String COORDINATOR_ACTION_TRACKER_URI = "trackerUri";
+    String COORDINATOR_ACTION_CONSOLE_URL = "consoleUrl";
+    String COORDINATOR_ACTION_ERROR_CODE = "errorCode";
+    String COORDINATOR_ACTION_ERROR_MESSAGE = "errorMessage";
+    String COORDINATOR_ACTIONS = "actions";
+    String COORDINATOR_ACTION_DATA = "data";
+    String COORDINATOR_JOB_DATA = "data";
+
+    String BUNDLE_JOB_ID = "bundleJobId";
+    String BUNDLE_JOB_NAME = "bundleJobName";
+    String BUNDLE_JOB_PATH = "bundleJobPath";
+    String BUNDLE_JOB_TIMEUNIT = "timeUnit";
+    String BUNDLE_JOB_TIMEOUT = "timeOut";
+    String BUNDLE_JOB_CONF = "conf";
+    String BUNDLE_JOB_STATUS = "status";
+    String BUNDLE_JOB_KICKOFF_TIME = "kickoffTime";
+    String BUNDLE_JOB_START_TIME = "startTime";
+    String BUNDLE_JOB_END_TIME = "endTime";
+    String BUNDLE_JOB_PAUSE_TIME = "pauseTime";
+    String BUNDLE_JOB_CREATED_TIME = "createdTime";
+    String BUNDLE_JOB_CONSOLE_URL = "consoleUrl";
+    String BUNDLE_JOB_USER = "user";
     @Deprecated
-    public static final String BUNDLE_JOB_GROUP = "group";
-    public static final String BUNDLE_JOB_ACL = "acl";
-    public static final String BUNDLE_JOB_EXTERNAL_ID = "bundleExternalId";
-    public static final String BUNDLE_COORDINATOR_JOBS = "bundleCoordJobs";
-
-    public static final String SLA_SUMMARY_LIST = "slaSummaryList";
-    public static final String SLA_SUMMARY_ID = "id";
-    public static final String SLA_SUMMARY_PARENT_ID = "parentId";
-    public static final String SLA_SUMMARY_APP_NAME = "appName";
-    public static final String SLA_SUMMARY_APP_TYPE = "appType";
-    public static final String SLA_SUMMARY_USER = "user";
-    public static final String SLA_SUMMARY_NOMINAL_TIME = "nominalTime";
-    public static final String SLA_SUMMARY_EXPECTED_START = "expectedStart";
-    public static final String SLA_SUMMARY_ACTUAL_START = "actualStart";
-    public static final String SLA_SUMMARY_START_DELAY = "startDelay";
-    public static final String SLA_SUMMARY_EXPECTED_END = "expectedEnd";
-    public static final String SLA_SUMMARY_ACTUAL_END = "actualEnd";
-    public static final String SLA_SUMMARY_END_DELAY = "endDelay";
-    public static final String SLA_SUMMARY_EXPECTED_DURATION = "expectedDuration";
-    public static final String SLA_SUMMARY_ACTUAL_DURATION = "actualDuration";
-    public static final String SLA_SUMMARY_DURATION_DELAY = "durationDelay";
-    public static final String SLA_SUMMARY_JOB_STATUS = "jobStatus";
-    public static final String SLA_SUMMARY_SLA_STATUS = "slaStatus";
-    public static final String SLA_SUMMARY_EVENT_STATUS = "eventStatus";
-    public static final String SLA_SUMMARY_LAST_MODIFIED = "lastModified";
-    public static final String SLA_ALERT_STATUS = "slaAlertStatus";
-
-
-    public static final String TO_STRING = "toString";
-
-
-    public static final String ERROR = "error";
-    public static final String ERROR_CODE = "code";
-    public static final String ERROR_MESSAGE = "message";
-
-    public static final String INSTR_TIMERS = "timers";
-    public static final String INSTR_VARIABLES = "variables";
-    public static final String INSTR_SAMPLERS = "samplers";
-    public static final String INSTR_COUNTERS = "counters";
-    public static final String INSTR_DATA = "data";
-
-    public static final String INSTR_GROUP = "group";
-    public static final String INSTR_NAME = "name";
-
-    public static final String INSTR_TIMER_OWN_TIME_AVG = "ownTimeAvg";
-    public static final String INSTR_TIMER_TOTAL_TIME_AVG = "totalTimeAvg";
-    public static final String INSTR_TIMER_TICKS = "ticks";
-    public static final String INSTR_TIMER_OWN_STD_DEV = "ownTimeStdDev";
-    public static final String INSTR_TIMER_TOTAL_STD_DEV = "totalTimeStdDev";
-    public static final String INSTR_TIMER_OWN_MIN_TIME = "ownMinTime";
-    public static final String INSTR_TIMER_OWN_MAX_TIME = "ownMaxTime";
-    public static final String INSTR_TIMER_TOTAL_MIN_TIME = "totalMinTime";
-    public static final String INSTR_TIMER_TOTAL_MAX_TIME = "totalMaxTime";
-
-    public static final String INSTR_VARIABLE_VALUE = "value";
-    public static final String INSTR_SAMPLER_VALUE = "value";
-
-    public static final Object COORDINATOR_JOBS = "coordinatorjobs";
-    public static final Object COORD_JOB_TOTAL = "total";
-    public static final Object COORD_JOB_OFFSET = "offset";
-    public static final Object COORD_JOB_LEN = "len";
-
-    public static final Object BUNDLE_JOBS = "bundlejobs";
-    public static final Object BUNDLE_JOB_TOTAL = "total";
-    public static final Object BUNDLE_JOB_OFFSET = "offset";
-    public static final Object BUNDLE_JOB_LEN = "len";
-
-    public static final String BULK_RESPONSE_BUNDLE = "bulkbundle";
-    public static final String BULK_RESPONSE_COORDINATOR = "bulkcoord";
-    public static final String BULK_RESPONSE_ACTION = "bulkaction";
-    public static final Object BULK_RESPONSES = "bulkresponses";
-    public static final Object BULK_RESPONSE_TOTAL = "total";
-    public static final Object BULK_RESPONSE_OFFSET = "offset";
-    public static final Object BULK_RESPONSE_LEN = "len";
-
-    public static final String AVAILABLE_TIME_ZONES = "available-timezones";
-    public static final String TIME_ZOME_DISPLAY_NAME = "timezoneDisplayName";
-    public static final String TIME_ZONE_ID = "timezoneId";
-
-    public static final String JMS_TOPIC_PATTERN = "jmsTopicPattern";
-    public static final String JMS_JNDI_PROPERTIES = "jmsJNDIProps";
-    public static final String JMS_TOPIC_PREFIX = "jmsTopicPrefix";
-
-    public static final String JMS_TOPIC_NAME = "jmsTopicName";
-    public static final String COORD_UPDATE = RestConstants.JOB_COORD_UPDATE;
-    public static final String COORD_UPDATE_DIFF = "diff";
-
-    public static final String STATUS = "status";
-
-    public static final String VALIDATE = "validate";
+    String BUNDLE_JOB_GROUP = "group";
+    String BUNDLE_JOB_ACL = "acl";
+    String BUNDLE_JOB_EXTERNAL_ID = "bundleExternalId";
+    String BUNDLE_COORDINATOR_JOBS = "bundleCoordJobs";
+
+    String SLA_SUMMARY_LIST = "slaSummaryList";
+    String SLA_SUMMARY_ID = "id";
+    String SLA_SUMMARY_PARENT_ID = "parentId";
+    String SLA_SUMMARY_APP_NAME = "appName";
+    String SLA_SUMMARY_APP_TYPE = "appType";
+    String SLA_SUMMARY_USER = "user";
+    String SLA_SUMMARY_NOMINAL_TIME = "nominalTime";
+    String SLA_SUMMARY_EXPECTED_START = "expectedStart";
+    String SLA_SUMMARY_ACTUAL_START = "actualStart";
+    String SLA_SUMMARY_START_DELAY = "startDelay";
+    String SLA_SUMMARY_EXPECTED_END = "expectedEnd";
+    String SLA_SUMMARY_ACTUAL_END = "actualEnd";
+    String SLA_SUMMARY_END_DELAY = "endDelay";
+    String SLA_SUMMARY_EXPECTED_DURATION = "expectedDuration";
+    String SLA_SUMMARY_ACTUAL_DURATION = "actualDuration";
+    String SLA_SUMMARY_DURATION_DELAY = "durationDelay";
+    String SLA_SUMMARY_JOB_STATUS = "jobStatus";
+    String SLA_SUMMARY_SLA_STATUS = "slaStatus";
+    String SLA_SUMMARY_EVENT_STATUS = "eventStatus";
+    String SLA_SUMMARY_LAST_MODIFIED = "lastModified";
+    String SLA_ALERT_STATUS = "slaAlertStatus";
+
+
+    String TO_STRING = "toString";
+
+
+    String ERROR = "error";
+    String ERROR_CODE = "code";
+    String ERROR_MESSAGE = "message";
+
+    String INSTR_TIMERS = "timers";
+    String INSTR_VARIABLES = "variables";
+    String INSTR_SAMPLERS = "samplers";
+    String INSTR_COUNTERS = "counters";
+    String INSTR_DATA = "data";
+
+    String INSTR_GROUP = "group";
+    String INSTR_NAME = "name";
+
+    String INSTR_TIMER_OWN_TIME_AVG = "ownTimeAvg";
+    String INSTR_TIMER_TOTAL_TIME_AVG = "totalTimeAvg";
+    String INSTR_TIMER_TICKS = "ticks";
+    String INSTR_TIMER_OWN_STD_DEV = "ownTimeStdDev";
+    String INSTR_TIMER_TOTAL_STD_DEV = "totalTimeStdDev";
+    String INSTR_TIMER_OWN_MIN_TIME = "ownMinTime";
+    String INSTR_TIMER_OWN_MAX_TIME = "ownMaxTime";
+    String INSTR_TIMER_TOTAL_MIN_TIME = "totalMinTime";
+    String INSTR_TIMER_TOTAL_MAX_TIME = "totalMaxTime";
+
+    String INSTR_VARIABLE_VALUE = "value";
+    String INSTR_SAMPLER_VALUE = "value";
+
+    Object COORDINATOR_JOBS = "coordinatorjobs";
+    Object COORD_JOB_TOTAL = "total";
+    Object COORD_JOB_OFFSET = "offset";
+    Object COORD_JOB_LEN = "len";
+
+    Object BUNDLE_JOBS = "bundlejobs";
+    Object BUNDLE_JOB_TOTAL = "total";
+    Object BUNDLE_JOB_OFFSET = "offset";
+    Object BUNDLE_JOB_LEN = "len";
+
+    String BULK_RESPONSE_BUNDLE = "bulkbundle";
+    String BULK_RESPONSE_COORDINATOR = "bulkcoord";
+    String BULK_RESPONSE_ACTION = "bulkaction";
+    Object BULK_RESPONSES = "bulkresponses";
+    Object BULK_RESPONSE_TOTAL = "total";
+    Object BULK_RESPONSE_OFFSET = "offset";
+    Object BULK_RESPONSE_LEN = "len";
+
+    String AVAILABLE_TIME_ZONES = "available-timezones";
+    String TIME_ZOME_DISPLAY_NAME = "timezoneDisplayName";
+    String TIME_ZONE_ID = "timezoneId";
+
+    String JMS_TOPIC_PATTERN = "jmsTopicPattern";
+    String JMS_JNDI_PROPERTIES = "jmsJNDIProps";
+    String JMS_TOPIC_PREFIX = "jmsTopicPrefix";
+
+    String JMS_TOPIC_NAME = "jmsTopicName";
+    String COORD_UPDATE = RestConstants.JOB_COORD_UPDATE;
+    String COORD_UPDATE_DIFF = "diff";
+
+    String STATUS = "status";
+
+    String VALIDATE = "validate";
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/client/src/main/java/org/apache/oozie/client/rest/RestConstants.java
----------------------------------------------------------------------
diff --git a/client/src/main/java/org/apache/oozie/client/rest/RestConstants.java b/client/src/main/java/org/apache/oozie/client/rest/RestConstants.java
index 3c69319..4129364 100644
--- a/client/src/main/java/org/apache/oozie/client/rest/RestConstants.java
+++ b/client/src/main/java/org/apache/oozie/client/rest/RestConstants.java
@@ -23,196 +23,196 @@ package org.apache.oozie.client.rest;
  */
 public interface RestConstants {
 
-    public static final String VERSIONS = "versions";
+    String VERSIONS = "versions";
 
-    public static final String JOB = "job";
+    String JOB = "job";
 
-    public static final String JOBS = "jobs";
+    String JOBS = "jobs";
 
-    public static final String ADMIN = "admin";
+    String ADMIN = "admin";
 
-    public static final String JSON_CONTENT_TYPE = "application/json";
+    String JSON_CONTENT_TYPE = "application/json";
 
-    public static final String XML_CONTENT_TYPE = "application/xml";
+    String XML_CONTENT_TYPE = "application/xml";
 
-    public static final String FORM_CONTENT_TYPE = "application/x-www-form-urlencoded";
+    String FORM_CONTENT_TYPE = "application/x-www-form-urlencoded";
 
-    public static final String TEXT_CONTENT_TYPE = "text/plain";
+    String TEXT_CONTENT_TYPE = "text/plain";
 
-    public static final String PNG_IMAGE_CONTENT_TYPE = "image/png";
+    String PNG_IMAGE_CONTENT_TYPE = "image/png";
 
-    public static final String ACTION_PARAM = "action";
+    String ACTION_PARAM = "action";
 
-    public static final String OFFSET_PARAM = "offset";
+    String OFFSET_PARAM = "offset";
 
-    public static final String LEN_PARAM = "len";
+    String LEN_PARAM = "len";
 
-    public static final String ORDER_PARAM = "order";
+    String ORDER_PARAM = "order";
 
-    public static final String JOB_FILTER_PARAM = "filter";
+    String JOB_FILTER_PARAM = "filter";
 
-    public static final String JOB_RESOURCE = "/job";
+    String JOB_RESOURCE = "/job";
 
-    public static final String JOB_ACTION_START = "start";
+    String JOB_ACTION_START = "start";
 
-    public static final String JOB_ACTION_DRYRUN = "dryrun";
+    String JOB_ACTION_DRYRUN = "dryrun";
 
-    public static final String JOB_ACTION_SHOWDIFF = "diff";
+    String JOB_ACTION_SHOWDIFF = "diff";
 
-    public static final String JOB_ACTION_SUSPEND = "suspend";
+    String JOB_ACTION_SUSPEND = "suspend";
 
-    public static final String JOB_ACTION_RESUME = "resume";
+    String JOB_ACTION_RESUME = "resume";
 
-    public static final String JOB_ACTION_KILL = "kill";
+    String JOB_ACTION_KILL = "kill";
 
-    public static final String JOB_ACTION_CHANGE = "change";
+    String JOB_ACTION_CHANGE = "change";
 
-    public static final String JOB_CHANGE_VALUE = "value";
+    String JOB_CHANGE_VALUE = "value";
 
-    public static final String JOB_ACTION_RERUN = "rerun";
+    String JOB_ACTION_RERUN = "rerun";
 
-    public static final String JOB_ACTION_IGNORE = "ignore";
+    String JOB_ACTION_IGNORE = "ignore";
 
-    public static final String JOB_COORD_ACTION_RERUN = "coord-rerun";
+    String JOB_COORD_ACTION_RERUN = "coord-rerun";
 
-    public static final String JOB_COORD_UPDATE = "update";
+    String JOB_COORD_UPDATE = "update";
 
-    public static final String JOB_BUNDLE_ACTION_RERUN = "bundle-rerun";
+    String JOB_BUNDLE_ACTION_RERUN = "bundle-rerun";
 
-    public static final String JOB_SHOW_PARAM = "show";
+    String JOB_SHOW_PARAM = "show";
 
-    public static final String JOB_SHOW_CONFIG = "config";
+    String JOB_SHOW_CONFIG = "config";
 
-    public static final String JOB_SHOW_INFO = "info";
+    String JOB_SHOW_INFO = "info";
 
-    public static final String JOB_SHOW_LOG = "log";
+    String JOB_SHOW_LOG = "log";
 
-    public static final String JOB_SHOW_ERROR_LOG = "errorlog";
+    String JOB_SHOW_ERROR_LOG = "errorlog";
 
-    public static final String JOB_SHOW_AUDIT_LOG = "auditlog";
+    String JOB_SHOW_AUDIT_LOG = "auditlog";
 
-    public static final String JOB_SHOW_DEFINITION = "definition";
+    String JOB_SHOW_DEFINITION = "definition";
 
-    public static final String JOB_SHOW_GRAPH = "graph";
+    String JOB_SHOW_GRAPH = "graph";
 
-    public static final String JOB_SHOW_KILL_PARAM = "show-kill";
+    String JOB_SHOW_KILL_PARAM = "show-kill";
 
-    public static final String JOB_SHOW_STATUS = "status";
+    String JOB_SHOW_STATUS = "status";
 
-    public static final String JOB_BUNDLE_RERUN_COORD_SCOPE_PARAM = "coord-scope";
+    String JOB_BUNDLE_RERUN_COORD_SCOPE_PARAM = "coord-scope";
 
-    public static final String JOB_BUNDLE_RERUN_DATE_SCOPE_PARAM = "date-scope";
+    String JOB_BUNDLE_RERUN_DATE_SCOPE_PARAM = "date-scope";
 
-    public static final String JOB_COORD_RANGE_TYPE_PARAM = "type";
+    String JOB_COORD_RANGE_TYPE_PARAM = "type";
 
-    public static final String JOB_COORD_SCOPE_DATE = "date";
+    String JOB_COORD_SCOPE_DATE = "date";
 
-    public static final String JOB_COORD_SCOPE_ACTION = "action";
+    String JOB_COORD_SCOPE_ACTION = "action";
 
-    public static final String JOB_COORD_SCOPE_PARAM = "scope";
+    String JOB_COORD_SCOPE_PARAM = "scope";
 
-    public static final String JOB_COORD_RERUN_REFRESH_PARAM = "refresh";
+    String JOB_COORD_RERUN_REFRESH_PARAM = "refresh";
 
-    public static final String JOB_COORD_RERUN_NOCLEANUP_PARAM = "nocleanup";
+    String JOB_COORD_RERUN_NOCLEANUP_PARAM = "nocleanup";
 
-    public static final String JOB_LOG_ACTION = "action";
+    String JOB_LOG_ACTION = "action";
 
-    public static final String JOB_LOG_DATE = "date";
+    String JOB_LOG_DATE = "date";
 
-    public static final String JOB_LOG_SCOPE_PARAM = "scope";
+    String JOB_LOG_SCOPE_PARAM = "scope";
 
-    public static final String JOB_LOG_TYPE_PARAM = "type";
+    String JOB_LOG_TYPE_PARAM = "type";
 
-    public static final String JOBS_FILTER_PARAM = "filter";
+    String JOBS_FILTER_PARAM = "filter";
 
-    public static final String JOBS_BULK_PARAM = "bulk";
+    String JOBS_BULK_PARAM = "bulk";
 
-    public static final String JOBS_EXTERNAL_ID_PARAM = "external-id";
+    String JOBS_EXTERNAL_ID_PARAM = "external-id";
 
-    public static final String ADMIN_STATUS_RESOURCE = "status";
+    String ADMIN_STATUS_RESOURCE = "status";
 
-    public static final String ADMIN_SAFE_MODE_PARAM = "safemode";
+    String ADMIN_SAFE_MODE_PARAM = "safemode";
 
-    public static final String ADMIN_SYSTEM_MODE_PARAM = "systemmode";
+    String ADMIN_SYSTEM_MODE_PARAM = "systemmode";
 
-    public static final String ADMIN_LOG_RESOURCE = "log";
+    String ADMIN_LOG_RESOURCE = "log";
 
-    public static final String ADMIN_OS_ENV_RESOURCE = "os-env";
+    String ADMIN_OS_ENV_RESOURCE = "os-env";
 
-    public static final String ADMIN_JAVA_SYS_PROPS_RESOURCE = "java-sys-properties";
+    String ADMIN_JAVA_SYS_PROPS_RESOURCE = "java-sys-properties";
 
-    public static final String ADMIN_CONFIG_RESOURCE = "configuration";
+    String ADMIN_CONFIG_RESOURCE = "configuration";
 
-    public static final String ADMIN_INSTRUMENTATION_RESOURCE = "instrumentation";
+    String ADMIN_INSTRUMENTATION_RESOURCE = "instrumentation";
 
-    public static final String ADMIN_BUILD_VERSION_RESOURCE = "build-version";
+    String ADMIN_BUILD_VERSION_RESOURCE = "build-version";
 
-    public static final String ADMIN_QUEUE_DUMP_RESOURCE = "queue-dump";
+    String ADMIN_QUEUE_DUMP_RESOURCE = "queue-dump";
 
-    public static final String ADMIN_METRICS_RESOURCE = "metrics";
+    String ADMIN_METRICS_RESOURCE = "metrics";
 
-    public static final String OOZIE_ERROR_CODE = "oozie-error-code";
+    String OOZIE_ERROR_CODE = "oozie-error-code";
 
-    public static final String OOZIE_ERROR_MESSAGE = "oozie-error-message";
+    String OOZIE_ERROR_MESSAGE = "oozie-error-message";
 
-    public static final String JOBTYPE_PARAM = "jobtype";
+    String JOBTYPE_PARAM = "jobtype";
 
-    public static final String SLA_GT_SEQUENCE_ID = "gt-sequence-id";
+    String SLA_GT_SEQUENCE_ID = "gt-sequence-id";
 
-    public static final String MAX_EVENTS = "max-events";
+    String MAX_EVENTS = "max-events";
 
-    public static final String SLA = "sla";
+    String SLA = "sla";
 
-    public static final String DO_AS_PARAM = "doAs";
+    String DO_AS_PARAM = "doAs";
 
-    public static final String TIME_ZONE_PARAM = "timezone";
+    String TIME_ZONE_PARAM = "timezone";
 
-    public static final String ADMIN_TIME_ZONES_RESOURCE = "available-timezones";
+    String ADMIN_TIME_ZONES_RESOURCE = "available-timezones";
 
-    public static final String ADMIN_JMS_INFO = "jmsinfo";
+    String ADMIN_JMS_INFO = "jmsinfo";
 
-    public static final String JOB_SHOW_JMS_TOPIC = "jmstopic";
+    String JOB_SHOW_JMS_TOPIC = "jmstopic";
 
-    public static final String ADMIN_AVAILABLE_OOZIE_SERVERS_RESOURCE = "available-oozie-servers";
+    String ADMIN_AVAILABLE_OOZIE_SERVERS_RESOURCE = "available-oozie-servers";
 
-    public static final String ADMIN_UPDATE_SHARELIB = "update_sharelib";
+    String ADMIN_UPDATE_SHARELIB = "update_sharelib";
 
-    public static final String ADMIN_LIST_SHARELIB = "list_sharelib";
+    String ADMIN_LIST_SHARELIB = "list_sharelib";
 
-    public static final String SHARE_LIB_REQUEST_KEY = "lib";
+    String SHARE_LIB_REQUEST_KEY = "lib";
 
-    public static final String ALL_SERVER_REQUEST = "allservers";
+    String ALL_SERVER_REQUEST = "allservers";
 
-    public static final String ALL_WORKFLOWS_FOR_COORD_ACTION = "allruns";
+    String ALL_WORKFLOWS_FOR_COORD_ACTION = "allruns";
 
-    public static final String LOG_FILTER_OPTION = "logfilter";
+    String LOG_FILTER_OPTION = "logfilter";
 
-    public static final String JOB_COORD_RERUN_FAILED_PARAM = "failed";
+    String JOB_COORD_RERUN_FAILED_PARAM = "failed";
 
-    public static final String SLA_DISABLE_ALERT = "sla-disable";
+    String SLA_DISABLE_ALERT = "sla-disable";
 
-    public static final String SLA_ENABLE_ALERT = "sla-enable";
+    String SLA_ENABLE_ALERT = "sla-enable";
 
-    public static final String SLA_CHANGE = "sla-change";
+    String SLA_CHANGE = "sla-change";
 
-    public static final String SLA_ALERT_RANGE = "sla-alert-range";
+    String SLA_ALERT_RANGE = "sla-alert-range";
 
-    public static final String COORDINATORS_PARAM = "coordinators";
+    String COORDINATORS_PARAM = "coordinators";
 
-    public static final String SLA_NOMINAL_TIME = "sla-nominal-time";
+    String SLA_NOMINAL_TIME = "sla-nominal-time";
 
-    public static final String SLA_SHOULD_START = "sla-should-start";
+    String SLA_SHOULD_START = "sla-should-start";
 
-    public static final String SLA_SHOULD_END = "sla-should-end";
+    String SLA_SHOULD_END = "sla-should-end";
 
-    public static final String SLA_MAX_DURATION = "sla-max-duration";
+    String SLA_MAX_DURATION = "sla-max-duration";
 
-    public static final String JOB_COORD_SCOPE_ACTION_LIST = "action-list";
+    String JOB_COORD_SCOPE_ACTION_LIST = "action-list";
 
-    public static final String VALIDATE = "validate";
+    String VALIDATE = "validate";
 
-    public static final String FILE_PARAM = "file";
+    String FILE_PARAM = "file";
 
-    public static final String USER_PARAM = "user";
+    String USER_PARAM = "user";
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/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 292fb64..c8bd7c2 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
@@ -30,7 +30,7 @@ public interface JsonBean {
      *
      * @return the JSONObject for the bean with GMT time zone.
      */
-    public JSONObject toJSONObject();
+    JSONObject toJSONObject();
     
     /**
      * Return the JSONObject for the bean with the given time zone.
@@ -38,6 +38,6 @@ public interface JsonBean {
      * @param timeZoneId the time zone to use
      * @return the JSONObject for the bean with the given time zone.
      */
-    public JSONObject toJSONObject(String timeZoneId);
+    JSONObject toJSONObject(String timeZoneId);
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/compression/CompressionCodec.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/compression/CompressionCodec.java b/core/src/main/java/org/apache/oozie/compression/CompressionCodec.java
index f25dcc5..1572e5e 100644
--- a/core/src/main/java/org/apache/oozie/compression/CompressionCodec.java
+++ b/core/src/main/java/org/apache/oozie/compression/CompressionCodec.java
@@ -23,11 +23,11 @@ import java.io.IOException;
 
 public interface CompressionCodec {
 
-    public byte[] compressBytes(byte[] header, byte[] data) throws IOException;
+    byte[] compressBytes(byte[] header, byte[] data) throws IOException;
 
-    public byte[] compressString(byte[] header, String data) throws IOException;
+    byte[] compressString(byte[] header, String data) throws IOException;
 
-    public String decompressToString(DataInputStream dais) throws IOException;
+    String decompressToString(DataInputStream dais) throws IOException;
 
-    public byte[] decompressToBytes(DataInputStream dais) throws IOException;
+    byte[] decompressToBytes(DataInputStream dais) throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/coord/input/logic/CoordInputLogicEvaluator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/coord/input/logic/CoordInputLogicEvaluator.java b/core/src/main/java/org/apache/oozie/coord/input/logic/CoordInputLogicEvaluator.java
index c495570..3cca552 100644
--- a/core/src/main/java/org/apache/oozie/coord/input/logic/CoordInputLogicEvaluator.java
+++ b/core/src/main/java/org/apache/oozie/coord/input/logic/CoordInputLogicEvaluator.java
@@ -19,7 +19,7 @@
 package org.apache.oozie.coord.input.logic;
 
 public interface CoordInputLogicEvaluator {
-    public static final String INPUT_LOGIC = "input-logic";
+    String INPUT_LOGIC = "input-logic";
 
 
     /**
@@ -30,7 +30,7 @@ public interface CoordInputLogicEvaluator {
      * @param wait the wait
      * @return the coord input logic evaluator result
      */
-    public CoordInputLogicEvaluatorResult evalInput(String inputDataSet, int min, int wait);
+    CoordInputLogicEvaluatorResult evalInput(String inputDataSet, int min, int wait);
 
     /**
      * Eval combine input.
@@ -40,5 +40,5 @@ public interface CoordInputLogicEvaluator {
      * @param wait the wait
      * @return the coord input logic evaluator result
      */
-    public CoordInputLogicEvaluatorResult evalCombineInput(String[] combineDatasets, int min, int wait);
+    CoordInputLogicEvaluatorResult evalCombineInput(String[] combineDatasets, int min, int wait);
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/dependency/URIHandler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/dependency/URIHandler.java b/core/src/main/java/org/apache/oozie/dependency/URIHandler.java
index 45e23fb..da68b00 100644
--- a/core/src/main/java/org/apache/oozie/dependency/URIHandler.java
+++ b/core/src/main/java/org/apache/oozie/dependency/URIHandler.java
@@ -31,7 +31,7 @@ public interface URIHandler {
      * Type of the dependency. PULL dependencies are those whose availability is determined by
      * polling and PUSH dependencies are those whose availability is known from notifications
      */
-    public enum DependencyType {
+    enum DependencyType {
         PULL,
         PUSH;
     }
@@ -41,28 +41,28 @@ public interface URIHandler {
      *
      * @param conf Configuration for initialization
      */
-    public void init(Configuration conf);
+    void init(Configuration conf);
 
     /**
      * Get the list of uri schemes supported by this URIHandler
      *
      * @return supported list of uri schemes
      */
-    public Set<String> getSupportedSchemes();
+    Set<String> getSupportedSchemes();
 
     /**
      * Get the URIHandler that will be used to handle the supported schemes in launcher
      *
      * @return LauncherURIHandler that handles URI in the launcher
      */
-    public Class<? extends LauncherURIHandler> getLauncherURIHandlerClass();
+    Class<? extends LauncherURIHandler> getLauncherURIHandlerClass();
 
     /**
      * Get list of classes to ship to launcher for LauncherURIHandler
      *
      * @return list of classes to ship to launcher
      */
-    public List<Class<?>> getClassesForLauncher();
+    List<Class<?>> getClassesForLauncher();
 
     /**
      * Get the dependency type of the URI. When the availability of the
@@ -72,7 +72,7 @@ public interface URIHandler {
      *
      * @return dependency type of URI
      */
-    public DependencyType getDependencyType(URI uri) throws URIHandlerException;
+    DependencyType getDependencyType(URI uri) throws URIHandlerException;
 
     /**
      * Register for notifications in case of a push dependency
@@ -84,7 +84,7 @@ public interface URIHandler {
      *
      * @throws URIHandlerException
      */
-    public void registerForNotification(URI uri, Configuration conf, String user, String actionID)
+    void registerForNotification(URI uri, Configuration conf, String user, String actionID)
             throws URIHandlerException;
 
     /**
@@ -93,7 +93,7 @@ public interface URIHandler {
      * @param uri The URI to be removed from missing dependency
      * @param actionID The id of action which was dependent on the uri.
      */
-    public boolean unregisterFromNotification(URI uri, String actionID);
+    boolean unregisterFromNotification(URI uri, String actionID);
 
     /**
      * Get the Context which can be used to access URI of the same scheme and
@@ -107,7 +107,7 @@ public interface URIHandler {
      *
      * @throws URIHandlerException
      */
-    public Context getContext(URI uri, Configuration conf, String user, boolean readOnly) throws URIHandlerException;
+    Context getContext(URI uri, Configuration conf, String user, boolean readOnly) throws URIHandlerException;
 
     /**
      * Check if the dependency identified by the URI is available
@@ -120,7 +120,7 @@ public interface URIHandler {
      *
      * @throws URIHandlerException
      */
-    public boolean exists(URI uri, Context context) throws URIHandlerException;
+    boolean exists(URI uri, Context context) throws URIHandlerException;
 
     /**
      * Check if the dependency identified by the URI is available
@@ -135,7 +135,7 @@ public interface URIHandler {
      *
      * @throws URIHandlerException
      */
-    public boolean exists(URI uri, Configuration conf, String user) throws URIHandlerException;
+    boolean exists(URI uri, Configuration conf, String user) throws URIHandlerException;
 
     /**
      * Delete a URI
@@ -144,7 +144,7 @@ public interface URIHandler {
      * @param context Context to access the URI
      * @throws URIHandlerException
      */
-    public void delete(URI uri, Context context) throws URIHandlerException;
+    void delete(URI uri, Context context) throws URIHandlerException;
 
     /**
      * Delete a URI
@@ -154,7 +154,7 @@ public interface URIHandler {
      * @param user name of the user the URI should be accessed as
      * @throws URIHandlerException
      */
-    public void delete(URI uri, Configuration conf, String user) throws URIHandlerException;
+    void delete(URI uri, Configuration conf, String user) throws URIHandlerException;
 
     /**
      * Get the URI based on the done flag
@@ -166,7 +166,7 @@ public interface URIHandler {
      *
      * @throws URIHandlerException
      */
-    public String getURIWithDoneFlag(String uri, String doneFlag) throws URIHandlerException;
+    String getURIWithDoneFlag(String uri, String doneFlag) throws URIHandlerException;
 
     /**
      * Get the URI path from path which has done flag
@@ -178,7 +178,7 @@ public interface URIHandler {
      *
      * @throws URIHandlerException
      */
-    public String getURIWithoutDoneFlag(String uri, String doneFlag) throws URIHandlerException;
+    String getURIWithoutDoneFlag(String uri, String doneFlag) throws URIHandlerException;
 
 
     /**
@@ -186,12 +186,12 @@ public interface URIHandler {
      * @param uri
      * @throws URIHandlerException
      */
-    public void validate(String uri) throws URIHandlerException;
+    void validate(String uri) throws URIHandlerException;
 
     /**
      * Destroy the URIHandler
      */
-    public void destroy();
+    void destroy();
 
     public static abstract class Context {
 

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/dependency/hcat/HCatDependencyCache.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/dependency/hcat/HCatDependencyCache.java b/core/src/main/java/org/apache/oozie/dependency/hcat/HCatDependencyCache.java
index ab8b1b1..a5a31e4 100644
--- a/core/src/main/java/org/apache/oozie/dependency/hcat/HCatDependencyCache.java
+++ b/core/src/main/java/org/apache/oozie/dependency/hcat/HCatDependencyCache.java
@@ -32,7 +32,7 @@ public interface HCatDependencyCache {
      *
      * @param conf configuration
      */
-    public void init(Configuration conf);
+    void init(Configuration conf);
 
     /**
      * Add a missing partition dependency and the actionID waiting on it
@@ -40,7 +40,7 @@ public interface HCatDependencyCache {
      * @param hcatURI dependency URI
      * @param actionID ID of action which is waiting for the dependency
      */
-    public void addMissingDependency(HCatURI hcatURI, String actionID);
+    void addMissingDependency(HCatURI hcatURI, String actionID);
 
     /**
      * Remove a missing partition dependency associated with a actionID
@@ -49,7 +49,7 @@ public interface HCatDependencyCache {
      * @param actionID ID of action which is waiting for the dependency
      * @return true if successful, else false
      */
-    public boolean removeMissingDependency(HCatURI hcatURI, String actionID);
+    boolean removeMissingDependency(HCatURI hcatURI, String actionID);
 
     /**
      * Get the list of actionIDs waiting for a partition
@@ -57,7 +57,7 @@ public interface HCatDependencyCache {
      * @param hcatURI dependency URI
      * @return list of actionIDs
      */
-    public Collection<String> getWaitingActions(HCatURI hcatURI);
+    Collection<String> getWaitingActions(HCatURI hcatURI);
 
     /**
      * Mark a partition dependency as available
@@ -68,7 +68,7 @@ public interface HCatDependencyCache {
      * @param partitions list of available partitions
      * @return list of actionIDs for which the dependency is now available
      */
-    public Collection<String> markDependencyAvailable(String server, String db, String table, Map<String, String> partitions);
+    Collection<String> markDependencyAvailable(String server, String db, String table, Map<String, String> partitions);
 
     /**
      * Get a list of available dependency URIs for a actionID
@@ -76,7 +76,7 @@ public interface HCatDependencyCache {
      * @param actionID action id
      * @return list of available dependency URIs
      */
-    public Collection<String> getAvailableDependencyURIs(String actionID);
+    Collection<String> getAvailableDependencyURIs(String actionID);
 
     /**
      * Remove the list of available dependency URIs for a actionID once the missing dependencies are processed.
@@ -85,21 +85,21 @@ public interface HCatDependencyCache {
      * @param dependencyURIs set of dependency URIs
      * @return true if successful, else false
      */
-    public boolean removeAvailableDependencyURIs(String actionID, Collection<String> dependencyURIs);
+    boolean removeAvailableDependencyURIs(String actionID, Collection<String> dependencyURIs);
 
     /**
      * Destroy the cache
      */
-    public void destroy();
+    void destroy();
 
     /**
      * Purge stale actions
      */
-    public void removeNonWaitingCoordActions(Set<String> coordActions);
+    void removeNonWaitingCoordActions(Set<String> coordActions);
 
     /**
      * Remove coordAction when all dependencies met
      */
-    public void removeCoordActionWithDependenciesAvailable(String coordAction);
+    void removeCoordActionWithDependenciesAvailable(String coordAction);
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/event/EventQueue.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/event/EventQueue.java b/core/src/main/java/org/apache/oozie/event/EventQueue.java
index 6dbf8c5..67fb0f9 100644
--- a/core/src/main/java/org/apache/oozie/event/EventQueue.java
+++ b/core/src/main/java/org/apache/oozie/event/EventQueue.java
@@ -43,53 +43,53 @@ public interface EventQueue {
      * Initialize the event queue
      * @param conf
      */
-    public void init(Configuration conf);
+    void init(Configuration conf);
 
     /**
      * Add event to queue
      * @param e
      */
-    public void add(Event e);
+    void add(Event e);
 
     /**
      * Fetch events from queue in batch
      * @return events set
      */
-    public List<Event> pollBatch();
+    List<Event> pollBatch();
 
     /**
     * Fetch single event from queue
     * @return event
     */
-   public Event poll();
+   Event poll();
 
     /**
      * Find out if queue is empty
      * @return boolean
      */
-    public boolean isEmpty();
+    boolean isEmpty();
 
     /**
      * Get current queue size
      * @return size
      */
-    public int size();
+    int size();
 
     /**
      * Read topmost event from queue but do not pop from it
      * @return event
      */
-    public Event peek();
+    Event peek();
 
     /**
      * Get the batch size used during polling events
      * @return batchSize
      */
-    public int getBatchSize();
+    int getBatchSize();
 
     /**
      * Clear the events queue
      */
-    public void clear();
+    void clear();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/executor/jpa/JPAExecutor.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/executor/jpa/JPAExecutor.java b/core/src/main/java/org/apache/oozie/executor/jpa/JPAExecutor.java
index f3b71af..038ae21 100644
--- a/core/src/main/java/org/apache/oozie/executor/jpa/JPAExecutor.java
+++ b/core/src/main/java/org/apache/oozie/executor/jpa/JPAExecutor.java
@@ -32,7 +32,7 @@ public interface JPAExecutor<T> {
      *
      * @return the name of the JPA executor.
      */
-    public String getName();
+    String getName();
 
     /**
      * Method that encapsulates JPA access operations.
@@ -45,6 +45,6 @@ public interface JPAExecutor<T> {
      * @return a return value if any.
      * @throws JPAExecutorException thrown if a jpa executor failed
      */
-    public T execute(EntityManager em) throws JPAExecutorException;
+    T execute(EntityManager em) throws JPAExecutorException;
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/jms/ConnectionContext.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/jms/ConnectionContext.java b/core/src/main/java/org/apache/oozie/jms/ConnectionContext.java
index a07edfa..6794569 100644
--- a/core/src/main/java/org/apache/oozie/jms/ConnectionContext.java
+++ b/core/src/main/java/org/apache/oozie/jms/ConnectionContext.java
@@ -38,21 +38,21 @@ public interface ConnectionContext {
      * @param props the properties used for creating jndi context
      * @throws JMSException
      */
-    public void createConnection(Properties props) throws NamingException, JMSException;
+    void createConnection(Properties props) throws NamingException, JMSException;
 
     /**
      * Set the exception Listener
      *
      * @param exceptionListener
      */
-    public void setExceptionListener(ExceptionListener exceptionListener) throws JMSException;
+    void setExceptionListener(ExceptionListener exceptionListener) throws JMSException;
 
     /**
      * Checks whether connection is initialized or not
      *
      * @return
      */
-    public boolean isConnectionInitialized();
+    boolean isConnectionInitialized();
 
     /**
      * Creates session using the specified session opts
@@ -61,7 +61,7 @@ public interface ConnectionContext {
      * @return
      * @throws JMSException
      */
-    public Session createSession(int sessionOpts) throws JMSException;
+    Session createSession(int sessionOpts) throws JMSException;
 
     /**
      * Creates consumer using session and topic name
@@ -71,7 +71,7 @@ public interface ConnectionContext {
      * @return
      * @throws JMSException
      */
-    public MessageConsumer createConsumer(Session session, String topicName) throws JMSException;
+    MessageConsumer createConsumer(Session session, String topicName) throws JMSException;
 
     /**
      * Creates consumer using session, topic name and selector
@@ -81,7 +81,7 @@ public interface ConnectionContext {
      * @return
      * @throws JMSException
      */
-    public MessageConsumer createConsumer(Session session, String topicName, String selector) throws JMSException;
+    MessageConsumer createConsumer(Session session, String topicName, String selector) throws JMSException;
 
     /**
      * Creates producer using session and topic
@@ -91,7 +91,7 @@ public interface ConnectionContext {
      * @return
      * @throws JMSException
      */
-    public MessageProducer createProducer(Session session, String topicName) throws JMSException;
+    MessageProducer createProducer(Session session, String topicName) throws JMSException;
 
     /**
      * Creates a threadlocal session using session opts
@@ -100,11 +100,11 @@ public interface ConnectionContext {
      * @return
      * @throws JMSException
      */
-    public Session createThreadLocalSession(final int sessionOpts) throws JMSException;
+    Session createThreadLocalSession(final int sessionOpts) throws JMSException;
 
     /**
      * Closes the connection
      */
-    public void close();
+    void close();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/jms/MessageHandler.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/jms/MessageHandler.java b/core/src/main/java/org/apache/oozie/jms/MessageHandler.java
index 5b766f7..ead936b 100644
--- a/core/src/main/java/org/apache/oozie/jms/MessageHandler.java
+++ b/core/src/main/java/org/apache/oozie/jms/MessageHandler.java
@@ -26,5 +26,5 @@ public interface MessageHandler {
      *
      * @param msg : to be processed
      */
-    public void process(Message msg);
+    void process(Message msg);
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/service/Service.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/service/Service.java b/core/src/main/java/org/apache/oozie/service/Service.java
index 4e9c921..a165f72 100644
--- a/core/src/main/java/org/apache/oozie/service/Service.java
+++ b/core/src/main/java/org/apache/oozie/service/Service.java
@@ -22,12 +22,12 @@ package org.apache.oozie.service;
  * A service is component managed by the {@link Services} singleton.
  */
 public interface Service {
-    public static final String DEFAULT_LOCK_TIMEOUT = "oozie.service.default.lock.timeout";
+    String DEFAULT_LOCK_TIMEOUT = "oozie.service.default.lock.timeout";
 
     /**
      * Prefix for all services configuration properties.
      */
-    public static final String CONF_PREFIX = "oozie.service.";
+    String CONF_PREFIX = "oozie.service.";
 
     /**
      * Initialize the service. <p> Invoked by the {@link Service} singleton at start up time.
@@ -35,12 +35,12 @@ public interface Service {
      * @param services services singleton initializing the service.
      * @throws ServiceException thrown if the service could not initialize.
      */
-    public void init(Services services) throws ServiceException;
+    void init(Services services) throws ServiceException;
 
     /**
      * Destroy the service. <p> Invoked by the {@link Service} singleton at shutdown time.
      */
-    public void destroy();
+    void destroy();
 
     /**
      * Return the public interface of the service. <p> Services are retrieved by its public interface. Specializations
@@ -48,11 +48,11 @@ public interface Service {
      *
      * @return the interface of the service.
      */
-    public Class<? extends Service> getInterface();
+    Class<? extends Service> getInterface();
 
     /**
      * Lock timeout value if service is only allowed to have one single running instance.
      */
-    public static long lockTimeout = ConfigurationService.getLong(DEFAULT_LOCK_TIMEOUT);
+    long lockTimeout = ConfigurationService.getLong(DEFAULT_LOCK_TIMEOUT);
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/sla/SLACalculator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/sla/SLACalculator.java b/core/src/main/java/org/apache/oozie/sla/SLACalculator.java
index 8949515..146cdcb 100644
--- a/core/src/main/java/org/apache/oozie/sla/SLACalculator.java
+++ b/core/src/main/java/org/apache/oozie/sla/SLACalculator.java
@@ -103,6 +103,6 @@ public interface SLACalculator {
      * @throws JPAExecutorException the JPA executor exception
      * @throws ServiceException the service exception
      */
-    public boolean changeDefinition(List<Pair<String, Map<String,String>>> jobIdsSLAPair ) throws JPAExecutorException,
+    boolean changeDefinition(List<Pair<String, Map<String,String>>> jobIdsSLAPair ) throws JPAExecutorException,
             ServiceException;
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/util/Instrumentable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/Instrumentable.java b/core/src/main/java/org/apache/oozie/util/Instrumentable.java
index b425afa..36ad11a 100644
--- a/core/src/main/java/org/apache/oozie/util/Instrumentable.java
+++ b/core/src/main/java/org/apache/oozie/util/Instrumentable.java
@@ -29,6 +29,6 @@ public interface Instrumentable {
      *
      * @param instr system instrumentation.
      */
-    public void instrument(Instrumentation instr);
+    void instrument(Instrumentation instr);
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/util/XCallable.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/util/XCallable.java b/core/src/main/java/org/apache/oozie/util/XCallable.java
index baf47cf..2c034a4 100644
--- a/core/src/main/java/org/apache/oozie/util/XCallable.java
+++ b/core/src/main/java/org/apache/oozie/util/XCallable.java
@@ -32,14 +32,14 @@ public interface XCallable<T> extends Callable<T> {
      *
      * @return the callable name.
      */
-    public String getName();
+    String getName();
 
     /**
      * Return the priority of the callable.
      *
      * @return the callable priority.
      */
-    public int getPriority();
+    int getPriority();
 
     /**
      * Return the callable type. <p> The callable type is used for concurrency throttling in the {@link
@@ -47,39 +47,39 @@ public interface XCallable<T> extends Callable<T> {
      *
      * @return the callable type.
      */
-    public String getType();
+    String getType();
 
     /**
      * Returns the createdTime of the callable in milliseconds
      *
      * @return the callable createdTime
      */
-    public long getCreatedTime();
+    long getCreatedTime();
 
     /**
      * Return the key of the callable
      *
      * @return the callable key
      */
-    public String getKey();
+    String getKey();
 
     /**
      * Return the lock key of the callable
      *
      * @return the callable Lock key
      */
-    public String getEntityKey();
+    String getEntityKey();
 
     /**
      * set the mode of execution for the callable. True if in interrupt, false
      * if not
      */
-    public void setInterruptMode(boolean mode);
+    void setInterruptMode(boolean mode);
 
     /**
      * @return the mode of execution. true if it is executed as an Interrupt,
      *         false otherwise
      */
-    public boolean inInterruptMode();
+    boolean inInterruptMode();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/workflow/WorkflowApp.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/workflow/WorkflowApp.java b/core/src/main/java/org/apache/oozie/workflow/WorkflowApp.java
index a09bd12..203b3db 100644
--- a/core/src/main/java/org/apache/oozie/workflow/WorkflowApp.java
+++ b/core/src/main/java/org/apache/oozie/workflow/WorkflowApp.java
@@ -28,12 +28,12 @@ public interface WorkflowApp {
      *
      * @return the name of teh workflow application.
      */
-    public String getName();
+    String getName();
 
     /**
      * Return the original workflow definition (normally XML).
      *
      * @return the original workflow definition (normally XML).
      */
-    public String getDefinition();
+    String getDefinition();
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/workflow/WorkflowInstance.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/workflow/WorkflowInstance.java b/core/src/main/java/org/apache/oozie/workflow/WorkflowInstance.java
index e91079c..9313642 100644
--- a/core/src/main/java/org/apache/oozie/workflow/WorkflowInstance.java
+++ b/core/src/main/java/org/apache/oozie/workflow/WorkflowInstance.java
@@ -32,12 +32,12 @@ public interface WorkflowInstance {
      * Separator to qualify variables belonging to a node. <p> Variables names should be compossed as <code>nodeName +
      * {@link #NODE_VAR_SEPARATOR} + varName</code>.
      */
-    public final static String NODE_VAR_SEPARATOR = "#";
+    String NODE_VAR_SEPARATOR = "#";
 
     /**
      * Defines the possible stati of a {@link WorkflowInstance}.
      */
-    public static enum Status {
+    enum Status {
         PREP(false),
         RUNNING(false),
         SUSPENDED(false),
@@ -67,28 +67,28 @@ public interface WorkflowInstance {
      *
      * @return the configuration of the instance.
      */
-    public Configuration getConf();
+    Configuration getConf();
 
     /**
      * Return the ID of the instance.
      *
      * @return the ID of the instance.
      */
-    public String getId();
+    String getId();
 
     /**
      * Return the workflow application that defines the instance.
      *
      * @return the workflow application that defines the instance.
      */
-    public WorkflowApp getApp();
+    WorkflowApp getApp();
 
     /**
      * Start the instance.
      *
      * @throws WorkflowException thrown if the instance could not be started.
      */
-    public boolean start() throws WorkflowException;
+    boolean start() throws WorkflowException;
 
     /**
      * Signal the instance that a node has completed.
@@ -97,7 +97,7 @@ public interface WorkflowInstance {
      * @param signaValue signal value for the node.
      * @return <code>true</code> if the instance has completed its execution, <code>false</code> otherwise.
      */
-    public boolean signal(String path, String signaValue) throws WorkflowException;
+    boolean signal(String path, String signaValue) throws WorkflowException;
 
     /**
      * Fail the instance. <p> All executing nodes will be be signaled for fail.
@@ -105,35 +105,35 @@ public interface WorkflowInstance {
      * @param nodeName the name of the node to be failed.
      * @throws WorkflowException thrown if the instance could not be failed.
      */
-    public void fail(String nodeName) throws WorkflowException;
+    void fail(String nodeName) throws WorkflowException;
 
     /**
      * Kill the instance. <p> All executing nodes will be be signaled for kill.
      *
      * @throws WorkflowException thrown if the instance could not be killed.
      */
-    public void kill() throws WorkflowException;
+    void kill() throws WorkflowException;
 
     /**
      * Suspend the instance.
      *
      * @throws WorkflowException thrown if the instance could not be suspended.
      */
-    public void suspend() throws WorkflowException;
+    void suspend() throws WorkflowException;
 
     /**
      * Resume the instance.
      *
      * @throws WorkflowException thrown if the instance could not be resume.
      */
-    public void resume() throws WorkflowException;
+    void resume() throws WorkflowException;
 
     /**
      * Return the current status of the instance.
      *
      * @return the current status of the instance.
      */
-    public Status getStatus();
+    Status getStatus();
 
     /**
      * Set a variable in the context of the instance. <p> Variables are persisted with the instance.
@@ -141,7 +141,7 @@ public interface WorkflowInstance {
      * @param name variable name.
      * @param value variable value, setting a <code>null</code> value removes the variable.
      */
-    public void setVar(String name, String value);
+    void setVar(String name, String value);
 
     /**
      * Return a variable from the context of the instance.
@@ -149,21 +149,21 @@ public interface WorkflowInstance {
      * @param name name of the variable.
      * @return variable value, <code>null</code> if the variable is not in the context.
      */
-    public String getVar(String name);
+    String getVar(String name);
 
     /**
      * Return a map with all the variables in the context of the instance.
      *
      * @return a map with all the variables in the context of the instance.
      */
-    public Map<String, String> getAllVars();
+    Map<String, String> getAllVars();
 
     /**
      * Add a set of variables in the context of the instance. <p> Variables are persisted with the instance.
      *
      * @param varMap map with the variables to add.
      */
-    public void setAllVars(Map<String, String> varMap);
+    void setAllVars(Map<String, String> varMap);
 
     /**
      * Set a transient variable in the context of the instance. <p> Transient variables are not persisted with the
@@ -172,7 +172,7 @@ public interface WorkflowInstance {
      * @param name transient variable name.
      * @param value transient variable value, setting a <code>null</code> value removes the variable.
      */
-    public void setTransientVar(String name, Object value);
+    void setTransientVar(String name, Object value);
 
     /**
      * Return a transient variable from the context of the instance.
@@ -180,7 +180,7 @@ public interface WorkflowInstance {
      * @param name name of the transient variable.
      * @return transient variable value, <code>null</code> if the variable is not in the context.
      */
-    public Object getTransientVar(String name);
+    Object getTransientVar(String name);
 
     /**
      * Return the transition a node did. <p> This is meaninful only for action and decision nodes.
@@ -188,13 +188,13 @@ public interface WorkflowInstance {
      * @param node the node name.
      * @return the transition the node did, <code>null</code> if the node didn't execute yet.
      */
-    public String getTransition(String node);
+    String getTransition(String node);
 
     /**
      * Get NodeDef from workflow instance
      * @param executionPath execution path
      * @return node def
      */
-    public NodeDef getNodeDef(String executionPath);
+    NodeDef getNodeDef(String executionPath);
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/core/src/main/java/org/apache/oozie/workflow/WorkflowLib.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/oozie/workflow/WorkflowLib.java b/core/src/main/java/org/apache/oozie/workflow/WorkflowLib.java
index 58ff823..f7f1057 100644
--- a/core/src/main/java/org/apache/oozie/workflow/WorkflowLib.java
+++ b/core/src/main/java/org/apache/oozie/workflow/WorkflowLib.java
@@ -39,7 +39,7 @@ public interface WorkflowLib {
      * @return the parse workflow application.
      * @throws WorkflowException thrown if the definition could not be parsed.
      */
-    public WorkflowApp parseDef(String wfXml, Configuration jobConf, Configuration configDefault)
+    WorkflowApp parseDef(String wfXml, Configuration jobConf, Configuration configDefault)
             throws WorkflowException;
 
     /**
@@ -50,7 +50,7 @@ public interface WorkflowLib {
      * @return the newly created workflow instance.
      * @throws WorkflowException thrown if the instance could not be created.
      */
-    public WorkflowInstance createInstance(WorkflowApp app, Configuration conf) throws WorkflowException;
+    WorkflowInstance createInstance(WorkflowApp app, Configuration conf) throws WorkflowException;
 
     /**
      * Create a workflow instance with the given wfId and actions endtime map. This will be used for re-running workflows.
@@ -61,7 +61,7 @@ public interface WorkflowLib {
      * @return the newly created workflow instance.
      * @throws WorkflowException thrown if the instance could not be created.
      */
-    public WorkflowInstance createInstance(WorkflowApp app, Configuration conf, String wfId)
+    WorkflowInstance createInstance(WorkflowApp app, Configuration conf, String wfId)
             throws WorkflowException;
 
     /**
@@ -70,7 +70,7 @@ public interface WorkflowLib {
      * @param instance of the workflow instance to insert.
      * @throws WorkflowException thrown if the instance could not be inserted.
      */
-    public void insert(WorkflowInstance instance) throws WorkflowException;
+    void insert(WorkflowInstance instance) throws WorkflowException;
 
     /**
      * Load a workflow instance from storage.
@@ -79,7 +79,7 @@ public interface WorkflowLib {
      * @return the loaded workflow instance.
      * @throws WorkflowException thrown if the instance could not be loaded.
      */
-    public WorkflowInstance get(String id) throws WorkflowException;
+    WorkflowInstance get(String id) throws WorkflowException;
 
     /**
      * Update a workflow instance in storage.
@@ -87,7 +87,7 @@ public interface WorkflowLib {
      * @param instance workflow instance to update.
      * @throws WorkflowException thrown if the instance could not be loaded.
      */
-    public void update(WorkflowInstance instance) throws WorkflowException;
+    void update(WorkflowInstance instance) throws WorkflowException;
 
     /**
      * Delete a workflow instance from storage.
@@ -95,7 +95,7 @@ public interface WorkflowLib {
      * @param id ID of the workflow instance to delete.
      * @throws WorkflowException thrown if the instance could not be deleted.
      */
-    public void delete(String id) throws WorkflowException;
+    void delete(String id) throws WorkflowException;
 
 
     /**
@@ -103,13 +103,13 @@ public interface WorkflowLib {
      *
      * @throws WorkflowException thrown if the commit could not be done.
      */
-    public void commit() throws WorkflowException;
+    void commit() throws WorkflowException;
 
     /**
      * Close store. It rollbacks if there was no commit.
      *
      * @throws WorkflowException thrown if the close could not be done.
      */
-    public void close() throws WorkflowException;
+    void close() throws WorkflowException;
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/release-log.txt
----------------------------------------------------------------------
diff --git a/release-log.txt b/release-log.txt
index 326642a..500eaea 100644
--- a/release-log.txt
+++ b/release-log.txt
@@ -1,5 +1,6 @@
 -- Oozie 4.3.0 release (trunk - unreleased)
 
+OOZIE-2657 Clean up redundant access modifiers from oozie interfaces (abhishekbafna via jaydeepvishwakarma)
 OOZIE-2517 Add support for startCreatedTime and endCreatedTime filters for coord and bundles (abhishekbafna via jaydeepvishwakarma)
 OOZIE-2589 CompletedActionXCommand is hardcoded to wrong priority (tm_linfly via rkanter)
 OOZIE-2081 WorkflowJob notification to include coordinator action id (seoeun25 via rkanter)

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/LauncherURIHandler.java
----------------------------------------------------------------------
diff --git a/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/LauncherURIHandler.java b/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/LauncherURIHandler.java
index 1dd164f..ec6ee00 100644
--- a/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/LauncherURIHandler.java
+++ b/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/LauncherURIHandler.java
@@ -36,7 +36,7 @@ public interface LauncherURIHandler {
      *
      * @throws LauncherException
      */
-    public boolean create(URI uri, Configuration conf) throws LauncherException;
+    boolean create(URI uri, Configuration conf) throws LauncherException;
 
     /**
      * Delete the resource identified by the URI
@@ -48,7 +48,7 @@ public interface LauncherURIHandler {
      *         <code>false</code> if the URI does not exist
      * @throws LauncherException
      */
-    public boolean delete(URI uri, Configuration conf) throws LauncherException;
+    boolean delete(URI uri, Configuration conf) throws LauncherException;
 
 
     /**
@@ -56,6 +56,6 @@ public interface LauncherURIHandler {
      *
      * @return list of classes to ship to launcher
      */
-    public List<Class<?>> getClassesForLauncher();
+    List<Class<?>> getClassesForLauncher();
 
 }

http://git-wip-us.apache.org/repos/asf/oozie/blob/4c88e29e/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/OozieActionConfigurator.java
----------------------------------------------------------------------
diff --git a/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/OozieActionConfigurator.java b/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/OozieActionConfigurator.java
index 46ae700..c2a100e 100644
--- a/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/OozieActionConfigurator.java
+++ b/sharelib/oozie/src/main/java/org/apache/oozie/action/hadoop/OozieActionConfigurator.java
@@ -33,5 +33,5 @@ public interface OozieActionConfigurator {
      * @param actionConf The action configuration
      * @throws OozieActionConfiguratorException
      */
-    public void configure(JobConf actionConf) throws OozieActionConfiguratorException;
+    void configure(JobConf actionConf) throws OozieActionConfiguratorException;
 }